A B C D E F G H I J K L M N O P Q R S T U V W X Y _
All Classes All Packages
All Classes All Packages
A
- A - Variable in class org.apache.lucene.spatial.geometry.shape.LineSegment
-
Deprecated.
- abort() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexWriter
-
Deprecated.
- ABSOLUTE_MIN_SORT_BUFFER_SIZE - Static variable in class org.apache.lucene.search.suggest.fst.Sort
-
Absolute minimum required buffer size for sorting.
- AbstractAllGroupHeadsCollector<GH extends AbstractAllGroupHeadsCollector.GroupHead> - Class in org.apache.lucene.search.grouping
-
This collector specializes in collecting the most relevant document (group head) for each group that match the query.
- AbstractAllGroupHeadsCollector(int) - Constructor for class org.apache.lucene.search.grouping.AbstractAllGroupHeadsCollector
- AbstractAllGroupHeadsCollector.GroupHead<GROUP_VALUE_TYPE> - Class in org.apache.lucene.search.grouping
-
Represents a group head.
- AbstractAllGroupHeadsCollector.TemporalResult - Class in org.apache.lucene.search.grouping
-
Contains the result of group head retrieval.
- AbstractAllGroupsCollector<GROUP_VALUE_TYPE> - Class in org.apache.lucene.search.grouping
-
A collector that collects all groups that match the query.
- AbstractAllGroupsCollector() - Constructor for class org.apache.lucene.search.grouping.AbstractAllGroupsCollector
- AbstractAllTermDocs - Class in org.apache.lucene.index
-
Base class for enumerating all but deleted docs.
- AbstractAllTermDocs(int) - Constructor for class org.apache.lucene.index.AbstractAllTermDocs
- AbstractEncoder - Class in org.apache.lucene.analysis.payloads
-
Base class for payload encoders.
- AbstractEncoder() - Constructor for class org.apache.lucene.analysis.payloads.AbstractEncoder
- AbstractField - Class in org.apache.lucene.document
-
Base class for Field implementations
- AbstractField() - Constructor for class org.apache.lucene.document.AbstractField
- AbstractField(String, Field.Store, Field.Index, Field.TermVector) - Constructor for class org.apache.lucene.document.AbstractField
- AbstractFirstPassGroupingCollector<GROUP_VALUE_TYPE> - Class in org.apache.lucene.search.grouping
-
FirstPassGroupingCollector is the first of two passes necessary to collect grouped hits.
- AbstractFirstPassGroupingCollector(Sort, int) - Constructor for class org.apache.lucene.search.grouping.AbstractFirstPassGroupingCollector
-
Create the first pass collector.
- AbstractQueryConfig - Class in org.apache.lucene.queryParser.core.config
-
This class is the base of
QueryConfigHandler
andFieldConfig
. - 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.standard.nodes
-
This class should be extended by nodes intending to represent range queries.
- AbstractRangeQueryNode() - Constructor for class org.apache.lucene.queryParser.standard.nodes.AbstractRangeQueryNode
-
Constructs an
AbstractRangeQueryNode
, it should be invoked only by its extenders. - AbstractSecondPassGroupingCollector<GROUP_VALUE_TYPE> - Class in org.apache.lucene.search.grouping
-
SecondPassGroupingCollector is the second of two passes necessary to collect grouped docs.
- AbstractSecondPassGroupingCollector(Collection<SearchGroup<GROUP_VALUE_TYPE>>, Sort, Sort, int, boolean, boolean, boolean) - Constructor for class org.apache.lucene.search.grouping.AbstractSecondPassGroupingCollector
- AbstractSecondPassGroupingCollector.SearchGroupDocs<GROUP_VALUE_TYPE> - Class in org.apache.lucene.search.grouping
- accept() - Method in class org.apache.lucene.analysis.FilteringTokenFilter
-
Override this method and return if the current input token should be returned by
FilteringTokenFilter.incrementToken()
. - accept() - Method in class org.apache.lucene.analysis.ja.JapanesePartOfSpeechStopFilter
- accept() - Method in class org.apache.lucene.analysis.LengthFilter
- accept() - Method in class org.apache.lucene.analysis.StopFilter
-
Returns the next input Token whose term() is not a stop word.
- accept() - Method in class org.apache.lucene.analysis.TypeTokenFilter
-
By default accept the token if its type is not a stop type.
- accept(File, String) - Method in class org.apache.lucene.index.IndexFileNameFilter
- accept(String) - Method in interface org.apache.lucene.document.FieldSelector
- accept(String) - Method in class org.apache.lucene.document.LoadFirstFieldSelector
- accept(String) - Method in class org.apache.lucene.document.MapFieldSelector
-
Load field according to its associated value in fieldSelections
- accept(String) - Method in class org.apache.lucene.document.SetBasedFieldSelector
-
Indicate whether to load the field with the given name or not.
- accept(IndexReader, int, String, TermVectorMapper) - Method in class org.apache.lucene.index.TermVectorAccessor
-
Visits the TermVectorMapper and populates it with terms available for a given document, either via a vector created at index time or by resolving them from the inverted index.
- accept(AttributeSource) - Method in class org.apache.lucene.analysis.sinks.DateRecognizerSinkFilter
- accept(AttributeSource) - Method in class org.apache.lucene.analysis.sinks.TokenRangeSinkFilter
- accept(AttributeSource) - Method in class org.apache.lucene.analysis.sinks.TokenTypeSinkFilter
- accept(AttributeSource) - Method in class org.apache.lucene.analysis.TeeSinkTokenFilter.SinkFilter
-
Returns true, iff the current state of the passed-in
AttributeSource
shall be stored in the sink. - acceptPosition(Spans) - Method in class org.apache.lucene.search.spans.SpanFirstQuery
- acceptPosition(Spans) - Method in class org.apache.lucene.search.spans.SpanNearPayloadCheckQuery
- acceptPosition(Spans) - Method in class org.apache.lucene.search.spans.SpanPayloadCheckQuery
- acceptPosition(Spans) - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery
-
Implementing classes are required to return whether the current position is a match for the passed in "match"
SpanQuery
. - acceptPosition(Spans) - Method in class org.apache.lucene.search.spans.SpanPositionRangeQuery
- acceptsDocsOutOfOrder() - Method in class org.apache.lucene.facet.search.FacetsCollector
- acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.CachingCollector
- acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.CheckHits.ExplanationAsserter
- acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.CheckHits.SetCollector
- acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.Collector
-
Return
true
if this collector does not require the matching docIDs to be delivered in int sort order (smallest to largest) toCollector.collect(int)
. - acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.grouping.AbstractAllGroupHeadsCollector
- acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.grouping.AbstractAllGroupsCollector
- acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.grouping.AbstractFirstPassGroupingCollector
- acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.grouping.AbstractSecondPassGroupingCollector
- acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.grouping.BlockGroupingCollector
- acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.join.ToParentBlockJoinCollector
- acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.MultiCollector
- acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.PositiveScoresOnlyCollector
- acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.TimeLimitingCollector
- acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.TopFieldCollector
- acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.TotalHitCountCollector
- accumulate(ScoredDocIDs) - Method in class org.apache.lucene.facet.search.AdaptiveFacetsAccumulator
- accumulate(ScoredDocIDs) - Method in class org.apache.lucene.facet.search.FacetsAccumulator
-
Accumulate facets over given documents, according to facet requests in effect.
- accumulate(ScoredDocIDs) - Method in class org.apache.lucene.facet.search.sampling.SamplingAccumulator
- accumulate(ScoredDocIDs) - Method in class org.apache.lucene.facet.search.SamplingWrapper
- accumulate(ScoredDocIDs) - Method in class org.apache.lucene.facet.search.StandardFacetsAccumulator
- 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 - acquireWriteLock() - Method in class org.apache.lucene.index.IndexReader
-
Deprecated.Write support will be removed in Lucene 4.0.
- ACRONYM - Static variable in class org.apache.lucene.analysis.standard.ClassicTokenizer
- ACRONYM - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
-
Deprecated.
- ACRONYM_DEP - Static variable in class org.apache.lucene.analysis.standard.ClassicTokenizer
-
Deprecated.this solves a bug where HOSTs that end with '.' are identified as ACRONYMs.
- ACRONYM_DEP - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
-
Deprecated.this solves a bug where HOSTs that end with '.' are identified as ACRONYMs.
- ACRONYM_ID - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
- actualDocsToAccumulate(ScoredDocIDs) - Method in class org.apache.lucene.facet.search.sampling.SamplingAccumulator
- actualDocsToAccumulate(ScoredDocIDs) - Method in class org.apache.lucene.facet.search.StandardFacetsAccumulator
-
Set the actual set of documents over which accumulation should take place.
- actualEnum - Variable in class org.apache.lucene.search.FilteredTermEnum
-
the delegate enum - to set this member use
FilteredTermEnum.setEnum(org.apache.lucene.index.TermEnum)
- actualSampleRatio - Variable in class org.apache.lucene.facet.search.sampling.Sampler.SampleResult
- AdaptiveFacetsAccumulator - Class in org.apache.lucene.facet.search
-
FacetsAccumulator
whose behavior regarding complements, sampling, etc. - AdaptiveFacetsAccumulator(FacetSearchParams, IndexReader, TaxonomyReader) - Constructor for class org.apache.lucene.facet.search.AdaptiveFacetsAccumulator
-
Create an
AdaptiveFacetsAccumulator
- AdaptiveFacetsAccumulator(FacetSearchParams, IndexReader, TaxonomyReader, IntArrayAllocator, FloatArrayAllocator) - Constructor for class org.apache.lucene.facet.search.AdaptiveFacetsAccumulator
-
Create an
AdaptiveFacetsAccumulator
- add(char[]) - Method in class org.apache.lucene.analysis.CharArraySet
-
Add this char[] directly to the set.
- add(int) - Method in class org.apache.lucene.util.collections.IntHashSet
-
Add a mapping int key -> int 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, IndexReader) - Method in class org.apache.lucene.util.ReaderUtil.Gather
- add(int, QueryNodeProcessor) - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorPipeline
- add(long) - Method in class org.apache.lucene.util.packed.PackedInts.Writer
- add(E) - Method in class org.apache.lucene.util.MapBackedSet
- add(Reader) - Method in class org.apache.lucene.analysis.synonym.SolrSynonymParser
- add(Reader) - Method in class org.apache.lucene.analysis.synonym.WordnetSynonymParser
- add(CharSequence) - Method in class org.apache.lucene.analysis.CharArraySet
-
Add this CharSequence into the set
- add(CharSequence) - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
-
Add the given component to the end of the path.
- add(CharSequence, char) - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
-
Add the given components to the end of the path.
- 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.
- add(CharSequence, CharSequence) - Method in class org.egothor.stemmer.Trie
-
Add the given key associated with the given patch command.
- add(CharSequence, Object) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellLookup
- add(CharSequence, Object) - Method in class org.apache.lucene.search.suggest.tst.TSTLookup
- add(Long, Long) - Method in class org.apache.lucene.util.fst.PositiveIntOutputs
- add(Object) - Method in class org.apache.lucene.analysis.CharArraySet
- add(Object, Object) - Method in class org.apache.lucene.util.fst.NoOutputs
- add(Object, Object) - Method in class org.apache.lucene.util.fst.UpToTwoPositiveIntOutputs
- add(String) - Method in class org.apache.lucene.analysis.CharArraySet
-
Add this String into the set
- add(String, boolean) - Method in class org.apache.lucene.index.FieldInfos
-
Calls 5 parameter add with false for all TermVector parameters.
- add(String, boolean, boolean) - Method in class org.apache.lucene.index.FieldInfos
-
Calls 5 parameter add with false for term vector positions and offsets.
- add(String, boolean, boolean, boolean) - Method in class org.apache.lucene.index.FieldInfos
-
If the field is not yet known, adds it.
- add(String, boolean, boolean, boolean, boolean, FieldInfo.IndexOptions) - Method in class org.apache.lucene.index.FieldInfos
-
If the field is not yet known, adds it.
- add(String, String) - Method in class org.apache.lucene.analysis.NormalizeCharMap
-
Records a replacement to be applied to the inputs stream.
- add(String, ParserExtension) - Method in class org.apache.lucene.queryParser.ext.Extensions
-
Adds a new
ParserExtension
instance associated with the given key. - add(Collection<Query>) - Method in class org.apache.lucene.search.DisjunctionMaxQuery
-
Add a collection of disjuncts to this disjunction via Iterable
- add(List<QueryNode>) - Method in interface org.apache.lucene.queryParser.core.nodes.QueryNode
- add(List<QueryNode>) - Method in class org.apache.lucene.queryParser.core.nodes.QueryNodeImpl
- add(TaskStats) - Method in class org.apache.lucene.benchmark.byTask.stats.TaskStats
-
Add data from another stat, for aggregation
- add(Document) - Method in class org.apache.lucene.index.FieldInfos
-
Adds field info for a Document.
- add(Fieldable) - Method in class org.apache.lucene.document.Document
-
Adds a field to a document.
- add(FieldInfo) - Method in class org.apache.lucene.index.FieldInfos
- add(FieldInfos) - Method in class org.apache.lucene.index.FieldInfos
- add(IndexReader) - Method in class org.apache.lucene.index.ParallelReader
-
Add an IndexReader.
- add(IndexReader, boolean) - Method in class org.apache.lucene.index.ParallelReader
-
Add an IndexReader whose stored fields will not be returned.
- add(MergePolicy.OneMerge) - Method in class org.apache.lucene.index.MergePolicy.MergeSpecification
- add(SegmentInfo) - Method in class org.apache.lucene.index.SegmentInfos
- add(Term) - Method in class org.apache.lucene.search.MultiPhraseQuery
-
Add a single term at the next position in the phrase.
- add(Term) - Method in class org.apache.lucene.search.PhraseQuery
-
Adds a term to the end of the query phrase.
- add(Term[]) - Method in class org.apache.lucene.search.MultiPhraseQuery
-
Add multiple terms at the next position in the phrase.
- add(Term[], int) - Method in class org.apache.lucene.search.MultiPhraseQuery
-
Allows to specify the relative position of terms within the phrase.
- add(Term, int) - Method in class org.apache.lucene.search.PhraseQuery
-
Adds a term to the end of the query phrase.
- add(QueryNode) - Method in interface org.apache.lucene.queryParser.core.nodes.QueryNode
- add(QueryNode) - Method in class org.apache.lucene.queryParser.core.nodes.QueryNodeImpl
- add(QueryNodeProcessor) - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorPipeline
- add(BooleanClause) - Method in class org.apache.lucene.search.BooleanQuery
-
Adds a clause to a boolean query.
- add(FilterClause) - Method in class org.apache.lucene.search.BooleanFilter
-
Adds a new FilterClause to the Boolean Filter container
- add(Filter, BooleanClause.Occur) - Method in class org.apache.lucene.search.BooleanFilter
- add(Query) - Method in class org.apache.lucene.search.DisjunctionMaxQuery
-
Add a subquery to this disjunction
- add(Query, BooleanClause.Occur) - Method in class org.apache.lucene.search.BooleanQuery
-
Adds a clause to a boolean query.
- add(Point2D) - Method in class org.apache.lucene.spatial.geometry.shape.Point2D
-
Deprecated.
- add(Vector2D) - Method in class org.apache.lucene.spatial.geometry.shape.Point2D
-
Deprecated.
- add(AttributeSource.State) - Method in class org.apache.lucene.analysis.LookaheadTokenFilter.Position
- 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) - Method in class org.apache.lucene.search.suggest.fst.InMemorySorter
- add(BytesRef) - Method in class org.apache.lucene.util.BytesRefHash
-
Adds a new
BytesRef
- 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, int) - Method in class org.apache.lucene.util.BytesRefHash
-
Adds a new
BytesRef
with a pre-calculated hash code. - add(BytesRef, BytesRef) - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
- add(CharsRef, CharsRef, boolean) - Method in class org.apache.lucene.analysis.synonym.SynonymMap.Builder
-
Add a phrase->phrase synonym mapping.
- add(PairOutputs.Pair<A, B>, PairOutputs.Pair<A, B>) - Method in class org.apache.lucene.util.fst.PairOutputs
- add(IntsRef, IntsRef) - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
- add(IntsRef, T) - Method in class org.apache.lucene.util.fst.Builder
-
It's OK to add the same input twice in a row with different outputs, as long as outputs impls the merge method.
- add(T) - Method in interface org.apache.lucene.facet.search.Heap
-
Add a new value to the heap, return the new top().
- add(T) - Method in class org.apache.lucene.util.PriorityQueue
-
Adds an Object to a PriorityQueue in log(size) time.
- add(T, T) - Method in class org.apache.lucene.util.fst.Outputs
-
Eg add("foo", "bar") -> "foobar"
- addAll(int, Collection<? extends QueryNodeProcessor>) - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorPipeline
- addAll(Iterable<SegmentInfo>) - Method in class org.apache.lucene.index.SegmentInfos
- addAll(Collection<? extends QueryNodeProcessor>) - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorPipeline
- addAnalyzer(String, Analyzer) - Method in class org.apache.lucene.analysis.PerFieldAnalyzerWrapper
-
Deprecated.Changing the Analyzer for a field after instantiation prevents reusability. Analyzers for fields should be set during construction.
- addAndGet(long) - Method in class org.apache.lucene.util.Counter
-
Adds the given delta to the counters current value
- addArc(int, Builder.Node) - Method in class org.apache.lucene.util.fst.Builder.UnCompiledNode
- addAttribute(Class<A>) - Method in class org.apache.lucene.queryParser.core.config.AbstractQueryConfig
- addAttribute(Class<A>) - 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.
- addBox(double) - Method in class org.apache.lucene.spatial.tier.Shape
-
Deprecated.
- addBuffer(int) - Method in class org.apache.lucene.store.RAMFile
- addBuilder(String, SpanQueryBuilder) - Method in class org.apache.lucene.xmlparser.builders.SpanQueryBuilderFactory
- addBuilder(String, FilterBuilder) - Method in class org.apache.lucene.xmlparser.FilterBuilderFactory
- addBuilder(String, QueryBuilder) - Method in class org.apache.lucene.xmlparser.QueryBuilderFactory
- addByPoolOffset(int) - Method in class org.apache.lucene.util.BytesRefHash
- addBytes(long) - Method in class org.apache.lucene.benchmark.byTask.feeds.ContentItemsSource
-
update count of bytes generated by this source
- addCategory(CategoryAttribute) - Method in class org.apache.lucene.facet.index.CategoryContainer
-
Add an entire
CategoryAttribute
. - addCategory(CategoryPath) - Method in class org.apache.lucene.facet.index.CategoryContainer
-
Add a category.
- addCategory(CategoryPath) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
- addCategory(CategoryPath) - 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.
- addCategory(CategoryPath, CategoryProperty) - Method in class org.apache.lucene.facet.index.CategoryContainer
-
Add a category with a property.
- addCategory(CategoryPath, CategoryProperty...) - Method in class org.apache.lucene.facet.index.CategoryContainer
-
Add a category with multiple properties.
- addCategoryDocument(CategoryPath, int, int) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
- addCategoryEnhancements(CategoryEnhancement...) - Method in class org.apache.lucene.facet.enhancements.params.DefaultEnhancementsIndexingParams
- addCategoryEnhancements(CategoryEnhancement...) - Method in interface org.apache.lucene.facet.enhancements.params.EnhancementsIndexingParams
-
Add
CategoryEnhancement
s to the indexing parameters - addCategoryListParams(CategoryPath, CategoryListParams) - Method in class org.apache.lucene.facet.index.params.PerDimensionIndexingParams
-
Add a CategoryListParams for a given CategoryPath's dimension or "zero-th" category.
- 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.
- addClass(String) - Method in class org.apache.lucene.analysis.compound.hyphenation.PatternParser
- addClause(List<BooleanClause>, int, int, Query) - Method in class org.apache.lucene.queryParser.QueryParser
- addClause(BooleanQuery, Term, float) - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsBoostOnlyBooleanQueryRewrite
- addClause(BooleanQuery, Term, float) - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsScoringBooleanQueryRewrite
- addClause(SpanQuery) - Method in class org.apache.lucene.search.spans.SpanOrQuery
-
Adds a clause to this query
- addCoreClosedListener(SegmentReader.CoreClosedListener) - Method in class org.apache.lucene.index.SegmentReader
-
Expert: adds a CoreClosedListener to this reader's shared core
- addCount - Variable in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
- addDefaultQueryTemplate(InputStream) - Method in class org.apache.lucene.xmlparser.QueryTemplateManager
- addDetail(Explanation) - Method in class org.apache.lucene.search.Explanation
-
Adds a sub-node to this explanation node.
- 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(Document) - Method in class org.apache.lucene.index.IndexWriter
-
Adds a document to this index.
- addDocument(Document) - Method in class org.apache.lucene.index.RandomIndexWriter
-
Adds a Document.
- addDocument(Document) - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
- addDocument(Document) - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexWriter
-
Deprecated.Adds a document to this index.
- addDocument(Document, Analyzer) - Method in class org.apache.lucene.index.IndexWriter
-
Adds a document to this index, using the provided analyzer instead of the value of
IndexWriter.getAnalyzer()
. - addDocument(Document, Analyzer) - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
- addDocument(Document, Analyzer) - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexWriter
-
Deprecated.Adds a document to this index, using the provided analyzer instead of the value of
InstantiatedIndexWriter.getAnalyzer()
. - addDocument(Term, Document) - Method in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
- addDocument(InstantiatedDocument, Analyzer) - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexWriter
-
Deprecated.Tokenizes a document and adds it to the buffer.
- addDocuments(Collection<Document>) - Method in class org.apache.lucene.index.IndexWriter
-
Atomically adds a block of documents with sequentially assigned document IDs, such that an external reader will see all or none of the documents.
- addDocuments(Collection<Document>) - Method in class org.apache.lucene.index.RandomIndexWriter
- addDocuments(Collection<Document>) - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
- addDocuments(Collection<Document>, Analyzer) - Method in class org.apache.lucene.index.IndexWriter
-
Atomically adds a block of documents, analyzed using the provided analyzer, with sequentially assigned document IDs, such that an external reader will see all or none of the documents.
- addDocuments(Collection<Document>, Analyzer) - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
- addDocuments(Term, Collection<Document>) - 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.
- addError(Test, Throwable) - Method in class org.apache.lucene.util.LuceneJUnitResultFormatter
-
A test caused an error.
- addEscapes(String) - Static method in error org.apache.lucene.benchmark.byTask.feeds.demohtml.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.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
- addEscapes(String) - Static method in error org.apache.lucene.queryParser.TokenMgrError
-
Replaces unprintable characters by their escaped (or unicode escaped) equivalents in the given string
- 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.
- addException(String, ArrayList<Object>) - Method in class org.apache.lucene.analysis.compound.hyphenation.PatternParser
- 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
- addFacetRequest(FacetRequest) - Method in class org.apache.lucene.facet.search.params.FacetSearchParams
-
Add a facet request to apply for this faceted search.
- addFailure(Test, Throwable) - Method in class org.apache.lucene.util.LuceneJUnitResultFormatter
-
Interface TestListener for JUnit <= 3.4.
- addFailure(Test, AssertionFailedError) - Method in class org.apache.lucene.util.LuceneJUnitResultFormatter
-
Interface TestListener for JUnit > 3.4.
- 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 istokenized
,not stored
,termVectorStored with positions
(ortermVectorStored with positions and offsets
), - addField(String, TokenStream) - Method in class org.apache.lucene.index.memory.MemoryIndex
-
Equivalent to
addField(fieldName, stream, 1.0f)
. - addField(String, TokenStream, float) - 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.core.config.QueryConfigHandler
-
Adds a listener.
- addFile(String) - Method in class org.apache.lucene.index.CompoundFileWriter
-
Add a source stream.
- addFile(String, Directory) - Method in class org.apache.lucene.index.CompoundFileWriter
-
Same as
CompoundFileWriter.addFile(String)
, only for files that are found in an externalDirectory
. - addFilterBuilder(String, FilterBuilder) - Method in class org.apache.lucene.xmlparser.CoreParser
- addIndexes(IndexReader...) - Method in class org.apache.lucene.index.IndexWriter
-
Merges the provided indexes into this index.
- addIndexes(IndexReader...) - Method in class org.apache.lucene.index.RandomIndexWriter
- addIndexes(IndexReader...) - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
- addIndexes(IndexReader[]) - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexWriter
-
Deprecated.
- addIndexes(Directory...) - Method in class org.apache.lucene.index.IndexWriter
-
Adds all segments from an array of indexes into this index.
- addIndexes(Directory...) - Method in class org.apache.lucene.index.RandomIndexWriter
- addIndexes(Directory...) - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
- addIndexesNoOptimize(Directory...) - Method in class org.apache.lucene.index.IndexWriter
-
Deprecated.use
IndexWriter.addIndexes(Directory...)
instead - addItem() - Method in class org.apache.lucene.benchmark.byTask.feeds.ContentItemsSource
-
update count of items generated by this source
- addLabel(CategoryPath, int) - Method in class org.apache.lucene.facet.taxonomy.writercache.cl2o.CompactLabelToOrdinal
- addLabel(CategoryPath, int) - Method in class org.apache.lucene.facet.taxonomy.writercache.cl2o.LabelToOrdinal
-
Adds a new label if its not yet in the table.
- addLabel(CategoryPath, int, int) - Method in class org.apache.lucene.facet.taxonomy.writercache.cl2o.CollisionMap
- addLabel(CategoryPath, int, int) - Method in class org.apache.lucene.facet.taxonomy.writercache.cl2o.CompactLabelToOrdinal
- addLabel(CategoryPath, int, int) - Method in class org.apache.lucene.facet.taxonomy.writercache.cl2o.LabelToOrdinal
-
Adds a new label if its not yet in the table.
- addLabel(CategoryPath, int, int, int) - Method in class org.apache.lucene.facet.taxonomy.writercache.cl2o.CollisionMap
- addLabelOffset(int, int, int) - Method in class org.apache.lucene.facet.taxonomy.writercache.cl2o.CollisionMap
-
This method does not check if the same value is already in the map because we pass in an char-array offset, so so we now that we're in resize-mode here.
- 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
- addOffCorrectMap(int, int) - Method in class org.apache.lucene.analysis.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.
- addPattern(String, String) - Method in class org.apache.lucene.analysis.compound.hyphenation.PatternParser
- addPosition(int, int) - Method in class org.apache.lucene.search.SpanFilterResult.PositionInfo
- addPositionSpans(List<PositionSpan>) - Method in class org.apache.lucene.search.highlight.WeightedSpanTerm
- addPrefix(HunspellAffix) - Method in class org.apache.lucene.analysis.hunspell.HunspellStemmer.Stem
-
Adds a prefix to the list of prefixes used to generate this stem.
- addProcessor(QueryNodeProcessor) - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorPipeline
-
Deprecated.this class now conforms to
List
interface, so useQueryNodeProcessorPipeline.add(QueryNodeProcessor)
instead - addProperty(CategoryProperty) - Method in interface org.apache.lucene.facet.index.attributes.CategoryAttribute
-
Add a property.
- addProperty(CategoryProperty) - Method in class org.apache.lucene.facet.index.attributes.CategoryAttributeImpl
- addQueryBuilder(String, QueryBuilder) - Method in class org.apache.lucene.xmlparser.CoreParser
- addQueryTemplate(String, InputStream) - Method in class org.apache.lucene.xmlparser.QueryTemplateManager
- addRange(int, int, int) - Method in class org.apache.lucene.util.NumericUtils.IntRangeBuilder
-
Overwrite this method, if you like to receive the raw int range bounds.
- addRange(long, long, int) - Method in class org.apache.lucene.util.NumericUtils.LongRangeBuilder
-
Overwrite this method, if you like to receive the raw long range bounds.
- addRange(String, String) - Method in class org.apache.lucene.util.NumericUtils.IntRangeBuilder
-
Overwrite this method, if you like to receive the already prefix encoded range bounds.
- addRange(String, String) - Method in class org.apache.lucene.util.NumericUtils.LongRangeBuilder
-
Overwrite this method, if you like to receive the already prefix encoded range bounds.
- addReaderClosedListener(IndexReader.ReaderClosedListener) - Method in class org.apache.lucene.index.IndexReader
-
Expert: adds a
IndexReader.ReaderClosedListener
. - addResult(int, boolean, long) - Method in class org.apache.lucene.benchmark.quality.QualityStats
-
Add a (possibly relevant) doc.
- addRetainableProperty(Class<? extends CategoryProperty>) - Method in class org.apache.lucene.facet.index.streaming.CategoryParentsStream
-
Add a
CategoryProperty
class which is retained when creating parent tokens. - addSinkTokenStream(TeeSinkTokenFilter.SinkTokenStream) - Method in class org.apache.lucene.analysis.TeeSinkTokenFilter
-
Adds a
TeeSinkTokenFilter.SinkTokenStream
created by anotherTeeSinkTokenFilter
to this one. - addSpanNearQuery(Query) - Method in class org.apache.lucene.queryParser.surround.query.SpanNearClauseFactory
- 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
- addSpanQueryWeighted(SpanQuery, float) - Method in class org.apache.lucene.queryParser.surround.query.SpanNearClauseFactory
- addStopWords(IndexReader) - Method in class org.apache.lucene.analysis.query.QueryAutoStopWordAnalyzer
-
Deprecated.Stopwords should be calculated at instantiation using
QueryAutoStopWordAnalyzer(Version, Analyzer, IndexReader)
- addStopWords(IndexReader, float) - Method in class org.apache.lucene.analysis.query.QueryAutoStopWordAnalyzer
-
Deprecated.Stowords should be calculated at instantiation using
QueryAutoStopWordAnalyzer(Version, Analyzer, IndexReader, float)
- addStopWords(IndexReader, int) - Method in class org.apache.lucene.analysis.query.QueryAutoStopWordAnalyzer
-
Deprecated.Stopwords should be calculated at instantiation using
QueryAutoStopWordAnalyzer(Version, Analyzer, IndexReader, int)
- addStopWords(IndexReader, String, float) - Method in class org.apache.lucene.analysis.query.QueryAutoStopWordAnalyzer
-
Deprecated.Stowords should be calculated at instantiation using
QueryAutoStopWordAnalyzer(Version, Analyzer, IndexReader, Collection, float)
- addStopWords(IndexReader, String, int) - Method in class org.apache.lucene.analysis.query.QueryAutoStopWordAnalyzer
-
Deprecated.Stowords should be calculated at instantiation using
QueryAutoStopWordAnalyzer(Version, Analyzer, IndexReader, Collection, int)
- addSuffix(HunspellAffix) - Method in class org.apache.lucene.analysis.hunspell.HunspellStemmer.Stem
-
Adds a suffix to the list of suffixes used to generate this stem.
- 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.
- addTerm(Term) - Method in class org.apache.lucene.search.TermsFilter
-
Adds a term to the list of acceptable terms
- addTerms(String, String, float, int) - Method in class org.apache.lucene.search.FuzzyLikeThisQuery
-
Adds user input for "fuzzification"
- addTermWeighted(Term, float) - Method in class org.apache.lucene.queryParser.surround.query.SpanNearClauseFactory
- addToArray(int) - Method in class org.apache.lucene.util.collections.IntArray
-
Adds a value to the array.
- addWaitingListener(NRTManager.WaitingListener) - Method in class org.apache.lucene.search.NRTManager
-
Adds a listener, to be notified when a caller is waiting for a specific generation searcher to be visible.
- adjustBeginLineColumn(int, int) - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
-
Method to adjust line and column numbers for the start of a token.
- adjustBeginLineColumn(int, int) - Method in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
-
Method to adjust line and column numbers for the start of a token.
- AdjustBuffSize() - Method in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
- adjustTop() - Method in class org.apache.lucene.util.ScorerDocQueue
-
Deprecated.Should be called when the scorer at top changes doc() value.
- advance(int) - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantScorer
- advance(int) - Method in class org.apache.lucene.search.DocIdSetIterator
-
Advances to the first beyond (see NOTE below) the current whose document number is greater than or equal to target.
- advance(int) - Method in class org.apache.lucene.search.FilteredDocIdSetIterator
- advance(int) - Method in class org.apache.lucene.search.ScoreCachingWrappingScorer
- advance(int) - Method in class org.apache.lucene.search.spans.SpanScorer
- advance(int) - Method in class org.apache.lucene.util.OpenBitSetIterator
- advise(FileDescriptor, long, long, int) - Static method in class org.apache.lucene.store.NativePosixUtil
- afterClass() - Static method in class org.apache.lucene.search.SearchEquivalenceTestBase
- afterClassLuceneTestCaseJ4() - Static method in class org.apache.lucene.util.LuceneTestCase
- afterClose() - Method in class org.apache.lucene.search.NRTManager
- afterClose() - Method in class org.apache.lucene.search.ReferenceManager
-
Called after close(), so subclass can free any resources.
- AfterEquals - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
Lexical state.
- 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() - Method in class org.apache.lucene.search.NRTManager
- afterRefresh() - Method in class org.apache.lucene.search.ReferenceManager
-
Called after swapReference has installed a new instance.
- aggregate(int) - Method in interface org.apache.lucene.facet.search.aggregator.Aggregator
-
Collect (and do whatever an implementation deems appropriate) the category given by its ordinal.
- aggregate(int) - Method in class org.apache.lucene.facet.search.aggregator.association.AssociationFloatSumAggregator
- aggregate(int) - Method in class org.apache.lucene.facet.search.aggregator.association.AssociationIntSumAggregator
- aggregate(int) - Method in class org.apache.lucene.facet.search.aggregator.ComplementCountingAggregator
- aggregate(int) - Method in class org.apache.lucene.facet.search.aggregator.CountingAggregator
- aggregate(int) - Method in class org.apache.lucene.facet.search.aggregator.ScoringAggregator
- Aggregator - Interface in org.apache.lucene.facet.search.aggregator
-
An Aggregator is the analogue of Lucene's Collector (see
Collector
), for processing the categories belonging to a certain document. - 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
-
Aligns an object size to be the next multiple of
RamUsageEstimator.NUM_BYTES_OBJECT_ALIGNMENT
. - ALL - Static variable in class org.apache.lucene.index.SortedTermVectorMapper
-
Stand-in name for the field in
TermVectorEntry
. - allFragmentsProcessed() - Method in class org.apache.lucene.search.highlight.QueryTermScorer
- 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.facet.search.TemporaryObjectAllocator
-
Allocate a new object.
- allocate() - Method in class org.apache.lucene.queryParser.core.nodes.QueryNodeImpl
- Allocator(int) - Constructor for class org.apache.lucene.util.ByteBlockPool.Allocator
- allocSlice(byte[], int) - Method in class org.apache.lucene.util.ByteBlockPool
- ALLOW_LEADING_WILDCARD - Static variable in class org.apache.lucene.queryParser.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
- AllowLeadingWildcardAttribute - Interface in org.apache.lucene.queryParser.standard.config
-
Deprecated.
- AllowLeadingWildcardAttributeImpl - Class in org.apache.lucene.queryParser.standard.config
-
Deprecated.
- AllowLeadingWildcardAttributeImpl() - Constructor for class org.apache.lucene.queryParser.standard.config.AllowLeadingWildcardAttributeImpl
-
Deprecated.
- AllowLeadingWildcardProcessor - Class in org.apache.lucene.queryParser.standard.processors
-
This processor verifies if
StandardQueryConfigHandler.ConfigurationKeys.ALLOW_LEADING_WILDCARD
is defined in theQueryConfigHandler
. - AllowLeadingWildcardProcessor() - Constructor for class org.apache.lucene.queryParser.standard.processors.AllowLeadingWildcardProcessor
- ALPHA - Static variable in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
- ALPHANUM - Static variable in class org.apache.lucene.analysis.standard.ClassicTokenizer
- ALPHANUM - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
- ALPHANUM - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
- 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
- AlreadySetException() - Constructor for exception org.apache.lucene.util.SetOnce.AlreadySetException
- ALWAYS - org.apache.lucene.store.MockDirectoryWrapper.Throttling
-
always emulate a slow hard disk.
- alwaysIgnoredTestMethod() - Method in class org.apache.lucene.util.LuceneTestCase
- Among - Class in org.tartarus.snowball
- Among(String, int, int, String, SnowballProgram) - Constructor for class org.tartarus.snowball.Among
- ANALYSIS_DATA_DIR - Static variable in class org.apache.lucene.analysis.cn.smart.AnalyzerProfile
-
Global indicating the configured analysis data directory
- analyze(Analyzer, String, CharsRef) - Static method in class org.apache.lucene.analysis.synonym.SynonymMap.Builder
-
Sugar: analyzes the text with the analyzer and separates by
SynonymMap.WORD_SEPARATOR
. - ANALYZED - org.apache.lucene.document.Field.Index
-
Index the tokens produced by running the field's value through an Analyzer.
- ANALYZED_NO_NORMS - org.apache.lucene.document.Field.Index
-
Expert: Index the tokens produced by running the field's value through an Analyzer, and also separately disable the storing of norms.
- analyzer - Static variable in class org.apache.lucene.search.SearchEquivalenceTestBase
- analyzer - Variable in class org.apache.lucene.xmlparser.CoreParser
- Analyzer - Class in org.apache.lucene.analysis
-
An Analyzer builds TokenStreams, which analyze text.
- Analyzer() - Constructor for class org.apache.lucene.analysis.Analyzer
- ANALYZER - Static variable in class org.apache.lucene.queryParser.standard.config.StandardQueryConfigHandler.ConfigurationKeys
-
Key used to set the
Analyzer
used for terms found in the query - AnalyzerAttribute - Interface in org.apache.lucene.queryParser.standard.config
-
Deprecated.
- AnalyzerAttributeImpl - Class in org.apache.lucene.queryParser.standard.config
-
Deprecated.
- AnalyzerAttributeImpl() - Constructor for class org.apache.lucene.queryParser.standard.config.AnalyzerAttributeImpl
-
Deprecated.
- 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.standard.processors
-
This processor verifies if
StandardQueryConfigHandler.ConfigurationKeys.ANALYZER
is defined in theQueryConfigHandler
. - AnalyzerQueryNodeProcessor() - Constructor for class org.apache.lucene.queryParser.standard.processors.AnalyzerQueryNodeProcessor
- AnalyzingQueryParser - Class in org.apache.lucene.queryParser.analyzing
-
Overrides Lucene's default QueryParser so that Fuzzy-, Prefix-, Range-, and WildcardQuerys are also passed through the given analyzer, but wild card characters (like
*
) don't get removed from the search terms. - AnalyzingQueryParser(Version, String, Analyzer) - Constructor for class org.apache.lucene.queryParser.analyzing.AnalyzingQueryParser
-
Constructs a query parser.
- and(DocIdSetIterator) - Method in class org.apache.lucene.util.FixedBitSet
-
Does in-place AND of the bits provided by the iterator.
- and(FixedBitSet) - Method in class org.apache.lucene.util.FixedBitSet
-
this = this AND other
- and(OpenBitSet) - Method in class org.apache.lucene.util.OpenBitSet
- AND - org.apache.lucene.queryParser.QueryParser.Operator
- AND - org.apache.lucene.queryParser.standard.config.DefaultOperatorAttribute.Operator
-
Deprecated.
- AND - org.apache.lucene.queryParser.standard.config.StandardQueryConfigHandler.Operator
- AND - org.apache.lucene.queryParser.standard.QueryParserWrapper.Operator
-
Deprecated.
- AND - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
-
RegularExpression Id.
- AND - Static variable in interface org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- AND - Static variable in interface org.apache.lucene.queryParser.surround.parser.QueryParserConstants
-
RegularExpression Id.
- AND - Static variable in class org.apache.lucene.search.ChainedFilter
- AND_OPERATOR - Static variable in class org.apache.lucene.queryParser.QueryParser
-
Alternative form of QueryParser.Operator.AND
- AND_OPERATOR - Static variable in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.Alternative form of QueryParser.Operator.AND
- andNot(DocIdSetIterator) - Method in class org.apache.lucene.util.FixedBitSet
-
Does in-place AND NOT of the bits provided by the iterator.
- andNot(FixedBitSet) - Method in class org.apache.lucene.util.FixedBitSet
-
this = this AND NOT other
- andNot(OpenBitSet) - Method in class org.apache.lucene.util.OpenBitSet
- ANDNOT - Static variable in class org.apache.lucene.search.ChainedFilter
- andNotCount(OpenBitSet, OpenBitSet) - Static method in class org.apache.lucene.util.OpenBitSet
-
Returns the popcount or cardinality of "a and not b" or "intersection(a, not(b))".
- AndQuery - Class in org.apache.lucene.queryParser.surround.query
- AndQuery(List<SrndQuery>, boolean, String) - Constructor for class org.apache.lucene.queryParser.surround.query.AndQuery
- AndQuery() - Method in class org.apache.lucene.queryParser.surround.parser.QueryParser
- AndQueryNode - Class in org.apache.lucene.queryParser.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.core.nodes.AndQueryNode
- angularDistance(double, double) - Static method in class org.apache.lucene.spatial.DistanceUtils
-
Deprecated.distance/radius.
- anyFilesExceptWriteLock(Directory) - Static method in class org.apache.lucene.util._TestUtil
- AnyQueryNode - Class in org.apache.lucene.queryParser.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.core.nodes.AnyQueryNode
- AnyQueryNodeBuilder - Class in org.apache.lucene.queryParser.standard.builders
- AnyQueryNodeBuilder() - Constructor for class org.apache.lucene.queryParser.standard.builders.AnyQueryNodeBuilder
- anyUnhandledExceptions() - Static method in class org.apache.lucene.index.ConcurrentMergeScheduler
-
Used for testing
- APOSTROPHE - Static variable in class org.apache.lucene.analysis.standard.ClassicTokenizer
- APOSTROPHE - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
-
Deprecated.
- APOSTROPHE_ID - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
- append(char) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
- append(char) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
- append(char) - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
- append(char[], int, int) - Method in class org.apache.lucene.util.CharsRef
-
Appends the given array to this CharsRef
- append(long) - Method in class org.apache.lucene.util.LuceneJUnitResultFormatter
- append(CharSequence) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
- append(CharSequence) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
- append(CharSequence) - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
- append(CharSequence, int, int) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
- append(CharSequence, int, int) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
- append(CharSequence, int, int) - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
- append(String) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
-
Appends the specified
String
to this character sequence. - append(String) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
- append(String) - Method in class org.apache.lucene.util.LuceneJUnitResultFormatter
- append(StringBuilder) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
-
Appends the specified
StringBuilder
to this character sequence. - append(StringBuilder) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
- append(CharTermAttribute) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
-
Appends the contents of the other
CharTermAttribute
to this character sequence. - append(CharTermAttribute) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
- append(BytesRef) - Method in class org.apache.lucene.search.suggest.BytesRefList
-
Appends a copy of the given
BytesRef
to thisBytesRefList
. - append(BytesRef) - Method in class org.apache.lucene.util.BytesRef
-
Appends the bytes from the given
BytesRef
- APPEND - org.apache.lucene.index.IndexWriterConfig.OpenMode
- appendIntToStream(int) - Method in class org.apache.lucene.facet.index.CategoryListPayloadStream
-
Appends an integer to the stream.
- appendRegExpForChar(char, StringBuilder) - Method in class org.apache.lucene.queryParser.surround.query.SrndTruncQuery
- appendSubResult(FacetResultNode) - Method in class org.apache.lucene.facet.search.results.MutableFacetResultNode
-
Append a sub result (as last).
- appendTo(Appendable, char) - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
-
Build a string representation of the path, with its components separated by the given delimiter character.
- appendTo(Appendable, char, int) - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
-
like
CategoryPath.appendTo(Appendable, char)
, but takes only a prefix of the path, rather than the whole path. - appendTo(Appendable, char, int, int) - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
-
like
CategoryPath.appendTo(Appendable, char)
, but takes only a part of the path, rather than the whole path. - apply(char[], int) - Method in class org.apache.lucene.analysis.pt.RSLPStemmerBase.Step
- apply(StringBuilder, CharSequence) - Static method in class org.egothor.stemmer.Diff
-
Apply the given patch string diff to the given string dest.
- apply(Statement, Description) - Method in class org.apache.lucene.util.StoreClassNameRule
- apply(Statement, Description) - Method in class org.apache.lucene.util.SystemPropertiesInvariantRule
- apply(Statement, Description) - Method in class org.apache.lucene.util.SystemPropertiesRestoreRule
- apply(Statement, Description) - Method in class org.apache.lucene.util.UncaughtExceptionsRule
- applyAffix(char[], int, HunspellAffix, int) - Method in class org.apache.lucene.analysis.hunspell.HunspellStemmer
-
Applies the affix rule to the given word, producing a list of stems if any are found
- ArabicAnalyzer - Class in org.apache.lucene.analysis.ar
-
Analyzer
for Arabic. - ArabicAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.ar.ArabicAnalyzer
-
Builds an analyzer with the default stop words:
ArabicAnalyzer.DEFAULT_STOPWORD_FILE
. - ArabicAnalyzer(Version, File) - Constructor for class org.apache.lucene.analysis.ar.ArabicAnalyzer
-
Deprecated.use
ArabicAnalyzer(Version, Set)
instead - ArabicAnalyzer(Version, String...) - Constructor for class org.apache.lucene.analysis.ar.ArabicAnalyzer
-
Deprecated.use
ArabicAnalyzer(Version, Set)
instead - ArabicAnalyzer(Version, Hashtable<?, ?>) - Constructor for class org.apache.lucene.analysis.ar.ArabicAnalyzer
-
Deprecated.use
ArabicAnalyzer(Version, Set)
instead - ArabicAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.ar.ArabicAnalyzer
-
Builds an analyzer with the given stop words
- ArabicAnalyzer(Version, Set<?>, Set<?>) - Constructor for class org.apache.lucene.analysis.ar.ArabicAnalyzer
-
Builds an analyzer with the given stop word.
- ArabicLetterTokenizer - Class in org.apache.lucene.analysis.ar
-
Deprecated.(3.1) Use
StandardTokenizer
instead. - ArabicLetterTokenizer(Reader) - Constructor for class org.apache.lucene.analysis.ar.ArabicLetterTokenizer
-
Deprecated.use
ArabicLetterTokenizer(Version, Reader)
instead. This will be removed in Lucene 4.0. - ArabicLetterTokenizer(AttributeSource.AttributeFactory, Reader) - Constructor for class org.apache.lucene.analysis.ar.ArabicLetterTokenizer
-
Deprecated.use
ArabicLetterTokenizer(Version, AttributeSource.AttributeFactory, Reader)
instead. This will be removed in Lucene 4.0. - ArabicLetterTokenizer(AttributeSource, Reader) - Constructor for class org.apache.lucene.analysis.ar.ArabicLetterTokenizer
-
Deprecated.use
ArabicLetterTokenizer(Version, AttributeSource, Reader)
instead. This will be removed in Lucene 4.0. - ArabicLetterTokenizer(Version, Reader) - Constructor for class org.apache.lucene.analysis.ar.ArabicLetterTokenizer
-
Deprecated.Construct a new ArabicLetterTokenizer.
- ArabicLetterTokenizer(Version, AttributeSource.AttributeFactory, Reader) - Constructor for class org.apache.lucene.analysis.ar.ArabicLetterTokenizer
-
Deprecated.Construct a new ArabicLetterTokenizer using a given
AttributeSource.AttributeFactory
. - ArabicLetterTokenizer(Version, AttributeSource, Reader) - Constructor for class org.apache.lucene.analysis.ar.ArabicLetterTokenizer
-
Deprecated.Construct a new ArabicLetterTokenizer using a given
AttributeSource
. - ArabicNormalizationFilter - Class in org.apache.lucene.analysis.ar
-
A
TokenFilter
that appliesArabicNormalizer
to normalize the orthography. - ArabicNormalizationFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.ar.ArabicNormalizationFilter
- 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
-
A
TokenFilter
that appliesArabicStemmer
to stem Arabic words.. - ArabicStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.ar.ArabicStemFilter
- ArabicStemmer - Class in org.apache.lucene.analysis.ar
-
Stemmer for Arabic.
- ArabicStemmer() - Constructor for class org.apache.lucene.analysis.ar.ArabicStemmer
- Arc() - Constructor for class org.apache.lucene.util.fst.Builder.Arc
- Arc() - Constructor for class org.apache.lucene.util.fst.FST.Arc
- arcCount - Variable in class org.apache.lucene.util.fst.FST
- arcDistance(LatLng) - Method in class org.apache.lucene.spatial.geometry.LatLng
-
Deprecated.Calculates the distance between two lat/lng's in miles.
- arcDistance(LatLng, DistanceUnits) - Method in class org.apache.lucene.spatial.geometry.LatLng
-
Deprecated.Calculates the distance between two lat/lng's in miles or meters.
- arcs - Variable in class org.apache.lucene.util.fst.Builder.UnCompiledNode
- arcWithOutputCount - Variable in class org.apache.lucene.util.fst.FST
- area() - Method in class org.apache.lucene.spatial.geometry.shape.Ellipse
-
Deprecated.
- area() - Method in interface org.apache.lucene.spatial.geometry.shape.Geometry2D
-
Deprecated.Return the area
- area() - Method in class org.apache.lucene.spatial.geometry.shape.LLRect
-
Deprecated.Return the area in units of lat-lng squared.
- area() - Method in class org.apache.lucene.spatial.geometry.shape.Rectangle
-
Deprecated.
- ArgEquals - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
RegularExpression Id.
- ArgName - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
RegularExpression Id.
- ArgQuote1 - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
RegularExpression Id.
- ArgQuote2 - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
RegularExpression Id.
- ArgValue - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
RegularExpression Id.
- ArgValue() - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParser
- ArmenianAnalyzer - Class in org.apache.lucene.analysis.hy
-
Analyzer
for Armenian. - ArmenianAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.hy.ArmenianAnalyzer
-
Builds an analyzer with the default stop words:
ArmenianAnalyzer.DEFAULT_STOPWORD_FILE
. - ArmenianAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.hy.ArmenianAnalyzer
-
Builds an analyzer with the given stop words.
- ArmenianAnalyzer(Version, Set<?>, Set<?>) - 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
- ARRAY_HEADER_SIZE - org.apache.lucene.util.RamUsageEstimator.JvmFeature
- ArrayHashMap<K,V> - Class in org.apache.lucene.util.collections
-
An Array-based hashtable which maps, similar to Java's HashMap, only performance tests showed it performs better.
- ArrayHashMap() - Constructor for class org.apache.lucene.util.collections.ArrayHashMap
-
Constructs a map with default capacity.
- ArrayHashMap(int) - Constructor for class org.apache.lucene.util.collections.ArrayHashMap
-
Constructs a map with given capacity.
- arrayToString(int[]) - Static method in class org.apache.lucene.util._TestUtil
-
Deprecated.-- in 3.0 we can use Arrays.toString instead
- arrayToString(Object[]) - Static method in class org.apache.lucene.util._TestUtil
-
Deprecated.-- in 3.0 we can use Arrays.toString instead
- ArrayUtil - Class in org.apache.lucene.util
-
Methods for manipulating arrays.
- ArrayUtil() - Constructor for class org.apache.lucene.util.ArrayUtil
-
Deprecated.This constructor was not intended to be public and should not be used. This class contains solely a static utility methods. It will be made private in Lucene 4.0
- ASCENDING - org.apache.lucene.facet.search.params.FacetRequest.SortOrder
- ASCIIFoldingFilter - Class in org.apache.lucene.analysis
-
This class converts alphabetic, numeric, and symbolic Unicode characters which are not in the first 127 ASCII characters (the "Basic Latin" Unicode block) into their ASCII equivalents, if one exists.
- ASCIIFoldingFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.ASCIIFoldingFilter
- asList() - Method in class org.apache.lucene.index.SegmentInfos
-
Returns all contained segments as an unmodifiable
List
view. - assertAnalyzesTo(Analyzer, 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
- 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[], String[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
- assertAnalyzesToPositions(Analyzer, String, String[], int[], int[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
- assertAnalyzesToReuse(Analyzer, String, String[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
- assertAnalyzesToReuse(Analyzer, String, String[], int[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
- assertAnalyzesToReuse(Analyzer, String, String[], int[], int[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
- assertAnalyzesToReuse(Analyzer, String, String[], int[], int[], int[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
- assertAnalyzesToReuse(Analyzer, String, String[], int[], int[], String[], int[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
- assertAnalyzesToReuse(Analyzer, String, String[], String[]) - 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
- assertDateRangeQueryEquals(QueryParser, String, String, String, Date, DateTools.Resolution) - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- assertEquals(double, double) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Deprecated.
- assertEquals(float, float) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Deprecated.
- assertEquals(String, double, double) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Deprecated.
- assertEquals(String, float, float) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Deprecated.
- assertEquals(TopDocs, TopDocs) - Static method in class org.apache.lucene.util._TestUtil
- assertEscapedQueryEquals(String, Analyzer, String) - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- AssertingIndexSearcher - Class in org.apache.lucene.search
-
Helper class that adds some extra checks to ensure correct usage of
IndexSearcher
andWeight
. - AssertingIndexSearcher(IndexReader) - Constructor for class org.apache.lucene.search.AssertingIndexSearcher
- AssertingIndexSearcher(IndexReader, ExecutorService) - Constructor for class org.apache.lucene.search.AssertingIndexSearcher
- assertParseException(String) - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- assertQueryEquals(String, Analyzer, String) - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- assertQueryEquals(QueryParser, String, String, String) - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- assertQueryEqualsDOA(String, Analyzer, String) - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- 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 byq2
- assertSaneFieldCaches(String) - Method in class org.apache.lucene.util.LuceneTestCase
-
Asserts that FieldCacheSanityChecker does not detect any problems with FieldCache.DEFAULT.
- assertSubsetOf(Query, Query) - Method in class org.apache.lucene.search.SearchEquivalenceTestBase
-
Asserts that the documents returned by
q1
are a subset of those returned byq2
- assertSubsetOf(Query, Query, Filter) - Method in class org.apache.lucene.search.SearchEquivalenceTestBase
-
Asserts that the documents returned by
q1
are a subset of those returned byq2
. - assertThreadSafe(Analyzer) - Method in class org.apache.lucene.analysis.CollationTestBase
- assertTokenStreamContents(TokenStream, 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[], int[]) - 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
- assertTokenStreamContents(TokenStream, String[], int[], int[], int[], Integer) - 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[], String[], int[]) - 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[], int[], Integer, boolean) - 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[], String[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
- assertVocabulary(Analyzer, File, String) - Static method in class org.apache.lucene.analysis.VocabularyAssert
-
Run a vocabulary test against a tab-separated data file inside a zip file
- assertVocabulary(Analyzer, File, 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, InputStream) - Static method in class org.apache.lucene.analysis.VocabularyAssert
-
Run a vocabulary test against one file: tab separated.
- assertVocabulary(Analyzer, InputStream, InputStream) - Static method in class org.apache.lucene.analysis.VocabularyAssert
-
Run a vocabulary test against two data files.
- assertWildcardQueryEquals(String, boolean, String) - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- assertWildcardQueryEquals(String, boolean, String, boolean) - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- assertWildcardQueryEquals(String, String) - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- asSet() - Method in class org.apache.lucene.index.SegmentInfos
-
Returns all contained segments as an unmodifiable
Set
view. - asSet(T...) - Static method in class org.apache.lucene.util.LuceneTestCase
- assign_to(StringBuilder) - Method in class org.tartarus.snowball.SnowballProgram
- association - Variable in class org.apache.lucene.facet.enhancements.association.AssociationProperty
- ASSOCIATION_POSTING_TERM - Static variable in class org.apache.lucene.facet.enhancements.association.AssociationsPayloadIterator
-
Default Term for associations
- AssociationEnhancement - Class in org.apache.lucene.facet.enhancements.association
-
A
CategoryEnhancement
for adding associations data to the index (categories withAssociationProperty
s). - AssociationEnhancement() - Constructor for class org.apache.lucene.facet.enhancements.association.AssociationEnhancement
- AssociationFloatProperty - Class in org.apache.lucene.facet.enhancements.association
-
An
AssociationProperty
which treats the association as float - the association bits are actually float bits, and thus merging two associations is done by float summation. - AssociationFloatProperty(float) - Constructor for class org.apache.lucene.facet.enhancements.association.AssociationFloatProperty
-
Constructor.
- AssociationFloatSumAggregator - Class in org.apache.lucene.facet.search.aggregator.association
-
An
Aggregator
which updates the weight of a category by summing the weights of the float association it finds for every document. - AssociationFloatSumAggregator(String, IndexReader, float[]) - Constructor for class org.apache.lucene.facet.search.aggregator.association.AssociationFloatSumAggregator
- AssociationFloatSumAggregator(IndexReader, float[]) - Constructor for class org.apache.lucene.facet.search.aggregator.association.AssociationFloatSumAggregator
- AssociationFloatSumFacetRequest - Class in org.apache.lucene.facet.search.params.association
-
Facet request for weighting facets according to their float association by summing the association values.
- AssociationFloatSumFacetRequest(CategoryPath, int) - Constructor for class org.apache.lucene.facet.search.params.association.AssociationFloatSumFacetRequest
-
Create a float association facet request for a given node in the taxonomy.
- AssociationIntProperty - Class in org.apache.lucene.facet.enhancements.association
-
An
AssociationProperty
which treats the association as int - merges two associations by summation. - AssociationIntProperty(int) - Constructor for class org.apache.lucene.facet.enhancements.association.AssociationIntProperty
- AssociationIntSumAggregator - Class in org.apache.lucene.facet.search.aggregator.association
-
An
Aggregator
which updates the weight of a category by summing the weights of the integer association it finds for every document. - AssociationIntSumAggregator(String, IndexReader, int[]) - Constructor for class org.apache.lucene.facet.search.aggregator.association.AssociationIntSumAggregator
- AssociationIntSumAggregator(IndexReader, int[]) - Constructor for class org.apache.lucene.facet.search.aggregator.association.AssociationIntSumAggregator
- AssociationIntSumFacetRequest - Class in org.apache.lucene.facet.search.params.association
-
Facet request for weighting facets according to their integer association by summing the association values.
- AssociationIntSumFacetRequest(CategoryPath, int) - Constructor for class org.apache.lucene.facet.search.params.association.AssociationIntSumFacetRequest
-
Create an integer association facet request for a given node in the taxonomy.
- AssociationListTokenizer - Class in org.apache.lucene.facet.enhancements.association
-
Tokenizer for associations of a category
- AssociationListTokenizer(TokenStream, EnhancementsIndexingParams, CategoryEnhancement) - Constructor for class org.apache.lucene.facet.enhancements.association.AssociationListTokenizer
- AssociationProperty - Class in org.apache.lucene.facet.enhancements.association
-
A
CategoryProperty
associating a single integer value to aCategoryAttribute
. - AssociationProperty(int) - Constructor for class org.apache.lucene.facet.enhancements.association.AssociationProperty
-
Construct an
AssociationProperty
. - associationsPayloadIterator - Variable in class org.apache.lucene.facet.search.aggregator.association.AssociationFloatSumAggregator
- associationsPayloadIterator - Variable in class org.apache.lucene.facet.search.aggregator.association.AssociationIntSumAggregator
- AssociationsPayloadIterator - Class in org.apache.lucene.facet.enhancements.association
-
Allows easy iteration over the associations payload, decoding and breaking it to (ordinal, value) pairs, stored in a hash.
- AssociationsPayloadIterator(IndexReader, String) - Constructor for class org.apache.lucene.facet.enhancements.association.AssociationsPayloadIterator
-
Construct a new association-iterator, initializing the inner payload iterator, with the supplied term and checking whether there are any associations within the given index
- 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
- atLeast(int) - Static method in class org.apache.lucene.util.LuceneTestCase
- atLeast(Random, int) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Returns a number of at least
i
- Attribute - Interface in org.apache.lucene.util
-
Base interface for attributes.
- AttributeFactory() - Constructor for class org.apache.lucene.util.AttributeSource.AttributeFactory
- AttributeImpl - Class in org.apache.lucene.util
-
Base class for Attributes that can be added to a
AttributeSource
. - AttributeImpl() - Constructor for class org.apache.lucene.util.AttributeImpl
- AttributeReflector - Interface in org.apache.lucene.util
-
This interface is used to reflect contents of
AttributeSource
orAttributeImpl
. - 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
-
An AttributeSource using the default attribute factory
AttributeSource.AttributeFactory.DEFAULT_ATTRIBUTE_FACTORY
. - AttributeSource(AttributeSource) - Constructor for class org.apache.lucene.util.AttributeSource
-
An AttributeSource that uses the same attributes as the supplied one.
- AttributeSource(AttributeSource.AttributeFactory) - Constructor for class org.apache.lucene.util.AttributeSource
-
An AttributeSource using the supplied
AttributeSource.AttributeFactory
for creating newAttribute
instances. - AttributeSource.AttributeFactory - Class in org.apache.lucene.util
-
An AttributeFactory creates instances of
AttributeImpl
s. - AttributeSource.State - Class in org.apache.lucene.util
-
This class holds the state of an AttributeSource.
- automatic() - Static method in class org.apache.lucene.search.suggest.fst.Sort.BufferSize
-
Approximately half of the currently available free heap, but no less than
Sort.ABSOLUTE_MIN_SORT_BUFFER_SIZE
. - available() - Method in class org.apache.lucene.util.UnsafeByteArrayInputStream
- 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.search.payloads
-
Calculate the final score as the average score of all payloads seen.
- AveragePayloadFunction() - Constructor for class org.apache.lucene.search.payloads.AveragePayloadFunction
- Avg - org.apache.lucene.search.join.ToParentBlockJoinQuery.ScoreMode
-
Parent hit's score is the average of all child scores.
B
- B - Variable in class org.apache.lucene.spatial.geometry.shape.LineSegment
-
Deprecated.
- BACK - org.apache.lucene.analysis.ngram.EdgeNGramTokenFilter.Side
-
Get the n-gram from the end of the input
- BACK - org.apache.lucene.analysis.ngram.EdgeNGramTokenizer.Side
-
Get the n-gram from the end of the input
- backup(int) - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
-
Backup a number of characters.
- backup(int) - Method in interface org.apache.lucene.queryParser.CharStream
-
Backs up the input stream by amount steps.
- backup(int) - Method in class org.apache.lucene.queryParser.FastCharStream
- backup(int) - Method in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
-
Retreat.
- 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
- BalancedSegmentMergePolicy - Class in org.apache.lucene.index
-
Deprecated.This class is removed in 4.0; use
TieredMergePolicy
instead. - BalancedSegmentMergePolicy() - Constructor for class org.apache.lucene.index.BalancedSegmentMergePolicy
-
Deprecated.
- BalancedSegmentMergePolicy.MergePolicyParams - Class in org.apache.lucene.index
-
Deprecated.Specifies configuration parameters for BalancedSegmentMergePolicy.
- 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.QueryParserConstants
-
RegularExpression Id.
- base - Variable in class org.apache.lucene.index.UpgradeIndexMergePolicy
- base - Variable in class org.apache.lucene.search.CachingCollector
- BaseCharFilter - Class in org.apache.lucene.analysis
-
Base utility class for implementing a
CharFilter
. - BaseCharFilter(CharStream) - Constructor for class org.apache.lucene.analysis.BaseCharFilter
- BaseFormAttribute - Interface in org.apache.lucene.analysis.ja.tokenattributes
-
Attribute for
Token.getBaseForm()
. - BaseFormAttributeImpl - Class in org.apache.lucene.analysis.ja.tokenattributes
-
Attribute for
Token.getBaseForm()
. - BaseFormAttributeImpl() - Constructor for class org.apache.lucene.analysis.ja.tokenattributes.BaseFormAttributeImpl
- BaseFragmentsBuilder - Class in org.apache.lucene.search.vectorhighlight
- BaseFragmentsBuilder() - Constructor for class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
- BaseFragmentsBuilder(String[], String[]) - Constructor for class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
- BaseFragmentsBuilder(String[], String[], BoundaryScanner) - Constructor for class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
- BaseFragmentsBuilder(BoundaryScanner) - Constructor for class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
- 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. - 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.
- BasicQueryFactory - Class in org.apache.lucene.queryParser.surround.query
- BasicQueryFactory() - Constructor for class org.apache.lucene.queryParser.surround.query.BasicQueryFactory
- BasicQueryFactory(int) - Constructor for class org.apache.lucene.queryParser.surround.query.BasicQueryFactory
- BasqueAnalyzer - Class in org.apache.lucene.analysis.eu
-
Analyzer
for Basque. - BasqueAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.eu.BasqueAnalyzer
-
Builds an analyzer with the default stop words:
BasqueAnalyzer.DEFAULT_STOPWORD_FILE
. - BasqueAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.eu.BasqueAnalyzer
-
Builds an analyzer with the given stop words.
- BasqueAnalyzer(Version, Set<?>, Set<?>) - 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
- beforeClass() - Static method in class org.apache.lucene.search.SearchEquivalenceTestBase
- beforeClassLuceneTestCaseJ4() - Static method in class org.apache.lucene.util.LuceneTestCase
- begin - Variable in class org.apache.lucene.queryParser.core.nodes.FieldQueryNode
-
The term's begin position.
- beginColumn - Variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.Token
-
The column number of the first character of this Token.
- beginColumn - Variable in class org.apache.lucene.queryParser.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.
- beginColumn - Variable in class org.apache.lucene.queryParser.Token
-
The column number of the first character of this Token.
- beginLine - Variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.Token
-
The line number of the first character of this Token.
- beginLine - Variable in class org.apache.lucene.queryParser.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.
- beginLine - Variable in class org.apache.lucene.queryParser.Token
-
The line number of the first character of this Token.
- BeginToken() - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
-
Start.
- BeginToken() - Method in interface org.apache.lucene.queryParser.CharStream
-
Returns the next character that marks the beginning of the next token.
- BeginToken() - Method in class org.apache.lucene.queryParser.FastCharStream
- BeginToken() - Method in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
- 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
- Benchmark - Class in org.apache.lucene.benchmark.byTask
-
Run the benchmark algorithm.
- Benchmark(Reader) - Constructor for class org.apache.lucene.benchmark.byTask.Benchmark
- BenchmarkHighlighter - Class in org.apache.lucene.benchmark.byTask.tasks
- BenchmarkHighlighter() - Constructor for class org.apache.lucene.benchmark.byTask.tasks.BenchmarkHighlighter
- bestFit(double) - Method in class org.apache.lucene.spatial.tier.projections.CartesianTierPlotter
-
Deprecated.Find the tier with the best fit for a bounding box Best fit is defined as the ceiling of log2 (circumference of earth / distance) distance is defined as the smallest box fitting the corner between a radius and a bounding box.
- 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
- binaryLength - Variable in class org.apache.lucene.document.AbstractField
- binaryOffset - Variable in class org.apache.lucene.document.AbstractField
- binarySearch(String[], String) - Static method in class org.apache.lucene.search.FieldComparator
- binarySearch(String[], String, int, int) - Static method in class org.apache.lucene.search.FieldComparator
- binarySearchAssociatedDocuments(int) - Method in class org.apache.lucene.store.instantiated.InstantiatedTerm
- binarySearchAssociatedDocuments(int, int) - Method in class org.apache.lucene.store.instantiated.InstantiatedTerm
- binarySearchAssociatedDocuments(int, int, int) - Method in class org.apache.lucene.store.instantiated.InstantiatedTerm
- binarySearchLookup(String) - Method in class org.apache.lucene.search.FieldCache.StringIndex
- bitlist - Static variable in class org.apache.lucene.util.OpenBitSetIterator
- bits - Variable in class org.apache.lucene.util.OpenBitSet
- Bits - Interface in org.apache.lucene.util
-
Interface for Bitset-like structures.
- 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.OpenBitSet
-
returns the number of 64 bit words it would take to hold numBits
- bitSpans(IndexReader) - Method in class org.apache.lucene.search.CachingSpanFilter
- bitSpans(IndexReader) - Method in class org.apache.lucene.search.SpanFilter
-
Returns a SpanFilterResult with true for documents which should be permitted in search results, and false for those that should not and Spans for where the true docs match.
- bitSpans(IndexReader) - Method in class org.apache.lucene.search.SpanQueryFilter
- bitsPerValue - Variable in class org.apache.lucene.util.packed.PackedInts.ReaderImpl
- bitsPerValue - Variable in class org.apache.lucene.util.packed.PackedInts.Writer
- bitsRequired(long) - Static method in class org.apache.lucene.util.packed.PackedInts
-
Returns how many bits are required to hold values up to and including maxValue
- BitUtil - Class in org.apache.lucene.util
-
A variety of high efficiency bit twiddling routines.
- BitVector - Class in org.apache.lucene.util
-
Optimized implementation of a vector of bits.
- BitVector(int) - Constructor for class org.apache.lucene.util.BitVector
-
Constructs a vector capable of holding
n
bits. - BitVector(Directory, String) - Constructor for class org.apache.lucene.util.BitVector
-
Constructs a bit vector from the file
name
in Directoryd
, as written by theBitVector.write(org.apache.lucene.store.Directory, java.lang.String)
method. - BLOCK_SIZE - Static variable in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
- 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(java.util.Collection<org.apache.lucene.document.Document>)
orIndexWriter.updateDocuments(org.apache.lucene.index.Term, java.util.Collection<org.apache.lucene.document.Document>)
API. - BlockGroupingCollector(Sort, int, boolean, Filter) - Constructor for class org.apache.lucene.search.grouping.BlockGroupingCollector
-
Create the single pass collector.
- blockSize - Variable in class org.apache.lucene.util.ByteBlockPool.Allocator
- BODY_FIELD - Static variable in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
- bodyIndexVal - Variable in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
- bodyStoreVal - Variable in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
- 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
- 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.
- BooleanFilter - Class in org.apache.lucene.search
-
A container Filter that allows Boolean composition of Filters.
- BooleanFilter() - Constructor for class org.apache.lucene.search.BooleanFilter
- BooleanFilterBuilder - Class in org.apache.lucene.xmlparser.builders
- BooleanFilterBuilder(FilterBuilder) - Constructor for class org.apache.lucene.xmlparser.builders.BooleanFilterBuilder
- BooleanModifierNode - Class in org.apache.lucene.queryParser.standard.nodes
-
A
BooleanModifierNode
has the same behaviour asModifierQueryNode
, it only indicates that this modifier was added byGroupQueryNodeProcessor
and not by the user. - BooleanModifierNode(QueryNode, ModifierQueryNode.Modifier) - Constructor for class org.apache.lucene.queryParser.standard.nodes.BooleanModifierNode
- BooleanModifiersQueryNodeProcessor - Class in org.apache.lucene.queryParser.precedence.processors
-
This processor is used to apply the correct
ModifierQueryNode
toBooleanQueryNode
s children. - BooleanModifiersQueryNodeProcessor() - Constructor for class org.apache.lucene.queryParser.precedence.processors.BooleanModifiersQueryNodeProcessor
- BooleanQuery - Class in org.apache.lucene.search
-
A Query that matches documents matching boolean combinations of other queries, e.g.
- BooleanQuery() - Constructor for class org.apache.lucene.search.BooleanQuery
-
Constructs an empty boolean query.
- BooleanQuery(boolean) - Constructor for class org.apache.lucene.search.BooleanQuery
-
Constructs an empty boolean query.
- BooleanQuery.BooleanWeight - Class in org.apache.lucene.search
-
Expert: the Weight for BooleanQuery, used to normalize, score and explain these queries.
- BooleanQuery.TooManyClauses - Exception in org.apache.lucene.search
-
Thrown when an attempt is made to add more than
BooleanQuery.getMaxClauseCount()
clauses. - BooleanQuery2ModifierNodeProcessor - Class in org.apache.lucene.queryParser.standard.processors
-
This processor is used to apply the correct
ModifierQueryNode
toBooleanQueryNode
s children. - BooleanQuery2ModifierNodeProcessor() - Constructor for class org.apache.lucene.queryParser.standard.processors.BooleanQuery2ModifierNodeProcessor
- BooleanQueryBuilder - Class in org.apache.lucene.xmlparser.builders
- BooleanQueryBuilder(QueryBuilder) - Constructor for class org.apache.lucene.xmlparser.builders.BooleanQueryBuilder
- BooleanQueryNode - Class in org.apache.lucene.queryParser.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.core.nodes.BooleanQueryNode
- BooleanQueryNodeBuilder - Class in org.apache.lucene.queryParser.standard.builders
-
Builds a
BooleanQuery
object from aBooleanQueryNode
object. - BooleanQueryNodeBuilder() - Constructor for class org.apache.lucene.queryParser.standard.builders.BooleanQueryNodeBuilder
- BOOLEANS - Static variable in class org.apache.lucene.benchmark.Constants
- BooleanSingleChildOptimizationQueryNodeProcessor - Class in org.apache.lucene.queryParser.standard.processors
-
This processor removes every
BooleanQueryNode
that contains only one child and returns this child. - BooleanSingleChildOptimizationQueryNodeProcessor() - Constructor for class org.apache.lucene.queryParser.standard.processors.BooleanSingleChildOptimizationQueryNodeProcessor
- BooleanWeight(Searcher, boolean) - Constructor for class org.apache.lucene.search.BooleanQuery.BooleanWeight
- boost - Variable in class org.apache.lucene.document.AbstractField
- boost(float) - Static method in class org.apache.lucene.util.ToStringUtils
-
for printing boost only if not 1.0
- Boost - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
-
Lexical state.
- Boost - Static variable in interface org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserConstants
-
Lexical state.
- Boost - Static variable in interface org.apache.lucene.queryParser.surround.parser.QueryParserConstants
-
Lexical state.
- BOOST - Static variable in class org.apache.lucene.queryParser.standard.config.StandardQueryConfigHandler.ConfigurationKeys
-
Key used to set the boost value in
FieldConfig
objects. - BoostAttribute - Interface in org.apache.lucene.queryParser.standard.config
-
Deprecated.
- BoostAttributeImpl - Class in org.apache.lucene.queryParser.standard.config
-
Deprecated.
- BoostAttributeImpl() - Constructor for class org.apache.lucene.queryParser.standard.config.BoostAttributeImpl
-
Deprecated.
- BoostingQuery - Class in org.apache.lucene.search
-
The BoostingQuery class can be used to effectively demote results that match a given query.
- BoostingQuery(Query, Query, float) - Constructor for class org.apache.lucene.search.BoostingQuery
- BoostingQueryBuilder - Class in org.apache.lucene.xmlparser.builders
- BoostingQueryBuilder(QueryBuilder) - Constructor for class org.apache.lucene.xmlparser.builders.BoostingQueryBuilder
- BoostingTermBuilder - Class in org.apache.lucene.xmlparser.builders
- BoostingTermBuilder() - Constructor for class org.apache.lucene.xmlparser.builders.BoostingTermBuilder
- BoostQueryNode - Class in org.apache.lucene.queryParser.core.nodes
-
A
BoostQueryNode
boosts the QueryNode tree which is under this node. - BoostQueryNode(QueryNode, float) - Constructor for class org.apache.lucene.queryParser.core.nodes.BoostQueryNode
-
Constructs a boost node
- BoostQueryNodeBuilder - Class in org.apache.lucene.queryParser.standard.builders
-
This builder basically reads the
Query
object set on theBoostQueryNode
child usingQueryTreeBuilder.QUERY_TREE_BUILDER_TAGID
and applies the boost value defined in theBoostQueryNode
. - BoostQueryNodeBuilder() - Constructor for class org.apache.lucene.queryParser.standard.builders.BoostQueryNodeBuilder
- BoostQueryNodeProcessor - Class in org.apache.lucene.queryParser.standard.processors
-
This processor iterates the query node tree looking for every
FieldableNode
that hasStandardQueryConfigHandler.ConfigurationKeys.BOOST
in its config. - BoostQueryNodeProcessor() - Constructor for class org.apache.lucene.queryParser.standard.processors.BoostQueryNodeProcessor
- boosts - Variable in class org.apache.lucene.queryParser.MultiFieldQueryParser
- BOTH - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
-
Output the both the untokenized token and the splits
- boundaryChars - Variable in class org.apache.lucene.search.vectorhighlight.SimpleBoundaryScanner
- BoundaryScanner - Interface in org.apache.lucene.search.vectorhighlight
- bra - Variable in class org.tartarus.snowball.SnowballProgram
- BRAZILIAN_STOP_WORDS - Static variable in class org.apache.lucene.analysis.br.BrazilianAnalyzer
-
Deprecated.use
BrazilianAnalyzer.getDefaultStopSet()
instead - BrazilianAnalyzer - Class in org.apache.lucene.analysis.br
-
Analyzer
for Brazilian Portuguese language. - BrazilianAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.br.BrazilianAnalyzer
-
Builds an analyzer with the default stop words (
BrazilianAnalyzer.getDefaultStopSet()
). - BrazilianAnalyzer(Version, File) - Constructor for class org.apache.lucene.analysis.br.BrazilianAnalyzer
-
Deprecated.use
BrazilianAnalyzer(Version, Set)
instead - BrazilianAnalyzer(Version, String...) - Constructor for class org.apache.lucene.analysis.br.BrazilianAnalyzer
-
Deprecated.use
BrazilianAnalyzer(Version, Set)
instead - BrazilianAnalyzer(Version, Map<?, ?>) - Constructor for class org.apache.lucene.analysis.br.BrazilianAnalyzer
-
Deprecated.use
BrazilianAnalyzer(Version, Set)
instead - BrazilianAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.br.BrazilianAnalyzer
-
Builds an analyzer with the given stop words
- BrazilianAnalyzer(Version, Set<?>, Set<?>) - 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
-
A
TokenFilter
that appliesBrazilianStemmer
. - BrazilianStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.br.BrazilianStemFilter
-
Creates a new BrazilianStemFilter
- BrazilianStemFilter(TokenStream, Set<?>) - Constructor for class org.apache.lucene.analysis.br.BrazilianStemFilter
-
Deprecated.use
KeywordAttribute
withKeywordMarkerFilter
instead. - BrazilianStemmer - Class in org.apache.lucene.analysis.br
-
A stemmer for Brazilian Portuguese words.
- BrazilianStemmer() - Constructor for class org.apache.lucene.analysis.br.BrazilianStemmer
- BreakIteratorBoundaryScanner - Class in org.apache.lucene.search.vectorhighlight
-
A
BoundaryScanner
implementation that usesBreakIterator
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
- buf - Variable in class org.apache.lucene.analysis.util.OpenStringBuilder
- BUF_SIZE_INT - Static variable in class org.apache.lucene.util.NumericUtils
-
Expert: The maximum term length (used for
char[]
buffer size) for encodingint
values. - BUF_SIZE_LONG - Static variable in class org.apache.lucene.util.NumericUtils
-
Expert: The maximum term length (used for
char[]
buffer size) for encodinglong
values. - bufcolumn - Variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
- bufcolumn - Variable in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
- buffer - Variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
- buffer - Variable in class org.apache.lucene.facet.search.PayloadIterator
- buffer - Variable in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
- buffer - Variable in class org.apache.lucene.store.BufferedIndexInput
- buffer - Variable in class org.apache.lucene.util.ByteBlockPool
- buffer() - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
-
Returns the internal termBuffer character array which you can then directly alter.
- buffer() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
- BUFFER_SIZE - Static variable in class org.apache.lucene.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
- BufferedIndexInput - Class in org.apache.lucene.store
-
Base implementation class for buffered
IndexInput
. - BufferedIndexInput() - Constructor for class org.apache.lucene.store.BufferedIndexInput
-
Deprecated.please pass resourceDesc
- BufferedIndexInput(int) - Constructor for class org.apache.lucene.store.BufferedIndexInput
-
Deprecated.please pass resourceDesc
- BufferedIndexInput(String) - Constructor for class org.apache.lucene.store.BufferedIndexInput
- BufferedIndexInput(String, int) - Constructor for class org.apache.lucene.store.BufferedIndexInput
-
Inits BufferedIndexInput with a specific bufferSize
- BufferedIndexOutput - Class in org.apache.lucene.store
-
Base implementation class for buffered
IndexOutput
. - BufferedIndexOutput() - Constructor for class org.apache.lucene.store.BufferedIndexOutput
- BufferingTermFreqIteratorWrapper - Class in org.apache.lucene.search.suggest
-
This wrapper buffers incoming elements.
- BufferingTermFreqIteratorWrapper(TermFreqIterator) - Constructor for class org.apache.lucene.search.suggest.BufferingTermFreqIteratorWrapper
- buffers - Variable in class org.apache.lucene.store.RAMFile
- buffers - Variable in class org.apache.lucene.util.ByteBlockPool
- bufferSize - Variable in class org.apache.lucene.search.suggest.fst.Sort.SortInfo
- bufline - Variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
- bufline - Variable in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
- bufpos - Variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
-
Position in buffer.
- bufpos - Variable in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
-
Position in buffer.
- build() - Method in class org.apache.lucene.analysis.synonym.SynonymMap.Builder
-
Builds an
SynonymMap
and returns it. - build() - Method in class org.apache.lucene.search.suggest.fst.FSTCompletionBuilder
-
Builds the final automaton from a list of added entries.
- build(Document) - Method in class org.apache.lucene.facet.index.CategoryDocumentBuilder
-
Adds the fields created in one of the "set" methods to the document
- build(QueryNode) - Method in interface org.apache.lucene.queryParser.core.builders.QueryBuilder
-
Builds some kind of object from a query tree.
- build(QueryNode) - Method in class org.apache.lucene.queryParser.core.builders.QueryTreeBuilder
-
Builds some kind of object from a query tree.
- build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.AnyQueryNodeBuilder
- build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.BooleanQueryNodeBuilder
- build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.BoostQueryNodeBuilder
- build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.DummyQueryNodeBuilder
-
Always return
null
. - build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.FieldQueryNodeBuilder
- build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.FuzzyQueryNodeBuilder
- build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.GroupQueryNodeBuilder
- build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.MatchAllDocsQueryNodeBuilder
- build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.MatchNoDocsQueryNodeBuilder
- build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.ModifierQueryNodeBuilder
- build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.MultiPhraseQueryNodeBuilder
- build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.NumericRangeQueryNodeBuilder
- build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.PhraseQueryNodeBuilder
- build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.PrefixWildcardQueryNodeBuilder
- build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.RangeQueryNodeBuilder
-
Deprecated.
- build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.SlopQueryNodeBuilder
- build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.StandardBooleanQueryNodeBuilder
- build(QueryNode) - Method in interface org.apache.lucene.queryParser.standard.builders.StandardQueryBuilder
- build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.StandardQueryTreeBuilder
- build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.TermRangeQueryNodeBuilder
- build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.WildcardQueryNodeBuilder
- build(Dictionary) - Method in class org.apache.lucene.search.suggest.Lookup
-
Build lookup from a dictionary.
- build(TermFreqIterator) - Method in class org.apache.lucene.search.suggest.fst.FSTCompletionLookup
-
Builds up a new internal
Lookup
representation based on the givenTermFreqIterator
. - build(TermFreqIterator) - Method in class org.apache.lucene.search.suggest.fst.FSTLookup
-
Deprecated.
- build(TermFreqIterator) - Method in class org.apache.lucene.search.suggest.fst.WFSTCompletionLookup
- build(TermFreqIterator) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellLookup
- build(TermFreqIterator) - Method in class org.apache.lucene.search.suggest.Lookup
-
Builds up a new internal
Lookup
representation based on the givenTermFreqIterator
. - build(TermFreqIterator) - Method in class org.apache.lucene.search.suggest.tst.TSTLookup
- 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(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(FST.INPUT_TYPE, int, int, boolean, boolean, int, Outputs<T>, Builder.FreezeTail<T>, boolean) - Constructor for class org.apache.lucene.util.fst.Builder
-
Instantiates an FST/FSA builder with all the possible tuning and construction tweaks.
- Builder(FST.INPUT_TYPE, Outputs<T>) - Constructor for class org.apache.lucene.util.fst.Builder
-
Instantiates an FST/FSA builder without any pruning.
- Builder.Arc<T> - Class in org.apache.lucene.util.fst
-
Expert: holds a pending (seen but not yet serialized) arc.
- Builder.FreezeTail<T> - Class in org.apache.lucene.util.fst
-
Expert: this is invoked by Builder whenever a suffix is serialized.
- 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.
- buildFieldConfig(FieldConfig) - Method in interface org.apache.lucene.queryParser.core.config.FieldConfigListener
-
This method is called ever time a field configuration is requested.
- buildFieldConfig(FieldConfig) - Method in class org.apache.lucene.queryParser.standard.config.FieldBoostMapFCListener
- buildFieldConfig(FieldConfig) - Method in class org.apache.lucene.queryParser.standard.config.FieldDateResolutionFCListener
- buildFieldConfig(FieldConfig) - Method in class org.apache.lucene.queryParser.standard.config.NumericFieldConfigListener
- BulgarianAnalyzer - Class in org.apache.lucene.analysis.bg
-
Analyzer
for Bulgarian. - BulgarianAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.bg.BulgarianAnalyzer
-
Builds an analyzer with the default stop words:
BulgarianAnalyzer.DEFAULT_STOPWORD_FILE
. - BulgarianAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.bg.BulgarianAnalyzer
-
Builds an analyzer with the given stop words.
- BulgarianAnalyzer(Version, Set<?>, Set<?>) - 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
-
A
TokenFilter
that appliesBulgarianStemmer
to stem Bulgarian words. - BulgarianStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.bg.BulgarianStemFilter
- BulgarianStemmer - Class in org.apache.lucene.analysis.bg
-
Light Stemmer for Bulgarian.
- BulgarianStemmer() - Constructor for class org.apache.lucene.analysis.bg.BulgarianStemmer
- ByDocComparator() - Constructor for class org.apache.lucene.index.pruning.CarmelTopKTermPruningPolicy.ByDocComparator
- ByDocComparator() - Constructor for class org.apache.lucene.index.pruning.CarmelUniformTermPruningPolicy.ByDocComparator
- BYTE - Static variable in class org.apache.lucene.search.function.FieldScoreQuery.Type
-
field values are interpreted as numeric byte values.
- BYTE - Static variable in class org.apache.lucene.search.SortField
-
Sort using term values as encoded Bytes.
- 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
- BYTE1 - org.apache.lucene.util.fst.FST.INPUT_TYPE
- BYTE2 - org.apache.lucene.util.fst.FST.INPUT_TYPE
- byte315ToFloat(byte) - Static method in class org.apache.lucene.util.SmallFloat
-
byteToFloat(b, mantissaBits=3, zeroExponent=15)
- BYTE4 - org.apache.lucene.util.fst.FST.INPUT_TYPE
- byte52ToFloat(byte) - Static method in class org.apache.lucene.util.SmallFloat
-
byteToFloat(b, mantissaBits=5, zeroExponent=2)
- byteArray(StringBuilder, byte[]) - Static method in class org.apache.lucene.util.ToStringUtils
- ByteArrayDataInput - Class in org.apache.lucene.store
-
DataInput backed by a byte array.
- ByteArrayDataInput() - Constructor for class org.apache.lucene.store.ByteArrayDataInput
- ByteArrayDataInput(byte[]) - Constructor for class org.apache.lucene.store.ByteArrayDataInput
- ByteArrayDataInput(byte[], int, int) - Constructor for class org.apache.lucene.store.ByteArrayDataInput
- ByteArrayDataOutput - Class in org.apache.lucene.store
-
DataOutput backed by a byte array.
- ByteArrayDataOutput() - Constructor for class org.apache.lucene.store.ByteArrayDataOutput
- ByteArrayDataOutput(byte[]) - Constructor for class org.apache.lucene.store.ByteArrayDataOutput
- ByteArrayDataOutput(byte[], int, int) - Constructor for class org.apache.lucene.store.ByteArrayDataOutput
- byteAt(int) - Method in class org.apache.lucene.index.Payload
-
Returns the byte at the given index.
- ByteBlockPool - Class in org.apache.lucene.util
-
Class that Posting and PostingVector use to write byte streams into shared fixed-size byte[] arrays.
- ByteBlockPool(ByteBlockPool.Allocator) - Constructor for class org.apache.lucene.util.ByteBlockPool
- ByteBlockPool.Allocator - Class in org.apache.lucene.util
-
Abstract class for allocating and freeing byte blocks.
- ByteBlockPool.DirectAllocator - Class in org.apache.lucene.util
-
A simple
ByteBlockPool.Allocator
that never recycles. - ByteBlockPool.DirectTrackingAllocator - Class in org.apache.lucene.util
-
A simple
ByteBlockPool.Allocator
that never recycles, but tracks how much total RAM is in use. - ByteFieldSource - Class in org.apache.lucene.search.function
-
Expert: obtains single byte field values from the
FieldCache
usinggetBytes()
and makes those values available as other numeric types, casting as needed. - ByteFieldSource(String) - Constructor for class org.apache.lucene.search.function.ByteFieldSource
-
Create a cached byte field source with default string-to-byte parser.
- ByteFieldSource(String, FieldCache.ByteParser) - Constructor for class org.apache.lucene.search.function.ByteFieldSource
-
Create a cached byte field source with a specific string-to-byte parser.
- byteOffset - Variable in class org.apache.lucene.util.ByteBlockPool
- bytes - Variable in class org.apache.lucene.util.BytesRef
-
The contents of the BytesRef.
- bytes - Variable in class org.apache.lucene.util.fst.FST.BytesReader
- BYTES_FIELD - Static variable in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
- bytesDifference(byte[], int, byte[], int) - Static method in class org.apache.lucene.util.StringHelper
-
Compares two byte[] arrays, element by element, and returns the number of elements common to both arrays.
- bytesEquals(BytesRef) - Method in class org.apache.lucene.util.BytesRef
-
Expert: compares the bytes against another BytesRef, returning true if the bytes are equal.
- ByteSequenceOutputs - Class in org.apache.lucene.util.fst
-
An FST
Outputs
implementation where each output is a sequence of bytes. - ByteSequencesReader(DataInput) - Constructor for class org.apache.lucene.search.suggest.fst.Sort.ByteSequencesReader
- ByteSequencesReader(File) - Constructor for class org.apache.lucene.search.suggest.fst.Sort.ByteSequencesReader
- ByteSequencesWriter(DataOutput) - Constructor for class org.apache.lucene.search.suggest.fst.Sort.ByteSequencesWriter
- ByteSequencesWriter(File) - Constructor for class org.apache.lucene.search.suggest.fst.Sort.ByteSequencesWriter
- bytesNeeded(int) - Static method in class org.apache.lucene.util.Vint8
-
Returns the number of bytes needed to encode
number
. - BytesReader(byte[], int) - Constructor for class org.apache.lucene.util.fst.FST.BytesReader
- BytesRef - Class in org.apache.lucene.util
-
Represents byte[], as a slice (offset + length) into an existing byte[].
- BytesRef() - Constructor for class org.apache.lucene.util.BytesRef
-
Create a BytesRef with
BytesRef.EMPTY_BYTES
- BytesRef(byte[]) - Constructor for class org.apache.lucene.util.BytesRef
-
This instance will directly reference bytes w/o making a copy.
- BytesRef(byte[], int, int) - Constructor for class org.apache.lucene.util.BytesRef
-
This instance will directly reference bytes w/o making a copy.
- BytesRef(int) - Constructor for class org.apache.lucene.util.BytesRef
-
Create a BytesRef pointing to a new array of size
capacity
. - BytesRef(CharSequence) - Constructor for class org.apache.lucene.util.BytesRef
-
Initialize the byte[] from the UTF8 bytes for the provided String.
- BytesRefFSTEnum<T> - Class in org.apache.lucene.util.fst
-
Enumerates all input (BytesRef) + output pairs in an FST.
- BytesRefFSTEnum(FST<T>) - Constructor for class org.apache.lucene.util.fst.BytesRefFSTEnum
-
doFloor controls the behavior of advance: if it's true doFloor is true, advance positions to the biggest term before target.
- BytesRefFSTEnum.InputOutput<T> - Class in org.apache.lucene.util.fst
-
Holds a single input (BytesRef) + output pair.
- BytesRefHash - Class in org.apache.lucene.util
-
BytesRefHash
is a special purpose hash-map like data-structure optimized forBytesRef
instances. - BytesRefHash() - Constructor for class org.apache.lucene.util.BytesRefHash
- BytesRefHash(ByteBlockPool) - Constructor for class org.apache.lucene.util.BytesRefHash
-
Creates a new
BytesRefHash
- BytesRefHash(ByteBlockPool, int, BytesRefHash.BytesStartArray) - Constructor for class org.apache.lucene.util.BytesRefHash
-
Creates a new
BytesRefHash
- BytesRefHash.BytesStartArray - Class in org.apache.lucene.util
-
Manages allocation of the per-term addresses.
- BytesRefHash.DirectBytesStartArray - Class in org.apache.lucene.util
-
A simple
BytesRefHash.BytesStartArray
that tracks memory allocation using a privateAtomicLong
instance. - BytesRefHash.MaxBytesLengthExceededException - Exception in org.apache.lucene.util
- BytesRefHash.TrackingDirectBytesStartArray - Class in org.apache.lucene.util
-
A simple
BytesRefHash.BytesStartArray
that tracks all memory allocation using a sharedAtomicLong
instance. - BytesRefIterator - Interface in org.apache.lucene.util
-
A simple iterator interface for
BytesRef
iteration. - BytesRefList - Class in org.apache.lucene.search.suggest
-
A simple append only random-access
BytesRef
array that stores full copies of the appended bytes in aByteBlockPool
. - BytesRefList() - Constructor for class org.apache.lucene.search.suggest.BytesRefList
-
Creates a new
BytesRefList
- BytesRefSorter - Interface in org.apache.lucene.search.suggest.fst
-
Collects
BytesRef
and then allows one to iterate over their sorted order. - 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 ord - bytesToCharSequence(BytesRef, Random) - Static method in class org.apache.lucene.util._TestUtil
- bytesUsed - Variable in class org.apache.lucene.util.BytesRefHash.TrackingDirectBytesStartArray
- bytesUsed() - Method in class org.apache.lucene.search.suggest.BytesRefList
-
Returns the number internally used bytes to hold the appended bytes in memory
- bytesUsed() - Method in class org.apache.lucene.util.BytesRefHash.BytesStartArray
-
A
AtomicLong
reference holding the number of bytes used by thisBytesRefHash.BytesStartArray
. - bytesUsed() - Method in class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
- bytesUsed() - Method in class org.apache.lucene.util.BytesRefHash.TrackingDirectBytesStartArray
- bytesUsed() - Method in class org.apache.lucene.util.RecyclingByteBlockAllocator
- byteToFloat(byte, int, int) - Static method in class org.apache.lucene.util.SmallFloat
-
Converts an 8 bit float to a 32 bit float.
- byteUpto - Variable in class org.apache.lucene.util.ByteBlockPool
- 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(byte[]) - Constructor for class org.apache.lucene.analysis.compound.hyphenation.ByteVector
- ByteVector(byte[], int) - Constructor for class org.apache.lucene.analysis.compound.hyphenation.ByteVector
- ByteVector(int) - Constructor for class org.apache.lucene.analysis.compound.hyphenation.ByteVector
- BZIP2 - org.apache.lucene.benchmark.byTask.utils.StreamUtils.Type
-
BZIP2 is automatically used for .bz2 and .bzip2 extensions.
C
- cache - Variable in class org.apache.lucene.search.CachingWrapperFilter
- cache - Variable in class org.apache.lucene.search.FilterManager
-
Deprecated.The cache itself
- cacheCleanSize - Variable in class org.apache.lucene.search.FilterManager
-
Deprecated.Maximum allowed cache size
- cachedDocs - Variable in class org.apache.lucene.search.CachingCollector
- cachedFieldSourceEquals(FieldCacheSource) - Method in class org.apache.lucene.search.function.ByteFieldSource
- cachedFieldSourceEquals(FieldCacheSource) - Method in class org.apache.lucene.search.function.FieldCacheSource
-
Check if equals to another
FieldCacheSource
, already knowing that cache and field are equal. - cachedFieldSourceEquals(FieldCacheSource) - Method in class org.apache.lucene.search.function.FloatFieldSource
- cachedFieldSourceEquals(FieldCacheSource) - Method in class org.apache.lucene.search.function.IntFieldSource
- cachedFieldSourceEquals(FieldCacheSource) - Method in class org.apache.lucene.search.function.ShortFieldSource
- cachedFieldSourceHashCode() - Method in class org.apache.lucene.search.function.ByteFieldSource
- cachedFieldSourceHashCode() - Method in class org.apache.lucene.search.function.FieldCacheSource
-
Return a hash code of a
FieldCacheSource
, without the hash-codes of the field and the cache (those are taken care of elsewhere). - cachedFieldSourceHashCode() - Method in class org.apache.lucene.search.function.FloatFieldSource
- cachedFieldSourceHashCode() - Method in class org.apache.lucene.search.function.IntFieldSource
- cachedFieldSourceHashCode() - Method in class org.apache.lucene.search.function.ShortFieldSource
- CachedFilterBuilder - Class in org.apache.lucene.xmlparser.builders
-
Filters are cached in an LRU Cache keyed on the contained query or filter object.
- CachedFilterBuilder(QueryBuilderFactory, FilterBuilderFactory, int) - Constructor for class org.apache.lucene.xmlparser.builders.CachedFilterBuilder
- cachedSegs - Variable in class org.apache.lucene.search.CachingCollector
- CacheEntry() - Constructor for class org.apache.lucene.search.FieldCache.CacheEntry
- CachingCollector - Class in org.apache.lucene.search
-
Caches all docs, and optionally also scores, coming from a search, and is then able to replay them to another collector.
- CachingSpanFilter - Class in org.apache.lucene.search
-
Wraps another SpanFilter's result and caches it.
- CachingSpanFilter(SpanFilter) - Constructor for class org.apache.lucene.search.CachingSpanFilter
-
New deletions always result in a cache miss, by default (
CachingWrapperFilter.DeletesMode.RECACHE
. - CachingSpanFilter(SpanFilter, CachingWrapperFilter.DeletesMode) - Constructor for class org.apache.lucene.search.CachingSpanFilter
- CachingTokenFilter - Class in org.apache.lucene.analysis
-
This class can be used if the token attributes of a TokenStream are intended to be consumed more than once.
- CachingTokenFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.CachingTokenFilter
- CachingWrapperFilter - Class in org.apache.lucene.search
-
Wraps another filter's result and caches it.
- CachingWrapperFilter(Filter) - Constructor for class org.apache.lucene.search.CachingWrapperFilter
-
New deletes are ignored by default, which gives higher cache hit rate on reopened readers.
- CachingWrapperFilter(Filter, CachingWrapperFilter.DeletesMode) - Constructor for class org.apache.lucene.search.CachingWrapperFilter
-
Expert: by default, the cached filter will be shared across reopened segments that only had changes to their deletions.
- CachingWrapperFilter.DeletesMode - Enum in org.apache.lucene.search
-
Expert: Specifies how new deletions against a reopened reader should be handled.
- CachingWrapperFilterHelper - Class in org.apache.lucene.search
-
A unit test helper class to test when the filter is getting cached and when it is not.
- CachingWrapperFilterHelper(Filter) - Constructor for class org.apache.lucene.search.CachingWrapperFilterHelper
- calcBaseHashIndex(float) - Method in class org.apache.lucene.util.collections.FloatToObjectMap
-
Calculating the baseHash index using the internal
hashFactor
. - calcBaseHashIndex(int) - Method in class org.apache.lucene.util.collections.IntHashSet
-
Calculating the baseHash index using the internal
hashFactor
. - calcBaseHashIndex(int) - Method in class org.apache.lucene.util.collections.IntToDoubleMap
-
Calculating the baseHash index using the internal
hashFactor
. - calcBaseHashIndex(int) - Method in class org.apache.lucene.util.collections.IntToIntMap
-
Calculating the baseHash index using the internal
hashFactor
. - calcBaseHashIndex(int) - Method in class org.apache.lucene.util.collections.IntToObjectMap
-
Calculating the baseHash index using the internal
hashFactor
. - calcBaseHashIndex(K) - Method in class org.apache.lucene.util.collections.ArrayHashMap
-
Calculating the baseHash index using the internal internal
hashFactor
. - calcBaseHashIndex(K) - Method in class org.apache.lucene.util.collections.ObjectToFloatMap
-
Calculating the baseHash index using the internal
hashFactor
. - calcBaseHashIndex(K) - Method in class org.apache.lucene.util.collections.ObjectToIntMap
-
Calculating the baseHash index using the internal
hashFactor
. - calculateMidpoint(LatLng) - Method in class org.apache.lucene.spatial.geometry.FixedLatLng
-
Deprecated.
- calculateMidpoint(LatLng) - Method in class org.apache.lucene.spatial.geometry.FloatLatLng
-
Deprecated.
- calculateMidpoint(LatLng) - Method in class org.apache.lucene.spatial.geometry.LatLng
-
Deprecated.Calculate the midpoint between this point an another.
- calculateShingleWeight(Token, List<Token>, int, List<ShingleMatrixFilter.Matrix.Column.Row>, List<Token>) - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter
-
Deprecated.Evaluates the new shingle token weight.
- calibrateSizeByDeletes - Variable in class org.apache.lucene.index.LogMergePolicy
- CannedTokenStream - Class in org.apache.lucene.analysis
-
TokenStream from a canned list of Tokens.
- CannedTokenStream(Token...) - Constructor for class org.apache.lucene.analysis.CannedTokenStream
- cantOpenSegments - Variable in class org.apache.lucene.index.CheckIndex.Status
-
True if we were unable to open the segments_N file.
- capacity() - Method in class org.apache.lucene.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
- capacity() - Method in class org.apache.lucene.facet.taxonomy.writercache.cl2o.CollisionMap
- capacity() - Method in class org.apache.lucene.util.OpenBitSet
-
Returns the current capacity in bits (1 greater than the index of the last bit)
- capacityChars() - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
-
Returns the current character capacity of the CategoryPath.
- capacityComponents() - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
-
Returns the current component capacity of the CategoryPath.
- captureState() - Method in class org.apache.lucene.util.AttributeSource
-
Captures the state of all Attributes.
- CARAT - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
-
RegularExpression Id.
- CARAT - Static variable in interface org.apache.lucene.queryParser.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.FixedBitSet
-
Returns number of set bits.
- cardinality() - Method in class org.apache.lucene.util.OpenBitSet
- CarmelTopKTermPruningPolicy - Class in org.apache.lucene.index.pruning
-
Pruning policy with a search quality parameterized guarantee - configuration of this policy allows to specify two parameters: k and ε such that:
- CarmelTopKTermPruningPolicy(IndexReader, Map<String, Integer>) - Constructor for class org.apache.lucene.index.pruning.CarmelTopKTermPruningPolicy
-
Constructor with default parameters
- CarmelTopKTermPruningPolicy(IndexReader, Map<String, Integer>, int, float, int, Similarity) - Constructor for class org.apache.lucene.index.pruning.CarmelTopKTermPruningPolicy
-
Constructor with specific settings
- CarmelTopKTermPruningPolicy.ByDocComparator - Class in org.apache.lucene.index.pruning
- CarmelUniformTermPruningPolicy - Class in org.apache.lucene.index.pruning
-
Enhanced implementation of Carmel Uniform Pruning,
- CarmelUniformTermPruningPolicy(IndexReader, Map<String, Integer>, Map<String, Float>, float, Similarity) - Constructor for class org.apache.lucene.index.pruning.CarmelUniformTermPruningPolicy
- CarmelUniformTermPruningPolicy.ByDocComparator - Class in org.apache.lucene.index.pruning
- CartesianPoint - Class in org.apache.lucene.spatial.geometry
-
Deprecated.
- CartesianPoint(int, int) - Constructor for class org.apache.lucene.spatial.geometry.CartesianPoint
-
Deprecated.
- CartesianPolyFilterBuilder - Class in org.apache.lucene.spatial.tier
-
Deprecated.
- CartesianPolyFilterBuilder(String, int, int) - Constructor for class org.apache.lucene.spatial.tier.CartesianPolyFilterBuilder
-
Deprecated.
- CartesianShapeFilter - Class in org.apache.lucene.spatial.tier
-
Deprecated.
- CartesianTierPlotter - Class in org.apache.lucene.spatial.tier.projections
-
Deprecated.
- CartesianTierPlotter(int, IProjector, String) - Constructor for class org.apache.lucene.spatial.tier.projections.CartesianTierPlotter
-
Deprecated.
- CatalanAnalyzer - Class in org.apache.lucene.analysis.ca
-
Analyzer
for Catalan. - CatalanAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.ca.CatalanAnalyzer
-
Builds an analyzer with the default stop words:
CatalanAnalyzer.DEFAULT_STOPWORD_FILE
. - CatalanAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.ca.CatalanAnalyzer
-
Builds an analyzer with the given stop words.
- CatalanAnalyzer(Version, Set<?>, Set<?>) - 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
- categoriesMap - Variable in class org.apache.lucene.facet.index.CategoryDocumentBuilder
- CATEGORY - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
- CATEGORY_ID - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
- categoryAttribute - Variable in class org.apache.lucene.facet.index.streaming.CategoryAttributesStream
- categoryAttribute - Variable in class org.apache.lucene.facet.index.streaming.CategoryParentsStream
-
An attribute containing all data related to the category
- categoryAttribute - Variable in class org.apache.lucene.facet.index.streaming.CategoryTokenizerBase
-
The stream's category attributes.
- CategoryAttribute - Interface in org.apache.lucene.facet.index.attributes
-
An attribute which contains for a certain category the
CategoryPath
and additional properties. - CategoryAttributeImpl - Class in org.apache.lucene.facet.index.attributes
-
An implementation of
CategoryAttribute
. - CategoryAttributeImpl() - Constructor for class org.apache.lucene.facet.index.attributes.CategoryAttributeImpl
-
Construct an empty CategoryAttributeImpl.
- CategoryAttributeImpl(CategoryPath) - Constructor for class org.apache.lucene.facet.index.attributes.CategoryAttributeImpl
-
Construct a CategoryAttributeImpl with the given CategoryPath.
- CategoryAttributesIterable - Class in org.apache.lucene.facet.index.attributes
-
This class transforms an
Iterable
ofCategoryPath
objects into anIterable
ofCategoryAttribute
objects, which can be used to construct aCategoryAttributesStream
. - CategoryAttributesIterable(Iterable<CategoryPath>) - Constructor for class org.apache.lucene.facet.index.attributes.CategoryAttributesIterable
- CategoryAttributesStream - Class in org.apache.lucene.facet.index.streaming
-
An attribute stream built from an
Iterable
ofCategoryAttribute
. - CategoryAttributesStream(Iterable<CategoryAttribute>) - Constructor for class org.apache.lucene.facet.index.streaming.CategoryAttributesStream
-
Constructor
- CategoryContainer - Class in org.apache.lucene.facet.index
-
A container to add categories which are to be introduced to
CategoryDocumentBuilder.setCategories(Iterable)
. - CategoryContainer() - Constructor for class org.apache.lucene.facet.index.CategoryContainer
-
Constructor.
- CategoryDocumentBuilder - Class in org.apache.lucene.facet.index
-
A utility class which allows attachment of
CategoryPath
s orCategoryAttribute
s to a given document using a taxonomy.
Construction could be done with either a givenFacetIndexingParams
or the default implementationDefaultFacetIndexingParams
.
A CategoryDocumentBuilder can be reused by repeatedly setting the categories and building the document. - CategoryDocumentBuilder(TaxonomyWriter) - Constructor for class org.apache.lucene.facet.index.CategoryDocumentBuilder
-
Creating a facets document builder with default facet indexing parameters.
See:CategoryDocumentBuilder(TaxonomyWriter, FacetIndexingParams)
- CategoryDocumentBuilder(TaxonomyWriter, FacetIndexingParams) - Constructor for class org.apache.lucene.facet.index.CategoryDocumentBuilder
-
Creating a facets document builder with a given facet indexing parameters object.
- CategoryEnhancement - Interface in org.apache.lucene.facet.enhancements
-
This interface allows easy addition of enhanced category features.
- CategoryListCache - Class in org.apache.lucene.facet.search.cache
-
Cache for
CategoryListData
, perCategoryListParams
. - CategoryListCache() - Constructor for class org.apache.lucene.facet.search.cache.CategoryListCache
- CategoryListData - Class in org.apache.lucene.facet.search.cache
-
Category list data maintained in RAM.
- CategoryListData() - Constructor for class org.apache.lucene.facet.search.cache.CategoryListData
-
Empty constructor for extensions with modified computation of the data.
- CategoryListIterator - Interface in org.apache.lucene.facet.search
-
An interface for iterating over a "category list", i.e., the list of categories per document.
- CategoryListParams - Class in org.apache.lucene.facet.index.params
-
Contains parameters for a category list *
- CategoryListParams() - Constructor for class org.apache.lucene.facet.index.params.CategoryListParams
-
Constructs a default category list parameters object, using
CategoryListParams.DEFAULT_TERM
. - CategoryListParams(Term) - Constructor for class org.apache.lucene.facet.index.params.CategoryListParams
-
Constructs a category list parameters object, using the given
Term
. - CategoryListPayloadStream - Class in org.apache.lucene.facet.index
-
Accumulates category IDs for a single document, for writing in byte array form, for example, to a Lucene Payload.
- CategoryListPayloadStream(IntEncoder) - Constructor for class org.apache.lucene.facet.index.CategoryListPayloadStream
-
Creates a Payload stream using the specified encoder.
- CategoryListTokenizer - Class in org.apache.lucene.facet.index.streaming
-
A base class for category list tokenizers, which add category list tokens to category streams.
- CategoryListTokenizer(TokenStream, FacetIndexingParams) - Constructor for class org.apache.lucene.facet.index.streaming.CategoryListTokenizer
- CategoryParentsStream - Class in org.apache.lucene.facet.index.streaming
-
This class adds parents to a
CategoryAttributesStream
. - CategoryParentsStream(CategoryAttributesStream, TaxonomyWriter, FacetIndexingParams) - Constructor for class org.apache.lucene.facet.index.streaming.CategoryParentsStream
-
Constructor.
- categoryPath - Variable in class org.apache.lucene.facet.index.attributes.CategoryAttributeImpl
-
The category path instance.
- CategoryPath - Class in org.apache.lucene.facet.taxonomy
-
A CategoryPath holds a sequence of string components, specifying the hierarchical name of a category.
- CategoryPath() - Constructor for class org.apache.lucene.facet.taxonomy.CategoryPath
-
Create an empty CategoryPath object.
- CategoryPath(int, int) - Constructor for class org.apache.lucene.facet.taxonomy.CategoryPath
-
Construct a new empty CategoryPath object.
- CategoryPath(CharSequence...) - Constructor for class org.apache.lucene.facet.taxonomy.CategoryPath
-
Construct a new CategoryPath object, copying an existing path given as an array of strings.
- CategoryPath(String, char) - Constructor for class org.apache.lucene.facet.taxonomy.CategoryPath
-
Construct a new CategoryPath object, given a single string with components separated by a given delimiter character.
- CategoryPath(CategoryPath) - Constructor for class org.apache.lucene.facet.taxonomy.CategoryPath
-
Construct a new CategoryPath object, copying the path given in an existing CategoryPath object.
- CategoryPath(CategoryPath, int) - Constructor for class org.apache.lucene.facet.taxonomy.CategoryPath
-
Construct a new CategoryPath object, copying a prefix with the given number of components of the path given in an existing CategoryPath object.
- CategoryProperty - Interface in org.apache.lucene.facet.index.attributes
-
Property that can be added to
CategoryAttribute
s during indexing. - CategoryTokenizer - Class in org.apache.lucene.facet.index.streaming
-
Basic class for setting the
CharTermAttribute
s andPayloadAttribute
s of category tokens. - CategoryTokenizer(TokenStream, FacetIndexingParams) - Constructor for class org.apache.lucene.facet.index.streaming.CategoryTokenizer
- CategoryTokenizerBase - Class in org.apache.lucene.facet.index.streaming
-
A base class for all token filters which add term and payload attributes to tokens and are to be used in
CategoryDocumentBuilder
. - CategoryTokenizerBase(TokenStream, FacetIndexingParams) - Constructor for class org.apache.lucene.facet.index.streaming.CategoryTokenizerBase
-
Constructor.
- centroid() - Method in class org.apache.lucene.spatial.geometry.shape.Ellipse
-
Deprecated.
- centroid() - Method in interface org.apache.lucene.spatial.geometry.shape.Geometry2D
-
Deprecated.Return the centroid
- centroid() - Method in class org.apache.lucene.spatial.geometry.shape.Rectangle
-
Deprecated.
- ChainedFilter - Class in org.apache.lucene.search
-
Allows multiple
Filter
s to be chained. - ChainedFilter(Filter[]) - Constructor for class org.apache.lucene.search.ChainedFilter
-
Ctor.
- ChainedFilter(Filter[], int) - Constructor for class org.apache.lucene.search.ChainedFilter
-
Ctor.
- ChainedFilter(Filter[], int[]) - Constructor for class org.apache.lucene.search.ChainedFilter
-
Ctor.
- changed() - Method in class org.apache.lucene.index.SegmentInfos
-
Call this before committing if changes have been made to the segments.
- CharacterDefinition - Class in org.apache.lucene.analysis.ja.dict
-
Character category data.
- characters(char[], int, int) - Method in class org.apache.lucene.analysis.compound.hyphenation.PatternParser
- CharacterUtils - Class in org.apache.lucene.util
-
CharacterUtils
provides a unified interface to Character-related operations to implement backwards compatible character operations based on aVersion
instance. - CharacterUtils() - Constructor for class org.apache.lucene.util.CharacterUtils
- CharacterUtils.CharacterBuffer - Class in org.apache.lucene.util
-
A simple IO buffer to use with
CharacterUtils.fill(CharacterBuffer, Reader)
. - 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(Version, int, boolean) - Constructor for class org.apache.lucene.analysis.CharArrayMap
-
Create map with enough capacity to hold startSize terms
- CharArrayMap(Version, Map<?, ? extends V>, boolean) - Constructor for class org.apache.lucene.analysis.CharArrayMap
-
Creates a map from the mappings in another map.
- CharArrayMap.EntryIterator - Class in org.apache.lucene.analysis
-
public iterator class so efficient methods are exposed to users
- CharArrayMap.EntrySet - Class in org.apache.lucene.analysis
-
public EntrySet class so efficient methods are exposed to users
- CharArraySet - Class in org.apache.lucene.analysis
-
A simple class that stores Strings as char[]'s in a hash table.
- CharArraySet(int, boolean) - Constructor for class org.apache.lucene.analysis.CharArraySet
-
Deprecated.use
CharArraySet(Version, int, boolean)
instead - CharArraySet(Collection<?>, boolean) - Constructor for class org.apache.lucene.analysis.CharArraySet
-
Deprecated.use
CharArraySet(Version, Collection, boolean)
instead - CharArraySet(Version, int, boolean) - Constructor for class org.apache.lucene.analysis.CharArraySet
-
Create set with enough capacity to hold startSize terms
- CharArraySet(Version, Collection<?>, boolean) - Constructor for class org.apache.lucene.analysis.CharArraySet
-
Creates a set from a Collection of objects.
- CharArraySet.CharArraySetIterator - Class in org.apache.lucene.analysis
-
Deprecated.Use the standard iterator, which returns
char[]
instances. - charAt(int) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
- charAt(int) - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
- charAt(int) - Method in class org.apache.lucene.queryParser.core.util.UnescapedCharSequence
- charAt(int) - Method in class org.apache.lucene.util.CharsRef
- CharFilter - Class in org.apache.lucene.analysis
-
Subclasses of CharFilter can be chained to filter CharStream.
- CharFilter(CharStream) - Constructor for class org.apache.lucene.analysis.CharFilter
- CharReader - Class in org.apache.lucene.analysis
-
CharReader is a Reader wrapper.
- chars - Variable in class org.apache.lucene.facet.taxonomy.CategoryPath
- chars - Variable in class org.apache.lucene.util.CharsRef
- 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
- charset - Variable in class org.apache.lucene.analysis.payloads.IdentityEncoder
- CHARSET_UTF_8 - Static variable in class org.apache.lucene.util.IOUtils
-
UTF-8
Charset
instance to prevent repeatedCharset.forName(String)
lookups - charsetName - Variable in class org.apache.lucene.analysis.payloads.IdentityEncoder
-
Deprecated.This field is no longer used. Use
IdentityEncoder.charset
instead. - charsNeededForFullPath() - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
-
Returns the number of characters required to represent this entire category path, if written using
CategoryPath.copyToCharArray(char[], int, int, char)
orCategoryPath.appendTo(Appendable, char)
. - CharsRef - Class in org.apache.lucene.util
-
Represents char[], as a slice (offset + length) into an existing char[].
- CharsRef() - Constructor for class org.apache.lucene.util.CharsRef
-
Creates a new
CharsRef
initialized an empty array zero-length - CharsRef(char[], int, int) - Constructor for class org.apache.lucene.util.CharsRef
-
Creates a new
CharsRef
initialized with the given array, offset and length - CharsRef(int) - Constructor for class org.apache.lucene.util.CharsRef
-
Creates a new
CharsRef
initialized with an array of the given capacity - CharsRef(String) - Constructor for class org.apache.lucene.util.CharsRef
-
Creates a new
CharsRef
initialized with the given Strings character array - CharStream - Class in org.apache.lucene.analysis
-
CharStream adds
CharStream.correctOffset(int)
functionality overReader
. - CharStream - Interface in org.apache.lucene.queryParser
-
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.
- CharStream() - Constructor for class org.apache.lucene.analysis.CharStream
- CharTermAttribute - Interface in org.apache.lucene.analysis.tokenattributes
-
The term text of a Token.
- CharTermAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
-
The term text of a Token.
- CharTermAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
- CharTokenizer - Class in org.apache.lucene.analysis
-
An abstract base class for simple, character-oriented tokenizers.
- CharTokenizer(Reader) - Constructor for class org.apache.lucene.analysis.CharTokenizer
-
Deprecated.use
CharTokenizer(Version, Reader)
instead. This will be removed in Lucene 4.0. - CharTokenizer(AttributeSource.AttributeFactory, Reader) - Constructor for class org.apache.lucene.analysis.CharTokenizer
-
Deprecated.use
CharTokenizer(Version, AttributeSource.AttributeFactory, Reader)
instead. This will be removed in Lucene 4.0. - CharTokenizer(AttributeSource, Reader) - Constructor for class org.apache.lucene.analysis.CharTokenizer
-
Deprecated.use
CharTokenizer(Version, AttributeSource, Reader)
instead. This will be removed in Lucene 4.0. - CharTokenizer(Version, Reader) - Constructor for class org.apache.lucene.analysis.CharTokenizer
-
Creates a new
CharTokenizer
instance - CharTokenizer(Version, AttributeSource.AttributeFactory, Reader) - Constructor for class org.apache.lucene.analysis.CharTokenizer
-
Creates a new
CharTokenizer
instance - CharTokenizer(Version, AttributeSource, Reader) - Constructor for class org.apache.lucene.analysis.CharTokenizer
-
Creates a new
CharTokenizer
instance - 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(char[]) - Constructor for class org.apache.lucene.analysis.compound.hyphenation.CharVector
- CharVector(char[], int) - Constructor for class org.apache.lucene.analysis.compound.hyphenation.CharVector
- CharVector(int) - Constructor for class org.apache.lucene.analysis.compound.hyphenation.CharVector
- check(Random, Query, Searcher) - 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, Searcher, boolean) - Static method in class org.apache.lucene.search.QueryUtils
- check(FieldCache.CacheEntry...) - Method in class org.apache.lucene.util.FieldCacheSanityChecker
-
Tests a CacheEntry[] for indication of "insane" cache usage.
- check(Query) - Static method in class org.apache.lucene.search.QueryUtils
-
Check the types of things query objects should be able to do.
- 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
- CheckClearAttributesAttributeImpl() - Constructor for class org.apache.lucene.analysis.BaseTokenStreamTestCase.CheckClearAttributesAttributeImpl
- checkCondition(CharSequence) - Method in class org.apache.lucene.analysis.hunspell.HunspellAffix
-
Checks whether the given text matches the conditional pattern on this affix
- 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, Query) - Static method in class org.apache.lucene.search.QueryUtils
- checkEqual(Query, ScoreDoc[], ScoreDoc[]) - Static method in class org.apache.lucene.search.CheckHits
- checkExplanations(Query) - Method in class org.apache.lucene.search.CheckHits.ExplanationAssertingSearcher
- checkExplanations(Query, String, Searcher) - 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, Searcher, 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, Searcher) - Static method in class org.apache.lucene.search.QueryUtils
-
deep check that explanations of a query 'score' correctly
- 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.util.CodecUtil
- checkHitCollector(Random, Query, String, Searcher, 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(Random, Query, String, Searcher, int[]) - Static method in class org.apache.lucene.search.CheckHits
-
Tests that a query matches the an expected set of documents using Hits.
- 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.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.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.
- checkIndex() - Method in class org.apache.lucene.index.CheckIndex
-
Returns a
CheckIndex.Status
instance detailing the state of the index. - checkIndex(List<String>) - Method in class org.apache.lucene.index.CheckIndex
-
Returns a
CheckIndex.Status
instance detailing the state of the index. - checkIndex(Directory) - Static method in class org.apache.lucene.util._TestUtil
-
This runs the CheckIndex tool on the index in.
- 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.Status - Class in org.apache.lucene.index
-
Returned from
CheckIndex.checkIndex()
detailing the health and status of the index. - CheckIndex.Status.FieldNormStatus - Class in org.apache.lucene.index
-
Status from testing field norms.
- CheckIndex.Status.SegmentInfoStatus - Class in org.apache.lucene.index
-
Holds the status of each segment in the index.
- CheckIndex.Status.StoredFieldStatus - Class in org.apache.lucene.index
-
Status from testing stored fields.
- CheckIndex.Status.TermIndexStatus - Class in org.apache.lucene.index
-
Status from testing term index.
- CheckIndex.Status.TermVectorStatus - Class in org.apache.lucene.index
-
Status from testing stored fields.
- checkNoMatchExplanations(Query, String, Searcher, 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
- checkOneTerm(Analyzer, String, String) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
- checkOneTermReuse(Analyzer, String, String) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
- 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, 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) - 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
- checkSanity(FieldCache) - Static method in class org.apache.lucene.util.FieldCacheSanityChecker
-
Quick and dirty convenience method
- checkSanity(FieldCache.CacheEntry...) - Static method in class org.apache.lucene.util.FieldCacheSanityChecker
-
Quick and dirty convenience method that instantiates an instance with "good defaults" and uses it to test the CacheEntrys
- checkSkipTo(Query, IndexSearcher) - Static method in class org.apache.lucene.search.QueryUtils
-
alternate scorer skipTo(),skipTo(),next(),next(),skipTo(),skipTo(), etc and ensure a hitcollector receives same docs and scores
- checkSnapshotted(String) - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
-
Checks if the given id is already used by another snapshot, and throws
IllegalStateException
if it is. - ChecksumIndexInput - Class in org.apache.lucene.store
-
Writes bytes through to a primary IndexOutput, computing checksum as it goes.
- ChecksumIndexInput(IndexInput) - Constructor for class org.apache.lucene.store.ChecksumIndexInput
- ChecksumIndexOutput - Class in org.apache.lucene.store
-
Writes bytes through to a primary IndexOutput, computing checksum.
- ChecksumIndexOutput(IndexOutput) - Constructor for class org.apache.lucene.store.ChecksumIndexOutput
- checkUnequal(Query, Query) - Static method in class org.apache.lucene.search.QueryUtils
- CHINESE_WORD - Static variable in class org.apache.lucene.analysis.cn.smart.WordType
-
Chinese Word
- ChineseAnalyzer - Class in org.apache.lucene.analysis.cn
-
Deprecated.Use
StandardAnalyzer
instead, which has the same functionality. This analyzer will be removed in Lucene 5.0 - ChineseAnalyzer() - Constructor for class org.apache.lucene.analysis.cn.ChineseAnalyzer
-
Deprecated.
- ChineseFilter - Class in org.apache.lucene.analysis.cn
-
Deprecated.Use
StopFilter
instead, which has the same functionality. This filter will be removed in Lucene 5.0 - ChineseFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.cn.ChineseFilter
-
Deprecated.
- ChineseTokenizer - Class in org.apache.lucene.analysis.cn
-
Deprecated.Use
StandardTokenizer
instead, which has the same functionality. This filter will be removed in Lucene 5.0 - ChineseTokenizer(Reader) - Constructor for class org.apache.lucene.analysis.cn.ChineseTokenizer
-
Deprecated.
- ChineseTokenizer(AttributeSource.AttributeFactory, Reader) - Constructor for class org.apache.lucene.analysis.cn.ChineseTokenizer
-
Deprecated.
- ChineseTokenizer(AttributeSource, Reader) - Constructor for class org.apache.lucene.analysis.cn.ChineseTokenizer
-
Deprecated.
- ChunksIntEncoder - Class in org.apache.lucene.util.encoding
-
An
IntEncoder
which encodes values in chunks. - ChunksIntEncoder(int) - Constructor for class org.apache.lucene.util.encoding.ChunksIntEncoder
- chunkSize - Variable in class org.apache.lucene.store.SimpleFSDirectory.SimpleFSIndexInput
- 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 - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
-
Deprecated.
- CJ_ID - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
- CJKAnalyzer - Class in org.apache.lucene.analysis.cjk
-
An
Analyzer
that tokenizes text withStandardTokenizer
, normalizes content withCJKWidthFilter
, folds case withLowerCaseFilter
, forms bigrams of CJK withCJKBigramFilter
, and filters stopwords withStopFilter
- CJKAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.cjk.CJKAnalyzer
-
Builds an analyzer which removes words in
CJKAnalyzer.getDefaultStopSet()
. - CJKAnalyzer(Version, String...) - Constructor for class org.apache.lucene.analysis.cjk.CJKAnalyzer
-
Deprecated.use
CJKAnalyzer(Version, Set)
instead - CJKAnalyzer(Version, Set<?>) - 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
-
Create a new CJKBigramFilter, specifying which writing systems should be bigrammed.
- CJKTokenizer - Class in org.apache.lucene.analysis.cjk
-
Deprecated.Use StandardTokenizer, CJKWidthFilter, CJKBigramFilter, and LowerCaseFilter instead.
- CJKTokenizer(Reader) - Constructor for class org.apache.lucene.analysis.cjk.CJKTokenizer
-
Deprecated.Construct a token stream processing the given input.
- CJKTokenizer(AttributeSource.AttributeFactory, Reader) - Constructor for class org.apache.lucene.analysis.cjk.CJKTokenizer
-
Deprecated.
- CJKTokenizer(AttributeSource, Reader) - Constructor for class org.apache.lucene.analysis.cjk.CJKTokenizer
-
Deprecated.
- 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
- Cl2oTaxonomyWriterCache - Class in org.apache.lucene.facet.taxonomy.writercache.cl2o
- Cl2oTaxonomyWriterCache(int, float, int) - Constructor for class org.apache.lucene.facet.taxonomy.writercache.cl2o.Cl2oTaxonomyWriterCache
- CLASS_COUNT - Static variable in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
- ClassicAnalyzer - Class in org.apache.lucene.analysis.standard
-
Filters
ClassicTokenizer
withClassicFilter
,LowerCaseFilter
andStopFilter
, using a list of English stop words. - ClassicAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.standard.ClassicAnalyzer
-
Builds an analyzer with the default stop words (
ClassicAnalyzer.STOP_WORDS_SET
). - ClassicAnalyzer(Version, File) - Constructor for class org.apache.lucene.analysis.standard.ClassicAnalyzer
-
Deprecated.Use
ClassicAnalyzer(Version, Reader)
instead. - ClassicAnalyzer(Version, Reader) - Constructor for class org.apache.lucene.analysis.standard.ClassicAnalyzer
-
Builds an analyzer with the stop words from the given reader.
- ClassicAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.standard.ClassicAnalyzer
-
Builds an analyzer with the given stop words.
- ClassicFilter - Class in org.apache.lucene.analysis.standard
-
Normalizes tokens extracted with
ClassicTokenizer
. - ClassicFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.standard.ClassicFilter
-
Construct filtering in.
- ClassicTokenizer - Class in org.apache.lucene.analysis.standard
-
A grammar-based tokenizer constructed with JFlex
- ClassicTokenizer(Version, Reader) - Constructor for class org.apache.lucene.analysis.standard.ClassicTokenizer
-
Creates a new instance of the
ClassicTokenizer
. - ClassicTokenizer(Version, AttributeSource.AttributeFactory, Reader) - Constructor for class org.apache.lucene.analysis.standard.ClassicTokenizer
-
Creates a new ClassicTokenizer with a given
AttributeSource.AttributeFactory
- ClassicTokenizer(Version, AttributeSource, Reader) - Constructor for class org.apache.lucene.analysis.standard.ClassicTokenizer
-
Creates a new ClassicTokenizer with a given
AttributeSource
. - classmap - Variable in class org.apache.lucene.analysis.compound.hyphenation.HyphenationTree
-
This map stores the character classes
- classRules - Static variable in class org.apache.lucene.util.LuceneTestCase
-
This controls how suite-level rules are nested.
- Clause(CharSequence) - Method in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParser
- Clause(String) - Method in class org.apache.lucene.queryParser.QueryParser
- clauses - Variable in class org.apache.lucene.search.spans.SpanNearQuery
- clauses() - Method in class org.apache.lucene.search.BooleanFilter
-
Returns the list of clauses
- clauses() - Method in class org.apache.lucene.search.BooleanQuery
-
Returns the list of clauses in this query.
- clean - Variable in class org.apache.lucene.index.CheckIndex.Status
-
True if no problems were found with the index.
- cleanSleepTime - Variable in class org.apache.lucene.search.FilterManager
-
Deprecated.Cache cleaning frequency
- cleanUp() - Method in class org.apache.lucene.spatial.tier.DistanceFieldComparatorSource
-
Deprecated.
- 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.Token
-
Resets the term text, payload, flags, and positionIncrement, startOffset, endOffset and token type to default.
- clear() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
- clear() - Method in class org.apache.lucene.analysis.tokenattributes.FlagsAttributeImpl
- clear() - Method in class org.apache.lucene.analysis.tokenattributes.KeywordAttributeImpl
- clear() - Method in class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
- clear() - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
- clear() - Method in class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
- clear() - Method in class org.apache.lucene.analysis.tokenattributes.PositionLengthAttributeImpl
- clear() - Method in class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
- clear() - Method in class org.apache.lucene.benchmark.byTask.feeds.DocData
- clear() - Method in interface org.apache.lucene.facet.index.attributes.CategoryAttribute
-
Resets this attribute to its initial value: a null category path and no properties.
- clear() - Method in class org.apache.lucene.facet.index.attributes.CategoryAttributeImpl
- clear() - Method in class org.apache.lucene.facet.index.attributes.OrdinalProperty
- clear() - Method in class org.apache.lucene.facet.index.CategoryContainer
-
Remove all categories.
- clear() - Method in interface org.apache.lucene.facet.search.Heap
-
Clear the heap
- clear() - Method in class org.apache.lucene.facet.search.TotalFacetCountsCache
-
Clear the cache.
- clear() - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
-
Empty the CategoryPath object, so that it has zero components.
- clear() - Method in class org.apache.lucene.index.SegmentInfos
- clear() - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorPipeline
- clear() - Method in class org.apache.lucene.queryParser.standard.config.AllowLeadingWildcardAttributeImpl
-
Deprecated.
- clear() - Method in class org.apache.lucene.queryParser.standard.config.AnalyzerAttributeImpl
-
Deprecated.
- clear() - Method in class org.apache.lucene.queryParser.standard.config.BoostAttributeImpl
-
Deprecated.
- clear() - Method in class org.apache.lucene.queryParser.standard.config.DateResolutionAttributeImpl
-
Deprecated.
- clear() - Method in class org.apache.lucene.queryParser.standard.config.DefaultOperatorAttributeImpl
-
Deprecated.
- clear() - Method in class org.apache.lucene.queryParser.standard.config.DefaultPhraseSlopAttributeImpl
-
Deprecated.
- clear() - Method in class org.apache.lucene.queryParser.standard.config.FieldBoostMapAttributeImpl
-
Deprecated.
- clear() - Method in class org.apache.lucene.queryParser.standard.config.FieldDateResolutionMapAttributeImpl
-
Deprecated.
- clear() - Method in class org.apache.lucene.queryParser.standard.config.FuzzyAttributeImpl
-
Deprecated.
- clear() - Method in class org.apache.lucene.queryParser.standard.config.LocaleAttributeImpl
-
Deprecated.
- clear() - Method in class org.apache.lucene.queryParser.standard.config.LowercaseExpandedTermsAttributeImpl
-
Deprecated.
- clear() - Method in class org.apache.lucene.queryParser.standard.config.MultiFieldAttributeImpl
-
Deprecated.
- clear() - Method in class org.apache.lucene.queryParser.standard.config.MultiTermRewriteMethodAttributeImpl
-
Deprecated.
- clear() - Method in class org.apache.lucene.queryParser.standard.config.PositionIncrementsAttributeImpl
-
Deprecated.
- clear() - Method in class org.apache.lucene.queryParser.standard.config.RangeCollatorAttributeImpl
-
Deprecated.
- clear() - Method in class org.apache.lucene.queryParser.surround.query.SpanNearClauseFactory
- clear() - Method in class org.apache.lucene.search.grouping.SentinelIntSet
- clear() - Method in class org.apache.lucene.search.suggest.BytesRefList
-
Clears this
BytesRefList
- clear() - Method in class org.apache.lucene.util.AttributeImpl
-
Clears the values in this AttributeImpl and resets it to its default value.
- clear() - Method in class org.apache.lucene.util.BytesRefHash.BytesStartArray
-
clears the
BytesRefHash.BytesStartArray
and returns the cleared instance. - clear() - Method in class org.apache.lucene.util.BytesRefHash
- clear() - Method in class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
- clear() - Method in class org.apache.lucene.util.BytesRefHash.TrackingDirectBytesStartArray
- clear() - Method in class org.apache.lucene.util.collections.ArrayHashMap
-
Empties the map.
- clear() - Method in class org.apache.lucene.util.collections.FloatToObjectMap
-
Empties the map.
- clear() - Method in class org.apache.lucene.util.collections.IntHashSet
-
Empties the map.
- clear() - Method in class org.apache.lucene.util.collections.IntToDoubleMap
-
Empties the map.
- clear() - Method in class org.apache.lucene.util.collections.IntToIntMap
-
Empties the map.
- clear() - Method in class org.apache.lucene.util.collections.IntToObjectMap
-
Empties the map.
- clear() - Method in class org.apache.lucene.util.collections.ObjectToFloatMap
-
Empties the map.
- clear() - Method in class org.apache.lucene.util.collections.ObjectToIntMap
-
Empties the map.
- clear() - Method in class org.apache.lucene.util.fst.Builder.UnCompiledNode
- clear() - Method in class org.apache.lucene.util.MapBackedSet
- clear() - Method in class org.apache.lucene.util.packed.GrowableWriter
- clear() - Method in interface org.apache.lucene.util.packed.PackedInts.Mutable
-
Sets all values to 0.
- clear() - Method in class org.apache.lucene.util.PriorityQueue
-
Removes all entries from the PriorityQueue.
- clear() - Method in class org.apache.lucene.util.ScorerDocQueue
-
Deprecated.Removes all entries from the ScorerDocQueue.
- clear() - Method in class org.apache.lucene.util.WeakIdentityMap
- clear(boolean) - Method in class org.apache.lucene.util.BytesRefHash
- clear(boolean) - Method in class org.apache.lucene.util.collections.IntArray
-
Clear the IntArray (set all elements to zero).
- clear(float[]) - Method in class org.apache.lucene.facet.search.FloatArrayAllocator
- clear(int) - Method in class org.apache.lucene.util.BitVector
-
Sets the value of
bit
to zero. - clear(int) - Method in class org.apache.lucene.util.FixedBitSet
- clear(int[]) - Method in class org.apache.lucene.facet.search.IntArrayAllocator
- clear(int, int) - Method in class org.apache.lucene.util.FixedBitSet
-
Clears a range of bits.
- clear(int, int) - Method in class org.apache.lucene.util.OpenBitSet
-
Clears a range of bits.
- clear(long) - Method in class org.apache.lucene.util.OpenBitSet
-
clears a bit, allowing access beyond the current set size without changing the size.
- clear(long, long) - Method in class org.apache.lucene.util.OpenBitSet
-
Clears a range of bits.
- clear(T) - Method in class org.apache.lucene.facet.search.TemporaryObjectAllocator
-
Subclasses must override this method to clear an existing object of the desired type, to prepare it for reuse.
- clearAttributes() - Method in class org.apache.lucene.util.AttributeSource
-
Resets all Attributes in this AttributeSource by calling
AttributeImpl.clear()
on each Attribute implementation. - clearCategoryProperties() - Method in class org.apache.lucene.facet.index.streaming.CategoryParentsStream
-
Clear the properties of the current
CategoryAttribute
attribute before setting the parent attributes. - clearCrash() - Method in class org.apache.lucene.store.MockDirectoryWrapper
- 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
- clearIndex() - Method in class org.apache.lucene.search.spell.SpellChecker
-
Removes all terms from the spell check index.
- clearLock(String) - Method in class org.apache.lucene.store.Directory
-
Attempt to clear (forcefully unlock and remove) the specified lock.
- clearLock(String) - Method in class org.apache.lucene.store.LockFactory
-
Attempt to clear (forcefully unlock and remove) the specified lock.
- clearLock(String) - Method in class org.apache.lucene.store.MockDirectoryWrapper
- clearLock(String) - Method in class org.apache.lucene.store.MockLockFactoryWrapper
- clearLock(String) - Method in class org.apache.lucene.store.NativeFSLockFactory
- clearLock(String) - Method in class org.apache.lucene.store.NoLockFactory
- clearLock(String) - Method in class org.apache.lucene.store.NRTCachingDirectory
- clearLock(String) - Method in class org.apache.lucene.store.SimpleFSLockFactory
- clearLock(String) - Method in class org.apache.lucene.store.SingleInstanceLockFactory
- clearLock(String) - Method in class org.apache.lucene.store.VerifyingLockFactory
- clearProperties() - Method in interface org.apache.lucene.facet.index.attributes.CategoryAttribute
-
Clear all properties.
- clearProperties() - Method in class org.apache.lucene.facet.index.attributes.CategoryAttributeImpl
- ClearStatsTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Clear statistics data.
- ClearStatsTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.ClearStatsTask
- clearTotalNumberOfTerms() - Method in class org.apache.lucene.search.MultiTermQuery
-
Deprecated.Don't use this method, as its not thread safe and useless.
- clearTotalNumberOfTerms() - Method in class org.apache.lucene.search.MultiTermQueryWrapperFilter
-
Deprecated.Don't use this method, as its not thread safe and useless.
- clearUnhandledExceptions() - Static method in class org.apache.lucene.index.ConcurrentMergeScheduler
- 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.icu.segmentation.LaoBreakIterator
-
Clone method.
- clone() - Method in class org.apache.lucene.analysis.Token
- clone() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
- clone() - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
- clone() - Method in class org.apache.lucene.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 interface org.apache.lucene.facet.index.attributes.CategoryAttribute
-
Clone this
CategoryAttribute
. - clone() - Method in class org.apache.lucene.facet.index.attributes.CategoryAttributeImpl
- clone() - Method in class org.apache.lucene.facet.search.params.FacetRequest
- clone() - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
- clone() - Method in class org.apache.lucene.index.FieldInfo
- clone() - Method in class org.apache.lucene.index.FieldInfos
-
Returns a deep clone of this FieldInfos instance.
- clone() - Method in class org.apache.lucene.index.IndexReader
-
Efficiently clones the IndexReader (sharing most internal state).
- clone() - Method in class org.apache.lucene.index.IndexWriterConfig
- clone() - Method in class org.apache.lucene.index.MultiReader
- clone() - Method in class org.apache.lucene.index.ParallelReader
- clone() - Method in class org.apache.lucene.index.Payload
-
Clones this payload by creating a copy of the underlying byte array.
- clone() - Method in class org.apache.lucene.index.SegmentInfo
- clone() - Method in class org.apache.lucene.index.SegmentInfos
-
Returns a copy of this instance, also copying each SegmentInfo.
- clone() - Method in class org.apache.lucene.index.SegmentReader
- clone() - Method in class org.apache.lucene.queryParser.core.nodes.PathQueryNode.QueryText
- clone() - Method in class org.apache.lucene.queryParser.core.nodes.QueryNodeImpl
- clone() - Method in class org.apache.lucene.queryParser.surround.query.SrndQuery
- clone() - Method in class org.apache.lucene.search.BooleanQuery
- clone() - Method in class org.apache.lucene.search.DisjunctionMaxQuery
-
Create a shallow copy of us -- used in rewriting if necessary
- clone() - Method in class org.apache.lucene.search.function.CustomScoreQuery
- clone() - Method in class org.apache.lucene.search.join.ToChildBlockJoinQuery
- clone() - Method in class org.apache.lucene.search.join.ToParentBlockJoinQuery
- clone() - Method in class org.apache.lucene.search.payloads.PayloadNearQuery
- clone() - Method in class org.apache.lucene.search.Query
-
Returns a clone of this query.
- clone() - Method in class org.apache.lucene.search.spans.SpanFirstQuery
- clone() - Method in class org.apache.lucene.search.spans.SpanNearPayloadCheckQuery
- clone() - Method in class org.apache.lucene.search.spans.SpanNearQuery
- clone() - Method in class org.apache.lucene.search.spans.SpanNotQuery
- clone() - Method in class org.apache.lucene.search.spans.SpanOrQuery
- clone() - Method in class org.apache.lucene.search.spans.SpanPayloadCheckQuery
- clone() - Method in class org.apache.lucene.search.spans.SpanPositionRangeQuery
- clone() - Method in class org.apache.lucene.store.BufferedIndexInput
- clone() - Method in class org.apache.lucene.store.DataInput
-
Returns a clone of this stream.
- clone() - Method in class org.apache.lucene.store.MockIndexInputWrapper
- clone() - Method in class org.apache.lucene.store.SimpleFSDirectory.SimpleFSIndexInput
- clone() - Method in class org.apache.lucene.store.WindowsDirectory.WindowsIndexInput
- clone() - Method in class org.apache.lucene.util.AttributeImpl
-
Shallow clone.
- clone() - Method in class org.apache.lucene.util.AttributeSource.State
- clone() - Method in class org.apache.lucene.util.BitVector
- clone() - Method in class org.apache.lucene.util.BytesRef
- clone() - Method in class org.apache.lucene.util.CharsRef
- clone() - Method in class org.apache.lucene.util.DoubleBarrelLRUCache.CloneableKey
- clone() - Method in class org.apache.lucene.util.FixedBitSet
- clone() - Method in class org.apache.lucene.util.IntsRef
- clone() - Method in class org.apache.lucene.util.OpenBitSet
- clone() - Method in class org.apache.lucene.util.PagedBytes.PagedBytesDataInput
- clone(boolean) - Method in class org.apache.lucene.index.IndexReader
-
Deprecated.Write support will be removed in Lucene 4.0. Use
IndexReader.clone()
instead. - clone(boolean) - Method in class org.apache.lucene.index.MultiReader
-
Deprecated.Write support will be removed in Lucene 4.0. Use
MultiReader.clone()
instead. - clone(boolean) - Method in class org.apache.lucene.index.ParallelReader
-
Deprecated.Write support will be removed in Lucene 4.0. Use
ParallelReader.clone()
instead. - clone(boolean) - Method in class org.apache.lucene.index.SegmentReader
-
Deprecated.
- clone(char[], int, int, int, int) - Method in class org.apache.lucene.analysis.Token
-
Makes a clone, but replaces the term buffer & start/end offset in the process.
- CloneableKey() - Constructor for class org.apache.lucene.util.DoubleBarrelLRUCache.CloneableKey
- cloneAttributes() - Method in class org.apache.lucene.util.AttributeSource
-
Performs a clone of all
AttributeImpl
instances returned in a newAttributeSource
instance. - cloneDeletedDocs(BitVector) - Method in class org.apache.lucene.index.SegmentReader
-
Deprecated.
- cloneDocument(Document) - Static method in class org.apache.lucene.util._TestUtil
- cloneNormBytes(byte[]) - Method in class org.apache.lucene.index.SegmentReader
-
Deprecated.
- cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.AnyQueryNode
- cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.BooleanQueryNode
- cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.BoostQueryNode
- cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.DeletedQueryNode
- cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.FieldQueryNode
- cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.FuzzyQueryNode
- cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.GroupQueryNode
- cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.MatchAllDocsQueryNode
- cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.ModifierQueryNode
- cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.NoTokenFoundQueryNode
- cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.OpaqueQueryNode
- cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.ParametricQueryNode
-
Deprecated.
- cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.ParametricRangeQueryNode
- cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.PathQueryNode
- cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.PhraseSlopQueryNode
- cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.ProximityQueryNode
- cloneTree() - Method in interface org.apache.lucene.queryParser.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.core.nodes.QueryNodeImpl
- cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.QuotedFieldQueryNode
- cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.SlopQueryNode
- cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.TokenizedPhraseQueryNode
- cloneTree() - Method in class org.apache.lucene.queryParser.standard.nodes.MultiPhraseQueryNode
- cloneTree() - Method in class org.apache.lucene.queryParser.standard.nodes.PrefixWildcardQueryNode
- cloneTree() - Method in class org.apache.lucene.queryParser.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
- close() - Method in class org.apache.lucene.analysis.charfilter.HTMLStripCharFilter
- close() - Method in class org.apache.lucene.analysis.CharReader
- close() - Method in class org.apache.lucene.analysis.miscellaneous.PrefixAndSuffixAwareTokenFilter
- close() - Method in class org.apache.lucene.analysis.miscellaneous.PrefixAwareTokenFilter
- close() - Method in class org.apache.lucene.analysis.MockCharFilter
- 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.TokenFilter
-
Close the input TokenStream.
- close() - Method in class org.apache.lucene.analysis.Tokenizer
-
By default, closes the input Reader.
- close() - Method in class org.apache.lucene.analysis.TokenStream
-
Releases resources associated with this stream.
- close() - Method in class org.apache.lucene.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
-
Closes the
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.ConsumeContentSourceTask
- 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.WriteLineDocTask
- close() - Method in class org.apache.lucene.benchmark.byTask.utils.StringBuilderReader
- close() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyReader
- 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 underlyingDirectory
. - close() - Method in class org.apache.lucene.facet.taxonomy.writercache.cl2o.Cl2oTaxonomyWriterCache
- close() - Method in class org.apache.lucene.facet.taxonomy.writercache.lru.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.index.AbstractAllTermDocs
- close() - Method in class org.apache.lucene.index.CompoundFileWriter
-
Merge files with the extensions added up to now.
- close() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
- close() - Method in class org.apache.lucene.index.FilterIndexReader.FilterTermDocs
- close() - Method in class org.apache.lucene.index.FilterIndexReader.FilterTermEnum
- close() - Method in class org.apache.lucene.index.IndexReader
-
Closes files associated with this index.
- close() - Method in class org.apache.lucene.index.IndexWriter
-
Commits all changes to an index and closes all associated files.
- close() - Method in class org.apache.lucene.index.LogMergePolicy
- close() - Method in class org.apache.lucene.index.MergePolicy
-
Release all resources for the policy.
- close() - Method in class org.apache.lucene.index.MergeScheduler
-
Close this MergeScheduler.
- close() - Method in class org.apache.lucene.index.MockIndexInput
- close() - Method in class org.apache.lucene.index.MockRandomMergePolicy
- close() - Method in class org.apache.lucene.index.MultipleTermPositions
- close() - Method in class org.apache.lucene.index.NoMergePolicy
- close() - Method in class org.apache.lucene.index.NoMergeScheduler
- close() - Method in class org.apache.lucene.index.PersistentSnapshotDeletionPolicy
-
Closes the index which writes the snapshots to the directory.
- close() - Method in class org.apache.lucene.index.RandomIndexWriter
-
Close this writer.
- close() - Method in class org.apache.lucene.index.SerialMergeScheduler
- close() - Method in interface org.apache.lucene.index.TermDocs
-
Frees associated resources.
- close() - Method in class org.apache.lucene.index.TermEnum
-
Closes the enumeration to further activity, freeing resources.
- close() - Method in class org.apache.lucene.index.TieredMergePolicy
- close() - Method in class org.apache.lucene.index.UpgradeIndexMergePolicy
- close() - Method in class org.apache.lucene.search.FilteredTermEnum
-
Closes the enumeration to further activity, freeing resources.
- close() - Method in class org.apache.lucene.search.FuzzyTermEnum
-
Closes the enumeration to further activity, freeing resources.
- close() - Method in class org.apache.lucene.search.IndexSearcher
-
Note that the underlying IndexReader is not closed, if IndexSearcher was constructed with IndexSearcher(IndexReader r).
- close() - Method in class org.apache.lucene.search.MultiSearcher
-
Deprecated.
- close() - Method in class org.apache.lucene.search.NRTManagerReopenThread
- close() - Method in class org.apache.lucene.search.ParallelMultiSearcher
-
Deprecated.
- close() - Method in class org.apache.lucene.search.ReferenceManager
-
Close this ReferenceManager to future
acquiring
. - close() - Method in class org.apache.lucene.search.regex.RegexTermEnum
- close() - Method in class org.apache.lucene.search.RemoteSearchable
-
Deprecated.
- close() - Method in interface org.apache.lucene.search.Searchable
-
Deprecated.Frees resources associated with this Searcher.
- close() - Method in class org.apache.lucene.search.Searcher
-
Deprecated.
- close() - Method in class org.apache.lucene.search.SearcherLifetimeManager
-
Close this to future searching; any searches still in process in other threads won't be affected, and they should still call
SearcherLifetimeManager.release(org.apache.lucene.search.IndexSearcher)
after they are done. - close() - Method in class org.apache.lucene.search.spell.SpellChecker
-
Close the IndexSearcher used by this SpellChecker
- close() - Method in class org.apache.lucene.search.suggest.fst.ExternalRefSorter
-
Removes any written temporary files.
- close() - Method in class org.apache.lucene.search.suggest.fst.Sort.ByteSequencesReader
- close() - Method in class org.apache.lucene.search.suggest.fst.Sort.ByteSequencesWriter
-
Closes the provided
DataOutput
if it isCloseable
. - close() - Method in class org.apache.lucene.store.BufferedIndexOutput
-
Closes this stream to further operations.
- close() - Method in class org.apache.lucene.store.ChecksumIndexInput
- close() - Method in class org.apache.lucene.store.ChecksumIndexOutput
- close() - Method in class org.apache.lucene.store.Directory
-
Closes the store.
- close() - Method in class org.apache.lucene.store.FileSwitchDirectory
- close() - Method in class org.apache.lucene.store.FSDirectory
-
Closes the store to future operations.
- close() - Method in class org.apache.lucene.store.FSDirectory.FSIndexOutput
- close() - Method in class org.apache.lucene.store.IndexInput
-
Closes the stream to further operations.
- close() - Method in class org.apache.lucene.store.IndexOutput
-
Closes this stream to further operations.
- close() - Method in class org.apache.lucene.store.InputStreamDataInput
- close() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndex
-
Deprecated.
- close() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexWriter
-
Deprecated.Flushes all changes to an index and closes all associated files.
- close() - Method in class org.apache.lucene.store.instantiated.InstantiatedTermDocs
-
Does nothing
- close() - Method in class org.apache.lucene.store.instantiated.InstantiatedTermEnum
-
Closes the enumeration to further activity, freeing resources.
- 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.NIOFSDirectory.NIOFSIndexInput
- close() - Method in class org.apache.lucene.store.NRTCachingDirectory
-
Close this directory, which flushes any cached files to the delegate and then closes the delegate.
- close() - Method in class org.apache.lucene.store.OutputStreamDataOutput
- close() - Method in class org.apache.lucene.store.RAMDirectory
-
Closes the store to future operations, releasing associated memory.
- close() - Method in class org.apache.lucene.store.RAMInputStream
- close() - Method in class org.apache.lucene.store.RAMOutputStream
- close() - Method in class org.apache.lucene.store.SimpleFSDirectory.SimpleFSIndexInput
- close() - Method in class org.apache.lucene.store.SimpleFSDirectory.SimpleFSIndexInput.Descriptor
- close() - Method in class org.apache.lucene.store.WindowsDirectory.WindowsIndexInput
- 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.encoding.ChunksIntEncoder
- close() - Method in class org.apache.lucene.util.encoding.IntEncoder
-
Instructs the encoder to finish the encoding process.
- close() - Method in class org.apache.lucene.util.encoding.IntEncoderFilter
- close() - Method in class org.apache.lucene.util.encoding.NOnesIntEncoder
- close() - Method in class org.apache.lucene.util.encoding.SortingIntEncoder
- close() - Method in class org.apache.lucene.util.LineFileDocs
- close() - Method in class org.apache.lucene.util.ThrottledIndexOutput
- close(boolean) - Method in class org.apache.lucene.index.IndexWriter
-
Closes the index with or without waiting for currently running merges to finish.
- close(Closeable...) - Static method in class org.apache.lucene.util.IOUtils
-
Closes all given Closeables.
- close(Iterable<? extends Closeable>) - Static method in class org.apache.lucene.util.IOUtils
- CloseableThreadLocal<T> - Class in org.apache.lucene.util
-
Java's builtin ThreadLocal has a serious flaw: it can take an arbitrarily long amount of time to dereference the things you had stored in it, even once the ThreadLocal instance itself is no longer referenced.
- CloseableThreadLocal() - Constructor for class org.apache.lucene.util.CloseableThreadLocal
- CloseIndexTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Close index writer.
- CloseIndexTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.CloseIndexTask
- CloseQuote1 - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
RegularExpression Id.
- CloseQuote2 - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
RegularExpression Id.
- 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(E, Closeable...) - Static method in class org.apache.lucene.util.IOUtils
-
Closes all given Closeables, suppressing all thrown exceptions.
- closeWhileHandlingException(E, Iterable<? extends Closeable>) - Static method in class org.apache.lucene.util.IOUtils
- closeWhileHandlingException(Closeable...) - Static method in class org.apache.lucene.util.IOUtils
-
Closes all given Closeables, suppressing all thrown exceptions.
- closeWhileHandlingException(Iterable<? extends Closeable>) - Static method in class org.apache.lucene.util.IOUtils
- CodecUtil - Class in org.apache.lucene.util
-
Utility class for reading and writing versioned headers.
- codePointAt(char[], int) - Method in class org.apache.lucene.util.CharacterUtils
-
Returns the code point at the given index of the char array.
- codePointAt(char[], int, int) - Method in class org.apache.lucene.util.CharacterUtils
-
Returns the code point at the given index of the char array where only elements with index less than the limit are used.
- codePointAt(CharSequence, int) - Method in class org.apache.lucene.util.CharacterUtils
-
Returns the code point at the given index of the
CharSequence
. - CollationKeyAnalyzer - Class in org.apache.lucene.collation
-
Filters
KeywordTokenizer
withCollationKeyFilter
. - CollationKeyAnalyzer(Collator) - Constructor for class org.apache.lucene.collation.CollationKeyAnalyzer
- CollationKeyFilter - Class in org.apache.lucene.collation
-
Converts each token into its
CollationKey
, and then encodes the CollationKey withIndexableBinaryStringTools
, to allow it to be stored as an index term. - CollationKeyFilter(TokenStream, Collator) - Constructor for class org.apache.lucene.collation.CollationKeyFilter
- 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.search.FacetsCollector
- collect(int) - Method in class org.apache.lucene.search.CheckHits.ExplanationAsserter
- collect(int) - Method in class org.apache.lucene.search.CheckHits.SetCollector
- collect(int) - Method in class org.apache.lucene.search.Collector
-
Called once for every document matching a query, with the unbased document number.
- collect(int) - Method in class org.apache.lucene.search.grouping.AbstractAllGroupHeadsCollector
- collect(int) - Method in class org.apache.lucene.search.grouping.AbstractFirstPassGroupingCollector
- collect(int) - Method in class org.apache.lucene.search.grouping.AbstractSecondPassGroupingCollector
- collect(int) - Method in class org.apache.lucene.search.grouping.BlockGroupingCollector
- collect(int) - Method in class org.apache.lucene.search.grouping.TermAllGroupsCollector
- collect(int) - Method in class org.apache.lucene.search.join.ToParentBlockJoinCollector
- collect(int) - Method in class org.apache.lucene.search.MultiCollector
- collect(int) - Method in class org.apache.lucene.search.PositiveScoresOnlyCollector
- collect(int) - Method in class org.apache.lucene.search.TimeLimitingCollector
-
Calls
Collector.collect(int)
on the decoratedCollector
unless the allowed time has passed, in which case it throws an exception. - collect(int) - Method in class org.apache.lucene.search.TotalHitCountCollector
- collectFiles(File, ArrayList<File>) - 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.
- CollectionUtil - Class in org.apache.lucene.util
-
Methods for manipulating (sorting) collections.
- collector - Variable in class org.apache.lucene.search.grouping.AbstractSecondPassGroupingCollector.SearchGroupDocs
- Collector - Class in org.apache.lucene.search
-
Expert: Collectors are primarily meant to be used to gather raw results from a search, and implement sorting or custom result filtering, collation, etc.
- Collector() - Constructor for class org.apache.lucene.search.Collector
- collectSpanQueryFields(SpanQuery, Set<String>) - Method in class org.apache.lucene.search.highlight.WeightedSpanTermExtractor
- CollisionMap - Class in org.apache.lucene.facet.taxonomy.writercache.cl2o
-
HashMap to store colliding labels.
- CollisionMap(int, CharBlockArray) - Constructor for class org.apache.lucene.facet.taxonomy.writercache.cl2o.CollisionMap
- CollisionMap(CharBlockArray) - Constructor for class org.apache.lucene.facet.taxonomy.writercache.cl2o.CollisionMap
- COLON - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
-
RegularExpression Id.
- COLON - Static variable in interface org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserConstants
-
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
- column - Variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
- column - Variable in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
- Column() - Constructor for class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.Matrix.Column
-
Deprecated.
- Column(Token) - Constructor for class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.Matrix.Column
-
Deprecated.
- combine(Query[]) - Method in class org.apache.lucene.search.Query
-
Expert: called when re-writing queries under MultiSearcher.
- 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
- Comment1 - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
RegularExpression Id.
- Comment2 - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
RegularExpression Id.
- CommentEnd1 - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
RegularExpression Id.
- CommentEnd2 - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
RegularExpression Id.
- CommentTag() - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParser
- CommentText1 - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
RegularExpression Id.
- CommentText2 - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
RegularExpression Id.
- commit() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
-
Calling commit() ensures that all the categories written so far are visible to a reader that is opened (or reopened) after that call.
- commit() - Method in class org.apache.lucene.index.IndexReader
-
Deprecated.Write support will be removed in Lucene 4.0.
- commit() - Method in class org.apache.lucene.index.IndexWriter
-
Commits all pending changes (added & deleted documents, segment merges, added indexes, etc.) to the index, and syncs all referenced index files, such that a reader will see the changes and the index updates will survive an OS or machine crash or power loss.
- commit() - Method in class org.apache.lucene.index.RandomIndexWriter
- commit() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexWriter
-
Deprecated.Locks the index and commits the buffered documents.
- commit() - Method in interface org.apache.lucene.util.TwoPhaseCommit
-
The second phase of a 2-phase commit.
- commit() - Method in class org.apache.lucene.util.TwoPhaseCommitTool.TwoPhaseCommitWrapper
- commit(Map<String, String>) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
-
Like commit(), but also store properties with the index.
- commit(Map<String, String>) - Method in class org.apache.lucene.index.IndexReader
-
Deprecated.Write support will be removed in Lucene 4.0.
- commit(Map<String, String>) - Method in class org.apache.lucene.index.IndexWriter
-
Commits all changes to the index, specifying a commitUserData Map (String -> String).
- commit(Map<String, String>) - Method in interface org.apache.lucene.util.TwoPhaseCommit
-
Like
TwoPhaseCommit.commit()
, but takes an additional commit data to be included w/ the commit. - commit(Map<String, String>) - Method in class org.apache.lucene.util.TwoPhaseCommitTool.TwoPhaseCommitWrapper
- CommitFailException(Throwable, TwoPhaseCommit) - Constructor for exception org.apache.lucene.util.TwoPhaseCommitTool.CommitFailException
- CommitIndexTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Commits the IndexWriter.
- CommitIndexTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.CommitIndexTask
- 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(Long, Long) - Method in class org.apache.lucene.util.fst.PositiveIntOutputs
- common(Object, Object) - Method in class org.apache.lucene.util.fst.NoOutputs
- common(Object, Object) - Method in class org.apache.lucene.util.fst.UpToTwoPositiveIntOutputs
- common(BytesRef, BytesRef) - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
- common(PairOutputs.Pair<A, B>, PairOutputs.Pair<A, B>) - Method in class org.apache.lucene.util.fst.PairOutputs
- common(IntsRef, IntsRef) - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
- common(T, T) - Method in class org.apache.lucene.util.fst.Outputs
-
Eg common("foo", "foobar") -> "foo"
- COMMON_DELIMITER - Static variable in class org.apache.lucene.analysis.cn.smart.Utility
-
Delimiters will be filtered to this character by
SegTokenFilter
- compact() - Method in class org.apache.lucene.util.BytesRefHash
-
Returns the ords array in arbitrary order.
- CompactLabelToOrdinal - Class in org.apache.lucene.facet.taxonomy.writercache.cl2o
-
This is a very efficient LabelToOrdinal implementation that uses a CharBlockArray to store all labels and a configurable number of HashArrays to reference the labels.
- CompactLabelToOrdinal(int, float, int) - Constructor for class org.apache.lucene.facet.taxonomy.writercache.cl2o.CompactLabelToOrdinal
- COMPANY - Static variable in class org.apache.lucene.analysis.standard.ClassicTokenizer
- COMPANY - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
-
Deprecated.
- COMPANY_ID - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
- comparator - Static variable in class org.apache.lucene.store.instantiated.InstantiatedTerm
- comparators - Variable in class org.apache.lucene.search.FieldValueHitQueue
- compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.ByteComparator
- compare(int, int) - Method in class org.apache.lucene.search.FieldComparator
-
Compare hit at slot1 with hit at slot2.
- compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.DocComparator
- compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.DoubleComparator
- compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.FloatComparator
- compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.IntComparator
- compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.LongComparator
- compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
- compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.ShortComparator
- compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.StringComparatorLocale
- compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.StringOrdValComparator
- compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.StringValComparator
- compare(int, int) - Method in class org.apache.lucene.search.grouping.AbstractAllGroupHeadsCollector.GroupHead
-
Compares the specified document for a specified comparator against the current most relevant document.
- compare(int, int) - Method in class org.apache.lucene.util.SorterTemplate
-
Compares slots
i
andj
of you data. - compare(TermVectorEntry, TermVectorEntry) - Method in class org.apache.lucene.index.TermVectorEntryFreqSortedComparator
- compare(ScoreDoc, ScoreDoc) - Method in class org.apache.lucene.index.pruning.CarmelTopKTermPruningPolicy.ByDocComparator
- compare(ScoreDoc, ScoreDoc) - Method in class org.apache.lucene.index.pruning.CarmelUniformTermPruningPolicy.ByDocComparator
- 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
- 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.ByteComparator
- compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator
-
Compare the bottom of the queue with doc.
- compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.DocComparator
- compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.DoubleComparator
- compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.FloatComparator
- compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.IntComparator
- compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.LongComparator
- compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
- compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.ShortComparator
- compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.StringComparatorLocale
- compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.StringOrdValComparator
- compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.StringValComparator
- compareByMergeDocCount - Static variable in class org.apache.lucene.index.ConcurrentMergeScheduler
- compareImplementationDistance(Class<? extends C>, VirtualMethod<C>, VirtualMethod<C>) - Static method in class org.apache.lucene.util.VirtualMethod
-
Utility method that compares the implementation/override distance of two methods.
- comparePivot(int) - Method in class org.apache.lucene.util.SorterTemplate
-
Implements the compare function for the previously stored pivot value.
- compareTo(QualityQuery) - Method in class org.apache.lucene.benchmark.quality.QualityQuery
- compareTo(CategoryPath) - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
-
Compares this CategoryPath with the other CategoryPath for lexicographic order.
- 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(SimpleTerm) - Method in class org.apache.lucene.queryParser.surround.query.SimpleTerm
- 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(FieldTermStack.TermInfo) - Method in class org.apache.lucene.search.vectorhighlight.FieldTermStack.TermInfo
- compareTo(BytesRef) - Method in class org.apache.lucene.util.BytesRef
-
Unsigned byte order comparison
- compareTo(CharsRef) - Method in class org.apache.lucene.util.CharsRef
-
Signed int order comparison
- compareTo(Util.MinResult<T>) - Method in class org.apache.lucene.util.fst.Util.MinResult
- compareTo(IntsRef) - Method in class org.apache.lucene.util.IntsRef
-
Signed int order comparison
- compareValues(Float, Float) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
- compareValues(String, String) - Method in class org.apache.lucene.search.FieldComparator.StringComparatorLocale
- compareValues(String, String) - Method in class org.apache.lucene.search.FieldComparator.StringOrdValComparator
- compareValues(String, String) - Method in class org.apache.lucene.search.FieldComparator.StringValComparator
- compareValues(T, T) - Method in class org.apache.lucene.search.FieldComparator
-
Returns -1 if first is less than second.
- compIDXEnd - Variable in class org.apache.lucene.search.grouping.AbstractAllGroupHeadsCollector
- compile(String) - Method in class org.apache.lucene.search.regex.JakartaRegexpCapabilities
- compile(String) - Method in class org.apache.lucene.search.regex.JavaUtilRegexCapabilities
- compile(String) - Method in interface org.apache.lucene.search.regex.RegexCapabilities
-
Called by the constructor of
RegexTermEnum
allowing implementations to cache a compiled version of the regular expression pattern. - Compile - Class in org.egothor.stemmer
-
The Compile class is used to compile a stemmer table.
- Compile() - Constructor for class org.egothor.stemmer.Compile
- ComplementCountingAggregator - Class in org.apache.lucene.facet.search.aggregator
-
A
CountingAggregator
used during complement counting. - ComplementCountingAggregator(int[]) - Constructor for class org.apache.lucene.facet.search.aggregator.ComplementCountingAggregator
- ComplexExplanation - Class in org.apache.lucene.search
-
Expert: Describes the score computation for document and query, and can distinguish a match independent of a positive value.
- ComplexExplanation() - Constructor for class org.apache.lucene.search.ComplexExplanation
- ComplexExplanation(boolean, float, String) - Constructor for class org.apache.lucene.search.ComplexExplanation
- ComplexPhraseQueryParser - Class in org.apache.lucene.queryParser.complexPhrase
-
QueryParser which permits complex phrase query syntax eg "(john jon jonathan~) peters*".
- ComplexPhraseQueryParser(Version, String, Analyzer) - Constructor for class org.apache.lucene.queryParser.complexPhrase.ComplexPhraseQueryParser
- ComposedQuery - Class in org.apache.lucene.queryParser.surround.query
- ComposedQuery(List, boolean, String) - Constructor for class org.apache.lucene.queryParser.surround.query.ComposedQuery
- compound - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
-
True if segment is compound file format.
- COMPOUND_EXTENSIONS - Static variable in class org.apache.lucene.index.IndexFileNames
-
File extensions of old-style index files
- COMPOUND_FILE_EXTENSION - Static variable in class org.apache.lucene.index.IndexFileNames
-
Extension of compound file
- COMPOUND_FILE_STORE_EXTENSION - Static variable in class org.apache.lucene.index.IndexFileNames
-
Extension of compound file for doc store files
- COMPOUND_FILES - Static variable in class org.apache.lucene.index.NoMergePolicy
-
A singleton
NoMergePolicy
which indicates the index uses compound files. - CompoundFileExtractor - Class in org.apache.lucene.index
-
Command-line tool for extracting sub-files out of a compound file.
- CompoundFileExtractor() - Constructor for class org.apache.lucene.index.CompoundFileExtractor
- CompoundFileWriter - Class in org.apache.lucene.index
-
Combines multiple files into a single compound file.
- CompoundFileWriter(Directory, String) - Constructor for class org.apache.lucene.index.CompoundFileWriter
-
Create the compound stream in the specified file.
- CompoundToken(int, int) - Constructor for class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase.CompoundToken
-
Construct the compound token based on a slice of the current
CompoundWordTokenFilterBase.termAtt
. - CompoundWordTokenFilterBase - Class in org.apache.lucene.analysis.compound
-
Base class for decomposition token filters.
- CompoundWordTokenFilterBase(TokenStream, String[]) - Constructor for class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
-
Deprecated.
- CompoundWordTokenFilterBase(TokenStream, String[], boolean) - Constructor for class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
-
Deprecated.
- CompoundWordTokenFilterBase(TokenStream, String[], int, int, int, boolean) - Constructor for class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
-
Deprecated.
- CompoundWordTokenFilterBase(TokenStream, Set<?>) - Constructor for class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
-
Deprecated.
- CompoundWordTokenFilterBase(TokenStream, Set<?>, boolean) - Constructor for class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
-
Deprecated.
- CompoundWordTokenFilterBase(TokenStream, Set<?>, int, int, int, boolean) - Constructor for class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
-
Deprecated.
- CompoundWordTokenFilterBase(Version, TokenStream, String[]) - Constructor for class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
- CompoundWordTokenFilterBase(Version, TokenStream, String[], boolean) - Constructor for class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
- CompoundWordTokenFilterBase(Version, TokenStream, String[], int, int, int, boolean) - Constructor for class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
- CompoundWordTokenFilterBase(Version, TokenStream, Set<?>) - Constructor for class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
- CompoundWordTokenFilterBase(Version, TokenStream, Set<?>, boolean) - Constructor for class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
- CompoundWordTokenFilterBase(Version, TokenStream, Set<?>, 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[]) - Static method in class org.apache.lucene.document.CompressionTools
-
Compresses all bytes in the array, with default BEST_COMPRESSION level
- compress(byte[], int, int) - Static method in class org.apache.lucene.document.CompressionTools
-
Compresses the specified byte range, with default BEST_COMPRESSION level
- compress(byte[], int, int, int) - Static method in class org.apache.lucene.document.CompressionTools
-
Compresses the specified byte range using the specified compressionLevel (constants are defined in java.util.zip.Deflater).
- CompressionTools - Class in org.apache.lucene.document
-
Simple utility class providing static methods to compress and decompress binary data for stored fields.
- compressString(String) - Static method in class org.apache.lucene.document.CompressionTools
-
Compresses the String value, with default BEST_COMPRESSION level
- compressString(String, int) - Static method in class org.apache.lucene.document.CompressionTools
-
Compresses the String value using the specified compressionLevel (constants are defined in java.util.zip.Deflater).
- computeLengthNorm(String, int) - Method in class org.apache.lucene.misc.SweetSpotSimilarity
-
Implemented as:
1/sqrt( steepness * (abs(x-min) + abs(x-max) - (max-min)) + 1 )
. - computeNorm(String, FieldInvertState) - Method in class org.apache.lucene.misc.SweetSpotSimilarity
-
Implemented as
state.getBoost() * lengthNorm(fieldName, numTokens)
where numTokens does not count overlap tokens if discountOverlaps is true by default or true for this specific field. - computeNorm(String, FieldInvertState) - Method in class org.apache.lucene.search.DefaultSimilarity
-
Implemented as
state.getBoost()*lengthNorm(numTerms)
, wherenumTerms
isFieldInvertState.getLength()
ifDefaultSimilarity.setDiscountOverlaps(boolean)
is false, else it'sFieldInvertState.getLength()
-FieldInvertState.getNumOverlap()
. - computeNorm(String, FieldInvertState) - Method in class org.apache.lucene.search.Similarity
-
Computes the normalization value for a field, given the accumulated state of term processing for this field (see
FieldInvertState
). - computeNorm(String, FieldInvertState) - Method in class org.apache.lucene.search.SimilarityDelegator
-
Deprecated.
- computeTestMethods() - Method in class org.apache.lucene.util.LuceneTestCaseRunner
- ConcurrentMergeScheduler - Class in org.apache.lucene.index
-
A
MergeScheduler
that runs each merge using a separate thread. - ConcurrentMergeScheduler() - Constructor for class org.apache.lucene.index.ConcurrentMergeScheduler
- ConcurrentMergeScheduler.MergeThread - Class in org.apache.lucene.index
- 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.
- ConfigAttribute - Interface in org.apache.lucene.queryParser.core.config
-
Deprecated.
- ConfigurationKey<T> - Class in org.apache.lucene.queryParser.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.standard.config.StandardQueryConfigHandler.ConfigurationKeys
- configureWriter(Config, PerfRunData, IndexWriterConfig.OpenMode, IndexCommit) - Static method in class org.apache.lucene.benchmark.byTask.tasks.CreateIndexTask
- ConjQuery(CharSequence) - Method in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParser
- Conjunction() - Method in class org.apache.lucene.queryParser.QueryParser
- Conjunction() - Method in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParser
- ConnectionCosts - Class in org.apache.lucene.analysis.ja.dict
-
n-gram connection cost data
- CONSTANT_SCORE_AUTO_REWRITE_DEFAULT - Static variable in class org.apache.lucene.search.MultiTermQuery
-
Read-only default instance of
MultiTermQuery.ConstantScoreAutoRewrite
, withConstantScoreAutoRewrite.setTermCountCutoff(int)
set toConstantScoreAutoRewrite.DEFAULT_TERM_COUNT_CUTOFF
andConstantScoreAutoRewrite.setDocCountPercent(double)
set toConstantScoreAutoRewrite.DEFAULT_DOC_COUNT_PERCENT
. - CONSTANT_SCORE_BOOLEAN_QUERY_REWRITE - Static variable in class org.apache.lucene.search.MultiTermQuery
-
Like
MultiTermQuery.SCORING_BOOLEAN_QUERY_REWRITE
except scores are not computed. - CONSTANT_SCORE_BOOLEAN_QUERY_REWRITE - Static variable in class org.apache.lucene.search.ScoringRewrite
-
Like
ScoringRewrite.SCORING_BOOLEAN_QUERY_REWRITE
except scores are not computed. - CONSTANT_SCORE_FILTER_REWRITE - Static variable in class org.apache.lucene.search.MultiTermQuery
-
A rewrite method that first creates a private Filter, by visiting each term in sequence and marking all docs for that term.
- Constants - Class in org.apache.lucene.benchmark
-
Various benchmarking constants (mostly defaults)
- Constants - Class in org.apache.lucene.util
-
Some useful constants.
- Constants() - Constructor for class org.apache.lucene.benchmark.Constants
- ConstantScoreAutoRewrite() - Constructor for class org.apache.lucene.search.MultiTermQuery.ConstantScoreAutoRewrite
- ConstantScoreQuery - Class in org.apache.lucene.search
-
A query that wraps another query or a filter and simply returns a constant score equal to the query boost for every document that matches the filter or query.
- ConstantScoreQuery(Filter) - Constructor for class org.apache.lucene.search.ConstantScoreQuery
-
Wraps a Filter as a Query.
- ConstantScoreQuery(Query) - Constructor for class org.apache.lucene.search.ConstantScoreQuery
-
Strips off scores from the passed in Query.
- ConstantScoreQuery.ConstantScorer - Class in org.apache.lucene.search
- ConstantScoreQuery.ConstantWeight - Class in org.apache.lucene.search
- ConstantScoreQueryBuilder - Class in org.apache.lucene.xmlparser.builders
- ConstantScoreQueryBuilder(FilterBuilderFactory) - Constructor for class org.apache.lucene.xmlparser.builders.ConstantScoreQueryBuilder
- ConstantScorer(Similarity, DocIdSetIterator, Weight) - Constructor for class org.apache.lucene.search.ConstantScoreQuery.ConstantScorer
- ConstantWeight(Searcher) - Constructor for class org.apache.lucene.search.ConstantScoreQuery.ConstantWeight
- consumeAllTokens() - Method in class org.apache.lucene.analysis.TeeSinkTokenFilter
-
TeeSinkTokenFilter
passes all tokens to the added sinks when itself is consumed. - ConsumeContentSourceTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Consumes a
ContentSource
. - ConsumeContentSourceTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.ConsumeContentSourceTask
- contains(char[], int, int) - Method in class org.apache.lucene.analysis.CharArraySet
-
true if the
len
chars oftext
starting atoff
are in the set - contains(int) - Method in class org.apache.lucene.util.collections.IntHashSet
-
Checks if a given key exists in the map.
- contains(CharSequence) - Method in class org.apache.lucene.analysis.CharArraySet
-
true if the
CharSequence
is in the set - contains(Object) - Method in class org.apache.lucene.analysis.CharArrayMap.EntrySet
- contains(Object) - Method in class org.apache.lucene.analysis.CharArraySet
- contains(Object) - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorPipeline
- contains(Object) - Method in class org.apache.lucene.util.MapBackedSet
- contains(SegmentInfo) - Method in class org.apache.lucene.index.SegmentInfos
- contains(Point2D) - Method in class org.apache.lucene.spatial.geometry.shape.Ellipse
-
Deprecated.
- contains(Point2D) - Method in interface org.apache.lucene.spatial.geometry.shape.Geometry2D
-
Deprecated.Does the shape contain the given point
- contains(Point2D) - Method in class org.apache.lucene.spatial.geometry.shape.Rectangle
-
Deprecated.
- CONTAINS - org.apache.lucene.spatial.geometry.shape.IntersectCase
-
Deprecated.
- containsAll(Collection<?>) - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorPipeline
- containsKey(char[], int, int) - Method in class org.apache.lucene.analysis.CharArrayMap
- containsKey(float) - Method in class org.apache.lucene.util.collections.FloatToObjectMap
-
Checks if a given key exists in the map.
- containsKey(int) - Method in class org.apache.lucene.util.collections.IntToDoubleMap
-
Checks if a given key exists in the map.
- containsKey(int) - Method in class org.apache.lucene.util.collections.IntToIntMap
-
Checks if a given key exists in the map.
- containsKey(int) - Method in class org.apache.lucene.util.collections.IntToObjectMap
-
Checks if a given key exists in the map.
- containsKey(CharSequence) - Method in class org.apache.lucene.analysis.CharArrayMap
-
true if the
CharSequence
is in theCharArrayMap.keySet
- containsKey(Object) - Method in class org.apache.lucene.analysis.CharArrayMap
- containsKey(Object) - Method in class org.apache.lucene.util.WeakIdentityMap
- containsKey(K) - Method in class org.apache.lucene.util.collections.ArrayHashMap
-
Returns true iff the key exists in the map.
- containsKey(K) - Method in class org.apache.lucene.util.collections.ObjectToFloatMap
-
Checks if a given key exists in the map.
- containsKey(K) - Method in class org.apache.lucene.util.collections.ObjectToIntMap
-
Checks if a given key exists in the map.
- containsTag(CharSequence) - Method in interface org.apache.lucene.queryParser.core.nodes.QueryNode
-
Deprecated.use
QueryNode.containsTag(String)
instead - containsTag(CharSequence) - Method in class org.apache.lucene.queryParser.core.nodes.QueryNodeImpl
-
Deprecated.use
QueryNodeImpl.containsTag(String)
instead - containsTag(String) - Method in interface org.apache.lucene.queryParser.core.nodes.QueryNode
-
verify if a node contains a tag
- containsTag(String) - Method in class org.apache.lucene.queryParser.core.nodes.QueryNodeImpl
-
verify if a node contains a tag
- containsValue(double) - Method in class org.apache.lucene.util.collections.IntToDoubleMap
-
Checks if the given value exists in the map.
This method iterates over the collection, trying to find an equal object. - containsValue(float) - Method in class org.apache.lucene.util.collections.ObjectToFloatMap
-
Checks if the given object exists in the map.
This method iterates over the collection, trying to find an equal object. - containsValue(int) - Method in class org.apache.lucene.util.collections.IntToIntMap
-
Checks if the given object exists in the map.
This method iterates over the collection, trying to find an equal object. - containsValue(int) - Method in class org.apache.lucene.util.collections.ObjectToIntMap
-
Checks if the given object exists in the map.
This method iterates over the collection, trying to find an equal object. - containsValue(Object) - Method in class org.apache.lucene.util.collections.ArrayHashMap
-
Returns true iff the object exists in the map.
- containsValue(Object) - Method in class org.apache.lucene.util.collections.FloatToObjectMap
-
Checks if the given object exists in the map.
This method iterates over the collection, trying to find an equal object. - containsValue(Object) - Method in class org.apache.lucene.util.collections.IntToObjectMap
-
Checks if the given object exists in the map.
This method iterates over the collection, trying to find an equal object. - 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
- convert(double, DistanceUnits) - Method in enum org.apache.lucene.spatial.geometry.DistanceUnits
-
Deprecated.Converts the given distance in given DistanceUnit, to a distance in the unit represented by
this
- convertStreamToByteArray() - Method in class org.apache.lucene.facet.index.CategoryListPayloadStream
-
Returns the streamed bytes so far accumulated, as an array of bytes.
- coord(int, int) - Method in class org.apache.lucene.search.DefaultSimilarity
-
Implemented as
overlap / maxOverlap
. - coord(int, int) - Method in class org.apache.lucene.search.Similarity
-
Computes a score factor based on the fraction of all query terms that a document contains.
- coord(int, int) - Method in class org.apache.lucene.search.SimilarityDelegator
-
Deprecated.
- coords(double, double) - Method in interface org.apache.lucene.spatial.tier.projections.IProjector
-
Deprecated.
- coords(double, double) - Method in class org.apache.lucene.spatial.tier.projections.SinusoidalProjector
-
Deprecated.
- coordsAsString(double, double) - Method in interface org.apache.lucene.spatial.tier.projections.IProjector
-
Deprecated.
- coordsAsString(double, double) - Method in class org.apache.lucene.spatial.tier.projections.SinusoidalProjector
-
Deprecated.
- copy() - Method in class org.apache.lucene.spatial.geometry.FixedLatLng
-
Deprecated.
- copy() - Method in class org.apache.lucene.spatial.geometry.FloatLatLng
-
Deprecated.
- copy() - Method in class org.apache.lucene.spatial.geometry.LatLng
-
Deprecated.
- copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.ByteComparator
- copy(int, int) - Method in class org.apache.lucene.search.FieldComparator
-
This method is called when a new hit is competitive.
- copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.DocComparator
- copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.DoubleComparator
- copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.FloatComparator
- copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.IntComparator
- copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.LongComparator
- copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
- copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.ShortComparator
- copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.StringComparatorLocale
- copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.StringOrdValComparator
- copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.StringValComparator
- copy(Set<?>) - Static method in class org.apache.lucene.analysis.CharArraySet
-
Deprecated.use
CharArraySet.copy(Version, Set)
instead. - copy(Directory, String, String) - Method in class org.apache.lucene.store.Directory
-
Copies the file src to
Directory
to under the new file name dest. - copy(Directory, String, String) - Method in class org.apache.lucene.store.MockDirectoryWrapper
- copy(Directory, Directory, boolean) - Static method in class org.apache.lucene.store.Directory
-
Deprecated.should be replaced with calls to
Directory.copy(Directory, String, String)
for every file that needs copying. You can use the following code:IndexFileNameFilter filter = IndexFileNameFilter.getFilter(); for (String file : src.listAll()) { if (filter.accept(null, file)) { src.copy(dest, file, file); } }
- copy(IndexInput, long) - Method in class org.apache.lucene.util.PagedBytes
-
Read this many bytes from in
- copy(BytesRef) - Method in class org.apache.lucene.util.ByteBlockPool
-
Copies the given
BytesRef
at the current positions (ByteBlockPool.byteUpto
across buffer boundaries - copy(BytesRef) - Method in class org.apache.lucene.util.PagedBytes
-
Copy BytesRef in
- copy(BytesRef, BytesRef) - Method in class org.apache.lucene.util.PagedBytes
-
Copy BytesRef in, setting BytesRef out to the result.
- copy(Version, Map<?, ? extends V>) - Static method in class org.apache.lucene.analysis.CharArrayMap
-
Returns a copy of the given map as a
CharArrayMap
. - copy(Version, Set<?>) - Static method in class org.apache.lucene.analysis.CharArraySet
-
Returns a copy of the given set as a
CharArraySet
. - 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.DataOutput
-
Copy numBytes bytes from input to ourself.
- copyBytes(DataInput, long) - Method in class org.apache.lucene.store.MockIndexOutputWrapper
- copyBytes(DataInput, long) - Method in class org.apache.lucene.store.RAMOutputStream
- copyBytes(DataInput, long) - Method in class org.apache.lucene.util.ThrottledIndexOutput
- copyBytes(IndexOutput, long) - Method in class org.apache.lucene.store.BufferedIndexInput
- copyBytes(IndexOutput, long) - Method in class org.apache.lucene.store.IndexInput
-
Copies
numBytes
bytes to the givenIndexOutput
. - copyBytes(IndexOutput, long) - Method in class org.apache.lucene.store.MockIndexInputWrapper
- copyBytes(IndexOutput, long) - Method in class org.apache.lucene.store.RAMInputStream
- copyBytes(IndexOutput, long) - Method in class org.apache.lucene.store.SimpleFSDirectory.SimpleFSIndexInput
- copyBytes(BytesRef) - Method in class org.apache.lucene.util.BytesRef
-
Copies the bytes from the given
BytesRef
- copyChars(char[], int, int) - Method in class org.apache.lucene.util.BytesRef
-
Copies the UTF8 bytes for this string.
- copyChars(char[], int, int) - Method in class org.apache.lucene.util.CharsRef
-
Copies the given array into this CharsRef.
- copyChars(CharSequence) - Method in class org.apache.lucene.util.BytesRef
-
Copies the UTF8 bytes for this string.
- copyChars(CharsRef) - Method in class org.apache.lucene.util.CharsRef
-
Copies the given
CharsRef
referenced content into this instance. - copyDocGroupValue(GROUP_VALUE_TYPE, GROUP_VALUE_TYPE) - Method in class org.apache.lucene.search.grouping.AbstractFirstPassGroupingCollector
-
Returns a copy of the specified group value by creating a new instance and copying the value from the specified groupValue in the new instance.
- copyDocGroupValue(String, String) - Method in class org.apache.lucene.search.grouping.TermFirstPassGroupingCollector
- copyFrom(BytesRef) - Method in class org.apache.lucene.util.ByteBlockPool
- copyFrom(FST.Arc<T>) - Method in class org.apache.lucene.util.fst.FST.Arc
-
Returns this
- copyInts(IntsRef) - Method in class org.apache.lucene.util.IntsRef
- copyText(UnicodeUtil.UTF16Result) - Method in class org.apache.lucene.util.UnicodeUtil.UTF16Result
- copyTo(byte[], int) - Method in class org.apache.lucene.index.Payload
-
Copies the payload data to a byte array.
- copyTo(AttributeImpl) - Method in class org.apache.lucene.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.Token
- copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
- copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.FlagsAttributeImpl
- copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.KeywordAttributeImpl
- copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
- copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
- copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
- copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.PositionLengthAttributeImpl
- copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
- copyTo(AttributeImpl) - Method in class org.apache.lucene.facet.index.attributes.CategoryAttributeImpl
- copyTo(AttributeImpl) - Method in class org.apache.lucene.queryParser.standard.config.AllowLeadingWildcardAttributeImpl
-
Deprecated.
- copyTo(AttributeImpl) - Method in class org.apache.lucene.queryParser.standard.config.AnalyzerAttributeImpl
-
Deprecated.
- copyTo(AttributeImpl) - Method in class org.apache.lucene.queryParser.standard.config.BoostAttributeImpl
-
Deprecated.
- copyTo(AttributeImpl) - Method in class org.apache.lucene.queryParser.standard.config.DateResolutionAttributeImpl
-
Deprecated.
- copyTo(AttributeImpl) - Method in class org.apache.lucene.queryParser.standard.config.DefaultOperatorAttributeImpl
-
Deprecated.
- copyTo(AttributeImpl) - Method in class org.apache.lucene.queryParser.standard.config.DefaultPhraseSlopAttributeImpl
-
Deprecated.
- copyTo(AttributeImpl) - Method in class org.apache.lucene.queryParser.standard.config.FieldBoostMapAttributeImpl
-
Deprecated.
- copyTo(AttributeImpl) - Method in class org.apache.lucene.queryParser.standard.config.FieldDateResolutionMapAttributeImpl
-
Deprecated.
- copyTo(AttributeImpl) - Method in class org.apache.lucene.queryParser.standard.config.FuzzyAttributeImpl
-
Deprecated.
- copyTo(AttributeImpl) - Method in class org.apache.lucene.queryParser.standard.config.LocaleAttributeImpl
-
Deprecated.
- copyTo(AttributeImpl) - Method in class org.apache.lucene.queryParser.standard.config.LowercaseExpandedTermsAttributeImpl
-
Deprecated.
- copyTo(AttributeImpl) - Method in class org.apache.lucene.queryParser.standard.config.MultiFieldAttributeImpl
-
Deprecated.
- copyTo(AttributeImpl) - Method in class org.apache.lucene.queryParser.standard.config.MultiTermRewriteMethodAttributeImpl
-
Deprecated.
- copyTo(AttributeImpl) - Method in class org.apache.lucene.queryParser.standard.config.PositionIncrementsAttributeImpl
-
Deprecated.
- copyTo(AttributeImpl) - Method in class org.apache.lucene.queryParser.standard.config.RangeCollatorAttributeImpl
-
Deprecated.
- 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 targetAttributeSource
. - copyToCharArray(char[], int, int, char) - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
-
Copies the specified number of components from this category path to the specified character array, with the components separated by a given delimiter character.
- copyUsingLengthPrefix(BytesRef) - Method in class org.apache.lucene.util.PagedBytes
-
Copy bytes in, writing the length as a 1 or 2 byte vInt prefix.
- CoreParser - Class in org.apache.lucene.xmlparser
-
Assembles a QueryBuilder which uses only core Lucene Query objects
- CoreParser(String, Analyzer) - Constructor for class org.apache.lucene.xmlparser.CoreParser
-
Constructs an XML parser that creates a QueryParser for each UserQuery request.
- CoreParser(String, Analyzer, QueryParser) - Constructor for class org.apache.lucene.xmlparser.CoreParser
- CoreParser(Analyzer, QueryParser) - Constructor for class org.apache.lucene.xmlparser.CoreParser
-
Construct an XML parser that uses a single instance QueryParser for handling UserQuery tags - all parse operations are synchronised on this parser
- CorePlusExtensionsParser - Class in org.apache.lucene.xmlparser
- CorePlusExtensionsParser(String, Analyzer) - Constructor for class org.apache.lucene.xmlparser.CorePlusExtensionsParser
-
Constructs an XML parser that creates a QueryParser for each UserQuery request.
- CorePlusExtensionsParser(Analyzer, QueryParser) - Constructor for class org.apache.lucene.xmlparser.CorePlusExtensionsParser
-
Construct an XML parser that uses a single instance QueryParser for handling UserQuery tags - all parse operations are synchronized on this parser
- correct(int) - Method in class org.apache.lucene.analysis.BaseCharFilter
-
Retrieve the corrected offset.
- correct(int) - Method in class org.apache.lucene.analysis.CharFilter
-
Subclass may want to override to correct the current offset.
- correctOffset(int) - Method in class org.apache.lucene.analysis.CharFilter
-
Chains the corrected offset through the input CharFilter.
- correctOffset(int) - Method in class org.apache.lucene.analysis.CharReader
- correctOffset(int) - Method in class org.apache.lucene.analysis.CharStream
-
Called by CharFilter(s) and Tokenizer to correct token offset.
- correctOffset(int) - Method in class org.apache.lucene.analysis.MockCharFilter
- correctOffset(int) - Method in class org.apache.lucene.analysis.Tokenizer
-
Return the corrected offset.
- CorruptIndexException - Exception in org.apache.lucene.index
-
This exception is thrown when Lucene detects an inconsistency in the index.
- CorruptIndexException(String) - Constructor for exception org.apache.lucene.index.CorruptIndexException
- COULD_NOT_PARSE_NUMBER - Static variable in class org.apache.lucene.queryParser.core.messages.QueryParserMessages
- count - Static variable in class org.apache.lucene.benchmark.utils.ExtractWikipedia
- count - Variable in class org.apache.lucene.search.grouping.SentinelIntSet
- count - Variable in class org.apache.lucene.search.spans.TermSpans
- count() - Method in class org.apache.lucene.util.BitVector
-
Returns the total number of one bits in this vector.
- counter - Variable in class org.apache.lucene.facet.taxonomy.writercache.cl2o.LabelToOrdinal
- counter - Variable in class org.apache.lucene.index.SegmentInfos
- Counter - Class in org.apache.lucene.util
-
Simple counter class
- Counter() - Constructor for class org.apache.lucene.util.Counter
- counterArray - Variable in class org.apache.lucene.facet.search.aggregator.CountingAggregator
- CountFacetRequest - Class in org.apache.lucene.facet.search.params
-
Facet request for counting facets.
- CountFacetRequest(CategoryPath, int) - Constructor for class org.apache.lucene.facet.search.params.CountFacetRequest
-
Create a count facet request for a given node in the taxonomy.
- CountingAggregator - Class in org.apache.lucene.facet.search.aggregator
-
A CountingAggregator updates a counter array with the size of the whole taxonomy, counting the number of times each category appears in the given set of documents.
- CountingAggregator(int[]) - Constructor for class org.apache.lucene.facet.search.aggregator.CountingAggregator
- CountingListTokenizer - Class in org.apache.lucene.facet.index.streaming
-
CategoryListTokenizer
for facet counting - CountingListTokenizer(TokenStream, FacetIndexingParams) - Constructor for class org.apache.lucene.facet.index.streaming.CountingListTokenizer
- cp - Variable in class org.apache.lucene.index.SnapshotDeletionPolicy.SnapshotCommitPoint
- crash() - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
Simulates a crash of OS or machine by overwriting unsynced files.
- create() - Method in class org.apache.lucene.facet.search.FloatArrayAllocator
- create() - Method in class org.apache.lucene.facet.search.IntArrayAllocator
- create() - Method in class org.apache.lucene.facet.search.TemporaryObjectAllocator
-
Subclasses must override this method to actually create a new object of the desired type.
- create(boolean, boolean, double) - Static method in class org.apache.lucene.search.CachingCollector
-
Creates a
CachingCollector
which does not wrap another collector. - create(int, boolean) - Static method in class org.apache.lucene.facet.search.ScoredDocIdCollector
-
Creates a new
ScoredDocIdCollector
with the given parameters. - create(int, boolean) - Static method in class org.apache.lucene.search.TopScoreDocCollector
-
Creates a new
TopScoreDocCollector
given the number of hits to collect and whether documents are scored in order by the inputScorer
toTopScoreDocCollector.setScorer(Scorer)
. - create(int, ScoreDoc, boolean) - Static method in class org.apache.lucene.search.TopScoreDocCollector
-
Creates a new
TopScoreDocCollector
given the number of hits to collect, the bottom of the previous page, and whether documents are scored in order by the inputScorer
toTopScoreDocCollector.setScorer(Scorer)
. - create(String, String, String, String) - Method in class org.apache.lucene.benchmark.utils.ExtractWikipedia
- create(String, Sort) - Static method in class org.apache.lucene.search.grouping.TermAllGroupHeadsCollector
-
Creates an
AbstractAllGroupHeadsCollector
instance based on the supplied arguments. - create(String, Sort, int) - Static method in class org.apache.lucene.search.grouping.TermAllGroupHeadsCollector
-
Creates an
AbstractAllGroupHeadsCollector
instance based on the supplied arguments. - create(Collector, boolean, double) - Static method in class org.apache.lucene.search.CachingCollector
-
Create a new
CachingCollector
that wraps the given collector and caches documents and scores up to the specified RAM threshold. - create(Collector, boolean, int) - Static method in class org.apache.lucene.search.CachingCollector
-
Create a new
CachingCollector
that wraps the given collector and caches documents and scores up to the specified max docs threshold. - create(SortField[], int) - Static method in class org.apache.lucene.search.FieldValueHitQueue
-
Creates a hit queue sorted by the given list of fields.
- create(Sort, int, boolean, boolean, boolean, boolean) - Static method in class org.apache.lucene.search.TopFieldCollector
-
Creates a new
TopFieldCollector
from the given arguments. - CREATE - org.apache.lucene.index.IndexWriterConfig.OpenMode
- CREATE_OR_APPEND - org.apache.lucene.index.IndexWriterConfig.OpenMode
- createAggregator(boolean, FacetArrays, IndexReader, TaxonomyReader) - Method in class org.apache.lucene.facet.search.params.association.AssociationFloatSumFacetRequest
- createAggregator(boolean, FacetArrays, IndexReader, TaxonomyReader) - Method in class org.apache.lucene.facet.search.params.association.AssociationIntSumFacetRequest
- createAggregator(boolean, FacetArrays, IndexReader, TaxonomyReader) - Method in class org.apache.lucene.facet.search.params.CountFacetRequest
- createAggregator(boolean, FacetArrays, IndexReader, TaxonomyReader) - Method in class org.apache.lucene.facet.search.params.FacetRequest
-
Create an aggregator for this facet request.
- createAggregator(boolean, FacetArrays, IndexReader, TaxonomyReader) - Method in class org.apache.lucene.facet.search.params.ScoreFacetRequest
- createAllDocsScoredDocIDs(IndexReader) - Static method in class org.apache.lucene.facet.util.ScoredDocIdsUtils
-
Creates a
ScoredDocIDs
which returns document IDs all non-deleted doc ids according to the given reader. - createAnalyzer(String) - Static method in class org.apache.lucene.benchmark.byTask.tasks.NewAnalyzerTask
- createAttributeInstance(Class<? extends Attribute>) - Method in class org.apache.lucene.analysis.Token.TokenAttributeFactory
- createAttributeInstance(Class<? extends Attribute>) - Method in class org.apache.lucene.util.AttributeSource.AttributeFactory
-
returns an
AttributeImpl
for the suppliedAttribute
interface class. - createBox(LatLng, double, double) - Static method in class org.apache.lucene.spatial.geometry.shape.LLRect
-
Deprecated.Approximates a box centered at the given point with the given width and height in miles.
- createCategoryListIterator(IndexReader, int) - Method in class org.apache.lucene.facet.index.params.CategoryListParams
-
Create the category list iterator for the specified partition.
- createCategoryListIterator(IndexReader, TaxonomyReader, FacetSearchParams, int) - Method in class org.apache.lucene.facet.search.params.FacetRequest
-
Create the category list iterator for the specified partition.
- createCollector() - Method in class org.apache.lucene.benchmark.byTask.tasks.ReadTask
- createCollector() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchWithCollectorTask
- createComponents(String, Reader) - Method in class org.apache.lucene.analysis.ar.ArabicAnalyzer
-
Creates
ReusableAnalyzerBase.TokenStreamComponents
used to tokenize all the text in the providedReader
. - createComponents(String, Reader) - Method in class org.apache.lucene.analysis.bg.BulgarianAnalyzer
-
Creates a
ReusableAnalyzerBase.TokenStreamComponents
which tokenizes all the text in the providedReader
. - createComponents(String, Reader) - Method in class org.apache.lucene.analysis.br.BrazilianAnalyzer
-
Creates
ReusableAnalyzerBase.TokenStreamComponents
used to tokenize all the text in the providedReader
. - createComponents(String, Reader) - Method in class org.apache.lucene.analysis.ca.CatalanAnalyzer
-
Creates a
ReusableAnalyzerBase.TokenStreamComponents
which tokenizes all the text in the providedReader
. - createComponents(String, Reader) - Method in class org.apache.lucene.analysis.cjk.CJKAnalyzer
- createComponents(String, Reader) - Method in class org.apache.lucene.analysis.cn.ChineseAnalyzer
-
Deprecated.Creates
ReusableAnalyzerBase.TokenStreamComponents
used to tokenize all the text in the providedReader
. - createComponents(String, Reader) - Method in class org.apache.lucene.analysis.cz.CzechAnalyzer
-
Creates
ReusableAnalyzerBase.TokenStreamComponents
used to tokenize all the text in the providedReader
. - createComponents(String, Reader) - Method in class org.apache.lucene.analysis.da.DanishAnalyzer
-
Creates a
ReusableAnalyzerBase.TokenStreamComponents
which tokenizes all the text in the providedReader
. - createComponents(String, Reader) - Method in class org.apache.lucene.analysis.de.GermanAnalyzer
-
Creates
ReusableAnalyzerBase.TokenStreamComponents
used to tokenize all the text in the providedReader
. - createComponents(String, Reader) - Method in class org.apache.lucene.analysis.el.GreekAnalyzer
-
Creates
ReusableAnalyzerBase.TokenStreamComponents
used to tokenize all the text in the providedReader
. - createComponents(String, Reader) - Method in class org.apache.lucene.analysis.en.EnglishAnalyzer
-
Creates a
ReusableAnalyzerBase.TokenStreamComponents
which tokenizes all the text in the providedReader
. - createComponents(String, Reader) - Method in class org.apache.lucene.analysis.es.SpanishAnalyzer
-
Creates a
ReusableAnalyzerBase.TokenStreamComponents
which tokenizes all the text in the providedReader
. - createComponents(String, Reader) - Method in class org.apache.lucene.analysis.eu.BasqueAnalyzer
-
Creates a
ReusableAnalyzerBase.TokenStreamComponents
which tokenizes all the text in the providedReader
. - createComponents(String, Reader) - Method in class org.apache.lucene.analysis.fa.PersianAnalyzer
-
Creates
ReusableAnalyzerBase.TokenStreamComponents
used to tokenize all the text in the providedReader
. - createComponents(String, Reader) - Method in class org.apache.lucene.analysis.fi.FinnishAnalyzer
-
Creates a
ReusableAnalyzerBase.TokenStreamComponents
which tokenizes all the text in the providedReader
. - createComponents(String, Reader) - Method in class org.apache.lucene.analysis.fr.FrenchAnalyzer
-
Creates
ReusableAnalyzerBase.TokenStreamComponents
used to tokenize all the text in the providedReader
. - createComponents(String, Reader) - Method in class org.apache.lucene.analysis.ga.IrishAnalyzer
-
Creates a
ReusableAnalyzerBase.TokenStreamComponents
which tokenizes all the text in the providedReader
. - createComponents(String, Reader) - Method in class org.apache.lucene.analysis.gl.GalicianAnalyzer
-
Creates a
ReusableAnalyzerBase.TokenStreamComponents
which tokenizes all the text in the providedReader
. - createComponents(String, Reader) - Method in class org.apache.lucene.analysis.hi.HindiAnalyzer
-
Creates
ReusableAnalyzerBase.TokenStreamComponents
used to tokenize all the text in the providedReader
. - createComponents(String, Reader) - Method in class org.apache.lucene.analysis.hu.HungarianAnalyzer
-
Creates a
ReusableAnalyzerBase.TokenStreamComponents
which tokenizes all the text in the providedReader
. - createComponents(String, Reader) - Method in class org.apache.lucene.analysis.hy.ArmenianAnalyzer
-
Creates a
ReusableAnalyzerBase.TokenStreamComponents
which tokenizes all the text in the providedReader
. - createComponents(String, Reader) - Method in class org.apache.lucene.analysis.id.IndonesianAnalyzer
-
Creates
ReusableAnalyzerBase.TokenStreamComponents
used to tokenize all the text in the providedReader
. - createComponents(String, Reader) - Method in class org.apache.lucene.analysis.it.ItalianAnalyzer
-
Creates a
ReusableAnalyzerBase.TokenStreamComponents
which tokenizes all the text in the providedReader
. - createComponents(String, Reader) - Method in class org.apache.lucene.analysis.ja.JapaneseAnalyzer
- createComponents(String, Reader) - Method in class org.apache.lucene.analysis.KeywordAnalyzer
- createComponents(String, Reader) - Method in class org.apache.lucene.analysis.lv.LatvianAnalyzer
-
Creates a
ReusableAnalyzerBase.TokenStreamComponents
which tokenizes all the text in the providedReader
. - createComponents(String, Reader) - Method in class org.apache.lucene.analysis.miscellaneous.PatternAnalyzer
-
Creates a token stream that tokenizes all the text in the given Reader; This implementation forwards to
tokenStream(String, Reader, String)
and is less efficient thantokenStream(String, Reader, String)
. - createComponents(String, Reader) - Method in class org.apache.lucene.analysis.nl.DutchAnalyzer
-
Returns a (possibly reused)
TokenStream
which tokenizes all the text in the providedReader
. - createComponents(String, Reader) - Method in class org.apache.lucene.analysis.no.NorwegianAnalyzer
-
Creates a
ReusableAnalyzerBase.TokenStreamComponents
which tokenizes all the text in the providedReader
. - createComponents(String, Reader) - Method in class org.apache.lucene.analysis.pl.PolishAnalyzer
-
Creates a
ReusableAnalyzerBase.TokenStreamComponents
which tokenizes all the text in the providedReader
. - createComponents(String, Reader) - Method in class org.apache.lucene.analysis.pt.PortugueseAnalyzer
-
Creates a
ReusableAnalyzerBase.TokenStreamComponents
which tokenizes all the text in the providedReader
. - createComponents(String, Reader) - Method in class org.apache.lucene.analysis.ReusableAnalyzerBase
-
Creates a new
ReusableAnalyzerBase.TokenStreamComponents
instance for this analyzer. - createComponents(String, Reader) - Method in class org.apache.lucene.analysis.ro.RomanianAnalyzer
-
Creates a
ReusableAnalyzerBase.TokenStreamComponents
which tokenizes all the text in the providedReader
. - createComponents(String, Reader) - Method in class org.apache.lucene.analysis.ru.RussianAnalyzer
-
Creates
ReusableAnalyzerBase.TokenStreamComponents
used to tokenize all the text in the providedReader
. - createComponents(String, Reader) - Method in class org.apache.lucene.analysis.SimpleAnalyzer
- createComponents(String, Reader) - Method in class org.apache.lucene.analysis.standard.ClassicAnalyzer
- createComponents(String, Reader) - Method in class org.apache.lucene.analysis.standard.StandardAnalyzer
- createComponents(String, Reader) - Method in class org.apache.lucene.analysis.standard.UAX29URLEmailAnalyzer
- createComponents(String, Reader) - Method in class org.apache.lucene.analysis.StopAnalyzer
-
Creates
ReusableAnalyzerBase.TokenStreamComponents
used to tokenize all the text in the providedReader
. - createComponents(String, Reader) - Method in class org.apache.lucene.analysis.sv.SwedishAnalyzer
-
Creates a
ReusableAnalyzerBase.TokenStreamComponents
which tokenizes all the text in the providedReader
. - createComponents(String, Reader) - Method in class org.apache.lucene.analysis.th.ThaiAnalyzer
-
Creates
ReusableAnalyzerBase.TokenStreamComponents
used to tokenize all the text in the providedReader
. - createComponents(String, Reader) - Method in class org.apache.lucene.analysis.tr.TurkishAnalyzer
-
Creates a
ReusableAnalyzerBase.TokenStreamComponents
which tokenizes all the text in the providedReader
. - createComponents(String, Reader) - Method in class org.apache.lucene.analysis.WhitespaceAnalyzer
- createComponents(String, Reader, String) - Method in class org.apache.lucene.analysis.miscellaneous.PatternAnalyzer
-
Creates a token stream that tokenizes the given string into token terms (aka words).
- createEncoder() - Method in class org.apache.lucene.facet.index.params.CategoryListParams
-
Allows to override how categories are encoded and decoded.
- createEntityResolver() - Static method in class org.apache.lucene.xmlparser.CoreParser
- createFacetResultsHandler(TaxonomyReader) - Method in class org.apache.lucene.facet.search.params.FacetRequest
-
Creates a new
FacetResultsHandler
that matches the request logic and current settings, such asdepth
,limits-mode
, etc, as well as the passed inTaxonomyReader
. - 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
- createFragment(IndexReader, int, String, FieldFragList) - 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 class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
- 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) - Method in interface org.apache.lucene.search.vectorhighlight.FragmentsBuilder
-
create multiple fragments.
- createFragments(IndexReader, int, String, FieldFragList, int, String[], String[], Encoder) - Method in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
- createFragments(IndexReader, int, String, FieldFragList, int, String[], String[], Encoder) - Method in interface org.apache.lucene.search.vectorhighlight.FragmentsBuilder
-
create multiple fragments.
- 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. - createJoinQuery(String, String, Query, IndexSearcher) - Static method in class org.apache.lucene.search.join.JoinUtil
-
Method for query time joining.
- createMatchingDecoder() - Method in class org.apache.lucene.util.encoding.DGapIntEncoder
- createMatchingDecoder() - Method in class org.apache.lucene.util.encoding.EightFlagsIntEncoder
- createMatchingDecoder() - Method in class org.apache.lucene.util.encoding.FourFlagsIntEncoder
- createMatchingDecoder() - Method in class org.apache.lucene.util.encoding.IntEncoder
-
Returns an
IntDecoder
which matches this encoder. - createMatchingDecoder() - Method in class org.apache.lucene.util.encoding.NOnesIntEncoder
- createMatchingDecoder() - Method in class org.apache.lucene.util.encoding.SimpleIntEncoder
- createMatchingDecoder() - Method in class org.apache.lucene.util.encoding.SortingIntEncoder
- createMatchingDecoder() - Method in class org.apache.lucene.util.encoding.UniqueValuesIntEncoder
- createMatchingDecoder() - Method in class org.apache.lucene.util.encoding.VInt8IntEncoder
- createNormalizedWeight(Query) - Method in class org.apache.lucene.search.AssertingIndexSearcher
-
Ensures, that the returned
Weight
is not normalized again, which may produce wrong scores. - createNormalizedWeight(Query) - Method in class org.apache.lucene.search.IndexSearcher
-
Creates a normalized weight for a top-level
Query
. - createNormalizedWeight(Query) - Method in class org.apache.lucene.search.MultiSearcher
-
Deprecated.Create weight in multiple index scenario.
- createNormalizedWeight(Query) - Method in class org.apache.lucene.search.Searcher
-
Deprecated.Creates a normalized weight for a top-level
Query
. - createOutput(String) - Method in class org.apache.lucene.store.DirectIOLinuxDirectory
- createOutput(String) - Method in class org.apache.lucene.store.Directory
-
Creates a new, empty file in the directory with the given name.
- createOutput(String) - Method in class org.apache.lucene.store.FileSwitchDirectory
- createOutput(String) - Method in class org.apache.lucene.store.FSDirectory
-
Creates an IndexOutput for the file with the given name.
- createOutput(String) - Method in class org.apache.lucene.store.MockDirectoryWrapper
- createOutput(String) - Method in class org.apache.lucene.store.NRTCachingDirectory
- createOutput(String) - Method in class org.apache.lucene.store.RAMDirectory
-
Creates a new, empty file in the directory with the given name.
- createQueryParser(String, Analyzer) - Method in class org.apache.lucene.xmlparser.builders.UserInputQueryBuilder
-
Method to create a QueryParser - designed to be overridden
- createSample(ScoredDocIDs, int, int) - Method in class org.apache.lucene.facet.search.sampling.RandomSampler
- createSample(ScoredDocIDs, int, int) - Method in class org.apache.lucene.facet.search.sampling.RepeatableSampler
- createSample(ScoredDocIDs, int, int) - Method in class org.apache.lucene.facet.search.sampling.Sampler
-
Create and return a sample of the input set
- createScoredDocIds(DocIdSet, int) - Static method in class org.apache.lucene.facet.util.ScoredDocIdsUtils
-
Create a ScoredDocIDs out of a given docIdSet and the total number of documents in an index
- createScoredDocIDsSubset(ScoredDocIDs, int[]) - Static method in class org.apache.lucene.facet.util.ScoredDocIdsUtils
-
Create a subset of an existing ScoredDocIDs object.
- 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.
- createSuitableHeap(FacetRequest) - Static method in class org.apache.lucene.facet.util.ResultSortUtils
-
Create a suitable heap according to facet request being served.
- 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
- createTempFile(String, String, File) - Static method in class org.apache.lucene.util._TestUtil
-
insecure, fast version of File.createTempFile uses Random instead of SecureRandom.
- createTerm(String) - Method in class org.apache.lucene.index.Term
-
Optimized construction of new Terms by reusing same field as this Term - avoids field.intern() overhead
- createWeight(Query) - Method in class org.apache.lucene.search.Searcher
-
Deprecated.never ever use this method in
Weight
implementations. Subclasses of Searcher should useSearcher.createNormalizedWeight(org.apache.lucene.search.Query)
, instead. - createWeight(Searcher) - Method in class org.apache.lucene.search.BooleanQuery
- createWeight(Searcher) - Method in class org.apache.lucene.search.ConstantScoreQuery
- createWeight(Searcher) - Method in class org.apache.lucene.search.DisjunctionMaxQuery
-
Create the Weight used to score us
- createWeight(Searcher) - Method in class org.apache.lucene.search.FilteredQuery
-
Returns a Weight that applies the filter to the enclosed query's Weight.
- createWeight(Searcher) - Method in class org.apache.lucene.search.function.CustomScoreQuery
- createWeight(Searcher) - Method in class org.apache.lucene.search.function.ValueSourceQuery
- createWeight(Searcher) - Method in class org.apache.lucene.search.join.ToChildBlockJoinQuery
- createWeight(Searcher) - Method in class org.apache.lucene.search.join.ToParentBlockJoinQuery
- createWeight(Searcher) - Method in class org.apache.lucene.search.MatchAllDocsQuery
- createWeight(Searcher) - Method in class org.apache.lucene.search.MultiPhraseQuery
- createWeight(Searcher) - Method in class org.apache.lucene.search.payloads.PayloadNearQuery
- createWeight(Searcher) - Method in class org.apache.lucene.search.payloads.PayloadTermQuery
- createWeight(Searcher) - Method in class org.apache.lucene.search.PhraseQuery
- createWeight(Searcher) - Method in class org.apache.lucene.search.Query
-
Expert: Constructs an appropriate Weight implementation for this query.
- createWeight(Searcher) - Method in class org.apache.lucene.search.spans.FieldMaskingSpanQuery
- createWeight(Searcher) - Method in class org.apache.lucene.search.spans.SpanQuery
- createWeight(Searcher) - Method in class org.apache.lucene.search.TermQuery
- createWriterConfig(Config, PerfRunData, IndexWriterConfig.OpenMode, IndexCommit) - Static method in class org.apache.lucene.benchmark.byTask.tasks.CreateIndexTask
- CreationPlaceholder() - Constructor for class org.apache.lucene.search.FieldCache.CreationPlaceholder
- CSVUtil - Class in org.apache.lucene.analysis.ja.util
-
Utility class for parsing CSV text
- 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.benchmark.byTask.feeds.demohtml.HTMLParserTokenManager
- curChar - Variable in class org.apache.lucene.queryParser.QueryParserTokenManager
- curChar - Variable in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserTokenManager
- curChar - Variable in class org.apache.lucene.queryParser.surround.parser.QueryParserTokenManager
- curDocs - Variable in class org.apache.lucene.search.CachingCollector
- curPos - Variable in class org.apache.lucene.search.suggest.BufferingTermFreqIteratorWrapper
- current - Variable in class org.apache.lucene.search.ReferenceManager
- current() - Method in class org.apache.lucene.analysis.icu.segmentation.LaoBreakIterator
- current() - Method in class org.apache.lucene.analysis.util.CharArrayIterator
- current() - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
- current() - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
- CURRENT_FORMAT - Static variable in class org.apache.lucene.index.SegmentInfos
- currentDocumentInformation - Variable in class org.apache.lucene.store.instantiated.InstantiatedTermDocs
- currentScore(int, String, int, int, int, float, float) - Method in class org.apache.lucene.search.payloads.AveragePayloadFunction
- currentScore(int, String, int, int, int, float, float) - Method in class org.apache.lucene.search.payloads.MaxPayloadFunction
- currentScore(int, String, int, int, int, float, float) - Method in class org.apache.lucene.search.payloads.MinPayloadFunction
- currentScore(int, String, int, int, int, float, float) - Method in class org.apache.lucene.search.payloads.PayloadFunction
-
Calculate the score up to this point for this doc and field
- currentTerm - Variable in class org.apache.lucene.search.FilteredTermEnum
-
the current term
- currentTerm - Variable in class org.apache.lucene.store.instantiated.InstantiatedTermDocs
- currentToken - Variable in exception org.apache.lucene.benchmark.byTask.feeds.demohtml.ParseException
-
This is the last token that has been consumed successfully.
- currentToken - Variable in exception org.apache.lucene.queryParser.ParseException
-
This is the last token that has been consumed successfully.
- currentToken - Variable in exception org.apache.lucene.queryParser.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
- cursor - Variable in class org.tartarus.snowball.SnowballProgram
- curThr - Variable in class org.apache.lucene.index.pruning.TFTermPruningPolicy
- CUSTOM - Static variable in class org.apache.lucene.search.SortField
-
Sort using a custom Comparator.
- customExplain(int, Explanation, Explanation) - Method in class org.apache.lucene.search.function.CustomScoreProvider
-
Explain the custom score.
- customExplain(int, Explanation, Explanation[]) - Method in class org.apache.lucene.search.function.CustomScoreProvider
-
Explain the custom score.
- customScore(int, float, float) - Method in class org.apache.lucene.search.function.CustomScoreProvider
-
Compute a custom score by the subQuery score and the ValueSourceQuery score.
- customScore(int, float, float[]) - Method in class org.apache.lucene.search.function.CustomScoreProvider
-
Compute a custom score by the subQuery score and a number of
ValueSourceQuery
scores. - CustomScoreProvider - Class in org.apache.lucene.search.function
-
An instance of this subclass should be returned by
CustomScoreQuery.getCustomScoreProvider(org.apache.lucene.index.IndexReader)
, if you want to modify the custom score calculation of aCustomScoreQuery
. - CustomScoreProvider(IndexReader) - Constructor for class org.apache.lucene.search.function.CustomScoreProvider
-
Creates a new instance of the provider class for the given
IndexReader
. - CustomScoreQuery - Class in org.apache.lucene.search.function
-
Query that sets document score as a programmatic function of several (sub) scores: the score of its subQuery (any query) (optional) the score of its ValueSourceQuery (or queries).
- CustomScoreQuery(Query) - Constructor for class org.apache.lucene.search.function.CustomScoreQuery
-
Create a CustomScoreQuery over input subQuery.
- CustomScoreQuery(Query, ValueSourceQuery) - Constructor for class org.apache.lucene.search.function.CustomScoreQuery
-
Create a CustomScoreQuery over input subQuery and a
ValueSourceQuery
. - CustomScoreQuery(Query, ValueSourceQuery...) - Constructor for class org.apache.lucene.search.function.CustomScoreQuery
-
Create a CustomScoreQuery over input subQuery and a
ValueSourceQuery
. - CYRILLIC - Static variable in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
- CZECH_STOP_WORDS - Static variable in class org.apache.lucene.analysis.cz.CzechAnalyzer
-
Deprecated.use
CzechAnalyzer.getDefaultStopSet()
instead - CzechAnalyzer - Class in org.apache.lucene.analysis.cz
-
Analyzer
for Czech language. - CzechAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.cz.CzechAnalyzer
-
Builds an analyzer with the default stop words (
CzechAnalyzer.getDefaultStopSet()
). - CzechAnalyzer(Version, File) - Constructor for class org.apache.lucene.analysis.cz.CzechAnalyzer
-
Deprecated.use
CzechAnalyzer(Version, Set)
instead - CzechAnalyzer(Version, String...) - Constructor for class org.apache.lucene.analysis.cz.CzechAnalyzer
-
Deprecated.use
CzechAnalyzer(Version, Set)
instead - CzechAnalyzer(Version, HashSet<?>) - Constructor for class org.apache.lucene.analysis.cz.CzechAnalyzer
-
Deprecated.use
CzechAnalyzer(Version, Set)
instead - CzechAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.cz.CzechAnalyzer
-
Builds an analyzer with the given stop words.
- CzechAnalyzer(Version, Set<?>, Set<?>) - 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
-
A
TokenFilter
that appliesCzechStemmer
to stem Czech words. - CzechStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.cz.CzechStemFilter
- CzechStemmer - Class in org.apache.lucene.analysis.cz
-
Light Stemmer for Czech.
- CzechStemmer() - Constructor for class org.apache.lucene.analysis.cz.CzechStemmer
D
- 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
-
Analyzer
for Danish. - DanishAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.da.DanishAnalyzer
-
Builds an analyzer with the default stop words:
DanishAnalyzer.DEFAULT_STOPWORD_FILE
. - DanishAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.da.DanishAnalyzer
-
Builds an analyzer with the given stop words.
- DanishAnalyzer(Version, Set<?>, Set<?>) - Constructor for class org.apache.lucene.analysis.da.DanishAnalyzer
-
Builds an analyzer with the given stop words.
- DanishStemmer - Class in org.tartarus.snowball.ext
-
Generated class implementing code defined by a snowball script.
- DanishStemmer() - Constructor for class org.tartarus.snowball.ext.DanishStemmer
- data - Variable in class org.apache.lucene.index.Payload
-
the byte array containing the payload data
- data - Variable in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie.TSTNode
-
The key to the node.
- DataInput - Class in org.apache.lucene.store
-
Abstract base class for performing read operations of Lucene's low-level data types.
- DataInput() - Constructor for class org.apache.lucene.store.DataInput
- DataOutput - Class in org.apache.lucene.store
-
Abstract base class for performing write operations of Lucene's low-level data types.
- DataOutput() - Constructor for class org.apache.lucene.store.DataOutput
- 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_RESOLUTION - Static variable in class org.apache.lucene.queryParser.standard.config.StandardQueryConfigHandler.ConfigurationKeys
-
Key used to set default
DateTools.Resolution
. - DATE_TYPE - Static variable in class org.apache.lucene.analysis.sinks.DateRecognizerSinkFilter
- DateField - Class in org.apache.lucene.document
-
Deprecated.If you build a new index, use
DateTools
orNumericField
instead. This class is included for use with existing indices and will be removed in a future release (possibly Lucene 4.0). - dateFormat - Variable in class org.apache.lucene.analysis.sinks.DateRecognizerSinkFilter
- DateRecognizerSinkFilter - Class in org.apache.lucene.analysis.sinks
-
Attempts to parse the
CharTermAttributeImpl.termBuffer()
as a Date using aDateFormat
. - DateRecognizerSinkFilter() - Constructor for class org.apache.lucene.analysis.sinks.DateRecognizerSinkFilter
-
Uses
DateFormat.getDateInstance()
as theDateFormat
object. - DateRecognizerSinkFilter(DateFormat) - Constructor for class org.apache.lucene.analysis.sinks.DateRecognizerSinkFilter
- DateResolutionAttribute - Interface in org.apache.lucene.queryParser.standard.config
-
Deprecated.
- DateResolutionAttributeImpl - Class in org.apache.lucene.queryParser.standard.config
-
Deprecated.
- DateResolutionAttributeImpl() - Constructor for class org.apache.lucene.queryParser.standard.config.DateResolutionAttributeImpl
-
Deprecated.
- DateTools - Class in org.apache.lucene.document
-
Provides support for converting dates to strings and vice-versa.
- DateTools.Resolution - Enum in org.apache.lucene.document
-
Specifies the time granularity.
- dateToString(Date) - Static method in class org.apache.lucene.document.DateField
-
Deprecated.Converts a Date to a string suitable for indexing.
- dateToString(Date, DateTools.Resolution) - Static method in class org.apache.lucene.document.DateTools
-
Converts a Date to a string suitable for indexing.
- DAY - org.apache.lucene.document.DateTools.Resolution
- DBBI_AVAILABLE - Static variable in class org.apache.lucene.analysis.th.ThaiWordFilter
-
True if the JRE supports a working dictionary-based breakiterator for Thai.
- debugStream - Variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserTokenManager
-
Debug output.
- debugStream - Variable in class org.apache.lucene.queryParser.QueryParserTokenManager
-
Debug output.
- debugStream - Variable in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserTokenManager
-
Debug output.
- debugStream - Variable in class org.apache.lucene.queryParser.surround.parser.QueryParserTokenManager
-
Debug output.
- Decl() - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParser
- DeclName - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
RegularExpression Id.
- decode() - Method in class org.apache.lucene.util.encoding.DGapIntDecoder
- decode() - Method in class org.apache.lucene.util.encoding.EightFlagsIntDecoder
- decode() - Method in class org.apache.lucene.util.encoding.FourFlagsIntDecoder
- decode() - Method in class org.apache.lucene.util.encoding.IntDecoder
-
Decodes data received from the input stream, and returns one decoded integer.
- decode() - Method in class org.apache.lucene.util.encoding.NOnesIntDecoder
- decode() - Method in class org.apache.lucene.util.encoding.SimpleIntDecoder
- decode() - Method in class org.apache.lucene.util.encoding.VInt8IntDecoder
- decode(byte[], Vint8.Position) - Static method in class org.apache.lucene.util.Vint8
-
Decodes a 32-bit integer from
bytes
, beginning at offsetpos.pos
. - decode(char[], int, int, byte[], int, int) - Static method in class org.apache.lucene.util.IndexableBinaryStringTools
-
Decodes the input char sequence into the output byte sequence.
- decode(InputStream) - Static method in class org.apache.lucene.util.Vint8
-
Decodes a 32-bit integer from bytes read from
in
. - decode(String) - Static method in class org.apache.lucene.spatial.geohash.GeoHashUtils
-
Deprecated.Decodes the given geohash into a latitude and longitude
- decode(CharBuffer) - Static method in class org.apache.lucene.util.IndexableBinaryStringTools
-
Deprecated.Use
IndexableBinaryStringTools.decode(char[], int, int, byte[], int, int)
instead. This method will be removed in Lucene 4.0 - decode(CharBuffer, ByteBuffer) - Static method in class org.apache.lucene.util.IndexableBinaryStringTools
-
Deprecated.Use
IndexableBinaryStringTools.decode(char[], int, int, byte[], int, int)
instead. This method will be removed in Lucene 4.0 - decode(BytesRef, ByteArrayDataInput) - Method in class org.apache.lucene.search.suggest.SortedTermFreqIteratorWrapper
- 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
-
Decode the payload that was encoded using
PayloadHelper.encodeFloat(float)
. - decodeInt(byte[], int) - Static method in class org.apache.lucene.analysis.payloads.PayloadHelper
- decodeNorm(byte) - Static method in class org.apache.lucene.search.Similarity
-
Deprecated.Use
Similarity.decodeNormValue(byte)
instead. - decodeNormValue(byte) - Method in class org.apache.lucene.search.Similarity
-
Decodes a normalization factor stored in an index.
- decompose() - Method in class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
-
Decomposes the current
CompoundWordTokenFilterBase.termAtt
and placesCompoundWordTokenFilterBase.CompoundToken
instances in theCompoundWordTokenFilterBase.tokens
list. - 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.
- decompress(byte[]) - Static method in class org.apache.lucene.document.CompressionTools
-
Decompress the byte array previously returned by compress
- decompressString(byte[]) - Static method in class org.apache.lucene.document.CompressionTools
-
Decompress the byte array previously returned by compressString back into a String
- decRef() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyReader
-
Expert: decreases the refCount of this TaxonomyReader instance.
- decRef() - Method in interface 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(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.NRTManager
- decRef(IndexSearcher) - Method in class org.apache.lucene.search.SearcherManager
- deepCopyOf(BytesRef) - Static method in class org.apache.lucene.util.BytesRef
-
Creates a new BytesRef that points to a copy of the bytes from
other
- 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
- DEFALT_FIELD_PREFIX - Static variable in class org.apache.lucene.spatial.tier.projections.CartesianTierPlotter
-
Deprecated.
- DEFAULT - Static variable in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
- DEFAULT - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
Lexical state.
- DEFAULT - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
-
Lexical state.
- DEFAULT - Static variable in interface org.apache.lucene.queryParser.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.search.ChainedFilter
-
Logical operation when none is declared.
- DEFAULT - Static variable in interface org.apache.lucene.search.FieldCache
-
Expert: The cache used internally by sorting and range query classes.
- DEFAULT_ACCURACY - Static variable in class org.apache.lucene.search.spell.SpellChecker
-
The default minimum score to use, if not specified by calling
SpellChecker.setAccuracy(float)
. - DEFAULT_ANALYZER - Static variable in class org.apache.lucene.analysis.miscellaneous.PatternAnalyzer
-
A lower-casing word analyzer with English stop words (can be shared freely across threads without harm); global per class loader.
- DEFAULT_ANALYZER - Static variable in class org.apache.lucene.search.similar.MoreLikeThis
-
Deprecated.This default will be removed in Lucene 4.0 (with the default being null). If you are not using term vectors, explicitly set your analyzer instead.
- DEFAULT_ATTRIBUTE_FACTORY - Static variable in class org.apache.lucene.util.AttributeSource.AttributeFactory
-
This is the default factory that creates
AttributeImpl
s using the class name of the suppliedAttribute
interface class by appendingImpl
to it. - DEFAULT_BOOST - Static variable in class org.apache.lucene.search.similar.MoreLikeThis
-
Boost terms in query based on score.
- DEFAULT_BOUNDARY_CHARS - Static variable in class org.apache.lucene.search.vectorhighlight.SimpleBoundaryScanner
- 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_BUFFERED_BLOCKS - Static variable in class org.apache.lucene.util.RecyclingByteBlockAllocator
- DEFAULT_BYTE_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
-
The default parser for byte values, which are encoded by
Byte.toString(byte)
- DEFAULT_CACHE_CLEAN_SIZE - Static variable in class org.apache.lucene.search.FilterManager
-
Deprecated.The default maximum number of Filters in the cache
- DEFAULT_CACHE_SIZE - Static variable in class org.apache.lucene.facet.search.TotalFacetCountsCache
-
Default size of in memory cache for computed total facet counts.
- DEFAULT_CACHE_SLEEP_TIME - Static variable in class org.apache.lucene.search.FilterManager
-
Deprecated.The default frequency of cache cleanup
- DEFAULT_CAPACITY - Static variable in class org.apache.lucene.util.BytesRefHash
- DEFAULT_COMPARATOR - Static variable in class org.apache.lucene.search.spell.SuggestWordQueue
- DEFAULT_COMPARATOR - Static variable in class org.apache.lucene.search.suggest.fst.Sort
- DEFAULT_COMPLEMENT_THRESHOLD - Static variable in class org.apache.lucene.facet.search.FacetsAccumulator
-
Default threshold for using the complements optimization.
- 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_DEPTH - Static variable in class org.apache.lucene.facet.search.params.FacetRequest
-
Default depth for facets accumulation.
- DEFAULT_DOC_DELETE_STEP - Static variable in class org.apache.lucene.benchmark.byTask.tasks.DeleteDocTask
-
Gap between ids of deleted docs, applies when no docid param is provided.
- DEFAULT_DOUBLE_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
-
The default parser for double values, which are encoded by
Double.toString(double)
- DEFAULT_EPSILON - Static variable in class org.apache.lucene.index.pruning.CarmelTopKTermPruningPolicy
-
Default largest meaningless score difference
- DEFAULT_EXTENSION_FIELD_DELIMITER - Static variable in class org.apache.lucene.queryParser.ext.Extensions
-
The default extension field delimiter character.
- DEFAULT_FACET_DELIM_CHAR - Static variable in class org.apache.lucene.facet.index.params.DefaultFacetIndexingParams
-
delimiter between a categories in a path, e.g.
- DEFAULT_FIELD_MATCH - Static variable in class org.apache.lucene.search.vectorhighlight.FastVectorHighlighter
- DEFAULT_FIELD_NAMES - Static variable in class org.apache.lucene.search.similar.MoreLikeThis
-
Default field names.
- DEFAULT_FIELDS - Static variable in class org.apache.lucene.benchmark.byTask.tasks.WriteLineDocTask
-
Fields to be written by default
- DEFAULT_FLOAT_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
-
The default parser for float values, which are encoded by
Float.toString(float)
- DEFAULT_INT_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
-
The default parser for int values, which are encoded by
Integer.toString(int)
- DEFAULT_LOG_STEP - Static variable in class org.apache.lucene.benchmark.Constants
- DEFAULT_LONG_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
-
The default parser for long values, which are encoded by
Long.toString(long)
- DEFAULT_MAX_BUFF - Static variable in class org.apache.lucene.store.MMapDirectory
- DEFAULT_MAX_BUFFERED - Static variable in class org.apache.lucene.benchmark.byTask.tasks.OpenIndexTask
- DEFAULT_MAX_BUFFERED_DELETE_TERMS - Static variable in class org.apache.lucene.index.IndexWriter
-
Deprecated.
- DEFAULT_MAX_BUFFERED_DELETE_TERMS - Static variable in class org.apache.lucene.index.IndexWriterConfig
-
Disabled by default (because IndexWriter flushes by RAM usage by default).
- DEFAULT_MAX_BUFFERED_DOCS - Static variable in class org.apache.lucene.index.IndexWriter
-
Deprecated.use
IndexWriterConfig.DEFAULT_MAX_BUFFERED_DOCS
instead. - 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_CHARS_TO_ANALYZE - Static variable in class org.apache.lucene.search.highlight.Highlighter
- DEFAULT_MAX_DOC_FREQ - Static variable in class org.apache.lucene.search.similar.MoreLikeThis
-
Ignore words which occur in more than this many docs.
- DEFAULT_MAX_FIELD_LENGTH - Static variable in class org.apache.lucene.benchmark.byTask.tasks.OpenIndexTask
- DEFAULT_MAX_FIELD_LENGTH - Static variable in class org.apache.lucene.index.IndexWriter
-
Deprecated.
- 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_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.search.similar.MoreLikeThis
-
Default maximum number of tokens to parse in each example doc field that is not stored with TermVector support.
- DEFAULT_MAX_QUERY_TERMS - Static variable in class org.apache.lucene.search.similar.MoreLikeThis
-
Return a Query with no more than this many terms.
- DEFAULT_MAX_SAMPLE_SIZE - Static variable in class org.apache.lucene.facet.search.sampling.SamplingParams
-
Default maximum size of sample.
- 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_THREAD_STATES - Static variable in class org.apache.lucene.index.IndexWriterConfig
-
The maximum number of simultaneous threads that may be indexing documents at once in IndexWriter; if more than this many threads arrive they will wait for others to finish.
- DEFAULT_MAX_TOKEN_LENGTH - Static variable in class org.apache.lucene.analysis.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_LENGTH - Static variable in class org.apache.lucene.search.similar.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_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_DOC_FREQ - Static variable in class org.apache.lucene.search.similar.MoreLikeThis
-
Ignore words which do not occur in at least this many docs.
- 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_SAMPLE_SIZE - Static variable in class org.apache.lucene.facet.search.sampling.SamplingParams
-
Default minimum size of sample.
- 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.search.similar.MoreLikeThis
-
Ignore terms with less than this frequency in the source doc.
- DEFAULT_MIN_WORD_LENGTH - Static variable in class org.apache.lucene.search.similar.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_MINIMAL_SUBPATH_LENGTH - Variable in class org.apache.lucene.facet.index.categorypolicy.NonTopLevelPathPolicy
-
The shortest path length delivered is two components (root + one child).
- 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_NUM_LARGE_SEGMENTS - Static variable in class org.apache.lucene.index.BalancedSegmentMergePolicy
-
Deprecated.
- DEFAULT_OPERATOR - Static variable in class org.apache.lucene.queryParser.standard.config.StandardQueryConfigHandler.ConfigurationKeys
-
Key used to set the default boolean operator
- DEFAULT_OVERSAMPLE_FACTOR - Static variable in class org.apache.lucene.facet.search.sampling.SamplingParams
-
Default factor by which more results are requested over the sample set.
- 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_R - Static variable in class org.apache.lucene.index.pruning.CarmelTopKTermPruningPolicy
-
Default number of query terms
- DEFAULT_RAM_BUFFER_SIZE_MB - Static variable in class org.apache.lucene.index.IndexWriter
-
Deprecated.use
IndexWriterConfig.DEFAULT_RAM_BUFFER_SIZE_MB
instead. - 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_READ_CHUNK_SIZE - Static variable in class org.apache.lucene.store.FSDirectory
-
Default read chunk size.
- DEFAULT_READER_POOLING - Static variable in class org.apache.lucene.index.IndexWriterConfig
-
Default setting for
IndexWriterConfig.setReaderPooling(boolean)
. - DEFAULT_READER_TERMS_INDEX_DIVISOR - Static variable in class org.apache.lucene.index.IndexWriterConfig
-
Default value is 1.
- DEFAULT_RESOLUTION - Static variable in class org.apache.lucene.search.TimeLimitingCollector.TimerThread
- DEFAULT_RESULT_MODE - Static variable in class org.apache.lucene.facet.search.params.FacetRequest
-
Default result mode
- DEFAULT_RUN_COUNT - Static variable in class org.apache.lucene.benchmark.Constants
- DEFAULT_SAMPLE_RATIO - Static variable in class org.apache.lucene.facet.search.sampling.SamplingParams
-
Default ratio between size of sample to original size of document set.
- DEFAULT_SAMPLING_THRESHOLD - Static variable in class org.apache.lucene.facet.search.sampling.SamplingParams
-
Default sampling threshold, if number of results is less than this number - no sampling will take place
- DEFAULT_SCALE_UP - Static variable in class org.apache.lucene.benchmark.Constants
- DEFAULT_SCORE - Static variable in interface org.apache.lucene.facet.search.ScoredDocIDsIterator
-
Default score used in case scoring is disabled.
- DEFAULT_SHORT_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
-
The default parser for short values, which are encoded by
Short.toString(short)
- DEFAULT_SIDE - Static variable in class org.apache.lucene.analysis.ngram.EdgeNGramTokenFilter
- DEFAULT_SIDE - Static variable in class org.apache.lucene.analysis.ngram.EdgeNGramTokenizer
- 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_SORT_BY - Static variable in class org.apache.lucene.facet.search.params.FacetRequest
-
Default sort mode.
- DEFAULT_STEMMER_FILE - Static variable in class org.apache.lucene.analysis.pl.PolishAnalyzer
-
File containing default Polish stemmer table.
- DEFAULT_STOP_WORDS - Static variable in class org.apache.lucene.search.similar.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.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.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.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_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_TERM - Static variable in class org.apache.lucene.facet.index.params.CategoryListParams
-
The default term used to store the facets information.
- DEFAULT_TERM_INDEX_INTERVAL - Static variable in class org.apache.lucene.index.IndexWriter
-
Deprecated.use
IndexWriterConfig.DEFAULT_TERM_INDEX_INTERVAL
instead. - DEFAULT_TERM_INDEX_INTERVAL - Static variable in class org.apache.lucene.index.IndexWriterConfig
-
Default value is 128.
- DEFAULT_TOKEN_TYPE - Static variable in class org.apache.lucene.analysis.shingle.ShingleFilter
-
default token type attribute value is "shingle"
- DEFAULT_TOP_K - Static variable in class org.apache.lucene.index.pruning.CarmelTopKTermPruningPolicy
-
Default number of guaranteed top K scores
- DEFAULT_TYPE - Static variable in interface org.apache.lucene.analysis.tokenattributes.TypeAttribute
-
the default type
- 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
- DefaultEnhancementsIndexingParams - Class in org.apache.lucene.facet.enhancements.params
-
Default implementation of
EnhancementsIndexingParams
- DefaultEnhancementsIndexingParams(CategoryEnhancement...) - Constructor for class org.apache.lucene.facet.enhancements.params.DefaultEnhancementsIndexingParams
-
Construct with a certain
enhancement
- DefaultEnhancementsIndexingParams(CategoryListParams, CategoryEnhancement...) - Constructor for class org.apache.lucene.facet.enhancements.params.DefaultEnhancementsIndexingParams
-
Construct with certain
enhancements
andCategoryListParams
- DefaultFacetIndexingParams - Class in org.apache.lucene.facet.index.params
-
Default implementation for
FacetIndexingParams
. - DefaultFacetIndexingParams() - Constructor for class org.apache.lucene.facet.index.params.DefaultFacetIndexingParams
- DefaultFacetIndexingParams(CategoryListParams) - Constructor for class org.apache.lucene.facet.index.params.DefaultFacetIndexingParams
- DefaultICUTokenizerConfig - Class in org.apache.lucene.analysis.icu.segmentation
-
Default
ICUTokenizerConfig
that is generally applicable to many languages. - DefaultICUTokenizerConfig() - Constructor for class org.apache.lucene.analysis.icu.segmentation.DefaultICUTokenizerConfig
- DefaultLoadFactor - Static variable in class org.apache.lucene.facet.taxonomy.writercache.cl2o.CompactLabelToOrdinal
- defaultMaxDocFreqPercent - Static variable in class org.apache.lucene.analysis.query.QueryAutoStopWordAnalyzer
- defaultMaxExpansions - Static variable in class org.apache.lucene.search.FuzzyQuery
- defaultMinSimilarity - Static variable in class org.apache.lucene.search.FuzzyQuery
- DEFAULTnumTerms - Static variable in class org.apache.lucene.misc.HighFreqTerms
- DefaultOperatorAttribute - Interface in org.apache.lucene.queryParser.standard.config
-
Deprecated.
- DefaultOperatorAttribute.Operator - Enum in org.apache.lucene.queryParser.standard.config
-
Deprecated.
- DefaultOperatorAttributeImpl - Class in org.apache.lucene.queryParser.standard.config
-
Deprecated.
- DefaultOperatorAttributeImpl() - Constructor for class org.apache.lucene.queryParser.standard.config.DefaultOperatorAttributeImpl
-
Deprecated.
- DefaultOrdinalPolicy - Class in org.apache.lucene.facet.index.categorypolicy
-
This class filters our the ROOT category ID.
- DefaultOrdinalPolicy() - Constructor for class org.apache.lucene.facet.index.categorypolicy.DefaultOrdinalPolicy
- DefaultPathPolicy - Class in org.apache.lucene.facet.index.categorypolicy
-
This class filters our the ROOT category path.
- DefaultPathPolicy() - Constructor for class org.apache.lucene.facet.index.categorypolicy.DefaultPathPolicy
- DefaultPhraseSlopAttribute - Interface in org.apache.lucene.queryParser.standard.config
-
Deprecated.
- DefaultPhraseSlopAttributeImpl - Class in org.apache.lucene.queryParser.standard.config
-
Deprecated.
- DefaultPhraseSlopAttributeImpl() - Constructor for class org.apache.lucene.queryParser.standard.config.DefaultPhraseSlopAttributeImpl
-
Deprecated.
- DefaultPhraseSlopQueryNodeProcessor - Class in org.apache.lucene.queryParser.standard.processors
-
This processor verifies if
StandardQueryConfigHandler.ConfigurationKeys.PHRASE_SLOP
is defined in theQueryConfigHandler
. - DefaultPhraseSlopQueryNodeProcessor() - Constructor for class org.apache.lucene.queryParser.standard.processors.DefaultPhraseSlopQueryNodeProcessor
- defaultPrefixLength - Static variable in class org.apache.lucene.search.FuzzyQuery
- defaultSettingsCodec - Static variable in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter
-
Deprecated.
- DefaultSimilarity - Class in org.apache.lucene.search
-
Expert: Default scoring implementation.
- DefaultSimilarity() - Constructor for class org.apache.lucene.search.DefaultSimilarity
- defaultSpacerCharacter - Static variable in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter
-
Deprecated.
- defaultTaxonomyWriterCache() - Static method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
-
Defines the default
TaxonomyWriterCache
to use in constructors which do not specify one. - defaultTempDir() - Static method in class org.apache.lucene.search.suggest.fst.Sort
-
Returns the default temporary directory.
- defThreshold - Variable in class org.apache.lucene.index.pruning.TFTermPruningPolicy
- DEG_180_AS_RADS - Static variable in class org.apache.lucene.spatial.DistanceUtils
-
Deprecated.
- DEG_225_AS_RADS - Static variable in class org.apache.lucene.spatial.DistanceUtils
-
Deprecated.
- DEG_270_AS_RADS - Static variable in class org.apache.lucene.spatial.DistanceUtils
-
Deprecated.
- DEG_45_AS_RADS - Static variable in class org.apache.lucene.spatial.DistanceUtils
-
Deprecated.
- DEG_90_AS_RADS - Static variable in class org.apache.lucene.spatial.DistanceUtils
-
Deprecated.
- DEGREES_TO_RADIANS - Static variable in class org.apache.lucene.spatial.DistanceUtils
-
Deprecated.
- DEL_ALL - Static variable in class org.apache.lucene.index.pruning.PruningPolicy
-
Delete all data for this field.
- DEL_PAYLOADS - Static variable in class org.apache.lucene.index.pruning.PruningPolicy
-
Delete (some or all) payloads in these fields.
- DEL_POSTINGS - Static variable in class org.apache.lucene.index.pruning.PruningPolicy
-
Delete (some or all) postings for this field.
- DEL_STORED - Static variable in class org.apache.lucene.index.pruning.PruningPolicy
-
Delete (some or all) stored values for this field.
- DEL_VECTOR - Static variable in class org.apache.lucene.index.pruning.PruningPolicy
-
Delete term frequency vectors for this field (whole vectors or individual terms).
- delCount - Variable in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
- DELETABLE - Static variable in class org.apache.lucene.index.IndexFileNames
-
Name of the index deletable file (only used in pre-lockless indices)
- delete() - Method in class org.apache.lucene.index.IndexCommit
-
Delete this commit point.
- delete() - Method in class org.apache.lucene.index.SnapshotDeletionPolicy.SnapshotCommitPoint
- delete(char[], int, int) - Static method in class org.apache.lucene.analysis.util.StemmerUtil
-
Delete a character in-place
- deleteAll - Variable in class org.apache.lucene.index.pruning.StorePruningPolicy
-
Fields to be completely deleted
- deleteAll() - Method in class org.apache.lucene.index.IndexWriter
-
Delete all documents in the index.
- deleteAll() - Method in class org.apache.lucene.index.RandomIndexWriter
- deleteAll() - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
- DeleteByPercentTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Deletes a percentage of documents from an index randomly over the number of documents.
- DeleteByPercentTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.DeleteByPercentTask
- deletedDocs - Variable in class org.apache.lucene.index.SegmentWriteState
- DeleteDocTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Delete a document by docid.
- DeleteDocTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.DeleteDocTask
- deleteDocument(int) - Method in class org.apache.lucene.index.IndexReader
-
Deprecated.Write support will be removed in Lucene 4.0. Use
IndexWriter.deleteDocuments(Term)
instead - deleteDocuments(Term) - Method in class org.apache.lucene.index.IndexReader
-
Deprecated.Write support will be removed in Lucene 4.0. Use
IndexWriter.deleteDocuments(Term)
instead - deleteDocuments(Term) - Method in class org.apache.lucene.index.IndexWriter
-
Deletes the document(s) containing
term
. - deleteDocuments(Term) - Method in class org.apache.lucene.index.RandomIndexWriter
- deleteDocuments(Term) - Method in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
- deleteDocuments(Term) - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
- deleteDocuments(Term) - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexWriter
-
Deprecated.
- deleteDocuments(Term...) - Method in class org.apache.lucene.index.IndexWriter
-
Deletes the document(s) containing any of the terms.
- deleteDocuments(Term...) - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
- deleteDocuments(Term[]) - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexWriter
-
Deprecated.
- deleteDocuments(Query) - Method in class org.apache.lucene.index.IndexWriter
-
Deletes the document(s) matching the provided query.
- deleteDocuments(Query) - Method in class org.apache.lucene.index.RandomIndexWriter
- deleteDocuments(Query) - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
- deleteDocuments(Query...) - Method in class org.apache.lucene.index.IndexWriter
-
Deletes the document(s) matching any of the provided queries.
- deleteDocuments(Query...) - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
- DeletedQueryNode - Class in org.apache.lucene.queryParser.core.nodes
-
A
DeletedQueryNode
represents a node that was deleted from the query node tree. - DeletedQueryNode() - Constructor for class org.apache.lucene.queryParser.core.nodes.DeletedQueryNode
- deleteFile(String) - Method in class org.apache.lucene.store.Directory
-
Removes an existing file in the directory.
- deleteFile(String) - Method in class org.apache.lucene.store.FileSwitchDirectory
- deleteFile(String) - Method in class org.apache.lucene.store.FSDirectory
-
Removes an existing file in the directory.
- deleteFile(String) - Method in class org.apache.lucene.store.MockDirectoryWrapper
- deleteFile(String) - Method in class org.apache.lucene.store.NRTCachingDirectory
- deleteFile(String) - Method in class org.apache.lucene.store.RAMDirectory
-
Removes an existing file in the directory.
- deleteLast(int, Builder.Node) - Method in class org.apache.lucene.util.fst.Builder.UnCompiledNode
- deleteN(char[], int, int, int) - Static method in class org.apache.lucene.analysis.util.StemmerUtil
-
Delete n characters in-place
- DELETES_EXTENSION - Static variable in class org.apache.lucene.index.IndexFileNames
-
Extension of deletes
- deleteUnusedFiles() - Method in class org.apache.lucene.index.IndexWriter
-
Expert: remove any index files that are no longer used.
- deletionsFileName - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
-
Name of the current deletions file name.
- delFields - Variable in class org.apache.lucene.index.pruning.StorePruningPolicy
- 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
- 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
- delTermCount - Variable in class org.apache.lucene.index.PruningReader
- delVecCount - Variable in class org.apache.lucene.index.PruningReader
- DemoHTMLParser - Class in org.apache.lucene.benchmark.byTask.feeds
-
HTML Parser that is based on Lucene's demo HTML parser.
- DemoHTMLParser() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.DemoHTMLParser
- depth - Variable in class org.apache.lucene.util.fst.Builder.UnCompiledNode
-
This node's depth, starting from the automaton root.
- DESCENDING - org.apache.lucene.facet.search.params.FacetRequest.SortOrder
- describeParams() - Method in class org.apache.lucene.search.similar.MoreLikeThis
-
Describe the parameters that control how the "more like this" query is formed.
- description - Variable in enum org.apache.lucene.util.RamUsageEstimator.JvmFeature
- description() - Method in class org.apache.lucene.search.function.ByteFieldSource
- description() - Method in class org.apache.lucene.search.function.FieldCacheSource
- description() - Method in class org.apache.lucene.search.function.FloatFieldSource
- description() - Method in class org.apache.lucene.search.function.IntFieldSource
- description() - Method in class org.apache.lucene.search.function.OrdFieldSource
- description() - Method in class org.apache.lucene.search.function.ReverseOrdFieldSource
- description() - Method in class org.apache.lucene.search.function.ShortFieldSource
- description() - Method in class org.apache.lucene.search.function.ValueSource
-
description of field, used in explain()
- Descriptor(File, String) - Constructor for class org.apache.lucene.store.SimpleFSDirectory.SimpleFSIndexInput.Descriptor
- deserializeCategoryAttribute(ObjectInputStream) - Method in class org.apache.lucene.facet.index.CategoryContainer
-
De-Serialize each of the
CategoryAttribute
s from the givenObjectInputStream
. - deserializeFromStreamReader(InputStreamReader) - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
-
Serializes the content of this CategoryPath to a byte stream, using UTF-8 encoding to convert characters to bytes, and treating the ends as 16-bit characters.
- DGapIntDecoder - Class in org.apache.lucene.util.encoding
-
An
IntDecoder
which wraps anotherIntDecoder
and reverts the d-gap that was encoded byDGapIntEncoder
. - DGapIntDecoder(IntDecoder) - Constructor for class org.apache.lucene.util.encoding.DGapIntDecoder
- DGapIntEncoder - Class in org.apache.lucene.util.encoding
-
An
IntEncoderFilter
which encodes the gap between the given values, rather than the values themselves. - DGapIntEncoder(IntEncoder) - Constructor for class org.apache.lucene.util.encoding.DGapIntEncoder
-
Initializes with the given encoder.
- 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_HEADER - Static variable in class org.apache.lucene.analysis.ja.dict.BinaryDictionary
- dictionary - Variable in class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
- Dictionary - Interface in org.apache.lucene.analysis.ja.dict
-
Dictionary interface for retrieving morphological data by id.
- Dictionary - Interface in org.apache.lucene.search.spell
-
A simple interface representing a Dictionary.
- DictionaryCompoundWordTokenFilter - Class in org.apache.lucene.analysis.compound
-
A
TokenFilter
that decomposes compound words found in many Germanic languages. - DictionaryCompoundWordTokenFilter(TokenStream, String[]) - Constructor for class org.apache.lucene.analysis.compound.DictionaryCompoundWordTokenFilter
-
Deprecated.
- DictionaryCompoundWordTokenFilter(TokenStream, String[], int, int, int, boolean) - Constructor for class org.apache.lucene.analysis.compound.DictionaryCompoundWordTokenFilter
-
Deprecated.
- DictionaryCompoundWordTokenFilter(TokenStream, Set) - Constructor for class org.apache.lucene.analysis.compound.DictionaryCompoundWordTokenFilter
-
Deprecated.
- DictionaryCompoundWordTokenFilter(TokenStream, Set, int, int, int, boolean) - Constructor for class org.apache.lucene.analysis.compound.DictionaryCompoundWordTokenFilter
-
Deprecated.
- DictionaryCompoundWordTokenFilter(Version, TokenStream, String[]) - Constructor for class org.apache.lucene.analysis.compound.DictionaryCompoundWordTokenFilter
-
Deprecated.Use the constructors taking
Set
- DictionaryCompoundWordTokenFilter(Version, TokenStream, String[], int, int, int, boolean) - Constructor for class org.apache.lucene.analysis.compound.DictionaryCompoundWordTokenFilter
-
Deprecated.Use the constructors taking
Set
- DictionaryCompoundWordTokenFilter(Version, TokenStream, Set<?>) - Constructor for class org.apache.lucene.analysis.compound.DictionaryCompoundWordTokenFilter
-
Creates a new
DictionaryCompoundWordTokenFilter
- DictionaryCompoundWordTokenFilter(Version, TokenStream, Set<?>, int, int, int, boolean) - Constructor for class org.apache.lucene.analysis.compound.DictionaryCompoundWordTokenFilter
-
Creates a new
DictionaryCompoundWordTokenFilter
- 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
- difference() - Method in class org.apache.lucene.search.FilteredTermEnum
-
Equality measure on the term
- difference() - Method in class org.apache.lucene.search.FuzzyTermEnum
-
Equality measure on the term
- difference() - Method in class org.apache.lucene.search.PrefixTermEnum
- difference() - Method in class org.apache.lucene.search.regex.RegexTermEnum
- difference() - Method in class org.apache.lucene.search.SingleTermEnum
- difference() - Method in class org.apache.lucene.search.TermRangeTermEnum
- difference() - Method in class org.apache.lucene.search.WildcardTermEnum
- DiffIt - Class in org.egothor.stemmer
-
The DiffIt class is a means generate patch commands from an already prepared stemmer table.
- DiffIt() - Constructor for class org.egothor.stemmer.DiffIt
- DIGIT - Static variable in class org.apache.lucene.analysis.cn.smart.CharType
-
Numeric Digits
- dir - Variable in class org.apache.lucene.index.CheckIndex.Status
-
Directory index is in.
- dir - Variable in class org.apache.lucene.index.ConcurrentMergeScheduler
- dir - Variable in class org.apache.lucene.index.SegmentInfo
- dir - Variable in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
- DirContentSource - Class in org.apache.lucene.benchmark.byTask.feeds
-
A
ContentSource
using the Dir collection for its input. - 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
- DirectBytesStartArray(int) - Constructor for class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
- DirectIOLinuxDirectory - Class in org.apache.lucene.store
-
An
Directory
implementation that uses the Linux-specific O_DIRECT flag to bypass all OS level caching. - DirectIOLinuxDirectory(File, LockFactory, int) - Constructor for class org.apache.lucene.store.DirectIOLinuxDirectory
-
Create a new NIOFSDirectory for the named location.
- directory - Variable in class org.apache.lucene.index.SegmentWriteState
- directory - Static variable in class org.apache.lucene.search.SearchEquivalenceTestBase
- directory - Variable in class org.apache.lucene.store.FSDirectory
- directory() - Method in class org.apache.lucene.index.FilterIndexReader
- directory() - Method in class org.apache.lucene.index.IndexReader
-
Returns the directory associated with this index.
- directory() - Method in class org.apache.lucene.index.SegmentReader
-
Returns the directory this index resides in.
- directory() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexReader
-
Deprecated.
- directory(int, File) - Method in class org.apache.lucene.benchmark.utils.ExtractWikipedia
- Directory - Class in org.apache.lucene.store
-
A Directory is a flat list of files.
- Directory() - Constructor for class org.apache.lucene.store.Directory
- DirectoryTaxonomyReader - Class in org.apache.lucene.facet.taxonomy.directory
-
A
TaxonomyReader
which retrieves stored taxonomy information from aDirectory
. - DirectoryTaxonomyReader(Directory) - Constructor for class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyReader
-
Open for reading a taxonomy stored in a given
Directory
. - DirectoryTaxonomyWriter - Class in org.apache.lucene.facet.taxonomy.directory
-
TaxonomyWriter
which uses aDirectory
to store the taxonomy information on disk, and keeps an additional in-memory cache of some or all categories. - DirectoryTaxonomyWriter(Directory) - Constructor for class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
- DirectoryTaxonomyWriter(Directory, IndexWriterConfig.OpenMode) - Constructor for class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
-
Creates a new instance with a default cached as defined by
DirectoryTaxonomyWriter.defaultTaxonomyWriterCache()
. - DirectoryTaxonomyWriter(Directory, IndexWriterConfig.OpenMode, TaxonomyWriterCache) - Constructor for class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
-
Construct a Taxonomy writer.
- DirectoryTaxonomyWriter.DiskOrdinalMap - Class in org.apache.lucene.facet.taxonomy.directory
-
DirectoryTaxonomyWriter.OrdinalMap
maintained on file system - DirectoryTaxonomyWriter.MemoryOrdinalMap - Class in org.apache.lucene.facet.taxonomy.directory
-
DirectoryTaxonomyWriter.OrdinalMap
maintained in memory - DirectoryTaxonomyWriter.OrdinalMap - Interface in org.apache.lucene.facet.taxonomy.directory
-
Mapping from old ordinal to new ordinals, used when merging indexes wit separate taxonomies.
- DirectTrackingAllocator(int, AtomicLong) - Constructor for class org.apache.lucene.util.ByteBlockPool.DirectTrackingAllocator
- DirectTrackingAllocator(AtomicLong) - Constructor for class org.apache.lucene.util.ByteBlockPool.DirectTrackingAllocator
- DirPayloadProcessor() - Constructor for class org.apache.lucene.index.PayloadProcessorProvider.DirPayloadProcessor
-
Deprecated.
- DISABLE_AUTO_FLUSH - Static variable in class org.apache.lucene.index.IndexWriter
-
Deprecated.use
IndexWriterConfig.DISABLE_AUTO_FLUSH
instead - DISABLE_AUTO_FLUSH - Static variable in class org.apache.lucene.index.IndexWriterConfig
-
Denotes a flush trigger is disabled.
- DISABLE_COMPLEMENT - Static variable in class org.apache.lucene.facet.search.FacetsAccumulator
-
Passing this to
FacetsAccumulator.setComplementThreshold(double)
will disable using complement optimization. - disable_tracing() - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParser
-
Disable tracing.
- disable_tracing() - Method in class org.apache.lucene.queryParser.QueryParser
-
Disable tracing.
- disable_tracing() - Method in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParser
-
Disable tracing.
- disable_tracing() - Method in class org.apache.lucene.queryParser.surround.parser.QueryParser
-
Disable tracing.
- DISALLOW_EXTERNAL_ENTITY_RESOLVER - Static variable in class org.apache.lucene.xmlparser.CoreParser
- discardEscapeChar(CharSequence) - Static method in class org.apache.lucene.queryParser.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.DefaultSimilarity
- DisjQuery(CharSequence) - Method in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParser
- DisjunctionMaxQuery - Class in org.apache.lucene.search
-
A query that generates the union of documents produced by its subqueries, and that scores each document with the maximum score for that document as produced by any subquery, plus a tie breaking increment for any additional matching subqueries.
- DisjunctionMaxQuery(float) - Constructor for class org.apache.lucene.search.DisjunctionMaxQuery
-
Creates a new empty DisjunctionMaxQuery.
- DisjunctionMaxQuery(Collection<Query>, float) - Constructor for class org.apache.lucene.search.DisjunctionMaxQuery
-
Creates a new DisjunctionMaxQuery
- DisjunctionMaxQuery.DisjunctionMaxWeight - Class in org.apache.lucene.search
-
Expert: the Weight for DisjunctionMaxQuery, used to normalize, score and explain these queries.
- DisjunctionMaxWeight(Searcher) - Constructor for class org.apache.lucene.search.DisjunctionMaxQuery.DisjunctionMaxWeight
-
Construct the Weight for this Query searched by searcher.
- DiskOrdinalMap(File) - Constructor for class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter.DiskOrdinalMap
- distance - Variable in class org.apache.lucene.spatial.tier.DistanceFilter
-
Deprecated.
- distance(Point2D, Point2D) - Method in class org.apache.lucene.spatial.geometry.shape.LineSegment
-
Deprecated.Finds the distance of a specified point from the line segment and the closest point on the segment to the specified point.
- DistanceApproximation - Class in org.apache.lucene.spatial.geometry.shape
-
Deprecated.This has been replaced with more accurate math in
LLRect
. This class will be removed in a future release. - DistanceApproximation() - Constructor for class org.apache.lucene.spatial.geometry.shape.DistanceApproximation
-
Deprecated.
- DistanceFieldComparatorSource - Class in org.apache.lucene.spatial.tier
-
Deprecated.
- DistanceFieldComparatorSource(Filter) - Constructor for class org.apache.lucene.spatial.tier.DistanceFieldComparatorSource
-
Deprecated.
- DistanceFilter - Class in org.apache.lucene.spatial.tier
-
Deprecated.
- DistanceFilter(Filter, double) - Constructor for class org.apache.lucene.spatial.tier.DistanceFilter
-
Deprecated.Filters the startingFilter by precise distance checking filter
- DistanceHandler - Class in org.apache.lucene.spatial.tier
-
Deprecated.
- DistanceHandler(Map<Integer, Double>, Map<String, Double>, DistanceHandler.Precision) - Constructor for class org.apache.lucene.spatial.tier.DistanceHandler
-
Deprecated.
- DistanceHandler.Precision - Enum in org.apache.lucene.spatial.tier
-
Deprecated.
- distanceLookupCache - Variable in class org.apache.lucene.spatial.tier.DistanceFilter
-
Deprecated.
- DistanceQuery - Class in org.apache.lucene.queryParser.surround.query
- DistanceQuery(List<SrndQuery>, boolean, int, String, boolean) - Constructor for class org.apache.lucene.queryParser.surround.query.DistanceQuery
- DistanceQueryBuilder - Class in org.apache.lucene.spatial.tier
-
Deprecated.
- DistanceQueryBuilder(double, double, double, String, String, boolean, int, int) - Constructor for class org.apache.lucene.spatial.tier.DistanceQueryBuilder
-
Deprecated.Create a distance query using a boundary box wrapper around a more precise DistanceFilter.
- DistanceQueryBuilder(double, double, double, String, String, String, boolean, int, int) - Constructor for class org.apache.lucene.spatial.tier.DistanceQueryBuilder
-
Deprecated.Create a distance query using a boundary box wrapper around a more precise DistanceFilter.
- distances - Variable in class org.apache.lucene.spatial.tier.DistanceFilter
-
Deprecated.
- DistanceSubQuery - Interface in org.apache.lucene.queryParser.surround.query
- 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
- DistanceUnits - Enum in org.apache.lucene.spatial.geometry
-
Deprecated.
- DistanceUtils - Class in org.apache.lucene.spatial
-
Deprecated.
- DistanceUtils() - Constructor for class org.apache.lucene.spatial.DistanceUtils
-
Deprecated.
- 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() - Method in class org.apache.lucene.store.Lock.With
-
Code to execute with exclusive access.
- doBody(String) - Method in class org.apache.lucene.index.SegmentInfos.FindSegmentsFile
-
Subclass must implement this.
- 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.index.AbstractAllTermDocs
- doc - Variable in class org.apache.lucene.search.grouping.AbstractAllGroupHeadsCollector.GroupHead
- doc - Variable in class org.apache.lucene.search.ScoreDoc
-
Expert: A hit document's number.
- doc - Variable in class org.apache.lucene.search.spans.SpanScorer
- doc - Variable in class org.apache.lucene.search.spans.TermSpans
- doc() - Method in class org.apache.lucene.index.AbstractAllTermDocs
- doc() - Method in class org.apache.lucene.index.FilterIndexReader.FilterTermDocs
- doc() - Method in class org.apache.lucene.index.MultipleTermPositions
- doc() - Method in interface org.apache.lucene.index.TermDocs
-
Returns the current document number.
- doc() - Method in class org.apache.lucene.search.spans.NearSpansOrdered
- doc() - Method in class org.apache.lucene.search.spans.NearSpansUnordered
- doc() - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery.PositionCheckSpan
- doc() - Method in class org.apache.lucene.search.spans.Spans
-
Returns the document number of the current match.
- doc() - Method in class org.apache.lucene.search.spans.TermSpans
- doc() - Method in class org.apache.lucene.store.instantiated.InstantiatedTermDocs
- doc(int) - Method in class org.apache.lucene.search.IndexSearcher
- doc(int) - Method in class org.apache.lucene.search.MultiSearcher
-
Deprecated.
- doc(int) - Method in class org.apache.lucene.search.RemoteSearchable
-
Deprecated.
- doc(int) - Method in interface org.apache.lucene.search.Searchable
-
Deprecated.Returns the stored fields of document
i
. - doc(int) - Method in class org.apache.lucene.search.Searcher
-
Deprecated.
- doc(int, FieldSelector) - Method in class org.apache.lucene.search.IndexSearcher
- doc(int, FieldSelector) - Method in class org.apache.lucene.search.MultiSearcher
-
Deprecated.
- doc(int, FieldSelector) - Method in class org.apache.lucene.search.RemoteSearchable
-
Deprecated.
- doc(int, FieldSelector) - Method in interface org.apache.lucene.search.Searchable
-
Deprecated.Get the
Document
at then
th position. - doc(int, FieldSelector) - Method in class org.apache.lucene.search.Searcher
-
Deprecated.
- DOC - Static variable in class org.apache.lucene.benchmark.byTask.feeds.TrecContentSource
- DOC - Static variable in class org.apache.lucene.search.SortField
-
Sort by document number (index order).
- doCacheWrite(String) - Method in class org.apache.lucene.store.NRTCachingDirectory
-
Subclass can override this to customize logic; return true if this file should be written to the RAMDirectory.
- docBase - Variable in class org.apache.lucene.facet.search.ScoredDocIdCollector
- docCount - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
-
Document count (does not take deletions into account).
- docCount - Variable in class org.apache.lucene.index.CheckIndex.Status.StoredFieldStatus
-
Number of documents tested.
- docCount - Variable in class org.apache.lucene.index.CheckIndex.Status.TermVectorStatus
-
Number of documents tested.
- docCount - Variable in class org.apache.lucene.index.PruningReader
- docCount - Variable in class org.apache.lucene.index.SegmentInfo
- docCount() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexWriter
-
Deprecated.Returns the number of documents currently in this index.
- 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
- docFreq() - Method in class org.apache.lucene.index.FilterIndexReader.FilterTermEnum
- docFreq() - Method in class org.apache.lucene.index.TermEnum
-
Returns the docFreq of the current Term in the enumeration.
- docFreq() - Method in class org.apache.lucene.search.FilteredTermEnum
-
Returns the docFreq of the current Term in the enumeration.
- docFreq() - Method in class org.apache.lucene.store.instantiated.InstantiatedTermEnum
-
Returns the docFreq of the current Term in the enumeration.
- docFreq(Term) - Method in class org.apache.lucene.index.FilterIndexReader
- docFreq(Term) - Method in class org.apache.lucene.index.IndexReader
-
Returns the number of documents containing the term
t
. - docFreq(Term) - Method in class org.apache.lucene.index.MultiReader
- docFreq(Term) - Method in class org.apache.lucene.index.ParallelReader
- docFreq(Term) - Method in class org.apache.lucene.index.SegmentReader
- docFreq(Term) - Method in class org.apache.lucene.search.IndexSearcher
-
Returns total docFreq for this term.
- docFreq(Term) - Method in class org.apache.lucene.search.MultiSearcher
-
Deprecated.
- docFreq(Term) - Method in class org.apache.lucene.search.ParallelMultiSearcher
-
Deprecated.Executes each
Searchable
's docFreq() in its own thread and waits for each search to complete and merge the results back together. - docFreq(Term) - Method in class org.apache.lucene.search.RemoteSearchable
-
Deprecated.
- docFreq(Term) - Method in interface org.apache.lucene.search.Searchable
-
Deprecated.Expert: Returns the number of documents containing
term
. - docFreq(Term) - Method in class org.apache.lucene.search.Searcher
-
Deprecated.
- docFreq(Term) - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexReader
-
Deprecated.
- docFreqs(Term[]) - Method in class org.apache.lucene.search.RemoteSearchable
-
Deprecated.
- docFreqs(Term[]) - Method in interface org.apache.lucene.search.Searchable
-
Deprecated.Expert: For each term in the terms array, calculates the number of documents containing
term
. - docFreqs(Term[]) - Method in class org.apache.lucene.search.Searcher
-
Deprecated.
- docID() - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantScorer
- docID() - Method in class org.apache.lucene.search.DocIdSetIterator
-
Returns the following: -1 or
DocIdSetIterator.NO_MORE_DOCS
ifDocIdSetIterator.nextDoc()
orDocIdSetIterator.advance(int)
were not called yet. - docID() - Method in class org.apache.lucene.search.FilteredDocIdSetIterator
- docID() - Method in class org.apache.lucene.search.ScoreCachingWrappingScorer
- docID() - Method in class org.apache.lucene.search.spans.SpanScorer
- docID() - Method in class org.apache.lucene.util.OpenBitSetIterator
- DocIdBitSet - Class in org.apache.lucene.util
-
Simple DocIdSet and DocIdSetIterator backed by a BitSet
- DocIdBitSet(BitSet) - Constructor for class org.apache.lucene.util.DocIdBitSet
- docids - Variable in class org.apache.lucene.facet.search.sampling.Sampler.SampleResult
- docIds - Variable in class org.apache.lucene.facet.search.ScoredDocIdCollector
- DocIdSet - Class in org.apache.lucene.search
-
A DocIdSet contains a set of doc ids.
- DocIdSet() - Constructor for class org.apache.lucene.search.DocIdSet
- DocIdSetIterator - Class in org.apache.lucene.search
-
This abstract class defines methods to iterate over a set of non-decreasing doc ids.
- DocIdSetIterator() - Constructor for class org.apache.lucene.search.DocIdSetIterator
- docIdSetToCache(DocIdSet, IndexReader) - Method in class org.apache.lucene.search.CachingWrapperFilter
-
Provide the DocIdSet to be cached, using the DocIdSet provided by the wrapped Filter.
- doClose() - Method in class org.apache.lucene.index.FilterIndexReader
- doClose() - Method in class org.apache.lucene.index.IndexReader
-
Implements close.
- doClose() - Method in class org.apache.lucene.index.MultiReader
- doClose() - Method in class org.apache.lucene.index.ParallelReader
- doClose() - Method in class org.apache.lucene.index.SegmentReader
- doClose() - Method in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
- doClose() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexReader
-
Deprecated.
- docMaker - Variable in class org.apache.lucene.benchmark.utils.ExtractWikipedia
- DocMaker - Class in org.apache.lucene.benchmark.byTask.feeds
-
Creates
Document
objects. - DocMaker() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.DocMaker
- 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
- doCommit(Map<String, String>) - Method in class org.apache.lucene.index.FilterIndexReader
-
Deprecated.
- doCommit(Map<String, String>) - Method in class org.apache.lucene.index.IndexReader
-
Deprecated.Write support will be removed in Lucene 4.0.
- doCommit(Map<String, String>) - Method in class org.apache.lucene.index.MultiReader
-
Deprecated.
- doCommit(Map<String, String>) - Method in class org.apache.lucene.index.ParallelReader
-
Deprecated.
- doCommit(Map<String, String>) - Method in class org.apache.lucene.index.SegmentReader
-
Deprecated.
- doCommit(Map<String, String>) - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexReader
-
Deprecated.
- DOCS_AND_FREQS - org.apache.lucene.index.FieldInfo.IndexOptions
-
only documents and term frequencies are indexed: positions are omitted
- DOCS_AND_FREQS_AND_POSITIONS - org.apache.lucene.index.FieldInfo.IndexOptions
-
full postings: documents, frequencies, and positions
- DOCS_ONLY - org.apache.lucene.index.FieldInfo.IndexOptions
-
only documents are indexed: term frequencies and positions are omitted
- docScore(int, String, int, float) - Method in class org.apache.lucene.search.payloads.AveragePayloadFunction
- docScore(int, String, int, float) - Method in class org.apache.lucene.search.payloads.MaxPayloadFunction
- docScore(int, String, int, float) - Method in class org.apache.lucene.search.payloads.MinPayloadFunction
- docScore(int, String, int, float) - Method in class org.apache.lucene.search.payloads.PayloadFunction
-
Calculate the final score for all the payloads seen so far for this doc/field
- docStarts - Variable in class org.apache.lucene.search.IndexSearcher
- docStoreCompoundFile - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
-
True if the shared doc store files are compound file format.
- docStoreOffset - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
-
Doc store offset, if this segment shares the doc store files (stored fields and term vectors) with other segments.
- docStoreSegment - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
-
String of the shared doc store segment, or null if this segment does not share the doc store files.
- docsWithField - Variable in class org.apache.lucene.search.FieldComparator.NumericComparator
- document(int) - Method in class org.apache.lucene.index.IndexReader
-
Returns the stored fields of the
n
thDocument
in this index. - document(int, FieldSelector) - Method in class org.apache.lucene.index.FilterIndexReader
- document(int, FieldSelector) - Method in class org.apache.lucene.index.IndexReader
-
Get the
Document
at then
th position. - document(int, FieldSelector) - Method in class org.apache.lucene.index.MultiReader
- document(int, FieldSelector) - Method in class org.apache.lucene.index.ParallelReader
- document(int, FieldSelector) - Method in class org.apache.lucene.index.PruningReader
-
Applies a
StorePruningPolicy
to stored fields of a document. - document(int, FieldSelector) - Method in class org.apache.lucene.index.SegmentReader
- document(int, FieldSelector) - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexReader
-
Deprecated.Return the
Document
at then
th position. - 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.
- documentNumberComparator - Static variable in class org.apache.lucene.store.instantiated.InstantiatedTermDocumentInformation
- DocValues - Class in org.apache.lucene.search.function
-
Expert: represents field values as different types.
- DocValues() - Constructor for class org.apache.lucene.search.function.DocValues
- doDelete(int) - Method in class org.apache.lucene.index.FilterIndexReader
-
Deprecated.
- doDelete(int) - Method in class org.apache.lucene.index.IndexReader
-
Deprecated.Write support will be removed in Lucene 4.0. Use
IndexWriter.deleteDocuments(Term)
instead - doDelete(int) - Method in class org.apache.lucene.index.MultiReader
-
Deprecated.
- doDelete(int) - Method in class org.apache.lucene.index.ParallelReader
-
Deprecated.
- doDelete(int) - Method in class org.apache.lucene.index.SegmentReader
-
Deprecated.
- doDelete(int) - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexReader
-
Deprecated.
- doFail - Variable in class org.apache.lucene.store.MockDirectoryWrapper.Failure
- doHighlight(IndexReader, int, String, Document, Analyzer, String) - Method in class org.apache.lucene.benchmark.byTask.tasks.BenchmarkHighlighter
- 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.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.DeleteByPercentTask
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.DeleteDocTask
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.FlushReaderTask
- 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.NewShingleAnalyzerTask
- 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.WaitForMergesTask
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.WaitTask
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.WriteLineDocTask
- doMerge(MergePolicy.OneMerge) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
-
Does the actual merge, by calling
IndexWriter.merge(org.apache.lucene.index.MergePolicy.OneMerge)
- DOMUtils - Class in org.apache.lucene.xmlparser
- DOMUtils() - Constructor for class org.apache.lucene.xmlparser.DOMUtils
- Done() - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
-
Reset buffer when finished.
- Done() - Method in interface org.apache.lucene.queryParser.CharStream
-
The lexer calls this function to indicate that it is done with the stream and hence implementations can free any resources held by this class.
- Done() - Method in class org.apache.lucene.queryParser.FastCharStream
- Done() - Method in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
-
Set buffers back to null when finished.
- 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
- doNext() - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery.PositionCheckSpan
- DONTNEED - Static variable in class org.apache.lucene.store.NativePosixUtil
- doOpenIfChanged() - Method in class org.apache.lucene.index.IndexReader
-
If the index has changed since it was opened, open and return a new reader; else, return
null
. - doOpenIfChanged() - Method in class org.apache.lucene.index.MultiReader
- doOpenIfChanged() - Method in class org.apache.lucene.index.ParallelReader
- doOpenIfChanged() - Method in class org.apache.lucene.index.SegmentReader
- doOpenIfChanged(boolean) - Method in class org.apache.lucene.index.IndexReader
-
Deprecated.Write support will be removed in Lucene 4.0. Use
IndexReader.doOpenIfChanged()
instead - doOpenIfChanged(boolean) - Method in class org.apache.lucene.index.MultiReader
-
Deprecated.Write support will be removed in Lucene 4.0. Use
MultiReader.doOpenIfChanged()
instead. - doOpenIfChanged(boolean) - Method in class org.apache.lucene.index.ParallelReader
-
Deprecated.Write support will be removed in Lucene 4.0. Use
ParallelReader.doOpenIfChanged()
instead. - doOpenIfChanged(boolean) - Method in class org.apache.lucene.index.SegmentReader
-
Deprecated.
- doOpenIfChanged(IndexCommit) - Method in class org.apache.lucene.index.IndexReader
-
If the index has changed since it was opened, open and return a new reader; else, return
null
. - doOpenIfChanged(IndexWriter, boolean) - Method in class org.apache.lucene.index.IndexReader
-
If the index has changed since it was opened, open and return a new reader; else, return
null
. - 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
- doSetNorm(int, String, byte) - Method in class org.apache.lucene.index.FilterIndexReader
-
Deprecated.
- doSetNorm(int, String, byte) - Method in class org.apache.lucene.index.IndexReader
-
Deprecated.Write support will be removed in Lucene 4.0. There will be no replacement for this method.
- doSetNorm(int, String, byte) - Method in class org.apache.lucene.index.MultiReader
-
Deprecated.
- doSetNorm(int, String, byte) - Method in class org.apache.lucene.index.ParallelReader
-
Deprecated.
- doSetNorm(int, String, byte) - Method in class org.apache.lucene.index.SegmentReader
-
Deprecated.
- doSetNorm(int, String, byte) - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexReader
-
Deprecated.
- dot(Vector2D) - Method in class org.apache.lucene.spatial.geometry.shape.Vector2D
-
Deprecated.
- DOTLESS_YEH - Static variable in class org.apache.lucene.analysis.ar.ArabicNormalizer
- DOUBLE - org.apache.lucene.document.NumericField.DataType
- DOUBLE - Static variable in class org.apache.lucene.search.SortField
-
Sort using term values as encoded Doubles.
- DOUBLE_TYPE - Static variable in class org.apache.lucene.analysis.cjk.CJKBigramFilter
-
when we emit a bigram, its then marked as this type
- DoubleBarrelLRUCache<K extends DoubleBarrelLRUCache.CloneableKey,V> - Class in org.apache.lucene.util
-
Simple concurrent LRU cache, using a "double barrel" approach where two ConcurrentHashMaps record entries.
- DoubleBarrelLRUCache(int) - Constructor for class org.apache.lucene.util.DoubleBarrelLRUCache
- DoubleBarrelLRUCache.CloneableKey - Class in org.apache.lucene.util
-
Object providing clone(); the key class must subclass this.
- DoubleIterator - Interface in org.apache.lucene.util.collections
-
Iterator interface for primitive double iteration.
- 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
- doubleToFixed(double) - Static method in class org.apache.lucene.spatial.geometry.FixedLatLng
-
Deprecated.
- doubleToPrefixCoded(double) - Static method in class org.apache.lucene.util.NumericUtils
- doubleToSortableLong(double) - Static method in class org.apache.lucene.util.NumericUtils
-
Converts a
double
value to a sortable signedlong
. - doubleVal(int) - Method in class org.apache.lucene.search.function.DocValues
-
Return doc value as a double.
- doumentNumberIntegerComparator - Static variable in class org.apache.lucene.store.instantiated.InstantiatedTermDocumentInformation
- doUndeleteAll() - Method in class org.apache.lucene.index.FilterIndexReader
-
Deprecated.
- doUndeleteAll() - Method in class org.apache.lucene.index.IndexReader
-
Deprecated.Write support will be removed in Lucene 4.0. There will be no replacement for this method.
- doUndeleteAll() - Method in class org.apache.lucene.index.MultiReader
-
Deprecated.
- doUndeleteAll() - Method in class org.apache.lucene.index.ParallelReader
-
Deprecated.
- doUndeleteAll() - Method in class org.apache.lucene.index.SegmentReader
-
Deprecated.
- doUndeleteAll() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexReader
-
Deprecated.
- DrillDown - Class in org.apache.lucene.facet.search
-
Creation of drill down term or query.
- DrillDown() - Constructor for class org.apache.lucene.facet.search.DrillDown
- drillDownTermText(CategoryPath, char[]) - Method in class org.apache.lucene.facet.index.params.DefaultFacetIndexingParams
- drillDownTermText(CategoryPath, char[]) - Method in interface org.apache.lucene.facet.index.params.FacetIndexingParams
-
Return the drilldown Term-Text which does not need to do any allocations.
- dropBuffersAndReset() - Method in class org.apache.lucene.util.ByteBlockPool
- DummyConcurrentLock - Class in org.apache.lucene.util
-
A dummy lock as a replacement for
ReentrantLock
to disable locking - DummyConcurrentLock() - Constructor for class org.apache.lucene.util.DummyConcurrentLock
- DummyQueryNodeBuilder - Class in org.apache.lucene.queryParser.standard.builders
-
This builder does nothing.
- DummyQueryNodeBuilder() - Constructor for class org.apache.lucene.queryParser.standard.builders.DummyQueryNodeBuilder
-
Constructs a
DummyQueryNodeBuilder
object. - 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.
- DuplicateFilter - Class in org.apache.lucene.search
- DuplicateFilter(String) - Constructor for class org.apache.lucene.search.DuplicateFilter
- DuplicateFilter(String, int, int) - Constructor for class org.apache.lucene.search.DuplicateFilter
- DuplicateFilterBuilder - Class in org.apache.lucene.xmlparser.builders
- DuplicateFilterBuilder() - Constructor for class org.apache.lucene.xmlparser.builders.DuplicateFilterBuilder
- DUTCH_STOP_WORDS - Static variable in class org.apache.lucene.analysis.nl.DutchAnalyzer
-
Deprecated.use
DutchAnalyzer.getDefaultStopSet()
instead - DutchAnalyzer - Class in org.apache.lucene.analysis.nl
-
Analyzer
for Dutch language. - DutchAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.nl.DutchAnalyzer
-
Builds an analyzer with the default stop words (
DutchAnalyzer.getDefaultStopSet()
) and a few default entries for the stem exclusion table. - DutchAnalyzer(Version, File) - Constructor for class org.apache.lucene.analysis.nl.DutchAnalyzer
-
Deprecated.use
DutchAnalyzer(Version, Set)
instead - DutchAnalyzer(Version, String...) - Constructor for class org.apache.lucene.analysis.nl.DutchAnalyzer
-
Deprecated.use
DutchAnalyzer(Version, Set)
instead - DutchAnalyzer(Version, HashSet<?>) - Constructor for class org.apache.lucene.analysis.nl.DutchAnalyzer
-
Deprecated.use
DutchAnalyzer(Version, Set)
instead - DutchAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.nl.DutchAnalyzer
- DutchAnalyzer(Version, Set<?>, Set<?>) - Constructor for class org.apache.lucene.analysis.nl.DutchAnalyzer
- DutchAnalyzer(Version, Set<?>, Set<?>, CharArrayMap<String>) - Constructor for class org.apache.lucene.analysis.nl.DutchAnalyzer
- DutchStemFilter - Class in org.apache.lucene.analysis.nl
-
Deprecated.Use
SnowballFilter
withDutchStemmer
instead, which has the same functionality. This filter will be removed in Lucene 5.0 - DutchStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.nl.DutchStemFilter
-
Deprecated.
- DutchStemFilter(TokenStream, Map<?, ?>) - Constructor for class org.apache.lucene.analysis.nl.DutchStemFilter
-
Deprecated.
- DutchStemFilter(TokenStream, Set<?>) - Constructor for class org.apache.lucene.analysis.nl.DutchStemFilter
-
Deprecated.use
KeywordAttribute
withKeywordMarkerFilter
instead. - DutchStemFilter(TokenStream, Set<?>, Map<?, ?>) - Constructor for class org.apache.lucene.analysis.nl.DutchStemFilter
-
Deprecated.use
KeywordAttribute
withKeywordMarkerFilter
instead. - DutchStemmer - Class in org.apache.lucene.analysis.nl
-
Deprecated.Use
DutchStemmer
instead, which has the same functionality. This filter will be removed in Lucene 5.0 - DutchStemmer - Class in org.tartarus.snowball.ext
-
Generated class implementing code defined by a snowball script.
- DutchStemmer() - Constructor for class org.apache.lucene.analysis.nl.DutchStemmer
-
Deprecated.
- DutchStemmer() - Constructor for class org.tartarus.snowball.ext.DutchStemmer
- DYNAMIC - org.apache.lucene.search.CachingWrapperFilter.DeletesMode
E
- EARTH_EQUATORIAL_RADIUS_KM - Static variable in class org.apache.lucene.spatial.DistanceUtils
-
Deprecated.
- EARTH_EQUATORIAL_RADIUS_MI - Static variable in class org.apache.lucene.spatial.DistanceUtils
-
Deprecated.
- EARTH_MEAN_RADIUS_KM - Static variable in class org.apache.lucene.spatial.DistanceUtils
-
Deprecated.The International Union of Geodesy and Geophysics says the Earth's mean radius in KM is: [1] http://en.wikipedia.org/wiki/Earth_radius
- EARTH_MEAN_RADIUS_MI - Static variable in class org.apache.lucene.spatial.DistanceUtils
-
Deprecated.
- earthCircumference() - Method in enum org.apache.lucene.spatial.geometry.DistanceUnits
-
Deprecated.Returns the circumference of the Earth
- earthRadius() - Method in enum org.apache.lucene.spatial.geometry.DistanceUnits
-
Deprecated.Returns the average earth radius
- eat(Row, int[]) - Method in class org.egothor.stemmer.Gener
-
Test whether the given Row of Cells in a Trie should be included in an optimized Trie.
- EdgeNGramTokenFilter - Class in org.apache.lucene.analysis.ngram
-
Tokenizes the given token into n-grams of given size(s).
- EdgeNGramTokenFilter(TokenStream, String, int, int) - Constructor for class org.apache.lucene.analysis.ngram.EdgeNGramTokenFilter
-
Creates EdgeNGramTokenFilter that can generate n-grams in the sizes of the given range
- EdgeNGramTokenFilter(TokenStream, EdgeNGramTokenFilter.Side, int, int) - Constructor for class org.apache.lucene.analysis.ngram.EdgeNGramTokenFilter
-
Creates EdgeNGramTokenFilter that can generate n-grams in the sizes of the given range
- EdgeNGramTokenFilter.Side - Enum in org.apache.lucene.analysis.ngram
-
Specifies which side of the input the n-gram should be generated from
- EdgeNGramTokenizer - Class in org.apache.lucene.analysis.ngram
-
Tokenizes the input from an edge into n-grams of given size(s).
- EdgeNGramTokenizer(Reader, String, int, int) - Constructor for class org.apache.lucene.analysis.ngram.EdgeNGramTokenizer
-
Creates EdgeNGramTokenizer that can generate n-grams in the sizes of the given range
- EdgeNGramTokenizer(Reader, EdgeNGramTokenizer.Side, int, int) - Constructor for class org.apache.lucene.analysis.ngram.EdgeNGramTokenizer
-
Creates EdgeNGramTokenizer that can generate n-grams in the sizes of the given range
- EdgeNGramTokenizer(AttributeSource.AttributeFactory, Reader, String, int, int) - Constructor for class org.apache.lucene.analysis.ngram.EdgeNGramTokenizer
-
Creates EdgeNGramTokenizer that can generate n-grams in the sizes of the given range
- EdgeNGramTokenizer(AttributeSource.AttributeFactory, Reader, EdgeNGramTokenizer.Side, int, int) - Constructor for class org.apache.lucene.analysis.ngram.EdgeNGramTokenizer
-
Creates EdgeNGramTokenizer that can generate n-grams in the sizes of the given range
- EdgeNGramTokenizer(AttributeSource, Reader, String, int, int) - Constructor for class org.apache.lucene.analysis.ngram.EdgeNGramTokenizer
-
Creates EdgeNGramTokenizer that can generate n-grams in the sizes of the given range
- EdgeNGramTokenizer(AttributeSource, Reader, EdgeNGramTokenizer.Side, int, int) - Constructor for class org.apache.lucene.analysis.ngram.EdgeNGramTokenizer
-
Creates EdgeNGramTokenizer that can generate n-grams in the sizes of the given range
- EdgeNGramTokenizer.Side - Enum in org.apache.lucene.analysis.ngram
-
Specifies which side of the input the n-gram should be generated from
- EightFlagsIntDecoder - Class in org.apache.lucene.util.encoding
-
Decodes data which was encoded by
EightFlagsIntEncoder
. - EightFlagsIntDecoder() - Constructor for class org.apache.lucene.util.encoding.EightFlagsIntDecoder
- EightFlagsIntEncoder - Class in org.apache.lucene.util.encoding
-
A
ChunksIntEncoder
which encodes data in chunks of 8. - EightFlagsIntEncoder() - Constructor for class org.apache.lucene.util.encoding.EightFlagsIntEncoder
- ELAPSED - Static variable in class org.apache.lucene.benchmark.byTask.tasks.ReportTask
- ElisionFilter - Class in org.apache.lucene.analysis.fr
-
Removes elisions from a
TokenStream
. - ElisionFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.fr.ElisionFilter
-
Deprecated.use
ElisionFilter(Version, TokenStream)
instead - ElisionFilter(TokenStream, String[]) - Constructor for class org.apache.lucene.analysis.fr.ElisionFilter
-
Deprecated.use
ElisionFilter(Version, TokenStream, Set)
instead - ElisionFilter(TokenStream, Set<?>) - Constructor for class org.apache.lucene.analysis.fr.ElisionFilter
-
Deprecated.use
ElisionFilter(Version, TokenStream, Set)
instead - ElisionFilter(Version, TokenStream) - Constructor for class org.apache.lucene.analysis.fr.ElisionFilter
-
Constructs an elision filter with standard stop words
- ElisionFilter(Version, TokenStream, Set<?>) - Constructor for class org.apache.lucene.analysis.fr.ElisionFilter
-
Constructs an elision filter with a Set of stop words
- Ellipse - Class in org.apache.lucene.spatial.geometry.shape
-
Deprecated.
- Ellipse() - Constructor for class org.apache.lucene.spatial.geometry.shape.Ellipse
-
Deprecated.
- Ellipse(Point2D, Point2D, double) - Constructor for class org.apache.lucene.spatial.geometry.shape.Ellipse
-
Deprecated.Constructor given bounding rectangle and a rotation.
- EMAIL - Static variable in class org.apache.lucene.analysis.standard.ClassicTokenizer
- EMAIL - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
- EMAIL - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
- EMAIL_ID - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
- EMAIL_TYPE - Static variable in class org.apache.lucene.analysis.standard.std31.UAX29URLEmailTokenizerImpl31
-
Deprecated.
- EMAIL_TYPE - Static variable in class org.apache.lucene.analysis.standard.std34.UAX29URLEmailTokenizerImpl34
-
Deprecated.
- EMAIL_TYPE - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
-
Deprecated.use
UAX29URLEmailTokenizer.TOKEN_TYPES
instead - EMAIL_TYPE - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizerImpl
- EMPTY - Static variable in interface org.apache.lucene.util.BytesRefIterator
-
Singleton BytesRefIterator that iterates over 0 BytesRefs.
- EMPTY_ARRAY - Static variable in interface org.apache.lucene.util.Bits
- EMPTY_BYTES - Static variable in class org.apache.lucene.util.BytesRef
-
An empty byte array for convenience
- EMPTY_CHARS - Static variable in class org.apache.lucene.util.CharsRef
- EMPTY_DOCIDSET - Static variable in class org.apache.lucene.search.DocIdSet
-
An empty
DocIdSet
instance for easy use, e.g. - EMPTY_INTS - Static variable in class org.apache.lucene.util.IntsRef
- EMPTY_MESSAGE - Static variable in class org.apache.lucene.queryParser.core.messages.QueryParserMessages
- EMPTY_OFFSET_INFO - Static variable in class org.apache.lucene.index.TermVectorOffsetInfo
-
Convenience declaration when creating a
TermPositionVector
that stores only position information. - EMPTY_SET - Static variable in class org.apache.lucene.analysis.CharArraySet
- EMPTY_TOPDOCS - Static variable in class org.apache.lucene.search.TopDocsCollector
- emptyMap() - Static method in class org.apache.lucene.analysis.CharArrayMap
-
Returns an empty, unmodifiable map.
- EmptyTokenizer - Class in org.apache.lucene.analysis
-
Emits no tokens
- EmptyTokenizer(Reader) - Constructor for class org.apache.lucene.analysis.EmptyTokenizer
- EmptyTokenStream - Class in org.apache.lucene.analysis.miscellaneous
-
An always exhausted token stream.
- EmptyTokenStream() - Constructor for class org.apache.lucene.analysis.miscellaneous.EmptyTokenStream
- emptyVal - Variable in class org.apache.lucene.search.grouping.SentinelIntSet
- ENABLE_POSITION_INCREMENTS - Static variable in class org.apache.lucene.queryParser.standard.config.StandardQueryConfigHandler.ConfigurationKeys
-
Key used to set whether position increments is enabled
- enable_tracing() - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParser
-
Enable tracing.
- enable_tracing() - Method in class org.apache.lucene.queryParser.QueryParser
-
Enable tracing.
- enable_tracing() - Method in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParser
-
Enable tracing.
- enable_tracing() - Method in class org.apache.lucene.queryParser.surround.parser.QueryParser
-
Enable tracing.
- enableBackwards - Variable in class org.apache.lucene.util.AttributeImpl
-
Deprecated.this will be removed in Lucene 4.0.
- encode(byte[], int, int, char[], int, int) - Static method in class org.apache.lucene.util.IndexableBinaryStringTools
-
Encodes the input byte sequence into the output char sequence.
- encode(char[]) - Method in class org.apache.lucene.analysis.payloads.AbstractEncoder
- encode(char[]) - Method in interface org.apache.lucene.analysis.payloads.PayloadEncoder
- encode(char[], int, int) - Method in class org.apache.lucene.analysis.payloads.FloatEncoder
- encode(char[], int, int) - Method in class org.apache.lucene.analysis.payloads.IdentityEncoder
- encode(char[], int, int) - Method in class org.apache.lucene.analysis.payloads.IntegerEncoder
- encode(char[], int, int) - Method in interface org.apache.lucene.analysis.payloads.PayloadEncoder
-
Convert a char array to a
Payload
- encode(double, double) - Static method in class org.apache.lucene.spatial.geohash.GeoHashUtils
-
Deprecated.Encodes the given latitude and longitude into a geohash
- encode(int) - Method in class org.apache.lucene.util.encoding.DGapIntEncoder
- encode(int) - Method in class org.apache.lucene.util.encoding.EightFlagsIntEncoder
- encode(int) - Method in class org.apache.lucene.util.encoding.FourFlagsIntEncoder
-
Small values (<=3) are stored in the
indicator
while larger values are saved for later encoding in theChunksIntEncoder.encodeQueue
. - encode(int) - Method in class org.apache.lucene.util.encoding.IntEncoder
-
Encodes an integer to the output stream given in
reInit
- encode(int) - Method in class org.apache.lucene.util.encoding.NOnesIntEncoder
- encode(int) - Method in class org.apache.lucene.util.encoding.SimpleIntEncoder
-
This method makes sure the value wasn't previously encoded by checking against the Set.
- encode(int) - Method in class org.apache.lucene.util.encoding.SortingIntEncoder
- encode(int) - Method in class org.apache.lucene.util.encoding.UniqueValuesIntEncoder
- encode(int) - Method in class org.apache.lucene.util.encoding.VInt8IntEncoder
- encode(int, byte[], int) - Static method in class org.apache.lucene.util.Vint8
-
Encodes
number
intodest
, starting at offsetstart
from the beginning of the array. - encode(int, OutputStream) - Static method in class org.apache.lucene.util.Vint8
-
Encodes
number
toout
. - encode(String) - Static method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.Entities
- encode(ByteBuffer) - Static method in class org.apache.lucene.util.IndexableBinaryStringTools
-
Deprecated.Use
IndexableBinaryStringTools.encode(byte[], int, int, char[], int, int)
instead. This method will be removed in Lucene 4.0 - encode(ByteBuffer, CharBuffer) - Static method in class org.apache.lucene.util.IndexableBinaryStringTools
-
Deprecated.Use
IndexableBinaryStringTools.encode(byte[], int, int, char[], int, int)
instead. This method will be removed in Lucene 4.0 - encode(Sort.ByteSequencesWriter, ByteArrayDataOutput, byte[], BytesRef, long) - Method in class org.apache.lucene.search.suggest.SortedTermFreqIteratorWrapper
- encodeChunk() - Method in class org.apache.lucene.util.encoding.ChunksIntEncoder
-
Encodes the values of the current chunk.
- encodeCollationKey(byte[]) - Method in class org.apache.lucene.analysis.CollationTestBase
-
Convenience method to perform the same function as CollationKeyFilter.
- encodeFloat(float) - Static method in class org.apache.lucene.analysis.payloads.PayloadHelper
- encodeFloat(float, byte[], int) - Static method in class org.apache.lucene.analysis.payloads.PayloadHelper
- encodeInt(int) - Static method in class org.apache.lucene.analysis.payloads.PayloadHelper
- encodeInt(int, byte[], int) - Static method in class org.apache.lucene.analysis.payloads.PayloadHelper
- encodeNorm(float) - Static method in class org.apache.lucene.search.Similarity
-
Deprecated.Use
Similarity.encodeNormValue(float)
instead. - encodeNormValue(float) - Method in class org.apache.lucene.search.Similarity
-
Encodes a normalization factor for storage in an index.
- encodeQueue - Variable in class org.apache.lucene.util.encoding.ChunksIntEncoder
-
Holds the values which must be encoded, outside the indicator.
- encodeQueueSize - Variable in class org.apache.lucene.util.encoding.ChunksIntEncoder
- encoder - Variable in class org.apache.lucene.analysis.phonetic.PhoneticFilter
- encoder - Variable in class org.apache.lucene.util.encoding.ChunksIntEncoder
-
Encoder used to encode values outside the indicator.
- encoder - Variable in class org.apache.lucene.util.encoding.IntEncoderFilter
- Encoder - Interface in org.apache.lucene.search.highlight
-
Encodes original text.
- encodeText(String) - Method in class org.apache.lucene.search.highlight.DefaultEncoder
- encodeText(String) - Method in interface org.apache.lucene.search.highlight.Encoder
- encodeText(String) - Method in class org.apache.lucene.search.highlight.SimpleHTMLEncoder
- encoding - Variable in class org.apache.lucene.benchmark.byTask.feeds.ContentItemsSource
- end - Variable in class org.apache.lucene.analysis.LookaheadTokenFilter
- end - Variable in class org.apache.lucene.queryParser.core.nodes.FieldQueryNode
-
The term's end position.
- end - Variable in class org.apache.lucene.search.spans.SpanPositionRangeQuery
- end() - Method in class org.apache.lucene.analysis.CachingTokenFilter
- end() - Method in class org.apache.lucene.analysis.CharTokenizer
- end() - Method in class org.apache.lucene.analysis.cjk.CJKTokenizer
-
Deprecated.
- end() - Method in class org.apache.lucene.analysis.cn.ChineseTokenizer
-
Deprecated.
- end() - Method in class org.apache.lucene.analysis.cn.smart.SentenceTokenizer
- end() - Method in class org.apache.lucene.analysis.icu.segmentation.ICUTokenizer
- end() - Method in class org.apache.lucene.analysis.ja.JapaneseTokenizer
- end() - Method in class org.apache.lucene.analysis.KeywordTokenizer
- end() - Method in class org.apache.lucene.analysis.miscellaneous.PrefixAndSuffixAwareTokenFilter
- end() - Method in class org.apache.lucene.analysis.miscellaneous.PrefixAwareTokenFilter
- end() - Method in class org.apache.lucene.analysis.MockTokenizer
- end() - Method in class org.apache.lucene.analysis.ngram.EdgeNGramTokenizer
- end() - Method in class org.apache.lucene.analysis.ngram.NGramTokenizer
- end() - Method in class org.apache.lucene.analysis.path.PathHierarchyTokenizer
- end() - Method in class org.apache.lucene.analysis.path.ReversePathHierarchyTokenizer
- end() - Method in class org.apache.lucene.analysis.standard.ClassicTokenizer
- end() - Method in class org.apache.lucene.analysis.standard.StandardTokenizer
- end() - Method in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
- end() - Method in class org.apache.lucene.analysis.TeeSinkTokenFilter
- end() - Method in class org.apache.lucene.analysis.TeeSinkTokenFilter.SinkTokenStream
- end() - Method in class org.apache.lucene.analysis.TokenFilter
-
Performs end-of-stream operations, if any, and calls then
end()
on the input TokenStream. - end() - Method in class org.apache.lucene.analysis.TokenStream
-
This method is called by the consumer after the last token has been consumed, after
TokenStream.incrementToken()
returnedfalse
(using the newTokenStream
API). - end() - Method in class org.apache.lucene.analysis.ValidatingTokenFilter
- end() - Method in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
- end() - Method in class org.apache.lucene.search.spans.NearSpansOrdered
- end() - Method in class org.apache.lucene.search.spans.NearSpansUnordered
- end() - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery.PositionCheckSpan
- end() - Method in class org.apache.lucene.search.spans.Spans
-
Returns the end position of the current match.
- end() - Method in class org.apache.lucene.search.spans.TermSpans
- END_CHAR_ARRAY - Static variable in class org.apache.lucene.analysis.cn.smart.Utility
- END_LABEL - Static variable in class org.apache.lucene.util.fst.FST
- endColumn - Variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.Token
-
The column number of the last character of this Token.
- endColumn - Variable in class org.apache.lucene.queryParser.standard.parser.Token
-
The column number of the last character of this Token.
- endColumn - Variable in class org.apache.lucene.queryParser.surround.parser.Token
-
The column number of the last character of this Token.
- endColumn - Variable in class org.apache.lucene.queryParser.Token
-
The column number of the last character of this Token.
- endElement(String, String, String) - Method in class org.apache.lucene.analysis.compound.hyphenation.PatternParser
- endEnum() - Method in class org.apache.lucene.search.FilteredTermEnum
-
Indicates the end of the enumeration has been reached
- endEnum() - Method in class org.apache.lucene.search.FuzzyTermEnum
-
Indicates the end of the enumeration has been reached
- endEnum() - Method in class org.apache.lucene.search.PrefixTermEnum
- endEnum() - Method in class org.apache.lucene.search.regex.RegexTermEnum
- endEnum() - Method in class org.apache.lucene.search.SingleTermEnum
- endEnum() - Method in class org.apache.lucene.search.TermRangeTermEnum
- endEnum() - Method in class org.apache.lucene.search.WildcardTermEnum
- endLine - Variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.Token
-
The line number of the last character of this Token.
- endLine - Variable in class org.apache.lucene.queryParser.standard.parser.Token
-
The line number of the last character of this Token.
- endLine - Variable in class org.apache.lucene.queryParser.surround.parser.Token
-
The line number of the last character of this Token.
- endLine - Variable in class org.apache.lucene.queryParser.Token
-
The line number of the last character of this Token.
- endOffset - Variable in class org.apache.lucene.analysis.cn.smart.hhmm.SegToken
-
end offset into original sentence
- endOffset - Variable in class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase.CompoundToken
- endOffset - Variable in class org.apache.lucene.analysis.LookaheadTokenFilter.Position
- endOffset() - Method in class org.apache.lucene.analysis.Token
-
Returns this Token's ending offset, one greater than the position of the last character corresponding to this token in the source text.
- endOffset() - Method in interface org.apache.lucene.analysis.tokenattributes.OffsetAttribute
-
Returns this Token's ending offset, one greater than the position of the last character corresponding to this token in the source text.
- endOffset() - Method in class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
-
Returns this Token's ending offset, one greater than the position of the last character corresponding to this token in the source text.
- ends - Variable in class org.apache.lucene.facet.taxonomy.CategoryPath
- endsWith(char[], int, char[]) - Static method in class org.apache.lucene.analysis.util.StemmerUtil
-
Returns true if the character array ends with the suffix.
- endsWith(char[], int, String) - Static method in class org.apache.lucene.analysis.util.StemmerUtil
-
Returns true if the character array ends with the suffix.
- endsWith(BytesRef) - Method in class org.apache.lucene.util.BytesRef
- endTest(Test) - Method in class org.apache.lucene.util.LuceneJUnitResultFormatter
-
A test ended.
- endTestSuite(JUnitTest) - Method in class org.apache.lucene.util.LuceneJUnitResultFormatter
-
The whole testsuite ended.
- English - Class in org.apache.lucene.util
- ENGLISH_STOP_WORDS_SET - Static variable in class org.apache.lucene.analysis.StopAnalyzer
-
An unmodifiable set containing some common English words that are not usually useful for searching.
- EnglishAnalyzer - Class in org.apache.lucene.analysis.en
-
Analyzer
for English. - EnglishAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.en.EnglishAnalyzer
-
Builds an analyzer with the default stop words:
EnglishAnalyzer.getDefaultStopSet()
. - EnglishAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.en.EnglishAnalyzer
-
Builds an analyzer with the given stop words.
- EnglishAnalyzer(Version, Set<?>, Set<?>) - Constructor for class org.apache.lucene.analysis.en.EnglishAnalyzer
-
Builds an analyzer with the given stop words.
- EnglishMinimalStemFilter - Class in org.apache.lucene.analysis.en
-
A
TokenFilter
that appliesEnglishMinimalStemmer
to stem English words. - EnglishMinimalStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.en.EnglishMinimalStemFilter
- EnglishMinimalStemmer - Class in org.apache.lucene.analysis.en
-
Minimal plural stemmer for English.
- EnglishMinimalStemmer() - Constructor for class org.apache.lucene.analysis.en.EnglishMinimalStemmer
- EnglishPossessiveFilter - Class in org.apache.lucene.analysis.en
-
TokenFilter that removes possessives (trailing 's) from words.
- EnglishPossessiveFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.en.EnglishPossessiveFilter
-
Deprecated.Use
EnglishPossessiveFilter(Version, TokenStream)
instead. - EnglishPossessiveFilter(Version, TokenStream) - Constructor for class org.apache.lucene.analysis.en.EnglishPossessiveFilter
- EnglishStemmer - Class in org.tartarus.snowball.ext
-
Generated class implementing code defined by a snowball script.
- EnglishStemmer() - Constructor for class org.tartarus.snowball.ext.EnglishStemmer
- enhancementBytes - Variable in class org.apache.lucene.facet.enhancements.EnhancementsCategoryTokenizer
-
Buffers for enhancement payload bytes
- enhancements - Variable in class org.apache.lucene.facet.enhancements.EnhancementsCategoryTokenizer
-
The category enhancements to handle
- EnhancementsCategoryTokenizer - Class in org.apache.lucene.facet.enhancements
-
A tokenizer which adds to each category token payload according to the
CategoryEnhancement
s defined in the givenEnhancementsIndexingParams
. - EnhancementsCategoryTokenizer(TokenStream, EnhancementsIndexingParams) - Constructor for class org.apache.lucene.facet.enhancements.EnhancementsCategoryTokenizer
-
Constructor.
- EnhancementsDocumentBuilder - Class in org.apache.lucene.facet.enhancements
-
An
EnhancementsDocumentBuilder
is aCategoryDocumentBuilder
which adds categories to documents according to the list ofCategoryEnhancement
s fromEnhancementsIndexingParams
. - EnhancementsDocumentBuilder(TaxonomyWriter, EnhancementsIndexingParams) - Constructor for class org.apache.lucene.facet.enhancements.EnhancementsDocumentBuilder
- EnhancementsIndexingParams - Interface in org.apache.lucene.facet.enhancements.params
-
Facet indexing parameters
for definingcategory enhancements
. - EnhancementsPayloadIterator - Class in org.apache.lucene.facet.enhancements
-
A
PayloadIterator
for iterating over category posting lists generated usingEnhancementsCategoryTokenizer
. - EnhancementsPayloadIterator(List<CategoryEnhancement>, IndexReader, Term) - Constructor for class org.apache.lucene.facet.enhancements.EnhancementsPayloadIterator
-
Constructor.
- ensureCanWrite(String) - Method in class org.apache.lucene.store.FSDirectory
- ensureCapacity(long) - Method in class org.apache.lucene.util.OpenBitSet
-
Ensure that the long[] is big enough to hold numBits, expanding it if necessary.
- ensureCapacityWords(int) - Method in class org.apache.lucene.util.OpenBitSet
-
Expand the long[] with the size given as a number of words (64 bit longs).
- ensureOpen() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyReader
- ensureOpen() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
-
Verifies that this instance wasn't closed, or throws
AlreadyClosedException
if it is. - ensureOpen() - Method in class org.apache.lucene.index.IndexReader
- ensureOpen() - Method in class org.apache.lucene.index.IndexWriter
- ensureOpen() - Method in class org.apache.lucene.store.Directory
- ensureOpen(boolean) - Method in class org.apache.lucene.index.IndexWriter
-
Used internally to throw an
AlreadyClosedException
if this IndexWriter has been closed. - Entities - Class in org.apache.lucene.benchmark.byTask.feeds.demohtml
- Entities() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.demohtml.Entities
- Entity - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
RegularExpression Id.
- entries - Variable in class org.apache.lucene.search.suggest.BufferingTermFreqIteratorWrapper
- Entry(int, int, float) - Constructor for class org.apache.lucene.search.FieldValueHitQueue.Entry
- entrySet() - Method in class org.apache.lucene.analysis.CharArrayMap
- EnwikiContentSource - Class in org.apache.lucene.benchmark.byTask.feeds
-
A
ContentSource
which reads the English Wikipedia dump. - EnwikiContentSource() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.EnwikiContentSource
- EnwikiQueryMaker - Class in org.apache.lucene.benchmark.byTask.feeds
-
A QueryMaker that uses common and uncommon actual Wikipedia queries for searching the English Wikipedia collection.
- EnwikiQueryMaker() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.EnwikiQueryMaker
- eof() - Method in class org.apache.lucene.store.ByteArrayDataInput
- EOF - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
End of File.
- EOF - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
-
End of File.
- EOF - Static variable in interface org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserConstants
-
End of File.
- EOF - Static variable in interface org.apache.lucene.queryParser.surround.parser.QueryParserConstants
-
End of File.
- eol - Variable in exception org.apache.lucene.benchmark.byTask.feeds.demohtml.ParseException
-
The end of line string for this machine.
- eol - Variable in exception org.apache.lucene.queryParser.ParseException
-
The end of line string for this machine.
- eol - Variable in exception org.apache.lucene.queryParser.standard.parser.ParseException
-
The end of line string for this machine.
- eol - Variable in exception org.apache.lucene.queryParser.surround.parser.ParseException
-
The end of line string for this machine.
- EOS - Static variable in class org.apache.lucene.util.encoding.IntDecoder
-
A special long value which is used to indicate end-of-stream has reached.
- eq - Variable in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
-
Pointer to equal branch and to data when this node is a string terminator.
- EQ - org.apache.lucene.queryParser.core.nodes.ParametricQueryNode.CompareOperator
-
Deprecated.
- eq_s(int, CharSequence) - Method in class org.tartarus.snowball.SnowballProgram
- eq_s(int, String) - Method in class org.tartarus.snowball.SnowballProgram
-
Deprecated.for binary back compat. Will be removed in Lucene 4.0
- eq_s_b(int, CharSequence) - Method in class org.tartarus.snowball.SnowballProgram
- eq_s_b(int, String) - Method in class org.tartarus.snowball.SnowballProgram
-
Deprecated.for binary back compat. Will be removed in Lucene 4.0
- eq_v(CharSequence) - Method in class org.tartarus.snowball.SnowballProgram
- eq_v(StringBuilder) - Method in class org.tartarus.snowball.SnowballProgram
-
Deprecated.for binary back compat. Will be removed in Lucene 4.0
- eq_v_b(CharSequence) - Method in class org.tartarus.snowball.SnowballProgram
- eq_v_b(StringBuilder) - Method in class org.tartarus.snowball.SnowballProgram
-
Deprecated.for binary back compat. Will be removed in Lucene 4.0
- EQKID - Static variable in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie.TSTNode
-
Index values for accessing relatives array.
- equals(char[], int, char[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
-
See if two array slices are the same.
- equals(int[], int, int[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
-
See if two array slices are the same.
- equals(Object) - Method in class org.apache.lucene.analysis.BaseTokenStreamTestCase.CheckClearAttributesAttributeImpl
- equals(Object) - Method in class org.apache.lucene.analysis.cn.smart.hhmm.SegToken
- equals(Object) - Method in class org.apache.lucene.analysis.icu.tokenattributes.ScriptAttributeImpl
- equals(Object) - Method in class org.apache.lucene.analysis.miscellaneous.PatternAnalyzer
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class org.apache.lucene.analysis.Token
- equals(Object) - Method in class org.apache.lucene.analysis.Token.TokenAttributeFactory
- equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
- equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.FlagsAttributeImpl
- equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.KeywordAttributeImpl
- equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
- equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
- equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
- equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.PositionLengthAttributeImpl
- equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
- equals(Object) - Method in class org.apache.lucene.facet.enhancements.association.AssociationEnhancement
- equals(Object) - Method in class org.apache.lucene.facet.enhancements.association.AssociationFloatProperty
- equals(Object) - Method in class org.apache.lucene.facet.enhancements.association.AssociationIntProperty
- equals(Object) - Method in class org.apache.lucene.facet.enhancements.association.AssociationsPayloadIterator
- equals(Object) - Method in interface org.apache.lucene.facet.enhancements.CategoryEnhancement
-
Category enhancements must override
Object.equals(Object)
, as it is used inEnhancementsPayloadIterator.getCategoryData(CategoryEnhancement)
. - equals(Object) - Method in class org.apache.lucene.facet.index.attributes.CategoryAttributeImpl
- equals(Object) - Method in class org.apache.lucene.facet.index.attributes.OrdinalProperty
- equals(Object) - Method in class org.apache.lucene.facet.index.CategoryContainer
- equals(Object) - Method in class org.apache.lucene.facet.index.params.CategoryListParams
-
Equality is defined by the 'term' that defines this category list.
- equals(Object) - Method in class org.apache.lucene.facet.index.params.DefaultFacetIndexingParams
- equals(Object) - Method in class org.apache.lucene.facet.search.aggregator.association.AssociationFloatSumAggregator
- equals(Object) - Method in class org.apache.lucene.facet.search.aggregator.association.AssociationIntSumAggregator
- equals(Object) - Method in class org.apache.lucene.facet.search.aggregator.CountingAggregator
- equals(Object) - Method in class org.apache.lucene.facet.search.aggregator.ScoringAggregator
- equals(Object) - Method in class org.apache.lucene.facet.search.params.FacetRequest
- equals(Object) - Method in class org.apache.lucene.facet.search.PayloadIntDecodingIterator
- equals(Object) - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
-
Compare the given CategoryPath to another one.
- equals(Object) - Method in class org.apache.lucene.index.IndexCommit
-
Two IndexCommits are equal if both their Directory and versions are equal.
- equals(Object) - Method in class org.apache.lucene.index.Payload
- equals(Object) - Method in class org.apache.lucene.index.SegmentInfo
-
We consider another SegmentInfo instance equal if it has the same dir and same name.
- equals(Object) - Method in class org.apache.lucene.index.Term
- equals(Object) - Method in class org.apache.lucene.index.TermVectorEntry
- equals(Object) - Method in class org.apache.lucene.index.TermVectorOffsetInfo
-
Two TermVectorOffsetInfos are equals if both the start and end offsets are the same
- equals(Object) - Method in class org.apache.lucene.queryParser.standard.config.AllowLeadingWildcardAttributeImpl
-
Deprecated.
- equals(Object) - Method in class org.apache.lucene.queryParser.standard.config.AnalyzerAttributeImpl
-
Deprecated.
- equals(Object) - Method in class org.apache.lucene.queryParser.standard.config.BoostAttributeImpl
-
Deprecated.
- equals(Object) - Method in class org.apache.lucene.queryParser.standard.config.DateResolutionAttributeImpl
-
Deprecated.
- equals(Object) - Method in class org.apache.lucene.queryParser.standard.config.DefaultOperatorAttributeImpl
-
Deprecated.
- equals(Object) - Method in class org.apache.lucene.queryParser.standard.config.DefaultPhraseSlopAttributeImpl
-
Deprecated.
- equals(Object) - Method in class org.apache.lucene.queryParser.standard.config.FieldBoostMapAttributeImpl
-
Deprecated.
- equals(Object) - Method in class org.apache.lucene.queryParser.standard.config.FieldDateResolutionMapAttributeImpl
-
Deprecated.
- equals(Object) - Method in class org.apache.lucene.queryParser.standard.config.FuzzyAttributeImpl
-
Deprecated.
- equals(Object) - Method in class org.apache.lucene.queryParser.standard.config.LocaleAttributeImpl
-
Deprecated.
- equals(Object) - Method in class org.apache.lucene.queryParser.standard.config.LowercaseExpandedTermsAttributeImpl
-
Deprecated.
- equals(Object) - Method in class org.apache.lucene.queryParser.standard.config.MultiFieldAttributeImpl
-
Deprecated.
- equals(Object) - Method in class org.apache.lucene.queryParser.standard.config.MultiTermRewriteMethodAttributeImpl
-
Deprecated.
- equals(Object) - Method in class org.apache.lucene.queryParser.standard.config.NumericConfig
- equals(Object) - Method in class org.apache.lucene.queryParser.standard.config.PositionIncrementsAttributeImpl
-
Deprecated.
- equals(Object) - Method in class org.apache.lucene.queryParser.standard.config.RangeCollatorAttributeImpl
-
Deprecated.
- equals(Object) - Method in class org.apache.lucene.search.BooleanClause
-
Returns true if
o
is equal to this. - equals(Object) - Method in class org.apache.lucene.search.BooleanFilter
- equals(Object) - Method in class org.apache.lucene.search.BooleanQuery
-
Returns true iff
o
is equal to this. - equals(Object) - Method in class org.apache.lucene.search.BoostingQuery
- equals(Object) - Method in class org.apache.lucene.search.CachingSpanFilter
- equals(Object) - Method in class org.apache.lucene.search.CachingWrapperFilter
- equals(Object) - Method in class org.apache.lucene.search.CachingWrapperFilterHelper
- equals(Object) - Method in class org.apache.lucene.search.ConstantScoreQuery
- equals(Object) - Method in class org.apache.lucene.search.DisjunctionMaxQuery
-
Return true iff we represent the same query as o
- equals(Object) - Method in class org.apache.lucene.search.DuplicateFilter
- equals(Object) - Method in class org.apache.lucene.search.FieldCacheRangeFilter
- equals(Object) - Method in class org.apache.lucene.search.FieldValueFilter
- equals(Object) - Method in class org.apache.lucene.search.FilterClause
- equals(Object) - Method in class org.apache.lucene.search.FilteredQuery
-
Returns true iff
o
is equal to this. - equals(Object) - Method in class org.apache.lucene.search.function.CustomScoreQuery
-
Returns true if
o
is equal to this. - equals(Object) - Method in class org.apache.lucene.search.function.FieldCacheSource
- equals(Object) - Method in class org.apache.lucene.search.function.OrdFieldSource
- equals(Object) - Method in class org.apache.lucene.search.function.ReverseOrdFieldSource
- equals(Object) - Method in class org.apache.lucene.search.function.ValueSource
-
Needed for possible caching of query results - used by
ValueSourceQuery.equals(Object)
. - equals(Object) - Method in class org.apache.lucene.search.function.ValueSourceQuery
-
Returns true if
o
is equal to this. - equals(Object) - Method in class org.apache.lucene.search.FuzzyLikeThisQuery
- equals(Object) - Method in class org.apache.lucene.search.FuzzyQuery
- equals(Object) - Method in class org.apache.lucene.search.grouping.SearchGroup
- equals(Object) - Method in class org.apache.lucene.search.join.ToChildBlockJoinQuery
- equals(Object) - Method in class org.apache.lucene.search.join.ToParentBlockJoinQuery
- equals(Object) - Method in class org.apache.lucene.search.MatchAllDocsQuery
- equals(Object) - Method in class org.apache.lucene.search.MultiPhraseQuery
-
Returns true if
o
is equal to this. - equals(Object) - Method in class org.apache.lucene.search.MultiTermQuery
- equals(Object) - Method in class org.apache.lucene.search.MultiTermQueryWrapperFilter
- equals(Object) - Method in class org.apache.lucene.search.NGramPhraseQuery
-
Returns true iff
o
is equal to this. - equals(Object) - Method in class org.apache.lucene.search.NumericRangeQuery
- equals(Object) - Method in class org.apache.lucene.search.payloads.AveragePayloadFunction
- equals(Object) - Method in class org.apache.lucene.search.payloads.MaxPayloadFunction
- equals(Object) - Method in class org.apache.lucene.search.payloads.MinPayloadFunction
- equals(Object) - Method in class org.apache.lucene.search.payloads.PayloadFunction
- equals(Object) - Method in class org.apache.lucene.search.payloads.PayloadNearQuery
- equals(Object) - Method in class org.apache.lucene.search.payloads.PayloadTermQuery
- equals(Object) - Method in class org.apache.lucene.search.PhraseQuery
-
Returns true iff
o
is equal to this. - equals(Object) - Method in class org.apache.lucene.search.PrefixQuery
- equals(Object) - Method in class org.apache.lucene.search.Query
- equals(Object) - Method in class org.apache.lucene.search.QueryWrapperFilter
- equals(Object) - Method in class org.apache.lucene.search.regex.JakartaRegexpCapabilities
- equals(Object) - Method in class org.apache.lucene.search.regex.JavaUtilRegexCapabilities
- equals(Object) - Method in class org.apache.lucene.search.regex.RegexQuery
- equals(Object) - Method in class org.apache.lucene.search.Sort
-
Returns true if
o
is equal to this. - equals(Object) - Method in class org.apache.lucene.search.SortField
-
Returns true if
o
is equal to this. - equals(Object) - Method in class org.apache.lucene.search.SpanQueryFilter
- equals(Object) - Method in class org.apache.lucene.search.spans.FieldMaskingSpanQuery
- equals(Object) - Method in class org.apache.lucene.search.spans.SpanFirstQuery
- equals(Object) - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper
- equals(Object) - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper.TopTermsSpanBooleanQueryRewrite
- equals(Object) - Method in class org.apache.lucene.search.spans.SpanNearPayloadCheckQuery
- equals(Object) - Method in class org.apache.lucene.search.spans.SpanNearQuery
-
Returns true iff
o
is equal to this. - equals(Object) - Method in class org.apache.lucene.search.spans.SpanNotQuery
-
Returns true iff
o
is equal to this. - equals(Object) - Method in class org.apache.lucene.search.spans.SpanOrQuery
- equals(Object) - Method in class org.apache.lucene.search.spans.SpanPayloadCheckQuery
- equals(Object) - Method in class org.apache.lucene.search.spans.SpanPositionRangeQuery
- equals(Object) - Method in class org.apache.lucene.search.spans.SpanTermQuery
- equals(Object) - Method in class org.apache.lucene.search.TermQuery
-
Returns true iff
o
is equal to this. - equals(Object) - Method in class org.apache.lucene.search.TermRangeQuery
- equals(Object) - Method in class org.apache.lucene.search.TermsFilter
- equals(Object) - Method in class org.apache.lucene.search.TopTermsRewrite
- equals(Object) - Method in class org.apache.lucene.search.WildcardQuery
- equals(Object) - Method in class org.apache.lucene.spatial.geohash.GeoHashDistanceFilter
-
Deprecated.Returns true if
o
is equal to this. - equals(Object) - Method in class org.apache.lucene.spatial.geometry.CartesianPoint
-
Deprecated.
- equals(Object) - Method in class org.apache.lucene.spatial.geometry.FixedLatLng
-
Deprecated.
- equals(Object) - Method in class org.apache.lucene.spatial.geometry.FloatLatLng
-
Deprecated.
- equals(Object) - Method in class org.apache.lucene.spatial.geometry.LatLng
-
Deprecated.
- equals(Object) - Method in class org.apache.lucene.spatial.geometry.shape.LineSegment
-
Deprecated.
- equals(Object) - Method in class org.apache.lucene.spatial.geometry.shape.LLRect
-
Deprecated.
- equals(Object) - Method in class org.apache.lucene.spatial.geometry.shape.Point2D
-
Deprecated.
- equals(Object) - Method in class org.apache.lucene.spatial.geometry.shape.Rectangle
-
Deprecated.
- equals(Object) - Method in class org.apache.lucene.spatial.geometry.shape.Vector2D
-
Deprecated.
- equals(Object) - Method in class org.apache.lucene.spatial.tier.DistanceFilter
-
Deprecated.Returns true if
o
is equal to this. - equals(Object) - Method in class org.apache.lucene.spatial.tier.LatLongDistanceFilter
-
Deprecated.Returns true if
o
is equal to this. - equals(Object) - Method in class org.apache.lucene.util.AttributeSource
- equals(Object) - Method in class org.apache.lucene.util.BytesRef
- equals(Object) - Method in class org.apache.lucene.util.CharsRef
- equals(Object) - Method in class org.apache.lucene.util.collections.ArrayHashMap
- equals(Object) - Method in class org.apache.lucene.util.collections.FloatToObjectMap
- equals(Object) - Method in class org.apache.lucene.util.collections.IntArray
-
Equals method.
- equals(Object) - Method in class org.apache.lucene.util.collections.IntToDoubleMap
- equals(Object) - Method in class org.apache.lucene.util.collections.IntToIntMap
- equals(Object) - Method in class org.apache.lucene.util.collections.IntToObjectMap
- equals(Object) - Method in class org.apache.lucene.util.collections.ObjectToFloatMap
- equals(Object) - Method in class org.apache.lucene.util.collections.ObjectToIntMap
- equals(Object) - Method in class org.apache.lucene.util.FixedBitSet
-
returns true if both sets have the same bits set
- equals(Object) - Method in class org.apache.lucene.util.fst.PairOutputs.Pair
- equals(Object) - Method in class org.apache.lucene.util.fst.UpToTwoPositiveIntOutputs.TwoLongs
- equals(Object) - Method in class org.apache.lucene.util.IntsRef
- equals(Object) - Method in class org.apache.lucene.util.OpenBitSet
-
returns true if both sets have the same bits set
- equals(Object) - Method in class org.tartarus.snowball.ext.ArmenianStemmer
- equals(Object) - Method in class org.tartarus.snowball.ext.BasqueStemmer
- equals(Object) - Method in class org.tartarus.snowball.ext.CatalanStemmer
- equals(Object) - Method in class org.tartarus.snowball.ext.IrishStemmer
- equals(Vector2D) - Method in class org.apache.lucene.spatial.geometry.shape.Vector2D
-
Deprecated.
- equalsToSerialized(int, CharSequence, int) - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
-
Just like
CategoryPath.equalsToSerialized(CharSequence, int)
, but compare to a prefix of the CategoryPath, instead of the whole CategoryPath. - equalsToSerialized(CharSequence, int) - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
-
Check whether the current path is identical to the one serialized (with
CategoryPath.serializeAppendTo(Appendable)
) in the given buffer, at the given offset. - error - Variable in class org.apache.lucene.index.CheckIndex.Status.FieldNormStatus
-
Exception thrown during term index test (null on success)
- error - Variable in class org.apache.lucene.index.CheckIndex.Status.StoredFieldStatus
-
Exception thrown during stored fields test (null on success)
- error - Variable in class org.apache.lucene.index.CheckIndex.Status.TermIndexStatus
-
Exception thrown during term index test (null on success)
- error - Variable in class org.apache.lucene.index.CheckIndex.Status.TermVectorStatus
-
Exception thrown during term vector test (null on success)
- escape(CharSequence, Locale, EscapeQuerySyntax.Type) - Method in interface org.apache.lucene.queryParser.core.parser.EscapeQuerySyntax
- escape(CharSequence, Locale, EscapeQuerySyntax.Type) - Method in class org.apache.lucene.queryParser.standard.parser.EscapeQuerySyntaxImpl
- escape(String) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
- escape(String) - Static method in class org.apache.lucene.queryParser.QueryParser
-
Returns a String where those characters that QueryParser expects to be escaped are escaped by a preceding
\
. - escape(String) - Static method in class org.apache.lucene.queryParser.standard.QueryParserUtil
-
Returns a String where those characters that TextParser expects to be escaped are escaped by a preceding
\
. - escape(String) - Static method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.Returns a String where those characters that QueryParser expects to be escaped are escaped by a preceding
\
. - escapeExtensionField(String) - Method in class org.apache.lucene.queryParser.ext.Extensions
-
Escapes an extension field.
- EscapeQuerySyntax - Interface in org.apache.lucene.queryParser.core.parser
-
A parser needs to implement
EscapeQuerySyntax
to allow the QueryNode to escape the queries, when the toQueryString method is called. - EscapeQuerySyntax.Type - Enum in org.apache.lucene.queryParser.core.parser
- EscapeQuerySyntaxImpl - Class in org.apache.lucene.queryParser.standard.parser
- EscapeQuerySyntaxImpl() - Constructor for class org.apache.lucene.queryParser.standard.parser.EscapeQuerySyntaxImpl
- estimatedMergeBytes - Variable in class org.apache.lucene.index.MergePolicy.OneMerge
- estimateRamUsage(Object) - Method in class org.apache.lucene.util.RamUsageEstimator
-
Deprecated.Don't create instances of this class, instead use the static
RamUsageEstimator.sizeOf(Object)
method. - estimateSize() - Method in class org.apache.lucene.search.FieldCache.CacheEntry
-
Computes (and stores) the estimated size of the cache Value
- eval(MockDirectoryWrapper) - Method in class org.apache.lucene.store.MockDirectoryWrapper.Failure
-
eval is called on the first write of every new file.
- EXACT - org.apache.lucene.spatial.tier.DistanceHandler.Precision
-
Deprecated.
- exception - Variable in class org.apache.lucene.util.UncaughtExceptionsRule.UncaughtExceptionEntry
- exceptions - Variable in class org.apache.lucene.analysis.pt.RSLPStemmerBase.RuleWithSetExceptions
- exceptions - Variable in class org.apache.lucene.analysis.pt.RSLPStemmerBase.RuleWithSuffixExceptions
- exec(String[]) - Static method in class org.apache.lucene.benchmark.byTask.Benchmark
-
Utility: execute benchmark from command line
- exec(String, String) - Method in class org.egothor.stemmer.Diff
-
Construct a patch string that transforms a to b.
- execute() - Method in class org.apache.lucene.benchmark.byTask.Benchmark
-
Execute this benchmark
- execute() - Method in class org.apache.lucene.benchmark.byTask.utils.Algorithm
-
Execute this algorithm
- execute(Judge, SubmissionReport, PrintWriter) - Method in class org.apache.lucene.benchmark.quality.QualityBenchmark
-
Run the quality benchmark.
- execute(TwoPhaseCommit...) - Static method in class org.apache.lucene.util.TwoPhaseCommitTool
-
Executes a 2-phase commit algorithm by first
TwoPhaseCommit.prepareCommit()
all objects and only if all succeed, it proceeds withTwoPhaseCommit.commit()
. - exist(String) - Method in class org.apache.lucene.search.spell.SpellChecker
-
Check whether the word exists in the index.
- exists(int) - Method in class org.apache.lucene.search.grouping.SentinelIntSet
- ExpandBuff(boolean) - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
- ExpandBuff(boolean) - Method in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
- expandingWordNum(long) - Method in class org.apache.lucene.util.OpenBitSet
- EXPECTED - Static variable in class org.apache.lucene.util.FieldCacheSanityChecker.InsanityType
-
Indicates an expected bit of "insanity".
- expectedTokenSequences - Variable in exception org.apache.lucene.benchmark.byTask.feeds.demohtml.ParseException
-
Each entry in this array is an array of integers.
- expectedTokenSequences - Variable in exception org.apache.lucene.queryParser.ParseException
-
Each entry in this array is an array of integers.
- expectedTokenSequences - Variable in exception org.apache.lucene.queryParser.standard.parser.ParseException
-
Each entry in this array is an array of integers.
- expectedTokenSequences - Variable in exception org.apache.lucene.queryParser.surround.parser.ParseException
-
Each entry in this array is an array of integers.
- explain() - Method in class org.apache.lucene.search.Explanation.IDFExplanation
-
This should be calculated lazily if possible.
- explain(int) - Method in class org.apache.lucene.search.function.DocValues
-
Explain the scoring value for the input doc.
- explain(int) - Method in class org.apache.lucene.search.payloads.PayloadNearQuery.PayloadNearSpanScorer
- explain(int) - Method in class org.apache.lucene.search.payloads.PayloadTermQuery.PayloadTermWeight.PayloadTermSpanScorer
- explain(int) - Method in class org.apache.lucene.search.spans.SpanScorer
-
This method is no longer an official member of
Scorer
, but it is needed by SpanWeight to build an explanation. - explain(int, int, float) - Method in class org.apache.lucene.search.payloads.AveragePayloadFunction
- explain(int, int, float) - Method in class org.apache.lucene.search.payloads.MaxPayloadFunction
- explain(int, int, float) - Method in class org.apache.lucene.search.payloads.MinPayloadFunction
- explain(int, int, float) - Method in class org.apache.lucene.search.payloads.PayloadFunction
- explain(IndexReader, int) - Method in class org.apache.lucene.search.BooleanQuery.BooleanWeight
- explain(IndexReader, int) - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantWeight
- explain(IndexReader, int) - Method in class org.apache.lucene.search.DisjunctionMaxQuery.DisjunctionMaxWeight
-
Explain the score we computed for doc
- explain(IndexReader, int) - Method in class org.apache.lucene.search.payloads.PayloadTermQuery.PayloadTermWeight
- explain(IndexReader, int) - Method in class org.apache.lucene.search.spans.SpanWeight
- explain(IndexReader, int) - Method in class org.apache.lucene.search.Weight
-
An explanation of the score computation for the named document.
- explain(Query, int) - Method in class org.apache.lucene.search.IndexSearcher
-
Returns an Explanation that describes how
doc
scored againstquery
. - explain(Query, int) - Method in class org.apache.lucene.search.Searcher
-
Deprecated.Returns an Explanation that describes how
doc
scored againstquery
. - explain(Weight, int) - Method in class org.apache.lucene.search.IndexSearcher
-
Expert: low-level implementation method Returns an Explanation that describes how
doc
scored againstweight
. - explain(Weight, int) - Method in class org.apache.lucene.search.MultiSearcher
-
Deprecated.
- explain(Weight, int) - Method in class org.apache.lucene.search.RemoteSearchable
-
Deprecated.
- explain(Weight, int) - Method in interface org.apache.lucene.search.Searchable
-
Deprecated.Expert: low-level implementation method Returns an Explanation that describes how
doc
scored againstweight
. - explain(Weight, int) - Method in class org.apache.lucene.search.Searcher
-
Deprecated.
- EXPLAIN_SCORE_TOLERANCE_DELTA - Static variable in class org.apache.lucene.search.CheckHits
-
Some explains methods calculate their values though a slightly different order of operations from the actual scoring method ...
- Explanation - Class in org.apache.lucene.search
-
Expert: Describes the score computation for document and query.
- Explanation() - Constructor for class org.apache.lucene.search.Explanation
- Explanation(float, String) - Constructor for class org.apache.lucene.search.Explanation
- Explanation.IDFExplanation - Class in org.apache.lucene.search
-
Small Util class used to pass both an idf factor as well as an explanation for that factor.
- ExplanationAsserter(Query, String, Searcher) - Constructor for class org.apache.lucene.search.CheckHits.ExplanationAsserter
-
Constructs an instance which does shallow tests on the Explanation
- ExplanationAsserter(Query, String, Searcher, boolean) - Constructor for class org.apache.lucene.search.CheckHits.ExplanationAsserter
- ExplanationAssertingSearcher(IndexReader) - Constructor for class org.apache.lucene.search.CheckHits.ExplanationAssertingSearcher
- expungeDeletes() - Method in class org.apache.lucene.index.IndexWriter
-
Deprecated.
- expungeDeletes(boolean) - Method in class org.apache.lucene.index.IndexWriter
-
Deprecated.
- ExtendableQueryParser - Class in org.apache.lucene.queryParser.ext
-
The
ExtendableQueryParser
enables arbitrary query parser extension based on a customizable field naming scheme. - ExtendableQueryParser(Version, String, Analyzer) - Constructor for class org.apache.lucene.queryParser.ext.ExtendableQueryParser
-
Creates a new
ExtendableQueryParser
instance - ExtendableQueryParser(Version, String, Analyzer, Extensions) - Constructor for class org.apache.lucene.queryParser.ext.ExtendableQueryParser
-
Creates a new
ExtendableQueryParser
instance - EXTENDED - org.apache.lucene.analysis.ja.JapaneseTokenizer.Mode
-
Extended mode outputs unigrams for unknown words.
- EXTENDED_ANALYZER - Static variable in class org.apache.lucene.analysis.miscellaneous.PatternAnalyzer
-
A lower-casing word analyzer with extended English stop words (can be shared freely across threads without harm); global per class loader.
- ExtensionQuery - Class in org.apache.lucene.queryParser.ext
-
ExtensionQuery
holds all query components extracted from the original query string like the query field and the extension query string. - ExtensionQuery(QueryParser, String, String) - Constructor for class org.apache.lucene.queryParser.ext.ExtensionQuery
-
Creates a new
ExtensionQuery
- Extensions - Class in org.apache.lucene.queryParser.ext
-
The
Extensions
class represents an extension mapping to associateParserExtension
instances with extension keys. - Extensions() - Constructor for class org.apache.lucene.queryParser.ext.Extensions
-
Creates a new
Extensions
instance with theExtensions.DEFAULT_EXTENSION_FIELD_DELIMITER
as a delimiter character. - Extensions(char) - Constructor for class org.apache.lucene.queryParser.ext.Extensions
-
Creates a new
Extensions
instance - Extensions.Pair<Cur,Cud> - Class in org.apache.lucene.queryParser.ext
-
This class represents a generic pair.
- EXTERNAL_LINK - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
- EXTERNAL_LINK_ID - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
- EXTERNAL_LINK_URL - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
- EXTERNAL_LINK_URL_ID - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
- ExternalRefSorter - Class in org.apache.lucene.search.suggest.fst
-
Builds and iterates over sequences stored on disk.
- ExternalRefSorter(Sort) - Constructor for class org.apache.lucene.search.suggest.fst.ExternalRefSorter
-
Will buffer all sequences to a temporary file and then sort (all on-disk).
- extract() - Method in class org.apache.lucene.benchmark.utils.ExtractReuters
- extract() - Method in class org.apache.lucene.benchmark.utils.ExtractWikipedia
- extract(StringBuilder, String, String, int, String[]) - Static method in class org.apache.lucene.benchmark.byTask.feeds.TrecDocParser
-
Extract from
buf
the text of interest within specified tags - extract(Query, Map<String, WeightedSpanTerm>) - Method in class org.apache.lucene.search.highlight.WeightedSpanTermExtractor
-
Fills a
Map
with <@link WeightedSpanTerm>s using the terms from the suppliedQuery
. - extractCategoryTokenData(byte[], int, int) - Method in class org.apache.lucene.facet.enhancements.association.AssociationEnhancement
- extractCategoryTokenData(byte[], int, int) - Method in interface org.apache.lucene.facet.enhancements.CategoryEnhancement
-
Get the data of this enhancement from a category token payload.
- extractFile(File) - Method in class org.apache.lucene.benchmark.utils.ExtractReuters
-
Override if you wish to change what is extracted
- ExtractReuters - Class in org.apache.lucene.benchmark.utils
-
Split the Reuters SGML documents into Simple Text files containing: Title, Date, Dateline, Body
- ExtractReuters(File, File) - Constructor for class org.apache.lucene.benchmark.utils.ExtractReuters
- extractTasks() - Method in class org.apache.lucene.benchmark.byTask.utils.Algorithm
-
Expert: for test purposes, return all tasks participating in this algorithm.
- extractTerms(Set<Term>) - Method in class org.apache.lucene.search.BooleanQuery
- extractTerms(Set<Term>) - Method in class org.apache.lucene.search.ConstantScoreQuery
- extractTerms(Set<Term>) - Method in class org.apache.lucene.search.DisjunctionMaxQuery
- extractTerms(Set<Term>) - Method in class org.apache.lucene.search.FilteredQuery
- extractTerms(Set<Term>) - Method in class org.apache.lucene.search.function.CustomScoreQuery
- extractTerms(Set<Term>) - Method in class org.apache.lucene.search.function.ValueSourceQuery
- extractTerms(Set<Term>) - Method in class org.apache.lucene.search.join.ToChildBlockJoinQuery
- extractTerms(Set<Term>) - Method in class org.apache.lucene.search.join.ToParentBlockJoinQuery
- extractTerms(Set<Term>) - Method in class org.apache.lucene.search.MatchAllDocsQuery
- extractTerms(Set<Term>) - Method in class org.apache.lucene.search.MultiPhraseQuery
- extractTerms(Set<Term>) - Method in class org.apache.lucene.search.PhraseQuery
- extractTerms(Set<Term>) - Method in class org.apache.lucene.search.Query
-
Expert: adds all terms occurring in this query to the terms set.
- extractTerms(Set<Term>) - Method in class org.apache.lucene.search.spans.FieldMaskingSpanQuery
- extractTerms(Set<Term>) - Method in class org.apache.lucene.search.spans.SpanNearQuery
- extractTerms(Set<Term>) - Method in class org.apache.lucene.search.spans.SpanNotQuery
- extractTerms(Set<Term>) - Method in class org.apache.lucene.search.spans.SpanOrQuery
- extractTerms(Set<Term>) - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery
- extractTerms(Set<Term>) - Method in class org.apache.lucene.search.spans.SpanTermQuery
- extractTerms(Set<Term>) - Method in class org.apache.lucene.search.TermQuery
- extractUnknownQuery(Query, Map<String, WeightedSpanTerm>) - Method in class org.apache.lucene.search.highlight.WeightedSpanTermExtractor
- extractWeightedSpanTerms(Map<String, WeightedSpanTerm>, SpanQuery) - Method in class org.apache.lucene.search.highlight.WeightedSpanTermExtractor
-
Fills a
Map
with <@link WeightedSpanTerm>s using the terms from the suppliedSpanQuery
. - extractWeightedTerms(Map<String, WeightedSpanTerm>, Query) - Method in class org.apache.lucene.search.highlight.WeightedSpanTermExtractor
-
Fills a
Map
with <@link WeightedSpanTerm>s using the terms from the suppliedQuery
. - ExtractWikipedia - Class in org.apache.lucene.benchmark.utils
-
Extract the downloaded Wikipedia dump into separate files for indexing.
- ExtractWikipedia(DocMaker, File) - Constructor for class org.apache.lucene.benchmark.utils.ExtractWikipedia
F
- F_WORD - Static variable in class org.apache.lucene.search.spell.SpellChecker
-
Field name for each word in the ngram index.
- FacetArrays - Class in org.apache.lucene.facet.search
-
Provider of arrays used for facet operations such as counting.
- FacetArrays(IntArrayAllocator, FloatArrayAllocator) - Constructor for class org.apache.lucene.facet.search.FacetArrays
-
Create a FacetArrays with certain array allocators.
- FacetException - Exception in org.apache.lucene.facet
-
A parent class for exceptions thrown by the Facets code.
- FacetException() - Constructor for exception org.apache.lucene.facet.FacetException
- FacetException(String) - Constructor for exception org.apache.lucene.facet.FacetException
- FacetException(String, Throwable) - Constructor for exception org.apache.lucene.facet.FacetException
- FacetException(Throwable) - Constructor for exception org.apache.lucene.facet.FacetException
- FacetIndexingParams - Interface in org.apache.lucene.facet.index.params
-
Parameters on how facets are to be written to the index.
- FacetParamsMissingPropertyException - Exception in org.apache.lucene.facet.index.params
-
Thrown when the facets params are missing a property.
- FacetParamsMissingPropertyException(String) - Constructor for exception org.apache.lucene.facet.index.params.FacetParamsMissingPropertyException
- facetRequest - Variable in class org.apache.lucene.facet.search.FacetResultsHandler
-
Facet request served by this handler.
- FacetRequest - Class in org.apache.lucene.facet.search.params
-
Request to accumulate facet information for a specified facet and possibly also some of its descendants, upto a specified depth.
- FacetRequest(CategoryPath, int) - Constructor for class org.apache.lucene.facet.search.params.FacetRequest
-
Initialize the request with a given path, and a requested number of facets results.
- FacetRequest.ResultMode - Enum in org.apache.lucene.facet.search.params
-
Result structure manner of applying request's limits such as
FacetRequest.getNumLabel()
andFacetRequest.getNumResults()
. - FacetRequest.SortBy - Enum in org.apache.lucene.facet.search.params
-
Sort options for facet results.
- FacetRequest.SortOrder - Enum in org.apache.lucene.facet.search.params
-
Requested sort order for the results.
- facetRequests - Variable in class org.apache.lucene.facet.search.params.FacetSearchParams
- FacetResult - Class in org.apache.lucene.facet.search.results
-
Result of faceted search.
- FacetResult(FacetRequest, FacetResultNode, int) - Constructor for class org.apache.lucene.facet.search.results.FacetResult
- FacetResultNode - Interface in org.apache.lucene.facet.search.results
-
Result of faceted search for a certain taxonomy node.
- FacetResultsHandler - Class in org.apache.lucene.facet.search
-
Handler for facet results.
- FacetResultsHandler(TaxonomyReader, FacetRequest) - Constructor for class org.apache.lucene.facet.search.FacetResultsHandler
-
Create a faceted search handler.
- facetsAccumulator - Variable in class org.apache.lucene.facet.search.FacetsCollector
- FacetsAccumulator - Class in org.apache.lucene.facet.search
-
Driver for Accumulating facets of faceted search requests over given documents.
- FacetsAccumulator(FacetSearchParams, IndexReader, TaxonomyReader) - Constructor for class org.apache.lucene.facet.search.FacetsAccumulator
- FacetsCollector - Class in org.apache.lucene.facet.search
-
Collector for facet accumulation.
- FacetsCollector(FacetSearchParams, IndexReader, TaxonomyReader) - Constructor for class org.apache.lucene.facet.search.FacetsCollector
-
Create a collector for accumulating facets while collecting documents during search.
- FacetsDirPayloadProcessor(FacetIndexingParams, int[]) - Constructor for class org.apache.lucene.facet.index.FacetsPayloadProcessorProvider.FacetsDirPayloadProcessor
-
Construct FacetsDirPayloadProcessor with custom FacetIndexingParams
- FacetSearchParams - Class in org.apache.lucene.facet.search.params
-
Faceted search parameters indicate for which facets should info be gathered.
- FacetSearchParams() - Constructor for class org.apache.lucene.facet.search.params.FacetSearchParams
-
Construct with default faceted indexing parameters.
- FacetSearchParams(FacetIndexingParams) - Constructor for class org.apache.lucene.facet.search.params.FacetSearchParams
-
Construct with specific faceted indexing parameters.
- FacetSource - Class in org.apache.lucene.benchmark.byTask.feeds
-
Source items for facets.
- FacetSource() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.FacetSource
- FacetsPayloadProcessor(CategoryListParams, int[]) - Constructor for class org.apache.lucene.facet.index.FacetsPayloadProcessorProvider.FacetsPayloadProcessor
- FacetsPayloadProcessorProvider - Class in org.apache.lucene.facet.index
-
A
PayloadProcessorProvider
for updating facets ordinal references, based on an ordinal map. - FacetsPayloadProcessorProvider(Directory, int[], FacetIndexingParams) - Constructor for class org.apache.lucene.facet.index.FacetsPayloadProcessorProvider
-
Construct FacetsPayloadProcessorProvider with FacetIndexingParams
- FacetsPayloadProcessorProvider.FacetsDirPayloadProcessor - Class in org.apache.lucene.facet.index
- FacetsPayloadProcessorProvider.FacetsPayloadProcessor - Class in org.apache.lucene.facet.index
-
A PayloadProcessor for updating facets ordinal references, based on an ordinal map
- failed - Variable in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
- 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
- Failure() - Constructor for class org.apache.lucene.store.MockDirectoryWrapper.Failure
- failureReason - Variable in class org.apache.lucene.store.Lock
-
If a lock obtain called, this failureReason may be set with the "root cause" Exception as to why the lock was not obtained.
- FARSI_YEH - Static variable in class org.apache.lucene.analysis.fa.PersianNormalizer
- FastCharStream - Class in org.apache.lucene.queryParser
-
An efficient implementation of JavaCC's CharStream interface.
- 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.FastCharStream
-
Constructs from a Reader.
- FastCharStream(Reader) - Constructor for class org.apache.lucene.queryParser.surround.parser.FastCharStream
-
Constructs from a Reader.
- fastClear(int) - Method in class org.apache.lucene.util.OpenBitSet
-
clears a bit.
- fastClear(long) - Method in class org.apache.lucene.util.OpenBitSet
-
clears a bit.
- fastFlip(int) - Method in class org.apache.lucene.util.OpenBitSet
-
flips a bit.
- fastFlip(long) - Method in class org.apache.lucene.util.OpenBitSet
-
flips a bit.
- fastGet(int) - Method in class org.apache.lucene.util.OpenBitSet
-
Returns true or false for the specified bit index.
- fastGet(long) - Method in class org.apache.lucene.util.OpenBitSet
-
Returns true or false for the specified bit index.
- fastSet(int) - Method in class org.apache.lucene.util.OpenBitSet
-
Sets the bit at the specified index.
- fastSet(long) - Method in class org.apache.lucene.util.OpenBitSet
-
Sets the bit at the specified index.
- 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
- FBIS - org.apache.lucene.benchmark.byTask.feeds.TrecDocParser.ParsePathType
- FEH - Static variable in class org.apache.lucene.analysis.ar.ArabicStemmer
- fetchPartitionResult(FacetArrays, int) - Method in class org.apache.lucene.facet.search.FacetResultsHandler
-
Fetch results of a single partition, given facet arrays for that partition, and based on the matching documents and faceted search parameters.
- fetchPartitionResult(FacetArrays, int) - Method in class org.apache.lucene.facet.search.TopKFacetResultsHandler
- fetchPartitionResult(FacetArrays, int) - Method in class org.apache.lucene.facet.search.TopKInEachNodeHandler
-
Recursively explore all facets that can be potentially included in the
FacetResult
to be generated, and that belong to the given partition, so that values can be examined and collected. - field - Variable in class org.apache.lucene.facet.search.aggregator.association.AssociationFloatSumAggregator
- field - Variable in class org.apache.lucene.facet.search.aggregator.association.AssociationIntSumAggregator
- field - Variable in class org.apache.lucene.queryParser.core.nodes.FieldQueryNode
-
The term's field
- field - Variable in class org.apache.lucene.search.FieldComparator.NumericComparator
- field - Variable in class org.apache.lucene.search.function.OrdFieldSource
- field - Variable in class org.apache.lucene.search.function.ReverseOrdFieldSource
- field - Variable in class org.apache.lucene.search.spans.SpanNearQuery
- field() - Method in class org.apache.lucene.index.Term
-
Returns the field of this term, an interned string.
- field() - Method in class org.apache.lucene.search.FieldValueFilter
-
Returns the field this filter is applied on.
- field() - Method in class org.apache.lucene.store.instantiated.InstantiatedTerm
- Field - Class in org.apache.lucene.document
-
A field is a section of a Document.
- Field(String, boolean, String, Field.Store, Field.Index, Field.TermVector) - Constructor for class org.apache.lucene.document.Field
-
Create a field by specifying its name, value and how it will be saved in the index.
- Field(String, byte[]) - Constructor for class org.apache.lucene.document.Field
-
Create a stored field with binary value.
- Field(String, byte[], int, int) - Constructor for class org.apache.lucene.document.Field
-
Create a stored field with binary value.
- Field(String, byte[], int, int, Field.Store) - Constructor for class org.apache.lucene.document.Field
-
Deprecated.Use
instead
- Field(String, byte[], Field.Store) - Constructor for class org.apache.lucene.document.Field
-
Deprecated.Use
instead
- Field(String, Reader) - Constructor for class org.apache.lucene.document.Field
-
Create a tokenized and indexed field that is not stored.
- Field(String, Reader, Field.TermVector) - Constructor for class org.apache.lucene.document.Field
-
Create a tokenized and indexed field that is not stored, optionally with storing term vectors.
- Field(String, String, Field.Store, Field.Index) - Constructor for class org.apache.lucene.document.Field
-
Create a field by specifying its name, value and how it will be saved in the index.
- Field(String, String, Field.Store, Field.Index, Field.TermVector) - Constructor for class org.apache.lucene.document.Field
-
Create a field by specifying its name, value and how it will be saved in the index.
- Field(String, TokenStream) - Constructor for class org.apache.lucene.document.Field
-
Create a tokenized and indexed field that is not stored.
- Field(String, TokenStream, Field.TermVector) - Constructor for class org.apache.lucene.document.Field
-
Create a tokenized and indexed field that is not stored, optionally with storing term vectors.
- FIELD_BOOST_MAP - Static variable in class org.apache.lucene.queryParser.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.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_INFOS_EXTENSION - Static variable in class org.apache.lucene.index.IndexFileNames
-
Extension of field infos
- FIELD_OFFSETS - org.apache.lucene.util.RamUsageEstimator.JvmFeature
- FIELD_SCORE - Static variable in class org.apache.lucene.search.SortField
-
Represents sorting by document score (relevance).
- Field.Index - Enum in org.apache.lucene.document
-
Specifies whether and how a field should be indexed.
- Field.Store - Enum in org.apache.lucene.document
-
Specifies whether and how a field should be stored.
- Field.TermVector - Enum in org.apache.lucene.document
-
Specifies whether and how a field should have term vectors.
- Fieldable - Interface in org.apache.lucene.document
-
Synonymous with
Field
. - FieldableNode - Interface in org.apache.lucene.queryParser.core.nodes
-
A query node implements
FieldableNode
interface to indicate that its children and itself are associated to a specific field. - FieldBoostMapAttribute - Interface in org.apache.lucene.queryParser.standard.config
-
Deprecated.
- FieldBoostMapAttributeImpl - Class in org.apache.lucene.queryParser.standard.config
-
Deprecated.
- FieldBoostMapAttributeImpl() - Constructor for class org.apache.lucene.queryParser.standard.config.FieldBoostMapAttributeImpl
-
Deprecated.
- FieldBoostMapFCListener - Class in org.apache.lucene.queryParser.standard.config
-
This listener listens for every field configuration request and assign a
StandardQueryConfigHandler.ConfigurationKeys.BOOST
to the equivalentFieldConfig
based on a defined map: fieldName -> boostValue stored inStandardQueryConfigHandler.ConfigurationKeys.FIELD_BOOST_MAP
. - FieldBoostMapFCListener(QueryConfigHandler) - Constructor for class org.apache.lucene.queryParser.standard.config.FieldBoostMapFCListener
- FieldCache - Interface in org.apache.lucene.search
-
Expert: Maintains caches of term values.
- FieldCache.ByteParser - Interface in org.apache.lucene.search
-
Interface to parse bytes from document fields.
- FieldCache.CacheEntry - Class in org.apache.lucene.search
-
EXPERT: A unique Identifier/Description for each item in the FieldCache.
- FieldCache.CreationPlaceholder - Class in org.apache.lucene.search
- FieldCache.DoubleParser - Interface in org.apache.lucene.search
-
Interface to parse doubles from document fields.
- FieldCache.FloatParser - Interface in org.apache.lucene.search
-
Interface to parse floats from document fields.
- FieldCache.IntParser - Interface in org.apache.lucene.search
-
Interface to parse ints from document fields.
- FieldCache.LongParser - Interface in org.apache.lucene.search
-
Interface to parse long from document fields.
- FieldCache.Parser - Interface in org.apache.lucene.search
-
Marker interface as super-interface to all parsers.
- FieldCache.ShortParser - Interface in org.apache.lucene.search
-
Interface to parse shorts from document fields.
- FieldCache.StringIndex - Class in org.apache.lucene.search
-
Expert: Stores term text values and document ordering data.
- FieldCacheDocIdSet - Class in org.apache.lucene.search
-
Base class for DocIdSet to be used with FieldCache.
- FieldCacheDocIdSet(IndexReader) - Constructor for class org.apache.lucene.search.FieldCacheDocIdSet
- FieldCacheRangeFilter<T> - Class in org.apache.lucene.search
-
A range filter built on top of a cached single term field (in
FieldCache
). - FieldCacheSanityChecker - Class in org.apache.lucene.util
-
Provides methods for sanity checking that entries in the FieldCache are not wasteful or inconsistent.
- FieldCacheSanityChecker() - Constructor for class org.apache.lucene.util.FieldCacheSanityChecker
- FieldCacheSanityChecker.Insanity - Class in org.apache.lucene.util
-
Simple container for a collection of related CacheEntry objects that in conjunction with each other represent some "insane" usage of the FieldCache.
- FieldCacheSanityChecker.InsanityType - Class in org.apache.lucene.util
-
An Enumeration of the different types of "insane" behavior that may be detected in a FieldCache.
- FieldCacheSource - Class in org.apache.lucene.search.function
-
Expert: A base class for ValueSource implementations that retrieve values for a single field from the
FieldCache
. - FieldCacheSource(String) - Constructor for class org.apache.lucene.search.function.FieldCacheSource
-
Create a cached field source for the input field.
- FieldCacheTermsFilter - Class in org.apache.lucene.search
-
A
Filter
that only accepts documents whose single term value in the specified field is contained in the provided set of allowed terms. - FieldCacheTermsFilter(String, String...) - Constructor for class org.apache.lucene.search.FieldCacheTermsFilter
- FieldComparator<T> - Class in org.apache.lucene.search
-
Expert: a FieldComparator compares hits so as to determine their sort order when collecting the top results with
TopFieldCollector
. - FieldComparator() - Constructor for class org.apache.lucene.search.FieldComparator
- FieldComparator.ByteComparator - Class in org.apache.lucene.search
-
Parses field's values as byte (using
FieldCache.getBytes(org.apache.lucene.index.IndexReader, java.lang.String)
and sorts by ascending value - FieldComparator.DocComparator - Class in org.apache.lucene.search
-
Sorts by ascending docID
- FieldComparator.DoubleComparator - Class in org.apache.lucene.search
-
Parses field's values as double (using
FieldCache.getDoubles(org.apache.lucene.index.IndexReader, java.lang.String)
and sorts by ascending value - FieldComparator.FloatComparator - Class in org.apache.lucene.search
-
Parses field's values as float (using
FieldCache.getFloats(org.apache.lucene.index.IndexReader, java.lang.String)
and sorts by ascending value - FieldComparator.IntComparator - Class in org.apache.lucene.search
-
Parses field's values as int (using
FieldCache.getInts(org.apache.lucene.index.IndexReader, java.lang.String)
and sorts by ascending value - FieldComparator.LongComparator - Class in org.apache.lucene.search
-
Parses field's values as long (using
FieldCache.getLongs(org.apache.lucene.index.IndexReader, java.lang.String)
and sorts by ascending value - FieldComparator.NumericComparator<T extends Number> - Class in org.apache.lucene.search
- FieldComparator.RelevanceComparator - Class in org.apache.lucene.search
-
Sorts by descending relevance.
- FieldComparator.ShortComparator - Class in org.apache.lucene.search
-
Parses field's values as short (using
FieldCache.getShorts(org.apache.lucene.index.IndexReader, java.lang.String)
and sorts by ascending value - FieldComparator.StringComparatorLocale - Class in org.apache.lucene.search
-
Sorts by a field's value using the Collator for a given Locale.
- FieldComparator.StringOrdValComparator - Class in org.apache.lucene.search
-
Sorts by field's natural String sort order, using ordinals.
- FieldComparator.StringValComparator - Class in org.apache.lucene.search
-
Sorts by field's natural String sort order.
- FieldComparatorSource - Class in org.apache.lucene.search
-
Provides a
FieldComparator
for custom field sorting. - FieldComparatorSource() - Constructor for class org.apache.lucene.search.FieldComparatorSource
- FieldConfig - Class in org.apache.lucene.queryParser.core.config
-
This class represents a field configuration.
- FieldConfig(CharSequence) - Constructor for class org.apache.lucene.queryParser.core.config.FieldConfig
-
Deprecated.use
FieldConfig(String)
instead - FieldConfig(String) - Constructor for class org.apache.lucene.queryParser.core.config.FieldConfig
-
Constructs a
FieldConfig
- FieldConfigListener - Interface in org.apache.lucene.queryParser.core.config
-
This interface should be implemented by classes that wants to listen for field configuration requests.
- FieldDateResolutionFCListener - Class in org.apache.lucene.queryParser.standard.config
-
This listener listens for every field configuration request and assign a
DateResolutionAttribute
to the equivalentFieldConfig
based on a defined map: fieldName -> DateTools.Resolution stored inFieldDateResolutionMapAttribute
in theDateResolutionAttribute
. - FieldDateResolutionFCListener(QueryConfigHandler) - Constructor for class org.apache.lucene.queryParser.standard.config.FieldDateResolutionFCListener
- FieldDateResolutionMapAttribute - Interface in org.apache.lucene.queryParser.standard.config
-
Deprecated.
- FieldDateResolutionMapAttributeImpl - Class in org.apache.lucene.queryParser.standard.config
-
Deprecated.
- FieldDateResolutionMapAttributeImpl() - Constructor for class org.apache.lucene.queryParser.standard.config.FieldDateResolutionMapAttributeImpl
-
Deprecated.
- 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.
- fieldFlags - Variable in class org.apache.lucene.index.pruning.StorePruningPolicy
-
Pruning in effect for each field
- fieldFlags - Variable in class org.apache.lucene.index.pruning.TermPruningPolicy
-
Pruning operations to be conducted on fields.
- 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
- FieldFragList.WeightedFragInfo.SubInfo - Class in org.apache.lucene.search.vectorhighlight
- fieldInfo(int) - Method in class org.apache.lucene.index.FieldInfos
-
Return the fieldinfo object referenced by the fieldNumber.
- fieldInfo(String) - Method in class org.apache.lucene.index.FieldInfos
- FieldInfo - Class in org.apache.lucene.index
-
Access to the Fieldable Info file that describes document fields and whether or not they are indexed.
- FieldInfo.IndexOptions - Enum in org.apache.lucene.index
-
Controls how much information is stored in the postings lists.
- fieldInfos - Variable in class org.apache.lucene.index.SegmentWriteState
- FieldInfos - Class in org.apache.lucene.index
-
Collection of
FieldInfo
s (accessible by number or by name). - FieldInfos() - Constructor for class org.apache.lucene.index.FieldInfos
- FieldInfos(Directory, String) - Constructor for class org.apache.lucene.index.FieldInfos
-
Construct a FieldInfos object using the directory and the name of the file IndexInput
- FieldInvertState - Class in org.apache.lucene.index
-
This class tracks the number and position / offset parameters of terms being added to the index.
- FieldInvertState() - Constructor for class org.apache.lucene.index.FieldInvertState
- FieldInvertState(int, int, int, int, float) - Constructor for class org.apache.lucene.index.FieldInvertState
- fieldList - Variable in class org.apache.lucene.facet.index.CategoryDocumentBuilder
-
A list of fields which is filled at ancestors' construction and used during
CategoryDocumentBuilder.build(Document)
. - FieldMaskingSpanQuery - Class in org.apache.lucene.search.spans
-
Wrapper to allow
SpanQuery
objects participate in composite single-field SpanQueries by 'lying' about their search field. - FieldMaskingSpanQuery(SpanQuery, String) - Constructor for class org.apache.lucene.search.spans.FieldMaskingSpanQuery
- fieldName - Variable in class org.apache.lucene.search.payloads.PayloadNearQuery
- fieldName(int) - Method in class org.apache.lucene.index.FieldInfos
-
Return the fieldName identified by its number.
- 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
- FieldNormModifier - Class in org.apache.lucene.index
-
Deprecated.This class is broken, as it does not correctly take position overlaps into account.
- FieldNormModifier(Directory, Similarity) - Constructor for class org.apache.lucene.index.FieldNormModifier
-
Deprecated.Constructor for code that wishes to use this class programmatically If Similarity is null, kill the field norms.
- 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).
- FieldNormStatus() - Constructor for class org.apache.lucene.index.CheckIndex.Status.FieldNormStatus
- fieldNumber(String) - Method in class org.apache.lucene.index.FieldInfos
-
lookup the number of a field by name.
- 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.WeightedPhraseInfo - Class in org.apache.lucene.search.vectorhighlight
- FieldPhraseList.WeightedPhraseInfo.Toffs - Class in org.apache.lucene.search.vectorhighlight
- FieldQuery - Class in org.apache.lucene.search.vectorhighlight
-
FieldQuery breaks down query object into terms/phrases and keep them in QueryPhraseMap structure.
- FieldQuery.QueryPhraseMap - Class in org.apache.lucene.search.vectorhighlight
- FieldQueryNode - Class in org.apache.lucene.queryParser.core.nodes
-
A
FieldQueryNode
represents a element that contains field/text tuple - FieldQueryNode(CharSequence, CharSequence, int, int) - Constructor for class org.apache.lucene.queryParser.core.nodes.FieldQueryNode
- FieldQueryNodeBuilder - Class in org.apache.lucene.queryParser.standard.builders
-
Builds a
TermQuery
object from aFieldQueryNode
object. - FieldQueryNodeBuilder() - Constructor for class org.apache.lucene.queryParser.standard.builders.FieldQueryNodeBuilder
- FieldReaderException - Exception in org.apache.lucene.index
-
Exception thrown when stored fields have an unexpected format.
- FieldReaderException() - Constructor for exception org.apache.lucene.index.FieldReaderException
-
Constructs a new runtime exception with
null
as its detail message. - FieldReaderException(String) - Constructor for exception org.apache.lucene.index.FieldReaderException
-
Constructs a new runtime exception with the specified detail message.
- FieldReaderException(String, Throwable) - Constructor for exception org.apache.lucene.index.FieldReaderException
-
Constructs a new runtime exception with the specified detail message and cause.
- FieldReaderException(Throwable) - Constructor for exception org.apache.lucene.index.FieldReaderException
-
Constructs a new runtime exception with the specified cause and a detail message of (cause==null ? null : cause.toString()) (which typically contains the class and detail message of cause).
- fields - Variable in class org.apache.lucene.queryParser.MultiFieldQueryParser
- fields - Variable in class org.apache.lucene.search.FieldDoc
-
Expert: The values which are used to sort the referenced document.
- fields - Variable in class org.apache.lucene.search.FieldValueHitQueue
-
Stores the sort criteria being used.
- fields - Variable in class org.apache.lucene.search.TopFieldDocs
-
The fields which were used to sort results by.
- FIELDS_EXTENSION - Static variable in class org.apache.lucene.index.IndexFileNames
-
Extension of stored fields file
- FIELDS_HEADER_INDICATOR - Static variable in class org.apache.lucene.benchmark.byTask.tasks.WriteLineDocTask
- FIELDS_INDEX_EXTENSION - Static variable in class org.apache.lucene.index.IndexFileNames
-
Extension of stored fields index file
- FieldScoreQuery - Class in org.apache.lucene.search.function
-
A query that scores each document as the value of the numeric input field.
- FieldScoreQuery(String, FieldScoreQuery.Type) - Constructor for class org.apache.lucene.search.function.FieldScoreQuery
-
Create a FieldScoreQuery - a query that scores each document as the value of the numeric input field.
- FieldScoreQuery.Type - Class in org.apache.lucene.search.function
-
Type of score field, indicating how field values are interpreted/parsed.
- fieldsData - Variable in class org.apache.lucene.document.AbstractField
- fieldSelector - Variable in class org.apache.lucene.benchmark.byTask.tasks.SearchTravRetLoadFieldSelectorTask
- FieldSelector - Interface in org.apache.lucene.document
-
Similar to a
FileFilter
, the FieldSelector allows one to make decisions about what Fields get loaded on aDocument
byIndexReader.document(int,org.apache.lucene.document.FieldSelector)
- FieldSelectorResult - Enum in org.apache.lucene.document
-
Provides information about what should be done with this Field
- FieldSortedTermVectorMapper - Class in org.apache.lucene.index
-
For each Field, store a sorted collection of
TermVectorEntry
s - FieldSortedTermVectorMapper(boolean, boolean, Comparator<TermVectorEntry>) - Constructor for class org.apache.lucene.index.FieldSortedTermVectorMapper
- FieldSortedTermVectorMapper(Comparator<TermVectorEntry>) - Constructor for class org.apache.lucene.index.FieldSortedTermVectorMapper
- FieldsQuery - Class in org.apache.lucene.queryParser.surround.query
- FieldsQuery(SrndQuery, String, char) - Constructor for class org.apache.lucene.queryParser.surround.query.FieldsQuery
- FieldsQuery(SrndQuery, List<String>, char) - Constructor for class org.apache.lucene.queryParser.surround.query.FieldsQuery
- FieldsQuery() - Method in class org.apache.lucene.queryParser.surround.parser.QueryParser
- FieldsQueryList() - Method in class org.apache.lucene.queryParser.surround.parser.QueryParser
- 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
- FieldValueFilter - Class in org.apache.lucene.search
-
A
Filter
that accepts all documents that have one or more values in a given field. - FieldValueFilter(String) - Constructor for class org.apache.lucene.search.FieldValueFilter
-
Creates a new
FieldValueFilter
- FieldValueFilter(String, boolean) - Constructor for class org.apache.lucene.search.FieldValueFilter
-
Creates a new
FieldValueFilter
- FieldValueHitQueue<T extends FieldValueHitQueue.Entry> - Class in org.apache.lucene.search
-
Expert: A hit queue for sorting by hits by terms in more than one field.
- FieldValueHitQueue.Entry - Class in org.apache.lucene.search
- FieldValuePairQueryNode<T> - Interface in org.apache.lucene.queryParser.core.nodes
-
This interface should be implemented by
QueryNode
that holds a field and an arbitrary value. - file - Variable in class org.apache.lucene.store.SimpleFSDirectory.SimpleFSIndexInput
- 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
- FileDictionary(Reader) - Constructor for class org.apache.lucene.search.suggest.FileDictionary
-
Creates a dictionary based on a reader.
- fileExists(String) - Method in class org.apache.lucene.store.Directory
-
Returns true iff a file with the given name exists.
- fileExists(String) - Method in class org.apache.lucene.store.FileSwitchDirectory
- fileExists(String) - Method in class org.apache.lucene.store.FSDirectory
-
Returns true iff a file with the given name exists.
- fileExists(String) - Method in class org.apache.lucene.store.MockDirectoryWrapper
- fileExists(String) - Method in class org.apache.lucene.store.NRTCachingDirectory
- fileExists(String) - Method in class org.apache.lucene.store.RAMDirectory
-
Returns true iff the named file exists in this directory.
- fileLength(String) - Method in class org.apache.lucene.store.Directory
-
Returns the length of a file in the directory.
- fileLength(String) - Method in class org.apache.lucene.store.FileSwitchDirectory
- fileLength(String) - Method in class org.apache.lucene.store.FSDirectory
-
Returns the length in bytes of a file in the directory.
- fileLength(String) - Method in class org.apache.lucene.store.MockDirectoryWrapper
- fileLength(String) - Method in class org.apache.lucene.store.NRTCachingDirectory
- fileLength(String) - Method in class org.apache.lucene.store.RAMDirectory
-
Returns the length in bytes of a file in the directory.
- fileMap - Variable in class org.apache.lucene.store.RAMDirectory
- fileModified(File, String) - Static method in class org.apache.lucene.store.FSDirectory
-
Returns the time the named file was last modified.
- fileModified(String) - Method in class org.apache.lucene.store.Directory
-
Deprecated.
- fileModified(String) - Method in class org.apache.lucene.store.FileSwitchDirectory
- fileModified(String) - Method in class org.apache.lucene.store.FSDirectory
-
Returns the time the named file was last modified.
- fileModified(String) - Method in class org.apache.lucene.store.MockDirectoryWrapper
- fileModified(String) - Method in class org.apache.lucene.store.NRTCachingDirectory
- fileModified(String) - Method in class org.apache.lucene.store.RAMDirectory
-
Returns the time the named file was last modified.
- FILENAME - Static variable in class org.apache.lucene.search.suggest.fst.FSTLookup
-
Deprecated.Serialized automaton file name (storage).
- 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
- fileNameFromGeneration(String, String, long) - Static method in class org.apache.lucene.index.IndexFileNames
-
Computes the full file name from base, extension and generation.
- files() - Method in class org.apache.lucene.index.SegmentInfo
- files(Directory, boolean) - Method in class org.apache.lucene.index.SegmentInfos
-
Returns all file names referenced by SegmentInfo instances matching the provided Directory (ie files associated with any "external" segments are skipped).
- FileSwitchDirectory - Class in org.apache.lucene.store
-
Expert: A Directory instance that switches files between two other Directory instances.
- FileSwitchDirectory(Set<String>, Directory, Directory, boolean) - Constructor for class org.apache.lucene.store.FileSwitchDirectory
- FileUtils - Class in org.apache.lucene.benchmark.byTask.utils
-
File utilities.
- FileUtils() - Constructor for class org.apache.lucene.benchmark.byTask.utils.FileUtils
- fill(BytesRef, long) - Method in class org.apache.lucene.util.PagedBytes.Reader
-
Reads length as 1 or 2 byte vInt prefix, starting at start.
- fill(CharacterUtils.CharacterBuffer, Reader) - Method in class org.apache.lucene.util.CharacterUtils
-
Fills the
CharacterUtils.CharacterBuffer
with characters read from the given readerReader
. - fillAndGetIndex(BytesRef, long) - Method in class org.apache.lucene.util.PagedBytes.Reader
-
Reads length as 1 or 2 byte vInt prefix, starting at start.
- fillAndGetStart(BytesRef, long) - Method in class org.apache.lucene.util.PagedBytes.Reader
-
Reads length as 1 or 2 byte vInt prefix, starting at start and returns the start offset of the next part, suitable as start parameter on next call to sequentially read all
BytesRef
. - FillBuff() - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
- FillBuff() - Method in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
- fillCategoriesMap(Iterable<CategoryAttribute>) - Method in class org.apache.lucene.facet.index.CategoryDocumentBuilder
-
Fills the categories mapping between a field name and a list of categories that belongs to it according to this builder's
FacetIndexingParams
object - fillChildrenBufferAndApplyModifiery(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.BooleanQuery2ModifierNodeProcessor
- FILLER_TOKEN - Static variable in class org.apache.lucene.analysis.shingle.ShingleFilter
-
filler token for when positionIncrement is more than 1
- fillSlice(BytesRef, long, int) - Method in class org.apache.lucene.util.PagedBytes.Reader
-
Gets a slice out of
PagedBytes
starting at start with a given length. - fillSliceWithPrefix(BytesRef, long) - Method in class org.apache.lucene.util.PagedBytes.Reader
-
Gets a slice out of
PagedBytes
starting at start, the length is read as 1 or 2 byte vInt prefix. - fillTotalCountsForPartition(int[], int) - Method in class org.apache.lucene.facet.search.TotalFacetCounts
-
Fill a partition's array with the TotalCountsArray values.
- filter - Variable in class org.apache.lucene.search.ConstantScoreQuery
- filter - Variable in class org.apache.lucene.search.FilterManager.FilterItem
-
Deprecated.
- filter - Variable in class org.apache.lucene.search.RemoteCachingWrapperFilter
-
Deprecated.
- filter(SegToken) - Method in class org.apache.lucene.analysis.cn.smart.hhmm.SegTokenFilter
-
Filter an input
SegToken
- Filter - Class in org.apache.lucene.search
-
Abstract base class for restricting which documents may be returned during searching.
- Filter() - Constructor for class org.apache.lucene.search.Filter
- FilterBuilder - Interface in org.apache.lucene.xmlparser
- FilterBuilderFactory - Class in org.apache.lucene.xmlparser
- FilterBuilderFactory() - Constructor for class org.apache.lucene.xmlparser.FilterBuilderFactory
- FilterClause - Class in org.apache.lucene.search
-
A Filter that wrapped with an indication of how that filter is used when composed with another filter.
- FilterClause(Filter, BooleanClause.Occur) - Constructor for class org.apache.lucene.search.FilterClause
-
Create a new FilterClause
- filterCleaner - Variable in class org.apache.lucene.search.FilterManager
-
Deprecated.Cache cleaner that runs in a separate thread
- FilterCleaner() - Constructor for class org.apache.lucene.search.FilterManager.FilterCleaner
-
Deprecated.
- FilteredDocIdSet - Class in org.apache.lucene.search
-
Abstract decorator class for a DocIdSet implementation that provides on-demand filtering/validation mechanism on a given DocIdSet.
- FilteredDocIdSet(DocIdSet) - Constructor for class org.apache.lucene.search.FilteredDocIdSet
-
Constructor.
- FilteredDocIdSetIterator - Class in org.apache.lucene.search
-
Abstract decorator class of a DocIdSetIterator implementation that provides on-demand filter/validation mechanism on an underlying DocIdSetIterator.
- FilteredDocIdSetIterator(DocIdSetIterator) - Constructor for class org.apache.lucene.search.FilteredDocIdSetIterator
-
Constructor.
- FilteredQuery - Class in org.apache.lucene.search
-
A query that applies a filter to the results of another query.
- FilteredQuery(Query, Filter) - Constructor for class org.apache.lucene.search.FilteredQuery
-
Constructs a new query which applies a filter to the results of the original query.
- FilteredQueryBuilder - Class in org.apache.lucene.xmlparser.builders
- FilteredQueryBuilder(FilterBuilder, QueryBuilder) - Constructor for class org.apache.lucene.xmlparser.builders.FilteredQueryBuilder
- FilteredTermEnum - Class in org.apache.lucene.search
-
Abstract class for enumerating a subset of all terms.
- FilteredTermEnum() - Constructor for class org.apache.lucene.search.FilteredTermEnum
- filterFactory - Variable in class org.apache.lucene.xmlparser.CoreParser
- FilterIndexReader - Class in org.apache.lucene.index
-
A
FilterIndexReader
contains another IndexReader, which it uses as its basic source of data, possibly transforming the data along the way or providing additional functionality. - FilterIndexReader(IndexReader) - Constructor for class org.apache.lucene.index.FilterIndexReader
-
Construct a FilterIndexReader based on the specified base reader.
- FilterIndexReader.FilterTermDocs - Class in org.apache.lucene.index
-
Base class for filtering
TermDocs
implementations. - FilterIndexReader.FilterTermEnum - Class in org.apache.lucene.index
-
Base class for filtering
TermEnum
implementations. - FilterIndexReader.FilterTermPositions - Class in org.apache.lucene.index
-
Base class for filtering
TermPositions
implementations. - FilteringTokenFilter - Class in org.apache.lucene.analysis
-
Abstract base class for TokenFilters that may remove tokens.
- FilteringTokenFilter(boolean, TokenStream) - Constructor for class org.apache.lucene.analysis.FilteringTokenFilter
- FilterItem(Filter) - Constructor for class org.apache.lucene.search.FilterManager.FilterItem
-
Deprecated.
- FilterManager - Class in org.apache.lucene.search
-
Deprecated.used by remote package which is deprecated as well. You should use
CachingWrapperFilter
if you wish to cacheFilter
s. - FilterManager() - Constructor for class org.apache.lucene.search.FilterManager
-
Deprecated.Sets up the FilterManager singleton.
- FilterManager.FilterCleaner - Class in org.apache.lucene.search
-
Deprecated.Keeps the cache from getting too big.
- FilterManager.FilterItem - Class in org.apache.lucene.search
-
Deprecated.Holds the filter and the last time the filter was used, to make LRU-based cache cleaning possible.
- FilterTermDocs(TermDocs) - Constructor for class org.apache.lucene.index.FilterIndexReader.FilterTermDocs
- FilterTermEnum(TermEnum) - Constructor for class org.apache.lucene.index.FilterIndexReader.FilterTermEnum
- FilterTermPositions(TermPositions) - Constructor for class org.apache.lucene.index.FilterIndexReader.FilterTermPositions
- finalResult(OpenBitSetDISI, int) - Method in class org.apache.lucene.search.ChainedFilter
-
Deprecated.Either use CachingWrapperFilter, or switch to a different DocIdSet implementation yourself. This method will be removed in Lucene 4.0
- find(char[], int) - Method in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
- find(float) - Method in class org.apache.lucene.util.collections.FloatToObjectMap
-
Find the actual index of a given key.
- find(int) - Method in class org.apache.lucene.search.grouping.SentinelIntSet
-
returns the slot for this key, or -slot-1 if not found
- find(int) - Method in class org.apache.lucene.util.collections.IntHashSet
-
Find the actual index of a given key.
- find(int) - Method in class org.apache.lucene.util.collections.IntToDoubleMap
-
Find the actual index of a given key.
- find(int) - Method in class org.apache.lucene.util.collections.IntToIntMap
-
Find the actual index of a given key.
- find(int) - Method in class org.apache.lucene.util.collections.IntToObjectMap
-
Find the actual index of a given key.
- find(String) - Method in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
- find(K) - Method in class org.apache.lucene.util.collections.ArrayHashMap
-
Returns the index of the given key, or zero if the key wasn't found.
- find(K) - Method in class org.apache.lucene.util.collections.ObjectToFloatMap
-
Find the actual index of a given key.
- find(K) - Method in class org.apache.lucene.util.collections.ObjectToIntMap
-
Find the actual index of a given key.
- find_among(Among[], int) - Method in class org.tartarus.snowball.SnowballProgram
- find_among_b(Among[], int) - Method in class org.tartarus.snowball.SnowballProgram
- findCategory(CategoryPath) - 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.
- findDistanceUnit(String) - Static method in enum org.apache.lucene.spatial.geometry.DistanceUnits
-
Deprecated.Returns the DistanceUnit which represents the given unit
- 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) - Method in class org.apache.lucene.index.BalancedSegmentMergePolicy
-
Deprecated.
- findForcedDeletesMerges(SegmentInfos) - Method in class org.apache.lucene.index.LogMergePolicy
-
Finds merges necessary to force-merge all deletes from the index.
- findForcedDeletesMerges(SegmentInfos) - Method in class org.apache.lucene.index.MergePolicy
-
Determine what set of merge operations is necessary in order to expunge all deletes from the index.
- findForcedDeletesMerges(SegmentInfos) - Method in class org.apache.lucene.index.MockRandomMergePolicy
- findForcedDeletesMerges(SegmentInfos) - Method in class org.apache.lucene.index.NoMergePolicy
- findForcedDeletesMerges(SegmentInfos) - Method in class org.apache.lucene.index.TieredMergePolicy
- findForcedDeletesMerges(SegmentInfos) - Method in class org.apache.lucene.index.UpgradeIndexMergePolicy
- findForcedMerges(SegmentInfos, int, Map<SegmentInfo, Boolean>) - Method in class org.apache.lucene.index.BalancedSegmentMergePolicy
-
Deprecated.
- findForcedMerges(SegmentInfos, int, Map<SegmentInfo, Boolean>) - Method in class org.apache.lucene.index.LogMergePolicy
-
Returns the merges necessary to merge the index down to a specified number of segments.
- findForcedMerges(SegmentInfos, int, Map<SegmentInfo, Boolean>) - Method in class org.apache.lucene.index.MergePolicy
-
Determine what set of merge operations is necessary in order to merge to <= the specified segment count.
- findForcedMerges(SegmentInfos, int, Map<SegmentInfo, Boolean>) - Method in class org.apache.lucene.index.MockRandomMergePolicy
- findForcedMerges(SegmentInfos, int, Map<SegmentInfo, Boolean>) - Method in class org.apache.lucene.index.NoMergePolicy
- findForcedMerges(SegmentInfos, int, Map<SegmentInfo, Boolean>) - Method in class org.apache.lucene.index.TieredMergePolicy
- findForcedMerges(SegmentInfos, int, Map<SegmentInfo, Boolean>) - Method in class org.apache.lucene.index.UpgradeIndexMergePolicy
- findIndexCommit(Directory, String) - Static method in class org.apache.lucene.benchmark.byTask.tasks.OpenReaderTask
- findMerges(SegmentInfos) - Method in class org.apache.lucene.index.BalancedSegmentMergePolicy
-
Deprecated.
- findMerges(SegmentInfos) - Method in class org.apache.lucene.index.LogMergePolicy
-
Checks if any merges are now necessary and returns a
MergePolicy.MergeSpecification
if so. - findMerges(SegmentInfos) - Method in class org.apache.lucene.index.MergePolicy
-
Determine what set of merge operations are now necessary on the index.
- findMerges(SegmentInfos) - Method in class org.apache.lucene.index.MockRandomMergePolicy
- findMerges(SegmentInfos) - Method in class org.apache.lucene.index.NoMergePolicy
- findMerges(SegmentInfos) - Method in class org.apache.lucene.index.TieredMergePolicy
- findMerges(SegmentInfos) - Method in class org.apache.lucene.index.UpgradeIndexMergePolicy
- findPattern(String) - Method in class org.apache.lucene.analysis.compound.hyphenation.HyphenationTree
- FindSegmentsFile(Directory) - Constructor for class org.apache.lucene.index.SegmentInfos.FindSegmentsFile
- 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
- 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<T>, FST.Arc<T>, FST.BytesReader) - Method in class org.apache.lucene.util.fst.FST
-
Finds an arc leaving the incoming arc, replacing the arc in place.
- finish() - Method in class org.apache.lucene.analysis.ja.GraphvizFormatter
- finish() - Method in class org.apache.lucene.util.fst.Builder
-
Returns final FST.
- finish() - Method in class org.apache.lucene.util.packed.PackedInts.Writer
- finishCommit() - Method in class org.apache.lucene.store.ChecksumIndexOutput
- FinnishAnalyzer - Class in org.apache.lucene.analysis.fi
-
Analyzer
for Finnish. - FinnishAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.fi.FinnishAnalyzer
-
Builds an analyzer with the default stop words:
FinnishAnalyzer.DEFAULT_STOPWORD_FILE
. - FinnishAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.fi.FinnishAnalyzer
-
Builds an analyzer with the given stop words.
- FinnishAnalyzer(Version, Set<?>, Set<?>) - 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
-
A
TokenFilter
that appliesFinnishLightStemmer
to stem Finnish words. - FinnishLightStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.fi.FinnishLightStemFilter
- 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
-
Generated class implementing code defined by a snowball script.
- FinnishStemmer() - Constructor for class org.tartarus.snowball.ext.FinnishStemmer
- first - Variable in class org.apache.lucene.util.fst.UpToTwoPositiveIntOutputs.TwoLongs
- first() - Method in class org.apache.lucene.analysis.icu.segmentation.LaoBreakIterator
- first() - Method in class org.apache.lucene.analysis.util.CharArrayIterator
- FIRST_LEVEL_SIZE - Static variable in class org.apache.lucene.util.ByteBlockPool
- firstRangeBeginningOriginal - Variable in class org.apache.lucene.analysis.CollationTestBase
- firstRangeEndOriginal - Variable in class org.apache.lucene.analysis.CollationTestBase
- FixedBitSet - Class in org.apache.lucene.util
-
BitSet of fixed length (numBits), backed by accessible (
FixedBitSet.getBits()
) long[], accessed with an int index, implementing Bits and DocIdSet. - FixedBitSet(int) - Constructor for class org.apache.lucene.util.FixedBitSet
- FixedBitSet(FixedBitSet) - Constructor for class org.apache.lucene.util.FixedBitSet
-
Makes full copy.
- FixedLatLng - Class in org.apache.lucene.spatial.geometry
-
Deprecated.
- FixedLatLng(int, int) - Constructor for class org.apache.lucene.spatial.geometry.FixedLatLng
-
Deprecated.
- FixedLatLng(LatLng) - Constructor for class org.apache.lucene.spatial.geometry.FixedLatLng
-
Deprecated.
- fixedOrdinalPolicy() - Method in class org.apache.lucene.facet.index.params.DefaultFacetIndexingParams
-
"fixed" ordinal policy.
- fixedPartitionSize() - Method in class org.apache.lucene.facet.index.params.DefaultFacetIndexingParams
-
"fixed" partition size.
- fixedPathPolicy() - Method in class org.apache.lucene.facet.index.params.DefaultFacetIndexingParams
-
"fixed" path policy.
- fixedToDouble(int) - Static method in class org.apache.lucene.spatial.geometry.FixedLatLng
-
Deprecated.
- fixIndex(CheckIndex.Status) - Method in class org.apache.lucene.index.CheckIndex
-
Repairs the index using previously returned result from
CheckIndex.checkIndex()
. - fixResult(ScoredDocIDs, FacetResult) - Method in interface org.apache.lucene.facet.search.sampling.SampleFixer
-
Alter the input result, fixing it to account for the sampling.
- FLAG_CANON_EQ - Static variable in class org.apache.lucene.search.regex.JavaUtilRegexCapabilities
- FLAG_CASE_INSENSITIVE - Static variable in class org.apache.lucene.search.regex.JavaUtilRegexCapabilities
- FLAG_COMMENTS - Static variable in class org.apache.lucene.search.regex.JavaUtilRegexCapabilities
- FLAG_DOTALL - Static variable in class org.apache.lucene.search.regex.JavaUtilRegexCapabilities
- FLAG_LITERAL - Static variable in class org.apache.lucene.search.regex.JavaUtilRegexCapabilities
- FLAG_MATCH_CASEINDEPENDENT - Static variable in class org.apache.lucene.search.regex.JakartaRegexpCapabilities
-
Flag to specify that matching should be case-independent (folded)
- FLAG_MATCH_NORMAL - Static variable in class org.apache.lucene.search.regex.JakartaRegexpCapabilities
-
Flag to specify normal, case-sensitive matching behaviour.
- FLAG_MULTILINE - Static variable in class org.apache.lucene.search.regex.JavaUtilRegexCapabilities
- FLAG_UNICODE_CASE - Static variable in class org.apache.lucene.search.regex.JavaUtilRegexCapabilities
- FLAG_UNIX_LINES - Static variable in class org.apache.lucene.search.regex.JavaUtilRegexCapabilities
- FlagsAttribute - Interface in org.apache.lucene.analysis.tokenattributes
-
This attribute can be used to pass different flags down the
Tokenizer
chain, eg from one TokenFilter to another one. - FlagsAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
-
This attribute can be used to pass different flags down the tokenizer chain, eg from one TokenFilter to another one.
- FlagsAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.FlagsAttributeImpl
- flip(int, int) - Method in class org.apache.lucene.util.FixedBitSet
-
Flips a range of bits
- flip(long) - Method in class org.apache.lucene.util.OpenBitSet
-
flips a bit, expanding the set size if necessary
- flip(long, long) - Method in class org.apache.lucene.util.OpenBitSet
-
Flips a range of bits, expanding the set size if necessary
- flipAndGet(int) - Method in class org.apache.lucene.util.OpenBitSet
-
flips a bit and returns the resulting bit value.
- flipAndGet(long) - Method in class org.apache.lucene.util.OpenBitSet
-
flips a bit and returns the resulting bit value.
- FLOAT - org.apache.lucene.document.NumericField.DataType
- FLOAT - Static variable in class org.apache.lucene.search.function.FieldScoreQuery.Type
-
field values are interpreted as numeric float values.
- FLOAT - Static variable in class org.apache.lucene.search.SortField
-
Sort using term values as encoded Floats.
- floatArrayAllocator - Variable in class org.apache.lucene.facet.search.StandardFacetsAccumulator
- FloatArrayAllocator - Class in org.apache.lucene.facet.search
-
An FloatArrayAllocator is an object which manages float array objects of a certain size.
- FloatArrayAllocator(int, int) - Constructor for class org.apache.lucene.facet.search.FloatArrayAllocator
-
Construct an allocator for float arrays of size
size
, keeping around a pool of up tomaxArrays
old arrays. - FloatEncoder - Class in org.apache.lucene.analysis.payloads
-
Encode a character array Float as a
Payload
. - FloatEncoder() - Constructor for class org.apache.lucene.analysis.payloads.FloatEncoder
- FloatFieldSource - Class in org.apache.lucene.search.function
-
Expert: obtains float field values from the
FieldCache
usinggetFloats()
and makes those values available as other numeric types, casting as needed. - FloatFieldSource(String) - Constructor for class org.apache.lucene.search.function.FloatFieldSource
-
Create a cached float field source with default string-to-float parser.
- FloatFieldSource(String, FieldCache.FloatParser) - Constructor for class org.apache.lucene.search.function.FloatFieldSource
-
Create a cached float field source with a specific string-to-float parser.
- FloatIterator - Interface in org.apache.lucene.util.collections
-
Iterator interface for primitive int iteration.
- FloatLatLng - Class in org.apache.lucene.spatial.geometry
-
Deprecated.
- FloatLatLng(double, double) - Constructor for class org.apache.lucene.spatial.geometry.FloatLatLng
-
Deprecated.
- FloatLatLng(LatLng) - Constructor for class org.apache.lucene.spatial.geometry.FloatLatLng
-
Deprecated.
- floatToByte(float, int, int) - Static method in class org.apache.lucene.util.SmallFloat
-
Converts a 32 bit float to an 8 bit float.
- floatToByte315(float) - Static method in class org.apache.lucene.util.SmallFloat
-
floatToByte(b, mantissaBits=3, zeroExponent=15)
smallest non-zero value = 5.820766E-10
largest value = 7.5161928E9
epsilon = 0.125 - floatToByte52(float) - Static method in class org.apache.lucene.util.SmallFloat
-
floatToByte(b, mantissaBits=5, zeroExponent=2)
smallest nonzero value = 0.033203125
largest value = 1984.0
epsilon = 0.03125 - FloatToObjectMap<T> - Class in org.apache.lucene.util.collections
-
An Array-based hashtable which maps primitive float to Objects of generic type T.
The hashtable is constracted with a given capacity, or 16 as a default. - FloatToObjectMap() - Constructor for class org.apache.lucene.util.collections.FloatToObjectMap
-
Constructs a map with default capacity.
- FloatToObjectMap(int) - Constructor for class org.apache.lucene.util.collections.FloatToObjectMap
-
Constructs a map with given capacity.
- floatToPrefixCoded(float) - Static method in class org.apache.lucene.util.NumericUtils
- floatToSortableInt(float) - Static method in class org.apache.lucene.util.NumericUtils
-
Converts a
float
value to a sortable signedint
. - floatVal(int) - Method in class org.apache.lucene.search.function.DocValues
-
Return doc value as a float.
- 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.IndexReader
-
Deprecated.Write support will be removed in Lucene 4.0.
- flush() - Method in class org.apache.lucene.store.BufferedIndexOutput
-
Forces any buffered output to be written.
- flush() - Method in class org.apache.lucene.store.ChecksumIndexOutput
- flush() - Method in class org.apache.lucene.store.IndexOutput
-
Forces any buffered output to be written.
- flush() - Method in class org.apache.lucene.store.MockIndexOutputWrapper
- flush() - Method in class org.apache.lucene.store.RAMOutputStream
- flush() - Method in class org.apache.lucene.util.ThrottledIndexOutput
- flush(boolean, boolean) - Method in class org.apache.lucene.index.IndexWriter
-
Flush all in-memory buffered updates (adds and deletes) to the Directory.
- flush(boolean, boolean, boolean) - Method in class org.apache.lucene.index.IndexWriter
-
NOTE: flushDocStores is ignored now (hardwired to true); this method is only here for backwards compatibility
- flush(Map<String, String>) - Method in class org.apache.lucene.index.IndexReader
-
Deprecated.Write support will be removed in Lucene 4.0.
- flushBuffer(byte[], int, int) - Method in class org.apache.lucene.store.BufferedIndexOutput
-
Expert: implements buffer write.
- flushBuffer(byte[], int, int) - Method in class org.apache.lucene.store.FSDirectory.FSIndexOutput
-
output methods:
- flushBuffer(IndexOutput, long) - Method in class org.apache.lucene.store.BufferedIndexInput
-
Flushes the in-memory bufer to the given output, copying at most
numBytes
. - FlushReaderTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Commits via IndexReader.
- FlushReaderTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.FlushReaderTask
- foldToASCII(char[], int) - Method in class org.apache.lucene.analysis.ASCIIFoldingFilter
-
Converts characters above ASCII to their ASCII equivalents.
- foldToASCII(char[], int, char[], int, int) - Static method in class org.apache.lucene.analysis.ASCIIFoldingFilter
-
Converts characters above ASCII to their ASCII equivalents.
- following(int) - Method in class org.apache.lucene.analysis.icu.segmentation.LaoBreakIterator
- follows(TextFragment) - Method in class org.apache.lucene.search.highlight.TextFragment
- FORCE_COMPLEMENT - Static variable in class org.apache.lucene.facet.search.FacetsAccumulator
-
Passing this to
FacetsAccumulator.setComplementThreshold(double)
will force using complement optimization. - forceMerge(int) - Method in class org.apache.lucene.index.IndexWriter
-
Forces merge policy to merge segments until there's <= maxNumSegments.
- forceMerge(int) - Method in class org.apache.lucene.index.RandomIndexWriter
-
Forces a forceMerge.
- forceMerge(int, boolean) - Method in class org.apache.lucene.index.IndexWriter
-
Just like
IndexWriter.forceMerge(int)
, except you can specify whether the call should block until all merging completes. - forceMergeDeletes() - Method in class org.apache.lucene.index.IndexWriter
-
Forces merging of all segments that have deleted documents.
- forceMergeDeletes() - Method in class org.apache.lucene.index.RandomIndexWriter
- forceMergeDeletes(boolean) - Method in class org.apache.lucene.index.IndexWriter
-
Just like
IndexWriter.forceMergeDeletes()
, except you can specify whether the call should block until the operation completes. - forceMergeDeletes(boolean) - Method in class org.apache.lucene.index.RandomIndexWriter
- 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
- format(double, StringBuffer, FieldPosition) - Method in class org.apache.lucene.queryParser.standard.config.NumberDateFormat
- format(int, double, String) - Static method in 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, String) - Static method in class org.apache.lucene.benchmark.byTask.utils.Format
-
Pad a number from left.
- format(long, StringBuffer, FieldPosition) - Method in class org.apache.lucene.queryParser.standard.config.NumberDateFormat
- format(Object, StringBuffer, FieldPosition) - Method in class org.apache.lucene.queryParser.standard.config.NumberDateFormat
- format(String, String) - Static method in class org.apache.lucene.benchmark.byTask.utils.Format
-
Pad a string from right.
- 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 - Static variable in class org.apache.lucene.index.SegmentInfos
-
The file format version, a negative number.
- FORMAT_3_1 - Static variable in class org.apache.lucene.index.SegmentInfos
-
Each segment records the Lucene version that created it.
- FORMAT_CHECKSUM - Static variable in class org.apache.lucene.index.SegmentInfos
-
This format adds a checksum at the end of the file to ensure all bytes were successfully written.
- FORMAT_DEL_COUNT - Static variable in class org.apache.lucene.index.SegmentInfos
-
This format adds the deletion count for each segment.
- FORMAT_DIAGNOSTICS - Static variable in class org.apache.lucene.index.SegmentInfos
-
This format adds optional per-segment String diagnostics storage, and switches userData to Map
- FORMAT_HAS_PROX - Static variable in class org.apache.lucene.index.SegmentInfos
-
This format adds the boolean hasProx to record if any fields in the segment store prox information (ie, have omitTermFreqAndPositions==false)
- FORMAT_HAS_VECTORS - Static variable in class org.apache.lucene.index.SegmentInfos
-
Each segment records whether it has term vectors
- FORMAT_LOCKLESS - Static variable in class org.apache.lucene.index.SegmentInfos
-
This format adds details used for lockless commits.
- FORMAT_MAXIMUM - Static variable in class org.apache.lucene.index.SegmentInfos
- FORMAT_MINIMUM - Static variable in class org.apache.lucene.index.SegmentInfos
- FORMAT_OMIT_POSITIONS - Static variable in class org.apache.lucene.index.FieldInfos
- FORMAT_PRE - Static variable in class org.apache.lucene.index.FieldInfos
- FORMAT_SHARED_DOC_STORE - Static variable in class org.apache.lucene.index.SegmentInfos
-
This format allows multiple segments to share a single vectors and stored fields file.
- FORMAT_SINGLE_NORM_FILE - Static variable in class org.apache.lucene.index.SegmentInfos
-
This format adds a "hasSingleNormFile" flag into each segment info.
- FORMAT_START - Static variable in class org.apache.lucene.index.FieldInfos
- FORMAT_USER_DATA - Static variable in class org.apache.lucene.index.SegmentInfos
-
This format adds optional commit userData (String) storage.
- formatError(String, Test, Throwable) - Method in class org.apache.lucene.util.LuceneJUnitResultFormatter
-
Format an error and print it.
- formatPaddLeft(String, String) - Static method in class org.apache.lucene.benchmark.byTask.utils.Format
-
Pad a string from left.
- formatPaddRight(int, double, String) - Static method in class org.apache.lucene.benchmark.byTask.utils.Format
- formatPaddRight(int, float, String) - Static method in class org.apache.lucene.benchmark.byTask.utils.Format
-
Pad a number from right.
- 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.
- formatTest(Test) - Method in class org.apache.lucene.util.LuceneJUnitResultFormatter
-
Format the test for printing..
- formSimilarQuery(String, Analyzer, String, Set<?>) - Static method in class org.apache.lucene.search.similar.SimilarityQueries
-
Simple similarity query generators.
- FourFlagsIntDecoder - Class in org.apache.lucene.util.encoding
-
Decodes data which was encoded by
FourFlagsIntEncoder
. - FourFlagsIntDecoder() - Constructor for class org.apache.lucene.util.encoding.FourFlagsIntDecoder
- FourFlagsIntEncoder - Class in org.apache.lucene.util.encoding
-
A
ChunksIntEncoder
which encodes values in chunks of 4. - FourFlagsIntEncoder() - Constructor for class org.apache.lucene.util.encoding.FourFlagsIntEncoder
- FR94 - org.apache.lucene.benchmark.byTask.feeds.TrecDocParser.ParsePathType
- 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
-
FragmentsBuilder
is an interface for fragments (snippets) builder classes. - fragSize - Variable in class org.apache.lucene.benchmark.byTask.tasks.SearchTravRetVectorHighlightTask
- free() - Method in class org.apache.lucene.facet.search.FacetArrays
-
Notify allocators that they can free arrays allocated on behalf of this FacetArrays object.
- free(T) - Method in class org.apache.lucene.facet.search.TemporaryObjectAllocator
-
Return a no-longer-needed object back to the pool.
- freeBefore(int) - Method in class org.apache.lucene.util.RollingBuffer
- freeBefore(int) - Method in class org.apache.lucene.util.RollingCharBuffer
-
Call this to notify us that no chars before this absolute position are needed anymore.
- freeBlocks(int) - Method in class org.apache.lucene.util.RecyclingByteBlockAllocator
-
Removes the given number of byte blocks from the buffer if possible.
- freenode - Variable in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
- freeze(boolean) - Method in class org.apache.lucene.util.PagedBytes
-
Commits final byte[], trimming it if necessary and if trim=true
- freeze(Builder.UnCompiledNode<T>[], int, IntsRef) - Method in class org.apache.lucene.util.fst.Builder.FreezeTail
- FreezeTail() - Constructor for class org.apache.lucene.util.fst.Builder.FreezeTail
- FRENCH_STOP_WORDS - Static variable in class org.apache.lucene.analysis.fr.FrenchAnalyzer
-
Deprecated.use
FrenchAnalyzer.getDefaultStopSet()
instead - FrenchAnalyzer - Class in org.apache.lucene.analysis.fr
-
Analyzer
for French language. - FrenchAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.fr.FrenchAnalyzer
-
Builds an analyzer with the default stop words (
FrenchAnalyzer.getDefaultStopSet()
). - FrenchAnalyzer(Version, File) - Constructor for class org.apache.lucene.analysis.fr.FrenchAnalyzer
-
Deprecated.use
FrenchAnalyzer(Version, Set)
instead - FrenchAnalyzer(Version, String...) - Constructor for class org.apache.lucene.analysis.fr.FrenchAnalyzer
-
Deprecated.use
FrenchAnalyzer(Version, Set)
instead - FrenchAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.fr.FrenchAnalyzer
-
Builds an analyzer with the given stop words
- FrenchAnalyzer(Version, Set<?>, Set<?>) - 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
-
A
TokenFilter
that appliesFrenchLightStemmer
to stem French words. - FrenchLightStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.fr.FrenchLightStemFilter
- 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
-
A
TokenFilter
that appliesFrenchMinimalStemmer
to stem French words. - FrenchMinimalStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.fr.FrenchMinimalStemFilter
- FrenchMinimalStemmer - Class in org.apache.lucene.analysis.fr
-
Light Stemmer for French.
- FrenchMinimalStemmer() - Constructor for class org.apache.lucene.analysis.fr.FrenchMinimalStemmer
- FrenchStemFilter - Class in org.apache.lucene.analysis.fr
-
Deprecated.Use
SnowballFilter
withFrenchStemmer
instead, which has the same functionality. This filter will be removed in Lucene 5.0 - FrenchStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.fr.FrenchStemFilter
-
Deprecated.
- FrenchStemFilter(TokenStream, Set<?>) - Constructor for class org.apache.lucene.analysis.fr.FrenchStemFilter
-
Deprecated.use
KeywordAttribute
withKeywordMarkerFilter
instead. - FrenchStemmer - Class in org.apache.lucene.analysis.fr
-
Deprecated.Use
FrenchStemmer
instead, which has the same functionality. This filter will be removed in Lucene 5.0 - FrenchStemmer - Class in org.tartarus.snowball.ext
-
Generated class implementing code defined by a snowball script.
- FrenchStemmer() - Constructor for class org.apache.lucene.analysis.fr.FrenchStemmer
-
Deprecated.
- FrenchStemmer() - Constructor for class org.tartarus.snowball.ext.FrenchStemmer
- freq - Variable in class org.apache.lucene.search.spans.SpanScorer
- 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.index.AbstractAllTermDocs
- freq() - Method in class org.apache.lucene.index.FilterIndexReader.FilterTermDocs
- freq() - Method in class org.apache.lucene.index.MultipleTermPositions
- freq() - Method in interface org.apache.lucene.index.TermDocs
-
Returns the frequency of the term within the current document.
- freq() - Method in class org.apache.lucene.search.Scorer
-
Returns number of matches for the current document.
- freq() - Method in class org.apache.lucene.search.spans.SpanScorer
- freq() - Method in class org.apache.lucene.store.instantiated.InstantiatedTermDocs
- FREQ_EXTENSION - Static variable in class org.apache.lucene.index.IndexFileNames
-
Extension of freq postings file
- freqs - Variable in class org.apache.lucene.search.suggest.BufferingTermFreqIteratorWrapper
- fromCartesian(CartesianPoint) - Static method in class org.apache.lucene.spatial.geometry.LatLng
-
Deprecated.The inverse of toCartesian().
- FRONT - org.apache.lucene.analysis.ngram.EdgeNGramTokenFilter.Side
-
Get the n-gram from the front of the input
- FRONT - org.apache.lucene.analysis.ngram.EdgeNGramTokenizer.Side
-
Get the n-gram from the front of the input
- fs - Variable in class org.apache.lucene.index.pruning.StorePruningPolicy
- FSDirectory - Class in org.apache.lucene.store
- FSDirectory(File, LockFactory) - Constructor for class org.apache.lucene.store.FSDirectory
-
Create a new FSDirectory for the named location (ctor for subclasses).
- FSDirectory.FSIndexOutput - Class in org.apache.lucene.store
- FSIndexOutput(FSDirectory, String) - Constructor for class org.apache.lucene.store.FSDirectory.FSIndexOutput
- FSLockFactory - Class in org.apache.lucene.store
-
Base class for file system based locking implementation.
- FSLockFactory() - Constructor for class org.apache.lucene.store.FSLockFactory
- fst - Variable in class org.apache.lucene.analysis.synonym.SynonymMap
-
map>
- 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_FILENAME_SUFFIX - Static variable in class org.apache.lucene.analysis.ja.dict.TokenInfoDictionary
- FST.Arc<T> - Class in org.apache.lucene.util.fst
-
Represents a single arc.
- FST.BytesReader - Class in org.apache.lucene.util.fst
-
Reads the bytes from this FST.
- FST.INPUT_TYPE - Enum in org.apache.lucene.util.fst
-
Specifies allowed range of each int input label for this FST.
- FSTCompletion - Class in org.apache.lucene.search.suggest.fst
-
Finite state automata based implementation of "autocomplete" functionality.
- FSTCompletion(FST<Object>) - Constructor for class org.apache.lucene.search.suggest.fst.FSTCompletion
-
Defaults to higher weights first and exact first.
- FSTCompletion(FST<Object>, boolean, boolean) - Constructor for class org.apache.lucene.search.suggest.fst.FSTCompletion
- 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 andInMemorySorter
with a comparator obtained fromBytesRef.getUTF8SortedAsUnicodeComparator()
. - FSTCompletionBuilder(int, BytesRefSorter, int) - Constructor for class org.apache.lucene.search.suggest.fst.FSTCompletionBuilder
- FSTCompletionLookup - Class in org.apache.lucene.search.suggest.fst
-
An adapter from
Lookup
API toFSTCompletion
. - FSTCompletionLookup() - Constructor for class org.apache.lucene.search.suggest.fst.FSTCompletionLookup
-
This constructor prepares for creating a suggested FST using the
FSTCompletionLookup.build(TermFreqIterator)
method. - FSTCompletionLookup(int, boolean) - Constructor for class org.apache.lucene.search.suggest.fst.FSTCompletionLookup
-
This constructor prepares for creating a suggested FST using the
FSTCompletionLookup.build(TermFreqIterator)
method. - FSTCompletionLookup(FSTCompletion, boolean) - Constructor for class org.apache.lucene.search.suggest.fst.FSTCompletionLookup
-
This constructor takes a pre-built automaton.
- FSTLookup - Class in org.apache.lucene.search.suggest.fst
-
Deprecated.Use
FSTCompletionLookup
instead. - FSTLookup() - Constructor for class org.apache.lucene.search.suggest.fst.FSTLookup
-
Deprecated.
- FSTLookup(int, boolean) - Constructor for class org.apache.lucene.search.suggest.fst.FSTLookup
-
Deprecated.
- fsync(String) - Method in class org.apache.lucene.store.FSDirectory
- FT - org.apache.lucene.benchmark.byTask.feeds.TrecDocParser.ParsePathType
- 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
- fullyDelete(File) - Static method in class org.apache.lucene.benchmark.byTask.utils.FileUtils
-
Delete files and directories, even if non-empty.
- function - Variable in class org.apache.lucene.search.payloads.PayloadNearQuery
- function - Variable in class org.apache.lucene.search.payloads.PayloadTermQuery
- FUZZY_CONFIG - Static variable in class org.apache.lucene.queryParser.standard.config.StandardQueryConfigHandler.ConfigurationKeys
-
Key used to set the
FuzzyConfig
used to create fuzzy queries. - FUZZY_SLOP - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
-
RegularExpression Id.
- FUZZY_SLOP - Static variable in interface org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- FuzzyAttribute - Interface in org.apache.lucene.queryParser.standard.config
-
Deprecated.
- FuzzyAttributeImpl - Class in org.apache.lucene.queryParser.standard.config
-
Deprecated.
- FuzzyAttributeImpl() - Constructor for class org.apache.lucene.queryParser.standard.config.FuzzyAttributeImpl
-
Deprecated.
- FuzzyConfig - Class in org.apache.lucene.queryParser.standard.config
- FuzzyConfig() - Constructor for class org.apache.lucene.queryParser.standard.config.FuzzyConfig
- FuzzyLikeThisQuery - Class in org.apache.lucene.search
-
Fuzzifies ALL terms provided as strings and then picks the best n differentiating terms.
- FuzzyLikeThisQuery(int, Analyzer) - Constructor for class org.apache.lucene.search.FuzzyLikeThisQuery
- FuzzyLikeThisQueryBuilder - Class in org.apache.lucene.xmlparser.builders
- FuzzyLikeThisQueryBuilder(Analyzer) - Constructor for class org.apache.lucene.xmlparser.builders.FuzzyLikeThisQueryBuilder
- FuzzyQuery - Class in org.apache.lucene.search
-
Implements the fuzzy search query.
- FuzzyQuery(Term) - Constructor for class org.apache.lucene.search.FuzzyQuery
- FuzzyQuery(Term, float) - Constructor for class org.apache.lucene.search.FuzzyQuery
- FuzzyQuery(Term, float, int) - Constructor for class org.apache.lucene.search.FuzzyQuery
- FuzzyQuery(Term, float, int, int) - Constructor for class org.apache.lucene.search.FuzzyQuery
-
Create a new FuzzyQuery that will match terms with a similarity of at least
minimumSimilarity
toterm
. - FuzzyQueryNode - Class in org.apache.lucene.queryParser.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.core.nodes.FuzzyQueryNode
- FuzzyQueryNodeBuilder - Class in org.apache.lucene.queryParser.standard.builders
-
Builds a
FuzzyQuery
object from aFuzzyQueryNode
object. - FuzzyQueryNodeBuilder() - Constructor for class org.apache.lucene.queryParser.standard.builders.FuzzyQueryNodeBuilder
- FuzzyQueryNodeProcessor - Class in org.apache.lucene.queryParser.standard.processors
-
This processor iterates the query node tree looking for every
FuzzyQueryNode
, when this kind of node is found, it checks on the query configuration forStandardQueryConfigHandler.ConfigurationKeys.FUZZY_CONFIG
, gets the fuzzy prefix length and default similarity from it and set to the fuzzy node. - FuzzyQueryNodeProcessor() - Constructor for class org.apache.lucene.queryParser.standard.processors.FuzzyQueryNodeProcessor
- FuzzyTermEnum - Class in org.apache.lucene.search
-
Subclass of FilteredTermEnum for enumerating all terms that are similar to the specified filter term.
- FuzzyTermEnum(IndexReader, Term) - Constructor for class org.apache.lucene.search.FuzzyTermEnum
-
Creates a FuzzyTermEnum with an empty prefix and a minSimilarity of 0.5f.
- FuzzyTermEnum(IndexReader, Term, float) - Constructor for class org.apache.lucene.search.FuzzyTermEnum
-
Creates a FuzzyTermEnum with an empty prefix.
- FuzzyTermEnum(IndexReader, Term, float, int) - Constructor for class org.apache.lucene.search.FuzzyTermEnum
-
Constructor for enumeration of all terms from specified
reader
which share a prefix of lengthprefixLength
withterm
and which have a fuzzy similarity >minSimilarity
.
G
- GalicianAnalyzer - Class in org.apache.lucene.analysis.gl
-
Analyzer
for Galician. - GalicianAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.gl.GalicianAnalyzer
-
Builds an analyzer with the default stop words:
GalicianAnalyzer.DEFAULT_STOPWORD_FILE
. - GalicianAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.gl.GalicianAnalyzer
-
Builds an analyzer with the given stop words.
- GalicianAnalyzer(Version, Set<?>, Set<?>) - 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
-
A
TokenFilter
that appliesGalicianMinimalStemmer
to stem Galician words. - GalicianMinimalStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.gl.GalicianMinimalStemFilter
- 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
-
A
TokenFilter
that appliesGalicianStemmer
to stem Galician words. - GalicianStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.gl.GalicianStemFilter
- 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
- Gather(IndexReader) - Constructor for class org.apache.lucene.util.ReaderUtil.Gather
- gatherSubReaders(List<IndexReader>, IndexReader) - Method in class org.apache.lucene.search.IndexSearcher
- gatherSubReaders(List<IndexReader>, IndexReader) - Static method in class org.apache.lucene.util.ReaderUtil
-
Gathers sub-readers from reader into a List.
- GB - Static variable in class org.apache.lucene.search.suggest.fst.Sort
- GE - org.apache.lucene.queryParser.core.nodes.ParametricQueryNode.CompareOperator
-
Deprecated.
- GEN_EXTENSION - Static variable in class org.apache.lucene.index.IndexFileNames
-
Extension of gen file
- 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.
- generateParseException() - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParser
-
Generate ParseException.
- generateParseException() - Method in class org.apache.lucene.queryParser.QueryParser
-
Generate ParseException.
- generateParseException() - Method in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParser
-
Generate ParseException.
- generateParseException() - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.
- generateParseException() - Method in class org.apache.lucene.queryParser.surround.parser.QueryParser
-
Generate ParseException.
- generatesCategoryList() - Method in class org.apache.lucene.facet.enhancements.association.AssociationEnhancement
- generatesCategoryList() - Method in interface org.apache.lucene.facet.enhancements.CategoryEnhancement
-
Declarative method to indicate whether this enhancement generates separate category list.
- 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
- GeoHashDistanceFilter - Class in org.apache.lucene.spatial.geohash
-
Deprecated.
- GeoHashDistanceFilter(Filter, double, double, double, String) - Constructor for class org.apache.lucene.spatial.geohash.GeoHashDistanceFilter
-
Deprecated.Provide a distance filter based from a center point with a radius in miles
- GeoHashUtils - Class in org.apache.lucene.spatial.geohash
-
Deprecated.
- Geometry2D - Interface in org.apache.lucene.spatial.geometry.shape
-
Deprecated.
- GERMAN_STOP_WORDS - Static variable in class org.apache.lucene.analysis.de.GermanAnalyzer
-
Deprecated.use
GermanAnalyzer.getDefaultStopSet()
instead - German2Stemmer - Class in org.tartarus.snowball.ext
-
Generated class implementing code defined by a snowball script.
- German2Stemmer() - Constructor for class org.tartarus.snowball.ext.German2Stemmer
- GermanAnalyzer - Class in org.apache.lucene.analysis.de
-
Analyzer
for German language. - GermanAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.de.GermanAnalyzer
-
Builds an analyzer with the default stop words:
GermanAnalyzer.getDefaultStopSet()
. - GermanAnalyzer(Version, File) - Constructor for class org.apache.lucene.analysis.de.GermanAnalyzer
-
Deprecated.
- GermanAnalyzer(Version, String...) - Constructor for class org.apache.lucene.analysis.de.GermanAnalyzer
-
Deprecated.
- GermanAnalyzer(Version, Map<?, ?>) - Constructor for class org.apache.lucene.analysis.de.GermanAnalyzer
-
Deprecated.
- GermanAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.de.GermanAnalyzer
-
Builds an analyzer with the given stop words
- GermanAnalyzer(Version, Set<?>, Set<?>) - 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
-
A
TokenFilter
that appliesGermanLightStemmer
to stem German words. - GermanLightStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.de.GermanLightStemFilter
- 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
-
A
TokenFilter
that appliesGermanMinimalStemmer
to stem German words. - GermanMinimalStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.de.GermanMinimalStemFilter
- 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
-
Normalizes German characters according to the heuristics of the German2 snowball algorithm.
- GermanNormalizationFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.de.GermanNormalizationFilter
- GermanStemFilter - Class in org.apache.lucene.analysis.de
-
A
TokenFilter
that stems German words. - GermanStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.de.GermanStemFilter
-
Creates a
GermanStemFilter
instance - GermanStemFilter(TokenStream, Set<?>) - Constructor for class org.apache.lucene.analysis.de.GermanStemFilter
-
Deprecated.use
KeywordAttribute
withKeywordMarkerFilter
instead. - GermanStemmer - Class in org.apache.lucene.analysis.de
-
A stemmer for German words.
- GermanStemmer - Class in org.tartarus.snowball.ext
-
Generated class implementing code defined by a snowball script.
- GermanStemmer() - Constructor for class org.apache.lucene.analysis.de.GermanStemmer
- GermanStemmer() - Constructor for class org.tartarus.snowball.ext.GermanStemmer
- get() - Static method in class org.apache.lucene.LucenePackage
-
Return Lucene's package, including version information.
- get() - Method in class org.apache.lucene.util.CloseableThreadLocal
- get() - Method in class org.apache.lucene.util.Counter
-
Returns the counters current value
- get() - Method in class org.apache.lucene.util.SetOnce
-
Returns the object set by
SetOnce.set(Object)
. - get(boolean, SegmentInfo, int) - Static method in class org.apache.lucene.index.SegmentReader
- get(boolean, Directory, SegmentInfo, int, boolean, int) - Static method in class org.apache.lucene.index.SegmentReader
- get(char[], int, int) - Method in class org.apache.lucene.analysis.CharArrayMap
-
returns the value of the mapping of
len
chars oftext
starting atoff
- get(float) - Method in class org.apache.lucene.util.collections.FloatToObjectMap
-
Returns the object mapped with the given key.
- 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) - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorPipeline
- get(int) - Method in interface org.apache.lucene.util.Bits
- get(int) - Method in class org.apache.lucene.util.Bits.MatchAllBits
- get(int) - Method in class org.apache.lucene.util.Bits.MatchNoBits
- get(int) - Method in class org.apache.lucene.util.BitVector
-
Returns
true
ifbit
is one andfalse
if it is zero. - get(int) - Method in class org.apache.lucene.util.collections.IntArray
-
Get an element from a specific index.
- get(int) - Method in class org.apache.lucene.util.collections.IntToDoubleMap
-
Returns the value mapped with the given key.
- get(int) - Method in class org.apache.lucene.util.collections.IntToIntMap
-
Returns the object mapped with the given key.
- get(int) - Method in class org.apache.lucene.util.collections.IntToObjectMap
-
Returns the object mapped with the given key.
- get(int) - Method in class org.apache.lucene.util.FixedBitSet
- get(int) - Method in class org.apache.lucene.util.OpenBitSet
-
Returns true or false for the specified bit index.
- get(int) - Method in class org.apache.lucene.util.packed.GrowableWriter
- get(int) - Method in interface org.apache.lucene.util.packed.PackedInts.Reader
- get(int) - Method in class org.apache.lucene.util.RollingBuffer
-
Get T instance for this absolute position; this is allowed to be arbitrarily far "in the future" but cannot be before the last freeBefore.
- get(int) - Method in class org.apache.lucene.util.RollingCharBuffer
- get(int, int) - Method in class org.apache.lucene.analysis.ja.dict.ConnectionCosts
- get(int, int) - Method in class org.apache.lucene.util.RollingCharBuffer
- get(int, BytesRef) - Method in class org.apache.lucene.util.BytesRefHash
-
Populates and returns a
BytesRef
with the bytes for the given ord. - get(long) - Method in class org.apache.lucene.util.fst.UpToTwoPositiveIntOutputs
- get(long) - Method in class org.apache.lucene.util.OpenBitSet
-
Returns true or false for the specified bit index
- get(long, long) - Method in class org.apache.lucene.util.fst.UpToTwoPositiveIntOutputs
- get(Reader) - Static method in class org.apache.lucene.analysis.CharReader
- get(CharSequence) - Method in class org.apache.lucene.analysis.CharArrayMap
-
returns the value of the mapping of the chars inside this
CharSequence
- get(CharSequence) - Method in class org.apache.lucene.search.suggest.fst.FSTCompletionLookup
- get(CharSequence) - Method in class org.apache.lucene.search.suggest.fst.FSTLookup
-
Deprecated.Get the (approximated) weight of a single key (if there is a perfect match for it in the automaton).
- 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
- get(CharSequence) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Retrieve the object indexed by a key.
- get(CharSequence) - Method in class org.apache.lucene.search.suggest.tst.TSTLookup
- get(Object) - Method in class org.apache.lucene.analysis.CharArrayMap
- get(Object) - Method in class org.apache.lucene.util.WeakIdentityMap
- get(String) - Method in class org.apache.lucene.document.Document
-
Returns the string value of the field with the given name if any exist in this document, or null.
- get(String, boolean) - Method in class org.apache.lucene.benchmark.byTask.utils.Config
-
Return a boolean property.
- get(String, double) - Method in class org.apache.lucene.benchmark.byTask.utils.Config
-
Return a double property.
- get(String, int) - Method in class org.apache.lucene.benchmark.byTask.utils.Config
-
Return an int property.
- get(String, String) - Method in class org.apache.lucene.benchmark.byTask.utils.Config
-
Return a string property.
- get(K) - Method in class org.apache.lucene.util.collections.ArrayHashMap
-
Returns the object mapped with the given key, or null if the key wasn't found.
- get(K) - Method in class org.apache.lucene.util.collections.ObjectToFloatMap
-
Returns the float mapped with the given key.
- get(K) - Method in class org.apache.lucene.util.collections.ObjectToIntMap
-
Returns the int mapped with the given key.
- get(K) - Method in class org.apache.lucene.util.DoubleBarrelLRUCache
- get(CategoryListParams) - Method in class org.apache.lucene.facet.search.cache.CategoryListCache
-
Fetch the cached
CategoryListData
for a givenCategoryListParams
. - get(CategoryPath) - Method in class org.apache.lucene.facet.taxonomy.writercache.cl2o.Cl2oTaxonomyWriterCache
- get(CategoryPath) - Method in class org.apache.lucene.facet.taxonomy.writercache.lru.LruTaxonomyWriterCache
- get(CategoryPath) - 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(CategoryPath, int) - Method in class org.apache.lucene.facet.taxonomy.writercache.cl2o.Cl2oTaxonomyWriterCache
- get(CategoryPath, int) - Method in class org.apache.lucene.facet.taxonomy.writercache.cl2o.CollisionMap
- get(CategoryPath, int) - Method in class org.apache.lucene.facet.taxonomy.writercache.lru.LruTaxonomyWriterCache
- get(CategoryPath, int) - Method in interface org.apache.lucene.facet.taxonomy.writercache.TaxonomyWriterCache
-
Like
TaxonomyWriterCache.get(CategoryPath)
, but for a given prefix of the category path. - get(CategoryPath, int, int) - Method in class org.apache.lucene.facet.taxonomy.writercache.cl2o.CollisionMap
- get(ConfigurationKey<T>) - Method in class org.apache.lucene.queryParser.core.config.AbstractQueryConfig
-
Returns the value held by the given key.
- get(ConfigurationKey<T>, T) - Method in class org.apache.lucene.queryParser.core.config.AbstractQueryConfig
-
Returns the value held by the given key or the given default value if the key is not found.
- get(BytesRef, int) - Method in class org.apache.lucene.search.suggest.BytesRefList
-
Returns the n'th element of this
BytesRefList
- get(FST<T>, BytesRef) - Static method in class org.apache.lucene.util.fst.Util
-
Looks up the output for this input, or null if the input is not accepted
- get(FST<T>, IntsRef) - Static method in class org.apache.lucene.util.fst.Util
-
Looks up the output for this input, or null if the input is not accepted.
- getAccuracy() - Method in class org.apache.lucene.search.spell.SpellChecker
-
The accuracy (minimum score) to be used, unless overridden in
SpellChecker.suggestSimilar(String, int, org.apache.lucene.index.IndexReader, String, boolean, float)
, to decide whether a suggestion is included or not. - 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
- getAllCategoryListParams() - Method in class org.apache.lucene.facet.index.params.DefaultFacetIndexingParams
- getAllCategoryListParams() - Method in interface org.apache.lucene.facet.index.params.FacetIndexingParams
-
Return info about all category lists in the index.
- getAllCategoryListParams() - Method in class org.apache.lucene.facet.index.params.PerDimensionIndexingParams
-
Get all the categoryListParams, including the default.
- getAllowLeadingWildcard() - Method in class org.apache.lucene.queryParser.QueryParser
- getAllowLeadingWildcard() - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.
- getAllowLeadingWildcard() - Method in class org.apache.lucene.queryParser.standard.StandardQueryParser
- 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
-
Returns the default analyzer to use for indexing documents.
- getAnalyzer() - Method in class org.apache.lucene.queryParser.QueryParser
- getAnalyzer() - Method in interface org.apache.lucene.queryParser.standard.config.AnalyzerAttribute
-
Deprecated.
- getAnalyzer() - Method in class org.apache.lucene.queryParser.standard.config.AnalyzerAttributeImpl
-
Deprecated.
- getAnalyzer() - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.
- getAnalyzer() - Method in class org.apache.lucene.queryParser.standard.StandardQueryParser
- getAnalyzer() - Method in class org.apache.lucene.search.similar.MoreLikeThis
-
Returns an analyzer that will be used to parse source doc with.
- getAnalyzer() - Method in class org.apache.lucene.search.similar.MoreLikeThisQuery
- getAnalyzer() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexWriter
-
Deprecated.
- getAndClear(int) - Method in class org.apache.lucene.util.FixedBitSet
- getAndIncrement(String) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Retrieve the
Float
indexed by key, increment it by one unit and store the newFloat
. - 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.BitVector
-
Sets the value of
bit
to true, and returns true if bit was already set - getAndSet(int) - Method in class org.apache.lucene.util.FixedBitSet
- getAndSet(int) - Method in class org.apache.lucene.util.OpenBitSet
-
Sets a bit and returns the previous value.
- getAndSet(long) - Method in class org.apache.lucene.util.OpenBitSet
-
Sets a bit and returns the previous value.
- getAnyTokenStream(IndexReader, int, String, Analyzer) - Static method in class org.apache.lucene.search.highlight.TokenSources
-
A convenience method that tries a number of approaches to getting a token stream.
- getAnyTokenStream(IndexReader, int, String, Document, Analyzer) - Static method in class org.apache.lucene.search.highlight.TokenSources
-
A convenience method that tries to first get a TermPositionVector for the specified docId, then, falls back to using the passed in
Document
to retrieve the TokenStream. - getAppend() - Method in class org.apache.lucene.analysis.hunspell.HunspellAffix
-
Returns the append defined for the affix
- getAppendFlags() - Method in class org.apache.lucene.analysis.hunspell.HunspellAffix
-
Returns the flags defined for the affix append
- getArcCount() - Method in class org.apache.lucene.util.fst.FST
- getArcWithOutputCount() - Method in class org.apache.lucene.util.fst.FST
- getArea() - Method in class org.apache.lucene.spatial.tier.Shape
-
Deprecated.
- getArguments() - Method in interface org.apache.lucene.messages.Message
-
Deprecated.
- getArguments() - Method in class org.apache.lucene.messages.MessageImpl
-
Deprecated.
- 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
- getArray() - Method in class org.apache.lucene.util.packed.GrowableWriter
- getArray() - Method in interface org.apache.lucene.util.packed.PackedInts.Reader
-
Expert: if the bit-width of this reader matches one of java's native types, returns the underlying array (ie, byte[], short[], int[], long[]); else, returns null.
- getArray() - Method in class org.apache.lucene.util.packed.PackedInts.ReaderImpl
- getArraysLength() - Method in class org.apache.lucene.facet.search.FacetArrays
-
Return the arrays length
- getAssociatedDocument(int) - Method in class org.apache.lucene.store.instantiated.InstantiatedTerm
-
Navigates to the view of this occurrences of this term in a specific document.
- getAssociatedDocuments() - Method in class org.apache.lucene.store.instantiated.InstantiatedTerm
-
Meta data per document in which this term is occurring.
- getAssociatedOrdinals() - Method in class org.apache.lucene.facet.enhancements.association.AssociationsPayloadIterator
-
Get an iterator over the ordinals which has an association for the document set by
AssociationsPayloadIterator.setNextDoc(int)
. - getAssociation() - Method in class org.apache.lucene.facet.enhancements.association.AssociationProperty
-
Returns the association value.
- getAssociation(int) - Method in class org.apache.lucene.facet.enhancements.association.AssociationsPayloadIterator
-
Get int association value for the given ordinal.
- getAssociationProperty(CategoryAttribute) - Static method in class org.apache.lucene.facet.enhancements.association.AssociationEnhancement
- getAttribute(Class<A>) - Method in class org.apache.lucene.util.AttributeSource
-
The caller must pass in a Class<? extends Attribute> value.
- getAttribute(Element, String, boolean) - Static method in class org.apache.lucene.xmlparser.DOMUtils
- getAttribute(Element, String, float) - Static method in class org.apache.lucene.xmlparser.DOMUtils
- getAttribute(Element, String, int) - Static method in class org.apache.lucene.xmlparser.DOMUtils
- getAttribute(Element, String, String) - Static method in class org.apache.lucene.xmlparser.DOMUtils
- 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.xmlparser.DOMUtils
- getAttributeSource() - Method in class org.apache.lucene.index.FieldInvertState
- getAttributeWithInheritance(Element, String) - Static method in class org.apache.lucene.xmlparser.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.xmlparser.DOMUtils
- getAutoGeneratePhraseQueries() - Method in class org.apache.lucene.queryParser.QueryParser
- getAverageValue() - Method in class org.apache.lucene.search.function.DocValues
-
Returns the average of all values or
Float.NaN
if this DocValues instance does not contain any value. - getAvp() - Method in class org.apache.lucene.benchmark.quality.QualityStats
-
Return the average precision at recall points.
- getBackgroundColorString(float) - Method in class org.apache.lucene.search.highlight.GradientFormatter
- getBackgroundDeltaPriority() - Method in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
- 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
- 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
- getBasicQueryFactory() - Method in class org.apache.lucene.queryParser.surround.query.SpanNearClauseFactory
- getBegin() - Method in class org.apache.lucene.queryParser.core.nodes.FieldQueryNode
- getBegin() - Method in class org.apache.lucene.queryParser.core.nodes.PathQueryNode.QueryText
- getBeginColumn() - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
-
Get token beginning column number.
- getBeginColumn() - Method in interface org.apache.lucene.queryParser.CharStream
-
Returns the column number of the first character for current token (being matched after the last call to BeginTOken).
- getBeginColumn() - Method in exception org.apache.lucene.queryParser.core.QueryNodeParseException
-
For EndOfLine and EndOfFile ("
") 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 class org.apache.lucene.queryParser.FastCharStream
- getBeginColumn() - Method in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
- 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 class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
-
Get token beginning line number.
- getBeginLine() - Method in interface org.apache.lucene.queryParser.CharStream
-
Returns the line number of the first character for current token (being matched after the last call to BeginTOken).
- getBeginLine() - Method in exception org.apache.lucene.queryParser.core.QueryNodeParseException
-
For EndOfLine and EndOfFile ("
") 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 class org.apache.lucene.queryParser.FastCharStream
- getBeginLine() - Method in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
- 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
- getBenchmarkHighlighter(Query) - Method in class org.apache.lucene.benchmark.byTask.tasks.ReadTask
-
Return an appropriate highlighter to be used with highlighting tasks
- getBenchmarkHighlighter(Query) - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchTravRetHighlightTask
- getBenchmarkHighlighter(Query) - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchTravRetVectorHighlightTask
- 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.
- 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.
- getBinaryLength() - Method in class org.apache.lucene.document.AbstractField
-
Returns length of byte[] segment that is used as value, if Field is not binary returned value is undefined
- getBinaryLength() - Method in interface org.apache.lucene.document.Fieldable
-
Returns length of byte[] segment that is used as value, if Field is not binary returned value is undefined
- getBinaryOffset() - Method in class org.apache.lucene.document.AbstractField
-
Returns offset into byte[] segment that is used as value, if Field is not binary returned value is undefined
- getBinaryOffset() - Method in interface org.apache.lucene.document.Fieldable
-
Returns offset into byte[] segment that is used as value, if Field is not binary returned value is undefined
- getBinaryValue() - Method in class org.apache.lucene.document.AbstractField
-
Return the raw byte[] for the binary field.
- getBinaryValue() - Method in interface org.apache.lucene.document.Fieldable
-
Return the raw byte[] for the binary field.
- getBinaryValue(byte[]) - Method in class org.apache.lucene.document.AbstractField
- getBinaryValue(byte[]) - Method in interface org.apache.lucene.document.Fieldable
-
Return the raw byte[] for the binary field.
- getBinaryValue(byte[]) - Method in class org.apache.lucene.document.NumericField
-
Returns always
null
for numeric fields - 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.
- getBit(int) - Method in class org.apache.lucene.util.OpenBitSet
-
returns 1 if the bit is set, 0 if not.
- getBits() - Method in class org.apache.lucene.util.FixedBitSet
-
Expert.
- getBits() - Method in class org.apache.lucene.util.OpenBitSet
-
Expert: returns the long[] storing the bits
- getBitSet() - Method in class org.apache.lucene.util.DocIdBitSet
-
Returns the underlying BitSet.
- getBitsPerValue() - Method in class org.apache.lucene.util.packed.GrowableWriter
- getBitsPerValue() - Method in interface org.apache.lucene.util.packed.PackedInts.Reader
- getBitsPerValue() - Method in class org.apache.lucene.util.packed.PackedInts.ReaderImpl
- getBlockEnds() - Method in class org.apache.lucene.util.PagedBytes.Reader
- getBlocks() - Method in class org.apache.lucene.util.PagedBytes.Reader
- getBody() - Method in class org.apache.lucene.benchmark.byTask.feeds.DocData
- getBooleanQuery(List<BooleanClause>) - Method in class org.apache.lucene.queryParser.QueryParser
-
Factory method for generating query, given a set of clauses.
- getBooleanQuery(List<BooleanClause>, boolean) - Method in class org.apache.lucene.queryParser.QueryParser
-
Factory method for generating query, given a set of clauses.
- getBooleanQuery(List<BooleanClause>, boolean) - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.
- getBoost() - Method in class org.apache.lucene.document.AbstractField
-
Returns the boost factor for hits for this field.
- getBoost() - Method in class org.apache.lucene.document.Document
-
Returns, at indexing time, the boost factor as set by
Document.setBoost(float)
. - getBoost() - Method in interface org.apache.lucene.document.Fieldable
-
Returns the boost factor for hits for this field.
- getBoost() - Method in class org.apache.lucene.index.FieldInvertState
-
Get boost value.
- getBoost() - Method in interface org.apache.lucene.queryParser.standard.config.BoostAttribute
-
Deprecated.
- getBoost() - Method in class org.apache.lucene.queryParser.standard.config.BoostAttributeImpl
-
Deprecated.
- getBoost() - Method in class org.apache.lucene.search.Query
-
Gets the boost for this clause.
- getBoost() - Method in class org.apache.lucene.search.vectorhighlight.FieldQuery.QueryPhraseMap
- getBoostFactor() - Method in class org.apache.lucene.search.similar.MoreLikeThis
-
Returns the boost factor used when boosting terms
- getBottomSlot() - Method in class org.apache.lucene.search.FieldComparator.StringOrdValComparator
- getBoundary(double, double, double) - Static method in class org.apache.lucene.spatial.DistanceUtils
-
Deprecated.
- getBoundingArea(double, double, double) - Method in class org.apache.lucene.spatial.tier.CartesianPolyFilterBuilder
-
Deprecated.
- getBoxShape(double, double, double) - Method in class org.apache.lucene.spatial.tier.CartesianPolyFilterBuilder
-
Deprecated.
- 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.
- 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.facet.search.PayloadIterator
-
Get the buffer with the content of the last read payload.
- getBuffer() - Method in class org.apache.lucene.util.CharacterUtils.CharacterBuffer
-
Returns the internal buffer
- getBuffer(int) - Method in class org.apache.lucene.store.RAMFile
- getBufferSize() - Method in class org.apache.lucene.store.BufferedIndexInput
-
Returns buffer size.
- getByOutput(FST<Long>, long) - Static method in class org.apache.lucene.util.fst.Util
-
Reverse lookup (lookup by output instead of by input), in the special case when your FSTs outputs are strictly ascending.
- getByteBlock() - Method in class org.apache.lucene.util.ByteBlockPool.Allocator
- getByteBlock() - Method in class org.apache.lucene.util.ByteBlockPool.DirectTrackingAllocator
- getByteBlock() - Method in class org.apache.lucene.util.RecyclingByteBlockAllocator
- getBytes(IndexReader, String) - Method in interface org.apache.lucene.search.FieldCache
-
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in
field
as a single byte and returns an array of sizereader.maxDoc()
of the value each document has in the given field. - getBytes(IndexReader, String, FieldCache.ByteParser) - Method in interface org.apache.lucene.search.FieldCache
-
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in
field
as bytes and returns an array of sizereader.maxDoc()
of the value each document has in the given field. - getBytes(IndexReader, String, FieldCache.ByteParser, boolean) - Method in interface org.apache.lucene.search.FieldCache
-
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in
field
as bytes and returns an array of sizereader.maxDoc()
of the value each document has in the given field. - getBytesCount() - Method in class org.apache.lucene.benchmark.byTask.feeds.ContentItemsSource
-
Returns the number of bytes generated since last reset.
- getBytesCount() - Method in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
-
Returns the number of bytes generated by the content source since last reset.
- getByteSize() - Method in class org.apache.lucene.util.SortedVIntList
- getBytesReader(int) - Method in class org.apache.lucene.analysis.ja.dict.TokenInfoFST
- getBytesReader(int) - Method in class org.apache.lucene.util.fst.FST
- getCachedFieldValues(FieldCache, String, IndexReader) - Method in class org.apache.lucene.search.function.ByteFieldSource
- getCachedFieldValues(FieldCache, String, IndexReader) - Method in class org.apache.lucene.search.function.FieldCacheSource
-
Return cached DocValues for input field and reader.
- getCachedFieldValues(FieldCache, String, IndexReader) - Method in class org.apache.lucene.search.function.FloatFieldSource
- getCachedFieldValues(FieldCache, String, IndexReader) - Method in class org.apache.lucene.search.function.IntFieldSource
- getCachedFieldValues(FieldCache, String, IndexReader) - Method in class org.apache.lucene.search.function.ShortFieldSource
- getCacheEntries() - Method in interface org.apache.lucene.search.FieldCache
-
EXPERT: Generates an array of CacheEntry objects representing all items currently in the FieldCache.
- getCacheEntries() - Method in class org.apache.lucene.util.FieldCacheSanityChecker.Insanity
-
CacheEntry objects which suggest a problem
- getCacheMemoryUsage() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
-
Returns the number of memory bytes used by the cache.
- getCacheSize() - Method in class org.apache.lucene.facet.search.TotalFacetCountsCache
- getCacheType() - Method in class org.apache.lucene.search.FieldCache.CacheEntry
- getCalibrateSizeByDeletes() - Method in class org.apache.lucene.index.LogMergePolicy
-
Returns true if the segment size should be calibrated by the number of deletes when choosing segments for merge.
- getCategoryAttribute(CategoryPath) - Method in class org.apache.lucene.facet.index.CategoryContainer
-
Get the
CategoryAttribute
this container has for a certain category, ornull
if the category is not in the container. - getCategoryData(CategoryEnhancement) - Method in class org.apache.lucene.facet.enhancements.EnhancementsPayloadIterator
-
Get the data of the current category and document for a certain enhancement, or
null
if no such enhancement exists. - getCategoryEnhancements() - Method in class org.apache.lucene.facet.enhancements.params.DefaultEnhancementsIndexingParams
- getCategoryEnhancements() - Method in interface org.apache.lucene.facet.enhancements.params.EnhancementsIndexingParams
-
Get a list of the active category enhancements.
- getCategoryListMap(FacetArrays, int) - Method in class org.apache.lucene.facet.search.StandardFacetsAccumulator
- getCategoryListParams(CategoryPath) - Method in class org.apache.lucene.facet.index.params.DefaultFacetIndexingParams
- getCategoryListParams(CategoryPath) - Method in interface org.apache.lucene.facet.index.params.FacetIndexingParams
-
The name of the category-list to put this category in, or null if this category should not be aggregatable.
- getCategoryListParams(CategoryPath) - Method in class org.apache.lucene.facet.index.params.PerDimensionIndexingParams
-
Get the CategoryListParams based on the dimension or "zero-th category" of the specified CategoryPath.
- getCategoryListTermText() - Method in class org.apache.lucene.facet.enhancements.association.AssociationEnhancement
- getCategoryListTermText() - Method in interface org.apache.lucene.facet.enhancements.CategoryEnhancement
-
Returns the text of this enhancement's category list term.
- getCategoryListTokenizer(TokenStream) - Method in class org.apache.lucene.facet.enhancements.EnhancementsDocumentBuilder
- getCategoryListTokenizer(TokenStream) - Method in class org.apache.lucene.facet.index.CategoryDocumentBuilder
-
Get a category list tokenizer (or a series of such tokenizers) to create the category list tokens.
- getCategoryListTokenizer(TokenStream, EnhancementsIndexingParams, TaxonomyWriter) - Method in class org.apache.lucene.facet.enhancements.association.AssociationEnhancement
- getCategoryListTokenizer(TokenStream, EnhancementsIndexingParams, TaxonomyWriter) - Method in interface org.apache.lucene.facet.enhancements.CategoryEnhancement
-
Get the
CategoryListTokenizer
which generates the category list for this enhancement. - getCategoryPath() - Method in interface org.apache.lucene.facet.index.attributes.CategoryAttribute
-
Returns the value of this attribute: a category path.
- getCategoryPath() - Method in class org.apache.lucene.facet.index.attributes.CategoryAttributeImpl
-
Returns the category path value.
- getCategoryPath() - Method in class org.apache.lucene.facet.search.params.FacetRequest
-
The root category of this facet request.
- getCategoryTokenBytes(CategoryAttribute) - Method in class org.apache.lucene.facet.enhancements.association.AssociationEnhancement
- getCategoryTokenBytes(CategoryAttribute) - Method in interface org.apache.lucene.facet.enhancements.CategoryEnhancement
-
Get the bytes to be added to the category token payload for this enhancement.
- getCategoryTokenizer(TokenStream) - Method in class org.apache.lucene.facet.enhancements.EnhancementsDocumentBuilder
- getCategoryTokenizer(TokenStream) - Method in class org.apache.lucene.facet.index.CategoryDocumentBuilder
-
Get a
CategoryTokenizer
to create the category tokens. - 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
- getCharacterClass(char) - Method in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
- getCharacterDefinition() - Method in class org.apache.lucene.analysis.ja.dict.UnknownDictionary
- 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.MockDirectoryWrapper
- getChecksum() - Method in class org.apache.lucene.store.ChecksumIndexInput
- getChecksum() - Method in class org.apache.lucene.store.ChecksumIndexOutput
- getChild() - Method in class org.apache.lucene.queryParser.core.nodes.BoostQueryNode
-
Returns the single child which this node boosts.
- getChild() - Method in class org.apache.lucene.queryParser.core.nodes.GroupQueryNode
- getChild() - Method in class org.apache.lucene.queryParser.core.nodes.ModifierQueryNode
- getChild() - Method in class org.apache.lucene.queryParser.core.nodes.PhraseSlopQueryNode
- getChild() - Method in class org.apache.lucene.queryParser.core.nodes.SlopQueryNode
- getChildByTagName(Element, String) - Static method in class org.apache.lucene.xmlparser.DOMUtils
- getChildByTagOrFail(Element, String) - Static method in class org.apache.lucene.xmlparser.DOMUtils
- getChildren() - Method in interface org.apache.lucene.queryParser.core.nodes.QueryNode
-
get Children nodes
- getChildren() - Method in class org.apache.lucene.queryParser.core.nodes.QueryNodeImpl
- getChildrenArrays() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyReader
- getChildrenArrays() - Method in interface org.apache.lucene.facet.taxonomy.TaxonomyReader
-
getChildrenArrays() returns a
TaxonomyReader.ChildrenArrays
object which can be used together to efficiently enumerate the children of any category. - getChildTextByTagName(Element, String) - Static method in class org.apache.lucene.xmlparser.DOMUtils
- getClassResource(Class<?>, String) - Static method in class org.apache.lucene.analysis.ja.dict.BinaryDictionary
- getClauses() - Method in class org.apache.lucene.search.BooleanQuery
-
Returns the set of clauses in this query.
- getClauses() - Method in class org.apache.lucene.search.spans.SpanNearQuery
-
Return the clauses whose spans are matched.
- getClauses() - Method in class org.apache.lucene.search.spans.SpanOrQuery
-
Return the clauses whose spans are matched.
- getClCache() - Method in class org.apache.lucene.facet.search.params.FacetSearchParams
- 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
- getCollator() - Method in class org.apache.lucene.queryParser.standard.nodes.RangeQueryNode
-
Deprecated.
- getCollator() - Method in class org.apache.lucene.search.TermRangeFilter
-
Returns the collator used to determine range inclusion, if any.
- getCollator() - Method in class org.apache.lucene.search.TermRangeQuery
-
Returns the collator used to determine range inclusion, if any.
- getCollectedGroupHeads() - Method in class org.apache.lucene.search.grouping.AbstractAllGroupHeadsCollector
-
Returns the collected group heads.
- 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 class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.Matrix.Column.Row
-
Deprecated.
- getColumn() - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
-
Deprecated.
- getColumn() - Method in interface org.apache.lucene.queryParser.CharStream
-
Deprecated.
- getColumn() - Method in class org.apache.lucene.queryParser.FastCharStream
- getColumn() - Method in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
-
Deprecated.
- getColumn() - Method in interface org.apache.lucene.queryParser.surround.parser.CharStream
-
Deprecated.
- getColumn() - Method in class org.apache.lucene.queryParser.surround.parser.FastCharStream
- getColumns() - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.Matrix
-
Deprecated.
- getCommitUserData() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyReader
- getCommitUserData() - Method in interface org.apache.lucene.facet.taxonomy.TaxonomyReader
-
Retrieve user committed data.
- getCommitUserData() - Method in class org.apache.lucene.index.FilterIndexReader
- getCommitUserData() - Method in class org.apache.lucene.index.IndexReader
-
Deprecated.Call
IndexReader.getIndexCommit()
and then callIndexCommit.getUserData()
. - getCommitUserData(Directory) - Static method in class org.apache.lucene.index.IndexReader
-
Deprecated.Call
IndexReader.getIndexCommit()
on an open IndexReader, and then callIndexCommit.getUserData()
. - getComparator() - Method in class org.apache.lucene.index.FieldSortedTermVectorMapper
- getComparator() - Method in class org.apache.lucene.search.spell.SpellChecker
- getComparator() - Method in class org.apache.lucene.search.spell.TermFreqIterator.TermFreqIteratorWrapper
- getComparator() - Method in class org.apache.lucene.search.suggest.BufferingTermFreqIteratorWrapper
- getComparator() - Method in interface org.apache.lucene.search.suggest.fst.BytesRefSorter
- getComparator() - Method in class org.apache.lucene.search.suggest.fst.ExternalRefSorter
- getComparator() - Method in class org.apache.lucene.search.suggest.fst.InMemorySorter
- getComparator() - Method in class org.apache.lucene.search.suggest.fst.Sort
- getComparator() - Method in class org.apache.lucene.search.suggest.SortedTermFreqIteratorWrapper
- getComparator() - Method in interface org.apache.lucene.util.BytesRefIterator
-
Return the
BytesRef
Comparator used to sort terms provided by the iterator. - getComparator(int, int) - Method in class org.apache.lucene.search.SortField
-
Returns the
FieldComparator
to use for sorting. - getComparators() - Method in class org.apache.lucene.search.FieldValueHitQueue
- getComparatorSource() - Method in class org.apache.lucene.search.SortField
-
Returns the
FieldComparatorSource
used for custom sorting - getComplementSet(ScoredDocIDs, IndexReader) - Static method in class org.apache.lucene.facet.util.ScoredDocIdsUtils
-
Create a complement of the input set.
- getComplementThreshold() - Method in class org.apache.lucene.facet.search.FacetsAccumulator
- getComplementThreshold() - Method in class org.apache.lucene.facet.search.SamplingWrapper
- getComponent(int) - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
-
Return the i'th component of the path, in a new String object.
- getCondition() - Method in class org.apache.lucene.analysis.hunspell.HunspellAffix
-
Returns the condition that must be met before the affix can be applied
- 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 the private
IndexWriterConfig
, cloned from theIndexWriterConfig
passed toIndexWriter(Directory, IndexWriterConfig)
. - getCoreCacheKey() - Method in class org.apache.lucene.index.FilterIndexReader
-
If the subclass of FilteredIndexReader modifies the contents of the FieldCache, you must override this method to provide a different key
- getCoreCacheKey() - Method in class org.apache.lucene.index.IndexReader
-
Expert
- getCoreCacheKey() - Method in class org.apache.lucene.index.SegmentReader
- getCount() - Method in class org.apache.lucene.benchmark.byTask.feeds.DirContentSource.Iterator
- getCount() - Method in class org.apache.lucene.benchmark.byTask.stats.TaskStats
- getCountingListTokenizer(TokenStream) - Method in class org.apache.lucene.facet.index.CategoryDocumentBuilder
-
Get a
CountingListTokenizer
for creating counting list token. - getCountsByTime() - Method in class org.apache.lucene.benchmark.byTask.stats.TaskStats
- getCountsByTimeStepMSec() - Method in class org.apache.lucene.benchmark.byTask.stats.TaskStats
- 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
-
Get the valid length of the character array in
SnowballProgram.getCurrentBuffer()
. - getCurrentLabel() - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
- getCurrentLabel() - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
- getCurrentMerge() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler.MergeThread
- getCurrentSearcher() - Method in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
- getCurrentSearchingGen() - Method in class org.apache.lucene.search.NRTManager
-
Returns generation of current searcher.
- getCurrentStats() - Method in class org.apache.lucene.benchmark.byTask.stats.Points
- getCurrentVersion(Directory) - Static method in class org.apache.lucene.index.IndexReader
-
Deprecated.Use
IndexReader.getVersion()
on an opened IndexReader. - getCustom() - Method in class org.apache.lucene.search.FieldCache.CacheEntry
- getCustomScoreProvider(IndexReader) - Method in class org.apache.lucene.search.function.CustomScoreQuery
-
Returns a
CustomScoreProvider
that calculates the custom scores for the givenIndexReader
. - getData() - Method in class org.apache.lucene.index.Payload
-
Returns a reference to the underlying byte array that holds this payloads data.
- getDataFile(String) - Method in class org.apache.lucene.util.LuceneTestCase
-
Gets a resource from the classpath as
File
. - getDataInput() - Method in class org.apache.lucene.util.PagedBytes
-
Returns a DataInput to read values from this PagedBytes instance.
- getDataOutput() - Method in class org.apache.lucene.util.PagedBytes
-
Returns a DataOutput that you may use to write into this PagedBytes instance.
- getDataType() - Method in class org.apache.lucene.document.NumericField
-
Returns the data type of the current value,
null
if not yet set. - getDate() - Method in class org.apache.lucene.benchmark.byTask.feeds.DocData
- getDateResolution() - Method in interface org.apache.lucene.queryParser.standard.config.DateResolutionAttribute
-
Deprecated.
- getDateResolution() - Method in class org.apache.lucene.queryParser.standard.config.DateResolutionAttributeImpl
-
Deprecated.
- getDateResolution() - Method in class org.apache.lucene.queryParser.standard.StandardQueryParser
-
Returns the default
DateTools.Resolution
used for certain field when noDateTools.Resolution
is defined for this field. - getDateResolution(String) - Method in class org.apache.lucene.queryParser.QueryParser
-
Returns the date resolution that is used by RangeQueries for the given field.
- getDateResolution(String) - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.
- getDateResolutionMap() - Method in class org.apache.lucene.queryParser.standard.StandardQueryParser
-
Returns the field to
DateTools.Resolution
map used to normalize each date field. - getDecodedLength(char[], int, int) - Static method in class org.apache.lucene.util.IndexableBinaryStringTools
-
Returns the number of bytes required to decode the given char sequence.
- getDecodedLength(CharBuffer) - Static method in class org.apache.lucene.util.IndexableBinaryStringTools
-
Deprecated.Use
IndexableBinaryStringTools.getDecodedLength(char[], int, int)
instead. This method will be removed in Lucene 4.0 - getDecodingReader(File, Charset) - Static method in class org.apache.lucene.util.IOUtils
-
Opens a Reader for the given
File
using aCharsetDecoder
. - getDecodingReader(InputStream, Charset) - Static method in class org.apache.lucene.util.IOUtils
-
Wrapping the given
InputStream
in a reader using aCharsetDecoder
. - getDecodingReader(Class<?>, String, Charset) - Static method in class org.apache.lucene.util.IOUtils
-
Opens a Reader for the given resource using a
CharsetDecoder
. - getDefault() - Static method in class org.apache.lucene.search.Similarity
-
Return the default Similarity implementation used by indexing and search code.
- getDefaultGenLookahedCount() - Static method in class org.apache.lucene.index.SegmentInfos
- getDefaultInfoStream() - Static method in class org.apache.lucene.index.IndexWriter
-
Returns the current default infoStream for newly instantiated IndexWriters.
- getDefaultOperator() - Method in class org.apache.lucene.queryParser.QueryParser
-
Gets implicit operator setting, which will be either AND_OPERATOR or OR_OPERATOR.
- getDefaultOperator() - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.
- getDefaultOperator() - Method in class org.apache.lucene.queryParser.standard.StandardQueryParser
-
Gets implicit operator setting, which will be either
StandardQueryConfigHandler.Operator.AND
orStandardQueryConfigHandler.Operator.OR
. - getDefaultPhraseSlop() - Method in interface org.apache.lucene.queryParser.standard.config.DefaultPhraseSlopAttribute
-
Deprecated.
- getDefaultPhraseSlop() - Method in class org.apache.lucene.queryParser.standard.config.DefaultPhraseSlopAttributeImpl
-
Deprecated.
- getDefaultScore() - Method in class org.apache.lucene.facet.search.ScoredDocIdCollector
-
Returns the default score used when scoring is disabled.
- 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.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.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.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.
- getDefaultStopTags() - Static method in class org.apache.lucene.analysis.ja.JapaneseAnalyzer
- getDefaultWriteLockTimeout() - Static method in class org.apache.lucene.index.IndexWriter
-
Deprecated.use
IndexWriterConfig.getDefaultWriteLockTimeout()
instead - getDefaultWriteLockTimeout() - Static method in class org.apache.lucene.index.IndexWriterConfig
-
Returns the default write lock timeout for newly instantiated IndexWriterConfigs.
- getDelay(boolean) - Method in class org.apache.lucene.util.ThrottledIndexOutput
- getDelCount() - Method in class org.apache.lucene.index.SegmentInfo
- getDeletedDocuments() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndex
-
Deprecated.
- getDeletesCacheKey() - Method in class org.apache.lucene.index.FilterIndexReader
-
If the subclass of FilteredIndexReader modifies the deleted docs, you must override this method to provide a different key
- getDeletesCacheKey() - Method in class org.apache.lucene.index.IndexReader
-
Expert.
- getDeletesCacheKey() - Method in class org.apache.lucene.index.SegmentReader
- getDelFileName() - Method in class org.apache.lucene.index.SegmentInfo
- getDepth() - Method in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
- getDepth() - Method in class org.apache.lucene.facet.search.params.FacetRequest
-
How deeply to look under the given category.
- getDescription() - Method in class org.apache.lucene.search.Explanation
-
A description of this explanation node.
- getDetails() - Method in class org.apache.lucene.search.Explanation
-
The sub-nodes of this explanation node.
- getDiagnostics() - Method in class org.apache.lucene.index.SegmentInfo
- getDirectory() - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
- getDirectory() - Method in class org.apache.lucene.index.CompoundFileWriter
-
Returns the directory of the compound file.
- getDirectory() - Method in class org.apache.lucene.index.IndexCommit
-
Returns the
Directory
for the index. - getDirectory() - Method in class org.apache.lucene.index.IndexWriter
-
Returns the Directory used by this index.
- getDirectory() - Method in exception org.apache.lucene.index.MergePolicy.MergeException
-
Returns the
Directory
of the index that hit the exception. - getDirectory() - Method in class org.apache.lucene.index.SnapshotDeletionPolicy.SnapshotCommitPoint
- getDirectory() - Method in class org.apache.lucene.store.FSDirectory
- getDirectory(Directory) - Method in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
- getDirProcessor(Directory) - Method in class org.apache.lucene.index.PayloadProcessorProvider
-
Deprecated.Use
PayloadProcessorProvider.getReaderProcessor(org.apache.lucene.index.IndexReader)
instead. You can still select byDirectory
, if you retrieve the underlying directory fromIndexReader.directory()
. - getDiscountOverlaps() - Method in class org.apache.lucene.search.DefaultSimilarity
- getDistance() - Method in class org.apache.lucene.queryParser.core.nodes.ProximityQueryNode
- getDistance(int) - Method in class org.apache.lucene.spatial.tier.DistanceFilter
-
Deprecated.
- getDistance(int, double, double, double, double) - Method in class org.apache.lucene.spatial.tier.DistanceHandler
-
Deprecated.
- getDistance(String, String) - Method in class org.apache.lucene.search.spell.JaroWinklerDistance
- getDistance(String, String) - Method in class org.apache.lucene.search.spell.LevensteinDistance
- 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.
- getDistanceFilter() - Method in class org.apache.lucene.spatial.tier.DistanceQueryBuilder
-
Deprecated.
- getDistanceMi(double, double, double, double) - Static method in class org.apache.lucene.spatial.DistanceUtils
-
Deprecated.
- getDistanceQuery(List<SrndQuery>, boolean, Token, boolean) - Method in class org.apache.lucene.queryParser.surround.parser.QueryParser
- getDistances() - Method in class org.apache.lucene.spatial.tier.DistanceFilter
-
Deprecated.
- getDistanceSq(double, double) - Method in class org.apache.lucene.spatial.geometry.shape.DistanceApproximation
-
Deprecated.
- getDistanceSq(double, double, double, double) - Method in class org.apache.lucene.spatial.geometry.shape.DistanceApproximation
-
Deprecated.
- getDoc() - Method in class org.apache.lucene.search.SpanFilterResult.PositionInfo
- getDocGroupValue(int) - Method in class org.apache.lucene.search.grouping.AbstractFirstPassGroupingCollector
-
Returns the group value for the specified doc.
- getDocGroupValue(int) - Method in class org.apache.lucene.search.grouping.TermFirstPassGroupingCollector
- getDocID() - Method in interface org.apache.lucene.facet.search.ScoredDocIDsIterator
-
Returns the ID of the current document.
- getDocIDs() - Method in interface org.apache.lucene.facet.search.ScoredDocIDs
-
Returns the set of doc IDs.
- getDocIdSet() - Method in class org.apache.lucene.search.SpanFilterResult
-
Returns the docIdSet
- getDocIdSet(IndexReader) - Method in class org.apache.lucene.search.BooleanFilter
-
Returns the a DocIdSetIterator representing the Boolean composition of the filters that have been added.
- getDocIdSet(IndexReader) - Method in class org.apache.lucene.search.CachingSpanFilter
- getDocIdSet(IndexReader) - Method in class org.apache.lucene.search.CachingWrapperFilter
- getDocIdSet(IndexReader) - Method in class org.apache.lucene.search.CachingWrapperFilterHelper
- getDocIdSet(IndexReader) - Method in class org.apache.lucene.search.ChainedFilter
- getDocIdSet(IndexReader) - Method in class org.apache.lucene.search.DuplicateFilter
- getDocIdSet(IndexReader) - Method in class org.apache.lucene.search.FieldCacheRangeFilter
-
This method is implemented for each data type
- getDocIdSet(IndexReader) - Method in class org.apache.lucene.search.FieldCacheTermsFilter
- getDocIdSet(IndexReader) - Method in class org.apache.lucene.search.FieldValueFilter
- getDocIdSet(IndexReader) - Method in class org.apache.lucene.search.Filter
-
Creates a
DocIdSet
enumerating the documents that should be permitted in search results. - getDocIdSet(IndexReader) - Method in class org.apache.lucene.search.join.RawTermFilter
- getDocIdSet(IndexReader) - Method in class org.apache.lucene.search.MultiTermQueryWrapperFilter
-
Returns a DocIdSet with documents that should be permitted in search results.
- getDocIdSet(IndexReader) - Method in class org.apache.lucene.search.QueryWrapperFilter
- getDocIdSet(IndexReader) - Method in class org.apache.lucene.search.RemoteCachingWrapperFilter
-
Deprecated.Uses the
FilterManager
to keep the cache for a filter on the searcher side of a remote connection. - getDocIdSet(IndexReader) - Method in class org.apache.lucene.search.SpanQueryFilter
- getDocIdSet(IndexReader) - Method in class org.apache.lucene.search.TermsFilter
- getDocIdSet(IndexReader) - Method in class org.apache.lucene.spatial.geohash.GeoHashDistanceFilter
-
Deprecated.
- getDocIdSet(IndexReader) - Method in class org.apache.lucene.spatial.tier.CartesianShapeFilter
-
Deprecated.
- getDocIdSet(IndexReader) - Method in class org.apache.lucene.spatial.tier.LatLongDistanceFilter
-
Deprecated.
- 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
- getDocStoreIsCompoundFile() - Method in class org.apache.lucene.index.SegmentInfo
- getDocStoreOffset() - Method in class org.apache.lucene.index.SegmentInfo
- getDocStoreSegment() - Method in class org.apache.lucene.index.SegmentInfo
- getDocsWithField(IndexReader, String) - Method in interface org.apache.lucene.search.FieldCache
-
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in
field
and returns a bit set at the size ofreader.maxDoc()
, with turned on bits for each docid that does have a value for this field. - getDocument() - Method in class org.apache.lucene.store.instantiated.InstantiatedDocument
- getDocument() - Method in class org.apache.lucene.store.instantiated.InstantiatedTermDocumentInformation
- getDocumentNumber() - Method in class org.apache.lucene.store.instantiated.InstantiatedDocument
- getDocumentsByNumber() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndex
-
Deprecated.
- getDoubles(IndexReader, String) - Method in interface org.apache.lucene.search.FieldCache
-
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in
field
as integers and returns an array of sizereader.maxDoc()
of the value each document has in the given field. - getDoubles(IndexReader, String, FieldCache.DoubleParser) - Method in interface org.apache.lucene.search.FieldCache
-
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in
field
as doubles and returns an array of sizereader.maxDoc()
of the value each document has in the given field. - getDoubles(IndexReader, String, FieldCache.DoubleParser, boolean) - Method in interface org.apache.lucene.search.FieldCache
-
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in
field
as doubles and returns an array of sizereader.maxDoc()
of the value each document has in the given field. - getElapsed() - Method in class org.apache.lucene.benchmark.byTask.stats.TaskStats
- getEmptyOutput() - Method in class org.apache.lucene.util.fst.FST
- getEnablePositionIncrements() - Method in class org.apache.lucene.analysis.FilteringTokenFilter
- getEnablePositionIncrements() - Method in class org.apache.lucene.queryParser.QueryParser
- getEnablePositionIncrements() - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.
- getEnablePositionIncrements() - Method in class org.apache.lucene.queryParser.standard.StandardQueryParser
- getEnablePositionIncrementsVersionDefault(Version) - Static method in class org.apache.lucene.analysis.StopFilter
-
Deprecated.use
StopFilter(Version, TokenStream, Set)
instead - getEncodedLength(byte[], int, int) - Static method in class org.apache.lucene.util.IndexableBinaryStringTools
-
Returns the number of chars required to encode the given bytes.
- getEncodedLength(ByteBuffer) - Static method in class org.apache.lucene.util.IndexableBinaryStringTools
-
Deprecated.Use
IndexableBinaryStringTools.getEncodedLength(byte[], int, int)
instead. This method will be removed in Lucene 4.0 - getEncoder() - Method in class org.apache.lucene.search.highlight.Highlighter
- getEnd() - Method in class org.apache.lucene.queryParser.core.nodes.FieldQueryNode
- getEnd() - Method in class org.apache.lucene.queryParser.core.nodes.PathQueryNode.QueryText
- getEnd() - Method in class org.apache.lucene.search.SpanFilterResult.StartEnd
- getEnd() - Method in class org.apache.lucene.search.spans.SpanPositionRangeQuery
- getEndColumn() - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
-
Get token end column number.
- getEndColumn() - Method in interface org.apache.lucene.queryParser.CharStream
-
Returns the column number of the last character for current token (being matched after the last call to BeginTOken).
- getEndColumn() - Method in class org.apache.lucene.queryParser.FastCharStream
- getEndColumn() - Method in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
-
Get end column.
- 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 class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
-
Get token end line number.
- getEndLine() - Method in interface org.apache.lucene.queryParser.CharStream
-
Returns the line number of the last character for current token (being matched after the last call to BeginTOken).
- getEndLine() - Method in class org.apache.lucene.queryParser.FastCharStream
- getEndLine() - Method in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
-
Get end line.
- 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.index.TermVectorOffsetInfo
-
The accessor for the ending offset for the term
- getEndOffset() - Method in class org.apache.lucene.search.highlight.TokenGroup
- 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
- getEntityResolver() - Method in class org.apache.lucene.xmlparser.CoreParser
-
Returns a SAX
EntityResolver
to be used byDocumentBuilder
. - getEnum(IndexReader) - Method in class org.apache.lucene.search.FuzzyQuery
- getEnum(IndexReader) - Method in class org.apache.lucene.search.MultiTermQuery
-
Construct the enumeration to be used, expanding the pattern term.
- getEnum(IndexReader) - Method in class org.apache.lucene.search.NumericRangeQuery
- getEnum(IndexReader) - Method in class org.apache.lucene.search.PrefixQuery
- getEnum(IndexReader) - Method in class org.apache.lucene.search.regex.RegexQuery
- getEnum(IndexReader) - Method in class org.apache.lucene.search.TermRangeQuery
- getEnum(IndexReader) - Method in class org.apache.lucene.search.WildcardQuery
- getErrorHandler() - Method in class org.apache.lucene.xmlparser.CoreParser
-
Subclass and override to return a SAX
ErrorHandler
to be used byDocumentBuilder
. - getErrorToken() - Method in exception org.apache.lucene.queryParser.core.QueryNodeParseException
- getEstimatedSize() - Method in class org.apache.lucene.search.FieldCache.CacheEntry
-
The most recently estimated size of the value, null unless estimateSize has been called.
- 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
- getExtension(String) - Method in class org.apache.lucene.queryParser.ext.Extensions
-
Returns the
ParserExtension
instance for the given key ornull
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
- getFacetDelimChar() - Method in class org.apache.lucene.facet.index.params.DefaultFacetIndexingParams
-
Use
DefaultFacetIndexingParams.DEFAULT_FACET_DELIM_CHAR
as the delimiter. - getFacetDelimChar() - Method in interface org.apache.lucene.facet.index.params.FacetIndexingParams
-
Get the delimiter character used internally for drill-down terms
- getFacetIndexingParams() - Method in class org.apache.lucene.facet.search.params.FacetSearchParams
-
A list of
FacetRequest
objects, determining what to count. - getFacetRequest() - Method in class org.apache.lucene.facet.search.FacetResultsHandler
-
Return the facet request served by this handler.
- getFacetRequest() - Method in class org.apache.lucene.facet.search.results.FacetResult
-
Request for which this result was obtained.
- getFacetRequest() - Method in interface org.apache.lucene.facet.search.results.IntermediateFacetResult
-
Facet request for which this temporary result was created.
- getFacetRequest() - Method in class org.apache.lucene.facet.search.TopKInEachNodeHandler.IntermediateFacetResultWithHash
- getFacetRequests() - Method in class org.apache.lucene.facet.search.params.FacetSearchParams
-
Parameters which controlled the indexing of facets, and which are also needed during search.
- getFacetResultNode() - Method in class org.apache.lucene.facet.search.results.FacetResult
-
Facet result node matching the root of the
facet request
. - getFacetResults() - Method in class org.apache.lucene.facet.search.FacetsCollector
-
Return accumulated facets results (according to faceted search parameters) for collected documents.
- getFacetSource() - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
-
Returns the facet source.
- getField() - Method in interface org.apache.lucene.index.TermFreqVector
-
The
Fieldable
name. - getField() - Method in class org.apache.lucene.index.TermVectorEntry
- getField() - Method in class org.apache.lucene.queryParser.core.config.FieldConfig
-
Returns the field name this configuration represents.
- getField() - Method in class org.apache.lucene.queryParser.core.nodes.AnyQueryNode
-
returns null if the field was not specified
- getField() - Method in interface org.apache.lucene.queryParser.core.nodes.FieldableNode
-
Returns the field associated to the node and every node under it.
- getField() - Method in class org.apache.lucene.queryParser.core.nodes.FieldQueryNode
- getField() - Method in class org.apache.lucene.queryParser.core.nodes.ParametricRangeQueryNode
- getField() - Method in class org.apache.lucene.queryParser.core.nodes.PhraseSlopQueryNode
- getField() - Method in class org.apache.lucene.queryParser.core.nodes.ProximityQueryNode
-
returns null if the field was not specified in the query string
- getField() - Method in class org.apache.lucene.queryParser.core.nodes.SlopQueryNode
- getField() - Method in class org.apache.lucene.queryParser.core.nodes.TokenizedPhraseQueryNode
- getField() - Method in class org.apache.lucene.queryParser.ext.ExtensionQuery
-
Returns the query field
- getField() - Method in class org.apache.lucene.queryParser.QueryParser
- getField() - Method in class org.apache.lucene.queryParser.standard.nodes.AbstractRangeQueryNode
-
Returns the field associated with this node.
- getField() - Method in class org.apache.lucene.queryParser.standard.nodes.MultiPhraseQueryNode
- getField() - Method in class org.apache.lucene.queryParser.standard.nodes.NumericQueryNode
-
Returns the field associated with this node.
- getField() - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.
- getField() - Method in class org.apache.lucene.search.FieldCacheRangeFilter
-
Returns the field name for this filter
- getField() - Method in class org.apache.lucene.search.FieldComparator.StringOrdValComparator
- getField() - Method in class org.apache.lucene.search.NumericRangeFilter
-
Returns the field name for this filter
- getField() - Method in class org.apache.lucene.search.NumericRangeQuery
-
Returns the field name for this query
- getField() - Method in class org.apache.lucene.search.QueryTermVector
- getField() - Method in class org.apache.lucene.search.SortField
-
Returns the name of the field.
- getField() - Method in class org.apache.lucene.search.spans.FieldMaskingSpanQuery
- getField() - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper
- getField() - Method in class org.apache.lucene.search.spans.SpanNearQuery
- getField() - Method in class org.apache.lucene.search.spans.SpanNotQuery
- getField() - Method in class org.apache.lucene.search.spans.SpanOrQuery
- getField() - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery
- getField() - Method in class org.apache.lucene.search.spans.SpanQuery
-
Returns the name of the field matched by this query.
- getField() - Method in class org.apache.lucene.search.spans.SpanTermQuery
- getField() - Method in class org.apache.lucene.search.TermRangeFilter
-
Returns the field name for this filter
- getField() - Method in class org.apache.lucene.search.TermRangeQuery
-
Returns the field name for this query
- getField() - Method in class org.apache.lucene.store.instantiated.InstantiatedTermFreqVector
- getField(String) - Method in class org.apache.lucene.document.Document
-
Deprecated.use
Document.getFieldable(java.lang.String)
instead and cast depending on data type. - getFieldable(String) - Method in class org.apache.lucene.document.Document
-
Returns a field with the given name if any exist in this document, or null.
- getFieldables(String) - Method in class org.apache.lucene.document.Document
-
Returns an array of
Fieldable
s with the given name. - getFieldAsString() - Method in class org.apache.lucene.queryParser.core.nodes.AnyQueryNode
-
returns - null if the field was not specified
- getFieldAsString() - Method in class org.apache.lucene.queryParser.core.nodes.FieldQueryNode
-
returns null if the field was not specified in the query string
- getFieldAsString() - Method in class org.apache.lucene.queryParser.core.nodes.ProximityQueryNode
-
returns null if the field was not specified in the query string
- getFieldBoostMap() - Method in interface org.apache.lucene.queryParser.standard.config.FieldBoostMapAttribute
-
Deprecated.
- getFieldBoostMap() - Method in class org.apache.lucene.queryParser.standard.config.FieldBoostMapAttributeImpl
-
Deprecated.
- getFieldCache() - Method in class org.apache.lucene.search.FieldCacheTermsFilter
- getFieldConfig(CharSequence) - Method in class org.apache.lucene.queryParser.core.config.QueryConfigHandler
-
Deprecated.use
QueryConfigHandler.getFieldConfig(String)
instead - getFieldConfig(String) - Method in class org.apache.lucene.queryParser.core.config.QueryConfigHandler
-
Returns an implementation of
FieldConfig
for a specific field name. - getFieldDateResolutionMap() - Method in interface org.apache.lucene.queryParser.standard.config.FieldDateResolutionMapAttribute
-
Deprecated.
- getFieldDateResolutionMap() - Method in class org.apache.lucene.queryParser.standard.config.FieldDateResolutionMapAttributeImpl
-
Deprecated.
- getFieldInfos() - Method in class org.apache.lucene.index.FilterIndexReader
- getFieldInfos() - Method in class org.apache.lucene.index.IndexReader
-
Get the
FieldInfos
describing all fields in this reader. - getFieldInfos() - Method in class org.apache.lucene.index.MultiReader
- getFieldInfos() - Method in class org.apache.lucene.index.ParallelReader
- getFieldInfos() - Method in class org.apache.lucene.index.PruningReader
-
Applies a
StorePruningPolicy
to the list of available field infos. - getFieldInfos() - Method in class org.apache.lucene.index.SegmentReader
- getFieldInfos() - Method in class org.apache.lucene.index.SlowMultiReaderWrapper
- getFieldInfos() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndex
-
Deprecated.
- getFieldInfos() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexReader
-
Deprecated.
- getFieldInfos(FieldInfos) - Method in class org.apache.lucene.index.pruning.StorePruningPolicy
-
Compute field infos that should be retained
- getFieldName() - Method in class org.apache.lucene.queryParser.core.config.FieldConfig
-
Deprecated.use
FieldConfig.getField()
instead - getFieldName() - Method in class org.apache.lucene.queryParser.surround.query.SpanNearClauseFactory
- getFieldName() - Method in class org.apache.lucene.search.DuplicateFilter
- getFieldName() - Method in class org.apache.lucene.search.FieldCache.CacheEntry
- getFieldName() - Method in class org.apache.lucene.search.vectorhighlight.FieldTermStack
- getFieldNames() - Method in class org.apache.lucene.queryParser.surround.query.FieldsQuery
- getFieldNames() - Method in class org.apache.lucene.search.similar.MoreLikeThis
-
Returns the field names that will be used when generating the 'More Like This' query.
- 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) - Method in class org.apache.lucene.queryParser.QueryParser
-
Deprecated.Use
QueryParser.getFieldQuery(String,String,boolean)
instead. - getFieldQuery(String, String) - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.
- getFieldQuery(String, String, boolean) - Method in class org.apache.lucene.queryParser.ext.ExtendableQueryParser
- getFieldQuery(String, String, boolean) - Method in class org.apache.lucene.queryParser.MultiFieldQueryParser
- getFieldQuery(String, String, boolean) - Method in class org.apache.lucene.queryParser.QueryParser
- getFieldQuery(String, String, boolean) - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.
- getFieldQuery(String, String, int) - Method in class org.apache.lucene.queryParser.complexPhrase.ComplexPhraseQueryParser
- getFieldQuery(String, String, int) - Method in class org.apache.lucene.queryParser.MultiFieldQueryParser
- getFieldQuery(String, String, int) - Method in class org.apache.lucene.queryParser.QueryParser
-
Base implementation delegates to
QueryParser.getFieldQuery(String,String,boolean)
. - getFieldQuery(String, String, int) - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.Base implementation delegates to
QueryParserWrapper.getFieldQuery(String,String)
. - getFieldQuery(Query) - Method in class org.apache.lucene.search.vectorhighlight.FastVectorHighlighter
-
create a
FieldQuery
object. - getFieldQuery(Query, IndexReader) - Method in class org.apache.lucene.search.vectorhighlight.FastVectorHighlighter
-
create a
FieldQuery
object. - getFields() - Method in class org.apache.lucene.document.Document
-
Returns a List of all the fields in a document.
- getFields() - Method in interface org.apache.lucene.queryParser.standard.config.MultiFieldAttribute
-
Deprecated.
- getFields() - Method in class org.apache.lucene.queryParser.standard.config.MultiFieldAttributeImpl
-
Deprecated.
- getFields(String) - Method in class org.apache.lucene.document.Document
-
Deprecated.use
Document.getFieldable(java.lang.String)
instead and cast depending on data type. - getFields(IndexReader, int, String) - Method in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
- getFieldsBoost() - Method in class org.apache.lucene.queryParser.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
- getFieldsToHighlight(Document) - Method in class org.apache.lucene.benchmark.byTask.tasks.ReadTask
-
Define the fields to highlight.
- getFieldsToHighlight(Document) - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchTravRetHighlightTask
- getFieldsToHighlight(Document) - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchTravRetVectorHighlightTask
- getFieldTermMap(String, String) - Method in class org.apache.lucene.search.vectorhighlight.FieldQuery
- getFieldToTerms() - Method in class org.apache.lucene.index.FieldSortedTermVectorMapper
-
Get the mapping between fields and terms, sorted by the comparator
- getFieldToTerms() - Method in class org.apache.lucene.index.PositionBasedTermVectorMapper
-
Get the mapping between fields and terms, sorted by the comparator
- getFieldValues(IndexReader, int, String) - Method in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
-
Deprecated.
- getFile() - Method in class org.apache.lucene.store.FSDirectory
-
Deprecated.Use
FSDirectory.getDirectory()
instead. - getFileNames() - Method in class org.apache.lucene.index.IndexCommit
-
Returns all index files referenced by this commit point.
- getFileNames() - Method in class org.apache.lucene.index.SnapshotDeletionPolicy.SnapshotCommitPoint
- getFilePointer() - Method in class org.apache.lucene.store.BufferedIndexInput
- getFilePointer() - Method in class org.apache.lucene.store.BufferedIndexOutput
-
Returns the current position in this file, where the next write will occur.
- getFilePointer() - Method in class org.apache.lucene.store.ChecksumIndexInput
- getFilePointer() - Method in class org.apache.lucene.store.ChecksumIndexOutput
- getFilePointer() - Method in class org.apache.lucene.store.IndexInput
-
Returns the current position in this file, where the next read will occur.
- getFilePointer() - Method in class org.apache.lucene.store.IndexOutput
-
Returns the current position in this file, where the next write will occur.
- getFilePointer() - Method in class org.apache.lucene.store.MockIndexInputWrapper
- getFilePointer() - Method in class org.apache.lucene.store.MockIndexOutputWrapper
- getFilePointer() - Method in class org.apache.lucene.store.RAMInputStream
- getFilePointer() - Method in class org.apache.lucene.store.RAMOutputStream
- getFilePointer() - Method in class org.apache.lucene.util.ThrottledIndexOutput
- getFilter() - Static method in class org.apache.lucene.index.IndexFileNameFilter
- getFilter() - Method in class org.apache.lucene.search.ConstantScoreQuery
-
Returns the encapsulated filter, returns
null
if a query is wrapped. - getFilter() - Method in class org.apache.lucene.search.FilterClause
-
Returns this FilterClause's filter
- getFilter() - Method in class org.apache.lucene.search.FilteredQuery
- getFilter() - Method in class org.apache.lucene.spatial.tier.DistanceQueryBuilder
-
Deprecated.Create a distance query using a boundary box wrapper around a more precise DistanceFilter.
- getFilter(Filter) - Method in class org.apache.lucene.search.FilterManager
-
Deprecated.Returns the cached version of the filter.
- getFilter(Query) - Method in class org.apache.lucene.spatial.tier.DistanceQueryBuilder
-
Deprecated.
- getFilter(Element) - Method in class org.apache.lucene.xmlparser.builders.BooleanFilterBuilder
- getFilter(Element) - Method in class org.apache.lucene.xmlparser.builders.CachedFilterBuilder
- getFilter(Element) - Method in class org.apache.lucene.xmlparser.builders.DuplicateFilterBuilder
- getFilter(Element) - Method in class org.apache.lucene.xmlparser.builders.NumericRangeFilterBuilder
- getFilter(Element) - Method in class org.apache.lucene.xmlparser.builders.RangeFilterBuilder
- getFilter(Element) - Method in class org.apache.lucene.xmlparser.builders.TermsFilterBuilder
- getFilter(Element) - Method in interface org.apache.lucene.xmlparser.FilterBuilder
- getFilter(Element) - Method in class org.apache.lucene.xmlparser.FilterBuilderFactory
- getFilterBuilder(String) - Method in class org.apache.lucene.xmlparser.FilterBuilderFactory
- getFinalSearcher() - Method in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
- getFirstArc(FST.Arc<Long>) - Method in class org.apache.lucene.analysis.ja.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.xmlparser.DOMUtils
- getFirstChildOrFail(Element) - Static method in class org.apache.lucene.xmlparser.DOMUtils
- getFirstPathElement() - Method in class org.apache.lucene.queryParser.core.nodes.PathQueryNode
-
Returns the CharSequence value of a specific QueryText element
- getFixedLat() - Method in class org.apache.lucene.spatial.geometry.FixedLatLng
-
Deprecated.
- getFixedLat() - Method in class org.apache.lucene.spatial.geometry.FloatLatLng
-
Deprecated.
- getFixedLat() - Method in class org.apache.lucene.spatial.geometry.LatLng
-
Deprecated.
- getFixedLng() - Method in class org.apache.lucene.spatial.geometry.FixedLatLng
-
Deprecated.
- getFixedLng() - Method in class org.apache.lucene.spatial.geometry.FloatLatLng
-
Deprecated.
- getFixedLng() - Method in class org.apache.lucene.spatial.geometry.LatLng
-
Deprecated.
- getFlag() - Method in class org.apache.lucene.analysis.hunspell.HunspellAffix
-
Returns the affix flag
- getFlags() - Method in class org.apache.lucene.analysis.hunspell.HunspellWord
-
Returns the flags associated with the word
- getFlags() - Method in class org.apache.lucene.analysis.Token
-
Get the bitset for any bits that have been set.
- getFlags() - Method in interface org.apache.lucene.analysis.tokenattributes.FlagsAttribute
-
Get the bitset for any bits that have been set.
- getFlags() - Method in class org.apache.lucene.analysis.tokenattributes.FlagsAttributeImpl
-
Get the bitset for any bits that have been set.
- getFloatArray() - Method in class org.apache.lucene.facet.search.FacetArrays
-
Obtain a float array, e.g.
- getFloatAssociation() - Method in class org.apache.lucene.facet.enhancements.association.AssociationFloatProperty
- getFloats(IndexReader, String) - Method in interface org.apache.lucene.search.FieldCache
-
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in
field
as floats and returns an array of sizereader.maxDoc()
of the value each document has in the given field. - getFloats(IndexReader, String, FieldCache.FloatParser) - Method in interface org.apache.lucene.search.FieldCache
-
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in
field
as floats and returns an array of sizereader.maxDoc()
of the value each document has in the given field. - getFloats(IndexReader, String, FieldCache.FloatParser, boolean) - Method in interface org.apache.lucene.search.FieldCache
-
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in
field
as floats and returns an array of sizereader.maxDoc()
of the value each document has in the given field. - getFloorSegmentMB() - Method in class org.apache.lucene.index.TieredMergePolicy
- getForceMergeDeletesPctAllowed() - Method in class org.apache.lucene.index.TieredMergePolicy
- getForegroundColorString(float) - Method in class org.apache.lucene.search.highlight.GradientFormatter
- getFormat() - Method in class org.apache.lucene.index.SegmentInfos
- 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 ofScorer.getTokenScore()
. - getFragmentScorer() - Method in class org.apache.lucene.search.highlight.Highlighter
- getFragmentSize() - Method in class org.apache.lucene.search.highlight.SimpleFragmenter
- getFragmentSource(StringBuilder, int[], String[], int, int) - Method in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
-
Deprecated.
- 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
- getFrequency() - Method in class org.apache.lucene.index.TermVectorEntry
- 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.search.suggest.fst.FSTCompletion
-
Returns the internal automaton.
- 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.QueryParser
-
Get the minimal similarity for fuzzy queries.
- getFuzzyMinSim() - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.
- getFuzzyMinSim() - Method in class org.apache.lucene.queryParser.standard.StandardQueryParser
-
Get the minimal similarity for fuzzy queries.
- getFuzzyMinSimilarity() - Method in interface org.apache.lucene.queryParser.standard.config.FuzzyAttribute
-
Deprecated.
- getFuzzyMinSimilarity() - Method in class org.apache.lucene.queryParser.standard.config.FuzzyAttributeImpl
-
Deprecated.
- getFuzzyPrefixLength() - Method in class org.apache.lucene.queryParser.QueryParser
-
Get the prefix length for fuzzy queries.
- getFuzzyPrefixLength() - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.
- getFuzzyPrefixLength() - Method in class org.apache.lucene.queryParser.standard.StandardQueryParser
-
Get the prefix length for fuzzy queries.
- getFuzzyQuery(String, String, float) - Method in class org.apache.lucene.queryParser.analyzing.AnalyzingQueryParser
-
Called when parser parses an input term token that has the fuzzy suffix (~) appended.
- getFuzzyQuery(String, String, float) - Method in class org.apache.lucene.queryParser.complexPhrase.ComplexPhraseQueryParser
- getFuzzyQuery(String, String, float) - Method in class org.apache.lucene.queryParser.MultiFieldQueryParser
- getFuzzyQuery(String, String, float) - Method in class org.apache.lucene.queryParser.QueryParser
-
Factory method for generating a query (similar to
QueryParser.getWildcardQuery(java.lang.String, java.lang.String)
). - getFuzzyQuery(String, String, float) - Method in class org.apache.lucene.queryParser.QueryParserTestBase.QPTestParser
- getFuzzyQuery(String, String, float) - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.
- getGeneration() - Method in class org.apache.lucene.index.IndexCommit
-
Returns the generation (the _N in segments_N) for this IndexCommit
- getGeneration() - Method in class org.apache.lucene.index.SegmentInfos
- getGeneration() - Method in class org.apache.lucene.index.SnapshotDeletionPolicy.SnapshotCommitPoint
- getGeneration() - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
- getGlobalCounter() - Static method in class org.apache.lucene.search.TimeLimitingCollector
-
Returns the global TimerThreads
Counter
- getGlobalTimerThread() - Static method in class org.apache.lucene.search.TimeLimitingCollector
-
Returns the global
TimeLimitingCollector.TimerThread
. - getGroupCount() - Method in class org.apache.lucene.search.grouping.AbstractAllGroupsCollector
-
Returns the total number of groups for the executed search.
- getGroups() - Method in class org.apache.lucene.search.grouping.AbstractAllGroupsCollector
-
Returns the group values
- getGroups() - Method in class org.apache.lucene.search.grouping.TermAllGroupsCollector
-
Returns the group values
- getHasProx() - Method in class org.apache.lucene.index.SegmentInfo
- getHasVectors() - Method in class org.apache.lucene.index.SegmentInfo
- getHeapArray() - Method in class org.apache.lucene.util.PriorityQueue
-
This method returns the internal heap array as Object[].
- getHighFreqTerms(IndexReader, int, String) - Static method in class org.apache.lucene.misc.HighFreqTerms
- getHyphenationPoints() - Method in class org.apache.lucene.analysis.compound.hyphenation.Hyphenation
- getHyphenationTree(File) - Static method in class org.apache.lucene.analysis.compound.HyphenationCompoundWordTokenFilter
-
Create a hyphenator tree
- getHyphenationTree(Reader) - Static method in class org.apache.lucene.analysis.compound.HyphenationCompoundWordTokenFilter
-
Deprecated.Don't use Readers with fixed charset to load XML files, unless programatically created. Use
HyphenationCompoundWordTokenFilter.getHyphenationTree(InputSource)
instead, where you can supply default charset and input stream, if you like. - 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
- getIdf() - Method in class org.apache.lucene.search.Explanation.IDFExplanation
- 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
- GetImage() - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
-
Get token literal value.
- GetImage() - Method in interface org.apache.lucene.queryParser.CharStream
-
Returns a string made up of characters from the marked token beginning to the current buffer position.
- GetImage() - Method in class org.apache.lucene.queryParser.FastCharStream
- GetImage() - Method in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
- 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 betweenbaseClass
and the given subclasssubclazz
. - getInclude() - Method in class org.apache.lucene.search.spans.SpanNotQuery
-
Return the SpanQuery whose matches are filtered.
- getIndex() - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.Matrix.Column
-
Deprecated.
- getIndex() - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.Matrix.Column.Row
-
Deprecated.
- getIndex() - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.TokenPositioner
-
Deprecated.
- getIndex() - Method in class org.apache.lucene.analysis.util.CharArrayIterator
- getIndex() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexReader
-
Deprecated.
- getIndexCommit() - Method in class org.apache.lucene.index.FilterIndexReader
- getIndexCommit() - Method in class org.apache.lucene.index.IndexReader
-
Expert: return the IndexCommit that this reader has opened.
- getIndexCommit() - Method in class org.apache.lucene.index.IndexWriterConfig
-
Returns the
IndexCommit
as specified inIndexWriterConfig.setIndexCommit(IndexCommit)
or the default,null
which specifies to open the latest index commit point. - getIndexDeletionPolicy() - Method in class org.apache.lucene.index.IndexWriterConfig
-
Returns the
IndexDeletionPolicy
specified inIndexWriterConfig.setIndexDeletionPolicy(IndexDeletionPolicy)
or the defaultKeepOnlyLastCommitDeletionPolicy
/ - getIndexDeletionPolicy(Config) - Static method in class org.apache.lucene.benchmark.byTask.tasks.CreateIndexTask
- getIndexedFields(IndexReader) - Static method in class org.apache.lucene.util.ReaderUtil
- getIndexOptions() - Method in class org.apache.lucene.document.AbstractField
- getIndexOptions() - Method in interface org.apache.lucene.document.Fieldable
- getIndexReader() - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
- getIndexReader() - Method in class org.apache.lucene.queryParser.surround.query.SpanNearClauseFactory
- getIndexReader() - Method in class org.apache.lucene.search.IndexSearcher
-
Return the
IndexReader
this searches. - getIndexSearcher() - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
- getIndexWriter() - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
- getIndexWriter() - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
- getInflectedFormTranslation(String) - Static method in class org.apache.lucene.analysis.ja.util.ToStringUtil
-
Get the english form of inflected form
- 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
- 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
- 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
- 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
- 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.IndexWriter
-
Returns the current infoStream in use by this writer.
- getInfoStream() - Static method in class org.apache.lucene.index.SegmentInfos
- getInfoStream() - Method in interface org.apache.lucene.search.FieldCache
-
counterpart of
FieldCache.setInfoStream(PrintStream)
- getInfoStream() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexWriter
-
Deprecated.
- 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.search.FilterManager
-
Deprecated.
- getInstance(Version) - Static method in class org.apache.lucene.util.CharacterUtils
-
Returns a
CharacterUtils
implementation according to the givenVersion
instance. - getIntArray() - Method in class org.apache.lucene.facet.search.FacetArrays
-
Obtain an int array, e.g.
- getInterletterValues(String) - Static method in class org.apache.lucene.analysis.compound.hyphenation.PatternParser
- getInts(IndexReader, String) - Method in interface org.apache.lucene.search.FieldCache
-
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in
field
as integers and returns an array of sizereader.maxDoc()
of the value each document has in the given field. - getInts(IndexReader, String, FieldCache.IntParser) - Method in interface org.apache.lucene.search.FieldCache
-
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in
field
as integers and returns an array of sizereader.maxDoc()
of the value each document has in the given field. - getInts(IndexReader, String, FieldCache.IntParser, boolean) - Method in interface org.apache.lucene.search.FieldCache
-
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in
field
as integers and returns an array of sizereader.maxDoc()
of the value each document has in the given field. - getItemsCount() - Method in class org.apache.lucene.benchmark.byTask.feeds.ContentItemsSource
-
Returns the number of generated items since last reset.
- getKeepMode() - Method in class org.apache.lucene.search.DuplicateFilter
- getKey() - Method in interface org.apache.lucene.messages.Message
-
Deprecated.
- getKey() - Method in class org.apache.lucene.messages.MessageImpl
-
Deprecated.
- getKey(JaspellTernarySearchTrie.TSTNode) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Returns the key that indexes the node argument.
- getLabel() - Method in enum org.apache.lucene.analysis.ngram.EdgeNGramTokenFilter.Side
- getLabel() - Method in enum org.apache.lucene.analysis.ngram.EdgeNGramTokenizer.Side
- getLabel() - Method in interface org.apache.lucene.facet.search.results.FacetResultNode
-
Category path of the category of this result, or null if not computed, because the application did not request to compute it.
- getLabel() - Method in class org.apache.lucene.facet.search.results.MutableFacetResultNode
- getLabel(TaxonomyReader) - Method in interface org.apache.lucene.facet.search.results.FacetResultNode
-
Category path of the category of this result.
- getLabel(TaxonomyReader) - Method in class org.apache.lucene.facet.search.results.MutableFacetResultNode
- getLastCommitGeneration(String[]) - Static method in class org.apache.lucene.index.SegmentInfos
-
Get the generation of the most recent commit to the list of index files (N in the segments_N file).
- getLastCommitGeneration(Directory) - Static method in class org.apache.lucene.index.SegmentInfos
-
Get the generation of the most recent commit to the index in this directory (N in the segments_N file).
- getLastCommitSegmentsFileName(String[]) - Static method in class org.apache.lucene.index.SegmentInfos
-
Get the filename of the segments_N file for the most recent commit in the list of index files.
- getLastCommitSegmentsFileName(Directory) - Static method in class org.apache.lucene.index.SegmentInfos
-
Get the filename of the segments_N file for the most recent commit to the index in this Directory.
- getLastCumulativeDiff() - Method in class org.apache.lucene.analysis.BaseCharFilter
- getLastDocCollected() - Method in exception org.apache.lucene.search.TimeLimitingCollector.TimeExceededException
-
Returns last doc (absolute doc id) that was collected when the search time exceeded.
- getLastGeneration() - Method in class org.apache.lucene.index.SegmentInfos
- getLastModified() - Method in class org.apache.lucene.store.RAMFile
- 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
- getLat() - Method in class org.apache.lucene.spatial.geometry.FixedLatLng
-
Deprecated.
- getLat() - Method in class org.apache.lucene.spatial.geometry.FloatLatLng
-
Deprecated.
- getLat() - Method in class org.apache.lucene.spatial.geometry.LatLng
-
Deprecated.
- getLat() - Method in class org.apache.lucene.spatial.tier.DistanceQueryBuilder
-
Deprecated.
- 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
- getLength() - Method in class org.apache.lucene.analysis.ja.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.store.RAMFile
- getLength() - Method in class org.apache.lucene.util.CharacterUtils.CharacterBuffer
-
Return the length of the data in the internal buffer starting at
CharacterUtils.CharacterBuffer.getOffset()
- getLikeText() - Method in class org.apache.lucene.search.similar.MoreLikeThisQuery
- getLimit() - Method in class org.apache.lucene.index.IndexWriter.MaxFieldLength
-
Deprecated.
- getLine() - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
-
Deprecated.
- getLine() - Method in interface org.apache.lucene.queryParser.CharStream
-
Deprecated.
- getLine() - Method in class org.apache.lucene.queryParser.FastCharStream
- getLine() - Method in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
-
Deprecated.
- getLine() - Method in interface org.apache.lucene.queryParser.surround.parser.CharStream
-
Deprecated.
- getLine() - Method in class org.apache.lucene.queryParser.surround.parser.FastCharStream
- getLLMDistance(double, double, double, double) - Static method in class org.apache.lucene.spatial.DistanceUtils
-
Deprecated.
- getLng() - Method in class org.apache.lucene.spatial.geometry.FixedLatLng
-
Deprecated.
- getLng() - Method in class org.apache.lucene.spatial.geometry.FloatLatLng
-
Deprecated.
- getLng() - Method in class org.apache.lucene.spatial.geometry.LatLng
-
Deprecated.
- getLng() - Method in class org.apache.lucene.spatial.tier.DistanceQueryBuilder
-
Deprecated.
- getLocale() - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
- getLocale() - Method in class org.apache.lucene.queryParser.QueryParser
-
Returns current locale, allowing access by subclasses.
- getLocale() - Method in interface org.apache.lucene.queryParser.standard.config.LocaleAttribute
-
Deprecated.
- getLocale() - Method in class org.apache.lucene.queryParser.standard.config.LocaleAttributeImpl
-
Deprecated.
- getLocale() - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.
- getLocale() - Method in class org.apache.lucene.queryParser.standard.StandardQueryParser
-
Returns current locale, allowing access by subclasses.
- getLocale() - Method in class org.apache.lucene.search.SortField
-
Returns the Locale by which term values are interpreted.
- getLocalizedMessage() - Method in interface org.apache.lucene.messages.Message
-
Deprecated.
- getLocalizedMessage() - Method in class org.apache.lucene.messages.MessageImpl
-
Deprecated.
- getLocalizedMessage() - Method in exception org.apache.lucene.queryParser.core.QueryNodeException
- getLocalizedMessage(String) - Static method in class org.apache.lucene.messages.NLS
-
Deprecated.
- getLocalizedMessage(String, Object...) - Static method in class org.apache.lucene.messages.NLS
-
Deprecated.
- getLocalizedMessage(String, Locale) - Static method in class org.apache.lucene.messages.NLS
-
Deprecated.
- getLocalizedMessage(String, Locale, Object...) - Static method in class org.apache.lucene.messages.NLS
-
Deprecated.
- getLocalizedMessage(Locale) - Method in interface org.apache.lucene.messages.Message
-
Deprecated.
- getLocalizedMessage(Locale) - Method in class org.apache.lucene.messages.MessageImpl
-
Deprecated.
- getLocalizedMessage(Locale) - Method in exception org.apache.lucene.queryParser.core.QueryNodeException
- getLockDir() - Method in class org.apache.lucene.store.FSLockFactory
-
Retrieve the lock directory.
- getLockFactory() - Method in class org.apache.lucene.store.Directory
-
Get the LockFactory that this Directory instance is using for its locking implementation.
- getLockFactory() - Method in class org.apache.lucene.store.MockDirectoryWrapper
- getLockFactory() - Method in class org.apache.lucene.store.NRTCachingDirectory
- getLockID() - Method in class org.apache.lucene.store.Directory
-
Return a string identifier that uniquely differentiates this Directory instance from other Directory instances.
- getLockID() - Method in class org.apache.lucene.store.FSDirectory
- getLockID() - Method in class org.apache.lucene.store.MockDirectoryWrapper
- getLockID() - Method in class org.apache.lucene.store.NRTCachingDirectory
- getLockPrefix() - Method in class org.apache.lucene.store.LockFactory
-
Get the prefix in use for all locks created in this LockFactory.
- getLockPrefix() - Method in class org.apache.lucene.store.MockLockFactoryWrapper
- 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.DeleteDocTask
- 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
- getLongs(IndexReader, String) - Method in interface org.apache.lucene.search.FieldCache
-
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in
field
as longs and returns an array of sizereader.maxDoc()
of the value each document has in the given field. - getLongs(IndexReader, String, FieldCache.LongParser) - Method in interface org.apache.lucene.search.FieldCache
-
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in
field
as longs and returns an array of sizereader.maxDoc()
of the value each document has in the given field. - getLongs(IndexReader, String, FieldCache.LongParser, boolean) - Method in interface org.apache.lucene.search.FieldCache
-
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in
field
as longs and returns an array of sizereader.maxDoc()
of the value each document has in the given field. - getLowerBound() - Method in class org.apache.lucene.queryParser.core.nodes.ParametricRangeQueryNode
- getLowerBound() - Method in interface org.apache.lucene.queryParser.core.nodes.RangeQueryNode
- getLowerBound() - Method in class org.apache.lucene.queryParser.standard.nodes.AbstractRangeQueryNode
-
Returns the lower bound node.
- getLowerBound() - Method in class org.apache.lucene.queryParser.standard.nodes.RangeQueryNode
-
Deprecated.
- getLowercaseExpandedTerms() - Method in class org.apache.lucene.queryParser.QueryParser
- getLowercaseExpandedTerms() - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.
- getLowercaseExpandedTerms() - Method in class org.apache.lucene.queryParser.standard.StandardQueryParser
- getLowerLeft() - Method in class org.apache.lucene.spatial.geometry.shape.LLRect
-
Deprecated.
- getLowerTerm() - Method in class org.apache.lucene.search.TermRangeFilter
-
Returns the lower value of this range filter
- getLowerTerm() - Method in class org.apache.lucene.search.TermRangeQuery
-
Returns the lower value of this range query
- getLowerVal() - Method in class org.apache.lucene.search.FieldCacheRangeFilter
-
Returns the lower value of this range filter
- 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.search.ComplexExplanation
-
The match status of this explanation node.
- getMatch() - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery
- getMatrix() - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter
-
Deprecated.
- getMatrix() - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.Matrix.Column
-
Deprecated.
- getMax() - Method in class org.apache.lucene.search.NumericRangeFilter
-
Returns the upper value of this range filter
- getMax() - Method in class org.apache.lucene.search.NumericRangeQuery
-
Returns the upper value of this range query
- getMaxBasicQueries() - Method in class org.apache.lucene.queryParser.surround.query.BasicQueryFactory
- getMaxBufferedDeleteTerms() - Method in class org.apache.lucene.index.IndexWriter
-
Deprecated.use
IndexWriterConfig.getMaxBufferedDeleteTerms()
instead - getMaxBufferedDeleteTerms() - Method in class org.apache.lucene.index.IndexWriterConfig
-
Returns the number of buffered deleted terms that will trigger a flush if enabled.
- getMaxBufferedDocs() - Method in class org.apache.lucene.index.IndexWriter
-
Deprecated.use
IndexWriterConfig.getMaxBufferedDocs()
instead. - getMaxBufferedDocs() - Method in class org.apache.lucene.index.IndexWriterConfig
-
Returns the number of buffered added documents that will trigger a flush if enabled.
- getMaxChunkSize() - Method in class org.apache.lucene.store.MMapDirectory
-
Returns the current mmap chunk size.
- getMaxClauseCount() - Static method in class org.apache.lucene.search.BooleanQuery
-
Return the maximum number of clauses permitted, 1024 by default.
- getMaxDocCharsToAnalyze() - Method in class org.apache.lucene.search.highlight.Highlighter
- getMaxDocFreq() - Method in class org.apache.lucene.search.similar.MoreLikeThis
-
Returns the maximum frequency in which words may still appear.
- getMaxFieldLength() - Method in class org.apache.lucene.index.IndexWriter
-
Deprecated.use
LimitTokenCountAnalyzer
to limit number of tokens. - getMaxFieldLength() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexWriter
-
Deprecated.
- getMaxGoodPoints() - Method in class org.apache.lucene.benchmark.quality.QualityStats
-
Returns the maximal number of good points.
- getMaximumShingleSize() - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter
-
Deprecated.
- getMaxMergeAtOnce() - Method in class org.apache.lucene.index.TieredMergePolicy
- getMaxMergeAtOnceExplicit() - Method in class org.apache.lucene.index.TieredMergePolicy
- getMaxMergeCount() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
- getMaxMergeDocs() - Method in class org.apache.lucene.index.BalancedSegmentMergePolicy.MergePolicyParams
-
Deprecated.
- getMaxMergeDocs() - Method in class org.apache.lucene.index.IndexWriter
-
Deprecated.use
LogMergePolicy.getMaxMergeDocs()
directly. - getMaxMergeDocs() - Method in class org.apache.lucene.index.LogMergePolicy
-
Returns the largest segment (measured by document count) that may be merged with other segments.
- getMaxMergedSegmentMB() - Method in class org.apache.lucene.index.TieredMergePolicy
- getMaxMergeMB() - Method in class org.apache.lucene.index.LogByteSizeMergePolicy
-
Returns the largest segment (measured by total byte size of the segment's files, in MB) that may be merged with other segments.
- getMaxMergeMBForForcedMerge() - Method in class org.apache.lucene.index.LogByteSizeMergePolicy
-
Returns the largest segment (measured by total byte size of the segment's files, in MB) that may be merged with other segments during forceMerge.
- getMaxMergeMBForOptimize() - Method in class org.apache.lucene.index.LogByteSizeMergePolicy
-
Deprecated.
- getMaxNumTokensParsed() - Method in class org.apache.lucene.search.similar.MoreLikeThis
- getMaxOrdinal() - Method in class org.apache.lucene.facet.taxonomy.writercache.cl2o.LabelToOrdinal
-
return the maximal Ordinal assigned so far
- getMaxPoint() - Method in class org.apache.lucene.spatial.geometry.shape.Rectangle
-
Deprecated.
- getMaxQueries() - Method in class org.apache.lucene.benchmark.quality.QualityBenchmark
- getMaxQueryTerms() - Method in class org.apache.lucene.search.similar.MoreLikeThis
-
Returns the maximum number of query terms that will be included in any generated query.
- getMaxQueryTerms() - Method in class org.apache.lucene.search.similar.MoreLikeThisQuery
- getMaxResults() - Method in class org.apache.lucene.benchmark.quality.QualityBenchmark
- getMaxSampleSize() - Method in class org.apache.lucene.facet.search.sampling.SamplingParams
-
Return the maxSampleSize.
- 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.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).
- getMaxSize() - Method in class org.apache.lucene.util.collections.LRUHashMap
-
Return the max size
- getMaxSizeInBytes() - Method in class org.apache.lucene.store.MockDirectoryWrapper
- getMaxSmallSegments() - Method in class org.apache.lucene.index.BalancedSegmentMergePolicy
-
Deprecated.
- getMaxSmallSegments() - Method in class org.apache.lucene.index.BalancedSegmentMergePolicy.MergePolicyParams
-
Deprecated.
- getMaxTermFrequency() - Method in class org.apache.lucene.index.FieldInvertState
-
Get the maximum term-frequency encountered for any term in the field.
- 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
- getMaxThreadStates() - Method in class org.apache.lucene.index.IndexWriterConfig
-
Returns the max number of simultaneous threads that may be indexing documents at once in IndexWriter.
- getMaxTokenLength() - Method in class org.apache.lucene.analysis.standard.ClassicAnalyzer
- getMaxTokenLength() - Method in class org.apache.lucene.analysis.standard.ClassicTokenizer
- getMaxTokenLength() - Method in class org.apache.lucene.analysis.standard.StandardAnalyzer
- getMaxTokenLength() - Method in class org.apache.lucene.analysis.standard.StandardTokenizer
- getMaxTokenLength() - Method in class org.apache.lucene.analysis.standard.UAX29URLEmailAnalyzer
- getMaxTokenLength() - Method in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
- getMaxTotMem() - Method in class org.apache.lucene.benchmark.byTask.stats.TaskStats
- 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.
- getMaxValue() - Method in class org.apache.lucene.search.function.DocValues
-
Returns the maximum of all values or
Float.NaN
if this DocValues instance does not contain any value. - getMaxValue() - Method in class org.apache.lucene.util.packed.PackedInts.ReaderImpl
- getMaxWordLen() - Method in class org.apache.lucene.search.similar.MoreLikeThis
-
Returns the maximum word length above which words will be ignored.
- getMemorySize() - Method in class org.apache.lucene.index.memory.MemoryIndex
-
Returns a reasonable approximation of the main memory [bytes] consumed by this instance.
- getMemoryUsage() - Method in class org.apache.lucene.facet.taxonomy.writercache.cl2o.Cl2oTaxonomyWriterCache
-
Returns the number of bytes in memory used by this object.
- getMergedFieldInfos(IndexReader) - Static method in class org.apache.lucene.util.ReaderUtil
-
Call this to get the (merged) FieldInfos for a composite reader
- getMergedSegmentWarmer() - Method in class org.apache.lucene.index.IndexWriter
-
Deprecated.use
IndexWriterConfig.getMergedSegmentWarmer()
instead. - getMergedSegmentWarmer() - Method in class org.apache.lucene.index.IndexWriterConfig
-
Returns the current merged segment warmer.
- getMergeFactor() - Method in class org.apache.lucene.index.BalancedSegmentMergePolicy.MergePolicyParams
-
Deprecated.
- getMergeFactor() - Method in class org.apache.lucene.index.IndexWriter
-
Deprecated.use
LogMergePolicy.getMergeFactor()
directly. - 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.
- getMergeFactor() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexWriter
-
Deprecated.
- getMergePolicy() - Method in class org.apache.lucene.index.IndexWriter
-
Deprecated.use
IndexWriterConfig.getMergePolicy()
instead - getMergePolicy() - Method in class org.apache.lucene.index.IndexWriterConfig
-
Returns the current MergePolicy in use by this writer.
- getMergeScheduler() - Method in class org.apache.lucene.index.IndexWriter
-
Deprecated.use
IndexWriterConfig.getMergeScheduler()
instead - getMergeScheduler() - Method in class org.apache.lucene.index.IndexWriterConfig
-
Returns the
MergeScheduler
that was set byIndexWriterConfig.setMergeScheduler(MergeScheduler)
- getMergeScheduler() - Method in class org.apache.lucene.store.NRTCachingDirectory
- getMergeThread(IndexWriter, MergePolicy.OneMerge) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
-
Create and return a new MergeThread
- getMergeThreadPriority() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
-
Return the priority that merge threads run at.
- getMergingSegments() - Method in class org.apache.lucene.index.IndexWriter
-
Expert: to be used by a
MergePolicy
to avoid selecting merges for segments already being merged. - getMessage() - Method in error org.apache.lucene.benchmark.byTask.feeds.demohtml.TokenMgrError
-
You can also modify the body of this method to customize your error messages.
- getMessage() - Method in exception org.apache.lucene.queryParser.core.QueryNodeException
- getMessage() - Method in error org.apache.lucene.queryParser.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.
- getMessage() - Method in error org.apache.lucene.queryParser.TokenMgrError
-
You can also modify the body of this method to customize your error messages.
- getMessageObject() - Method in interface org.apache.lucene.messages.NLSException
-
Deprecated.
- getMessageObject() - Method in error org.apache.lucene.queryParser.core.QueryNodeError
- getMessageObject() - Method in exception org.apache.lucene.queryParser.core.QueryNodeException
- getMetaTags() - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParser
- getMidpoint() - Method in class org.apache.lucene.spatial.geometry.shape.LLRect
-
Deprecated.
- getMiles() - Method in class org.apache.lucene.spatial.tier.DistanceQueryBuilder
-
Deprecated.
- getMilesPerLatDeg() - Static method in class org.apache.lucene.spatial.geometry.shape.DistanceApproximation
-
Deprecated.
- getMilesPerLngDeg(double) - Static method in class org.apache.lucene.spatial.geometry.shape.DistanceApproximation
-
Deprecated.
- getMilliseconds() - Method in class org.apache.lucene.search.TimeLimitingCollector.TimerThread
-
Get the timer value in milliseconds.
- getMin() - Method in class org.apache.lucene.search.NumericRangeFilter
-
Returns the lower value of this range filter
- getMin() - Method in class org.apache.lucene.search.NumericRangeQuery
-
Returns the lower value of this range query
- getMinDocFreq() - Method in class org.apache.lucene.search.similar.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.search.similar.MoreLikeThisQuery
- getMinimumMatchingElements() - Method in class org.apache.lucene.queryParser.core.nodes.AnyQueryNode
- getMinimumNumberShouldMatch() - Method in class org.apache.lucene.search.BooleanQuery
-
Gets the minimum number of the optional BooleanClauses which must be satisfied.
- getMinimumShingleSize() - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter
-
Deprecated.
- 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.
- getMinPoint() - Method in class org.apache.lucene.spatial.geometry.shape.Rectangle
-
Deprecated.
- getMinSampleSize() - Method in class org.apache.lucene.facet.search.sampling.SamplingParams
-
Return the minSampleSize.
- getMinShingleSize() - Method in class org.apache.lucene.analysis.shingle.ShingleAnalyzerWrapper
-
The min shingle (token ngram) size
- getMinSimilarity() - Method in class org.apache.lucene.queryParser.standard.config.FuzzyConfig
- getMinSimilarity() - Method in class org.apache.lucene.search.FuzzyQuery
-
Returns the minimum similarity that is required for this query to match.
- getMinTermFreq() - Method in class org.apache.lucene.search.similar.MoreLikeThis
-
Returns the frequency below which terms will be ignored in the source doc.
- getMinTermFrequency() - Method in class org.apache.lucene.search.similar.MoreLikeThisQuery
- getMinValue() - Method in class org.apache.lucene.search.function.DocValues
-
Returns the minimum of all values or
Float.NaN
if this DocValues instance does not contain any value. - getMinWordLen() - Method in class org.apache.lucene.search.similar.MoreLikeThis
-
Returns the minimum word length below which words will be ignored.
- getModifier() - Method in class org.apache.lucene.queryParser.core.nodes.ModifierQueryNode
- getMoreLikeFields() - Method in class org.apache.lucene.search.similar.MoreLikeThisQuery
- getMRR() - Method in class org.apache.lucene.benchmark.quality.QualityStats
-
Returns the Mean reciprocal rank over the queries or RR for a single query.
- getMsg() - Method in class org.apache.lucene.util.FieldCacheSanityChecker.Insanity
-
Description of hte insane behavior
- getMultiFields(CharSequence[]) - Method in class org.apache.lucene.queryParser.standard.StandardQueryParser
-
Returns the fields used to expand the query when the field for a certain query is
null
- getMultiTermRewriteMethod() - Method in class org.apache.lucene.queryParser.QueryParser
- getMultiTermRewriteMethod() - Method in interface org.apache.lucene.queryParser.standard.config.MultiTermRewriteMethodAttribute
-
Deprecated.
- getMultiTermRewriteMethod() - Method in class org.apache.lucene.queryParser.standard.config.MultiTermRewriteMethodAttributeImpl
-
Deprecated.
- getMultiTermRewriteMethod() - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.
- getMultiTermRewriteMethod() - Method in class org.apache.lucene.queryParser.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) - Static method in class org.apache.lucene.util.packed.PackedInts
-
Create a packed integer array with the given amount of values initialized to 0.
- 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.index.CompoundFileWriter
-
Returns the name of the compound file.
- getName() - Method in class org.apache.lucene.util.LuceneTestCase
- getNames() - Method in class org.apache.lucene.benchmark.quality.QualityQuery
-
Return all the names of name-value-pairs in this QualityQuery.
- 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
- getNextFacets(CategoryContainer) - Method in class org.apache.lucene.benchmark.byTask.feeds.FacetSource
-
Returns the next
facets content item
. - getNextFacets(CategoryContainer) - Method in class org.apache.lucene.benchmark.byTask.feeds.RandomFacetSource
- getNextFixedSize(int) - Static method in class org.apache.lucene.util.packed.PackedInts
-
Rounds bitsPerValue up to 8, 16, 32 or 64.
- getNextMerge() - Method in class org.apache.lucene.index.IndexWriter
-
Expert: the
MergeScheduler
calls this method to retrieve the next merge requested by the MergePolicy - getNextOrdinal() - Method in class org.apache.lucene.facet.taxonomy.writercache.cl2o.LabelToOrdinal
-
Returns the next unassigned ordinal.
- getNextSegmentFileName() - Method in class org.apache.lucene.index.SegmentInfos
-
Get the next segments_N filename that will be written.
- getNextToken() - Method in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
-
Resumes scanning until the next regular expression is matched, the end of input is encountered or an I/O-Error occurs.
- getNextToken() - Method in interface org.apache.lucene.analysis.standard.StandardTokenizerInterface
-
Resumes scanning until the next regular expression is matched, the end of input is encountered or an I/O-Error occurs.
- getNextToken() - Method in class org.apache.lucene.analysis.standard.std31.StandardTokenizerImpl31
-
Deprecated.Resumes scanning until the next regular expression is matched, the end of input is encountered or an I/O-Error occurs.
- getNextToken() - Method in class org.apache.lucene.analysis.standard.std31.UAX29URLEmailTokenizerImpl31
-
Deprecated.Resumes scanning until the next regular expression is matched, the end of input is encountered or an I/O-Error occurs.
- getNextToken() - Method in class org.apache.lucene.analysis.standard.std34.UAX29URLEmailTokenizerImpl34
-
Deprecated.Resumes scanning until the next regular expression is matched, the end of input is encountered or an I/O-Error occurs.
- getNextToken() - Method in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizerImpl
-
Resumes scanning until the next regular expression is matched, the end of input is encountered or an I/O-Error occurs.
- getNextToken() - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParser
-
Get the next Token.
- getNextToken() - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserTokenManager
-
Get the next Token.
- getNextToken() - Method in class org.apache.lucene.queryParser.QueryParser
-
Get the next Token.
- getNextToken() - Method in class org.apache.lucene.queryParser.QueryParserTokenManager
-
Get the next Token.
- getNextToken() - Method in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParser
-
Get the next Token.
- getNextToken() - Method in class org.apache.lucene.queryParser.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.
- getNoCFSRatio() - Method in class org.apache.lucene.index.LogMergePolicy
- getNoCFSRatio() - Method in class org.apache.lucene.index.TieredMergePolicy
- getNode(CharSequence) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
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
-
Returns the node indexed by key, or
null
if that node doesn't exist. - getNodeCount() - Method in class org.apache.lucene.util.fst.FST
- getNoDeleteOpenFile() - Method in class org.apache.lucene.store.MockDirectoryWrapper
- getNoLockFactory() - Static method in class org.apache.lucene.store.NoLockFactory
- getNonBlankTextOrFail(Element) - Static method in class org.apache.lucene.xmlparser.DOMUtils
- getNoOutput() - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
- getNoOutput() - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
- getNoOutput() - Method in class org.apache.lucene.util.fst.NoOutputs
- getNoOutput() - Method in class org.apache.lucene.util.fst.Outputs
-
NOTE: this output is compared with == so you must ensure that all methods return the single object if it's really no output
- getNoOutput() - Method in class org.apache.lucene.util.fst.PairOutputs
- getNoOutput() - Method in class org.apache.lucene.util.fst.PositiveIntOutputs
- getNoOutput() - Method in class org.apache.lucene.util.fst.UpToTwoPositiveIntOutputs
- getNormDecoder() - Static method in class org.apache.lucene.search.Similarity
-
Deprecated.Use instance methods for encoding/decoding norm values to enable customization.
- getNormFileName(int) - Method in class org.apache.lucene.index.SegmentInfo
-
Get the file name for the norms file for this field.
- getNormsByFieldNameAndDocumentNumber() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndex
-
Deprecated.
- 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
- getNumberFormat() - Method in class org.apache.lucene.queryParser.standard.config.NumericConfig
- getNumberFormat() - Method in class org.apache.lucene.queryParser.standard.nodes.NumericQueryNode
-
Returns the
NumberFormat
used to convert the value toString
. - getNumericConfig() - Method in class org.apache.lucene.queryParser.standard.nodes.NumericRangeQueryNode
-
Returns the
NumericConfig
associated with the lower and upper bounds. - getNumericConfigMap() - Method in class org.apache.lucene.queryParser.standard.StandardQueryParser
- getNumericValue() - Method in class org.apache.lucene.document.NumericField
-
Returns the current numeric value as a subclass of
Number
,null
if not yet initialized. - getNumGoodPoints() - Method in class org.apache.lucene.benchmark.quality.QualityStats
-
Returns the number of good points (only relevant points).
- getNumLabel() - Method in class org.apache.lucene.facet.search.params.FacetRequest
-
If getNumLabel()
- getNumLargeSegments() - Method in class org.apache.lucene.index.BalancedSegmentMergePolicy
Deprecated.- getNumLargeSegments() - Method in class org.apache.lucene.index.BalancedSegmentMergePolicy.MergePolicyParams
Deprecated.- getNumOverlap() - Method in class org.apache.lucene.index.FieldInvertState
Get the number of terms withpositionIncrement == 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).- getNumResults() - Method in class org.apache.lucene.facet.search.params.FacetRequest
The number of sub-categories to return (at most).- getNumRuns() - Method in class org.apache.lucene.benchmark.byTask.stats.TaskStats
- getNumSubResults() - Method in interface org.apache.lucene.facet.search.results.FacetResultNode
Number of sub results- getNumSubResults() - Method in class org.apache.lucene.facet.search.results.MutableFacetResultNode
- getNumTokens() - Method in class org.apache.lucene.search.highlight.TokenGroup
- getNumValidDescendants() - Method in class org.apache.lucene.facet.search.results.FacetResult
Number of descendants ofroot facet result node
, up till the requested depth, which are valid by theresults handler in effect
.- getNumWords() - Method in class org.apache.lucene.util.OpenBitSet
Expert: gets the number of longs in the array that are in use- getOccur() - Method in class org.apache.lucene.search.BooleanClause
- getOccur() - Method in class org.apache.lucene.search.FilterClause
Returns this FilterClause's occur parameter- getOffset() - Method in class org.apache.lucene.analysis.ja.Token
- getOffset() - Method in class org.apache.lucene.index.FieldInvertState
Get end offset of the last processed term.- getOffset() - Method in class org.apache.lucene.index.Payload
Returns the offset in the underlying byte array- getOffset() - Method in class org.apache.lucene.util.CharacterUtils.CharacterBuffer
Returns the data offset in the internal buffer.- getOffsetGap(Fieldable) - Method in class org.apache.lucene.analysis.Analyzer
Just likeAnalyzer.getPositionIncrementGap(java.lang.String)
, except for Token offsets instead.- getOffsetGap(Fieldable) - Method in class org.apache.lucene.analysis.LimitTokenCountAnalyzer
- getOffsetGap(Fieldable) - Method in class org.apache.lucene.analysis.PerFieldAnalyzerWrapper
Return the offsetGap from the analyzer assigned to field- getOffsets() - Method in class org.apache.lucene.index.PositionBasedTermVectorMapper.TVPositionInfo
Parallel list (toPositionBasedTermVectorMapper.TVPositionInfo.getTerms()
) of TermVectorOffsetInfo objects.- getOffsets() - Method in class org.apache.lucene.index.TermVectorEntry
- getOffsets(int) - Method in interface org.apache.lucene.index.TermPositionVector
Returns an array of TermVectorOffsetInfo in which the term is found.- getOffsets(int) - Method in class org.apache.lucene.store.instantiated.InstantiatedTermPositionVector
- getOlderSiblingArray() - Method in interface org.apache.lucene.facet.taxonomy.TaxonomyReader.ChildrenArrays
getOlderSiblingArray() returns an int array of size getSize() listing for each category the ordinal of its immediate older sibling (the sibling in the taxonomy tree with the highest ordinal below that of the given ordinal).- getOmitNorms() - Method in class org.apache.lucene.document.AbstractField
True if norms are omitted for this indexed field- getOmitNorms() - Method in interface org.apache.lucene.document.Fieldable
True if norms are omitted for this indexed field- getOmitTermFreqAndPositions() - Method in class org.apache.lucene.document.AbstractField
Deprecated.useAbstractField.getIndexOptions()
instead.- getOpDistance() - Method in class org.apache.lucene.queryParser.surround.query.DistanceQuery
- getOpDistance(String) - Static method in class org.apache.lucene.queryParser.surround.parser.QueryParser
- getOpenDeletedFiles() - Method in class org.apache.lucene.store.MockDirectoryWrapper
- getOpenMode() - Method in class org.apache.lucene.index.IndexWriterConfig
Returns theIndexWriterConfig.OpenMode
set byIndexWriterConfig.setOpenMode(OpenMode)
.- getOperand() - Method in class org.apache.lucene.queryParser.core.nodes.ParametricQueryNode
Deprecated.- getOperator() - Method in class org.apache.lucene.queryParser.core.nodes.ParametricQueryNode
Deprecated.- getOperator() - Method in interface org.apache.lucene.queryParser.standard.config.DefaultOperatorAttribute
Deprecated.- getOperator() - Method in class org.apache.lucene.queryParser.standard.config.DefaultOperatorAttributeImpl
Deprecated.- getOperatorName() - Method in class org.apache.lucene.queryParser.surround.query.ComposedQuery
- getOrCreateNode(CharSequence) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
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.- getOrderedTerms() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndex
Deprecated.- getOrdinal() - Method in class org.apache.lucene.facet.index.attributes.OrdinalProperty
- getOrdinal() - Method in interface org.apache.lucene.facet.search.results.FacetResultNode
Ordinal of the category of this result.- getOrdinal() - Method in class org.apache.lucene.facet.search.results.MutableFacetResultNode
- getOrdinal(CategoryPath) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyReader
- getOrdinal(CategoryPath) - Method in interface org.apache.lucene.facet.taxonomy.TaxonomyReader
getOrdinal() returns the ordinal of the category given as a path.- getOrdinal(CategoryPath) - Method in class org.apache.lucene.facet.taxonomy.writercache.cl2o.CompactLabelToOrdinal
- getOrdinal(CategoryPath) - Method in class org.apache.lucene.facet.taxonomy.writercache.cl2o.LabelToOrdinal
- getOrdinal(CategoryPath, int) - Method in class org.apache.lucene.facet.taxonomy.writercache.cl2o.CompactLabelToOrdinal
- getOrdinal(CategoryPath, int) - Method in class org.apache.lucene.facet.taxonomy.writercache.cl2o.LabelToOrdinal
- getOrdinalPolicy() - Method in class org.apache.lucene.facet.index.params.DefaultFacetIndexingParams
- getOrdinalPolicy() - Method in interface org.apache.lucene.facet.index.params.FacetIndexingParams
Get the policy for indexing category ordinals, used for deciding how "high" to climb in taxonomy from a category when ingesting its ordinals- 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.- getOversampleFactor() - Method in class org.apache.lucene.facet.search.sampling.SamplingParams
Return the oversampleFactor.- getParams() - Method in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
- getParent() - Method in class org.apache.lucene.benchmark.byTask.tasks.TaskSequence
- getParent() - Method in interface org.apache.lucene.queryParser.core.nodes.QueryNode
- getParent() - Method in class org.apache.lucene.queryParser.core.nodes.QueryNodeImpl
- getParent(int) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyReader
- getParent(int) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
- getParent(int) - Method in interface org.apache.lucene.facet.taxonomy.TaxonomyReader
getParent() returns the ordinal of the parent category of the category with the given ordinal.- 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.- getParentArray() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyReader
getParentArray() returns an int array of size getSize() listing the ordinal of the parent category of each category in the taxonomy.- getParentArray() - Method in interface org.apache.lucene.facet.taxonomy.TaxonomyReader
getParentArray() returns an int array of size getSize() listing the ordinal of the parent category of each category in the taxonomy.- getParentsStream(CategoryAttributesStream) - Method in class org.apache.lucene.facet.enhancements.EnhancementsDocumentBuilder
- getParentsStream(CategoryAttributesStream) - Method in class org.apache.lucene.facet.index.CategoryDocumentBuilder
Get a stream of categories which includes the parents, according to policies defined in indexing parameters.- getParser() - Method in class org.apache.lucene.search.FieldCacheRangeFilter
Returns the current numeric parser (null
forT
isString
}- getParser() - Method in class org.apache.lucene.search.SortField
Returns the instance of aFieldCache
parser that fits to the given sort type.- getParser(Analyzer) - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- getPartialExpunge() - Method in class org.apache.lucene.index.BalancedSegmentMergePolicy
Deprecated.- getPartialExpunge() - Method in class org.apache.lucene.index.BalancedSegmentMergePolicy.MergePolicyParams
Deprecated.- getPartitionSize() - Method in class org.apache.lucene.facet.index.params.DefaultFacetIndexingParams
- getPartitionSize() - Method in interface org.apache.lucene.facet.index.params.FacetIndexingParams
Get the partition size.- 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
- 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
- getPath(int) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyReader
- getPath(int) - Method in interface org.apache.lucene.facet.taxonomy.TaxonomyReader
getPath() returns the path name of the category with the given ordinal.- getPath(int, CategoryPath) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyReader
- getPath(int, CategoryPath) - Method in interface org.apache.lucene.facet.taxonomy.TaxonomyReader
getPath() returns the path name of the category with the given ordinal.- getPathElement(int) - Method in class org.apache.lucene.queryParser.core.nodes.PathQueryNode
Returns the a specific QueryText element- getPathElements() - Method in class org.apache.lucene.queryParser.core.nodes.PathQueryNode
Returns the a List with all QueryText elements- getPathElements(int) - Method in class org.apache.lucene.queryParser.core.nodes.PathQueryNode
Returns a List QueryText element from position startIndex- getPathPolicy() - Method in class org.apache.lucene.facet.index.params.DefaultFacetIndexingParams
- getPathPolicy() - Method in interface org.apache.lucene.facet.index.params.FacetIndexingParams
Get the policy for indexing category paths, used for deciding how "high" to climb in taxonomy from a category when ingesting its category paths.- getPattern(String) - Static method in class org.apache.lucene.analysis.compound.hyphenation.PatternParser
- getPause() - Method in class org.apache.lucene.index.MergePolicy.OneMerge
- getPayload() - Method in class org.apache.lucene.analysis.Token
Returns this Token's payload.- getPayload() - Method in interface org.apache.lucene.analysis.tokenattributes.PayloadAttribute
Returns this Token's payload.- getPayload() - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
Returns this Token's payload.- getPayload() - Method in class org.apache.lucene.search.spans.NearSpansOrdered
- getPayload() - Method in class org.apache.lucene.search.spans.NearSpansUnordered
WARNING: The List is not necessarily in order of the the positions- getPayload() - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery.PositionCheckSpan
- getPayload() - Method in class org.apache.lucene.search.spans.Spans
Returns the payload data for the current span.- getPayload() - Method in class org.apache.lucene.search.spans.TermSpans
- getPayload(byte[], int) - Method in class org.apache.lucene.index.FilterIndexReader.FilterTermPositions
- getPayload(byte[], int) - Method in class org.apache.lucene.index.MultipleTermPositions
Not implemented.- getPayload(byte[], int) - Method in interface org.apache.lucene.index.TermPositions
Returns the payload data at the current term position.- getPayload(byte[], int) - Method in class org.apache.lucene.store.instantiated.InstantiatedTermPositions
- getPayloadLength() - Method in class org.apache.lucene.facet.search.PayloadIterator
Get the length of the last read payload.- getPayloadLength() - Method in class org.apache.lucene.index.FilterIndexReader.FilterTermPositions
- getPayloadLength() - Method in class org.apache.lucene.index.MultipleTermPositions
Not implemented.- getPayloadLength() - Method in interface org.apache.lucene.index.TermPositions
Returns the length of the payload at the current term position.- getPayloadLength() - Method in class org.apache.lucene.store.instantiated.InstantiatedTermPositions
- getPayloadProcessorProvider() - Method in class org.apache.lucene.index.IndexWriter
Returns thePayloadProcessorProvider
that is used during segment merges to process payloads.- getPayloads() - Method in class org.apache.lucene.store.instantiated.InstantiatedTermDocumentInformation
- getPayloads(Spans[]) - Method in class org.apache.lucene.search.payloads.PayloadNearQuery.PayloadNearSpanScorer
- getPayloadScore() - Method in class org.apache.lucene.search.payloads.PayloadTermQuery.PayloadTermWeight.PayloadTermSpanScorer
The score for the payload- getPayloadsForQuery(Query) - Method in class org.apache.lucene.search.payloads.PayloadSpanUtil
Query should be rewritten for wild/fuzzy support.- getPayloadStream(CategoryPath, int) - Method in class org.apache.lucene.facet.index.streaming.CountingListTokenizer
- getPercentTermsToMatch() - Method in class org.apache.lucene.search.similar.MoreLikeThisQuery
- getPerfObject(String) - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
Returns an object that was previously set byPerfRunData.setPerfObject(String, Object)
.- getPhraseLimit() - Method in class org.apache.lucene.search.vectorhighlight.FastVectorHighlighter
- getPhraseSlop() - Method in class org.apache.lucene.queryParser.QueryParser
Gets the default slop for phrases.- getPhraseSlop() - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
Deprecated.- getPhraseSlop() - Method in class org.apache.lucene.queryParser.standard.StandardQueryParser
Gets the default slop for phrases.- getPointer() - Method in class org.apache.lucene.util.PagedBytes
- getPoints() - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
- 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.index.PositionBasedTermVectorMapper.TVPositionInfo
- 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.util.PagedBytes.PagedBytesDataInput
Returns the current byte position.- getPosition() - Method in class org.apache.lucene.util.PagedBytes.PagedBytesDataOutput
Return the current byte position.- getPositionIncrement() - Method in class org.apache.lucene.analysis.Token
Returns the position increment of this Token.- getPositionIncrement() - Method in interface org.apache.lucene.analysis.tokenattributes.PositionIncrementAttribute
Returns the position increment of this Token.- getPositionIncrement() - Method in class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
Returns the position increment of this Token.- getPositionIncrement() - Method in class org.apache.lucene.queryParser.core.nodes.FieldQueryNode
- getPositionIncrementGap(String) - Method in class org.apache.lucene.analysis.Analyzer
Invoked before indexing a Fieldable instance if terms have already been added to that field.- getPositionIncrementGap(String) - Method in class org.apache.lucene.analysis.LimitTokenCountAnalyzer
- getPositionIncrementGap(String) - Method in class org.apache.lucene.analysis.MockAnalyzer
- getPositionIncrementGap(String) - Method in class org.apache.lucene.analysis.PerFieldAnalyzerWrapper
Return the positionIncrementGap from the analyzer assigned to fieldName- getPositionLength() - Method in class org.apache.lucene.analysis.ja.Token
Get the length (in tokens) of this token.- getPositionLength() - Method in class org.apache.lucene.analysis.Token
Get the position length.- getPositionLength() - Method in interface org.apache.lucene.analysis.tokenattributes.PositionLengthAttribute
Returns the position length of this Token.- getPositionLength() - Method in class org.apache.lucene.analysis.tokenattributes.PositionLengthAttributeImpl
Returns the position length of this Token.- getPositions() - Method in class org.apache.lucene.index.TermVectorEntry
- getPositions() - Method in class org.apache.lucene.search.MultiPhraseQuery
Returns the relative positions of terms in this phrase.- getPositions() - Method in class org.apache.lucene.search.PhraseQuery
Returns the relative positions of terms in this phrase.- getPositions() - Method in class org.apache.lucene.search.SpanFilterResult
The first entry in the array corresponds to the first "on" bit.- getPositions() - Method in class org.apache.lucene.search.SpanFilterResult.PositionInfo
- getPositions() - Method in class org.apache.lucene.search.spans.TermSpans
- getPositionSpans() - Method in class org.apache.lucene.search.highlight.WeightedSpanTerm
- 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
- getPrecision() - Method in class org.apache.lucene.spatial.tier.DistanceHandler
Deprecated.- getPrecision(double, DistanceHandler.Precision) - Static method in class org.apache.lucene.spatial.tier.DistanceHandler
Deprecated.- getPrecisionAt(int) - Method in class org.apache.lucene.benchmark.quality.QualityStats
Return the precision at rank n: |{relevant hits within firstn
hits}| /n
.- getPrecisionStep() - Method in class org.apache.lucene.analysis.NumericTokenStream
Returns the precision step.- getPrecisionStep() - Method in class org.apache.lucene.document.NumericField
Returns the precision step.- getPrecisionStep() - Method in class org.apache.lucene.queryParser.standard.config.NumericConfig
Returns the precision used to index the numeric values- getPrecisionStep() - Method in class org.apache.lucene.search.NumericRangeFilter
Returns the precision step.- getPrecisionStep() - Method in class org.apache.lucene.search.NumericRangeQuery
Returns the precision step.- getPrefix() - Method in class org.apache.lucene.analysis.miscellaneous.PrefixAwareTokenFilter
- getPrefix() - Method in class org.apache.lucene.queryParser.surround.query.SrndPrefixQuery
- getPrefix() - Method in class org.apache.lucene.search.PrefixFilter
- getPrefix() - Method in class org.apache.lucene.search.PrefixQuery
Returns the prefix of this query.- getPrefixes() - Method in class org.apache.lucene.analysis.hunspell.HunspellStemmer.Stem
Returns the list of prefixes used to generate the stem- getPrefixLength() - Method in class org.apache.lucene.queryParser.core.nodes.FuzzyQueryNode
- getPrefixLength() - Method in interface org.apache.lucene.queryParser.standard.config.FuzzyAttribute
Deprecated.- getPrefixLength() - Method in class org.apache.lucene.queryParser.standard.config.FuzzyAttributeImpl
Deprecated.- getPrefixLength() - Method in class org.apache.lucene.queryParser.standard.config.FuzzyConfig
- getPrefixLength() - Method in class org.apache.lucene.search.FuzzyQuery
Returns the non-fuzzy prefix length.- getPrefixQuery(String, boolean) - Method in class org.apache.lucene.queryParser.surround.parser.QueryParser
- getPrefixQuery(String, String) - Method in class org.apache.lucene.queryParser.analyzing.AnalyzingQueryParser
Called when parser parses an input term token that uses prefix notation; that is, contains a single '*' wildcard character as its last character.- getPrefixQuery(String, String) - Method in class org.apache.lucene.queryParser.MultiFieldQueryParser
- getPrefixQuery(String, String) - Method in class org.apache.lucene.queryParser.QueryParser
Factory method for generating a query (similar toQueryParser.getWildcardQuery(java.lang.String, java.lang.String)
).- getPrefixQuery(String, String) - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
Deprecated.- getPrefixSeparator() - Method in class org.apache.lucene.queryParser.surround.query.ComposedQuery
- getPrefixTerm() - Method in class org.apache.lucene.search.PrefixTermEnum
- getPreTag(int) - Method in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
- getPreTag(String[], int) - Method in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
- getPreviousTokenStream() - Method in class org.apache.lucene.analysis.Analyzer
Used by Analyzers that implement reusableTokenStream to retrieve previously saved TokenStreams for re-use by the same thread.- getPrimaryDir() - Method in class org.apache.lucene.store.FileSwitchDirectory
Return the primary directory- getProcessingMode() - Method in class org.apache.lucene.search.DuplicateFilter
- getProcessor(Term) - Method in class org.apache.lucene.facet.index.FacetsPayloadProcessorProvider.FacetsDirPayloadProcessor
- getProcessor(Term) - Method in class org.apache.lucene.index.PayloadProcessorProvider.ReaderPayloadProcessor
Returns aPayloadProcessorProvider.PayloadProcessor
for the given term.- 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
- 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
- getProperty(Class<? extends CategoryProperty>) - Method in interface org.apache.lucene.facet.index.attributes.CategoryAttribute
Get a property of a certain property class.- getProperty(Class<? extends CategoryProperty>) - Method in class org.apache.lucene.facet.index.attributes.CategoryAttributeImpl
- getProperty(Collection<Class<? extends CategoryProperty>>) - Method in interface org.apache.lucene.facet.index.attributes.CategoryAttribute
Get a property of one of given property classes.- getProperty(Collection<Class<? extends CategoryProperty>>) - Method in class org.apache.lucene.facet.index.attributes.CategoryAttributeImpl
- getPropertyClasses() - Method in interface org.apache.lucene.facet.index.attributes.CategoryAttribute
Get all the active property classes.- getPropertyClasses() - Method in class org.apache.lucene.facet.index.attributes.CategoryAttributeImpl
- getProps() - Method in class org.apache.lucene.benchmark.byTask.feeds.DocData
- getProximityType() - Method in class org.apache.lucene.queryParser.core.nodes.ProximityQueryNode
- getQuery() - Method in exception org.apache.lucene.queryParser.core.QueryNodeParseException
- getQuery() - Method in class org.apache.lucene.search.BooleanClause
- getQuery() - Method in class org.apache.lucene.search.BooleanQuery.BooleanWeight
- getQuery() - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantWeight
- getQuery() - Method in class org.apache.lucene.search.ConstantScoreQuery
Returns the encapsulated query, returnsnull
if a filter is wrapped.- getQuery() - Method in class org.apache.lucene.search.DisjunctionMaxQuery.DisjunctionMaxWeight
Return our associated DisjunctionMaxQuery- getQuery() - Method in class org.apache.lucene.search.FilteredQuery
- getQuery() - Method in class org.apache.lucene.search.SpanQueryFilter
- getQuery() - Method in class org.apache.lucene.search.spans.SpanWeight
- getQuery() - Method in class org.apache.lucene.search.Weight
The query that this concerns.- getQuery(String, Analyzer) - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- getQuery(Query) - Method in class org.apache.lucene.spatial.tier.DistanceQueryBuilder
Deprecated.- getQuery(Element) - Method in class org.apache.lucene.xmlparser.builders.BooleanQueryBuilder
- getQuery(Element) - Method in class org.apache.lucene.xmlparser.builders.BoostingQueryBuilder
- getQuery(Element) - Method in class org.apache.lucene.xmlparser.builders.ConstantScoreQueryBuilder
- getQuery(Element) - Method in class org.apache.lucene.xmlparser.builders.FilteredQueryBuilder
- getQuery(Element) - Method in class org.apache.lucene.xmlparser.builders.FuzzyLikeThisQueryBuilder
- getQuery(Element) - Method in class org.apache.lucene.xmlparser.builders.LikeThisQueryBuilder
- getQuery(Element) - Method in class org.apache.lucene.xmlparser.builders.MatchAllDocsQueryBuilder
- getQuery(Element) - Method in class org.apache.lucene.xmlparser.builders.NumericRangeQueryBuilder
- getQuery(Element) - Method in class org.apache.lucene.xmlparser.builders.SpanBuilderBase
- getQuery(Element) - Method in class org.apache.lucene.xmlparser.builders.SpanQueryBuilderFactory
- getQuery(Element) - Method in class org.apache.lucene.xmlparser.builders.TermQueryBuilder
- getQuery(Element) - Method in class org.apache.lucene.xmlparser.builders.TermsQueryBuilder
- getQuery(Element) - Method in class org.apache.lucene.xmlparser.builders.UserInputQueryBuilder
- getQuery(Element) - Method in class org.apache.lucene.xmlparser.CoreParser
- getQuery(Element) - Method in interface org.apache.lucene.xmlparser.QueryBuilder
- getQuery(Element) - Method in class org.apache.lucene.xmlparser.QueryBuilderFactory
- getQueryAsDOM(Properties) - Method in class org.apache.lucene.xmlparser.QueryTemplateManager
- getQueryAsDOM(Properties, InputStream) - Static method in class org.apache.lucene.xmlparser.QueryTemplateManager
Slow means of constructing query - parses stylesheet from input stream- getQueryAsDOM(Properties, String) - Method in class org.apache.lucene.xmlparser.QueryTemplateManager
- getQueryAsDOM(Properties, Templates) - Static method in class org.apache.lucene.xmlparser.QueryTemplateManager
Fast means of constructing query using a cached,precompiled stylesheet- getQueryAsXmlString(Properties) - Method in class org.apache.lucene.xmlparser.QueryTemplateManager
- getQueryAsXmlString(Properties, InputStream) - Static method in class org.apache.lucene.xmlparser.QueryTemplateManager
Slow means of constructing query parsing a stylesheet from an input stream- getQueryAsXmlString(Properties, String) - Method in class org.apache.lucene.xmlparser.QueryTemplateManager
- getQueryAsXmlString(Properties, Templates) - Static method in class org.apache.lucene.xmlparser.QueryTemplateManager
Fast means of constructing query using a precompiled stylesheet- getQueryBuilder() - Method in class org.apache.lucene.queryParser.core.QueryParserHelper
Returns the query builder used to build a object from the query node tree.- getQueryBuilder(String) - Method in class org.apache.lucene.xmlparser.QueryBuilderFactory
- getQueryConfigHandler() - Method in interface org.apache.lucene.queryParser.core.processors.QueryNodeProcessor
Returns theQueryConfigHandler
associated to the query tree if any, otherwise it returnsnull
- getQueryConfigHandler() - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorImpl
For reference about this method check:QueryNodeProcessor.getQueryConfigHandler()
.- getQueryConfigHandler() - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorPipeline
For reference about this method check:QueryNodeProcessor.getQueryConfigHandler()
.- getQueryConfigHandler() - Method in class org.apache.lucene.queryParser.core.QueryParserHelper
Returns the query configuration handler, which is used during the query node tree processing.- getQueryConfigHandler() - Method in class org.apache.lucene.queryParser.standard.processors.BooleanQuery2ModifierNodeProcessor
- getQueryConfigHandler() - Method in class org.apache.lucene.queryParser.standard.processors.GroupQueryNodeProcessor
Deprecated.- getQueryConfigHandler() - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
Deprecated.Returns the query config handler used by this query parser- getQueryDOA(String, Analyzer) - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- getQueryID() - Method in class org.apache.lucene.benchmark.quality.QualityQuery
Return the ID of this query.- 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
- getQueryMaker(ReadTask) - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
- getQueryNodeProcessor() - Method in class org.apache.lucene.queryParser.core.QueryParserHelper
Returns the processor object used to process the query node tree, it returnsnull
if no processor is used.- getQueryProcessor() - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
Deprecated.ReturnsQueryNodeProcessor
used to process the query node tree generated by theStandardSyntaxParser
.- getQuote() - Method in class org.apache.lucene.queryParser.surround.query.SimpleTerm
- getRAMBufferSizeMB() - Method in class org.apache.lucene.index.IndexWriter
Deprecated.useIndexWriterConfig.getRAMBufferSizeMB()
instead.- getRAMBufferSizeMB() - Method in class org.apache.lucene.index.IndexWriterConfig
Returns the value set byIndexWriterConfig.setRAMBufferSizeMB(double)
if enabled.- getRandomIOExceptionRate() - Method in class org.apache.lucene.store.MockDirectoryWrapper
- getRangeCollator() - Method in class org.apache.lucene.queryParser.QueryParser
- getRangeCollator() - Method in interface org.apache.lucene.queryParser.standard.config.RangeCollatorAttribute
Deprecated.- getRangeCollator() - Method in class org.apache.lucene.queryParser.standard.config.RangeCollatorAttributeImpl
Deprecated.- getRangeCollator() - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
Deprecated.- getRangeCollator() - Method in class org.apache.lucene.queryParser.standard.StandardQueryParser
- getRangeQuery(String, String, String, boolean) - Method in class org.apache.lucene.queryParser.analyzing.AnalyzingQueryParser
Overrides super class, by passing terms through analyzer.- getRangeQuery(String, String, String, boolean) - Method in class org.apache.lucene.queryParser.complexPhrase.ComplexPhraseQueryParser
- getRangeQuery(String, String, String, boolean) - Method in class org.apache.lucene.queryParser.MultiFieldQueryParser
- getRangeQuery(String, String, String, boolean) - Method in class org.apache.lucene.queryParser.QueryParser
- getRangeQuery(String, String, String, boolean) - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
Deprecated.- 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- getReadChunkSize() - Method in class org.apache.lucene.store.FSDirectory
The maximum number of bytes to read at once from the underlying file duringDataInput.readBytes(byte[], int, int)
.- getReader() - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParser
- getReader() - Method in class org.apache.lucene.index.IndexWriter
Deprecated.Please useIndexReader.open(IndexWriter,boolean)
instead.- getReader() - Method in class org.apache.lucene.index.RandomIndexWriter
- getReader(boolean) - Method in class org.apache.lucene.index.RandomIndexWriter
- getReader(int) - Method in class org.apache.lucene.index.IndexWriter
Deprecated.Please useIndexReader.open(IndexWriter,boolean)
instead. Furthermore, this method cannot guarantee the reader (and its sub-readers) will be opened with the termInfosIndexDivisor setting because some of them may have already been opened according toIndexWriterConfig.setReaderTermsIndexDivisor(int)
. You should set the requested termInfosIndexDivisor throughIndexWriterConfig.setReaderTermsIndexDivisor(int)
and useIndexWriter.getReader()
.- getReader(DataInput) - Static method in class org.apache.lucene.util.packed.PackedInts
Retrieve PackedInt data from the DataInput and return a packed int structure based on it.- getReaderForField(String) - Method in class org.apache.lucene.search.highlight.WeightedSpanTermExtractor
- getReaderKey() - Method in class org.apache.lucene.search.FieldCache.CacheEntry
- getReaderPooling() - Method in class org.apache.lucene.index.IndexWriterConfig
Returns true if IndexWriter should pool readers even ifIndexWriter.getReader()
has not been called.- getReaderProcessor(IndexReader) - Method in class org.apache.lucene.facet.index.FacetsPayloadProcessorProvider
- getReaderProcessor(IndexReader) - Method in class org.apache.lucene.index.PayloadProcessorProvider
Returns aPayloadProcessorProvider.ReaderPayloadProcessor
for the givenDirectory
, through whichPayloadProcessorProvider.PayloadProcessor
s can be obtained for eachTerm
, ornull
if none should be used.- getReaderTermsIndexDivisor() - Method in class org.apache.lucene.index.IndexWriter
Deprecated.useIndexWriterConfig.getReaderTermsIndexDivisor()
instead.- getReaderTermsIndexDivisor() - Method in class org.apache.lucene.index.IndexWriterConfig
- 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(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
- 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.- getRecallPoints() - Method in class org.apache.lucene.benchmark.quality.QualityStats
Returns the recallPoints.- getReclaimDeletesWeight() - Method in class org.apache.lucene.index.TieredMergePolicy
- 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.- getRecomputedCount() - Method in class org.apache.lucene.util.BitVector
For testing- 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() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyReader
Expert: returns the current refCount for this taxonomy reader- getRefCount() - Method in interface org.apache.lucene.facet.taxonomy.TaxonomyReader
Expert: 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- getRegexImplementation() - Method in class org.apache.lucene.search.regex.RegexQuery
- getRegexImplementation() - Method in interface org.apache.lucene.search.regex.RegexQueryCapable
- getRegexImplementation() - Method in class org.apache.lucene.search.regex.SpanRegexQuery
Deprecated.- 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.- getResidue() - Method in interface org.apache.lucene.facet.search.results.FacetResultNode
Value of screened out sub results.- getResidue() - Method in class org.apache.lucene.facet.search.results.MutableFacetResultNode
- 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
- getResultMode() - Method in class org.apache.lucene.facet.search.params.FacetRequest
Return the requested result mode.- getResults() - Method in class org.apache.lucene.search.suggest.Lookup.LookupPriorityQueue
Returns the top N results in descending order.- getRetainableProperties() - Method in class org.apache.lucene.facet.enhancements.params.DefaultEnhancementsIndexingParams
- getRetainableProperties() - Method in interface org.apache.lucene.facet.enhancements.params.EnhancementsIndexingParams
Get a list ofCategoryProperty
classes to be retained when creatingCategoryParentsStream
.- getRetainableProperty() - Method in class org.apache.lucene.facet.enhancements.association.AssociationEnhancement
- getRetainableProperty() - Method in interface org.apache.lucene.facet.enhancements.CategoryEnhancement
Get aCategoryProperty
class to be retained when creatingCategoryParentsStream
.- 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
- getRomanization(Appendable, CharSequence) - Static method in class org.apache.lucene.analysis.ja.util.ToStringUtil
Romanize katakana with modified hepburn- getRomanization(String) - Static method in class org.apache.lucene.analysis.ja.util.ToStringUtil
Romanize katakana with modified hepburn- getRound() - Method in class org.apache.lucene.benchmark.byTask.stats.TaskStats
- getRoundedFixedSize(int) - Static method in class org.apache.lucene.util.packed.PackedInts
Possibly wastes some storage in exchange for faster lookups- getRoundNumber() - Method in class org.apache.lucene.benchmark.byTask.utils.Config
- getRows() - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.Matrix.Column
Deprecated.- 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
- getRunningMerge() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler.MergeThread
- getSampleFixer(IndexReader, TaxonomyReader, FacetSearchParams) - Method in class org.apache.lucene.facet.search.sampling.Sampler
Get a fixer of sample facet accumulation results.- getSampler() - Method in class org.apache.lucene.facet.search.AdaptiveFacetsAccumulator
- getSampleRatio() - Method in class org.apache.lucene.facet.search.sampling.SamplingParams
- getSampleSet(ScoredDocIDs) - Method in class org.apache.lucene.facet.search.sampling.Sampler
Compute a sample set out of the input set, based on theSamplingParams.getSampleRatio()
in effect.- getSamplingParams() - Method in class org.apache.lucene.facet.search.sampling.Sampler
Return the sampling params in effect- getSamplingThreshold() - Method in class org.apache.lucene.facet.search.sampling.SamplingParams
Return the samplingThreshold.- getSchema() - Method in class org.apache.lucene.queryParser.core.nodes.OpaqueQueryNode
- getScore() - Method in interface org.apache.lucene.facet.search.ScoredDocIDsIterator
Returns the score of the current document.- getScore() - Method in class org.apache.lucene.search.highlight.TextFragment
- getScore(int) - Method in class org.apache.lucene.search.highlight.TokenGroup
- getScoredDocIDs() - Method in class org.apache.lucene.facet.search.ScoredDocIdCollector
- getSearchables() - Method in class org.apache.lucene.search.MultiSearcher
Deprecated.Return the array ofSearchable
s this searches.- 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- getSegmentCount() - Method in class org.apache.lucene.index.IndexCommit
Returns number of segments referenced by this commit.- getSegmentCount() - Method in class org.apache.lucene.index.SnapshotDeletionPolicy.SnapshotCommitPoint
- getSegmentName() - Method in class org.apache.lucene.index.SegmentReader
Return the name of the segment this reader is reading.- getSegmentsFileName() - Method in class org.apache.lucene.index.IndexCommit
Get the segments file (segments_N
) associated with this commit point.- getSegmentsFileName() - Method in class org.apache.lucene.index.SegmentInfos
Get the segments_N filename in use by this segment infos.- getSegmentsFileName() - Method in class org.apache.lucene.index.SnapshotDeletionPolicy.SnapshotCommitPoint
- getSegmentsPerTier() - Method in class org.apache.lucene.index.TieredMergePolicy
- getSentinelObject() - Method in class org.apache.lucene.util.PriorityQueue
This method can be overridden by extending classes to return a sentinel object which will be used byPriorityQueue.initialize(int)
to fill the queue, so that the code which uses that queue can always assume it's full and only change the top without attempting to insert any new object.
Those sentinel values should always compare worse than any non-sentinel value (i.e.,PriorityQueue.lessThan(T, T)
should always favor the non-sentinel values).
By default, this method returns false, which means the queue will not be filled with sentinel values.- getSeqnum() - Method in class org.apache.lucene.search.vectorhighlight.FieldFragList.WeightedFragInfo.SubInfo
- getSequentialSubReaders() - Method in class org.apache.lucene.index.FilterIndexReader
- getSequentialSubReaders() - Method in class org.apache.lucene.index.IndexReader
Expert: returns the sequential sub readers that this reader is logically composed of.- getSequentialSubReaders() - Method in class org.apache.lucene.index.MultiReader
- getSequentialSubReaders() - Method in class org.apache.lucene.index.PruningReader
- getSequentialSubReaders() - Method in class org.apache.lucene.index.SlowMultiReaderWrapper
- getShapeLoop(Shape, CartesianTierPlotter, double, double, double, double) - Method in class org.apache.lucene.spatial.tier.CartesianPolyFilterBuilder
Deprecated.- 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
- getShorts(IndexReader, String) - Method in interface org.apache.lucene.search.FieldCache
Checks the internal cache for an appropriate entry, and if none is found, reads the terms infield
as shorts and returns an array of sizereader.maxDoc()
of the value each document has in the given field.- getShorts(IndexReader, String, FieldCache.ShortParser) - Method in interface org.apache.lucene.search.FieldCache
Checks the internal cache for an appropriate entry, and if none is found, reads the terms infield
as shorts and returns an array of sizereader.maxDoc()
of the value each document has in the given field.- getShorts(IndexReader, String, FieldCache.ShortParser, boolean) - Method in interface org.apache.lucene.search.FieldCache
Checks the internal cache for an appropriate entry, and if none is found, reads the terms infield
as shorts and returns an array of sizereader.maxDoc()
of the value each document has in the given field.- getShrinkSize(int, int, int) - Static method in class org.apache.lucene.util.ArrayUtil
- getSide(String) - Static method in enum org.apache.lucene.analysis.ngram.EdgeNGramTokenFilter.Side
- getSide(String) - Static method in enum org.apache.lucene.analysis.ngram.EdgeNGramTokenizer.Side
- getSimilarity() - Method in class org.apache.lucene.index.IndexWriter
Deprecated.useIndexWriterConfig.getSimilarity()
instead- getSimilarity() - Method in class org.apache.lucene.index.IndexWriterConfig
Expert: returns theSimilarity
implementation used by this IndexWriter.- getSimilarity() - Method in class org.apache.lucene.queryParser.core.nodes.FuzzyQueryNode
- getSimilarity() - Method in class org.apache.lucene.search.IndexSearcher
- getSimilarity() - Method in class org.apache.lucene.search.ScoreCachingWrappingScorer
- getSimilarity() - Method in class org.apache.lucene.search.Scorer
Deprecated.Store any Similarity you might need privately in your implementation instead.- getSimilarity() - Method in class org.apache.lucene.search.Searcher
Deprecated.Expert: Return the Similarity implementation used by this Searcher.- getSimilarity() - Method in class org.apache.lucene.search.similar.MoreLikeThis
- getSimilarity() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexWriter
Deprecated.- getSimilarity(Searcher) - Method in class org.apache.lucene.search.Query
Deprecated.Instead of using "runtime" subclassing/delegation, subclass the Weight instead.- getSingleton() - Static method in class org.apache.lucene.facet.search.TotalFacetCountsCache
Get the single instance of this cache- getSingleton() - Static method in class org.apache.lucene.util.fst.ByteSequenceOutputs
- getSingleton() - Static method in class org.apache.lucene.util.fst.IntSequenceOutputs
- getSingleton() - Static method in class org.apache.lucene.util.fst.NoOutputs
- getSingleton(boolean) - Static method in class org.apache.lucene.util.fst.PositiveIntOutputs
- getSingleton(boolean) - Static method in class org.apache.lucene.util.fst.UpToTwoPositiveIntOutputs
- getSize() - Method in class org.apache.lucene.benchmark.byTask.stats.Report
Returns number of lines in the report.- getSize() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyReader
- getSize() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
getSize() returns the number of categories in the taxonomy.- getSize() - Method in interface org.apache.lucene.facet.taxonomy.TaxonomyReader
getSize() 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- getSizeInBytes() - Method in class org.apache.lucene.store.RAMFile
- getSlop() - Method in class org.apache.lucene.search.MultiPhraseQuery
Sets the phrase slop for this query.- getSlop() - Method in class org.apache.lucene.search.PhraseQuery
Returns the slop.- getSlop() - Method in class org.apache.lucene.search.spans.SpanNearQuery
Return the maximum number of intervening unmatched positions permitted.- getSlop() - Method in class org.apache.lucene.search.vectorhighlight.FieldQuery.QueryPhraseMap
- getSlot(int) - Method in class org.apache.lucene.search.grouping.SentinelIntSet
returns the slot for this key- getSnapshot(String) - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
Get a snapshotted IndexCommit by ID.- getSnapshots() - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
Get all the snapshots in a map of snapshot IDs to the segments they 'cover.' This can be passed toSnapshotDeletionPolicy(IndexDeletionPolicy, Map)
in order to initialize snapshots at construction.- getSnowballWordSet(Reader, CharArraySet) - Static method in class org.apache.lucene.analysis.WordlistLoader
Reads stopwords from a stopword list in Snowball format.- getSnowballWordSet(Reader, Version) - Static method in class org.apache.lucene.analysis.WordlistLoader
Reads stopwords from a stopword list in Snowball format.- getSort() - Method in class org.apache.lucene.benchmark.byTask.tasks.ReadTask
- getSort() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchWithSortTask
- getSort() - Method in class org.apache.lucene.search.Sort
Representation of the sort criteria.- getSortBy() - Method in class org.apache.lucene.facet.search.params.FacetRequest
Specify how should results be sorted.- getSortOrder() - Method in class org.apache.lucene.facet.search.params.FacetRequest
Return the requested order of results.- getSpacerCharacter() - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter
Deprecated.- getSpanNearQuery(IndexReader, String, float, BasicQueryFactory) - Method in class org.apache.lucene.queryParser.surround.query.DistanceQuery
- getSpanQuery(Element) - Method in class org.apache.lucene.xmlparser.builders.BoostingTermBuilder
- getSpanQuery(Element) - Method in class org.apache.lucene.xmlparser.builders.SpanFirstBuilder
- getSpanQuery(Element) - Method in class org.apache.lucene.xmlparser.builders.SpanNearBuilder
- getSpanQuery(Element) - Method in class org.apache.lucene.xmlparser.builders.SpanNotBuilder
- getSpanQuery(Element) - Method in class org.apache.lucene.xmlparser.builders.SpanOrBuilder
- getSpanQuery(Element) - Method in class org.apache.lucene.xmlparser.builders.SpanOrTermsBuilder
- getSpanQuery(Element) - Method in interface org.apache.lucene.xmlparser.builders.SpanQueryBuilder
- getSpanQuery(Element) - Method in class org.apache.lucene.xmlparser.builders.SpanQueryBuilderFactory
- getSpanQuery(Element) - Method in class org.apache.lucene.xmlparser.builders.SpanTermBuilder
- getSpans(IndexReader) - Method in class org.apache.lucene.search.spans.FieldMaskingSpanQuery
- getSpans(IndexReader) - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper
- getSpans(IndexReader) - Method in class org.apache.lucene.search.spans.SpanNearQuery
- getSpans(IndexReader) - Method in class org.apache.lucene.search.spans.SpanNotQuery
- getSpans(IndexReader) - Method in class org.apache.lucene.search.spans.SpanOrQuery
- getSpans(IndexReader) - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery
- getSpans(IndexReader) - Method in class org.apache.lucene.search.spans.SpanQuery
Expert: Returns the matches for this query in an index.- getSpans(IndexReader) - Method in class org.apache.lucene.search.spans.SpanTermQuery
- getSpanScore() - Method in class org.apache.lucene.search.payloads.PayloadTermQuery.PayloadTermWeight.PayloadTermSpanScorer
Returns the SpanScorer score only.- getStart() - Method in class org.apache.lucene.analysis.util.CharArrayIterator
- getStart() - Method in class org.apache.lucene.search.SpanFilterResult.StartEnd
The Start position- getStart() - Method in class org.apache.lucene.search.spans.SpanPositionRangeQuery
- getStartOffset() - Method in class org.apache.lucene.index.TermVectorOffsetInfo
The accessor for the starting offset of the term.- getStartOffset() - Method in class org.apache.lucene.search.highlight.TokenGroup
- 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
- getStartPos() - Method in class org.apache.lucene.util.UnsafeByteArrayOutputStream
Returns the start position data was written to.- getStarts() - Method in class org.apache.lucene.search.MultiSearcher
Deprecated.- getStartTimeMillis() - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
- getStem() - Method in class org.apache.lucene.analysis.hunspell.HunspellStemmer.Stem
Returns the actual word stem itself- getStemDict(Reader, CharArrayMap<String>) - Static method in class org.apache.lucene.analysis.WordlistLoader
Reads a stem dictionary.- getStemLength() - Method in class org.apache.lucene.analysis.hunspell.HunspellStemmer.Stem
- getStemString() - Method in class org.apache.lucene.analysis.hunspell.HunspellStemmer.Stem
- 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.search.similar.MoreLikeThis
Get the current stop words being used.- getStopWords() - Method in class org.apache.lucene.search.similar.MoreLikeThisQuery
- getStopWords(String) - Method in class org.apache.lucene.analysis.query.QueryAutoStopWordAnalyzer
Provides information on which stop words have been identified for a field- 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- getStringDistance() - Method in class org.apache.lucene.search.spell.SpellChecker
Returns theStringDistance
instance used by thisSpellChecker
instance.- getStringIndex(IndexReader, String) - Method in interface org.apache.lucene.search.FieldCache
Checks the internal cache for an appropriate entry, and if none is found reads the term values infield
and returns an array of them in natural order, along with an array telling which element in the term array each document uses.- getStrings(IndexReader, String) - Method in interface org.apache.lucene.search.FieldCache
Checks the internal cache for an appropriate entry, and if none is found, reads the term values infield
and returns an array of sizereader.maxDoc()
containing the value each document has in the given field.- getStrip() - Method in class org.apache.lucene.analysis.hunspell.HunspellAffix
Returns the stripping characters defined for the affix- getSubInfos() - Method in class org.apache.lucene.search.vectorhighlight.FieldFragList.WeightedFragInfo
- getSubQueriesIterator() - Method in class org.apache.lucene.queryParser.surround.query.ComposedQuery
- getSubQuery(int) - Method in class org.apache.lucene.queryParser.surround.query.ComposedQuery
- getSubReaders() - Method in class org.apache.lucene.search.IndexSearcher
Returns the atomic subReaders used by this searcher.- getSubResults() - Method in interface org.apache.lucene.facet.search.results.FacetResultNode
Contained sub results.- getSubResults() - Method in class org.apache.lucene.facet.search.results.MutableFacetResultNode
- getSubSpans() - Method in class org.apache.lucene.search.spans.NearSpansOrdered
- getSubSpans() - Method in class org.apache.lucene.search.spans.NearSpansUnordered
- getSuffix() - Method in class org.apache.lucene.analysis.miscellaneous.PrefixAwareTokenFilter
- GetSuffix(int) - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
Get the suffix.- GetSuffix(int) - Method in interface org.apache.lucene.queryParser.CharStream
Returns an array of characters that make up the suffix of length 'len' for the currently matched token.- GetSuffix(int) - Method in class org.apache.lucene.queryParser.FastCharStream
- GetSuffix(int) - Method in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
- 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
- getSuffixes() - Method in class org.apache.lucene.analysis.hunspell.HunspellStemmer.Stem
Returns the list of suffixes used to generate the stem- getSuffixOperator() - Method in class org.apache.lucene.queryParser.surround.query.SrndPrefixQuery
- getSummary() - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParser
- getSummary() - Method in class org.apache.lucene.search.ComplexExplanation
- getSummary() - Method in class org.apache.lucene.search.Explanation
A short one line summary which should contain all high level information about this Explanation, without the "Details"- getSupportedFeatures() - Static method in class org.apache.lucene.util.RamUsageEstimator
Return the set of supported JVM features that improve the estimation.- getSurfaceForm() - Method in class org.apache.lucene.analysis.ja.Token
- getSurfaceFormString() - Method in class org.apache.lucene.analysis.ja.Token
- getSyntaxParser() - Method in class org.apache.lucene.queryParser.core.QueryParserHelper
Returns the text parser used to build a query node tree from a query string.- getTabSize(int) - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
- getTabSize(int) - Method in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
- getTag(CharSequence) - Method in interface org.apache.lucene.queryParser.core.nodes.QueryNode
Deprecated.useQueryNode.getTag(String)
instead- getTag(CharSequence) - Method in class org.apache.lucene.queryParser.core.nodes.QueryNodeImpl
Deprecated.useQueryNodeImpl.getTag(String)
instead- getTag(String) - Method in interface org.apache.lucene.queryParser.core.nodes.QueryNode
- getTag(String) - Method in class org.apache.lucene.queryParser.core.nodes.QueryNodeImpl
- getTagMap() - Method in interface org.apache.lucene.queryParser.core.nodes.QueryNode
Returns a map containing all tags attached to this query node.- getTagMap() - Method in class org.apache.lucene.queryParser.core.nodes.QueryNodeImpl
Returns a map containing all tags attached to this query node.- getTags() - Method in interface org.apache.lucene.queryParser.core.nodes.QueryNode
Deprecated.- getTags() - Method in class org.apache.lucene.queryParser.core.nodes.QueryNodeImpl
Deprecated.useQueryNodeImpl.getTagMap()
instead- 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
- getTaxonomyReader() - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
- getTaxonomyReader() - Method in class org.apache.lucene.facet.search.FacetResultsHandler
Return taxonomy reader used for current facets accumulation operation.- getTaxonomyWriter() - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
- getTempDir(String) - Static method in class org.apache.lucene.util._TestUtil
Returns temp dir, based on String arg in its name; does not create the directory.- getTemplates(InputStream) - Static method in class org.apache.lucene.xmlparser.QueryTemplateManager
Parses a query stylesheet for repeated use- getTerm() - Method in class org.apache.lucene.facet.index.params.CategoryListParams
ATerm
who's payload holds the category-list.- getTerm() - Method in class org.apache.lucene.index.TermVectorEntry
- getTerm() - Method in class org.apache.lucene.search.FuzzyQuery
Returns the pattern term.- getTerm() - Method in class org.apache.lucene.search.highlight.WeightedTerm
- getTerm() - Method in class org.apache.lucene.search.regex.RegexQuery
- getTerm() - Method in class org.apache.lucene.search.regex.SpanRegexQuery
Deprecated.- getTerm() - Method in class org.apache.lucene.search.spans.SpanTermQuery
Return the term whose spans are matched.- getTerm() - Method in class org.apache.lucene.search.TermQuery
Returns the term of this query.- getTerm() - Method in class org.apache.lucene.search.WildcardQuery
Returns the pattern term.- getTerm() - Method in class org.apache.lucene.store.instantiated.InstantiatedTerm
- getTerm() - Method in class org.apache.lucene.store.instantiated.InstantiatedTermDocumentInformation
- getTermArrays() - Method in class org.apache.lucene.search.MultiPhraseQuery
Returns a List of the terms in the multiphrase.- getTermCount() - Method in class org.apache.lucene.util.fst.Builder
- getTermDocumentInformations() - Method in class org.apache.lucene.store.instantiated.InstantiatedTermFreqVector
- getTermEnum(String) - Method in class org.apache.lucene.queryParser.surround.query.SpanNearClauseFactory
- getTermEscaped(EscapeQuerySyntax) - Method in class org.apache.lucene.queryParser.core.nodes.FieldQueryNode
- getTermEscaped(EscapeQuerySyntax) - Method in class org.apache.lucene.queryParser.standard.nodes.NumericQueryNode
This method is used to get the value converted toString
and escaped using the givenEscapeQuerySyntax
.- getTermEscapeQuoted(EscapeQuerySyntax) - Method in class org.apache.lucene.queryParser.core.nodes.FieldQueryNode
- getTermFrequencies() - Method in interface org.apache.lucene.index.TermFreqVector
Array of term frequencies.- getTermFrequencies() - Method in class org.apache.lucene.search.QueryTermVector
- getTermFrequencies() - Method in class org.apache.lucene.store.instantiated.InstantiatedTermFreqVector
- getTermFreqVector(int, String) - Method in class org.apache.lucene.index.FilterIndexReader
- getTermFreqVector(int, String) - Method in class org.apache.lucene.index.IndexReader
Return a term frequency vector for the specified document and field.- getTermFreqVector(int, String) - Method in class org.apache.lucene.index.MultiReader
- getTermFreqVector(int, String) - Method in class org.apache.lucene.index.ParallelReader
- getTermFreqVector(int, String) - Method in class org.apache.lucene.index.SegmentReader
Return a term frequency vector for the specified document and field.- getTermFreqVector(int, String) - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexReader
Deprecated.- getTermFreqVector(int, String, TermVectorMapper) - Method in class org.apache.lucene.index.FilterIndexReader
- getTermFreqVector(int, String, TermVectorMapper) - Method in class org.apache.lucene.index.IndexReader
Load the Term Vector into a user-defined data structure instead of relying on the parallel arrays of theTermFreqVector
.- getTermFreqVector(int, String, TermVectorMapper) - Method in class org.apache.lucene.index.MultiReader
- getTermFreqVector(int, String, TermVectorMapper) - Method in class org.apache.lucene.index.ParallelReader
- getTermFreqVector(int, String, TermVectorMapper) - Method in class org.apache.lucene.index.SegmentReader
- getTermFreqVector(int, String, TermVectorMapper) - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexReader
Deprecated.- getTermFreqVector(int, TermVectorMapper) - Method in class org.apache.lucene.index.FilterIndexReader
- getTermFreqVector(int, TermVectorMapper) - Method in class org.apache.lucene.index.IndexReader
Map all the term vectors for all fields in a Document- getTermFreqVector(int, TermVectorMapper) - Method in class org.apache.lucene.index.MultiReader
- getTermFreqVector(int, TermVectorMapper) - Method in class org.apache.lucene.index.ParallelReader
- getTermFreqVector(int, TermVectorMapper) - Method in class org.apache.lucene.index.SegmentReader
- getTermFreqVector(int, TermVectorMapper) - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexReader
Deprecated.- getTermFreqVectors(int) - Method in class org.apache.lucene.index.FilterIndexReader
- getTermFreqVectors(int) - Method in class org.apache.lucene.index.IndexReader
Return an array of term frequency vectors for the specified document.- getTermFreqVectors(int) - Method in class org.apache.lucene.index.MultiReader
- getTermFreqVectors(int) - Method in class org.apache.lucene.index.ParallelReader
- getTermFreqVectors(int) - Method in class org.apache.lucene.index.PruningReader
AppliesTermPruningPolicy
to terms inside term vectors.- getTermFreqVectors(int) - Method in class org.apache.lucene.index.SegmentReader
Return an array of term frequency vectors for the specified document.- getTermFreqVectors(int) - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexReader
Deprecated.- getTermIndex() - Method in class org.apache.lucene.store.instantiated.InstantiatedTerm
- getTermIndexInterval() - Method in class org.apache.lucene.index.IndexWriter
Deprecated.- getTermIndexInterval() - Method in class org.apache.lucene.index.IndexWriterConfig
Returns the interval between indexed terms.- getTermInfo(Directory, Term) - Static method in class org.apache.lucene.misc.GetTermInfo
- 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
- getTermInfosIndexDivisor() - Method in class org.apache.lucene.index.FilterIndexReader
- getTermInfosIndexDivisor() - Method in class org.apache.lucene.index.IndexReader
For IndexReader implementations that use TermInfosReader to read terms, this returns the current indexDivisor as specified when the reader was opened.- getTermInfosIndexDivisor() - Method in class org.apache.lucene.index.SegmentReader
- getTermMap(String) - Method in class org.apache.lucene.search.vectorhighlight.FieldQuery.QueryPhraseMap
- getTermOffsets() - Method in class org.apache.lucene.store.instantiated.InstantiatedTermDocumentInformation
- getTermOrPhraseNumber() - Method in class org.apache.lucene.search.vectorhighlight.FieldQuery.QueryPhraseMap
- getTermPositions() - Method in class org.apache.lucene.store.instantiated.InstantiatedTermDocumentInformation
- getTermPositions(int) - Method in interface org.apache.lucene.index.TermPositionVector
Returns an array of positions in which the term is found.- getTermPositions(int) - Method in class org.apache.lucene.store.instantiated.InstantiatedTermPositionVector
- getTermQuery(String, boolean) - Method in class org.apache.lucene.queryParser.surround.parser.QueryParser
- getTerms() - Method in class org.apache.lucene.index.PositionBasedTermVectorMapper.TVPositionInfo
Note, there may be multiple terms at the same position- getTerms() - Method in interface org.apache.lucene.index.TermFreqVector
- getTerms() - Method in class org.apache.lucene.search.PhraseQuery
Returns the set of terms in this phrase.- getTerms() - Method in class org.apache.lucene.search.QueryTermVector
- getTerms() - Method in class org.apache.lucene.store.instantiated.InstantiatedTermFreqVector
- 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) - 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- getTermsByFieldAndText() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndex
Deprecated.- getTermsEnum(IndexReader, MultiTermQuery) - Method in class org.apache.lucene.search.MultiTermQuery.RewriteMethod
Returns theMultiTermQuery
sFilteredTermEnum
- getTermsOffsets() - Method in class org.apache.lucene.search.vectorhighlight.FieldFragList.WeightedFragInfo.SubInfo
- getTermText() - Method in class org.apache.lucene.queryParser.surround.query.SrndTermQuery
- getTermVectorEntrySet() - Method in class org.apache.lucene.index.SortedTermVectorMapper
The TermVectorEntrySet.- getTestClass() - Static method in class org.apache.lucene.util.LuceneTestCase
Return the current class being tested.- getTestClass() - Method in class org.apache.lucene.util.StoreClassNameRule
Returns the test class currently executing in this rule.- getTestLabel() - Method in class org.apache.lucene.util.LuceneTestCase
- getText() - Method in class org.apache.lucene.analysis.icu.segmentation.LaoBreakIterator
- 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.core.nodes.FieldQueryNode
Returns the term.- getText() - Method in interface org.apache.lucene.queryParser.core.nodes.TextableQueryNode
- getText() - Method in class org.apache.lucene.search.vectorhighlight.FieldTermStack.TermInfo
- getText(CharTermAttribute) - Method in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
Fills CharTermAttribute with the current token text.- getText(CharTermAttribute) - Method in interface org.apache.lucene.analysis.standard.StandardTokenizerInterface
Copies the matched text into the CharTermAttribute- getText(CharTermAttribute) - Method in class org.apache.lucene.analysis.standard.std31.StandardTokenizerImpl31
Deprecated.Fills CharTermAttribute with the current token text.- getText(CharTermAttribute) - Method in class org.apache.lucene.analysis.standard.std31.UAX29URLEmailTokenizerImpl31
Deprecated.Fills CharTermAttribute with the current token text.- getText(CharTermAttribute) - Method in class org.apache.lucene.analysis.standard.std34.UAX29URLEmailTokenizerImpl34
Deprecated.Fills CharTermAttribute with the current token text.- getText(CharTermAttribute) - Method in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizerImpl
Fills CharTermAttribute with the current token text.- getText(Node) - Static method in class org.apache.lucene.xmlparser.DOMUtils
- getTextAsString() - Method in class org.apache.lucene.queryParser.core.nodes.FieldQueryNode
- 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.- getTierBoxId(double, double) - Method in class org.apache.lucene.spatial.tier.projections.CartesianTierPlotter
Deprecated.TierBoxId is latitude box id + longitude box id where latitude box id, and longitude box id are transposed in to position coordinates.- getTierFieldName() - Method in class org.apache.lucene.spatial.tier.projections.CartesianTierPlotter
Deprecated.get the string name representing current tier _localTier<tiedId>- getTierFieldName(int) - Method in class org.apache.lucene.spatial.tier.projections.CartesianTierPlotter
Deprecated.get the string name representing tierId _localTier<tierId>- getTierId() - Method in class org.apache.lucene.spatial.tier.Shape
Deprecated.- getTierVerticalPosDivider() - Method in class org.apache.lucene.spatial.tier.projections.CartesianTierPlotter
Deprecated.- getTimeAllowed() - Method in exception org.apache.lucene.search.TimeLimitingCollector.TimeExceededException
Returns allowed time (milliseconds).- getTimeElapsed() - Method in exception org.apache.lucene.search.TimeLimitingCollector.TimeExceededException
Returns elapsed time (milliseconds).- getTimestamp() - Method in class org.apache.lucene.index.IndexCommit
Deprecated.If you need to track commit time of an index, you can store it in the commit data (seeIndexWriter.commit(Map)
- getTitle() - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParser
- getTitle() - Method in class org.apache.lucene.benchmark.byTask.feeds.DocData
- getToken() - Method in class org.apache.lucene.analysis.miscellaneous.SingleTokenTokenStream
- getToken(int) - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParser
Get the specific Token.- getToken(int) - Method in class org.apache.lucene.queryParser.QueryParser
Get the specific Token.- getToken(int) - Method in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParser
Get the specific Token.- getToken(int) - Method in class org.apache.lucene.queryParser.surround.parser.QueryParser
Get the specific Token.- getToken(int) - Method in class org.apache.lucene.search.highlight.TokenGroup
- getTokenPositioner(Token) - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.OneDimensionalNonWeightedTokenSettingsCodec
Deprecated.- getTokenPositioner(Token) - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.SimpleThreeDimensionalTokenSettingsCodec
Deprecated.- getTokenPositioner(Token) - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.TokenSettingsCodec
Deprecated.Retrieves information on how aToken
is to be inserted to aShingleMatrixFilter.Matrix
.- getTokenPositioner(Token) - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.TwoDimensionalNonWeightedSynonymTokenSettingsCodec
Deprecated.- getTokens() - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.Matrix.Column.Row
Deprecated.- 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.ReusableAnalyzerBase.TokenStreamComponents
Returns the sinkTokenStream
- getTokenStream() - Method in class org.apache.lucene.search.highlight.WeightedSpanTermExtractor
- getTokenStream(String, String, Analyzer) - Static method in class org.apache.lucene.search.highlight.TokenSources
- getTokenStream(Document, String, Analyzer) - Static method in class org.apache.lucene.search.highlight.TokenSources
- getTokenStream(IndexReader, int, String) - Static method in class org.apache.lucene.search.highlight.TokenSources
- getTokenStream(IndexReader, int, String, Analyzer) - Static method in class org.apache.lucene.search.highlight.TokenSources
- getTokenStream(TermPositionVector) - Static method in class org.apache.lucene.search.highlight.TokenSources
- getTokenStream(TermPositionVector, boolean) - Static method in class org.apache.lucene.search.highlight.TokenSources
Low level api.- getTopGroups(int) - Method in class org.apache.lucene.search.grouping.AbstractSecondPassGroupingCollector
- getTopGroups(int, boolean) - Method in class org.apache.lucene.search.grouping.AbstractFirstPassGroupingCollector
Returns top groups, starting from offset.- getTopGroups(ToParentBlockJoinQuery, Sort, int, int, int, boolean) - Method in class org.apache.lucene.search.join.ToParentBlockJoinCollector
Return the TopGroups for the specified BlockJoinQuery.- getTopGroups(Sort, int, int, int, boolean) - Method in class org.apache.lucene.search.grouping.BlockGroupingCollector
Returns the grouped results.- getTopLevelParser() - Method in class org.apache.lucene.queryParser.ext.ExtensionQuery
Returns the top level parser which created thisExtensionQuery
- getTopLevelQuery() - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsBoostOnlyBooleanQueryRewrite
- getTopLevelQuery() - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsScoringBooleanQueryRewrite
- getTotalBoost() - Method in class org.apache.lucene.search.vectorhighlight.FieldFragList.WeightedFragInfo
- getTotalBytesCount() - Method in class org.apache.lucene.benchmark.byTask.feeds.ContentItemsSource
Returns the total number of bytes that were generated by this source.- getTotalBytesCount() - Method in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
Returns the total number of bytes that were generated by the content source defined to that doc maker.- getTotalCount(int) - Method in class org.apache.lucene.facet.search.TotalFacetCounts
Return the total count of an input category- getTotalCounts(IndexReader, TaxonomyReader, FacetIndexingParams, CategoryListCache) - Method in class org.apache.lucene.facet.search.TotalFacetCountsCache
Get the total facet counts for a reader/taxonomy pair and facet indexing parameters.- getTotalCountsFactor() - Method in class org.apache.lucene.facet.search.sampling.SamplingAccumulator
- getTotalCountsFactor() - Method in class org.apache.lucene.facet.search.StandardFacetsAccumulator
Expert: factor by which counts should be multiplied when initializing the count arrays from total counts.- 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.- getTotalNumberOfTerms() - Method in class org.apache.lucene.search.MultiTermQuery
Deprecated.Don't use this method, as its not thread safe and useless.- getTotalNumberOfTerms() - Method in class org.apache.lucene.search.MultiTermQueryWrapperFilter
Deprecated.Don't use this method, as its not thread safe and useless.- getTotalScore() - Method in class org.apache.lucene.search.highlight.TokenGroup
- getTotalTermFreq(IndexReader, Term) - Static method in class org.apache.lucene.misc.HighFreqTerms
- getTotStateCount() - Method in class org.apache.lucene.util.fst.Builder
- getTruncated() - Method in class org.apache.lucene.queryParser.surround.query.SrndTruncQuery
- getTruncQuery(String) - Method in class org.apache.lucene.queryParser.surround.parser.QueryParser
- getType() - Method in class org.apache.lucene.queryParser.standard.config.NumericConfig
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.util.FieldCacheSanityChecker.Insanity
Type of insane behavior this object represents- 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.- getUniqueTermCount() - Method in class org.apache.lucene.index.FieldInvertState
Return the number of unique terms encountered in this field.- getUniqueTermCount() - Method in class org.apache.lucene.index.FilterIndexReader
- getUniqueTermCount() - Method in class org.apache.lucene.index.IndexReader
Returns the number of unique terms (across all fields) in this reader.- getUniqueTermCount() - Method in class org.apache.lucene.index.SegmentReader
- getUnit() - Method in enum org.apache.lucene.spatial.geometry.DistanceUnits
Deprecated.Returns the string representation of the distance unit- getUnsupportedFeatures() - Static method in class org.apache.lucene.util.RamUsageEstimator
Return the set of unsupported JVM features that improve the estimation.- getUpperBound() - Method in class org.apache.lucene.queryParser.core.nodes.ParametricRangeQueryNode
- getUpperBound() - Method in interface org.apache.lucene.queryParser.core.nodes.RangeQueryNode
- getUpperBound() - Method in class org.apache.lucene.queryParser.standard.nodes.AbstractRangeQueryNode
Returns the upper bound node.- getUpperBound() - Method in class org.apache.lucene.queryParser.standard.nodes.RangeQueryNode
Deprecated.- getUpperRight() - Method in class org.apache.lucene.spatial.geometry.shape.LLRect
Deprecated.- getUpperTerm() - Method in class org.apache.lucene.search.TermRangeFilter
Returns the upper value of this range filter- getUpperTerm() - Method in class org.apache.lucene.search.TermRangeQuery
Returns the upper value of this range query- getUpperVal() - Method in class org.apache.lucene.search.FieldCacheRangeFilter
Returns the upper value of this range filter- getUseCompoundFile() - Method in class org.apache.lucene.index.IndexWriter
Deprecated.- getUseCompoundFile() - Method in class org.apache.lucene.index.LogMergePolicy
Returns true if newly flushed and newly merge segments are written in compound file format.- getUseCompoundFile() - Method in class org.apache.lucene.index.SegmentInfo
Returns true if this segment is stored as a compound file; else, false.- getUseCompoundFile() - Method in class org.apache.lucene.index.TieredMergePolicy
- getUseOldRangeQuery() - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
Deprecated.- getUserData() - Method in class org.apache.lucene.index.IndexCommit
Returns userData, previously passed toIndexWriter.commit(Map)
for this commit.- getUserData() - Method in class org.apache.lucene.index.SegmentInfos
- getUserData() - Method in class org.apache.lucene.index.SnapshotDeletionPolicy.SnapshotCommitPoint
- getUseUnmap() - Method in class org.apache.lucene.store.MMapDirectory
Returnstrue
, if the unmap workaround is enabled.- getUTF16SortedAsUTF8Comparator() - Static method in class org.apache.lucene.util.CharsRef
- getUTF8SortedAsUnicodeComparator() - Static method in class org.apache.lucene.util.BytesRef
- getUTF8SortedAsUTF16Comparator() - Static method in class org.apache.lucene.util.BytesRef
- getValue() - Method in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree.Iterator
- getValue() - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.Token
An optional attribute value of the Token.- getValue() - Method in interface org.apache.lucene.facet.search.results.FacetResultNode
Value of this result - usually either count or a value derived from some computing on the association of it.- getValue() - Method in class org.apache.lucene.facet.search.results.MutableFacetResultNode
- getValue() - Method in class org.apache.lucene.queryParser.core.nodes.BoostQueryNode
Returns the boost value.- getValue() - Method in class org.apache.lucene.queryParser.core.nodes.FieldQueryNode
- getValue() - Method in class org.apache.lucene.queryParser.core.nodes.OpaqueQueryNode
- getValue() - Method in class org.apache.lucene.queryParser.core.nodes.PathQueryNode.QueryText
- getValue() - Method in class org.apache.lucene.queryParser.core.nodes.PhraseSlopQueryNode
- getValue() - Method in class org.apache.lucene.queryParser.core.nodes.SlopQueryNode
- getValue() - Method in interface org.apache.lucene.queryParser.core.nodes.ValueQueryNode
- getValue() - Method in class org.apache.lucene.queryParser.standard.nodes.NumericQueryNode
Returns the numeric value asNumber
.- getValue() - Method in class org.apache.lucene.queryParser.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.queryParser.Token
An optional attribute value of the Token.- getValue() - Method in class org.apache.lucene.search.BooleanQuery.BooleanWeight
- getValue() - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantWeight
- getValue() - Method in class org.apache.lucene.search.DisjunctionMaxQuery.DisjunctionMaxWeight
Return our boost- getValue() - Method in class org.apache.lucene.search.Explanation
The value assigned to this explanation node.- getValue() - Method in class org.apache.lucene.search.FieldCache.CacheEntry
- getValue() - Method in class org.apache.lucene.search.spans.SpanWeight
- getValue() - Method in class org.apache.lucene.search.Weight
The weight for this query.- getValue(String) - Method in class org.apache.lucene.benchmark.quality.QualityQuery
Return the value of a certain name-value pair.- getValueOf(FacetArrays, int) - Method in class org.apache.lucene.facet.search.params.association.AssociationFloatSumFacetRequest
- getValueOf(FacetArrays, int) - Method in class org.apache.lucene.facet.search.params.association.AssociationIntSumFacetRequest
- getValueOf(FacetArrays, int) - Method in class org.apache.lucene.facet.search.params.CountFacetRequest
- getValueOf(FacetArrays, int) - Method in class org.apache.lucene.facet.search.params.FacetRequest
Return the value of a category used for facets computations for this request.- getValueOf(FacetArrays, int) - Method in class org.apache.lucene.facet.search.params.ScoreFacetRequest
- getValues() - Method in class org.apache.lucene.search.FieldComparator.StringOrdValComparator
- getValues(int) - Method in class org.apache.lucene.analysis.compound.hyphenation.HyphenationTree
- getValues(String) - Method in class org.apache.lucene.document.Document
Returns an array of values of the field specified as the method parameter.- getValues(IndexReader) - Method in class org.apache.lucene.search.function.FieldCacheSource
- getValues(IndexReader) - Method in class org.apache.lucene.search.function.OrdFieldSource
- getValues(IndexReader) - Method in class org.apache.lucene.search.function.ReverseOrdFieldSource
- getValues(IndexReader) - Method in class org.apache.lucene.search.function.ValueSource
Return the DocValues used by the function query.- getVectorSpace() - Method in class org.apache.lucene.store.instantiated.InstantiatedDocument
- getVersion() - Method in class org.apache.lucene.analysis.hunspell.HunspellDictionary
- getVersion() - Method in class org.apache.lucene.index.FilterIndexReader
- getVersion() - Method in class org.apache.lucene.index.IndexCommit
Deprecated.useIndexCommit.getGeneration()
instead- getVersion() - Method in class org.apache.lucene.index.IndexReader
Version number when this IndexReader was opened.- getVersion() - Method in class org.apache.lucene.index.MultiReader
Not implemented.- getVersion() - Method in class org.apache.lucene.index.ParallelReader
Not implemented.- getVersion() - Method in class org.apache.lucene.index.SegmentInfo
Returns the version of the code which wrote the segment.- getVersion() - Method in class org.apache.lucene.index.SegmentInfos
version number when this SegmentInfos was generated.- getVersion() - Method in class org.apache.lucene.index.SnapshotDeletionPolicy.SnapshotCommitPoint
- getVersion() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndex
Deprecated.- getVersion() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexReader
Deprecated.An InstantiatedIndexReader is not a snapshot in time, it is completely in sync with the latest commit to the store!- getVersionComparator() - Static method in class org.apache.lucene.util.StringHelper
- getWeight() - Method in class org.apache.lucene.queryParser.surround.query.SrndQuery
- getWeight() - Method in class org.apache.lucene.search.highlight.WeightedTerm
- getWeight(Token) - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.OneDimensionalNonWeightedTokenSettingsCodec
Deprecated.- getWeight(Token) - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.SimpleThreeDimensionalTokenSettingsCodec
Deprecated.Returns a 32 bit float from the payload, or 1f it null.- getWeight(Token) - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.TokenSettingsCodec
Deprecated.Have this method return 1f in order to 'disable' weights.- getWeight(Token) - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.TwoDimensionalNonWeightedSynonymTokenSettingsCodec
Deprecated.- 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
Retrieve theWeightedSpanTerm
for the specified token.- getWeightedSpanTerms(Query, TokenStream) - Method in class org.apache.lucene.search.highlight.WeightedSpanTermExtractor
Creates a Map ofWeightedSpanTerms
from the givenQuery
andTokenStream
.- getWeightedSpanTerms(Query, TokenStream, String) - Method in class org.apache.lucene.search.highlight.WeightedSpanTermExtractor
Creates a Map ofWeightedSpanTerms
from the givenQuery
andTokenStream
.- getWeightedSpanTermsWithScores(Query, TokenStream, String, IndexReader) - Method in class org.apache.lucene.search.highlight.WeightedSpanTermExtractor
Creates a Map ofWeightedSpanTerms
from the givenQuery
andTokenStream
.- getWeightOperator() - Method in class org.apache.lucene.queryParser.surround.query.SrndQuery
- getWeightString() - Method in class org.apache.lucene.queryParser.surround.query.SrndQuery
- getWildcardQuery(String, String) - Method in class org.apache.lucene.queryParser.analyzing.AnalyzingQueryParser
Called when parser parses an input term token that contains one or more wildcard characters (like*
), but is not a prefix term token (one that has just a single * character at the end).- getWildcardQuery(String, String) - Method in class org.apache.lucene.queryParser.complexPhrase.ComplexPhraseQueryParser
- getWildcardQuery(String, String) - Method in class org.apache.lucene.queryParser.MultiFieldQueryParser
- getWildcardQuery(String, String) - Method in class org.apache.lucene.queryParser.QueryParser
Factory method for generating a query.- getWildcardQuery(String, String) - Method in class org.apache.lucene.queryParser.QueryParserTestBase.QPTestParser
- getWildcardQuery(String, String) - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
Deprecated.- 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
- 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).- getWordSet(Reader, String, Version) - Static method in class org.apache.lucene.analysis.WordlistLoader
Reads lines from a Reader and adds every non-comment line as an entry to a CharArraySet (omitting leading and trailing whitespace).- getWordSet(Reader, CharArraySet) - Static method in class org.apache.lucene.analysis.WordlistLoader
Reads lines from a Reader and adds every line as an entry to a CharArraySet (omitting leading and trailing whitespace).- getWordSet(Reader, Version) - Static method in class org.apache.lucene.analysis.WordlistLoader
Reads lines from a Reader and adds every line as an entry to a CharArraySet (omitting leading and trailing whitespace).- getWordsIterator() - Method in interface org.apache.lucene.search.spell.Dictionary
Return all words present in the dictionary- getWordsIterator() - Method in class org.apache.lucene.search.spell.HighFrequencyDictionary
- getWordsIterator() - Method in class org.apache.lucene.search.spell.LuceneDictionary
- getWordsIterator() - Method in class org.apache.lucene.search.spell.PlainTextDictionary
- getWordsIterator() - Method in class org.apache.lucene.search.suggest.FileDictionary
- getWriteLockTimeout() - Method in class org.apache.lucene.index.IndexWriter
Deprecated.- getWriteLockTimeout() - Method in class org.apache.lucene.index.IndexWriterConfig
Returns allowed timeout when acquiring the write lock.- getWriter(DataOutput, int, int) - Static method in class org.apache.lucene.util.packed.PackedInts
Create a packed integer array writer for the given number of values at the given bits/value.- getX() - Method in class org.apache.lucene.spatial.geometry.CartesianPoint
Deprecated.- getX() - Method in class org.apache.lucene.spatial.geometry.shape.Point2D
Deprecated.- getX() - Method in class org.apache.lucene.spatial.geometry.shape.Vector2D
Deprecated.- getY() - Method in class org.apache.lucene.spatial.geometry.CartesianPoint
Deprecated.- getY() - Method in class org.apache.lucene.spatial.geometry.shape.Point2D
Deprecated.- getY() - Method in class org.apache.lucene.spatial.geometry.shape.Vector2D
Deprecated.- getYoungestChildArray() - Method in interface org.apache.lucene.facet.taxonomy.TaxonomyReader.ChildrenArrays
getYoungestChildArray() returns an int array of size getSize() listing the ordinal of the youngest (highest numbered) child category of each category in the taxonomy.- GLOBAL_FLAT - org.apache.lucene.facet.search.params.FacetRequest.ResultMode
Limits are applied globally, on total number of results, and the result has a flat structure.- GOV2 - org.apache.lucene.benchmark.byTask.feeds.TrecDocParser.ParsePathType
- 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- 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
- GREEK - Static variable in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
- GreekAnalyzer - Class in org.apache.lucene.analysis.el
Analyzer
for the Greek language.- GreekAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.el.GreekAnalyzer
Builds an analyzer with the default stop words.- GreekAnalyzer(Version, String...) - Constructor for class org.apache.lucene.analysis.el.GreekAnalyzer
Deprecated.useGreekAnalyzer(Version, Set)
instead- GreekAnalyzer(Version, Map<?, ?>) - Constructor for class org.apache.lucene.analysis.el.GreekAnalyzer
Deprecated.useGreekAnalyzer(Version, Set)
instead- GreekAnalyzer(Version, Set<?>) - 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
Deprecated.UseGreekLowerCaseFilter(Version, TokenStream)
instead.- GreekLowerCaseFilter(Version, TokenStream) - Constructor for class org.apache.lucene.analysis.el.GreekLowerCaseFilter
Create a GreekLowerCaseFilter that normalizes Greek token text.- GreekStemFilter - Class in org.apache.lucene.analysis.el
ATokenFilter
that appliesGreekStemmer
to stem Greek words.- GreekStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.el.GreekStemFilter
- 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
- GROUD - Static variable in class org.apache.lucene.util.collections.IntToIntMap
- GROUND - Static variable in class org.apache.lucene.util.collections.IntToDoubleMap
- groupDocs - Variable in class org.apache.lucene.search.grouping.AbstractSecondPassGroupingCollector
- GroupDocs<GROUP_VALUE_TYPE> - Class in org.apache.lucene.search.grouping
Represents one group in the results.- GroupDocs(float, int, ScoreDoc[], GROUP_VALUE_TYPE, Object[]) - Constructor for class org.apache.lucene.search.grouping.GroupDocs
- groupHead - Variable in class org.apache.lucene.search.grouping.AbstractAllGroupHeadsCollector.TemporalResult
- GroupHead(GROUP_VALUE_TYPE, int) - Constructor for class org.apache.lucene.search.grouping.AbstractAllGroupHeadsCollector.GroupHead
- groupHeadsSize() - Method in class org.apache.lucene.search.grouping.AbstractAllGroupHeadsCollector
- groupMap - Variable in class org.apache.lucene.search.grouping.AbstractSecondPassGroupingCollector
- GroupQueryNode - Class in org.apache.lucene.queryParser.core.nodes
AGroupQueryNode
represents a location where the original user typed real parenthesis on the query string.- GroupQueryNode(QueryNode) - Constructor for class org.apache.lucene.queryParser.core.nodes.GroupQueryNode
This QueryNode is used to identify parenthesis on the original query string- GroupQueryNodeBuilder - Class in org.apache.lucene.queryParser.standard.builders
Builds no object, it only returns theQuery
object set on theGroupQueryNode
object using aQueryTreeBuilder.QUERY_TREE_BUILDER_TAGID
tag.- GroupQueryNodeBuilder() - Constructor for class org.apache.lucene.queryParser.standard.builders.GroupQueryNodeBuilder
- GroupQueryNodeProcessor - Class in org.apache.lucene.queryParser.standard.processors
Deprecated.useBooleanQuery2ModifierNodeProcessor
instead- GroupQueryNodeProcessor() - Constructor for class org.apache.lucene.queryParser.standard.processors.GroupQueryNodeProcessor
Deprecated.- groups - Variable in class org.apache.lucene.search.grouping.TopGroups
Group results in groupSort order- 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
Matches the groupSort passed toAbstractFirstPassGroupingCollector
.- groupValue - Variable in class org.apache.lucene.search.grouping.AbstractAllGroupHeadsCollector.GroupHead
- groupValue - Variable in class org.apache.lucene.search.grouping.AbstractSecondPassGroupingCollector.SearchGroupDocs
- 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() - Method in class org.apache.lucene.util.BytesRefHash.BytesStartArray
Grows theBytesRefHash.BytesStartArray
- grow() - Method in class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
- grow() - Method in class org.apache.lucene.util.BytesRefHash.TrackingDirectBytesStartArray
- grow() - Method in class org.apache.lucene.util.collections.ArrayHashMap
Allocates a new map of double the capacity, and fast-insert the old key-value pairs.- grow() - Method in class org.apache.lucene.util.collections.FloatToObjectMap
Grows the map.- grow() - Method in class org.apache.lucene.util.collections.IntHashSet
Grows the map.- grow() - Method in class org.apache.lucene.util.collections.IntToDoubleMap
Grows the map.- grow() - Method in class org.apache.lucene.util.collections.IntToIntMap
Grows the map.- grow() - Method in class org.apache.lucene.util.collections.IntToObjectMap
Grows the map.- grow() - Method in class org.apache.lucene.util.collections.ObjectToFloatMap
Grows the map.- grow() - Method in class org.apache.lucene.util.collections.ObjectToIntMap
Grows the map.- grow() - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
- grow() - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
- grow(boolean[]) - Static method in class org.apache.lucene.util.ArrayUtil
- grow(boolean[], int) - Static method in class org.apache.lucene.util.ArrayUtil
- grow(byte[]) - Static method in class org.apache.lucene.util.ArrayUtil
- grow(byte[], int) - Static method in class org.apache.lucene.util.ArrayUtil
- grow(char[]) - Static method in class org.apache.lucene.util.ArrayUtil
- grow(char[], int) - Static method in class org.apache.lucene.util.ArrayUtil
- grow(double[]) - Static method in class org.apache.lucene.util.ArrayUtil
- grow(double[], int) - Static method in class org.apache.lucene.util.ArrayUtil
- grow(float[]) - Static method in class org.apache.lucene.util.ArrayUtil
- grow(float[][]) - Static method in class org.apache.lucene.util.ArrayUtil
- grow(float[][], int) - Static method in class org.apache.lucene.util.ArrayUtil
- grow(float[], int) - Static method in class org.apache.lucene.util.ArrayUtil
- grow(int) - Method in class org.apache.lucene.util.BytesRef
Used to grow the reference array.- grow(int) - Method in class org.apache.lucene.util.CharsRef
Used to grow the reference array.- grow(int) - Method in class org.apache.lucene.util.IntsRef
Used to grow the reference array.- grow(int[]) - Static method in class org.apache.lucene.util.ArrayUtil
- grow(int[][]) - Static method in class org.apache.lucene.util.ArrayUtil
- grow(int[][], int) - Static method in class org.apache.lucene.util.ArrayUtil
- grow(int[], int) - Static method in class org.apache.lucene.util.ArrayUtil
- grow(long[]) - Static method in class org.apache.lucene.util.ArrayUtil
- grow(long[], int) - Static method in class org.apache.lucene.util.ArrayUtil
- grow(short[]) - Static method in class org.apache.lucene.util.ArrayUtil
- grow(short[], int) - Static method in class org.apache.lucene.util.ArrayUtil
- GrowableWriter - Class in org.apache.lucene.util.packed
ImplementsPackedInts.Mutable
, but grows the bit count of the underlying packed ints on-demand.- GrowableWriter(int, int, boolean) - Constructor for class org.apache.lucene.util.packed.GrowableWriter
- GT - org.apache.lucene.queryParser.core.nodes.ParametricQueryNode.CompareOperator
Deprecated.- GZIP - org.apache.lucene.benchmark.byTask.utils.StreamUtils.Type
GZIP is automatically used for .gz and .gzip extensions.H
- HAMZA_ABOVE - Static variable in class org.apache.lucene.analysis.fa.PersianNormalizer
- HAN - Static variable in class org.apache.lucene.analysis.cjk.CJKBigramFilter
-
bigram flag for Han Ideographs
- handleEndOfInput() - Method in class org.apache.lucene.facet.index.streaming.CategoryListTokenizer
-
A method invoked once when the input stream ends, for subclass-specific processing.
- handleMergeException(Throwable) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
-
Called when an exception is hit in a background merge thread
- handleStartOfInput() - Method in class org.apache.lucene.facet.enhancements.association.AssociationListTokenizer
- handleStartOfInput() - Method in class org.apache.lucene.facet.index.streaming.CategoryListTokenizer
-
A method invoked once when the input stream begins, for subclass-specific processing.
- handleStartOfInput() - Method in class org.apache.lucene.facet.index.streaming.CountingListTokenizer
- HANGUL - Static variable in class org.apache.lucene.analysis.cjk.CJKBigramFilter
-
bigram flag for Hangul
- HANGUL - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
- HANGUL - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
- HANGUL_TYPE - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
- HANGUL_TYPE - Static variable in class org.apache.lucene.analysis.standard.std31.StandardTokenizerImpl31
-
Deprecated.
- HANGUL_TYPE - Static variable in class org.apache.lucene.analysis.standard.std31.UAX29URLEmailTokenizerImpl31
-
Deprecated.
- HANGUL_TYPE - Static variable in class org.apache.lucene.analysis.standard.std34.UAX29URLEmailTokenizerImpl34
-
Deprecated.
- HANGUL_TYPE - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
-
Deprecated.use
UAX29URLEmailTokenizer.TOKEN_TYPES
instead - HANGUL_TYPE - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizerImpl
- HANZI - Static variable in class org.apache.lucene.analysis.cn.smart.CharType
-
Han Ideographs
- has(ConfigurationKey<T>) - Method in class org.apache.lucene.queryParser.core.config.AbstractQueryConfig
-
Returns true if there is a value set with the given key, otherwise false.
- HAS_BASEFORM - Static variable in class org.apache.lucene.analysis.ja.dict.BinaryDictionary
-
flag that the entry has baseform data.
- HAS_BUGGY_BREAKITERATORS - Static variable in class org.apache.lucene.analysis.util.CharArrayIterator
-
True if this JRE has a buggy BreakIterator implementation
- HAS_PRONUNCIATION - Static variable in class org.apache.lucene.analysis.ja.dict.BinaryDictionary
-
flag that the entry has pronunciation data.
- HAS_READING - Static variable in class org.apache.lucene.analysis.ja.dict.BinaryDictionary
-
flag that the entry has reading data.
- hasArray() - Method in class org.apache.lucene.util.packed.GrowableWriter
- hasArray() - Method in interface org.apache.lucene.util.packed.PackedInts.Reader
-
Returns true if this implementation is backed by a native java array.
- hasArray() - Method in class org.apache.lucene.util.packed.PackedInts.ReaderImpl
- hasAttribute(Class<? extends Attribute>) - Method in class org.apache.lucene.util.AttributeSource
-
The caller must pass in a Class<? extends Attribute> value.
- hasAttributes() - Method in class org.apache.lucene.util.AttributeSource
-
Returns true, iff this AttributeSource has any attributes
- hasBeenSet() - Method in class org.apache.lucene.facet.enhancements.association.AssociationProperty
-
Returns whether this attribute has been set (not all categories have an association).
- hasBeenSet() - Method in class org.apache.lucene.facet.index.attributes.OrdinalProperty
- hasChanges - Variable in class org.apache.lucene.index.IndexReader
- hasDeletions - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
-
True if this segment has pending deletions.
- hasDeletions() - Method in class org.apache.lucene.index.FilterIndexReader
- hasDeletions() - Method in class org.apache.lucene.index.IndexReader
-
Returns true if any documents have been deleted
- hasDeletions() - Method in class org.apache.lucene.index.IndexWriter
- hasDeletions() - Method in class org.apache.lucene.index.MultiReader
- hasDeletions() - Method in class org.apache.lucene.index.ParallelReader
- hasDeletions() - Method in class org.apache.lucene.index.SegmentInfo
- hasDeletions() - Method in class org.apache.lucene.index.SegmentReader
- hasDeletions() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexReader
-
Deprecated.
- hasFlag(char) - Method in class org.apache.lucene.analysis.hunspell.HunspellWord
-
Checks whether the word has the given flag associated with it
- hash(int) - Method in class org.apache.lucene.search.grouping.SentinelIntSet
- hashCode() - Method in class org.apache.lucene.analysis.BaseTokenStreamTestCase.CheckClearAttributesAttributeImpl
- hashCode() - Method in class org.apache.lucene.analysis.cn.smart.hhmm.SegToken
- hashCode() - Method in class org.apache.lucene.analysis.icu.tokenattributes.ScriptAttributeImpl
- hashCode() - Method in class org.apache.lucene.analysis.miscellaneous.PatternAnalyzer
-
Returns a hash code value for the object.
- hashCode() - Method in class org.apache.lucene.analysis.Token
- hashCode() - Method in class org.apache.lucene.analysis.Token.TokenAttributeFactory
- hashCode() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
- hashCode() - Method in class org.apache.lucene.analysis.tokenattributes.FlagsAttributeImpl
- hashCode() - Method in class org.apache.lucene.analysis.tokenattributes.KeywordAttributeImpl
- hashCode() - Method in class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
- hashCode() - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
- hashCode() - Method in class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
- hashCode() - Method in class org.apache.lucene.analysis.tokenattributes.PositionLengthAttributeImpl
- hashCode() - Method in class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
- hashCode() - Method in class org.apache.lucene.facet.enhancements.association.AssociationEnhancement
- hashCode() - Method in class org.apache.lucene.facet.enhancements.association.AssociationFloatProperty
- hashCode() - Method in class org.apache.lucene.facet.enhancements.association.AssociationIntProperty
- hashCode() - Method in class org.apache.lucene.facet.enhancements.association.AssociationsPayloadIterator
- hashCode() - Method in class org.apache.lucene.facet.index.attributes.CategoryAttributeImpl
- hashCode() - Method in class org.apache.lucene.facet.index.attributes.OrdinalProperty
- hashCode() - Method in class org.apache.lucene.facet.index.CategoryContainer
- hashCode() - Method in class org.apache.lucene.facet.index.params.CategoryListParams
-
Hashcode is similar to
CategoryListParams.equals(Object)
, in that it uses the term that defines this category list to derive the hashcode. - hashCode() - Method in class org.apache.lucene.facet.index.params.DefaultFacetIndexingParams
- hashCode() - Method in class org.apache.lucene.facet.search.aggregator.association.AssociationFloatSumAggregator
- hashCode() - Method in class org.apache.lucene.facet.search.aggregator.association.AssociationIntSumAggregator
- hashCode() - Method in class org.apache.lucene.facet.search.aggregator.CountingAggregator
- hashCode() - Method in class org.apache.lucene.facet.search.aggregator.ScoringAggregator
- hashCode() - Method in class org.apache.lucene.facet.search.params.FacetRequest
- hashCode() - Method in class org.apache.lucene.facet.search.PayloadIntDecodingIterator
- hashCode() - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
-
Calculate a hashCode for this path, used when a CategoryPath serves as a hash-table key.
- hashCode() - Method in class org.apache.lucene.index.IndexCommit
- hashCode() - Method in class org.apache.lucene.index.Payload
- hashCode() - Method in class org.apache.lucene.index.SegmentInfo
- hashCode() - Method in class org.apache.lucene.index.Term
- hashCode() - Method in class org.apache.lucene.index.TermVectorEntry
- hashCode() - Method in class org.apache.lucene.index.TermVectorOffsetInfo
- hashCode() - Method in class org.apache.lucene.queryParser.standard.config.AllowLeadingWildcardAttributeImpl
-
Deprecated.
- hashCode() - Method in class org.apache.lucene.queryParser.standard.config.AnalyzerAttributeImpl
-
Deprecated.
- hashCode() - Method in class org.apache.lucene.queryParser.standard.config.BoostAttributeImpl
-
Deprecated.
- hashCode() - Method in class org.apache.lucene.queryParser.standard.config.DateResolutionAttributeImpl
-
Deprecated.
- hashCode() - Method in class org.apache.lucene.queryParser.standard.config.DefaultOperatorAttributeImpl
-
Deprecated.
- hashCode() - Method in class org.apache.lucene.queryParser.standard.config.DefaultPhraseSlopAttributeImpl
-
Deprecated.
- hashCode() - Method in class org.apache.lucene.queryParser.standard.config.FieldBoostMapAttributeImpl
-
Deprecated.
- hashCode() - Method in class org.apache.lucene.queryParser.standard.config.FieldDateResolutionMapAttributeImpl
-
Deprecated.
- hashCode() - Method in class org.apache.lucene.queryParser.standard.config.FuzzyAttributeImpl
-
Deprecated.
- hashCode() - Method in class org.apache.lucene.queryParser.standard.config.LocaleAttributeImpl
-
Deprecated.
- hashCode() - Method in class org.apache.lucene.queryParser.standard.config.LowercaseExpandedTermsAttributeImpl
-
Deprecated.
- hashCode() - Method in class org.apache.lucene.queryParser.standard.config.MultiFieldAttributeImpl
-
Deprecated.
- hashCode() - Method in class org.apache.lucene.queryParser.standard.config.MultiTermRewriteMethodAttributeImpl
-
Deprecated.
- hashCode() - Method in class org.apache.lucene.queryParser.standard.config.PositionIncrementsAttributeImpl
-
Deprecated.
- hashCode() - Method in class org.apache.lucene.queryParser.standard.config.RangeCollatorAttributeImpl
-
Deprecated.
- hashCode() - Method in class org.apache.lucene.search.BooleanClause
-
Returns a hash code value for this object.
- hashCode() - Method in class org.apache.lucene.search.BooleanFilter
- hashCode() - Method in class org.apache.lucene.search.BooleanQuery
-
Returns a hash code value for this object.
- hashCode() - Method in class org.apache.lucene.search.BoostingQuery
- hashCode() - Method in class org.apache.lucene.search.CachingSpanFilter
- hashCode() - Method in class org.apache.lucene.search.CachingWrapperFilter
- hashCode() - Method in class org.apache.lucene.search.CachingWrapperFilterHelper
- hashCode() - Method in class org.apache.lucene.search.ConstantScoreQuery
- hashCode() - Method in class org.apache.lucene.search.DisjunctionMaxQuery
-
Compute a hash code for hashing us
- hashCode() - Method in class org.apache.lucene.search.DuplicateFilter
- hashCode() - Method in class org.apache.lucene.search.FieldCacheRangeFilter
- hashCode() - Method in class org.apache.lucene.search.FieldValueFilter
- hashCode() - Method in class org.apache.lucene.search.FilterClause
- hashCode() - Method in class org.apache.lucene.search.FilteredQuery
-
Returns a hash code value for this object.
- hashCode() - Method in class org.apache.lucene.search.function.CustomScoreQuery
-
Returns a hash code value for this object.
- hashCode() - Method in class org.apache.lucene.search.function.FieldCacheSource
- hashCode() - Method in class org.apache.lucene.search.function.OrdFieldSource
- hashCode() - Method in class org.apache.lucene.search.function.ReverseOrdFieldSource
- hashCode() - Method in class org.apache.lucene.search.function.ValueSource
-
Needed for possible caching of query results - used by
ValueSourceQuery.hashCode()
. - hashCode() - Method in class org.apache.lucene.search.function.ValueSourceQuery
-
Returns a hash code value for this object.
- hashCode() - Method in class org.apache.lucene.search.FuzzyLikeThisQuery
- hashCode() - Method in class org.apache.lucene.search.FuzzyQuery
- hashCode() - Method in class org.apache.lucene.search.grouping.SearchGroup
- hashCode() - Method in class org.apache.lucene.search.join.ToChildBlockJoinQuery
- hashCode() - Method in class org.apache.lucene.search.join.ToParentBlockJoinQuery
- hashCode() - Method in class org.apache.lucene.search.MatchAllDocsQuery
- hashCode() - Method in class org.apache.lucene.search.MultiPhraseQuery
-
Returns a hash code value for this object.
- hashCode() - Method in class org.apache.lucene.search.MultiTermQuery
- hashCode() - Method in class org.apache.lucene.search.MultiTermQueryWrapperFilter
- hashCode() - Method in class org.apache.lucene.search.NGramPhraseQuery
-
Returns a hash code value for this object.
- hashCode() - Method in class org.apache.lucene.search.NumericRangeQuery
- hashCode() - Method in class org.apache.lucene.search.payloads.AveragePayloadFunction
- hashCode() - Method in class org.apache.lucene.search.payloads.MaxPayloadFunction
- hashCode() - Method in class org.apache.lucene.search.payloads.MinPayloadFunction
- hashCode() - Method in class org.apache.lucene.search.payloads.PayloadFunction
- hashCode() - Method in class org.apache.lucene.search.payloads.PayloadNearQuery
- hashCode() - Method in class org.apache.lucene.search.payloads.PayloadTermQuery
- hashCode() - Method in class org.apache.lucene.search.PhraseQuery
-
Returns a hash code value for this object.
- hashCode() - Method in class org.apache.lucene.search.PrefixQuery
- hashCode() - Method in class org.apache.lucene.search.Query
- hashCode() - Method in class org.apache.lucene.search.QueryWrapperFilter
- hashCode() - Method in class org.apache.lucene.search.regex.JakartaRegexpCapabilities
- hashCode() - Method in class org.apache.lucene.search.regex.JavaUtilRegexCapabilities
- hashCode() - Method in class org.apache.lucene.search.regex.RegexQuery
- hashCode() - Method in class org.apache.lucene.search.Sort
-
Returns a hash code value for this object.
- hashCode() - Method in class org.apache.lucene.search.SortField
-
Returns true if
o
is equal to this. - hashCode() - Method in class org.apache.lucene.search.SpanQueryFilter
- hashCode() - Method in class org.apache.lucene.search.spans.FieldMaskingSpanQuery
- hashCode() - Method in class org.apache.lucene.search.spans.SpanFirstQuery
- hashCode() - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper
- hashCode() - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper.TopTermsSpanBooleanQueryRewrite
- hashCode() - Method in class org.apache.lucene.search.spans.SpanNearPayloadCheckQuery
- hashCode() - Method in class org.apache.lucene.search.spans.SpanNearQuery
- hashCode() - Method in class org.apache.lucene.search.spans.SpanNotQuery
- hashCode() - Method in class org.apache.lucene.search.spans.SpanOrQuery
- hashCode() - Method in class org.apache.lucene.search.spans.SpanPayloadCheckQuery
- hashCode() - Method in class org.apache.lucene.search.spans.SpanPositionRangeQuery
- hashCode() - Method in class org.apache.lucene.search.spans.SpanTermQuery
- hashCode() - Method in class org.apache.lucene.search.TermQuery
-
Returns a hash code value for this object.
- hashCode() - Method in class org.apache.lucene.search.TermRangeQuery
- hashCode() - Method in class org.apache.lucene.search.TermsFilter
- hashCode() - Method in class org.apache.lucene.search.TopTermsRewrite
- hashCode() - Method in class org.apache.lucene.search.WildcardQuery
- hashCode() - Method in class org.apache.lucene.spatial.geohash.GeoHashDistanceFilter
-
Deprecated.Returns a hash code value for this object.
- hashCode() - Method in class org.apache.lucene.spatial.geometry.CartesianPoint
-
Deprecated.
- hashCode() - Method in class org.apache.lucene.spatial.geometry.FixedLatLng
-
Deprecated.
- hashCode() - Method in class org.apache.lucene.spatial.geometry.FloatLatLng
-
Deprecated.
- hashCode() - Method in class org.apache.lucene.spatial.geometry.LatLng
-
Deprecated.
- hashCode() - Method in class org.apache.lucene.spatial.geometry.shape.LineSegment
-
Deprecated.
- hashCode() - Method in class org.apache.lucene.spatial.geometry.shape.LLRect
-
Deprecated.
- hashCode() - Method in class org.apache.lucene.spatial.geometry.shape.Point2D
-
Deprecated.
- hashCode() - Method in class org.apache.lucene.spatial.geometry.shape.Rectangle
-
Deprecated.
- hashCode() - Method in class org.apache.lucene.spatial.geometry.shape.Vector2D
-
Deprecated.
- hashCode() - Method in class org.apache.lucene.spatial.tier.DistanceFilter
-
Deprecated.Returns a hash code value for this object.
- hashCode() - Method in class org.apache.lucene.spatial.tier.LatLongDistanceFilter
-
Deprecated.Returns a hash code value for this object.
- hashCode() - Method in class org.apache.lucene.util.AttributeSource
- hashCode() - Method in class org.apache.lucene.util.BytesRef
-
Calculates the hash code as required by TermsHash during indexing.
- hashCode() - Method in class org.apache.lucene.util.CharsRef
- hashCode() - Method in class org.apache.lucene.util.collections.ArrayHashMap
- hashCode() - Method in class org.apache.lucene.util.collections.FloatToObjectMap
- hashCode() - Method in class org.apache.lucene.util.collections.IntArray
-
Calculates a hash-code for HashTables
- hashCode() - Method in class org.apache.lucene.util.collections.IntToDoubleMap
- hashCode() - Method in class org.apache.lucene.util.collections.IntToIntMap
- hashCode() - Method in class org.apache.lucene.util.collections.IntToObjectMap
- hashCode() - Method in class org.apache.lucene.util.collections.ObjectToFloatMap
- hashCode() - Method in class org.apache.lucene.util.collections.ObjectToIntMap
- hashCode() - Method in class org.apache.lucene.util.FixedBitSet
- hashCode() - Method in class org.apache.lucene.util.fst.PairOutputs.Pair
- hashCode() - Method in class org.apache.lucene.util.fst.UpToTwoPositiveIntOutputs.TwoLongs
- hashCode() - Method in class org.apache.lucene.util.IntsRef
- hashCode() - Method in class org.apache.lucene.util.OpenBitSet
- hashCode() - Method in class org.tartarus.snowball.ext.ArmenianStemmer
- hashCode() - Method in class org.tartarus.snowball.ext.BasqueStemmer
- hashCode() - Method in class org.tartarus.snowball.ext.CatalanStemmer
- hashCode() - Method in class org.tartarus.snowball.ext.IrishStemmer
- hashCode(byte[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Returns hash of bytes in range start (inclusive) to end (inclusive)
- hashCode(char[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Returns hash of chars in range start (inclusive) to end (inclusive)
- hashCode(int) - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
-
Like
CategoryPath.hashCode()
, but find the hash function of a prefix with the given number of components, rather than of the entire path. - hashCodeOfSerialized(CharSequence, int) - Static method in class org.apache.lucene.facet.taxonomy.CategoryPath
-
This method calculates a hash function of a path that has been written to (using
CategoryPath.serializeAppendTo(Appendable)
) a character buffer. - hasMoreElements() - Method in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree.Iterator
- hasNext() - Method in class org.apache.lucene.analysis.CharArrayMap.EntryIterator
- hasNext() - Method in class org.apache.lucene.analysis.CharArraySet.CharArraySetIterator
-
Deprecated.
- hasNext() - Method in class org.apache.lucene.benchmark.byTask.feeds.DirContentSource.Iterator
- hasNext() - Method in interface org.apache.lucene.util.collections.DoubleIterator
- hasNext() - Method in interface org.apache.lucene.util.collections.FloatIterator
- hasNext() - Method in interface org.apache.lucene.util.collections.IntIterator
- hasNorms(String) - Method in class org.apache.lucene.index.FilterIndexReader
- hasNorms(String) - Method in class org.apache.lucene.index.IndexReader
-
Returns true if there are norms stored for this field.
- hasNorms(String) - Method in class org.apache.lucene.index.MultiReader
- hasNorms(String) - Method in class org.apache.lucene.index.ParallelReader
- hasNorms(String) - Method in class org.apache.lucene.index.SegmentReader
- hasProx - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
-
True if at least one of the fields in this segment has position data
- hasProx() - Method in class org.apache.lucene.index.FieldInfos
-
Returns true if any fields do not omitTermFreqAndPositions
- hasRoom(int) - Method in class org.apache.lucene.facet.taxonomy.writercache.cl2o.Cl2oTaxonomyWriterCache
- hasRoom(int) - Method in class org.apache.lucene.facet.taxonomy.writercache.lru.LruTaxonomyWriterCache
- hasRoom(int) - Method in interface org.apache.lucene.facet.taxonomy.writercache.TaxonomyWriterCache
-
Sometimes the cache is either unlimited in size, or limited by a very big size, and in that case when we add a lot of categories it might make sense to pre-load the cache with all the existing categories.
- hasSeparateNorms() - Method in class org.apache.lucene.index.SegmentInfo
-
Returns true if any fields in this segment have separate norms.
- hasSeparateNorms(int) - Method in class org.apache.lucene.index.SegmentInfo
-
Returns true if this field for this segment has saved a separate norms file (_
_N.sX). - hasUncaughtExceptions() - Method in class org.apache.lucene.util.UncaughtExceptionsRule
-
Just a check if anything's been caught.
- hasVectors - Variable in class org.apache.lucene.index.SegmentWriteState
- hasVectors() - Method in class org.apache.lucene.index.FieldInfos
- haversine(double, double, double, double, double) - Static method in class org.apache.lucene.spatial.DistanceUtils
-
Deprecated.Computes the haversine distance between two points.
- header - Variable in class org.apache.lucene.benchmark.byTask.feeds.LineDocSource.LineParser
- HEADER - Static variable in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
- HEADER - Static variable in class org.apache.lucene.analysis.ja.dict.ConnectionCosts
- headerLength(String) - Static method in class org.apache.lucene.util.CodecUtil
- HeaderLineParser(String[]) - Constructor for class org.apache.lucene.benchmark.byTask.feeds.LineDocSource.HeaderLineParser
- HEADING - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
- HEADING_ID - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
- Heap<T> - Interface in org.apache.lucene.facet.search
-
Declares an interface for heap (and heap alike) structures, handling a given type T
- HEH - Static variable in class org.apache.lucene.analysis.ar.ArabicNormalizer
- HEH - Static variable in class org.apache.lucene.analysis.ar.ArabicStemmer
- HEH - Static variable in class org.apache.lucene.analysis.fa.PersianNormalizer
- HEH_GOAL - Static variable in class org.apache.lucene.analysis.fa.PersianNormalizer
- HEH_YEH - Static variable in class org.apache.lucene.analysis.fa.PersianNormalizer
- HEX - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
RegularExpression Id.
- hexToInt(String) - Static method in class org.apache.lucene.search.highlight.GradientFormatter
-
Converts a hex string into an int.
- HHMMSegmenter - Class in org.apache.lucene.analysis.cn.smart.hhmm
-
Finds the optimal segmentation of a sentence into Chinese words
- HHMMSegmenter() - Constructor for class org.apache.lucene.analysis.cn.smart.hhmm.HHMMSegmenter
- hi - Variable in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
-
Pointer to high branch.
- HighFreqTerms - Class in org.apache.lucene.misc
-
HighFreqTerms
class extracts the top n most frequent terms (by document frequency ) from an existing Lucene index and reports their document frequency. - HighFreqTerms() - Constructor for class org.apache.lucene.misc.HighFreqTerms
- HighFrequencyDictionary - Class in org.apache.lucene.search.spell
-
HighFrequencyDictionary: terms taken from the given field of a Lucene index, which appear in a number of documents above a given threshold.
- HighFrequencyDictionary(IndexReader, String, float) - Constructor for class org.apache.lucene.search.spell.HighFrequencyDictionary
- highlightBackground - Variable in class org.apache.lucene.search.highlight.GradientFormatter
- highlighter - Variable in class org.apache.lucene.benchmark.byTask.tasks.SearchTravRetHighlightTask
- highlighter - Variable in class org.apache.lucene.benchmark.byTask.tasks.SearchTravRetVectorHighlightTask
- Highlighter - Class in org.apache.lucene.search.highlight
-
Class used to markup highlighted terms found in the best sections of a text, using configurable
Fragmenter
,Scorer
,Formatter
,Encoder
and tokenizers. - Highlighter(Formatter, Encoder, Scorer) - Constructor for class org.apache.lucene.search.highlight.Highlighter
- Highlighter(Formatter, Scorer) - Constructor for class org.apache.lucene.search.highlight.Highlighter
- Highlighter(Scorer) - Constructor for class org.apache.lucene.search.highlight.Highlighter
- highlightForeground - Variable in class org.apache.lucene.search.highlight.GradientFormatter
- highlightTerm(String, TokenGroup) - Method in interface org.apache.lucene.search.highlight.Formatter
- highlightTerm(String, TokenGroup) - Method in class org.apache.lucene.search.highlight.GradientFormatter
- highlightTerm(String, TokenGroup) - Method in class org.apache.lucene.search.highlight.SimpleHTMLFormatter
- highlightTerm(String, TokenGroup) - Method in class org.apache.lucene.search.highlight.SpanGradientFormatter
- HIKID - Static variable in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie.TSTNode
-
Index values for accessing relatives array.
- HindiAnalyzer - Class in org.apache.lucene.analysis.hi
-
Analyzer for Hindi.
- HindiAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.hi.HindiAnalyzer
-
Builds an analyzer with the default stop words:
HindiAnalyzer.DEFAULT_STOPWORD_FILE
. - HindiAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.hi.HindiAnalyzer
-
Builds an analyzer with the given stop words
- HindiAnalyzer(Version, Set<?>, Set<?>) - Constructor for class org.apache.lucene.analysis.hi.HindiAnalyzer
-
Builds an analyzer with the given stop words
- HindiNormalizationFilter - Class in org.apache.lucene.analysis.hi
-
A
TokenFilter
that appliesHindiNormalizer
to normalize the orthography. - HindiNormalizationFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.hi.HindiNormalizationFilter
- HindiNormalizer - Class in org.apache.lucene.analysis.hi
-
Normalizer for Hindi.
- HindiNormalizer() - Constructor for class org.apache.lucene.analysis.hi.HindiNormalizer
- HindiStemFilter - Class in org.apache.lucene.analysis.hi
-
A
TokenFilter
that appliesHindiStemmer
to stem Hindi words. - HindiStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.hi.HindiStemFilter
- HindiStemmer - Class in org.apache.lucene.analysis.hi
-
Light Stemmer for Hindi.
- HindiStemmer() - Constructor for class org.apache.lucene.analysis.hi.HindiStemmer
- HIRAGANA - Static variable in class org.apache.lucene.analysis.cjk.CJKBigramFilter
-
bigram flag for Hiragana
- HIRAGANA - Static variable in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
- HIRAGANA - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
- HIRAGANA - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
- HIRAGANA_TYPE - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
- HIRAGANA_TYPE - Static variable in class org.apache.lucene.analysis.standard.std31.StandardTokenizerImpl31
-
Deprecated.
- HIRAGANA_TYPE - Static variable in class org.apache.lucene.analysis.standard.std31.UAX29URLEmailTokenizerImpl31
-
Deprecated.
- HIRAGANA_TYPE - Static variable in class org.apache.lucene.analysis.standard.std34.UAX29URLEmailTokenizerImpl34
-
Deprecated.
- HIRAGANA_TYPE - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
-
Deprecated.use
UAX29URLEmailTokenizer.TOKEN_TYPES
instead - HIRAGANA_TYPE - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizerImpl
- hits2str(ScoreDoc[], ScoreDoc[], int, int) - Static method in class org.apache.lucene.search.CheckHits
- HOST - Static variable in class org.apache.lucene.analysis.standard.ClassicTokenizer
- HOST - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
-
Deprecated.
- HOST_ID - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
- HOUR - org.apache.lucene.document.DateTools.Resolution
- hstrcmp(char[], int, char[], int) - Method in class org.apache.lucene.analysis.compound.hyphenation.HyphenationTree
-
String compare, returns 0 if equal or t is a substring of s
- HTMLDocument() - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParser
- htmlEncode(String) - Static method in class org.apache.lucene.search.highlight.SimpleHTMLEncoder
-
Encode string into HTML
- HTMLParser - Class in org.apache.lucene.benchmark.byTask.feeds.demohtml
- HTMLParser - Interface in org.apache.lucene.benchmark.byTask.feeds
-
HTML Parsing Interface for test purposes
- HTMLParser(InputStream) - Constructor for class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParser
-
Constructor with InputStream.
- HTMLParser(InputStream, String) - Constructor for class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParser
-
Constructor with InputStream and supplied encoding
- HTMLParser(Reader) - Constructor for class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParser
-
Constructor.
- HTMLParser(HTMLParserTokenManager) - Constructor for class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParser
-
Constructor with generated Token Manager.
- HTMLParserConstants - Interface in org.apache.lucene.benchmark.byTask.feeds.demohtml
-
Token literal values and constants.
- HTMLParserTokenManager - Class in org.apache.lucene.benchmark.byTask.feeds.demohtml
-
Token Manager.
- HTMLParserTokenManager(SimpleCharStream) - Constructor for class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserTokenManager
-
Constructor.
- HTMLParserTokenManager(SimpleCharStream, int) - Constructor for class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserTokenManager
-
Constructor.
- HTMLStripCharFilter - Class in org.apache.lucene.analysis.charfilter
-
A CharFilter that wraps another Reader and attempts to strip out HTML constructs.
- HTMLStripCharFilter(CharStream) - Constructor for class org.apache.lucene.analysis.charfilter.HTMLStripCharFilter
- HTMLStripCharFilter(CharStream, Set<String>) - Constructor for class org.apache.lucene.analysis.charfilter.HTMLStripCharFilter
- humanReadableUnits(long) - Static method in class org.apache.lucene.util.RamUsageEstimator
-
Returns
size
in human-readable units (GB, MB, KB or bytes). - humanReadableUnits(long, DecimalFormat) - Static method in class org.apache.lucene.util.RamUsageEstimator
-
Returns
size
in human-readable units (GB, MB, KB or bytes). - humanSizeOf(Object) - Static method in class org.apache.lucene.util.RamUsageEstimator
-
Return a human-readable size of a given object.
- HungarianAnalyzer - Class in org.apache.lucene.analysis.hu
-
Analyzer
for Hungarian. - HungarianAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.hu.HungarianAnalyzer
-
Builds an analyzer with the default stop words:
HungarianAnalyzer.DEFAULT_STOPWORD_FILE
. - HungarianAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.hu.HungarianAnalyzer
-
Builds an analyzer with the given stop words.
- HungarianAnalyzer(Version, Set<?>, Set<?>) - Constructor for class org.apache.lucene.analysis.hu.HungarianAnalyzer
-
Builds an analyzer with the given stop words.
- HungarianLightStemFilter - Class in org.apache.lucene.analysis.hu
-
A
TokenFilter
that appliesHungarianLightStemmer
to stem Hungarian words. - HungarianLightStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.hu.HungarianLightStemFilter
- HungarianLightStemmer - Class in org.apache.lucene.analysis.hu
-
Light Stemmer for Hungarian.
- HungarianLightStemmer() - Constructor for class org.apache.lucene.analysis.hu.HungarianLightStemmer
- HungarianStemmer - Class in org.tartarus.snowball.ext
-
Generated class implementing code defined by a snowball script.
- HungarianStemmer() - Constructor for class org.tartarus.snowball.ext.HungarianStemmer
- HunspellAffix - Class in org.apache.lucene.analysis.hunspell
-
Wrapper class representing a hunspell affix
- HunspellAffix() - Constructor for class org.apache.lucene.analysis.hunspell.HunspellAffix
- HunspellDictionary - Class in org.apache.lucene.analysis.hunspell
-
In-memory structure for the dictionary (.dic) and affix (.aff) data of a hunspell dictionary.
- HunspellDictionary(InputStream, InputStream, Version) - Constructor for class org.apache.lucene.analysis.hunspell.HunspellDictionary
-
Creates a new HunspellDictionary containing the information read from the provided InputStreams to hunspell affix and dictionary files.
- HunspellDictionary(InputStream, InputStream, Version, boolean) - Constructor for class org.apache.lucene.analysis.hunspell.HunspellDictionary
-
Creates a new HunspellDictionary containing the information read from the provided InputStreams to hunspell affix and dictionary files.
- HunspellDictionary(InputStream, List<InputStream>, Version, boolean) - Constructor for class org.apache.lucene.analysis.hunspell.HunspellDictionary
-
Creates a new HunspellDictionary containing the information read from the provided InputStreams to hunspell affix and dictionary files.
- HunspellStemFilter - Class in org.apache.lucene.analysis.hunspell
-
TokenFilter that uses hunspell affix rules and words to stem tokens.
- HunspellStemFilter(TokenStream, HunspellDictionary) - Constructor for class org.apache.lucene.analysis.hunspell.HunspellStemFilter
-
Creates a new HunspellStemFilter that will stem tokens from the given TokenStream using affix rules in the provided HunspellDictionary
- HunspellStemFilter(TokenStream, HunspellDictionary, boolean) - Constructor for class org.apache.lucene.analysis.hunspell.HunspellStemFilter
-
Creates a new HunspellStemFilter that will stem tokens from the given TokenStream using affix rules in the provided HunspellDictionary
- HunspellStemmer - Class in org.apache.lucene.analysis.hunspell
-
HunspellStemmer uses the affix rules declared in the HunspellDictionary to generate one or more stems for a word.
- HunspellStemmer(HunspellDictionary) - Constructor for class org.apache.lucene.analysis.hunspell.HunspellStemmer
-
Constructs a new HunspellStemmer which will use the provided HunspellDictionary to create its stems
- HunspellStemmer.Stem - Class in org.apache.lucene.analysis.hunspell
-
Stem represents all information known about a stem of a word.
- HunspellWord - Class in org.apache.lucene.analysis.hunspell
-
A dictionary (.dic) entry with its associated flags.
- HunspellWord() - Constructor for class org.apache.lucene.analysis.hunspell.HunspellWord
-
Creates a new HunspellWord with no associated flags
- HunspellWord(char[]) - Constructor for class org.apache.lucene.analysis.hunspell.HunspellWord
-
Constructs a new HunspellWord with the given flags
- hyperbolicTf(float) - Method in class org.apache.lucene.misc.SweetSpotSimilarity
-
Uses a hyperbolic tangent function that allows for a hard max...
- Hyphen - Class in org.apache.lucene.analysis.compound.hyphenation
-
This class represents a hyphen.
- hyphenate(char[], int, int, int, int) - Method in class org.apache.lucene.analysis.compound.hyphenation.HyphenationTree
-
Hyphenate word and return an array of hyphenation points.
- hyphenate(String, int, int) - Method in class org.apache.lucene.analysis.compound.hyphenation.HyphenationTree
-
Hyphenate word and return a Hyphenation object.
- Hyphenation - Class in org.apache.lucene.analysis.compound.hyphenation
-
This class represents a hyphenated word.
- HyphenationCompoundWordTokenFilter - Class in org.apache.lucene.analysis.compound
-
A
TokenFilter
that decomposes compound words found in many Germanic languages. - HyphenationCompoundWordTokenFilter(TokenStream, HyphenationTree, String[]) - Constructor for class org.apache.lucene.analysis.compound.HyphenationCompoundWordTokenFilter
-
Deprecated.
- HyphenationCompoundWordTokenFilter(TokenStream, HyphenationTree, String[], int, int, int, boolean) - Constructor for class org.apache.lucene.analysis.compound.HyphenationCompoundWordTokenFilter
- HyphenationCompoundWordTokenFilter(TokenStream, HyphenationTree, Set<?>) - Constructor for class org.apache.lucene.analysis.compound.HyphenationCompoundWordTokenFilter
-
Deprecated.
- HyphenationCompoundWordTokenFilter(TokenStream, HyphenationTree, Set<?>, int, int, int, boolean) - Constructor for class org.apache.lucene.analysis.compound.HyphenationCompoundWordTokenFilter
- HyphenationCompoundWordTokenFilter(Version, TokenStream, HyphenationTree) - Constructor for class org.apache.lucene.analysis.compound.HyphenationCompoundWordTokenFilter
-
Create a HyphenationCompoundWordTokenFilter with no dictionary.
- HyphenationCompoundWordTokenFilter(Version, TokenStream, HyphenationTree, int, int, int) - Constructor for class org.apache.lucene.analysis.compound.HyphenationCompoundWordTokenFilter
-
Create a HyphenationCompoundWordTokenFilter with no dictionary.
- HyphenationCompoundWordTokenFilter(Version, TokenStream, HyphenationTree, String[]) - Constructor for class org.apache.lucene.analysis.compound.HyphenationCompoundWordTokenFilter
-
Deprecated.Use the constructors taking
Set
- HyphenationCompoundWordTokenFilter(Version, TokenStream, HyphenationTree, String[], int, int, int, boolean) - Constructor for class org.apache.lucene.analysis.compound.HyphenationCompoundWordTokenFilter
-
Deprecated.Use the constructors taking
Set
- HyphenationCompoundWordTokenFilter(Version, TokenStream, HyphenationTree, Set<?>) - Constructor for class org.apache.lucene.analysis.compound.HyphenationCompoundWordTokenFilter
-
Creates a new
HyphenationCompoundWordTokenFilter
instance. - HyphenationCompoundWordTokenFilter(Version, TokenStream, HyphenationTree, Set<?>, int, int, int, boolean) - Constructor for class org.apache.lucene.analysis.compound.HyphenationCompoundWordTokenFilter
-
Creates a new
HyphenationCompoundWordTokenFilter
instance. - HyphenationException - Exception in org.apache.lucene.analysis.compound.hyphenation
-
This class has been taken from the Apache FOP project (http://xmlgraphics.apache.org/fop/).
- HyphenationException(String) - Constructor for exception org.apache.lucene.analysis.compound.hyphenation.HyphenationException
- HyphenationTree - Class in org.apache.lucene.analysis.compound.hyphenation
-
This tree structure stores the hyphenation patterns in an efficient way for fast lookup.
- HyphenationTree() - Constructor for class org.apache.lucene.analysis.compound.hyphenation.HyphenationTree
I
- ICU - org.apache.lucene.benchmark.byTask.tasks.NewCollationAnalyzerTask.Implementation
- ICUCollationKeyAnalyzer - Class in org.apache.lucene.collation
-
Filters
KeywordTokenizer
withICUCollationKeyFilter
. - ICUCollationKeyAnalyzer(Collator) - Constructor for class org.apache.lucene.collation.ICUCollationKeyAnalyzer
- ICUCollationKeyFilter - Class in org.apache.lucene.collation
-
Converts each token into its
CollationKey
, and then encodes the CollationKey withIndexableBinaryStringTools
, to allow it to be stored as an index term. - ICUCollationKeyFilter(TokenStream, Collator) - Constructor for class org.apache.lucene.collation.ICUCollationKeyFilter
- 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
- 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
- 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(Reader) - Constructor for class org.apache.lucene.analysis.icu.segmentation.ICUTokenizer
-
Construct a new ICUTokenizer that breaks text into words from the given Reader.
- ICUTokenizer(Reader, 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
- ICUTransformFilter - Class in org.apache.lucene.analysis.icu
-
A
TokenFilter
that transforms text with ICU. - ICUTransformFilter(TokenStream, Transliterator) - Constructor for class org.apache.lucene.analysis.icu.ICUTransformFilter
-
Create a new ICUTransformFilter that transforms text on the given stream.
- ID_FIELD - Static variable in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
- 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 - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
- IDEOGRAPHIC_TYPE - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
- IDEOGRAPHIC_TYPE - Static variable in class org.apache.lucene.analysis.standard.std31.StandardTokenizerImpl31
-
Deprecated.
- IDEOGRAPHIC_TYPE - Static variable in class org.apache.lucene.analysis.standard.std31.UAX29URLEmailTokenizerImpl31
-
Deprecated.
- IDEOGRAPHIC_TYPE - Static variable in class org.apache.lucene.analysis.standard.std34.UAX29URLEmailTokenizerImpl34
-
Deprecated.
- IDEOGRAPHIC_TYPE - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
-
Deprecated.use
UAX29URLEmailTokenizer.TOKEN_TYPES
instead - IDEOGRAPHIC_TYPE - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizerImpl
- idf - Variable in class org.apache.lucene.search.spans.SpanWeight
- idf(int, int) - Method in class org.apache.lucene.search.DefaultSimilarity
-
Implemented as
log(numDocs/(docFreq+1)) + 1
. - idf(int, int) - Method in class org.apache.lucene.search.Similarity
-
Computes a score factor based on a term's document frequency (the number of documents which contain the term).
- idf(int, int) - Method in class org.apache.lucene.search.SimilarityDelegator
-
Deprecated.
- idfExplain(Collection<Term>, Searcher) - Method in class org.apache.lucene.search.Similarity
-
Computes a score factor for a phrase.
- idfExplain(Term, Searcher) - Method in class org.apache.lucene.search.Similarity
-
This method forwards to
Similarity.idfExplain(Term,Searcher,int)
by passingsearcher.docFreq(term)
as the docFreq. - idfExplain(Term, Searcher, int) - Method in class org.apache.lucene.search.Similarity
-
Computes a score factor for a simple term and returns an explanation for that score factor.
- IDFExplanation() - Constructor for class org.apache.lucene.search.Explanation.IDFExplanation
- IGNORE - org.apache.lucene.search.CachingWrapperFilter.DeletesMode
- ignoringSinglePrefixOrSuffixShingleByDefault - Static variable in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter
-
Deprecated.
- image - Variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.Token
-
The string image of the token.
- image - Variable in class org.apache.lucene.queryParser.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.
- image - Variable in class org.apache.lucene.queryParser.Token
-
The string image of the token.
- in - Variable in class org.apache.lucene.index.FilterIndexReader.FilterTermDocs
- in - Variable in class org.apache.lucene.index.FilterIndexReader.FilterTermEnum
- in - Variable in class org.apache.lucene.index.FilterIndexReader
- in - Variable in class org.apache.lucene.index.pruning.StorePruningPolicy
- in - Variable in class org.apache.lucene.index.pruning.TermPruningPolicy
- in - Variable in class org.apache.lucene.util.encoding.IntDecoder
-
Input stream from which the encoded bytes are read
- 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
- inBuf - Variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
- inBuf - Variable in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
- includesLower() - Method in class org.apache.lucene.search.FieldCacheRangeFilter
-
Returns
true
if the lower endpoint is inclusive - includesLower() - Method in class org.apache.lucene.search.TermRangeFilter
-
Returns
true
if the lower endpoint is inclusive - includesLower() - Method in class org.apache.lucene.search.TermRangeQuery
-
Returns
true
if the lower endpoint is inclusive - includesMax() - Method in class org.apache.lucene.search.NumericRangeFilter
-
Returns
true
if the upper endpoint is inclusive - includesMax() - Method in class org.apache.lucene.search.NumericRangeQuery
-
Returns
true
if the upper endpoint is inclusive - includesMin() - Method in class org.apache.lucene.search.NumericRangeFilter
-
Returns
true
if the lower endpoint is inclusive - includesMin() - Method in class org.apache.lucene.search.NumericRangeQuery
-
Returns
true
if the lower endpoint is inclusive - includesUpper() - Method in class org.apache.lucene.search.FieldCacheRangeFilter
-
Returns
true
if the upper endpoint is inclusive - includesUpper() - Method in class org.apache.lucene.search.TermRangeFilter
-
Returns
true
if the upper endpoint is inclusive - includesUpper() - Method in class org.apache.lucene.search.TermRangeQuery
-
Returns
true
if the upper endpoint is inclusive - InconsistentTaxonomyException - Exception in org.apache.lucene.facet.taxonomy
-
Exception indicating that a certain operation could not be performed on a taxonomy related object because of an inconsistency.
- InconsistentTaxonomyException() - Constructor for exception org.apache.lucene.facet.taxonomy.InconsistentTaxonomyException
- InconsistentTaxonomyException(String) - Constructor for exception org.apache.lucene.facet.taxonomy.InconsistentTaxonomyException
- increaseResidue(double) - Method in class org.apache.lucene.facet.search.results.MutableFacetResultNode
-
increase the residue for this result.
- increaseValue(double) - Method in class org.apache.lucene.facet.search.results.MutableFacetResultNode
-
increase the value for this result.
- incRef() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyReader
-
Expert: increments the refCount of this TaxonomyReader instance.
- incRef() - Method in interface 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.
- 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.ASCIIFoldingFilter
- incrementToken() - Method in class org.apache.lucene.analysis.bg.BulgarianStemFilter
- incrementToken() - Method in class org.apache.lucene.analysis.br.BrazilianStemFilter
- incrementToken() - Method in class org.apache.lucene.analysis.CachingTokenFilter
- incrementToken() - Method in class org.apache.lucene.analysis.CannedTokenStream
- incrementToken() - Method in class org.apache.lucene.analysis.CharTokenizer
- incrementToken() - Method in class org.apache.lucene.analysis.cjk.CJKBigramFilter
- incrementToken() - Method in class org.apache.lucene.analysis.cjk.CJKTokenizer
-
Deprecated.Returns true for the next token in the stream, or false at EOS.
- incrementToken() - Method in class org.apache.lucene.analysis.cjk.CJKWidthFilter
- incrementToken() - Method in class org.apache.lucene.analysis.cn.ChineseFilter
-
Deprecated.
- incrementToken() - Method in class org.apache.lucene.analysis.cn.ChineseTokenizer
-
Deprecated.
- incrementToken() - Method in class org.apache.lucene.analysis.cn.smart.SentenceTokenizer
- incrementToken() - Method in class org.apache.lucene.analysis.cn.smart.WordTokenFilter
- incrementToken() - Method in class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
- 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.EmptyTokenizer
- 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.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.ElisionFilter
-
Increments the
TokenStream
with aCharTermAttribute
without elisioned start - 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.fr.FrenchStemFilter
-
Deprecated.
- 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
-
Consumers (i.e.,
IndexWriter
) use this method to advance the stream to the next token. - 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.ISOLatin1AccentFilter
-
Deprecated.
- 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.JapaneseReadingFormFilter
- incrementToken() - Method in class org.apache.lucene.analysis.ja.JapaneseTokenizer
- incrementToken() - Method in class org.apache.lucene.analysis.KeywordMarkerFilter
- incrementToken() - Method in class org.apache.lucene.analysis.KeywordTokenizer
- incrementToken() - Method in class org.apache.lucene.analysis.LimitTokenCountFilter
- incrementToken() - Method in class org.apache.lucene.analysis.LowerCaseFilter
- incrementToken() - Method in class org.apache.lucene.analysis.lv.LatvianStemFilter
- incrementToken() - Method in class org.apache.lucene.analysis.miscellaneous.EmptyTokenStream
- incrementToken() - Method in class org.apache.lucene.analysis.miscellaneous.PrefixAndSuffixAwareTokenFilter
- incrementToken() - Method in class org.apache.lucene.analysis.miscellaneous.PrefixAwareTokenFilter
- incrementToken() - Method in class org.apache.lucene.analysis.miscellaneous.SingleTokenTokenStream
- incrementToken() - Method in class org.apache.lucene.analysis.miscellaneous.StemmerOverrideFilter
- 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.MockRandomLookaheadTokenFilter
- 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.ngram.EdgeNGramTokenFilter
- incrementToken() - Method in class org.apache.lucene.analysis.ngram.EdgeNGramTokenizer
-
Returns the next token in the stream, or null at EOS.
- incrementToken() - Method in class org.apache.lucene.analysis.ngram.NGramTokenFilter
-
Returns the next token in the stream, or null at EOS.
- incrementToken() - Method in class org.apache.lucene.analysis.ngram.NGramTokenizer
-
Returns the next token in the stream, or null at EOS.
- incrementToken() - Method in class org.apache.lucene.analysis.nl.DutchStemFilter
-
Deprecated.Returns the next token in the stream, or null at EOS
- 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.NumericTokenStream
- 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.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.DoubleMetaphoneFilter
- incrementToken() - Method in class org.apache.lucene.analysis.phonetic.PhoneticFilter
- incrementToken() - Method in class org.apache.lucene.analysis.PorterStemFilter
- incrementToken() - Method in class org.apache.lucene.analysis.position.PositionFilter
- 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.ru.RussianLowerCaseFilter
-
Deprecated.
- incrementToken() - Method in class org.apache.lucene.analysis.ru.RussianStemFilter
-
Deprecated.Returns the next token in the stream, or null at EOS
- incrementToken() - Method in class org.apache.lucene.analysis.shingle.ShingleFilter
- incrementToken() - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter
-
Deprecated.
- 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.standard.ClassicFilter
-
Returns the next token in the stream, or null at EOS.
- incrementToken() - Method in class org.apache.lucene.analysis.standard.ClassicTokenizer
- incrementToken() - Method in class org.apache.lucene.analysis.standard.StandardFilter
- incrementToken() - Method in class org.apache.lucene.analysis.standard.StandardTokenizer
- incrementToken() - Method in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
- incrementToken() - Method in class org.apache.lucene.analysis.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
- incrementToken() - Method in class org.apache.lucene.analysis.TeeSinkTokenFilter
- incrementToken() - Method in class org.apache.lucene.analysis.TeeSinkTokenFilter.SinkTokenStream
- incrementToken() - Method in class org.apache.lucene.analysis.th.ThaiWordFilter
- 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.TurkishLowerCaseFilter
- 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.collation.CollationKeyFilter
- incrementToken() - Method in class org.apache.lucene.collation.ICUCollationKeyFilter
- incrementToken() - Method in class org.apache.lucene.facet.enhancements.association.AssociationListTokenizer
- incrementToken() - Method in class org.apache.lucene.facet.index.streaming.CategoryAttributesStream
- incrementToken() - Method in class org.apache.lucene.facet.index.streaming.CategoryListTokenizer
- incrementToken() - Method in class org.apache.lucene.facet.index.streaming.CategoryParentsStream
- incrementToken() - Method in class org.apache.lucene.facet.index.streaming.CategoryTokenizer
- incrementToken() - Method in class org.apache.lucene.facet.index.streaming.CategoryTokenizerBase
- incrementToken() - Method in class org.apache.lucene.facet.index.streaming.CountingListTokenizer
- incrementToken() - Method in class org.apache.lucene.queryParser.QueryParserTestBase.QPTestFilter
- incrementToken() - Method in class org.apache.lucene.search.highlight.OffsetLimitTokenFilter
- incrementToken() - Method in class org.apache.lucene.search.highlight.TokenStreamFromTermPositionVector
- incrementTokenClassic() - Method in class org.apache.lucene.analysis.standard.StandardFilter
- incTotalNumberOfTerms(int) - Method in class org.apache.lucene.search.MultiTermQuery
-
Deprecated.Don't use this method, as its not thread safe and useless.
- index - 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_CREATE_TIME - Static variable in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
-
Property name of user commit data that contains the creation time of a taxonomy index.
- INDEX_EXTENSIONS - Static variable in class org.apache.lucene.index.IndexFileNames
-
This array contains all filename extensions used by Lucene's index files, with two exceptions, namely the extension made up from
.f
+ a number and from.s
+ a number. - INDEX_EXTENSIONS_IN_COMPOUND_FILE - Static variable in class org.apache.lucene.index.IndexFileNames
-
File extensions that are added to a compound file (same as above, minus "del", "gen", "cfs").
- IndexableBinaryStringTools - Class in org.apache.lucene.util
-
Provides support for converting byte sequences to Strings and back again.
- IndexCommit - Class in org.apache.lucene.index
-
Expert: represents a single commit into an index as seen by the
IndexDeletionPolicy
orIndexReader
. - IndexCommit() - Constructor for class org.apache.lucene.index.IndexCommit
- IndexDeletionPolicy - Interface in org.apache.lucene.index
-
Expert: policy for deletion of stale
index commits
. - indexDictionary(Dictionary, IndexWriterConfig, boolean) - Method in class org.apache.lucene.search.spell.SpellChecker
-
Indexes the data from the given
Dictionary
. - indexesOf(String[], int, int) - Method in interface org.apache.lucene.index.TermFreqVector
-
Just like
indexOf(int)
but searches for a number of terms at the same time. - indexesOf(String[], int, int) - Method in class org.apache.lucene.search.QueryTermVector
- indexesOf(String[], int, int) - Method in class org.apache.lucene.store.instantiated.InstantiatedTermFreqVector
- indexExists(Directory) - Static method in class org.apache.lucene.index.IndexReader
-
Returns
true
if an index exists at the specified directory. - IndexFileNameFilter - Class in org.apache.lucene.index
-
Filename filter that accept filenames and extensions only created by Lucene.
- IndexFileNames - Class in org.apache.lucene.index
-
This class contains useful constants representing filenames and extensions used by lucene, as well as convenience methods for querying whether a file name matches an extension (
matchesExtension
), as well as generating file names from a segment name, generation and extension (fileNameFromGeneration
,segmentFileName
). - IndexFileNames() - Constructor for class org.apache.lucene.index.IndexFileNames
- 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
- IndexFormatTooNewException(DataInput, int, int, int) - Constructor for exception org.apache.lucene.index.IndexFormatTooNewException
- IndexFormatTooOldException - Exception in org.apache.lucene.index
-
This exception is thrown when Lucene detects an index that is too old for this Lucene version
- IndexFormatTooOldException(String, int, int, int) - Constructor for exception org.apache.lucene.index.IndexFormatTooOldException
- IndexFormatTooOldException(String, String) - Constructor for exception org.apache.lucene.index.IndexFormatTooOldException
- IndexFormatTooOldException(DataInput, int, int, int) - Constructor for exception org.apache.lucene.index.IndexFormatTooOldException
- IndexFormatTooOldException(DataInput, String) - Constructor for exception org.apache.lucene.index.IndexFormatTooOldException
- indexingParams - Variable in class org.apache.lucene.facet.index.CategoryDocumentBuilder
-
Parameters to be used when indexing categories.
- indexingParams - Variable in class org.apache.lucene.facet.index.streaming.CategoryTokenizerBase
-
Indexing params for creating term text
- indexingParams - Variable in class org.apache.lucene.facet.search.params.FacetSearchParams
- IndexInput - Class in org.apache.lucene.store
-
Abstract base class for input from a file in a
Directory
. - IndexInput() - Constructor for class org.apache.lucene.store.IndexInput
-
Deprecated.please pass resourceDescription
- IndexInput(String) - Constructor for class org.apache.lucene.store.IndexInput
-
resourceDescription should be a non-null, opaque string describing this resource; it's returned from
IndexInput.toString()
. - 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
- indexOf(Object) - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorPipeline
- indexOf(String) - Method in interface org.apache.lucene.index.TermFreqVector
-
Return an index in the term numbers array returned from
getTerms
at which the term with the specifiedterm
appears. - indexOf(String) - Method in class org.apache.lucene.search.QueryTermVector
- indexOf(String) - Method in class org.apache.lucene.store.instantiated.InstantiatedTermFreqVector
- indexOf(SegmentInfo) - Method in class org.apache.lucene.index.SegmentInfos
- indexOptions - Variable in class org.apache.lucene.document.AbstractField
- indexOptions - Variable in class org.apache.lucene.index.FieldInfo
- INDEXORDER - Static variable in class org.apache.lucene.search.Sort
-
Represents sorting by index order.
- IndexOutput - Class in org.apache.lucene.store
-
Abstract base class for output to a file in a Directory.
- IndexOutput() - Constructor for class org.apache.lucene.store.IndexOutput
- indexProperties - Variable in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
- indexReader - Variable in class org.apache.lucene.facet.search.FacetsAccumulator
- IndexReader - Class in org.apache.lucene.index
-
IndexReader is an abstract class, providing an interface for accessing an index.
- IndexReader() - Constructor for class org.apache.lucene.index.IndexReader
- IndexReader.ReaderClosedListener - Interface in org.apache.lucene.index
-
A custom listener that's invoked when the IndexReader is closed.
- indexReaderFactory() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndex
-
Deprecated.
- IndexReaderWarmer() - Constructor for class org.apache.lucene.index.IndexWriter.IndexReaderWarmer
- 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(IndexReader, IndexReader[], int[]) - Constructor for class org.apache.lucene.search.IndexSearcher
-
Expert: directly specify the reader, subReaders and their docID starts.
- IndexSearcher(IndexReader, IndexReader[], int[], ExecutorService) - Constructor for class org.apache.lucene.search.IndexSearcher
-
Expert: directly specify the reader, subReaders and their docID starts, and an ExecutorService.
- IndexSearcher(Directory) - Constructor for class org.apache.lucene.search.IndexSearcher
-
Deprecated.use
IndexSearcher(IndexReader)
instead. - IndexSearcher(Directory, boolean) - Constructor for class org.apache.lucene.search.IndexSearcher
-
Deprecated.Use
IndexSearcher(IndexReader)
instead. - IndexSorter - Class in org.apache.lucene.index
-
Sort an index by document importance factor.
- IndexSorter() - Constructor for class org.apache.lucene.index.IndexSorter
- 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(File) - Constructor for class org.apache.lucene.index.IndexSplitter
- 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, IndexWriterConfig, PrintStream, boolean) - Constructor for class org.apache.lucene.index.IndexUpgrader
-
Creates index upgrader on the given directory, using an
IndexWriter
using the given config. - IndexUpgrader(Directory, Version) - Constructor for class org.apache.lucene.index.IndexUpgrader
-
Creates index upgrader on the given directory, using an
IndexWriter
using the givenmatchVersion
. - IndexUpgrader(Directory, Version, PrintStream, boolean) - Constructor for class org.apache.lucene.index.IndexUpgrader
-
Creates index upgrader on the given directory, using an
IndexWriter
using the givenmatchVersion
. - indexVal - Variable in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
- IndexWriter - Class in org.apache.lucene.index
-
An
IndexWriter
creates and maintains an index. - IndexWriter(Directory, Analyzer, boolean, IndexDeletionPolicy, IndexWriter.MaxFieldLength) - Constructor for class org.apache.lucene.index.IndexWriter
-
Deprecated.use
IndexWriter(Directory, IndexWriterConfig)
instead - IndexWriter(Directory, Analyzer, boolean, IndexWriter.MaxFieldLength) - Constructor for class org.apache.lucene.index.IndexWriter
-
Deprecated.use
IndexWriter(Directory, IndexWriterConfig)
instead - IndexWriter(Directory, Analyzer, IndexDeletionPolicy, IndexWriter.MaxFieldLength) - Constructor for class org.apache.lucene.index.IndexWriter
-
Deprecated.use
IndexWriter(Directory, IndexWriterConfig)
instead - IndexWriter(Directory, Analyzer, IndexDeletionPolicy, IndexWriter.MaxFieldLength, IndexCommit) - Constructor for class org.apache.lucene.index.IndexWriter
-
Deprecated.use
IndexWriter(Directory, IndexWriterConfig)
instead - IndexWriter(Directory, Analyzer, IndexWriter.MaxFieldLength) - Constructor for class org.apache.lucene.index.IndexWriter
-
Deprecated.use
IndexWriter(Directory, IndexWriterConfig)
instead - IndexWriter(Directory, IndexWriterConfig) - Constructor for class org.apache.lucene.index.IndexWriter
-
Constructs a new IndexWriter per the settings given in
conf
. - IndexWriter.IndexReaderWarmer - Class in org.apache.lucene.index
-
If
IndexWriter.getReader()
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. - IndexWriter.MaxFieldLength - Class in org.apache.lucene.index
-
Deprecated.use
LimitTokenCountAnalyzer
instead. - IndexWriterConfig - Class in org.apache.lucene.index
-
Holds all the configuration of
IndexWriter
. - IndexWriterConfig(Version, Analyzer) - Constructor for class org.apache.lucene.index.IndexWriterConfig
- IndexWriterConfig.OpenMode - Enum in org.apache.lucene.index
-
Specifies the open mode for
IndexWriter
:IndexWriterConfig.OpenMode.CREATE
- creates a new index or overwrites an existing one. - indexWriterFactory(Analyzer, boolean) - Method in class org.apache.lucene.store.instantiated.InstantiatedIndex
-
Deprecated.
- indicator - Variable in class org.apache.lucene.util.encoding.ChunksIntEncoder
-
Represents bits flag byte.
- IndicNormalizationFilter - Class in org.apache.lucene.analysis.in
-
A
TokenFilter
that appliesIndicNormalizer
to normalize text in Indian Languages. - IndicNormalizationFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.in.IndicNormalizationFilter
- 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
- IndicTokenizer - Class in org.apache.lucene.analysis.in
-
Deprecated.(3.6) Use
StandardTokenizer
instead. - IndicTokenizer(Version, Reader) - Constructor for class org.apache.lucene.analysis.in.IndicTokenizer
-
Deprecated.
- IndicTokenizer(Version, AttributeSource.AttributeFactory, Reader) - Constructor for class org.apache.lucene.analysis.in.IndicTokenizer
-
Deprecated.
- IndicTokenizer(Version, AttributeSource, Reader) - Constructor for class org.apache.lucene.analysis.in.IndicTokenizer
-
Deprecated.
- IndonesianAnalyzer - Class in org.apache.lucene.analysis.id
-
Analyzer for Indonesian (Bahasa)
- IndonesianAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.id.IndonesianAnalyzer
-
Builds an analyzer with the default stop words:
IndonesianAnalyzer.DEFAULT_STOPWORD_FILE
. - IndonesianAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.id.IndonesianAnalyzer
-
Builds an analyzer with the given stop words
- IndonesianAnalyzer(Version, Set<?>, Set<?>) - 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
-
A
TokenFilter
that appliesIndonesianStemmer
to stem Indonesian words. - 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.
- IndonesianStemmer - Class in org.apache.lucene.analysis.id
-
Stemmer for Indonesian.
- IndonesianStemmer() - Constructor for class org.apache.lucene.analysis.id.IndonesianStemmer
- 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(int) - Method in class org.apache.lucene.index.SegmentInfos
- 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.IndexSplitter
- infoStream - Variable in class org.apache.lucene.index.SegmentWriteState
- init() - Method in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
- init() - Method in interface org.apache.lucene.facet.search.CategoryListIterator
-
Initializes the iterator.
- init() - Method in class org.apache.lucene.facet.search.PayloadIntDecodingIterator
- init() - Method in class org.apache.lucene.facet.search.PayloadIterator
-
(re)initialize the iterator.
- init() - Method in class org.apache.lucene.facet.util.MultiCategoryListIterator
-
Fails if all given iterators fail to init
- init() - Method in class org.apache.lucene.util.BytesRefHash.BytesStartArray
-
Initializes the BytesStartArray.
- init() - Method in class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
- init() - Method in class org.apache.lucene.util.BytesRefHash.TrackingDirectBytesStartArray
- 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
-
Called to init the Scorer with a
TokenStream
. - init(TaxonomyWriter) - Method in class org.apache.lucene.facet.index.categorypolicy.DefaultOrdinalPolicy
-
Implemented as NO-OP as the default is not taxonomy dependent
- init(TaxonomyWriter) - Method in class org.apache.lucene.facet.index.categorypolicy.NonTopLevelOrdinalPolicy
- init(TaxonomyWriter) - Method in interface org.apache.lucene.facet.index.categorypolicy.OrdinalPolicy
-
Initialize the policy with a TaxonomyWriter.
- initFacetsAccumulator(FacetSearchParams, IndexReader, TaxonomyReader) - Method in class org.apache.lucene.facet.search.FacetsCollector
-
Create the
FacetsAccumulator
to be used. - initialize(int) - Method in class org.apache.lucene.util.PriorityQueue
-
Subclass constructors must call this.
- initializeMessages(String, Class<? extends NLS>) - Static method in class org.apache.lucene.messages.NLS
-
Deprecated.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
- initPositionsTerm(TermPositions, Term) - Method in class org.apache.lucene.index.pruning.CarmelTopKTermPruningPolicy
- initPositionsTerm(TermPositions, Term) - Method in class org.apache.lucene.index.pruning.CarmelUniformTermPruningPolicy
- initPositionsTerm(TermPositions, Term) - Method in class org.apache.lucene.index.pruning.RIDFTermPruningPolicy
- initPositionsTerm(TermPositions, Term) - Method in class org.apache.lucene.index.pruning.TermPruningPolicy
-
Called when moving
TermPositions
to a newTerm
. - initPositionsTerm(TermPositions, Term) - Method in class org.apache.lucene.index.pruning.TFTermPruningPolicy
- initReader(Reader) - Method in class org.apache.lucene.analysis.fa.PersianAnalyzer
-
Wraps the Reader with
PersianCharFilter
- initReader(Reader) - Method in class org.apache.lucene.analysis.ReusableAnalyzerBase
-
Override this if you want to add a CharFilter chain.
- initScoredDocCollector(FacetSearchParams, IndexReader, TaxonomyReader) - Method in class org.apache.lucene.facet.search.FacetsCollector
-
Create a
ScoredDocIdCollector
to be used as the first phase of the facet collection. - initSize - Variable in class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
- initSize - Variable in class org.apache.lucene.util.BytesRefHash.TrackingDirectBytesStartArray
- inject - Variable in class org.apache.lucene.analysis.phonetic.PhoneticFilter
- InMemorySorter - Class in org.apache.lucene.search.suggest.fst
-
An
BytesRefSorter
that keeps all the entries in memory. - InMemorySorter(Comparator<BytesRef>) - Constructor for class org.apache.lucene.search.suggest.fst.InMemorySorter
- inOrder - Variable in class org.apache.lucene.search.spans.SpanNearQuery
- inPlaceAnd(DocIdSetIterator) - Method in class org.apache.lucene.util.OpenBitSetDISI
-
Perform an inplace AND with the doc ids from a given DocIdSetIterator, leaving only the bits set for which the doc ids are in common.
- inPlaceNot(DocIdSetIterator) - Method in class org.apache.lucene.util.OpenBitSetDISI
-
Perform an inplace NOT with the doc ids from a given DocIdSetIterator, clearing all the bits for each such doc id.
- inPlaceOr(DocIdSetIterator) - Method in class org.apache.lucene.util.OpenBitSetDISI
-
Perform an inplace OR with the doc ids from a given DocIdSetIterator, setting the bit for each such doc id.
- inPlaceXor(DocIdSetIterator) - Method in class org.apache.lucene.util.OpenBitSetDISI
-
Perform an inplace XOR with the doc ids from a given DocIdSetIterator, flipping all the bits for each such doc id.
- input - Variable in class org.apache.lucene.analysis.CharFilter
- input - Variable in class org.apache.lucene.analysis.TokenFilter
-
The source of tokens for this filter.
- input - Variable in class org.apache.lucene.analysis.Tokenizer
-
The text source for this Tokenizer.
- input - Variable in class org.apache.lucene.util.fst.BytesRefFSTEnum.InputOutput
- input - Variable in class org.apache.lucene.util.fst.IntsRefFSTEnum.InputOutput
- input - Variable in class org.apache.lucene.util.fst.Util.MinResult
- input_stream - Variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserTokenManager
- input_stream - Variable in class org.apache.lucene.queryParser.QueryParserTokenManager
- input_stream - Variable in class org.apache.lucene.queryParser.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
- InputOutput() - Constructor for class org.apache.lucene.util.fst.BytesRefFSTEnum.InputOutput
- InputOutput() - Constructor for class org.apache.lucene.util.fst.IntsRefFSTEnum.InputOutput
- inputPos - Variable in class org.apache.lucene.analysis.LookaheadTokenFilter
- inputStream - Variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
- inputStream - Variable in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
- inputStream(File) - 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
-
A
DataInput
wrapping a plainInputStream
. - 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
- Insanity(FieldCacheSanityChecker.InsanityType, String, FieldCache.CacheEntry...) - Constructor for class org.apache.lucene.util.FieldCacheSanityChecker.Insanity
- insert(char[], int, char) - Method in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
- insert(int, int, CharSequence) - Method in class org.tartarus.snowball.SnowballProgram
- insert(int, int, String) - Method in class org.tartarus.snowball.SnowballProgram
-
Deprecated.for binary back compat. Will be removed in Lucene 4.0
- insert(int, int, StringBuilder) - Method in class org.tartarus.snowball.SnowballProgram
-
Deprecated.for binary back compat. Will be removed in Lucene 4.0
- 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(Scorer) - Method in class org.apache.lucene.util.ScorerDocQueue
-
Deprecated.Adds a Scorer to the ScorerDocQueue in log(size) time if either the ScorerDocQueue is not full, or not lessThan(scorer, top()).
- 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.
- 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.xmlparser.DOMUtils
- insertionSort(int, int) - Method in class org.apache.lucene.util.SorterTemplate
-
Sorts via stable in-place InsertionSort algorithm (ideal for small collections which are mostly presorted).
- insertionSort(List<T>) - Static method in class org.apache.lucene.util.CollectionUtil
-
Sorts the given random access
List
in natural order. - insertionSort(List<T>, Comparator<? super T>) - Static method in class org.apache.lucene.util.CollectionUtil
-
Sorts the given random access
List
using theComparator
. - insertionSort(T[]) - Static method in class org.apache.lucene.util.ArrayUtil
-
Sorts the given array in natural order.
- insertionSort(T[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Sorts the given array slice in natural order.
- insertionSort(T[], int, int, Comparator<? super T>) - Static method in class org.apache.lucene.util.ArrayUtil
-
Sorts the given array slice using the
Comparator
. - insertionSort(T[], Comparator<? super T>) - Static method in class org.apache.lucene.util.ArrayUtil
-
Sorts the given array using the
Comparator
. - insertSubResult(FacetResultNode) - Method in class org.apache.lucene.facet.search.results.MutableFacetResultNode
-
Insert sub result (as first).
- insertToken() - Method in class org.apache.lucene.analysis.LookaheadTokenFilter
-
Call this only from within afterPosition, to insert a new token.
- insertWithOverflow(T) - Method in interface org.apache.lucene.facet.search.Heap
-
Insert a new value, returning the overflowen object
NOTE: This method should not be called after invokingHeap.pop()
- insertWithOverflow(T) - Method in class org.apache.lucene.util.PriorityQueue
-
Adds an Object to a PriorityQueue in log(size) time.
- INSTANCE - Static variable in class org.apache.lucene.index.NoDeletionPolicy
-
The single instance of this class.
- INSTANCE - Static variable in class org.apache.lucene.index.NoMergeScheduler
-
The single instance of
NoMergeScheduler
- INSTANCE - Static variable in class org.apache.lucene.index.pruning.CarmelTopKTermPruningPolicy.ByDocComparator
- INSTANCE - Static variable in class org.apache.lucene.index.pruning.CarmelUniformTermPruningPolicy.ByDocComparator
- INSTANCE - Static variable in class org.apache.lucene.util.DummyConcurrentLock
-
a default instance, can be always used, as this
Lock
is stateless. - InstantiatedDocument - Class in org.apache.lucene.store.instantiated
-
A document in the instantiated index object graph, optionally coupled to the vector space view.
- InstantiatedDocument() - Constructor for class org.apache.lucene.store.instantiated.InstantiatedDocument
- InstantiatedDocument(Document) - Constructor for class org.apache.lucene.store.instantiated.InstantiatedDocument
- InstantiatedIndex - Class in org.apache.lucene.store.instantiated
-
Deprecated.contrib/instantiated will be removed in 4.0; you can use the memory codec to hold all postings in RAM
- InstantiatedIndex() - Constructor for class org.apache.lucene.store.instantiated.InstantiatedIndex
-
Deprecated.Creates an empty instantiated index for you to fill with data using an
InstantiatedIndexWriter
. - InstantiatedIndex(IndexReader) - Constructor for class org.apache.lucene.store.instantiated.InstantiatedIndex
-
Deprecated.Creates a new instantiated index that looks just like the index in a specific state as represented by a reader.
- InstantiatedIndex(IndexReader, Set<String>) - Constructor for class org.apache.lucene.store.instantiated.InstantiatedIndex
-
Deprecated.Creates a new instantiated index that looks just like the index in a specific state as represented by a reader.
- InstantiatedIndexReader - Class in org.apache.lucene.store.instantiated
-
Deprecated.contrib/instantiated will be removed in 4.0; you can use the memory codec to hold all postings in RAM
- InstantiatedIndexReader(InstantiatedIndex) - Constructor for class org.apache.lucene.store.instantiated.InstantiatedIndexReader
-
Deprecated.
- InstantiatedIndexWriter - Class in org.apache.lucene.store.instantiated
-
Deprecated.contrib/instantiated will be removed in 4.0; you can use the memory codec to hold all postings in RAM
- InstantiatedIndexWriter(InstantiatedIndex) - Constructor for class org.apache.lucene.store.instantiated.InstantiatedIndexWriter
-
Deprecated.
- InstantiatedIndexWriter(InstantiatedIndex, Analyzer) - Constructor for class org.apache.lucene.store.instantiated.InstantiatedIndexWriter
-
Deprecated.
- InstantiatedIndexWriter(InstantiatedIndex, Analyzer, boolean) - Constructor for class org.apache.lucene.store.instantiated.InstantiatedIndexWriter
-
Deprecated.
- InstantiatedTerm - Class in org.apache.lucene.store.instantiated
-
A term in the inverted index, coupled to the documents it occurs in.
- InstantiatedTermDocs - Class in org.apache.lucene.store.instantiated
-
A
TermDocs
navigating anInstantiatedIndexReader
. - InstantiatedTermDocs(InstantiatedIndexReader) - Constructor for class org.apache.lucene.store.instantiated.InstantiatedTermDocs
- InstantiatedTermDocumentInformation - Class in org.apache.lucene.store.instantiated
-
There is one instance of this class per indexed term in a document and it contains the meta data about each occurrence of a term in a document.
- InstantiatedTermDocumentInformation(InstantiatedTerm, InstantiatedDocument, int[], byte[][]) - Constructor for class org.apache.lucene.store.instantiated.InstantiatedTermDocumentInformation
- InstantiatedTermEnum - Class in org.apache.lucene.store.instantiated
-
A
TermEnum
navigating anInstantiatedIndexReader
. - InstantiatedTermEnum(InstantiatedIndexReader) - Constructor for class org.apache.lucene.store.instantiated.InstantiatedTermEnum
- InstantiatedTermEnum(InstantiatedIndexReader, int) - Constructor for class org.apache.lucene.store.instantiated.InstantiatedTermEnum
- InstantiatedTermFreqVector - Class in org.apache.lucene.store.instantiated
-
Vector space view of a document in an
InstantiatedIndexReader
. - InstantiatedTermFreqVector(InstantiatedDocument, String) - Constructor for class org.apache.lucene.store.instantiated.InstantiatedTermFreqVector
- InstantiatedTermPositions - Class in org.apache.lucene.store.instantiated
-
A
TermPositions
navigating anInstantiatedIndexReader
. - InstantiatedTermPositions(InstantiatedIndexReader) - Constructor for class org.apache.lucene.store.instantiated.InstantiatedTermPositions
- InstantiatedTermPositionVector - Class in org.apache.lucene.store.instantiated
-
Extended vector space view of a document in an
InstantiatedIndexReader
. - InstantiatedTermPositionVector(InstantiatedDocument, String) - Constructor for class org.apache.lucene.store.instantiated.InstantiatedTermPositionVector
- INT - org.apache.lucene.document.NumericField.DataType
- INT - Static variable in class org.apache.lucene.search.function.FieldScoreQuery.Type
-
field values are interpreted as numeric int values.
- INT - Static variable in class org.apache.lucene.search.SortField
-
Sort using term values as encoded Integers.
- IntArray - Class in org.apache.lucene.util.collections
-
A Class wrapper for a grow-able int[] which can be sorted and intersect with other IntArrays.
- IntArray() - Constructor for class org.apache.lucene.util.collections.IntArray
-
Construct a default IntArray, size 0 and surly a sort should not occur.
- intArrayAllocator - Variable in class org.apache.lucene.facet.search.StandardFacetsAccumulator
- IntArrayAllocator - Class in org.apache.lucene.facet.search
-
An IntArrayAllocator is an object which manages counter array objects of a certain length.
- IntArrayAllocator(int, int) - Constructor for class org.apache.lucene.facet.search.IntArrayAllocator
-
Construct an allocator for counter arrays of length
length
, keeping around a pool of up tomaxArrays
old arrays. - IntDecoder - Class in org.apache.lucene.util.encoding
-
Decodes integers from a set
InputStream
. - IntDecoder() - Constructor for class org.apache.lucene.util.encoding.IntDecoder
- IntegerEncoder - Class in org.apache.lucene.analysis.payloads
-
Encode a character array Integer as a
Payload
. - IntegerEncoder() - Constructor for class org.apache.lucene.analysis.payloads.IntegerEncoder
- IntEncoder - Class in org.apache.lucene.util.encoding
-
Encodes integers to a set
OutputStream
. - IntEncoder() - Constructor for class org.apache.lucene.util.encoding.IntEncoder
-
Default constructor, provided here for robustness: if in the future a constructor with parameters will be added, this might break custom implementations of this class which call this implicit constructor.
- IntEncoderFilter - Class in org.apache.lucene.util.encoding
-
An abstract implementation of
IntEncoder
which is served as a filter on the values to encode. - IntEncoderFilter(IntEncoder) - Constructor for class org.apache.lucene.util.encoding.IntEncoderFilter
- IntermediateFacetResult - Interface in org.apache.lucene.facet.search.results
-
Intermediate
FacetResult
of faceted search. - IntermediateFacetResultWithHash(FacetRequest, IntToObjectMap<TopKInEachNodeHandler.AACO>) - Constructor for class org.apache.lucene.facet.search.TopKInEachNodeHandler.IntermediateFacetResultWithHash
- intern(char[], int, int) - Method in class org.apache.lucene.util.StringInterner
-
Returns a single object instance for each equal string.
- intern(String) - Method in class org.apache.lucene.util.SimpleStringInterner
- intern(String) - Static method in class org.apache.lucene.util.StringHelper
-
Return the same string object for all equal strings
- intern(String) - Method in class org.apache.lucene.util.StringInterner
-
Returns a single object instance for each equal string.
- 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
- interner - Static variable in class org.apache.lucene.util.StringHelper
-
Expert: The StringInterner implementation used by Lucene.
- intersect(LineSegment, Point2D, Point2D) - Method in class org.apache.lucene.spatial.geometry.shape.Ellipse
-
Deprecated.Determines if a line segment intersects the ellipse and if so finds the point(s) of intersection.
- intersect(Rectangle) - Method in class org.apache.lucene.spatial.geometry.shape.Ellipse
-
Deprecated.
- intersect(Rectangle) - Method in interface org.apache.lucene.spatial.geometry.shape.Geometry2D
-
Deprecated.Returns information about how this shape intersects the given rectangle
- intersect(Rectangle) - Method in class org.apache.lucene.spatial.geometry.shape.Rectangle
-
Deprecated.
- intersect(IntArray) - Method in class org.apache.lucene.util.collections.IntArray
-
Intersects the data with a given IntArray
- intersect(IntHashSet) - Method in class org.apache.lucene.util.collections.IntArray
-
Intersects the data with a given
IntHashSet
. - intersect(OpenBitSet) - Method in class org.apache.lucene.util.OpenBitSet
-
this = this AND other
- IntersectCase - Enum in org.apache.lucene.spatial.geometry.shape
-
Deprecated.
- intersectionCount(OpenBitSet, OpenBitSet) - Static method in class org.apache.lucene.util.OpenBitSet
-
Returns the popcount or cardinality of the intersection of the two sets.
- intersects(OpenBitSet) - Method in class org.apache.lucene.util.OpenBitSet
-
returns true if the sets have any elements in common
- INTERSECTS - org.apache.lucene.spatial.geometry.shape.IntersectCase
-
Deprecated.
- IntFieldSource - Class in org.apache.lucene.search.function
-
Expert: obtains int field values from the
FieldCache
usinggetInts()
and makes those values available as other numeric types, casting as needed. - IntFieldSource(String) - Constructor for class org.apache.lucene.search.function.IntFieldSource
-
Create a cached int field source with default string-to-int parser.
- IntFieldSource(String, FieldCache.IntParser) - Constructor for class org.apache.lucene.search.function.IntFieldSource
-
Create a cached int field source with a specific string-to-int parser.
- IntHashSet - Class in org.apache.lucene.util.collections
-
A Set or primitive int.
- IntHashSet() - Constructor for class org.apache.lucene.util.collections.IntHashSet
-
Constructs a map with default capacity.
- IntHashSet(int) - Constructor for class org.apache.lucene.util.collections.IntHashSet
-
Constructs a map with given capacity.
- IntIterator - Interface in org.apache.lucene.util.collections
-
Iterator interface for primitive int iteration.
- IntRangeBuilder() - Constructor for class org.apache.lucene.util.NumericUtils.IntRangeBuilder
- ints - Variable in class org.apache.lucene.util.IntsRef
- 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
- IntsRef(int[], int, int) - Constructor for class org.apache.lucene.util.IntsRef
- 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.
- IntToDoubleMap - Class in org.apache.lucene.util.collections
-
An Array-based hashtable which maps primitive int to a primitive double.
The hashtable is constracted with a given capacity, or 16 as a default. - IntToDoubleMap() - Constructor for class org.apache.lucene.util.collections.IntToDoubleMap
-
Constructs a map with default capacity.
- IntToDoubleMap(int) - Constructor for class org.apache.lucene.util.collections.IntToDoubleMap
-
Constructs a map with given capacity.
- intToEnglish(int) - Static method in class org.apache.lucene.util.English
- intToEnglish(int, StringBuilder) - Static method in class org.apache.lucene.util.English
- IntToIntMap - Class in org.apache.lucene.util.collections
-
An Array-based hashtable which maps primitive int to primitive int.
The hashtable is constracted with a given capacity, or 16 as a default. - IntToIntMap() - Constructor for class org.apache.lucene.util.collections.IntToIntMap
-
Constructs a map with default capacity.
- IntToIntMap(int) - Constructor for class org.apache.lucene.util.collections.IntToIntMap
-
Constructs a map with given capacity.
- IntToObjectMap<T> - Class in org.apache.lucene.util.collections
-
An Array-based hashtable which maps primitive int to Objects of generic type T.
The hashtable is constracted with a given capacity, or 16 as a default. - IntToObjectMap() - Constructor for class org.apache.lucene.util.collections.IntToObjectMap
-
Constructs a map with default capacity.
- IntToObjectMap(int) - Constructor for class org.apache.lucene.util.collections.IntToObjectMap
-
Constructs a map with given capacity.
- intToPrefixCoded(int) - Static method in class org.apache.lucene.util.NumericUtils
- intToPrefixCoded(int, int) - Static method in class org.apache.lucene.util.NumericUtils
- intToPrefixCoded(int, int, char[]) - Static method in class org.apache.lucene.util.NumericUtils
-
Expert: Returns prefix coded bits after reducing the precision by
shift
bits. - intVal(int) - Method in class org.apache.lucene.search.function.DocValues
-
Return doc value as an int.
- INVALID_ORDINAL - Static variable in interface org.apache.lucene.facet.taxonomy.TaxonomyReader
-
Ordinals are always non-negative, so a negative ordinal can be used to signify an error.
- INVALID_SYNTAX - Static variable in class org.apache.lucene.queryParser.core.messages.QueryParserMessages
- INVALID_SYNTAX_CANNOT_PARSE - Static variable in class org.apache.lucene.queryParser.core.messages.QueryParserMessages
- INVALID_SYNTAX_ESCAPE_CHARACTER - Static variable in class org.apache.lucene.queryParser.core.messages.QueryParserMessages
- INVALID_SYNTAX_ESCAPE_NONE_HEX_UNICODE - Static variable in class org.apache.lucene.queryParser.core.messages.QueryParserMessages
- INVALID_SYNTAX_ESCAPE_UNICODE_TRUNCATION - Static variable in class org.apache.lucene.queryParser.core.messages.QueryParserMessages
- INVALID_SYNTAX_FUZZY_LIMITS - Static variable in class org.apache.lucene.queryParser.core.messages.QueryParserMessages
- InvalidGeoException - Exception in org.apache.lucene.spatial.tier
-
Deprecated.
- InvalidGeoException(String) - Constructor for exception org.apache.lucene.spatial.tier.InvalidGeoException
-
Deprecated.
- InvalidOrdinal - Static variable in class org.apache.lucene.facet.taxonomy.writercache.cl2o.LabelToOrdinal
- 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
- IOUtils - Class in org.apache.lucene.util
-
This class emulates the new Java 7 "Try-With-Resources" statement.
- IProjector - Interface in org.apache.lucene.spatial.tier.projections
-
Deprecated.
- IrishAnalyzer - Class in org.apache.lucene.analysis.ga
-
Analyzer
for Irish. - IrishAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.ga.IrishAnalyzer
-
Builds an analyzer with the default stop words:
IrishAnalyzer.DEFAULT_STOPWORD_FILE
. - IrishAnalyzer(Version, CharArraySet) - Constructor for class org.apache.lucene.analysis.ga.IrishAnalyzer
-
Builds an analyzer with the given stop words.
- IrishAnalyzer(Version, 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.
- 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
- isAllowLabeling() - Method in class org.apache.lucene.facet.search.FacetsAccumulator
-
Check if labeling is allowed for this accumulator.
- isAllowLabeling() - Method in class org.apache.lucene.facet.search.SamplingWrapper
- isAllowLeadingWildcard() - Method in interface org.apache.lucene.queryParser.standard.config.AllowLeadingWildcardAttribute
-
Deprecated.
- isAllowLeadingWildcard() - Method in class org.apache.lucene.queryParser.standard.config.AllowLeadingWildcardAttributeImpl
-
Deprecated.
- isAnalyzed() - Method in enum org.apache.lucene.document.Field.Index
- isAssociationProperty(Class<? extends CategoryProperty>) - Static method in class org.apache.lucene.facet.enhancements.association.AssociationEnhancement
-
For a given class which extends a CategoryProperty, answers whether it is an instance of AssociationProperty (AP) or not.
- isBinary - Variable in class org.apache.lucene.document.AbstractField
- isBinary() - Method in class org.apache.lucene.document.AbstractField
-
True iff the value of the filed is stored as binary
- isBinary() - Method in interface org.apache.lucene.document.Fieldable
-
True if the value of the field is stored as binary
- isBoost() - Method in class org.apache.lucene.search.similar.MoreLikeThis
-
Returns whether to boost terms in query based on "score" or not.
- isCacheable() - Method in class org.apache.lucene.search.DocIdSet
-
This method is a hint for
CachingWrapperFilter
, if thisDocIdSet
should be cached without copying it into a BitSet. - isCacheable() - Method in class org.apache.lucene.search.FieldCacheDocIdSet
-
this DocIdSet is cacheable, if it works solely with FieldCache and no TermDocs
- isCacheable() - Method in class org.apache.lucene.search.FilteredDocIdSet
-
This DocIdSet implementation is cacheable if the inner set is cacheable.
- isCacheable() - Method in class org.apache.lucene.util.DocIdBitSet
-
This DocIdSet implementation is cacheable.
- isCacheable() - Method in class org.apache.lucene.util.FixedBitSet
-
This DocIdSet implementation is cacheable.
- isCacheable() - Method in class org.apache.lucene.util.OpenBitSet
-
This DocIdSet implementation is cacheable.
- isCacheable() - Method in class org.apache.lucene.util.SortedVIntList
-
This DocIdSet implementation is cacheable.
- isCached() - Method in class org.apache.lucene.search.CachingCollector
- isCachedTokenStream() - Method in class org.apache.lucene.search.highlight.WeightedSpanTermExtractor
- isCFSFile(String) - Method in class org.apache.lucene.index.IndexFileNameFilter
-
Returns true if this is a file that would be contained in a CFS file.
- 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
- isCoordDisabled() - Method in class org.apache.lucene.search.BooleanQuery
-
Returns true iff
Similarity.coord(int,int)
is disabled in scoring for this query instance. - isCrossProduct() - Method in class org.apache.lucene.analysis.hunspell.HunspellAffix
-
Returns whether the affix is defined as cross product
- isCurrent() - Method in class org.apache.lucene.index.FilterIndexReader
- isCurrent() - Method in class org.apache.lucene.index.IndexReader
-
Check whether any new changes have occurred to the index since this reader was opened.
- isCurrent() - Method in class org.apache.lucene.index.MultiReader
-
Checks recursively if all subreaders are up to date.
- isCurrent() - Method in class org.apache.lucene.index.ParallelReader
-
Checks recursively if all subreaders are up to date.
- isCurrent() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexReader
-
Deprecated.An InstantiatedIndexReader is always current! Check whether this IndexReader is still using the current (i.e., most recently committed) version of the index.
- isDefaultBooleanQueryNode(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.BooleanQuery2ModifierNodeProcessor
- isDefaultField(CharSequence) - Method in class org.apache.lucene.queryParser.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
- isDeleted() - Method in class org.apache.lucene.index.SnapshotDeletionPolicy.SnapshotCommitPoint
- isDeleted(int) - Method in class org.apache.lucene.index.AbstractAllTermDocs
- isDeleted(int) - Method in class org.apache.lucene.index.FilterIndexReader
- isDeleted(int) - Method in class org.apache.lucene.index.IndexReader
-
Returns true if document n has been deleted
- isDeleted(int) - Method in class org.apache.lucene.index.MultiReader
- isDeleted(int) - Method in class org.apache.lucene.index.ParallelReader
- isDeleted(int) - Method in class org.apache.lucene.index.SegmentReader
- isDeleted(int) - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexReader
-
Deprecated.
- isDescendantOf(CategoryPath) - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
-
Test whether this object is a descendant of another CategoryPath.
- isDisableCoord() - Method in class org.apache.lucene.queryParser.standard.nodes.StandardBooleanQueryNode
- isDisableCounting() - Method in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
-
Return true if counting is disabled for this task.
- isDocStoreFile(String) - Static method in class org.apache.lucene.index.IndexFileNames
-
Returns true if the provided filename is one of the doc store files (ends with an extension in
IndexFileNames.STORE_INDEX_EXTENSIONS
). - isEmpty() - Method in class org.apache.lucene.queryParser.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.util.collections.ArrayHashMap
-
Returns true iff the map is empty.
- isEmpty() - Method in class org.apache.lucene.util.collections.FloatToObjectMap
- isEmpty() - Method in class org.apache.lucene.util.collections.IntHashSet
- isEmpty() - Method in class org.apache.lucene.util.collections.IntToDoubleMap
- isEmpty() - Method in class org.apache.lucene.util.collections.IntToIntMap
- isEmpty() - Method in class org.apache.lucene.util.collections.IntToObjectMap
- isEmpty() - Method in class org.apache.lucene.util.collections.ObjectToFloatMap
- isEmpty() - Method in class org.apache.lucene.util.collections.ObjectToIntMap
- isEmpty() - Method in class org.apache.lucene.util.OpenBitSet
-
Returns true if there are no set bits
- isEmpty() - Method in class org.apache.lucene.util.WeakIdentityMap
- isExpandMultiTermQuery() - Method in class org.apache.lucene.search.highlight.QueryScorer
- 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
- isFirst() - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.Matrix.Column
-
Deprecated.
- isFixedPoint() - Method in class org.apache.lucene.spatial.geometry.FixedLatLng
-
Deprecated.
- isFixedPoint() - Method in class org.apache.lucene.spatial.geometry.FloatLatLng
-
Deprecated.
- isFixedPoint() - Method in class org.apache.lucene.spatial.geometry.LatLng
-
Deprecated.
- isGreedy() - Method in class org.apache.lucene.search.TimeLimitingCollector
-
Checks if this time limited collector is greedy in collecting the last hit.
- isGroup(char) - Method in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
- isIgnoreCase() - Method in class org.apache.lucene.analysis.hunspell.HunspellDictionary
- isIgnoreTF() - Method in class org.apache.lucene.search.FuzzyLikeThisQuery
- isIgnoringOffsets() - Method in class org.apache.lucene.index.TermVectorMapper
- isIgnoringPositions() - Method in class org.apache.lucene.index.PositionBasedTermVectorMapper
-
Never ignores positions.
- isIgnoringPositions() - Method in class org.apache.lucene.index.TermVectorMapper
-
Indicate to Lucene that even if there are positions stored, this mapper is not interested in them and they can be skipped over.
- isIgnoringSinglePrefixOrSuffixShingle() - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter
-
Deprecated.
- isIndexed - Variable in class org.apache.lucene.document.AbstractField
- isIndexed - Variable in class org.apache.lucene.index.FieldInfo
- isIndexed() - Method in class org.apache.lucene.document.AbstractField
-
True iff the value of the field is to be indexed, so that it may be searched on.
- isIndexed() - Method in enum org.apache.lucene.document.Field.Index
- isIndexed() - Method in interface org.apache.lucene.document.Fieldable
-
True if the value of the field is to be indexed, so that it may be searched on.
- isInOrder() - Method in class org.apache.lucene.queryParser.core.nodes.ProximityQueryNode
- isInOrder() - Method in class org.apache.lucene.search.spans.SpanNearQuery
-
Return true if matches are required to be in-order.
- isInside(double) - Method in class org.apache.lucene.spatial.tier.Shape
-
Deprecated.
- isInvoke(char) - Method in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
- isKanji(char) - Method in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
- isKeyword() - Method in interface org.apache.lucene.analysis.tokenattributes.KeywordAttribute
-
Returns
true
iff the current token is a keyword, otherwisefalse
/ - isKeyword() - Method in class org.apache.lucene.analysis.tokenattributes.KeywordAttributeImpl
-
Returns
true
iff the current token is a keyword, otherwisefalse
/ - isKnown() - Method in class org.apache.lucene.analysis.ja.Token
-
Returns true if this token is known word
- isLast() - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.Matrix.Column
-
Deprecated.
- isLast() - Method in class org.apache.lucene.util.fst.FST.Arc
- isLazy() - Method in class org.apache.lucene.document.AbstractField
- isLazy() - Method in interface org.apache.lucene.document.Fieldable
-
Indicates whether a Field is Lazy or not.
- isLeaf() - Method in interface org.apache.lucene.queryParser.core.nodes.QueryNode
-
verify if a node is a Leaf node
- isLeaf() - Method in class org.apache.lucene.queryParser.core.nodes.QueryNodeImpl
- isLocked() - Method in class org.apache.lucene.store.Lock
-
Returns true if the resource is currently locked.
- isLocked(Directory) - Static method in class org.apache.lucene.index.IndexWriter
-
Returns
true
iff the index in the named directory is currently locked. - isLowercaseExpandedTerms() - Method in interface org.apache.lucene.queryParser.standard.config.LowercaseExpandedTermsAttribute
-
Deprecated.
- isLowercaseExpandedTerms() - Method in class org.apache.lucene.queryParser.standard.config.LowercaseExpandedTermsAttributeImpl
-
Deprecated.
- isLowerInclusive() - Method in class org.apache.lucene.queryParser.core.nodes.ParametricRangeQueryNode
- isLowerInclusive() - Method in interface org.apache.lucene.queryParser.core.nodes.RangeQueryNode
- isLowerInclusive() - Method in class org.apache.lucene.queryParser.standard.nodes.AbstractRangeQueryNode
-
Returns whether the lower bound is inclusive or exclusive.
- isMatch() - Method in class org.apache.lucene.search.ComplexExplanation
-
Indicates whether or not this Explanation models a good match.
- isMatch() - Method in class org.apache.lucene.search.Explanation
-
Indicates whether or not this Explanation models a good match.
- isMerged(SegmentInfo) - Method in class org.apache.lucene.index.LogMergePolicy
-
Returns true if this single info is already fully merged (has no pending norms or deletes, is in the same dir as the writer, and matches the current compound file setting
- isMerged(SegmentInfos, int, Map<SegmentInfo, Boolean>) - Method in class org.apache.lucene.index.LogMergePolicy
- 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
- isNormalized() - Method in class org.apache.lucene.spatial.geometry.FixedLatLng
-
Deprecated.
- isNormalized() - Method in class org.apache.lucene.spatial.geometry.FloatLatLng
-
Deprecated.
- isNormalized() - Method in class org.apache.lucene.spatial.geometry.LatLng
-
Deprecated.
- isOffsetOverlap(FieldPhraseList.WeightedPhraseInfo) - Method in class org.apache.lucene.search.vectorhighlight.FieldPhraseList.WeightedPhraseInfo
- ISOLatin1AccentFilter - Class in org.apache.lucene.analysis
-
Deprecated.If you build a new index, use
ASCIIFoldingFilter
which covers a superset of Latin 1. This class is included for use with existing indexes and will be removed in a future release (possibly Lucene 4.0). - ISOLatin1AccentFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.ISOLatin1AccentFilter
-
Deprecated.
- isOpen - Variable in class org.apache.lucene.store.Directory
- isOpen - Variable in class org.apache.lucene.store.SimpleFSDirectory.SimpleFSIndexInput.Descriptor
- isOpen() - Method in class org.apache.lucene.store.MockDirectoryWrapper
- isOperatorInfix() - Method in class org.apache.lucene.queryParser.surround.query.ComposedQuery
- isOptimized() - Method in class org.apache.lucene.index.FilterIndexReader
-
Deprecated.
- isOptimized() - Method in class org.apache.lucene.index.IndexReader
-
Deprecated.Check segment count using
IndexReader.getSequentialSubReaders()
instead. - isOptimized() - Method in class org.apache.lucene.index.MultiReader
-
Deprecated.
- isOptimized() - Method in class org.apache.lucene.index.ParallelReader
-
Deprecated.
- isOptimized() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexReader
-
Deprecated.
- 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 subclasssubclazz
. - isParallel() - Method in class org.apache.lucene.benchmark.byTask.tasks.TaskSequence
- isPayloadAvailable() - Method in class org.apache.lucene.index.FilterIndexReader.FilterTermPositions
- isPayloadAvailable() - Method in class org.apache.lucene.index.MultipleTermPositions
- isPayloadAvailable() - Method in interface org.apache.lucene.index.TermPositions
-
Checks if a payload can be loaded at this position.
- isPayloadAvailable() - Method in class org.apache.lucene.search.spans.NearSpansOrdered
- isPayloadAvailable() - Method in class org.apache.lucene.search.spans.NearSpansUnordered
- isPayloadAvailable() - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery.PositionCheckSpan
- isPayloadAvailable() - Method in class org.apache.lucene.search.spans.Spans
-
Checks if a payload can be loaded at this position.
- isPayloadAvailable() - Method in class org.apache.lucene.search.spans.TermSpans
- isPayloadAvailable() - Method in class org.apache.lucene.store.instantiated.InstantiatedTermPositions
- isPhraseHighlight() - Method in class org.apache.lucene.search.vectorhighlight.FastVectorHighlighter
-
return whether phraseHighlight or not.
- isPositionIncrementsEnabled() - Method in interface org.apache.lucene.queryParser.standard.config.PositionIncrementsAttribute
-
Deprecated.
- isPositionIncrementsEnabled() - Method in class org.apache.lucene.queryParser.standard.config.PositionIncrementsAttributeImpl
-
Deprecated.
- isPositionSensitive() - Method in class org.apache.lucene.search.highlight.WeightedSpanTerm
- isPowerOfTwo(int) - Static method in class org.apache.lucene.util.BitUtil
-
returns true if v is a power of two or zero
- isPowerOfTwo(long) - Static method in class org.apache.lucene.util.BitUtil
-
returns true if v is a power of two or zero
- isProhibited() - Method in class org.apache.lucene.search.BooleanClause
- 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
- isReplaceInvalidAcronym() - Method in class org.apache.lucene.analysis.standard.ClassicTokenizer
-
Deprecated.Remove in 3.X and make true the only valid value
- isReplaceInvalidAcronym() - Method in class org.apache.lucene.analysis.standard.StandardTokenizer
-
Deprecated.Remove in 3.X and make true the only valid value
- isRequired() - Method in class org.apache.lucene.search.BooleanClause
- isRoot() - Method in class org.apache.lucene.queryParser.core.nodes.QueryNodeImpl
- isSearcherCurrent() - Method in class org.apache.lucene.search.NRTManager
-
Returns
true
if no changes have occured since this searcher ie. - isSearcherCurrent() - Method in class org.apache.lucene.search.SearcherManager
-
Returns
true
if no changes have occured since this searcher ie. - isSelected(File, String, File) - Method in class org.apache.lucene.util.LuceneJUnitDividingSelector
- isSelected(Resource) - Method in class org.apache.lucene.util.LuceneJUnitDividingSelector
- isSelfPartition(int, FacetArrays, int) - Method in class org.apache.lucene.facet.search.FacetResultsHandler
-
Check if an array contains the partition which contains ordinal
- isSeparateNormsFile(String) - Static method in class org.apache.lucene.index.IndexFileNames
-
Returns true if the given filename ends with the separate norms file pattern:
SEPARATE_NORMS_EXTENSION + "[0-9]+"
. - isSimpleFSIndexInput(IndexInput) - Static method in class org.apache.lucene.store._TestHelper
-
Returns true if the instance of the provided input stream is actually an SimpleFSIndexInput.
- isSimpleFSIndexInputClone(IndexInput) - Static method in class org.apache.lucene.store._TestHelper
-
Returns true if the provided input stream is an SimpleFSIndexInput and is a clone, that is it does not own its underlying file descriptor.
- isSimpleFSIndexInputOpen(IndexInput) - Static method in class org.apache.lucene.store._TestHelper
-
Given an instance of SimpleFSDirectory.SimpleFSIndexInput, this method returns true if the underlying file descriptor is valid, and false otherwise.
- isSnapshotted(String) - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
-
Returns true if the given ID is already used by a snapshot.
- isStored - Variable in class org.apache.lucene.document.AbstractField
- isStored() - Method in class org.apache.lucene.document.AbstractField
-
True iff the value of the field is to be stored in the index for return with search hits.
- isStored() - Method in enum org.apache.lucene.document.Field.Store
- isStored() - Method in enum org.apache.lucene.document.Field.TermVector
- isStored() - Method in interface org.apache.lucene.document.Fieldable
-
True if the value of the field is to be stored in the index for return with search hits.
- isStoreOffsetWithTermVector() - Method in class org.apache.lucene.document.AbstractField
-
True iff terms are stored as term vector together with their offsets (start and end position in source text).
- isStoreOffsetWithTermVector() - Method in interface org.apache.lucene.document.Fieldable
-
True if terms are stored as term vector together with their offsets (start and end positon in source text).
- isStorePositionWithTermVector() - Method in class org.apache.lucene.document.AbstractField
-
True iff terms are stored as term vector together with their token positions.
- isStorePositionWithTermVector() - Method in interface org.apache.lucene.document.Fieldable
-
True if terms are stored as term vector together with their token positions.
- isStrict() - Method in class org.apache.lucene.search.function.CustomScoreQuery
-
Checks if this is strict custom scoring.
- isSupportedJVM() - Static method in class org.apache.lucene.util.RamUsageEstimator
-
Returns true, if the current JVM is fully supported by
RamUsageEstimator
. - isTerminal() - Method in class org.apache.lucene.search.vectorhighlight.FieldQuery.QueryPhraseMap
- isTermVectorStored() - Method in class org.apache.lucene.document.AbstractField
-
True iff the term or terms used to index this field are stored as a term vector, available from
IndexReader.getTermFreqVector(int,String)
. - isTermVectorStored() - Method in interface org.apache.lucene.document.Fieldable
-
True if the term or terms used to index this field are stored as a term vector, available from
IndexReader.getTermFreqVector(int,String)
. - 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.
- isTokenChar(char) - Method in class org.apache.lucene.analysis.CharTokenizer
-
Deprecated.use
CharTokenizer.isTokenChar(int)
instead. This method will be removed in Lucene 4.0. - isTokenChar(int) - Method in class org.apache.lucene.analysis.ar.ArabicLetterTokenizer
-
Deprecated.Allows for Letter category or NonspacingMark category
- isTokenChar(int) - Method in class org.apache.lucene.analysis.CharTokenizer
-
Returns true iff a codepoint should be included in a token.
- isTokenChar(int) - Method in class org.apache.lucene.analysis.in.IndicTokenizer
-
Deprecated.
- isTokenChar(int) - Method in class org.apache.lucene.analysis.LetterTokenizer
-
Collects only characters which satisfy
Character.isLetter(int)
. - isTokenChar(int) - Method in class org.apache.lucene.analysis.MockTokenizer
- isTokenChar(int) - Method in class org.apache.lucene.analysis.ru.RussianLetterTokenizer
-
Deprecated.Collects only characters which satisfy
Character.isLetter(int)
. - isTokenChar(int) - Method in class org.apache.lucene.analysis.WhitespaceTokenizer
-
Collects only characters which do not satisfy
Character.isWhitespace(int)
. - isTokenized - Variable in class org.apache.lucene.document.AbstractField
- isTokenized() - Method in class org.apache.lucene.document.AbstractField
-
True iff the value of the field should be tokenized as text prior to indexing.
- isTokenized() - Method in interface org.apache.lucene.document.Fieldable
-
True if the value of the field should be tokenized as text prior to indexing.
- isUnknown() - Method in class org.apache.lucene.analysis.ja.Token
-
Returns true if this token is unknown word
- isUpperInclusive() - Method in class org.apache.lucene.queryParser.core.nodes.ParametricRangeQueryNode
- isUpperInclusive() - Method in interface org.apache.lucene.queryParser.core.nodes.RangeQueryNode
- isUpperInclusive() - Method in class org.apache.lucene.queryParser.standard.nodes.AbstractRangeQueryNode
-
Returns whether the upper bound is inclusive or exclusive.
- isUseCompoundFile() - Method in class org.apache.lucene.index.BalancedSegmentMergePolicy.MergePolicyParams
-
Deprecated.
- isUser() - Method in class org.apache.lucene.analysis.ja.Token
-
Returns true if this token is defined in user dictionary
- isUsingComplements - Variable in class org.apache.lucene.facet.search.StandardFacetsAccumulator
- 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
- ItalianAnalyzer - Class in org.apache.lucene.analysis.it
-
Analyzer
for Italian. - ItalianAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.it.ItalianAnalyzer
-
Builds an analyzer with the default stop words:
ItalianAnalyzer.DEFAULT_STOPWORD_FILE
. - ItalianAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.it.ItalianAnalyzer
-
Builds an analyzer with the given stop words.
- ItalianAnalyzer(Version, Set<?>, Set<?>) - 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
-
A
TokenFilter
that appliesItalianLightStemmer
to stem Italian words. - ItalianLightStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.it.ItalianLightStemFilter
- 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
-
Generated class implementing code 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
depending on the version used: ifmatchVersion
≥ 3.1, it returnschar[]
instances in this set. ifmatchVersion
is 3.0 or older, it returns new allocated Strings, so this method violates the Set interface. - iterator() - Method in class org.apache.lucene.facet.index.attributes.CategoryAttributesIterable
- iterator() - Method in class org.apache.lucene.facet.index.CategoryContainer
- iterator() - Method in interface org.apache.lucene.facet.search.ScoredDocIDs
-
Returns an iterator over the document IDs and their scores.
- iterator() - Method in class org.apache.lucene.index.FieldInfos
- 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.queryParser.core.processors.QueryNodeProcessorPipeline
- iterator() - Method in class org.apache.lucene.search.BooleanFilter
-
Returns an iterator on the clauses in this query.
- 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.DisjunctionMaxQuery
-
An Iterator
over the disjuncts - iterator() - Method in class org.apache.lucene.search.DocIdSet
-
Provides a
DocIdSetIterator
to access the set. - iterator() - Method in class org.apache.lucene.search.FieldCacheDocIdSet
- iterator() - Method in class org.apache.lucene.search.FilteredDocIdSet
-
Implementation of the contract to build a DocIdSetIterator.
- iterator() - Method in class org.apache.lucene.search.suggest.BytesRefList
-
sugar for
BytesRefList.iterator(Comparator)
with anull
comparator - iterator() - Method in interface org.apache.lucene.search.suggest.fst.BytesRefSorter
-
Sorts the entries added in
BytesRefSorter.add(BytesRef)
and returns an iterator over all sorted entries. - iterator() - Method in class org.apache.lucene.search.suggest.fst.ExternalRefSorter
- iterator() - Method in class org.apache.lucene.search.suggest.fst.InMemorySorter
- iterator() - Method in class org.apache.lucene.util.collections.ArrayHashMap
-
Returns an iterator on the mapped objects.
- iterator() - Method in class org.apache.lucene.util.collections.FloatToObjectMap
-
Returns a new iterator for the mapped objects.
- iterator() - Method in class org.apache.lucene.util.collections.IntHashSet
-
Returns a new iterator for the mapped objects.
- iterator() - Method in class org.apache.lucene.util.collections.IntToDoubleMap
-
Returns a new iterator for the mapped double values.
- iterator() - Method in class org.apache.lucene.util.collections.IntToIntMap
-
Returns a new iterator for the mapped objects.
- iterator() - Method in class org.apache.lucene.util.collections.IntToObjectMap
-
Returns a new iterator for the mapped objects.
- iterator() - Method in class org.apache.lucene.util.collections.ObjectToFloatMap
-
Returns a new iterator for the mapped floats.
- iterator() - Method in class org.apache.lucene.util.collections.ObjectToIntMap
-
Returns a new iterator for the mapped objects.
- iterator() - Method in class org.apache.lucene.util.DocIdBitSet
- iterator() - Method in class org.apache.lucene.util.FixedBitSet
- iterator() - Method in class org.apache.lucene.util.MapBackedSet
- iterator() - Method in class org.apache.lucene.util.OpenBitSet
- iterator() - Method in class org.apache.lucene.util.SortedVIntList
- iterator(int) - Method in class org.apache.lucene.facet.search.cache.CategoryListData
-
Iterate on the category list data for the specified partition.
- iterator(Comparator<BytesRef>) - Method in class org.apache.lucene.search.suggest.BytesRefList
-
Returns a
BytesRefIterator
with point in time semantics. - Iterator() - Constructor for class org.apache.lucene.analysis.compound.hyphenation.TernaryTree.Iterator
- Iterator(File) - Constructor for class org.apache.lucene.benchmark.byTask.feeds.DirContentSource.Iterator
J
- JakartaRegexpCapabilities - Class in org.apache.lucene.search.regex
-
Implementation tying Jakarta Regexp to RegexQuery.
- JakartaRegexpCapabilities() - Constructor for class org.apache.lucene.search.regex.JakartaRegexpCapabilities
-
Constructs a RegexCapabilities with the default MATCH_NORMAL match style.
- JakartaRegexpCapabilities(int) - Constructor for class org.apache.lucene.search.regex.JakartaRegexpCapabilities
-
Constructs a RegexCapabilities with the provided match flags.
- JapaneseAnalyzer - Class in org.apache.lucene.analysis.ja
-
Analyzer for Japanese that uses morphological analysis.
- JapaneseAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.ja.JapaneseAnalyzer
- JapaneseAnalyzer(Version, UserDictionary, JapaneseTokenizer.Mode, CharArraySet, Set<String>) - Constructor for class org.apache.lucene.analysis.ja.JapaneseAnalyzer
- JapaneseBaseFormFilter - Class in org.apache.lucene.analysis.ja
-
Replaces term text with the
BaseFormAttribute
. - JapaneseBaseFormFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.ja.JapaneseBaseFormFilter
- JapaneseKatakanaStemFilter - Class in org.apache.lucene.analysis.ja
-
A
TokenFilter
that normalizes common katakana spelling variations ending in a long sound character by removing this character (U+30FC). - JapaneseKatakanaStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.ja.JapaneseKatakanaStemFilter
- JapaneseKatakanaStemFilter(TokenStream, int) - Constructor for class org.apache.lucene.analysis.ja.JapaneseKatakanaStemFilter
- JapanesePartOfSpeechStopFilter - Class in org.apache.lucene.analysis.ja
-
Removes tokens that match a set of part-of-speech tags.
- JapanesePartOfSpeechStopFilter(boolean, TokenStream, Set<String>) - Constructor for class org.apache.lucene.analysis.ja.JapanesePartOfSpeechStopFilter
- JapaneseReadingFormFilter - Class in org.apache.lucene.analysis.ja
-
A
TokenFilter
that replaces the term attribute with the reading of a token in either katakana or romaji form. - JapaneseReadingFormFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.ja.JapaneseReadingFormFilter
- JapaneseReadingFormFilter(TokenStream, boolean) - Constructor for class org.apache.lucene.analysis.ja.JapaneseReadingFormFilter
- JapaneseTokenizer - Class in org.apache.lucene.analysis.ja
-
Tokenizer for Japanese that uses morphological analysis.
- JapaneseTokenizer(Reader, UserDictionary, boolean, JapaneseTokenizer.Mode) - Constructor for class org.apache.lucene.analysis.ja.JapaneseTokenizer
-
Create a new JapaneseTokenizer.
- JapaneseTokenizer.Mode - Enum in org.apache.lucene.analysis.ja
-
Tokenization mode: this determines how the tokenizer handles compound and unknown words.
- JaroWinklerDistance - Class in org.apache.lucene.search.spell
-
Similarity measure for short strings such as person names.
- JaroWinklerDistance() - Constructor for class org.apache.lucene.search.spell.JaroWinklerDistance
- JaspellLookup - Class in org.apache.lucene.search.suggest.jaspell
- JaspellLookup() - Constructor for class org.apache.lucene.search.suggest.jaspell.JaspellLookup
- JaspellTernarySearchTrie - Class in org.apache.lucene.search.suggest.jaspell
-
Implementation of a Ternary Search Trie, a data structure for storing
String
objects that combines the compact size of a binary search tree with the speed of a digital search trie, and is therefore ideal for practical use in sorting and searching data. - JaspellTernarySearchTrie() - Constructor for class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Constructs an empty Ternary Search Trie.
- JaspellTernarySearchTrie(File) - Constructor for class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Constructs a Ternary Search Trie and loads data from a
File
into the Trie. - JaspellTernarySearchTrie(File, boolean) - Constructor for class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Constructs a Ternary Search Trie and loads data from a
File
into the Trie. - JaspellTernarySearchTrie.TSTNode - Class in org.apache.lucene.search.suggest.jaspell
-
An inner class of Ternary Search Trie that represents a node in the trie.
- JAVA_1_1 - Static variable in class org.apache.lucene.util.Constants
-
Deprecated.This constant is useless since Lucene is on Java 5
- JAVA_1_2 - Static variable in class org.apache.lucene.util.Constants
-
Deprecated.This constant is useless since Lucene is on Java 5
- JAVA_1_3 - Static variable in class org.apache.lucene.util.Constants
-
Deprecated.This constant is useless since Lucene is on Java 5
- JAVA_VENDOR - Static variable in class org.apache.lucene.util.Constants
- JAVA_VERSION - Static variable in class org.apache.lucene.util.Constants
-
The value of System.getProperty("java.version").
- JavaCharStream - Class in org.apache.lucene.queryParser.standard.parser
-
An implementation of interface CharStream, where the stream is assumed to contain only ASCII characters (with java-like unicode escape processing).
- JavaCharStream(InputStream) - Constructor for class org.apache.lucene.queryParser.standard.parser.JavaCharStream
-
Constructor.
- JavaCharStream(InputStream, int, int) - Constructor for class org.apache.lucene.queryParser.standard.parser.JavaCharStream
-
Constructor.
- JavaCharStream(InputStream, int, int, int) - Constructor for class org.apache.lucene.queryParser.standard.parser.JavaCharStream
-
Constructor.
- JavaCharStream(InputStream, String) - Constructor for class org.apache.lucene.queryParser.standard.parser.JavaCharStream
-
Constructor.
- JavaCharStream(InputStream, String, int, int) - Constructor for class org.apache.lucene.queryParser.standard.parser.JavaCharStream
-
Constructor.
- JavaCharStream(InputStream, String, int, int, int) - Constructor for class org.apache.lucene.queryParser.standard.parser.JavaCharStream
-
Constructor.
- JavaCharStream(Reader) - Constructor for class org.apache.lucene.queryParser.standard.parser.JavaCharStream
-
Constructor.
- JavaCharStream(Reader, int, int) - Constructor for class org.apache.lucene.queryParser.standard.parser.JavaCharStream
-
Constructor.
- JavaCharStream(Reader, int, int, int) - Constructor for class org.apache.lucene.queryParser.standard.parser.JavaCharStream
-
Constructor.
- JavaUtilRegexCapabilities - Class in org.apache.lucene.search.regex
-
An implementation tying Java's built-in java.util.regex to RegexQuery.
- JavaUtilRegexCapabilities() - Constructor for class org.apache.lucene.search.regex.JavaUtilRegexCapabilities
-
Default constructor that uses java.util.regex.Pattern with its default flags.
- JavaUtilRegexCapabilities(int) - Constructor for class org.apache.lucene.search.regex.JavaUtilRegexCapabilities
-
Constructor that allows for the modification of the flags that the java.util.regex.Pattern will use to compile the regular expression.
- JDK - org.apache.lucene.benchmark.byTask.tasks.NewCollationAnalyzerTask.Implementation
- jj_nt - Variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParser
-
Next token.
- jj_nt - Variable in class org.apache.lucene.queryParser.QueryParser
-
Next token.
- jj_nt - Variable in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParser
-
Next token.
- jj_nt - Variable in class org.apache.lucene.queryParser.surround.parser.QueryParser
-
Next token.
- jjFillToken() - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserTokenManager
- jjFillToken() - Method in class org.apache.lucene.queryParser.QueryParserTokenManager
- jjFillToken() - Method in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserTokenManager
- jjFillToken() - Method in class org.apache.lucene.queryParser.surround.parser.QueryParserTokenManager
- jjnewLexState - Static variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserTokenManager
-
Lex State array.
- jjnewLexState - Static variable in class org.apache.lucene.queryParser.QueryParserTokenManager
-
Lex State array.
- jjnewLexState - Static variable in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserTokenManager
-
Lex State array.
- jjnewLexState - Static variable in class org.apache.lucene.queryParser.surround.parser.QueryParserTokenManager
-
Lex State array.
- jjstrLiteralImages - Static variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserTokenManager
-
Token literal values.
- jjstrLiteralImages - Static variable in class org.apache.lucene.queryParser.QueryParserTokenManager
-
Token literal values.
- jjstrLiteralImages - Static variable in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserTokenManager
-
Token literal values.
- jjstrLiteralImages - Static variable in class org.apache.lucene.queryParser.surround.parser.QueryParserTokenManager
-
Token literal values.
- join(String[], CharsRef) - Static method in class org.apache.lucene.analysis.synonym.SynonymMap.Builder
-
Sugar: just joins the provided terms with
SynonymMap.WORD_SEPARATOR
. - JoinUtil - Class in org.apache.lucene.search.join
-
Utility for query time joining using
TermsQuery
andTermsCollector
. - JRE_IS_64BIT - Static variable in class org.apache.lucene.util.Constants
-
True iff running on a 64bit JVM
- JRE_IS_MINIMUM_JAVA6 - Static variable in class org.apache.lucene.util.Constants
- JRE_IS_MINIMUM_JAVA7 - Static variable in class org.apache.lucene.util.Constants
- jreBugWorkaround(char) - Method in class org.apache.lucene.analysis.util.CharArrayIterator
- Judge - Interface in org.apache.lucene.benchmark.quality
-
Judge if a document is relevant for a quality query.
- JVM_INFO_STRING - Static variable in class org.apache.lucene.util.RamUsageEstimator
-
JVM info string for debugging and reports.
- JVM_NAME - Static variable in class org.apache.lucene.util.Constants
- JVM_VENDOR - Static variable in class org.apache.lucene.util.Constants
-
JVM vendor info.
- JVM_VERSION - Static variable in class org.apache.lucene.util.Constants
K
- KAF - Static variable in class org.apache.lucene.analysis.ar.ArabicStemmer
- KAF - Static variable in class org.apache.lucene.analysis.fa.PersianNormalizer
- KANJI - Static variable in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
- KANJINUMERIC - Static variable in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
- KASRA - Static variable in class org.apache.lucene.analysis.ar.ArabicNormalizer
- KASRATAN - Static variable in class org.apache.lucene.analysis.ar.ArabicNormalizer
- KATAKANA - Static variable in class org.apache.lucene.analysis.cjk.CJKBigramFilter
-
bigram flag for Katakana
- KATAKANA - Static variable in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
- KATAKANA - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
- KATAKANA - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
- KATAKANA_TYPE - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
- KATAKANA_TYPE - Static variable in class org.apache.lucene.analysis.standard.std31.StandardTokenizerImpl31
-
Deprecated.
- KATAKANA_TYPE - Static variable in class org.apache.lucene.analysis.standard.std31.UAX29URLEmailTokenizerImpl31
-
Deprecated.
- KATAKANA_TYPE - Static variable in class org.apache.lucene.analysis.standard.std34.UAX29URLEmailTokenizerImpl34
-
Deprecated.
- KATAKANA_TYPE - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
-
Deprecated.use
UAX29URLEmailTokenizer.TOKEN_TYPES
instead - KATAKANA_TYPE - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizerImpl
- keepFullyDeletedSegments(IndexWriter) - Static method in class org.apache.lucene.util._TestUtil
- KeepOnlyLastCommitDeletionPolicy - Class in org.apache.lucene.index
-
This
IndexDeletionPolicy
implementation that keeps only the most recent commit and immediately removes all prior commits after a new commit is done. - KeepOnlyLastCommitDeletionPolicy() - Constructor for class org.apache.lucene.index.KeepOnlyLastCommitDeletionPolicy
- KEHEH - Static variable in class org.apache.lucene.analysis.fa.PersianNormalizer
- ket - Variable in class org.tartarus.snowball.SnowballProgram
- key - Variable in class org.apache.lucene.search.suggest.Lookup.LookupResult
- keyIterator() - Method in class org.apache.lucene.util.collections.ArrayHashMap
-
Returns an iterator on the map keys.
- keyIterator() - Method in class org.apache.lucene.util.collections.FloatToObjectMap
-
Returns an iterator on the map keys.
- keyIterator() - Method in class org.apache.lucene.util.collections.IntToDoubleMap
-
Returns an iterator on the map keys.
- keyIterator() - Method in class org.apache.lucene.util.collections.IntToIntMap
-
Returns an iterator on the map keys.
- keyIterator() - Method in class org.apache.lucene.util.collections.IntToObjectMap
-
Returns an iterator on the map keys.
- keyIterator() - Method in class org.apache.lucene.util.collections.ObjectToFloatMap
-
Returns an iterator on the map keys.
- keyIterator() - Method in class org.apache.lucene.util.collections.ObjectToIntMap
- keyIterator() - Method in class org.apache.lucene.util.WeakIdentityMap
-
Returns an iterator over all weak keys of this map.
- keys - Variable in class org.apache.lucene.search.grouping.SentinelIntSet
- keys() - Method in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
- keySet() - Method in class org.apache.lucene.analysis.CharArrayMap
-
Returns an
CharArraySet
view on the map's keys. - KEYWORD - Static variable in class org.apache.lucene.analysis.MockTokenizer
-
Acts Similar to KeywordTokenizer.
- KeywordAnalyzer - Class in org.apache.lucene.analysis
-
"Tokenizes" the entire stream as a single token.
- KeywordAnalyzer() - Constructor for class org.apache.lucene.analysis.KeywordAnalyzer
- KeywordAttribute - Interface in org.apache.lucene.analysis.tokenattributes
-
This attribute can be used to mark a token as a keyword.
- KeywordAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
-
This attribute can be used to mark a token as a keyword.
- KeywordAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.KeywordAttributeImpl
- KeywordMarkerFilter - Class in org.apache.lucene.analysis
-
Marks terms as keywords via the
KeywordAttribute
. - KeywordMarkerFilter(TokenStream, Set<?>) - Constructor for class org.apache.lucene.analysis.KeywordMarkerFilter
-
Create a new KeywordMarkerFilter, that marks the current token as a keyword if the tokens term buffer is contained in the given set via the
KeywordAttribute
. - KeywordMarkerFilter(TokenStream, CharArraySet) - Constructor for class org.apache.lucene.analysis.KeywordMarkerFilter
-
Create a new KeywordMarkerFilter, that marks the current token as a keyword if the tokens term buffer is contained in the given set via the
KeywordAttribute
. - KeywordTokenizer - Class in org.apache.lucene.analysis
-
Emits the entire input as a single token.
- KeywordTokenizer(Reader) - Constructor for class org.apache.lucene.analysis.KeywordTokenizer
- KeywordTokenizer(Reader, int) - Constructor for class org.apache.lucene.analysis.KeywordTokenizer
- KeywordTokenizer(AttributeSource.AttributeFactory, Reader, int) - Constructor for class org.apache.lucene.analysis.KeywordTokenizer
- KeywordTokenizer(AttributeSource, Reader, int) - Constructor for class org.apache.lucene.analysis.KeywordTokenizer
- keywordTokenStream(Collection<T>) - Method in class org.apache.lucene.index.memory.MemoryIndex
-
Convenience method; Creates and returns a token stream that generates a token for each keyword in the given collection, "as is", without any transforming text analysis.
- KILOMETERS - org.apache.lucene.spatial.geometry.DistanceUnits
-
Deprecated.
- KILOMETERS_PER_MILE - Static variable in class org.apache.lucene.spatial.geometry.shape.DistanceApproximation
-
Deprecated.
- kind - Variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.Token
-
An integer that describes the kind of this token.
- kind - Variable in class org.apache.lucene.queryParser.standard.parser.Token
-
An integer that describes the kind of this token.
- kind - Variable in class org.apache.lucene.queryParser.surround.parser.Token
-
An integer that describes the kind of this token.
- kind - Variable in class org.apache.lucene.queryParser.Token
-
An integer that describes the kind of this token.
- KM_TO_MILES - Static variable in class org.apache.lucene.spatial.DistanceUtils
-
Deprecated.
- KM_USE_FIRST_OCCURRENCE - Static variable in class org.apache.lucene.search.DuplicateFilter
- KM_USE_LAST_OCCURRENCE - Static variable in class org.apache.lucene.search.DuplicateFilter
- knows(String) - Method in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
- KpStemmer - Class in org.tartarus.snowball.ext
-
Generated class implementing code defined by a snowball script.
- KpStemmer() - Constructor for class org.tartarus.snowball.ext.KpStemmer
- KStemFilter - Class in org.apache.lucene.analysis.en
-
A high-performance kstem filter for english.
- KStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.en.KStemFilter
- KStemmer - Class in org.apache.lucene.analysis.en
-
This class implements the Kstem algorithm
- kv - Variable in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
-
This vector holds the trailing of the keys when the branch is compressed.
L
- label - Variable in class org.apache.lucene.util.fst.Builder.Arc
- label - Variable in class org.apache.lucene.util.fst.FST.Arc
- labelResult(FacetResult) - Method in class org.apache.lucene.facet.search.FacetResultsHandler
-
Label results according to settings in
FacetRequest
, such asFacetRequest.getNumLabel()
. - labelResult(FacetResult) - Method in class org.apache.lucene.facet.search.TopKFacetResultsHandler
- labelResult(FacetResult) - Method in class org.apache.lucene.facet.search.TopKInEachNodeHandler
- LabelToOrdinal - Class in org.apache.lucene.facet.taxonomy.writercache.cl2o
-
Abstract class for storing Label->Ordinal mappings in a taxonomy.
- LabelToOrdinal() - Constructor for class org.apache.lucene.facet.taxonomy.writercache.cl2o.LabelToOrdinal
- LAM - Static variable in class org.apache.lucene.analysis.ar.ArabicStemmer
- LaoBreakIterator - Class in org.apache.lucene.analysis.icu.segmentation
-
Syllable iterator for Lao text.
- LaoBreakIterator(RuleBasedBreakIterator) - Constructor for class org.apache.lucene.analysis.icu.segmentation.LaoBreakIterator
- last() - Method in class org.apache.lucene.analysis.icu.segmentation.LaoBreakIterator
- last() - Method in class org.apache.lucene.analysis.util.CharArrayIterator
- lastCommit - Variable in class org.apache.lucene.index.SnapshotDeletionPolicy
- lastComponent() - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
-
Return the last component of the path, in a new String object.
- lastDocBase - Variable in class org.apache.lucene.search.CachingCollector
- lastIndexOf(Object) - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorPipeline
- lastModified(Directory) - Static method in class org.apache.lucene.index.IndexReader
-
Deprecated.If you need to track commit time of an index, you can store it in the commit data (see
IndexWriter.commit(Map)
- LATENT - org.apache.lucene.document.FieldSelectorResult
-
Lazily load this
Field
, but do not cache the result. - LATIMES - org.apache.lucene.benchmark.byTask.feeds.TrecDocParser.ParsePathType
- LatLng - Class in org.apache.lucene.spatial.geometry
-
Deprecated.
- LatLng() - Constructor for class org.apache.lucene.spatial.geometry.LatLng
-
Deprecated.
- latLonCorner(double, double, double, double[], boolean, double) - Static method in class org.apache.lucene.spatial.DistanceUtils
-
Deprecated.Uses Haversine to calculate the corner of a box (upper right or lower left) that is the distance away, given a sphere of the specified radius.
- latLonCornerDegs(double, double, double, double[], boolean, double) - Static method in class org.apache.lucene.spatial.DistanceUtils
-
Deprecated.
- LatLongDistanceFilter - Class in org.apache.lucene.spatial.tier
-
Deprecated.
- LatLongDistanceFilter(Filter, double, double, double, String, String) - Constructor for class org.apache.lucene.spatial.tier.LatLongDistanceFilter
-
Deprecated.Provide a distance filter based from a center point with a radius in miles.
- LatvianAnalyzer - Class in org.apache.lucene.analysis.lv
-
Analyzer
for Latvian. - LatvianAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.lv.LatvianAnalyzer
-
Builds an analyzer with the default stop words:
LatvianAnalyzer.DEFAULT_STOPWORD_FILE
. - LatvianAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.lv.LatvianAnalyzer
-
Builds an analyzer with the given stop words.
- LatvianAnalyzer(Version, Set<?>, Set<?>) - 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
-
A
TokenFilter
that appliesLatvianStemmer
to stem Latvian words. - LatvianStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.lv.LatvianStemFilter
- LatvianStemmer - Class in org.apache.lucene.analysis.lv
-
Light stemmer for Latvian.
- LatvianStemmer() - Constructor for class org.apache.lucene.analysis.lv.LatvianStemmer
- lazy - Variable in class org.apache.lucene.document.AbstractField
- LAZY_LOAD - org.apache.lucene.document.FieldSelectorResult
-
Lazily load this
Field
. - LE - org.apache.lucene.queryParser.core.nodes.ParametricQueryNode.CompareOperator
-
Deprecated.
- LEADING_WILDCARD_NOT_ALLOWED - Static variable in class org.apache.lucene.queryParser.core.messages.QueryParserMessages
- LEFT_ID - Static variable in class org.apache.lucene.analysis.ja.dict.UserDictionary
- legalCategory() - Method in class org.apache.lucene.facet.index.streaming.CountingListTokenizer
-
A method which allows extending classes to filter the categories going into the counting list.
- len - Variable in class org.apache.lucene.analysis.util.OpenStringBuilder
- length - Variable in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
- length - Variable in class org.apache.lucene.index.Payload
-
the length of the payload data
- length - Variable in class org.apache.lucene.util.BytesRef
-
Length of used bytes.
- length - Variable in class org.apache.lucene.util.CharsRef
- length - Variable in class org.apache.lucene.util.IntsRef
- length - Variable in class org.apache.lucene.util.UnicodeUtil.UTF16Result
- length - Variable in class org.apache.lucene.util.UnicodeUtil.UTF8Result
- 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() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
- length() - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
- length() - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
-
Return the number of components in the facet path.
- length() - Method in class org.apache.lucene.index.MockIndexInput
- length() - Method in class org.apache.lucene.index.Payload
-
Returns the length of the payload data.
- length() - Method in class org.apache.lucene.queryParser.core.util.UnescapedCharSequence
- length() - Method in class org.apache.lucene.store.BufferedIndexOutput
-
The number of bytes in the file.
- length() - Method in class org.apache.lucene.store.ChecksumIndexInput
- length() - Method in class org.apache.lucene.store.ChecksumIndexOutput
- length() - Method in class org.apache.lucene.store.FSDirectory.FSIndexOutput
- length() - Method in class org.apache.lucene.store.IndexInput
-
The number of bytes in the file.
- length() - Method in class org.apache.lucene.store.IndexOutput
-
The number of bytes in the file.
- length() - Method in class org.apache.lucene.store.MockIndexInputWrapper
- length() - Method in class org.apache.lucene.store.MockIndexOutputWrapper
- length() - Method in class org.apache.lucene.store.RAMInputStream
- length() - Method in class org.apache.lucene.store.RAMOutputStream
- length() - Method in class org.apache.lucene.store.SimpleFSDirectory.SimpleFSIndexInput
- length() - Method in class org.apache.lucene.store.WindowsDirectory.WindowsIndexInput
- length() - Method in interface org.apache.lucene.util.Bits
- length() - Method in class org.apache.lucene.util.Bits.MatchAllBits
- length() - Method in class org.apache.lucene.util.Bits.MatchNoBits
- length() - Method in class org.apache.lucene.util.BitVector
-
Returns the number of bits in this vector.
- length() - Method in class org.apache.lucene.util.CharsRef
- length() - Method in class org.apache.lucene.util.FixedBitSet
- length() - Method in class org.apache.lucene.util.OpenBitSet
- length() - Method in class org.apache.lucene.util.ThrottledIndexOutput
- length() - Method in class org.apache.lucene.util.UnsafeByteArrayOutputStream
-
Returns the number of relevant bytes.
- LengthFilter - Class in org.apache.lucene.analysis
-
Removes words that are too long or too short from the stream.
- LengthFilter(boolean, TokenStream, int, int) - Constructor for class org.apache.lucene.analysis.LengthFilter
-
Build a filter that removes words that are too long or too short from the text.
- LengthFilter(TokenStream, int, int) - Constructor for class org.apache.lucene.analysis.LengthFilter
-
Deprecated.Use
LengthFilter(boolean, TokenStream, int, int)
instead. - lengthNorm(String, int) - Method in class org.apache.lucene.search.Similarity
-
Deprecated.Please override computeNorm instead
- Less(String, String) - Static method in class org.apache.lucene.search.TermRangeFilter
-
Constructs a filter for field
fieldName
matching less than or equal toupperTerm
. - 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.
- LET - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
RegularExpression Id.
- LETTER - Static variable in class org.apache.lucene.analysis.cn.smart.CharType
-
Letters
- LetterTokenizer - Class in org.apache.lucene.analysis
-
A LetterTokenizer is a tokenizer that divides text at non-letters.
- LetterTokenizer(Reader) - Constructor for class org.apache.lucene.analysis.LetterTokenizer
-
Deprecated.use
LetterTokenizer(Version, Reader)
instead. This will be removed in Lucene 4.0. - LetterTokenizer(AttributeSource.AttributeFactory, Reader) - Constructor for class org.apache.lucene.analysis.LetterTokenizer
-
Deprecated.use
LetterTokenizer(Version, AttributeSource.AttributeFactory, Reader)
instead. This will be removed in Lucene 4.0. - LetterTokenizer(AttributeSource, Reader) - Constructor for class org.apache.lucene.analysis.LetterTokenizer
-
Deprecated.use
LetterTokenizer(Version, AttributeSource, Reader)
instead. This will be removed in Lucene 4.0. - LetterTokenizer(Version, Reader) - Constructor for class org.apache.lucene.analysis.LetterTokenizer
-
Construct a new LetterTokenizer.
- LetterTokenizer(Version, AttributeSource.AttributeFactory, Reader) - Constructor for class org.apache.lucene.analysis.LetterTokenizer
-
Construct a new LetterTokenizer using a given
AttributeSource.AttributeFactory
. - LetterTokenizer(Version, AttributeSource, Reader) - Constructor for class org.apache.lucene.analysis.LetterTokenizer
-
Construct a new LetterTokenizer using a given
AttributeSource
. - LEVEL_LOG_SPAN - Static variable in class org.apache.lucene.index.LogMergePolicy
-
Defines the allowed range of log(size) for each level.
- levelSizeArray - Static variable in class org.apache.lucene.util.ByteBlockPool
- LevensteinDistance - Class in org.apache.lucene.search.spell
-
Levenstein edit distance class.
- LevensteinDistance() - Constructor for class org.apache.lucene.search.spell.LevensteinDistance
-
Optimized to run a bit faster than the static getDistance().
- LexicalError(boolean, int, int, int, String, char) - Static method in error org.apache.lucene.benchmark.byTask.feeds.demohtml.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.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.
- LexicalError(boolean, int, int, int, String, char) - Static method in error org.apache.lucene.queryParser.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.benchmark.byTask.feeds.demohtml.HTMLParserTokenManager
-
Lexer state names.
- lexStateNames - Static variable in class org.apache.lucene.queryParser.QueryParserTokenManager
-
Lexer state names.
- lexStateNames - Static variable in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserTokenManager
-
Lexer state names.
- lexStateNames - Static variable in class org.apache.lucene.queryParser.surround.parser.QueryParserTokenManager
-
Lexer state names.
- 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.search.similar.MoreLikeThis
-
Return a query that will return docs like the passed lucene document ID.
- like(File) - Method in class org.apache.lucene.search.similar.MoreLikeThis
-
Deprecated.use
MoreLikeThis.like(Reader, String)
instead - like(InputStream) - Method in class org.apache.lucene.search.similar.MoreLikeThis
-
Deprecated.use
MoreLikeThis.like(Reader, String)
instead - like(Reader) - Method in class org.apache.lucene.search.similar.MoreLikeThis
-
Deprecated.use
MoreLikeThis.like(Reader, String)
instead - like(Reader, String) - Method in class org.apache.lucene.search.similar.MoreLikeThis
-
Return a query that will return docs like the passed Reader.
- like(URL) - Method in class org.apache.lucene.search.similar.MoreLikeThis
-
Deprecated.use
MoreLikeThis.like(Reader, String)
instead - LikeThisQueryBuilder - Class in org.apache.lucene.xmlparser.builders
- LikeThisQueryBuilder(Analyzer, String[]) - Constructor for class org.apache.lucene.xmlparser.builders.LikeThisQueryBuilder
- limit - Variable in class org.tartarus.snowball.SnowballProgram
- limit_backward - Variable in class org.tartarus.snowball.SnowballProgram
- LIMITED - Static variable in class org.apache.lucene.index.IndexWriter.MaxFieldLength
-
Deprecated.Sets the maximum field length to
IndexWriter.DEFAULT_MAX_FIELD_LENGTH
- LimitTokenCountAnalyzer - Class in org.apache.lucene.analysis
-
This Analyzer limits the number of tokens while indexing.
- LimitTokenCountAnalyzer(Analyzer, int) - Constructor for class org.apache.lucene.analysis.LimitTokenCountAnalyzer
-
Build an analyzer that limits the maximum number of tokens per field.
- LimitTokenCountFilter - Class in org.apache.lucene.analysis
-
This TokenFilter limits the number of tokens while indexing.
- LimitTokenCountFilter(TokenStream, int) - Constructor for class org.apache.lucene.analysis.LimitTokenCountFilter
-
Build a filter that only accepts tokens up to a maximum number.
- line - Variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
- line - Variable in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
- LineDocSource - Class in org.apache.lucene.benchmark.byTask.feeds
-
A
ContentSource
reading one line at a time as aDocument
from a single file. - LineDocSource() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.LineDocSource
- LineDocSource.HeaderLineParser - Class in org.apache.lucene.benchmark.byTask.feeds
-
LineDocSource.LineParser
which sets field names and order by the header - any header - of the lines file. - 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
-
LineDocSource.LineParser
which ignores the header passed to its constructor and assumes simply that field names and their order are the same as inWriteLineDocTask.DEFAULT_FIELDS
- LineFileDocs - Class in org.apache.lucene.util
-
Minimal port of contrib/benchmark's LneDocSource + DocMaker, so tests can enum docs from a line file created by contrib/benchmark's WriteLineDoc task
- LineFileDocs(Random) - Constructor for class org.apache.lucene.util.LineFileDocs
- 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)
- LineParser(String[]) - Constructor for class org.apache.lucene.benchmark.byTask.feeds.LineDocSource.LineParser
-
Construct with the header
- lines - Variable in class org.apache.lucene.search.suggest.fst.Sort.SortInfo
- LineSegment - Class in org.apache.lucene.spatial.geometry.shape
-
Deprecated.
- LineSegment() - Constructor for class org.apache.lucene.spatial.geometry.shape.LineSegment
-
Deprecated.
- LineSegment(Point2D, Point2D) - Constructor for class org.apache.lucene.spatial.geometry.shape.LineSegment
-
Deprecated.
- LINUX - Static variable in class org.apache.lucene.util.Constants
-
True iff running on Linux.
- listAll() - Method in class org.apache.lucene.store.Directory
-
Returns an array of strings, one for each file in the directory.
- listAll() - Method in class org.apache.lucene.store.FileSwitchDirectory
- listAll() - Method in class org.apache.lucene.store.FSDirectory
-
Lists all files (not subdirectories) in the directory.
- 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
- listAll(File) - Static method in class org.apache.lucene.store.FSDirectory
-
Lists all files (not subdirectories) in the directory.
- listCachedFiles() - Method in class org.apache.lucene.store.NRTCachingDirectory
- listCommits(Directory) - Static method in class org.apache.lucene.index.IndexReader
-
Returns all commit points that exist in the Directory.
- listIterator() - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorPipeline
- listIterator(int) - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorPipeline
- listSegments() - Method in class org.apache.lucene.index.IndexSplitter
- LLRect - Class in org.apache.lucene.spatial.geometry.shape
-
Deprecated.
- LLRect(LatLng, LatLng) - Constructor for class org.apache.lucene.spatial.geometry.shape.LLRect
-
Deprecated.
- LLRect(LLRect) - Constructor for class org.apache.lucene.spatial.geometry.shape.LLRect
-
Deprecated.
- 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(File, IndexReader, TaxonomyReader, FacetIndexingParams) - Method in class org.apache.lucene.facet.search.TotalFacetCountsCache
-
Load
TotalFacetCounts
matching input parameters from the provided outputFile and add them into the cache for the provided indexReader, taxonomy, and facetIndexingParams. - load(InputStream) - Static method in class org.apache.lucene.analysis.stempel.StempelStemmer
-
Load a stemmer table from an inputstream.
- load(InputStream) - Method in class org.apache.lucene.search.suggest.fst.FSTCompletionLookup
- load(InputStream) - Method in class org.apache.lucene.search.suggest.fst.FSTLookup
-
Deprecated.
- load(InputStream) - Method in class org.apache.lucene.search.suggest.fst.WFSTCompletionLookup
- load(InputStream) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellLookup
- load(InputStream) - Method in class org.apache.lucene.search.suggest.Lookup
-
Discard current lookup data and load it from a previously saved copy.
- load(InputStream) - Method in class org.apache.lucene.search.suggest.tst.TSTLookup
- LOAD - org.apache.lucene.document.FieldSelectorResult
- LOAD_AND_BREAK - org.apache.lucene.document.FieldSelectorResult
-
Load this field as in the
FieldSelectorResult.LOAD
case, but immediately return fromField
loading for theDocument
. - loadAndRegister(CategoryListParams, IndexReader, TaxonomyReader, FacetIndexingParams) - Method in class org.apache.lucene.facet.search.cache.CategoryListCache
-
Load and register
CategoryListData
. - loadDirectoryClass(String) - Static method in class org.apache.lucene.util.CommandLineUtil
-
Loads a specific Directory implementation
- LoadFirstFieldSelector - Class in org.apache.lucene.document
-
Load the First field and break.
- LoadFirstFieldSelector() - Constructor for class org.apache.lucene.document.LoadFirstFieldSelector
- loadFSDirectoryClass(String) - Static method in class org.apache.lucene.util.CommandLineUtil
-
Loads a specific FSDirectory implementation
- loadPatterns(File) - Method in class org.apache.lucene.analysis.compound.hyphenation.HyphenationTree
-
Read hyphenation patterns from an XML file.
- loadPatterns(InputSource) - Method in class org.apache.lucene.analysis.compound.hyphenation.HyphenationTree
-
Read hyphenation patterns from an XML file.
- loadStopWords(InputStream, String) - Method in class org.apache.lucene.analysis.cz.CzechAnalyzer
-
Deprecated.
- loadStopwordSet(boolean, Class<? extends ReusableAnalyzerBase>, String, String) - Static method in class org.apache.lucene.analysis.StopwordAnalyzerBase
-
Creates a CharArraySet from a file resource associated with a class.
- loadStopwordSet(File, Version) - Static method in class org.apache.lucene.analysis.StopwordAnalyzerBase
-
Creates a CharArraySet from a file.
- loadStopwordSet(Reader, Version) - Static method in class org.apache.lucene.analysis.StopwordAnalyzerBase
-
Creates a CharArraySet from a file.
- loadXML(Reader) - Static method in class org.apache.lucene.xmlparser.DOMUtils
-
Helper method to parse an XML file into a DOM tree, given a reader.
- LOCALE - Static variable in class org.apache.lucene.queryParser.standard.config.StandardQueryConfigHandler.ConfigurationKeys
-
Key used to set the
Locale
used when parsing the query - LocaleAttribute - Interface in org.apache.lucene.queryParser.standard.config
-
Deprecated.
- LocaleAttributeImpl - Class in org.apache.lucene.queryParser.standard.config
-
Deprecated.
- LocaleAttributeImpl() - Constructor for class org.apache.lucene.queryParser.standard.config.LocaleAttributeImpl
-
Deprecated.
- localeForName(String) - Static method in class org.apache.lucene.util.LuceneTestCase
-
return a Locale object equivalent to its programmatic name
- lock() - Method in class org.apache.lucene.util.DummyConcurrentLock
- 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.Lock
-
Pass this value to
Lock.obtain(long)
to try forever to obtain the lock. - LOCK_POLL_INTERVAL - Static variable in class org.apache.lucene.store.Lock
-
How long
Lock.obtain(long)
waits, in milliseconds, in between attempts to acquire the lock. - Lock.With - Class in org.apache.lucene.store
-
Utility class for executing code with exclusive access.
- lockDir - Variable in class org.apache.lucene.store.FSLockFactory
-
Directory for the lock files.
- lockFactory - Variable in class org.apache.lucene.store.Directory
-
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
- lockInterruptibly() - Method in class org.apache.lucene.util.DummyConcurrentLock
- 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
- lockPrefix - Variable in class org.apache.lucene.store.LockFactory
- 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
- LockStressTest - Class in org.apache.lucene.store
-
Simple standalone tool that forever acquires & releases a lock using a specific LockFactory.
- LockStressTest() - Constructor for class org.apache.lucene.store.LockStressTest
- LockVerifyServer - Class in org.apache.lucene.store
-
Simple standalone server that must be running when you use
VerifyingLockFactory
. - LockVerifyServer() - Constructor for class org.apache.lucene.store.LockVerifyServer
- log() - 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.
- log2(double) - Method in class org.apache.lucene.spatial.tier.projections.CartesianTierPlotter
-
Deprecated.a log to the base 2 formula
Math.log(value) / Math.log(2)
- 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
- 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
- logicalAnd(QueryNode, QueryNode) - Static method in class org.apache.lucene.queryParser.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
- 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
-
Index values for accessing relatives array.
- LONG - org.apache.lucene.document.NumericField.DataType
- LONG - Static variable in class org.apache.lucene.search.SortField
-
Sort using term values as encoded Longs.
- longestOp(Iterable<TaskStats>) - Method in class org.apache.lucene.benchmark.byTask.tasks.ReportTask
-
find the longest op name out of completed tasks.
- longHashCode() - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
-
Calculate a 64-bit hash function for this path.
- longHashCode(int) - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
-
Like
CategoryPath.longHashCode()
, but find the hash function of a prefix with the given number of components, rather than of the entire path. - LongRangeBuilder() - Constructor for class org.apache.lucene.util.NumericUtils.LongRangeBuilder
- 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
- longToPrefixCoded(long) - Static method in class org.apache.lucene.util.NumericUtils
- longToPrefixCoded(long, int) - Static method in class org.apache.lucene.util.NumericUtils
- longToPrefixCoded(long, int, char[]) - Static method in class org.apache.lucene.util.NumericUtils
-
Expert: Returns prefix coded bits after reducing the precision by
shift
bits. - longToString(long) - Static method in class org.apache.lucene.document.NumberTools
-
Deprecated.Converts a long to a String suitable for indexing.
- longVal(int) - Method in class org.apache.lucene.search.function.DocValues
-
Return doc value as a long.
- 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 - Variable in class org.apache.lucene.search.FieldCache.StringIndex
-
All the term values, in natural order.
- 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(CharSequence, boolean, int) - Method in class org.apache.lucene.search.suggest.fst.FSTCompletionLookup
- lookup(CharSequence, boolean, int) - Method in class org.apache.lucene.search.suggest.fst.FSTLookup
-
Deprecated.Lookup autocomplete suggestions to
key
. - lookup(CharSequence, boolean, int) - Method in class org.apache.lucene.search.suggest.fst.WFSTCompletionLookup
- lookup(CharSequence, boolean, int) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellLookup
- 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, boolean, int) - Method in class org.apache.lucene.search.suggest.tst.TSTLookup
- lookup(CharSequence, int) - Method in class org.apache.lucene.search.suggest.fst.FSTCompletion
-
Lookup suggestions to
key
. - Lookup - Class in org.apache.lucene.search.suggest
-
Simple Lookup interface for
CharSequence
suggestions. - Lookup() - Constructor for class org.apache.lucene.search.suggest.Lookup
- Lookup.LookupPriorityQueue - Class in org.apache.lucene.search.suggest
-
A
PriorityQueue
collecting a fixed size of high priorityLookup.LookupResult
- Lookup.LookupResult - Class in org.apache.lucene.search.suggest
-
Result of a lookup.
- lookupCharacterClass(String) - Static method in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
- lookupPrefix(char[], int, int) - Method in class org.apache.lucene.analysis.hunspell.HunspellDictionary
-
Looks up HunspellAffix prefixes that have an append that matches the String created from the given char array, offset and length
- LookupPriorityQueue(int) - Constructor for class org.apache.lucene.search.suggest.Lookup.LookupPriorityQueue
- LookupResult(CharSequence, long) - Constructor for class org.apache.lucene.search.suggest.Lookup.LookupResult
- lookupSegmentation(int) - Method in class org.apache.lucene.analysis.ja.dict.UserDictionary
- lookupSuffix(char[], int, int) - Method in class org.apache.lucene.analysis.hunspell.HunspellDictionary
-
Looks up HunspellAffix suffixes that have an append that matches the String created from the given char array, offset and length
- lookupWord(char[], int, int) - Method in class org.apache.lucene.analysis.hunspell.HunspellDictionary
-
Looks up HunspellWords that match the String created from the given char array, offset and length
- lookupWordIds(int, IntsRef) - Method in class org.apache.lucene.analysis.ja.dict.BinaryDictionary
- LovinsStemmer - Class in org.tartarus.snowball.ext
-
Generated class implementing code defined by a snowball script.
- LovinsStemmer() - Constructor for class org.tartarus.snowball.ext.LovinsStemmer
- LOWERCASE_EXPANDED_TERMS - Static variable in class org.apache.lucene.queryParser.standard.config.StandardQueryConfigHandler.ConfigurationKeys
-
Key used to set whether expanded terms should be expanded
- LowercaseExpandedTermsAttribute - Interface in org.apache.lucene.queryParser.standard.config
-
Deprecated.
- LowercaseExpandedTermsAttributeImpl - Class in org.apache.lucene.queryParser.standard.config
-
Deprecated.
- LowercaseExpandedTermsAttributeImpl() - Constructor for class org.apache.lucene.queryParser.standard.config.LowercaseExpandedTermsAttributeImpl
-
Deprecated.
- LowercaseExpandedTermsQueryNodeProcessor - Class in org.apache.lucene.queryParser.standard.processors
-
This processor verifies if
StandardQueryConfigHandler.ConfigurationKeys.LOWERCASE_EXPANDED_TERMS
is defined in theQueryConfigHandler
. - LowercaseExpandedTermsQueryNodeProcessor() - Constructor for class org.apache.lucene.queryParser.standard.processors.LowercaseExpandedTermsQueryNodeProcessor
- LowerCaseFilter - Class in org.apache.lucene.analysis
-
Normalizes token text to lower case.
- LowerCaseFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.LowerCaseFilter
-
Deprecated.Use
LowerCaseFilter(Version, TokenStream)
instead. - LowerCaseFilter(Version, TokenStream) - Constructor for class org.apache.lucene.analysis.LowerCaseFilter
-
Create a new LowerCaseFilter, that normalizes token text to lower case.
- LowerCaseTokenizer - Class in org.apache.lucene.analysis
-
LowerCaseTokenizer performs the function of LetterTokenizer and LowerCaseFilter together.
- LowerCaseTokenizer(Reader) - Constructor for class org.apache.lucene.analysis.LowerCaseTokenizer
-
Deprecated.use
LowerCaseTokenizer(Version, Reader)
instead. This will be removed in Lucene 4.0. - LowerCaseTokenizer(AttributeSource.AttributeFactory, Reader) - Constructor for class org.apache.lucene.analysis.LowerCaseTokenizer
-
Deprecated.use
LowerCaseTokenizer(Version, AttributeSource.AttributeFactory, Reader)
instead. This will be removed in Lucene 4.0. - LowerCaseTokenizer(AttributeSource, Reader) - Constructor for class org.apache.lucene.analysis.LowerCaseTokenizer
-
Deprecated.use
LowerCaseTokenizer(Version, AttributeSource, Reader)
instead. This will be removed in Lucene 4.0. - LowerCaseTokenizer(Version, Reader) - Constructor for class org.apache.lucene.analysis.LowerCaseTokenizer
-
Construct a new LowerCaseTokenizer.
- LowerCaseTokenizer(Version, AttributeSource.AttributeFactory, Reader) - Constructor for class org.apache.lucene.analysis.LowerCaseTokenizer
-
Construct a new LowerCaseTokenizer using a given
AttributeSource.AttributeFactory
. - LowerCaseTokenizer(Version, AttributeSource, Reader) - Constructor for class org.apache.lucene.analysis.LowerCaseTokenizer
-
Construct a new LowerCaseTokenizer using a given
AttributeSource
. - LPAREN - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
-
RegularExpression Id.
- LPAREN - Static variable in interface org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- LPAREN - Static variable in interface org.apache.lucene.queryParser.surround.parser.QueryParserConstants
-
RegularExpression Id.
- LRU_HASHED - org.apache.lucene.facet.taxonomy.writercache.lru.LruTaxonomyWriterCache.LRUType
- LRU_STRING - org.apache.lucene.facet.taxonomy.writercache.lru.LruTaxonomyWriterCache.LRUType
- LRUHashMap<K,V> - Class in org.apache.lucene.util.collections
-
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.util.collections.LRUHashMap
-
Create a new hash map with a bounded size and with least recently used entries removed.
- LruTaxonomyWriterCache - Class in org.apache.lucene.facet.taxonomy.writercache.lru
-
LRU
TaxonomyWriterCache
- good choice for huge taxonomies. - LruTaxonomyWriterCache(int) - Constructor for class org.apache.lucene.facet.taxonomy.writercache.lru.LruTaxonomyWriterCache
- LruTaxonomyWriterCache(int, LruTaxonomyWriterCache.LRUType) - Constructor for class org.apache.lucene.facet.taxonomy.writercache.lru.LruTaxonomyWriterCache
- LruTaxonomyWriterCache.LRUType - Enum in org.apache.lucene.facet.taxonomy.writercache.lru
- LT - org.apache.lucene.queryParser.core.nodes.ParametricQueryNode.CompareOperator
-
Deprecated.
- LUCENE_20 - org.apache.lucene.util.Version
-
Deprecated.(3.1) Use latest
- LUCENE_21 - org.apache.lucene.util.Version
-
Deprecated.(3.1) Use latest
- LUCENE_22 - org.apache.lucene.util.Version
-
Deprecated.(3.1) Use latest
- LUCENE_23 - org.apache.lucene.util.Version
-
Deprecated.(3.1) Use latest
- LUCENE_24 - org.apache.lucene.util.Version
-
Deprecated.(3.1) Use latest
- LUCENE_29 - org.apache.lucene.util.Version
-
Deprecated.(3.1) Use latest
- LUCENE_30 - org.apache.lucene.util.Version
-
Match settings and bugs in Lucene's 3.0 release.
- LUCENE_31 - org.apache.lucene.util.Version
-
Match settings and bugs in Lucene's 3.1 release.
- LUCENE_32 - org.apache.lucene.util.Version
-
Match settings and bugs in Lucene's 3.2 release.
- LUCENE_33 - org.apache.lucene.util.Version
-
Match settings and bugs in Lucene's 3.3 release.
- LUCENE_34 - org.apache.lucene.util.Version
-
Match settings and bugs in Lucene's 3.4 release.
- LUCENE_35 - org.apache.lucene.util.Version
-
Match settings and bugs in Lucene's 3.5 release.
- LUCENE_36 - org.apache.lucene.util.Version
-
Match settings and bugs in Lucene's 3.6 release.
- LUCENE_CURRENT - org.apache.lucene.util.Version
-
Deprecated.Use an actual version instead.
- LUCENE_MAIN_VERSION - Static variable in class org.apache.lucene.util.Constants
- LUCENE_QUERY_CONVERSION_ERROR - Static variable in class org.apache.lucene.queryParser.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
- LuceneJUnitDividingSelector - Class in org.apache.lucene.util
-
Divides filesets into equal groups
- LuceneJUnitDividingSelector() - Constructor for class org.apache.lucene.util.LuceneJUnitDividingSelector
- LuceneJUnitResultFormatter - Class in org.apache.lucene.util
-
Just like BriefJUnitResultFormatter "brief" bundled with ant, except all formatted text is buffered until the test suite is finished.
- LuceneJUnitResultFormatter() - Constructor for class org.apache.lucene.util.LuceneJUnitResultFormatter
-
Constructor for LuceneJUnitResultFormatter.
- 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.Nightly - Annotation Type in org.apache.lucene.util
-
Annotation for tests that should only be run during nightly builds.
- LuceneTestCaseRunner - Class in org.apache.lucene.util
-
optionally filters the tests to be run by TEST_METHOD
- LuceneTestCaseRunner(Class<?>) - Constructor for class org.apache.lucene.util.LuceneTestCaseRunner
M
- 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
- main(String[]) - Static method in class org.apache.lucene.analysis.compound.hyphenation.PatternParser
- main(String[]) - Static method in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
- main(String[]) - Static method in class org.apache.lucene.analysis.hunspell.HunspellStemmer
-
HunspellStemmer entry point.
- 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.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.index.CheckIndex
-
Command-line interface to check and fix an index.
- main(String[]) - Static method in class org.apache.lucene.index.CompoundFileExtractor
- main(String[]) - Static method in class org.apache.lucene.index.FieldNormModifier
-
Deprecated.Command Line Execution method.
- main(String[]) - Static method in class org.apache.lucene.index.IndexSorter
- main(String[]) - Static method in class org.apache.lucene.index.IndexSplitter
- main(String[]) - Static method in class org.apache.lucene.index.IndexUpgrader
- main(String[]) - Static method in class org.apache.lucene.index.MultiPassIndexSplitter
- main(String[]) - Static method in class org.apache.lucene.index.pruning.PruningTool
- 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.queryParser.QueryParser
-
Command line tool to test QueryParser, using
SimpleAnalyzer
. - main(String[]) - Static method in class org.apache.lucene.search.RemoteSearchable
-
Deprecated.Exports a searcher for the index in args[0] named "//localhost/Searchable".
- main(String[]) - Static method in class org.apache.lucene.search.vectorhighlight.FieldTermStack
- 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.
- main(String[]) - Static method in class org.tartarus.snowball.TestApp
- makeDictionary(Version, String[]) - Static method in class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
-
Deprecated.Only available for backwards compatibility.
- 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
-
Same as
DocMaker.makeDocument()
, only this method creates a document of the given size input bysize
. - makeFragment(StringBuilder, int[], String[], FieldFragList.WeightedFragInfo) - Method in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
-
Deprecated.
- makeFragment(StringBuilder, int[], Field[], FieldFragList.WeightedFragInfo, String[], String[], Encoder) - Method in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
- makeLock(String) - Method in class org.apache.lucene.store.Directory
-
Construct a
Lock
. - makeLock(String) - Method in class org.apache.lucene.store.LockFactory
-
Return a new Lock instance identified by lockName.
- makeLock(String) - Method in class org.apache.lucene.store.MockDirectoryWrapper
- makeLock(String) - Method in class org.apache.lucene.store.MockLockFactoryWrapper
- makeLock(String) - Method in class org.apache.lucene.store.NativeFSLockFactory
- makeLock(String) - Method in class org.apache.lucene.store.NoLockFactory
- makeLock(String) - Method in class org.apache.lucene.store.NRTCachingDirectory
- makeLock(String) - Method in class org.apache.lucene.store.SimpleFSLockFactory
- makeLock(String) - Method in class org.apache.lucene.store.SingleInstanceLockFactory
- makeLock(String) - Method in class org.apache.lucene.store.VerifyingLockFactory
- 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
- makeQuery() - Method in class org.apache.lucene.benchmark.byTask.feeds.AbstractQueryMaker
- makeQuery() - Method in class org.apache.lucene.benchmark.byTask.feeds.LongToEnglishQueryMaker
- makeQuery() - Method in interface org.apache.lucene.benchmark.byTask.feeds.QueryMaker
-
Create the next query
- 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(int) - Method in interface org.apache.lucene.benchmark.byTask.feeds.QueryMaker
-
Create the next query, of the given size.
- makeSpanNearClause() - Method in class org.apache.lucene.queryParser.surround.query.SpanNearClauseFactory
- makeStopSet(String...) - Static method in class org.apache.lucene.analysis.StopFilter
-
Deprecated.use
StopFilter.makeStopSet(Version, String...)
instead - makeStopSet(String[], boolean) - Static method in class org.apache.lucene.analysis.StopFilter
-
Deprecated.use
StopFilter.makeStopSet(Version, String[], boolean)
instead; - makeStopSet(List<?>) - Static method in class org.apache.lucene.analysis.StopFilter
-
Deprecated.use
StopFilter.makeStopSet(Version, List)
instead - makeStopSet(List<?>, boolean) - Static method in class org.apache.lucene.analysis.StopFilter
-
Deprecated.use
StopFilter.makeStopSet(Version, List, boolean)
instead - makeStopSet(Version, 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(Version, String[], boolean) - Static method in class org.apache.lucene.analysis.StopFilter
-
Creates a stopword set from the given stopword array.
- makeStopSet(Version, 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(Version, List<?>, boolean) - Static method in class org.apache.lucene.analysis.StopFilter
-
Creates a stopword set from the given stopword list.
- manager - Static variable in class org.apache.lucene.search.FilterManager
-
Deprecated.
- map - Variable in class org.apache.lucene.facet.index.CategoryContainer
- map(String, int, TermVectorOffsetInfo[], int[]) - Method in class org.apache.lucene.index.FieldSortedTermVectorMapper
- map(String, int, TermVectorOffsetInfo[], int[]) - Method in class org.apache.lucene.index.PositionBasedTermVectorMapper
-
Callback for the TermVectorReader.
- map(String, int, TermVectorOffsetInfo[], int[]) - Method in class org.apache.lucene.index.SortedTermVectorMapper
- map(String, int, TermVectorOffsetInfo[], int[]) - Method in class org.apache.lucene.index.TermVectorMapper
-
Map the Term Vector information into your own structure
- MapBackedSet<E> - Class in org.apache.lucene.util
-
A Set implementation that wraps an actual Map based implementation.
- MapBackedSet(Map<E, Boolean>) - Constructor for class org.apache.lucene.util.MapBackedSet
-
Creates a new instance which wraps the specified
map
. - MapFieldSelector - Class in org.apache.lucene.document
-
A
FieldSelector
based on a Map of field names toFieldSelectorResult
s - MapFieldSelector(String...) - Constructor for class org.apache.lucene.document.MapFieldSelector
-
Create a a MapFieldSelector
- MapFieldSelector(List<String>) - Constructor for class org.apache.lucene.document.MapFieldSelector
-
Create a a MapFieldSelector
- MapFieldSelector(Map<String, FieldSelectorResult>) - Constructor for class org.apache.lucene.document.MapFieldSelector
-
Create a a MapFieldSelector
- 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
- MappingCharFilter - Class in org.apache.lucene.analysis
-
Simplistic
CharFilter
that applies the mappings contained in aNormalizeCharMap
to the character stream, and correcting the resulting changes to the offsets. - MappingCharFilter(NormalizeCharMap, Reader) - Constructor for class org.apache.lucene.analysis.MappingCharFilter
-
Easy-use constructor that takes a
Reader
. - MappingCharFilter(NormalizeCharMap, CharStream) - Constructor for class org.apache.lucene.analysis.MappingCharFilter
-
Default constructor that takes a
CharStream
. - mapToAACOs - Variable in class org.apache.lucene.facet.search.TopKInEachNodeHandler.IntermediateFacetResultWithHash
- MARGIN_DEFAULT - Static variable in class org.apache.lucene.search.vectorhighlight.SimpleFragListBuilder
- mark(int) - Method in class org.apache.lucene.analysis.CharFilter
- mark(int) - Method in class org.apache.lucene.analysis.CharReader
- mark(int) - Method in class org.apache.lucene.benchmark.byTask.utils.StringBuilderReader
-
Mark the present position in the stream.
- mark(int) - Method in class org.apache.lucene.util.UnsafeByteArrayInputStream
- markSupported() - Method in class org.apache.lucene.analysis.CharFilter
- markSupported() - Method in class org.apache.lucene.analysis.CharReader
- markSupported() - Method in class org.apache.lucene.analysis.MockReaderWrapper
- markSupported() - Method in class org.apache.lucene.benchmark.byTask.utils.StringBuilderReader
- markSupported() - Method in class org.apache.lucene.util.UnsafeByteArrayInputStream
- 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.search.spans.SpanPositionCheckQuery
- match(int) - Method in class org.apache.lucene.search.FilteredDocIdSet
-
Validation method to determine whether a docid should be in the result set.
- match(int) - Method in class org.apache.lucene.search.FilteredDocIdSetIterator
-
Validation method to determine whether a docid should be in the result set.
- match(String) - Method in class org.apache.lucene.search.regex.JakartaRegexpCapabilities
- match(String) - Method in class org.apache.lucene.search.regex.JavaUtilRegexCapabilities
- match(String) - Method in interface org.apache.lucene.search.regex.RegexCapabilities
- 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
- MatchAllDocsQuery(String) - Constructor for class org.apache.lucene.search.MatchAllDocsQuery
- MatchAllDocsQueryBuilder - Class in org.apache.lucene.xmlparser.builders
- MatchAllDocsQueryBuilder() - Constructor for class org.apache.lucene.xmlparser.builders.MatchAllDocsQueryBuilder
- MatchAllDocsQueryNode - Class in org.apache.lucene.queryParser.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.core.nodes.MatchAllDocsQueryNode
- MatchAllDocsQueryNodeBuilder - Class in org.apache.lucene.queryParser.standard.builders
-
Builds a
MatchAllDocsQuery
object from aMatchAllDocsQueryNode
object. - MatchAllDocsQueryNodeBuilder() - Constructor for class org.apache.lucene.queryParser.standard.builders.MatchAllDocsQueryNodeBuilder
- MatchAllDocsQueryNodeProcessor - Class in org.apache.lucene.queryParser.standard.processors
-
This processor converts every
WildcardQueryNode
that is "*:*" toMatchAllDocsQueryNode
. - MatchAllDocsQueryNodeProcessor() - Constructor for class org.apache.lucene.queryParser.standard.processors.MatchAllDocsQueryNodeProcessor
- matchAlmost(CharSequence, int) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Returns a
List
of keys that almost match the argument key. - matchAlmost(String) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Returns a
List
of keys that almost match the argument key. - matchDoc(int) - Method in class org.apache.lucene.search.FieldCacheDocIdSet
-
this method checks, if a doc is a hit
- 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
- matchesExtension(String, String) - Static method in class org.apache.lucene.index.IndexFileNames
-
Returns true if the given filename ends with the given extension.
- matchingChar(char) - Method in class org.apache.lucene.queryParser.surround.query.SrndTruncQuery
- MatchNoBits(int) - Constructor for class org.apache.lucene.util.Bits.MatchNoBits
- MatchNoDocsQueryNode - Class in org.apache.lucene.queryParser.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.core.nodes.MatchNoDocsQueryNode
- MatchNoDocsQueryNodeBuilder - Class in org.apache.lucene.queryParser.standard.builders
-
Builds an empty
BooleanQuery
object from aMatchNoDocsQueryNode
object. - MatchNoDocsQueryNodeBuilder() - Constructor for class org.apache.lucene.queryParser.standard.builders.MatchNoDocsQueryNodeBuilder
- matchPrefix(CharSequence, int) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Returns an alphabetical
List
of all keys in the trie that begin with a given prefix. - matchPrefix(String) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Returns an alphabetical
List
of all keys in the trie that begin with a given prefix. - matchVersion - Variable in class org.apache.lucene.analysis.StopwordAnalyzerBase
- Matrix() - Constructor for class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.Matrix
-
Deprecated.
- Max - org.apache.lucene.search.join.ToParentBlockJoinQuery.ScoreMode
-
Parent hit's score is the max of all child scores.
- MAX_DATE_STRING() - Static method in class org.apache.lucene.document.DateField
-
Deprecated.
- MAX_FREQUENCE - Static variable in class org.apache.lucene.analysis.cn.smart.Utility
-
Maximum bigram frequency (used in the smoothing function).
- MAX_POINTS - Static variable in class org.apache.lucene.benchmark.quality.QualityStats
-
Number of points for which precision is computed.
- MAX_STRING_VALUE - Static variable in class org.apache.lucene.document.NumberTools
-
Deprecated.Equivalent to longToString(Long.MAX_VALUE)
- MAX_TEMPFILES - Static variable in class org.apache.lucene.search.suggest.fst.Sort
-
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.
- maxBufferedBlocks() - Method in class org.apache.lucene.util.RecyclingByteBlockAllocator
- maxCoord - Variable in class org.apache.lucene.search.BooleanQuery.BooleanWeight
- maxDoc - Variable in class org.apache.lucene.index.AbstractAllTermDocs
- maxDoc() - Method in class org.apache.lucene.index.FilterIndexReader
- maxDoc() - Method in class org.apache.lucene.index.IndexReader
-
Returns one greater than the largest possible document number.
- maxDoc() - Method in class org.apache.lucene.index.IndexWriter
-
Returns total number of docs in this index, including docs not yet flushed (still in the RAM buffer), not counting deletions.
- maxDoc() - Method in class org.apache.lucene.index.MultiReader
- maxDoc() - Method in class org.apache.lucene.index.ParallelReader
- maxDoc() - Method in class org.apache.lucene.index.RandomIndexWriter
- maxDoc() - Method in class org.apache.lucene.index.SegmentReader
- maxDoc() - Method in class org.apache.lucene.search.IndexSearcher
-
Expert: Returns one greater than the largest possible document number.
- maxDoc() - Method in class org.apache.lucene.search.MultiSearcher
-
Deprecated.
- maxDoc() - Method in class org.apache.lucene.search.RemoteSearchable
-
Deprecated.
- maxDoc() - Method in interface org.apache.lucene.search.Searchable
-
Deprecated.Expert: Returns one greater than the largest possible document number.
- maxDoc() - Method in class org.apache.lucene.search.Searcher
-
Deprecated.
- maxDoc() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexReader
-
Deprecated.
- maxDocCharsToAnalyze - Variable in class org.apache.lucene.benchmark.byTask.tasks.SearchTravRetHighlightTask
- maxDocsToCache - Variable in class org.apache.lucene.search.CachingCollector
- MaxFieldLength(int) - Constructor for class org.apache.lucene.index.IndexWriter.MaxFieldLength
-
Deprecated.Public constructor to allow users to specify the maximum field size limit.
- maxFrags - Variable in class org.apache.lucene.benchmark.byTask.tasks.SearchTravRetHighlightTask
- maxFrags - Variable in class org.apache.lucene.benchmark.byTask.tasks.SearchTravRetVectorHighlightTask
- maxHorizontalContext - Variable in class org.apache.lucene.analysis.synonym.SynonymMap
-
maxHorizontalContext: maximum context we need on the tokenstream
- MAXIMUM_BYTES_NEEDED - Static variable in class org.apache.lucene.util.Vint8
-
The maximum number of bytes needed to encode a number using
Vint8
. - maxMergeDocs - Variable in class org.apache.lucene.index.LogMergePolicy
- maxMergeSize - Variable in class org.apache.lucene.index.LogMergePolicy
- maxMergeSizeForForcedMerge - Variable in class org.apache.lucene.index.LogMergePolicy
- maxNextCharInd - Variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
- maxNextCharInd - Variable in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
- maxNumCachedFilters - Static variable in class org.apache.lucene.xmlparser.CoreParser
- maxPartitions - Variable in class org.apache.lucene.facet.search.StandardFacetsAccumulator
- MaxPayloadFunction - Class in org.apache.lucene.search.payloads
-
Returns the maximum payload score seen, else 1 if there are no payloads on the doc.
- MaxPayloadFunction() - Constructor for class org.apache.lucene.search.payloads.MaxPayloadFunction
- 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
- maxSegmentName - Variable in class org.apache.lucene.index.CheckIndex.Status
-
The greatest segment name.
- maxSkipLevels - Variable in class org.apache.lucene.index.SegmentWriteState
-
Expert: The maximum number of skip levels.
- maxSubwordSize - Variable in class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
- maxValue(int) - Static method in class org.apache.lucene.util.packed.PackedInts
-
Calculates the maximum unsigned long that can be expressed with the given number of bits.
- maybeMerge() - Method in class org.apache.lucene.index.IndexWriter
-
Expert: asks the mergePolicy whether any merges are necessary now and if so, runs the requested merges and then iterate (test again if merges are needed) until no more merges are returned by the mergePolicy.
- maybeRefresh() - Method in class org.apache.lucene.search.ReferenceManager
-
You must call this, periodically, if you want that
ReferenceManager.acquire()
will return refreshed instances. - maybeReopen() - Method in class org.apache.lucene.search.SearcherManager
-
Deprecated.
- mayComplement() - Method in class org.apache.lucene.facet.search.FacetsAccumulator
-
check if all requests are complementable
- MB - Static variable in class org.apache.lucene.search.suggest.fst.Sort
- mBitsToBytes(int) - Static method in class org.apache.lucene.util.ThrottledIndexOutput
- megabytes(long) - Static method in class org.apache.lucene.search.suggest.fst.Sort.BufferSize
-
Creates a
Sort.BufferSize
in MB. - 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.
- MemoryOrdinalMap() - Constructor for class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter.MemoryOrdinalMap
- merge(Object, Object) - Method in class org.apache.lucene.util.fst.UpToTwoPositiveIntOutputs
- 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(CategoryProperty) - Method in class org.apache.lucene.facet.enhancements.association.AssociationFloatProperty
- merge(CategoryProperty) - Method in class org.apache.lucene.facet.enhancements.association.AssociationIntProperty
- merge(CategoryProperty) - Method in interface org.apache.lucene.facet.index.attributes.CategoryProperty
-
When adding categories with properties to a certain document, it is possible that the same category will be added more than once with different instances of the same property.
- merge(CategoryProperty) - Method in class org.apache.lucene.facet.index.attributes.OrdinalProperty
- merge(CategoryContainer) - Method in class org.apache.lucene.facet.index.CategoryContainer
-
Add the categories from another
CategoryContainer
to this one. - merge(IndexWriter) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
- merge(IndexWriter) - Method in class org.apache.lucene.index.MergeScheduler
-
Run the merges provided by
IndexWriter.getNextMerge()
. - merge(IndexWriter) - Method in class org.apache.lucene.index.NoMergeScheduler
- merge(IndexWriter) - Method in class org.apache.lucene.index.SerialMergeScheduler
-
Just do the merges in sequence.
- 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(TopGroups<T>[], Sort, Sort, int, int) - 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(Sort, int, TopDocs[]) - Static method in class org.apache.lucene.search.TopDocs
-
Returns a new TopDocs, containing topN results across the provided TopDocs, sorting by the specified
Sort
. - 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(Row, Row) - Method in class org.egothor.stemmer.Optimizer
-
Merge the given rows and return the resulting Row.
- merge(T, T) - Method in class org.apache.lucene.util.fst.Outputs
- MergeAbortedException() - Constructor for exception org.apache.lucene.index.MergePolicy.MergeAbortedException
- MergeAbortedException(String) - Constructor for exception org.apache.lucene.index.MergePolicy.MergeAbortedException
- mergeBooleanQueries(BooleanQuery...) - Static method in class org.apache.lucene.search.Query
-
Expert: merges the clauses of a set of BooleanQuery's into a single BooleanQuery.
- mergeContiguous - Variable in class org.apache.lucene.benchmark.byTask.tasks.SearchTravRetHighlightTask
- MergeException(String, Directory) - Constructor for exception org.apache.lucene.index.MergePolicy.MergeException
- MergeException(Throwable, Directory) - Constructor for exception org.apache.lucene.index.MergePolicy.MergeException
- mergeFactor - Variable in class org.apache.lucene.index.LogMergePolicy
- 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.MergeAbortedException - Exception in org.apache.lucene.index
- 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.
- MergePolicyParams() - Constructor for class org.apache.lucene.index.BalancedSegmentMergePolicy.MergePolicyParams
-
Deprecated.
- mergeResults(IntermediateFacetResult...) - Method in class org.apache.lucene.facet.search.FacetResultsHandler
-
Merge results of several facet partitions.
- mergeResults(IntermediateFacetResult...) - Method in class org.apache.lucene.facet.search.TopKFacetResultsHandler
- mergeResults(IntermediateFacetResult...) - Method in class org.apache.lucene.facet.search.TopKInEachNodeHandler
-
Merge several partitions'
IntermediateFacetResult
-s into one of the same format - mergeRounds - Variable in class org.apache.lucene.search.suggest.fst.Sort.SortInfo
- merges - Variable in class org.apache.lucene.index.MergePolicy.MergeSpecification
-
The subset of segments to be included in the primitive merge.
- MergeScheduler - Class in org.apache.lucene.index
-
Expert:
IndexWriter
uses an instance implementing this interface to execute the merges selected by aMergePolicy
. - MergeScheduler() - Constructor for class org.apache.lucene.index.MergeScheduler
- MergeScore() - Constructor for class org.apache.lucene.index.TieredMergePolicy.MergeScore
- mergeSort(int, int) - Method in class org.apache.lucene.util.SorterTemplate
-
Sorts via stable in-place MergeSort algorithm For small collections falls back to
SorterTemplate.insertionSort(int,int)
. - mergeSort(List<T>) - Static method in class org.apache.lucene.util.CollectionUtil
-
Sorts the given random access
List
in natural order. - mergeSort(List<T>, Comparator<? super T>) - Static method in class org.apache.lucene.util.CollectionUtil
-
Sorts the given random access
List
using theComparator
. - mergeSort(T[]) - Static method in class org.apache.lucene.util.ArrayUtil
-
Sorts the given array in natural order.
- mergeSort(T[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Sorts the given array slice in natural order.
- mergeSort(T[], int, int, Comparator<? super T>) - Static method in class org.apache.lucene.util.ArrayUtil
-
Sorts the given array slice using the
Comparator
. - mergeSort(T[], Comparator<? super T>) - Static method in class org.apache.lucene.util.ArrayUtil
-
Sorts the given array using the
Comparator
. - MergeSpecification() - Constructor for class org.apache.lucene.index.MergePolicy.MergeSpecification
- MergeThread(IndexWriter, MergePolicy.OneMerge) - Constructor for class org.apache.lucene.index.ConcurrentMergeScheduler.MergeThread
- 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.
- mergeThreads - Variable in class org.apache.lucene.index.ConcurrentMergeScheduler
- mergeTime - Variable in class org.apache.lucene.search.suggest.fst.Sort.SortInfo
- message - Variable in exception org.apache.lucene.queryParser.core.QueryNodeException
- message(String) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
-
Outputs the given message - this method assumes
ConcurrentMergeScheduler.verbose()
was called and returned true. - message(String) - Method in class org.apache.lucene.index.IndexWriter
-
Prints a message to the infoStream (if non-null), prefixed with the identifying information for this writer and the thread that's calling it.
- message(String) - Method in class org.apache.lucene.index.LogMergePolicy
- Message - Interface in org.apache.lucene.messages
-
Deprecated.Will be moved to a private package inside flexible query parser (Lucene 4.0).
- MessageImpl - Class in org.apache.lucene.messages
-
Deprecated.Will be moved to a private package inside flexible query parser (Lucene 4.0).
- MessageImpl(String) - Constructor for class org.apache.lucene.messages.MessageImpl
-
Deprecated.
- MessageImpl(String, Object...) - Constructor for class org.apache.lucene.messages.MessageImpl
-
Deprecated.
- method - Variable in class org.tartarus.snowball.Among
- methodobject - Variable in class org.tartarus.snowball.Among
- MILES - org.apache.lucene.spatial.geometry.DistanceUnits
-
Deprecated.
- MILES_FLOOR - Static variable in class org.apache.lucene.spatial.tier.CartesianPolyFilterBuilder
-
Deprecated.
- MILES_PER_LATITUDE - Static variable in class org.apache.lucene.spatial.geometry.shape.DistanceApproximation
-
Deprecated.
- MILES_TO_KM - Static variable in class org.apache.lucene.spatial.DistanceUtils
-
Deprecated.
- MILLISECOND - org.apache.lucene.document.DateTools.Resolution
- min - Variable in class org.apache.lucene.analysis.pt.RSLPStemmerBase.Rule
- min - Variable in class org.apache.lucene.analysis.pt.RSLPStemmerBase.Step
- MIN_BUFFER_SIZE_MB - Static variable in class org.apache.lucene.search.suggest.fst.Sort
-
Minimum recommended buffer size for sorting.
- MIN_DATE_STRING() - Static method in class org.apache.lucene.document.DateField
-
Deprecated.
- MIN_FRAG_CHAR_SIZE_FACTOR - Static variable in class org.apache.lucene.search.vectorhighlight.SimpleFragListBuilder
- MIN_STRING_VALUE - Static variable in class org.apache.lucene.document.NumberTools
-
Deprecated.Equivalent to longToString(Long.MIN_VALUE)
- minMergeSize - Variable in class org.apache.lucene.index.LogMergePolicy
- minNrShouldMatch - Variable in class org.apache.lucene.search.BooleanQuery
- MinPayloadFunction - Class in org.apache.lucene.search.payloads
-
Calculates the minimum payload seen
- MinPayloadFunction() - Constructor for class org.apache.lucene.search.payloads.MinPayloadFunction
- MinResult(IntsRef, T, Comparator<T>) - Constructor for class org.apache.lucene.util.fst.Util.MinResult
- minSubwordSize - Variable in class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
- MINUS - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
-
RegularExpression Id.
- MINUS - Static variable in interface org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- MINUTE - org.apache.lucene.document.DateTools.Resolution
- minWordSize - Variable in class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
- missingSegments - Variable in class org.apache.lucene.index.CheckIndex.Status
-
True if we were unable to locate and load the segments_N file.
- missingSegmentVersion - Variable in class org.apache.lucene.index.CheckIndex.Status
-
True if we were unable to read the version number from segments_N file.
- missingValue - Variable in class org.apache.lucene.search.FieldComparator.NumericComparator
- MMapDirectory - Class in org.apache.lucene.store
-
File-based
Directory
implementation that uses mmap for reading, andFSDirectory.FSIndexOutput
for writing. - MMapDirectory(File) - Constructor for class org.apache.lucene.store.MMapDirectory
-
Create a new MMapDirectory for the named location and
NativeFSLockFactory
. - MMapDirectory(File, LockFactory) - Constructor for class org.apache.lucene.store.MMapDirectory
-
Create a new MMapDirectory for the named location.
- MockAnalyzer - Class in org.apache.lucene.analysis
-
Analyzer for testing
- MockAnalyzer(Random) - Constructor for class org.apache.lucene.analysis.MockAnalyzer
-
Create a Whitespace-lowercasing analyzer with no stopwords removal.
- MockAnalyzer(Random, int, boolean) - Constructor for class org.apache.lucene.analysis.MockAnalyzer
- MockAnalyzer(Random, int, boolean, CharArraySet, boolean) - Constructor for class org.apache.lucene.analysis.MockAnalyzer
-
Creates a new MockAnalyzer.
- 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) - Constructor for class org.apache.lucene.analysis.MockCharFilter
- MockCharFilter(Reader, int) - 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.Throttling - Enum in org.apache.lucene.store
- 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
- MockHoleInjectingTokenFilter(Random, TokenStream) - Constructor for class org.apache.lucene.analysis.MockHoleInjectingTokenFilter
- MockIndexInput - Class in org.apache.lucene.index
-
IndexInput backed by a byte[] for testing.
- MockIndexInput(byte[]) - Constructor for class org.apache.lucene.index.MockIndexInput
- 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) - Constructor for class org.apache.lucene.store.MockIndexInputWrapper
-
Construct an empty output buffer.
- 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.
- MockLockFactoryWrapper - Class in org.apache.lucene.store
-
Used by MockDirectoryWrapper to wrap another factory and track open locks.
- MockLockFactoryWrapper(MockDirectoryWrapper, LockFactory) - Constructor for class org.apache.lucene.store.MockLockFactoryWrapper
- MockRandomLookaheadTokenFilter - Class in org.apache.lucene.analysis
-
Uses
LookaheadTokenFilter
to randomly peek at future tokens. - 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
- 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
- MockTokenizer - Class in org.apache.lucene.analysis
-
Tokenizer for testing.
- MockTokenizer(Reader) - Constructor for class org.apache.lucene.analysis.MockTokenizer
- MockTokenizer(Reader, int, boolean) - Constructor for class org.apache.lucene.analysis.MockTokenizer
- MockTokenizer(Reader, int, boolean, int) - Constructor for class org.apache.lucene.analysis.MockTokenizer
- MockTokenizer(AttributeSource.AttributeFactory, Reader, int, boolean, int) - Constructor for class org.apache.lucene.analysis.MockTokenizer
- 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
- MOD_NONE - org.apache.lucene.queryParser.core.nodes.ModifierQueryNode.Modifier
- MOD_NOT - org.apache.lucene.queryParser.core.nodes.ModifierQueryNode.Modifier
- MOD_REQ - org.apache.lucene.queryParser.core.nodes.ModifierQueryNode.Modifier
- ModClause(CharSequence) - Method in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParser
- ModifierQueryNode - Class in org.apache.lucene.queryParser.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.core.nodes.ModifierQueryNode
-
Used to store the modifier value on the original query string
- ModifierQueryNode.Modifier - Enum in org.apache.lucene.queryParser.core.nodes
- ModifierQueryNodeBuilder - Class in org.apache.lucene.queryParser.standard.builders
-
Builds no object, it only returns the
Query
object set on theModifierQueryNode
object using aQueryTreeBuilder.QUERY_TREE_BUILDER_TAGID
tag. - ModifierQueryNodeBuilder() - Constructor for class org.apache.lucene.queryParser.standard.builders.ModifierQueryNodeBuilder
- Modifiers() - Method in class org.apache.lucene.queryParser.QueryParser
- Modifiers() - Method in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParser
- MONTH - org.apache.lucene.document.DateTools.Resolution
- more - Variable in class org.apache.lucene.search.spans.SpanScorer
- More(String, String) - Static method in class org.apache.lucene.search.TermRangeFilter
-
Constructs a filter for field
fieldName
matching greater than or equal tolowerTerm
. - MoreLikeThis - Class in org.apache.lucene.search.similar
-
Generate "more like this" similarity queries.
- MoreLikeThis(IndexReader) - Constructor for class org.apache.lucene.search.similar.MoreLikeThis
-
Constructor requiring an IndexReader.
- MoreLikeThis(IndexReader, Similarity) - Constructor for class org.apache.lucene.search.similar.MoreLikeThis
- MoreLikeThisQuery - Class in org.apache.lucene.search.similar
-
A simple wrapper for MoreLikeThis for use in scenarios where a Query object is required eg in custom QueryParser extensions.
- MoreLikeThisQuery(String, String[], Analyzer) - Constructor for class org.apache.lucene.search.similar.MoreLikeThisQuery
-
Deprecated.
- MoreLikeThisQuery(String, String[], Analyzer, String) - Constructor for class org.apache.lucene.search.similar.MoreLikeThisQuery
- mult(double) - Method in class org.apache.lucene.spatial.geometry.shape.Vector2D
-
Deprecated.
- MULTI_FIELDS - Static variable in class org.apache.lucene.queryParser.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.standard.config.StandardQueryConfigHandler.ConfigurationKeys
-
Key used to set the
MultiTermQuery.RewriteMethod
used when creating queries - MultiCategoryListIterator - Class in org.apache.lucene.facet.util
-
Iterates over multiple
CategoryListIterator
s, consuming the provided iterators in order. - MultiCategoryListIterator(CategoryListIterator...) - Constructor for class org.apache.lucene.facet.util.MultiCategoryListIterator
-
Receives the iterators to iterate on
- MultiCollector - Class in org.apache.lucene.search
- MultiFieldAttribute - Interface in org.apache.lucene.queryParser.standard.config
-
Deprecated.
- MultiFieldAttributeImpl - Class in org.apache.lucene.queryParser.standard.config
-
Deprecated.
- MultiFieldAttributeImpl() - Constructor for class org.apache.lucene.queryParser.standard.config.MultiFieldAttributeImpl
-
Deprecated.
- MultiFieldQueryNodeProcessor - Class in org.apache.lucene.queryParser.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.standard.processors.MultiFieldQueryNodeProcessor
- MultiFieldQueryParser - Class in org.apache.lucene.queryParser
-
A QueryParser which constructs queries to search multiple fields.
- MultiFieldQueryParser(Version, String[], Analyzer) - Constructor for class org.apache.lucene.queryParser.MultiFieldQueryParser
-
Creates a MultiFieldQueryParser.
- MultiFieldQueryParser(Version, String[], Analyzer, Map<String, Float>) - Constructor for class org.apache.lucene.queryParser.MultiFieldQueryParser
-
Creates a MultiFieldQueryParser.
- MultiFieldQueryParserWrapper - Class in org.apache.lucene.queryParser.standard
-
Deprecated.this class will be removed soon, it's a temporary class to be used along the transition from the old query parser to the new one
- MultiFieldQueryParserWrapper(String[], Analyzer) - Constructor for class org.apache.lucene.queryParser.standard.MultiFieldQueryParserWrapper
-
Deprecated.Creates a MultiFieldQueryParser.
- MultiFieldQueryParserWrapper(String[], Analyzer, Map<String, Float>) - Constructor for class org.apache.lucene.queryParser.standard.MultiFieldQueryParserWrapper
-
Deprecated.Creates a MultiFieldQueryParser.
- 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
-
MultiPhraseQuery is a generalized version of PhraseQuery, with an added method
MultiPhraseQuery.add(Term[])
. - MultiPhraseQuery() - Constructor for class org.apache.lucene.search.MultiPhraseQuery
- MultiPhraseQueryNode - Class in org.apache.lucene.queryParser.standard.nodes
-
A
MultiPhraseQueryNode
indicates that its children should be used to build aMultiPhraseQuery
instead ofPhraseQuery
. - MultiPhraseQueryNode() - Constructor for class org.apache.lucene.queryParser.standard.nodes.MultiPhraseQueryNode
- MultiPhraseQueryNodeBuilder - Class in org.apache.lucene.queryParser.standard.builders
-
Builds a
MultiPhraseQuery
object from aMultiPhraseQueryNode
object. - MultiPhraseQueryNodeBuilder() - Constructor for class org.apache.lucene.queryParser.standard.builders.MultiPhraseQueryNodeBuilder
- MultipleTermPositions - Class in org.apache.lucene.index
- MultipleTermPositions(IndexReader, Term[]) - Constructor for class org.apache.lucene.index.MultipleTermPositions
-
Creates a new
MultipleTermPositions
instance. - MultiReader - Class in org.apache.lucene.index
-
An IndexReader which reads multiple indexes, appending their content.
- MultiReader(IndexReader...) - Constructor for class org.apache.lucene.index.MultiReader
-
Construct a MultiReader aggregating the named set of (sub)readers.
- MultiReader(IndexReader[], boolean) - Constructor for class org.apache.lucene.index.MultiReader
-
Construct a MultiReader aggregating the named set of (sub)readers.
- MultiSearcher - Class in org.apache.lucene.search
-
Deprecated.If you are using MultiSearcher over IndexSearchers, please use MultiReader instead; this class does not properly handle certain kinds of queries (see LUCENE-2756).
- MultiSearcher(Searchable...) - Constructor for class org.apache.lucene.search.MultiSearcher
-
Deprecated.Creates a searcher which searches searchers.
- MultiTermQuery - Class in org.apache.lucene.search
-
An abstract
Query
that matches documents containing a subset of terms provided by aFilteredTermEnum
enumeration. - MultiTermQuery() - Constructor for class org.apache.lucene.search.MultiTermQuery
-
Constructs a query matching terms that cannot be represented with a single Term.
- MultiTermQuery.ConstantScoreAutoRewrite - Class in org.apache.lucene.search
-
A rewrite method that tries to pick the best constant-score rewrite method based on term and document counts from the query.
- MultiTermQuery.RewriteMethod - Class in org.apache.lucene.search
-
Abstract class that defines how the query is rewritten.
- MultiTermQuery.TopTermsBoostOnlyBooleanQueryRewrite - Class in org.apache.lucene.search
-
A rewrite method that first translates each term into
BooleanClause.Occur.SHOULD
clause in a BooleanQuery, but the scores are only computed as the boost. - MultiTermQuery.TopTermsScoringBooleanQueryRewrite - Class in org.apache.lucene.search
-
A rewrite method that first translates each term into
BooleanClause.Occur.SHOULD
clause in a BooleanQuery, and keeps the scores as computed by the query. - MultiTermQueryWrapperFilter<Q extends MultiTermQuery> - Class in org.apache.lucene.search
-
A wrapper for
MultiTermQuery
, that exposes its functionality as aFilter
. - MultiTermQueryWrapperFilter(Q) - Constructor for class org.apache.lucene.search.MultiTermQueryWrapperFilter
-
Wrap a
MultiTermQuery
as a Filter. - MultiTermRewriteMethodAttribute - Interface in org.apache.lucene.queryParser.standard.config
-
Deprecated.
- MultiTermRewriteMethodAttributeImpl - Class in org.apache.lucene.queryParser.standard.config
-
Deprecated.
- MultiTermRewriteMethodAttributeImpl() - Constructor for class org.apache.lucene.queryParser.standard.config.MultiTermRewriteMethodAttributeImpl
-
Deprecated.
- MultiTermRewriteMethodProcessor - Class in org.apache.lucene.queryParser.standard.processors
-
This processor instates the default
MultiTermQuery.RewriteMethod
,MultiTermQuery.CONSTANT_SCORE_AUTO_REWRITE_DEFAULT
, for multi-term query nodes. - MultiTermRewriteMethodProcessor() - Constructor for class org.apache.lucene.queryParser.standard.processors.MultiTermRewriteMethodProcessor
- MultiTrie - Class in org.egothor.stemmer
-
The MultiTrie is a Trie of Tries.
- MultiTrie(boolean) - Constructor for class org.egothor.stemmer.MultiTrie
-
Constructor for the MultiTrie object
- MultiTrie(DataInput) - 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(boolean) - Constructor for class org.egothor.stemmer.MultiTrie2
-
Constructor for the MultiTrie2 object
- MultiTrie2(DataInput) - Constructor for class org.egothor.stemmer.MultiTrie2
-
Constructor for the MultiTrie object.
- MUST - org.apache.lucene.search.BooleanClause.Occur
-
Use this operator for clauses that must appear in the matching documents.
- MUST_NOT - org.apache.lucene.search.BooleanClause.Occur
-
Use this operator for clauses that must not appear in the matching documents.
- mustRewriteQuery(SpanQuery) - Method in class org.apache.lucene.search.highlight.WeightedSpanTermExtractor
- MutableFacetResultNode - Class in org.apache.lucene.facet.search.results
-
Mutable implementation for Result of faceted search for a certain taxonomy node.
- MutableFacetResultNode(int, double) - Constructor for class org.apache.lucene.facet.search.results.MutableFacetResultNode
-
Create a Facet Result Node.
- MutableFacetResultNode(int, double, double, CategoryPath, List<FacetResultNode>) - Constructor for class org.apache.lucene.facet.search.results.MutableFacetResultNode
-
Create a Facet Result Node.
- MutableFacetResultNode(FacetResultNode, boolean) - Constructor for class org.apache.lucene.facet.search.results.MutableFacetResultNode
-
Create a mutable facet result node from another result node
N
- 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 - Variable in class org.apache.lucene.document.AbstractField
- name - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
-
Name of the segment.
- name - Variable in class org.apache.lucene.index.FieldInfo
- name - Variable in class org.apache.lucene.index.SegmentInfo
- name() - Method in class org.apache.lucene.document.AbstractField
-
Returns the name of the field as an interned string.
- name() - Method in interface org.apache.lucene.document.Fieldable
-
Returns the name of the field as an interned string.
- name() - Method in class org.apache.lucene.search.function.CustomScoreQuery
-
A short name of this query, used in
CustomScoreQuery.toString(String)
. - NAME_FIELD - Static variable in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
- NamedThreadFactory - Class in org.apache.lucene.util
-
A default
ThreadFactory
implementation that accepts the name prefix of the created threads as a constructor argument. - NamedThreadFactory(String) - Constructor for class org.apache.lucene.util.NamedThreadFactory
-
Creates a new
NamedThreadFactory
instance - NameHashIntCacheLRU - Class in org.apache.lucene.facet.taxonomy.writercache.lru
-
An an LRU cache of mapping from name to int.
- NativeFSLockFactory - Class in org.apache.lucene.store
-
Implements
LockFactory
using native OS file locks. - NativeFSLockFactory() - Constructor for class org.apache.lucene.store.NativeFSLockFactory
-
Create a NativeFSLockFactory instance, with null (unset) lock directory.
- NativeFSLockFactory(File) - Constructor for class org.apache.lucene.store.NativeFSLockFactory
-
Create a NativeFSLockFactory instance, storing lock files into the specified lockDir:
- NativeFSLockFactory(String) - Constructor for class org.apache.lucene.store.NativeFSLockFactory
-
Create a NativeFSLockFactory instance, storing lock files into the specified lockDirName:
- NativePosixUtil - Class in org.apache.lucene.store
- NativePosixUtil() - Constructor for class org.apache.lucene.store.NativePosixUtil
- ncomponents - Variable in class org.apache.lucene.facet.taxonomy.CategoryPath
- NE - org.apache.lucene.queryParser.core.nodes.ParametricQueryNode.CompareOperator
-
Deprecated.
- 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(SpanNearQuery, IndexReader) - Constructor for class org.apache.lucene.search.spans.NearSpansOrdered
- NearSpansOrdered(SpanNearQuery, IndexReader, boolean) - Constructor for class org.apache.lucene.search.spans.NearSpansOrdered
- NearSpansUnordered - Class in org.apache.lucene.search.spans
-
Similar to
NearSpansOrdered
, but for the unordered case. - NearSpansUnordered(SpanNearQuery, IndexReader) - Constructor for class org.apache.lucene.search.spans.NearSpansUnordered
- negate() - Method in class org.apache.lucene.search.FieldValueFilter
-
Returns
true
iff this filter is negated, otherwisefalse
- NEVER - org.apache.lucene.store.MockDirectoryWrapper.Throttling
-
never throttle output
- 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
- 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
- newBooleanClause(Query, BooleanClause.Occur) - Method in class org.apache.lucene.queryParser.QueryParser
-
Builds a new BooleanClause instance
- newBooleanQuery(boolean) - Method in class org.apache.lucene.queryParser.QueryParser
-
Builds a new BooleanQuery instance
- newBuffer(byte[]) - Method in class org.apache.lucene.store.BufferedIndexInput
- newBuffer(byte[]) - Method in class org.apache.lucene.store.NIOFSDirectory.NIOFSIndexInput
- newBuffer(int) - Method in class org.apache.lucene.store.RAMFile
-
Expert: allocate a new buffer.
- newByteRange(String, Byte, Byte, boolean, boolean) - Static method in class org.apache.lucene.search.FieldCacheRangeFilter
-
Creates a numeric range filter using
FieldCache.getBytes(IndexReader,String)
. - newByteRange(String, FieldCache.ByteParser, Byte, Byte, boolean, boolean) - Static method in class org.apache.lucene.search.FieldCacheRangeFilter
-
Creates a numeric range filter using
FieldCache.getBytes(IndexReader,String,FieldCache.ByteParser)
. - newCharacterBuffer(int) - Static method in class org.apache.lucene.util.CharacterUtils
-
Creates a new
CharacterUtils.CharacterBuffer
and allocates achar[]
of the given bufferSize. - 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
- newColumn - Static variable in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.TokenPositioner
-
Deprecated.
- newComparator(String, int, int, boolean) - Method in class org.apache.lucene.search.FieldComparatorSource
-
Creates a comparator for the field in the given index.
- newComparator(String, int, int, boolean) - Method in class org.apache.lucene.spatial.tier.DistanceFieldComparatorSource
-
Deprecated.
- newConcurrentHashMap() - Static method in class org.apache.lucene.util.WeakIdentityMap
-
Creates a new
WeakIdentityMap
based on aConcurrentHashMap
. - newCondition() - Method in class org.apache.lucene.util.DummyConcurrentLock
- 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.
- 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, 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.
- newDirectory(Directory) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Returns a new Directory instance, with contents copied from the provided directory.
- newDoubleRange(String, int, Double, Double, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeFilter
-
Factory that creates a
NumericRangeFilter
, that filters adouble
range using the givenprecisionStep
. - newDoubleRange(String, int, Double, Double, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeQuery
-
Factory that creates a
NumericRangeQuery
, that queries adouble
range using the givenprecisionStep
. - newDoubleRange(String, Double, Double, boolean, boolean) - Static method in class org.apache.lucene.search.FieldCacheRangeFilter
-
Creates a numeric range filter using
FieldCache.getDoubles(IndexReader,String)
. - newDoubleRange(String, Double, Double, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeFilter
-
Factory that creates a
NumericRangeFilter
, that queries adouble
range using the defaultprecisionStep
NumericUtils.PRECISION_STEP_DEFAULT
(4). - newDoubleRange(String, Double, Double, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeQuery
-
Factory that creates a
NumericRangeQuery
, that queries adouble
range using the defaultprecisionStep
NumericUtils.PRECISION_STEP_DEFAULT
(4). - newDoubleRange(String, FieldCache.DoubleParser, Double, Double, boolean, boolean) - Static method in class org.apache.lucene.search.FieldCacheRangeFilter
-
Creates a numeric range filter using
FieldCache.getDoubles(IndexReader,String,FieldCache.DoubleParser)
. - newField(String, String, Field.Index) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Returns a new field instance.
- newField(String, String, Field.Store, Field.Index) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Returns a new field instance.
- newField(String, String, Field.Store, Field.Index, Field.TermVector) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Returns a new Field instance.
- newField(Random, String, String, Field.Index) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Returns a new field instance, using the specified random.
- newField(Random, String, String, Field.Store, Field.Index) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Returns a new field instance, using the specified random.
- newField(Random, String, String, Field.Store, Field.Index, Field.TermVector) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Returns a new field instance, using the specified random.
- newFloatRange(String, int, Float, Float, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeFilter
-
Factory that creates a
NumericRangeFilter
, that filters afloat
range using the givenprecisionStep
. - newFloatRange(String, int, Float, Float, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeQuery
- newFloatRange(String, Float, Float, boolean, boolean) - Static method in class org.apache.lucene.search.FieldCacheRangeFilter
-
Creates a numeric range filter using
FieldCache.getFloats(IndexReader,String)
. - newFloatRange(String, Float, Float, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeFilter
-
Factory that creates a
NumericRangeFilter
, that queries afloat
range using the defaultprecisionStep
NumericUtils.PRECISION_STEP_DEFAULT
(4). - newFloatRange(String, Float, Float, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeQuery
-
Factory that creates a
NumericRangeQuery
, that queries afloat
range using the defaultprecisionStep
NumericUtils.PRECISION_STEP_DEFAULT
(4). - newFloatRange(String, FieldCache.FloatParser, Float, Float, boolean, boolean) - Static method in class org.apache.lucene.search.FieldCacheRangeFilter
-
Creates a numeric range filter using
FieldCache.getFloats(IndexReader,String,FieldCache.FloatParser)
. - newFromDelegate(IndexOutput) - Method in class org.apache.lucene.util.ThrottledIndexOutput
- newFSDirectory(File) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Returns a new FSDirectory instance over the given file, which must be a folder.
- newFSDirectory(File, LockFactory) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Returns a new FSDirectory instance over the given file, which must be a folder.
- newFSDirectory(Class<? extends FSDirectory>, File) - Static method in class org.apache.lucene.util.CommandLineUtil
-
Creates a new specific FSDirectory instance
- newFSDirectory(String, File) - Static method in class org.apache.lucene.util.CommandLineUtil
-
Creates a specific FSDirectory instance starting from its class name
- newFuzzyQuery(Term, float, int) - Method in class org.apache.lucene.queryParser.QueryParser
-
Builds a new FuzzyQuery instance
- newHashMap() - Static method in class org.apache.lucene.util.WeakIdentityMap
-
Creates a new
WeakIdentityMap
based on a non-synchronizedHashMap
. - newIndexWriterConfig(Random, Version, Analyzer) - Static method in class org.apache.lucene.util.LuceneTestCase
-
create a new index writer config with random defaults using the specified random
- newIndexWriterConfig(Version, Analyzer) - Static method in class org.apache.lucene.util.LuceneTestCase
-
create a new index writer config with random defaults
- newInstance() - Static method in class org.apache.lucene.queryParser.core.config.ConfigurationKey
-
Creates a new instance.
- newInstance() - Method in class org.apache.lucene.util.RollingBuffer
- newIntRange(String, int, Integer, Integer, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeFilter
- newIntRange(String, int, Integer, Integer, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeQuery
- newIntRange(String, Integer, Integer, boolean, boolean) - Static method in class org.apache.lucene.search.FieldCacheRangeFilter
-
Creates a numeric range filter using
FieldCache.getInts(IndexReader,String)
. - newIntRange(String, Integer, Integer, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeFilter
-
Factory that creates a
NumericRangeFilter
, that queries aint
range using the defaultprecisionStep
NumericUtils.PRECISION_STEP_DEFAULT
(4). - newIntRange(String, Integer, Integer, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeQuery
-
Factory that creates a
NumericRangeQuery
, that queries aint
range using the defaultprecisionStep
NumericUtils.PRECISION_STEP_DEFAULT
(4). - newIntRange(String, FieldCache.IntParser, Integer, Integer, boolean, boolean) - Static method in class org.apache.lucene.search.FieldCacheRangeFilter
-
Creates a numeric range filter using
FieldCache.getInts(IndexReader,String,FieldCache.IntParser)
. - newline - Static variable in class org.apache.lucene.benchmark.byTask.tasks.ReportTask
- 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(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
- newLogMergePolicy(Random) - Static method in class org.apache.lucene.util.LuceneTestCase
- newLongRange(String, int, Long, Long, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeFilter
- newLongRange(String, int, Long, Long, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeQuery
- newLongRange(String, Long, Long, boolean, boolean) - Static method in class org.apache.lucene.search.FieldCacheRangeFilter
-
Creates a numeric range filter using
FieldCache.getLongs(IndexReader,String)
. - newLongRange(String, Long, Long, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeFilter
-
Factory that creates a
NumericRangeFilter
, that queries along
range using the defaultprecisionStep
NumericUtils.PRECISION_STEP_DEFAULT
(4). - newLongRange(String, Long, Long, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeQuery
-
Factory that creates a
NumericRangeQuery
, that queries along
range using the defaultprecisionStep
NumericUtils.PRECISION_STEP_DEFAULT
(4). - newLongRange(String, FieldCache.LongParser, Long, Long, boolean, boolean) - Static method in class org.apache.lucene.search.FieldCacheRangeFilter
-
Creates a numeric range filter using
FieldCache.getLongs(IndexReader,String,FieldCache.LongParser)
. - newMatchAllDocsQuery() - Method in class org.apache.lucene.queryParser.QueryParser
-
Builds a new MatchAllDocsQuery instance
- newMultiPhraseQuery() - Method in class org.apache.lucene.queryParser.QueryParser
-
Builds a new MultiPhraseQuery instance
- newPair(A, B) - Method in class org.apache.lucene.util.fst.PairOutputs
-
Create a new Pair
- newPhraseQuery() - Method in class org.apache.lucene.queryParser.QueryParser
-
Builds a new PhraseQuery instance
- 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(Term) - Method in class org.apache.lucene.queryParser.QueryParser
-
Builds a new PrefixQuery instance
- newRAMFile() - Method in class org.apache.lucene.store.RAMDirectory
-
Returns a new
RAMFile
for storing data. - newRangeQuery(String, String, String, boolean) - Method in class org.apache.lucene.queryParser.complexPhrase.ComplexPhraseQueryParser
- newRangeQuery(String, String, String, boolean) - Method in class org.apache.lucene.queryParser.QueryParser
-
Builds a new TermRangeQuery instance
- 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
- newRow - Static variable in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.TokenPositioner
-
Deprecated.
- newSearcher(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.
- 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()
- NewShingleAnalyzerTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Task to support benchmarking ShingleFilter / ShingleAnalyzerWrapper
- NewShingleAnalyzerTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.NewShingleAnalyzerTask
- newShortRange(String, Short, Short, boolean, boolean) - Static method in class org.apache.lucene.search.FieldCacheRangeFilter
-
Creates a numeric range filter using
FieldCache.getShorts(IndexReader,String)
. - newShortRange(String, FieldCache.ShortParser, Short, Short, boolean, boolean) - Static method in class org.apache.lucene.search.FieldCacheRangeFilter
-
Creates a numeric range filter using
FieldCache.getShorts(IndexReader,String,FieldCache.ShortParser)
. - newSinkTokenStream() - Method in class org.apache.lucene.analysis.TeeSinkTokenFilter
-
Returns a new
TeeSinkTokenFilter.SinkTokenStream
that receives all tokens consumed by this stream. - newSinkTokenStream(TeeSinkTokenFilter.SinkFilter) - Method in class org.apache.lucene.analysis.TeeSinkTokenFilter
-
Returns a new
TeeSinkTokenFilter.SinkTokenStream
that receives all tokens consumed by this stream that pass the supplied filter. - newSlice(int) - Method in class org.apache.lucene.util.ByteBlockPool
- newSpanTermQuery(Term) - Method in class org.apache.lucene.queryParser.surround.query.BasicQueryFactory
- newString(int[], int, int) - Static method in class org.apache.lucene.util.UnicodeUtil
-
Cover JDK 1.5 API.
- newStringRange(String, String, String, boolean, boolean) - Static method in class org.apache.lucene.search.FieldCacheRangeFilter
-
Creates a string range filter using
FieldCache.getStringIndex(org.apache.lucene.index.IndexReader, java.lang.String)
. - newTermExtractor(String) - Method in class org.apache.lucene.search.highlight.QueryScorer
- newTermQuery(Term) - Method in class org.apache.lucene.queryParser.complexPhrase.ComplexPhraseQueryParser
- newTermQuery(Term) - Method in class org.apache.lucene.queryParser.QueryParser
-
Builds a new TermQuery instance
- newTermQuery(Term) - Method in class org.apache.lucene.queryParser.surround.query.BasicQueryFactory
- 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) - Static method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.Token
- newToken(int) - Static method in class org.apache.lucene.queryParser.standard.parser.Token
- newToken(int) - Static method in class org.apache.lucene.queryParser.surround.parser.Token
- newToken(int) - Static method in class org.apache.lucene.queryParser.Token
- newToken(int, String) - Static method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.Token
-
Returns a new Token object, by default.
- newToken(int, String) - Static method in class org.apache.lucene.queryParser.standard.parser.Token
-
Returns a new Token object, by default.
- newToken(int, String) - Static method in class org.apache.lucene.queryParser.surround.parser.Token
-
Returns a new Token object, by default.
- newToken(int, String) - Static method in class org.apache.lucene.queryParser.Token
-
Returns a new Token object, by default.
- 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
- newWildcardQuery(Term) - Method in class org.apache.lucene.queryParser.QueryParser
-
Builds a new WildcardQuery instance
- 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 - Variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.Token
-
A reference to the next regular (non-special) token from the input stream.
- next - Variable in class org.apache.lucene.queryParser.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.queryParser.Token
-
A reference to the next regular (non-special) token from the input stream.
- next() - Method in class org.apache.lucene.analysis.CharArrayMap.EntryIterator
-
use nextCharArray() + currentValue() for better efficiency.
- next() - Method in class org.apache.lucene.analysis.CharArraySet.CharArraySetIterator
-
Deprecated.Returns the next String, as a Set
would... - next() - Method in class org.apache.lucene.analysis.icu.segmentation.LaoBreakIterator
- 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 interface org.apache.lucene.facet.search.ScoredDocIDsIterator
-
Iterate to the next document/score pair.
- next() - Method in class org.apache.lucene.index.AbstractAllTermDocs
- next() - Method in class org.apache.lucene.index.FilterIndexReader.FilterTermDocs
- next() - Method in class org.apache.lucene.index.FilterIndexReader.FilterTermEnum
- next() - Method in class org.apache.lucene.index.MultipleTermPositions
- next() - Method in interface org.apache.lucene.index.TermDocs
-
Moves to the next pair in the enumeration.
- next() - Method in class org.apache.lucene.index.TermEnum
-
Increments the enumeration to the next element.
- next() - Method in class org.apache.lucene.search.FilteredTermEnum
-
Increments the enumeration to the next element.
- next() - Method in class org.apache.lucene.search.spans.NearSpansOrdered
- next() - Method in class org.apache.lucene.search.spans.NearSpansUnordered
- next() - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery.PositionCheckSpan
- next() - Method in class org.apache.lucene.search.spans.Spans
-
Move to the next match, returning true iff any such exists.
- next() - Method in class org.apache.lucene.search.spans.TermSpans
- next() - Method in class org.apache.lucene.search.spell.TermFreqIterator.TermFreqIteratorWrapper
- next() - Method in class org.apache.lucene.search.suggest.BufferingTermFreqIteratorWrapper
- next() - Method in class org.apache.lucene.search.suggest.SortedTermFreqIteratorWrapper
- next() - Method in class org.apache.lucene.search.suggest.UnsortedTermFreqIteratorWrapper
- next() - Method in class org.apache.lucene.store.instantiated.InstantiatedTermDocs
- next() - Method in class org.apache.lucene.store.instantiated.InstantiatedTermEnum
-
Increments the enumeration to the next element.
- next() - Method in class org.apache.lucene.store.instantiated.InstantiatedTermPositions
-
Moves to the next pair in the enumeration.
- next() - Method in interface org.apache.lucene.util.BytesRefIterator
-
Increments the iteration to the next
BytesRef
in the iterator. - next() - Method in interface org.apache.lucene.util.collections.DoubleIterator
- next() - Method in interface org.apache.lucene.util.collections.FloatIterator
- next() - Method in interface org.apache.lucene.util.collections.IntIterator
- next() - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
- next() - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
- next(int) - Method in class org.apache.lucene.analysis.icu.segmentation.LaoBreakIterator
- next(int) - Method in class org.apache.lucene.util.SmartRandom
- nextBuffer() - Method in class org.apache.lucene.util.ByteBlockPool
- nextCategory() - Method in interface org.apache.lucene.facet.search.CategoryListIterator
-
Returns the next category for the current document that is set through
CategoryListIterator.skipTo(int)
, or a number higher thanInteger.MAX_VALUE
. - nextCategory() - Method in class org.apache.lucene.facet.search.PayloadIntDecodingIterator
- nextCategory() - Method in class org.apache.lucene.facet.util.MultiCategoryListIterator
-
Return a value larger than
Integer.MAX_VALUE
only if all iterators are exhausted - nextCharArray() - Method in class org.apache.lucene.analysis.CharArraySet.CharArraySetIterator
-
Deprecated.do not modify the returned char[]
- nextCharBuf - Variable in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
- nextCharInd - Variable in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
- nextDoc() - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantScorer
- 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.ScoreCachingWrappingScorer
- nextDoc() - Method in class org.apache.lucene.search.spans.SpanScorer
- nextDoc() - Method in class org.apache.lucene.util.LineFileDocs
-
Note: Document instance is re-used per-thread
- nextDoc() - Method in class org.apache.lucene.util.OpenBitSetIterator
-
alternate shift implementations // 32 bit shifts, but a long shift needed at the end private void shift2() { int y = (int)word; if (y==0) {wordShift +=32; y = (int)(word >>>32); } if ((y & 0x0000FFFF) == 0) { wordShift +=16; y>>>=16; } if ((y & 0x000000FF) == 0) { wordShift +=8; y>>>=8; } indexArray = bitlist[y & 0xff]; word >>>= (wordShift +1); } private void shift3() { int lower = (int)word; int lowByte = lower & 0xff; if (lowByte != 0) { indexArray=bitlist[lowByte]; return; } shift(); }
- nextDocBase - Variable in class org.apache.lucene.spatial.tier.DistanceFilter
-
Deprecated.
- 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
- 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
- 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
- nextLevelArray - Static variable in class org.apache.lucene.util.ByteBlockPool
- nextPosition() - Method in class org.apache.lucene.index.FilterIndexReader.FilterTermPositions
- nextPosition() - Method in class org.apache.lucene.index.MultipleTermPositions
- nextPosition() - Method in interface org.apache.lucene.index.TermPositions
-
Returns next position in the current document.
- nextPosition() - Method in class org.apache.lucene.store.instantiated.InstantiatedTermPositions
-
Returns next position in the current document.
- nextQnum() - Method in class org.apache.lucene.benchmark.byTask.feeds.AbstractQueryMaker
- nextRead - Variable in class org.apache.lucene.analysis.LookaheadTokenFilter.Position
- nextSetBit(int) - Method in class org.apache.lucene.util.FixedBitSet
-
Returns the index of the first set bit starting at the index specified.
- nextSetBit(int) - Method in class org.apache.lucene.util.OpenBitSet
-
Returns the index of the first set bit starting at the index specified.
- nextSetBit(long) - Method in class org.apache.lucene.util.OpenBitSet
-
Returns the index of the first set bit starting at the index specified.
- nextState() - Method in class org.apache.lucene.analysis.LookaheadTokenFilter.Position
- 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.
- NGRAM - Static variable in class org.apache.lucene.analysis.ja.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() - Constructor for class org.apache.lucene.search.spell.NGramDistance
-
Creates an N-Gram distance measure using n-grams of size 2.
- NGramDistance(int) - Constructor for class org.apache.lucene.search.spell.NGramDistance
-
Creates an N-Gram distance measure using n-grams of the specified size.
- NGramPhraseQuery - Class in org.apache.lucene.search
-
This is a
PhraseQuery
which is optimized for n-gram phrase query. - NGramPhraseQuery(int) - 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) - Constructor for class org.apache.lucene.analysis.ngram.NGramTokenFilter
-
Creates NGramTokenFilter with default min and max n-grams.
- NGramTokenFilter(TokenStream, int, int) - Constructor for class org.apache.lucene.analysis.ngram.NGramTokenFilter
-
Creates NGramTokenFilter with given min and max n-grams.
- NGramTokenizer - Class in org.apache.lucene.analysis.ngram
-
Tokenizes the input into n-grams of the given size(s).
- NGramTokenizer(Reader) - Constructor for class org.apache.lucene.analysis.ngram.NGramTokenizer
-
Creates NGramTokenizer with default min and max n-grams.
- NGramTokenizer(Reader, int, int) - Constructor for class org.apache.lucene.analysis.ngram.NGramTokenizer
-
Creates NGramTokenizer with given min and max n-grams.
- NGramTokenizer(AttributeSource.AttributeFactory, Reader, int, int) - Constructor for class org.apache.lucene.analysis.ngram.NGramTokenizer
-
Creates NGramTokenizer with given min and max n-grams.
- NGramTokenizer(AttributeSource, Reader, int, int) - Constructor for class org.apache.lucene.analysis.ngram.NGramTokenizer
-
Creates NGramTokenizer with given min and max n-grams.
- 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(File) - Constructor for class org.apache.lucene.store.NIOFSDirectory
-
Create a new NIOFSDirectory for the named location and
NativeFSLockFactory
. - NIOFSDirectory(File, LockFactory) - Constructor for class org.apache.lucene.store.NIOFSDirectory
-
Create a new NIOFSDirectory for the named location.
- NIOFSDirectory.NIOFSIndexInput - Class in org.apache.lucene.store
- NIOFSIndexInput(File, int, int) - Constructor for class org.apache.lucene.store.NIOFSDirectory.NIOFSIndexInput
- NLS - Class in org.apache.lucene.messages
-
Deprecated.Will be moved to a private package inside flexible query parser (Lucene 4.0).
- NLS() - Constructor for class org.apache.lucene.messages.NLS
-
Deprecated.
- NLSException - Interface in org.apache.lucene.messages
-
Deprecated.Will be moved to a private package inside flexible query parser (Lucene 4.0).
- nlz(long) - Static method in class org.apache.lucene.util.BitUtil
-
Returns the number of leading zero bits.
- nlzTable - Static variable in class org.apache.lucene.util.BitUtil
-
table of number of leading zeros in a byte
- NO - org.apache.lucene.document.Field.Index
-
Do not index the field value.
- NO - org.apache.lucene.document.Field.Store
-
Do not store the field value in the index.
- NO - org.apache.lucene.document.Field.TermVector
-
Do not store term vectors.
- NO - org.apache.lucene.search.spans.SpanPositionCheckQuery.AcceptStatus
- NO_AND_ADVANCE - org.apache.lucene.search.spans.SpanPositionCheckQuery.AcceptStatus
- NO_ASSOCIATION - Static variable in class org.apache.lucene.facet.enhancements.association.AssociationsPayloadIterator
-
The long-special-value returned for ordinals which have no associated int value.
- NO_COMPOUND_FILES - Static variable in class org.apache.lucene.index.NoMergePolicy
-
A singleton
NoMergePolicy
which indicates the index does not use compound files. - NO_DOC_ID_PROVIDED - Static variable in class org.apache.lucene.search.Similarity
- NO_LOAD - org.apache.lucene.document.FieldSelectorResult
-
Do not load the
Field
. - NO_MORE_DOCS - Static variable in class org.apache.lucene.search.DocIdSetIterator
-
When returned by
DocIdSetIterator.nextDoc()
,DocIdSetIterator.advance(int)
andDocIdSetIterator.docID()
it means there are no more docs in the iterator. - NO_OUTPUT - Variable in class org.apache.lucene.analysis.ja.dict.TokenInfoFST
- noBreak - Variable in class org.apache.lucene.analysis.compound.hyphenation.Hyphen
- noCFSRatio - Variable in class org.apache.lucene.index.LogMergePolicy
- NoChildOptimizationQueryNodeProcessor - Class in org.apache.lucene.queryParser.core.processors
-
A
NoChildOptimizationQueryNodeProcessor
removes every BooleanQueryNode, BoostQueryNode, TokenizedPhraseQueryNode or ModifierQueryNode that do not have a valid children. - NoChildOptimizationQueryNodeProcessor() - Constructor for class org.apache.lucene.queryParser.core.processors.NoChildOptimizationQueryNodeProcessor
- NODE_ACTION_NOT_SUPPORTED - Static variable in class org.apache.lucene.queryParser.core.messages.QueryParserMessages
- nodeCount - Variable in class org.apache.lucene.util.fst.FST
- NoDeletionPolicy - Class in org.apache.lucene.index
-
An
IndexDeletionPolicy
which keeps all index commits around, never deleting them. - NoLockFactory - Class in org.apache.lucene.store
-
Use this
LockFactory
to disable locking entirely. - NoLockFactory() - Constructor for class org.apache.lucene.store.NoLockFactory
-
Deprecated.This constructor was not intended to be public and should not be used. It will be made private in Lucene 4.0
- NoMergePolicy - Class in org.apache.lucene.index
-
A
MergePolicy
which never returns merges to execute (hence it's name). - NoMergeScheduler - Class in org.apache.lucene.index
-
A
MergeScheduler
which never executes any merges. - 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
- NON_STORE_INDEX_EXTENSIONS - Static variable in class org.apache.lucene.index.IndexFileNames
- NON_WORD_PATTERN - Static variable in class org.apache.lucene.analysis.miscellaneous.PatternAnalyzer
-
"\\W+"
; Divides text at non-letters (NOT Character.isLetter(c)) - None - org.apache.lucene.search.join.ToParentBlockJoinQuery.ScoreMode
-
Do no scoring.
- NOnesIntDecoder - Class in org.apache.lucene.util.encoding
-
Decodes data which was encoded by
NOnesIntEncoder
. - NOnesIntDecoder(int) - Constructor for class org.apache.lucene.util.encoding.NOnesIntDecoder
-
Constructs a decoder with a given N (Number of consecutive '1's which are translated into a single target value '2'.
- NOnesIntEncoder - Class in org.apache.lucene.util.encoding
-
A variation of
FourFlagsIntEncoder
which translates the data as follows: Values ≥ 2 are trnalsated tovalue+1
(2 ⇒ 3, 3 ⇒ 4 and so forth). - NOnesIntEncoder(int) - Constructor for class org.apache.lucene.util.encoding.NOnesIntEncoder
-
Constructs an encoder with a given value of N (N: Number of consecutive '1's to be translated into single target value '2').
- NonTopLevelOrdinalPolicy - Class in org.apache.lucene.facet.index.categorypolicy
-
Filter out any "top level" category ordinals.
- NonTopLevelOrdinalPolicy() - Constructor for class org.apache.lucene.facet.index.categorypolicy.NonTopLevelOrdinalPolicy
-
Constructs a new non-top-level-ordinal-filter.
- NonTopLevelPathPolicy - Class in org.apache.lucene.facet.index.categorypolicy
-
This class filters our the ROOT category, and it's direct descendants.
- NonTopLevelPathPolicy() - Constructor for class org.apache.lucene.facet.index.categorypolicy.NonTopLevelPathPolicy
- NOON - Static variable in class org.apache.lucene.analysis.ar.ArabicStemmer
- 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() - Method in class org.apache.lucene.spatial.geometry.shape.Vector2D
-
Deprecated.
- NORMAL - org.apache.lucene.analysis.ja.JapaneseTokenizer.Mode
-
Ordinary segmentation: no decomposition for compounds,
- NORMAL - org.apache.lucene.queryParser.core.parser.EscapeQuerySyntax.Type
- NORMAL - Static variable in class org.apache.lucene.store.NativePosixUtil
- normalize() - Method in class org.apache.lucene.spatial.geometry.FixedLatLng
-
Deprecated.
- normalize() - Method in class org.apache.lucene.spatial.geometry.FloatLatLng
-
Deprecated.
- normalize() - Method in class org.apache.lucene.spatial.geometry.LatLng
-
Deprecated.
- normalize(char) - Method in class org.apache.lucene.analysis.CharTokenizer
-
Deprecated.use
CharTokenizer.normalize(int)
instead. This method will be removed in Lucene 4.0. - normalize(char[], int) - Method in class org.apache.lucene.analysis.ar.ArabicNormalizer
-
Normalize an input buffer of Arabic text
- normalize(char[], int) - Method in class org.apache.lucene.analysis.fa.PersianNormalizer
-
Normalize an input buffer of Persian text
- normalize(char[], int) - Method in class org.apache.lucene.analysis.hi.HindiNormalizer
-
Normalize an input buffer of Hindi text
- normalize(char[], int) - Method in class org.apache.lucene.analysis.in.IndicNormalizer
-
Normalizes input text, and returns the new length.
- normalize(float) - Method in class org.apache.lucene.search.BooleanQuery.BooleanWeight
- normalize(float) - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantWeight
- normalize(float) - Method in class org.apache.lucene.search.DisjunctionMaxQuery.DisjunctionMaxWeight
-
Apply the computed normalization factor to our subqueries
- normalize(float) - Method in class org.apache.lucene.search.spans.SpanWeight
- normalize(float) - Method in class org.apache.lucene.search.Weight
-
Assigns the query normalization factor to this.
- normalize(int) - Method in class org.apache.lucene.analysis.CharTokenizer
-
Called on each token character to normalize it before it is added to the token.
- normalize(int) - Method in class org.apache.lucene.analysis.LowerCaseTokenizer
-
Converts char to lower case
Character.toLowerCase(int)
. - normalize(int) - Method in class org.apache.lucene.analysis.MockTokenizer
- NormalizeCharMap - Class in org.apache.lucene.analysis
-
Holds a map of String input to String output, to be used with
MappingCharFilter
. - NormalizeCharMap() - Constructor for class org.apache.lucene.analysis.NormalizeCharMap
- normalizeException(ArrayList<?>) - Method in class org.apache.lucene.analysis.compound.hyphenation.PatternParser
- normLat(double[]) - Static method in class org.apache.lucene.spatial.DistanceUtils
-
Deprecated.
- normLng(double[]) - Static method in class org.apache.lucene.spatial.DistanceUtils
-
Deprecated.Returns a normalized Lng rectangle shape for the bounding box
- norms - Variable in class org.apache.lucene.search.spans.SpanScorer
- norms(String) - Method in class org.apache.lucene.index.FilterIndexReader
- norms(String) - Method in class org.apache.lucene.index.IndexReader
-
Returns the byte-encoded normalization factor for the named field of every document.
- norms(String) - Method in class org.apache.lucene.index.MultiReader
- norms(String) - Method in class org.apache.lucene.index.ParallelReader
- norms(String) - Method in class org.apache.lucene.index.SegmentReader
- norms(String) - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexReader
-
Deprecated.never ever touch these values.
- norms(String, byte[], int) - Method in class org.apache.lucene.index.FilterIndexReader
- norms(String, byte[], int) - Method in class org.apache.lucene.index.IndexReader
-
Reads the byte-encoded normalization factor for the named field of every document.
- norms(String, byte[], int) - Method in class org.apache.lucene.index.MultiReader
- norms(String, byte[], int) - Method in class org.apache.lucene.index.ParallelReader
- norms(String, byte[], int) - Method in class org.apache.lucene.index.SegmentReader
-
Read norms into a pre-allocated array.
- norms(String, byte[], int) - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexReader
-
Deprecated.
- NORMS_EXTENSION - Static variable in class org.apache.lucene.index.IndexFileNames
-
Extension of norms file
- normSqr() - Method in class org.apache.lucene.spatial.geometry.shape.Vector2D
-
Deprecated.Vector length (magnitude) squared
- NorwegianAnalyzer - Class in org.apache.lucene.analysis.no
-
Analyzer
for Norwegian. - NorwegianAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.no.NorwegianAnalyzer
-
Builds an analyzer with the default stop words:
NorwegianAnalyzer.DEFAULT_STOPWORD_FILE
. - NorwegianAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.no.NorwegianAnalyzer
-
Builds an analyzer with the given stop words.
- NorwegianAnalyzer(Version, Set<?>, Set<?>) - 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
-
A
TokenFilter
that appliesNorwegianLightStemmer
to stem Norwegian words. - NorwegianLightStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.no.NorwegianLightStemFilter
- NorwegianLightStemmer - Class in org.apache.lucene.analysis.no
-
Light Stemmer for Norwegian.
- NorwegianLightStemmer() - Constructor for class org.apache.lucene.analysis.no.NorwegianLightStemmer
- NorwegianMinimalStemFilter - Class in org.apache.lucene.analysis.no
-
A
TokenFilter
that appliesNorwegianMinimalStemmer
to stem Norwegian words. - NorwegianMinimalStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.no.NorwegianMinimalStemFilter
- NorwegianMinimalStemmer - Class in org.apache.lucene.analysis.no
-
Minimal Stemmer for Norwegian bokmål (no-nb)
- NorwegianMinimalStemmer() - Constructor for class org.apache.lucene.analysis.no.NorwegianMinimalStemmer
- NorwegianStemmer - Class in org.tartarus.snowball.ext
-
Generated class implementing code defined by a snowball script.
- NorwegianStemmer() - Constructor for class org.tartarus.snowball.ext.NorwegianStemmer
- NoSuchDirectoryException - Exception in org.apache.lucene.store
-
This exception is thrown when you try to list a non-existent directory.
- NoSuchDirectoryException(String) - Constructor for exception org.apache.lucene.store.NoSuchDirectoryException
- NOT - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
-
RegularExpression Id.
- NOT - Static variable in interface org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- NOT - Static variable in interface org.apache.lucene.queryParser.surround.parser.QueryParserConstants
-
RegularExpression Id.
- NOT_ANALYZED - org.apache.lucene.document.Field.Index
-
Index the field's value without using an Analyzer, so it can be searched.
- NOT_ANALYZED_NO_NORMS - org.apache.lucene.document.Field.Index
-
Expert: Index the field's value without an Analyzer, and also disable the indexing of norms.
- NoTokenFoundQueryNode - Class in org.apache.lucene.queryParser.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.core.nodes.NoTokenFoundQueryNode
- NotQuery - Class in org.apache.lucene.queryParser.surround.query
- NotQuery(List<SrndQuery>, String) - Constructor for class org.apache.lucene.queryParser.surround.query.NotQuery
- NotQuery() - Method in class org.apache.lucene.queryParser.surround.parser.QueryParser
- 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
- NRTManager - Class in org.apache.lucene.search
-
Utility class to manage sharing near-real-time searchers across multiple searching thread.
- NRTManager(NRTManager.TrackingIndexWriter, SearcherFactory) - Constructor for class org.apache.lucene.search.NRTManager
-
Create new NRTManager.
- NRTManager(NRTManager.TrackingIndexWriter, SearcherFactory, boolean) - Constructor for class org.apache.lucene.search.NRTManager
-
Expert: just like
NRTManager(TrackingIndexWriter,SearcherFactory)
, but you can also specify whether each reopened searcher must apply deletes. - NRTManager.TrackingIndexWriter - Class in org.apache.lucene.search
-
Class that tracks changes to a delegated IndexWriter.
- NRTManager.WaitingListener - Interface in org.apache.lucene.search
-
NRTManager invokes this interface to notify it when a caller is waiting for a specific generation searcher to be visible.
- NRTManagerReopenThread - Class in org.apache.lucene.search
-
Utility class that runs a reopen thread to periodically reopen the NRT searchers in the provided
NRTManager
. - NRTManagerReopenThread(NRTManager, double, double) - Constructor for class org.apache.lucene.search.NRTManagerReopenThread
-
Create NRTManagerReopenThread, to periodically reopen the NRT searcher.
- ntz(int) - Static method in class org.apache.lucene.util.BitUtil
-
Returns number of trailing zeros in a 32 bit int value.
- ntz(long) - Static method in class org.apache.lucene.util.BitUtil
-
Returns number of trailing zeros in a 64 bit long value.
- ntz2(long) - Static method in class org.apache.lucene.util.BitUtil
-
returns 0 based index of first set bit (only works for x!=0)
This is an alternate implementation of ntz() - ntz3(long) - Static method in class org.apache.lucene.util.BitUtil
-
returns 0 based index of first set bit
This is an alternate implementation of ntz() - ntzTable - Static variable in class org.apache.lucene.util.BitUtil
-
table of number of trailing zeros in a byte
- 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
- NUM - Static variable in class org.apache.lucene.analysis.standard.ClassicTokenizer
- NUM - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
- NUM - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
- NUM - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
RegularExpression Id.
- 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
- numBadSegments - Variable in class org.apache.lucene.index.CheckIndex.Status
-
How many bad segments were found.
- number - Variable in class org.apache.lucene.index.FieldInfo
- NUMBER - org.apache.lucene.queryParser.core.nodes.ProximityQueryNode.Type
- NUMBER - Static variable in class org.apache.lucene.analysis.cn.smart.WordType
-
ASCII Alphanumeric
- NUMBER - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
-
RegularExpression Id.
- NUMBER - Static variable in interface org.apache.lucene.queryParser.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.core.messages.QueryParserMessages
- NumberDateFormat - Class in org.apache.lucene.queryParser.standard.config
- NumberDateFormat(DateFormat) - Constructor for class org.apache.lucene.queryParser.standard.config.NumberDateFormat
-
Constructs a
NumberDateFormat
object using the givenDateFormat
. - NumberTools - Class in org.apache.lucene.document
-
Deprecated.For new indexes use
NumericUtils
instead, which provides a sortable binary representation (prefix encoded) of numeric values. To index and efficiently query numeric values useNumericField
andNumericRangeQuery
. This class is included for use with existing indices and will be removed in a future release (possibly Lucene 4.0). - NumberTools() - Constructor for class org.apache.lucene.document.NumberTools
-
Deprecated.
- numBufferedBlocks() - Method in class org.apache.lucene.util.RecyclingByteBlockAllocator
- numBuffers() - Method in class org.apache.lucene.store.RAMFile
- numDataNodes() - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
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
-
Returns the number of nodes in the subtrie below and including the starting node.
- numDeleted - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
-
Number of deleted documents.
- numDeletedDocs() - Method in class org.apache.lucene.index.IndexReader
-
Returns the number of deleted documents.
- numDeletedDocs(SegmentInfo) - Method in class org.apache.lucene.index.IndexWriter
-
Obtain the number of deleted docs for a pooled reader.
- numDocIds - Variable in class org.apache.lucene.facet.search.ScoredDocIdCollector
- numDocs - Variable in class org.apache.lucene.index.SegmentWriteState
- numDocs() - Method in class org.apache.lucene.index.FilterIndexReader
- numDocs() - Method in class org.apache.lucene.index.IndexReader
-
Returns the number of documents in this index.
- numDocs() - Method in class org.apache.lucene.index.IndexWriter
-
Returns total number of docs in this index, including docs not yet flushed (still in the RAM buffer), and including deletions.
- numDocs() - Method in class org.apache.lucene.index.MultiReader
- numDocs() - Method in class org.apache.lucene.index.ParallelReader
- numDocs() - Method in class org.apache.lucene.index.RandomIndexWriter
- numDocs() - Method in class org.apache.lucene.index.SegmentReader
- numDocs() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexReader
-
Deprecated.
- NUMERIC - Static variable in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
- NUMERIC_CONFIG - Static variable in class org.apache.lucene.queryParser.standard.config.StandardQueryConfigHandler.ConfigurationKeys
-
Key used to set a field to its
NumericConfig
. - NUMERIC_CONFIG_MAP - Static variable in class org.apache.lucene.queryParser.standard.config.StandardQueryConfigHandler.ConfigurationKeys
-
Key used to set the
NumericConfig
inFieldConfig
for numeric fields. - NUMERIC_TYPE - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
-
Numbers
- NUMERIC_TYPE - Static variable in class org.apache.lucene.analysis.standard.std31.StandardTokenizerImpl31
-
Deprecated.Numbers
- NUMERIC_TYPE - Static variable in class org.apache.lucene.analysis.standard.std31.UAX29URLEmailTokenizerImpl31
-
Deprecated.Numbers
- NUMERIC_TYPE - Static variable in class org.apache.lucene.analysis.standard.std34.UAX29URLEmailTokenizerImpl34
-
Deprecated.Numbers
- NUMERIC_TYPE - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
-
Deprecated.use
UAX29URLEmailTokenizer.TOKEN_TYPES
instead - NUMERIC_TYPE - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizerImpl
-
Numbers
- NUMERIC_UTILS_DOUBLE_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
-
A parser instance for double values encoded with
NumericUtils
, e.g. - NUMERIC_UTILS_FLOAT_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
-
A parser instance for float values encoded with
NumericUtils
, e.g. - NUMERIC_UTILS_INT_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
-
A parser instance for int values encoded by
NumericUtils.intToPrefixCoded(int)
, e.g. - NUMERIC_UTILS_LONG_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
-
A parser instance for long values encoded by
NumericUtils.longToPrefixCoded(long)
, e.g. - NumericComparator(String, T) - Constructor for class org.apache.lucene.search.FieldComparator.NumericComparator
- numericConfig - Variable in class org.apache.lucene.queryParser.standard.nodes.NumericRangeQueryNode
- NumericConfig - Class in org.apache.lucene.queryParser.standard.config
-
This class holds the configuration used to parse numeric queries and create
NumericRangeQuery
s. - NumericConfig(int, NumberFormat, NumericField.DataType) - Constructor for class org.apache.lucene.queryParser.standard.config.NumericConfig
-
Constructs a
NumericConfig
object. - NumericField - Class in org.apache.lucene.document
-
This class provides a
Field
that enables indexing of numeric values for efficient range filtering and sorting. - NumericField(String) - Constructor for class org.apache.lucene.document.NumericField
-
Creates a field for numeric values using the default
precisionStep
NumericUtils.PRECISION_STEP_DEFAULT
(4). - NumericField(String, int) - Constructor for class org.apache.lucene.document.NumericField
-
Creates a field for numeric values with the specified
precisionStep
. - NumericField(String, int, Field.Store, boolean) - Constructor for class org.apache.lucene.document.NumericField
-
Creates a field for numeric values with the specified
precisionStep
. - NumericField(String, Field.Store, boolean) - Constructor for class org.apache.lucene.document.NumericField
-
Creates a field for numeric values using the default
precisionStep
NumericUtils.PRECISION_STEP_DEFAULT
(4). - NumericField.DataType - Enum in org.apache.lucene.document
-
Data type of the value in
NumericField
. - NumericFieldConfigListener - Class in org.apache.lucene.queryParser.standard.config
-
This listener is used to listen to
FieldConfig
requests inQueryConfigHandler
and addStandardQueryConfigHandler.ConfigurationKeys.NUMERIC_CONFIG
based on theStandardQueryConfigHandler.ConfigurationKeys.NUMERIC_CONFIG_MAP
set in theQueryConfigHandler
. - NumericFieldConfigListener(QueryConfigHandler) - Constructor for class org.apache.lucene.queryParser.standard.config.NumericFieldConfigListener
-
Construcs a
NumericFieldConfigListener
object using the givenQueryConfigHandler
. - NumericPayloadTokenFilter - Class in org.apache.lucene.analysis.payloads
-
Assigns a payload to a token based on the
Token.type()
- NumericPayloadTokenFilter(TokenStream, float, String) - Constructor for class org.apache.lucene.analysis.payloads.NumericPayloadTokenFilter
- NumericQueryNode - Class in org.apache.lucene.queryParser.standard.nodes
-
This query node represents a field query that holds a numeric value.
- NumericQueryNode(CharSequence, Number, NumberFormat) - Constructor for class org.apache.lucene.queryParser.standard.nodes.NumericQueryNode
-
Creates a
NumericQueryNode
object using the given field,Number
value andNumberFormat
used to convert the value toString
. - NumericQueryNodeProcessor - Class in org.apache.lucene.queryParser.standard.processors
-
This processor is used to convert
FieldQueryNode
s toNumericRangeQueryNode
s. - NumericQueryNodeProcessor() - Constructor for class org.apache.lucene.queryParser.standard.processors.NumericQueryNodeProcessor
-
Constructs a
NumericQueryNodeProcessor
object. - NumericRangeFilter<T extends Number> - Class in org.apache.lucene.search
-
A
Filter
that only accepts numeric values within a specified range. - NumericRangeFilterBuilder - Class in org.apache.lucene.xmlparser.builders
-
Creates a
NumericRangeFilter
. - NumericRangeFilterBuilder() - Constructor for class org.apache.lucene.xmlparser.builders.NumericRangeFilterBuilder
- NumericRangeQuery<T extends Number> - Class in org.apache.lucene.search
-
A
Query
that matches numeric values within a specified range. - NumericRangeQueryBuilder - Class in org.apache.lucene.xmlparser.builders
-
Creates a
NumericRangeQuery
. - NumericRangeQueryBuilder() - Constructor for class org.apache.lucene.xmlparser.builders.NumericRangeQueryBuilder
- NumericRangeQueryNode - Class in org.apache.lucene.queryParser.standard.nodes
-
This query node represents a range query composed by
NumericQueryNode
bounds, which means the bound values areNumber
s. - NumericRangeQueryNode(NumericQueryNode, NumericQueryNode, boolean, boolean, NumericConfig) - Constructor for class org.apache.lucene.queryParser.standard.nodes.NumericRangeQueryNode
-
Constructs a
NumericRangeQueryNode
object using the givenNumericQueryNode
as its bounds andNumericConfig
. - NumericRangeQueryNodeBuilder - Class in org.apache.lucene.queryParser.standard.builders
-
Builds
NumericRangeQuery
s out ofNumericRangeQueryNode
s. - NumericRangeQueryNodeBuilder() - Constructor for class org.apache.lucene.queryParser.standard.builders.NumericRangeQueryNodeBuilder
-
Constructs a
NumericRangeQueryNodeBuilder
object. - NumericRangeQueryNodeProcessor - Class in org.apache.lucene.queryParser.standard.processors
-
This processor is used to convert
ParametricRangeQueryNode
s toNumericRangeQueryNode
s. - NumericRangeQueryNodeProcessor() - Constructor for class org.apache.lucene.queryParser.standard.processors.NumericRangeQueryNodeProcessor
-
Constructs an empty
NumericRangeQueryNode
object. - NumericTokenStream - Class in org.apache.lucene.analysis
-
Expert: This class provides a
TokenStream
for indexing numeric values that can be used byNumericRangeQuery
orNumericRangeFilter
. - NumericTokenStream() - Constructor for class org.apache.lucene.analysis.NumericTokenStream
-
Creates a token stream for numeric values using the default
precisionStep
NumericUtils.PRECISION_STEP_DEFAULT
(4). - NumericTokenStream(int) - Constructor for class org.apache.lucene.analysis.NumericTokenStream
-
Creates a token stream for numeric values with the specified
precisionStep
. - NumericTokenStream(AttributeSource.AttributeFactory, int) - Constructor for class org.apache.lucene.analysis.NumericTokenStream
-
Expert: Creates a token stream for numeric values with the specified
precisionStep
using the givenAttributeSource.AttributeFactory
. - NumericTokenStream(AttributeSource, int) - Constructor for class org.apache.lucene.analysis.NumericTokenStream
-
Expert: Creates a token stream for numeric values with the specified
precisionStep
using the givenAttributeSource
. - NumericUtils - Class in org.apache.lucene.util
-
This is a helper class to generate prefix-encoded representations for numerical values and supplies converters to represent float/double values as sortable integers/longs.
- NumericUtils.IntRangeBuilder - Class in org.apache.lucene.util
- NumericUtils.LongRangeBuilder - Class in org.apache.lucene.util
- 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.
- numNodes() - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Returns the total number of nodes in the trie.
- numNodes(JaspellTernarySearchTrie.TSTNode) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Returns the total number of nodes in the subtrie below and including the starting Node.
- 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.
- numTerms - Static variable in class org.apache.lucene.misc.HighFreqTerms
- numToHighlight - Variable in class org.apache.lucene.benchmark.byTask.tasks.SearchTravRetHighlightTask
- numToHighlight - Variable in class org.apache.lucene.benchmark.byTask.tasks.SearchTravRetVectorHighlightTask
- numToHighlight() - Method in class org.apache.lucene.benchmark.byTask.tasks.ReadTask
-
Set to the number of documents to highlight.
- numToHighlight() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchTravRetHighlightTask
- numToHighlight() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchTravRetVectorHighlightTask
O
- OBJECT_ALIGNMENT - org.apache.lucene.util.RamUsageEstimator.JvmFeature
- OBJECT_REFERENCE_SIZE - org.apache.lucene.util.RamUsageEstimator.JvmFeature
- ObjectToFloatMap<K> - Class in org.apache.lucene.util.collections
-
An Array-based hashtable which maps Objects of generic type T to primitive float values.
The hashtable is constructed with a given capacity, or 16 as a default. - ObjectToFloatMap() - Constructor for class org.apache.lucene.util.collections.ObjectToFloatMap
-
Constructs a map with default capacity.
- ObjectToFloatMap(int) - Constructor for class org.apache.lucene.util.collections.ObjectToFloatMap
-
Constructs a map with given capacity.
- ObjectToIntMap<K> - Class in org.apache.lucene.util.collections
-
An Array-based hashtable which maps Objects of generic type T to primitive int values.
The hashtable is constructed with a given capacity, or 16 as a default. - ObjectToIntMap() - Constructor for class org.apache.lucene.util.collections.ObjectToIntMap
-
Constructs a map with default capacity.
- ObjectToIntMap(int) - Constructor for class org.apache.lucene.util.collections.ObjectToIntMap
-
Constructs a map with given capacity.
- obtain() - Method in class org.apache.lucene.store.Lock
-
Attempts to obtain exclusive access and immediately return upon success or failure.
- obtain(long) - Method in class org.apache.lucene.store.Lock
-
Attempts to obtain an exclusive lock within amount of time given.
- offset - Variable in class org.apache.lucene.index.Payload
-
the offset within the byte array
- offset - Variable in class org.apache.lucene.util.BytesRef
-
Offset of first valid byte.
- offset - Variable in class org.apache.lucene.util.CharsRef
- offset - Variable in class org.apache.lucene.util.IntsRef
- 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
-
The start and end character offset of a Token.
- OffsetAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
- 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.util.UnicodeUtil.UTF16Result
- omitNorms - Variable in class org.apache.lucene.document.AbstractField
- omitNorms - Variable in class org.apache.lucene.index.FieldInfo
- omitNorms() - Method in enum org.apache.lucene.document.Field.Index
- onClose(IndexReader) - Method in interface org.apache.lucene.index.IndexReader.ReaderClosedListener
- onClose(SegmentReader) - Method in interface org.apache.lucene.index.SegmentReader.CoreClosedListener
- onCommit(List<? extends IndexCommit>) - Method in interface 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
- 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.
- OneDimensionalNonWeightedTokenSettingsCodec() - Constructor for class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.OneDimensionalNonWeightedTokenSettingsCodec
-
Deprecated.
- OneMerge(List<SegmentInfo>) - Constructor for class org.apache.lucene.index.MergePolicy.OneMerge
- onIndexOutputClosed(FSDirectory.FSIndexOutput) - Method in class org.apache.lucene.store.FSDirectory
- onInit(List<? extends IndexCommit>) - Method in interface 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.PersistentSnapshotDeletionPolicy
- onInit(List<? extends IndexCommit>) - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
- onlyLongestMatch - Variable in class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
- onOrAfter(Version) - Method in enum org.apache.lucene.util.Version
- 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.
- OpaqueQueryNode - Class in org.apache.lucene.queryParser.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.core.nodes.OpaqueQueryNode
- open(File) - Static method in class org.apache.lucene.store.FSDirectory
-
Creates an FSDirectory instance, trying to pick the best implementation given the current environment.
- open(File, LockFactory) - Static method in class org.apache.lucene.store.FSDirectory
-
Just like
FSDirectory.open(File)
, but allows you to also specify a customLockFactory
. - open(IndexCommit) - Static method in class org.apache.lucene.index.IndexReader
-
Expert: returns an IndexReader reading the index in the given
IndexCommit
. - open(IndexCommit, boolean) - Static method in class org.apache.lucene.index.IndexReader
-
Deprecated.Write support will be removed in Lucene 4.0. Use
IndexReader.open(IndexCommit)
instead - open(IndexCommit, int) - Static method in class org.apache.lucene.index.IndexReader
-
Expert: returns an IndexReader reading the index in the given
IndexCommit
and termInfosIndexDivisor. - open(IndexCommit, IndexDeletionPolicy, boolean) - Static method in class org.apache.lucene.index.IndexReader
-
Deprecated.Write support will be removed in Lucene 4.0. Use
IndexReader.open(IndexCommit)
instead - open(IndexCommit, IndexDeletionPolicy, boolean, int) - Static method in class org.apache.lucene.index.IndexReader
-
Deprecated.Write support will be removed in Lucene 4.0. Use
IndexReader.open(IndexCommit,int)
instead - open(IndexWriter, boolean) - Static method in class org.apache.lucene.index.IndexReader
-
Open a near real time IndexReader from the
IndexWriter
. - open(Directory) - Static method in class org.apache.lucene.index.IndexReader
-
Returns a IndexReader reading the index in the given Directory, with readOnly=true.
- open(Directory, boolean) - Static method in class org.apache.lucene.index.IndexReader
-
Deprecated.Write support will be removed in Lucene 4.0. Use
IndexReader.open(Directory)
instead - open(Directory, int) - Static method in class org.apache.lucene.index.IndexReader
-
Expert: Returns a IndexReader reading the index in the given Director and given termInfosIndexDivisor
- open(Directory, IndexDeletionPolicy, boolean) - Static method in class org.apache.lucene.index.IndexReader
-
Deprecated.Write support will be removed in Lucene 4.0. Use
IndexReader.open(Directory)
instead - open(Directory, IndexDeletionPolicy, boolean, int) - Static method in class org.apache.lucene.index.IndexReader
-
Deprecated.Write support will be removed in Lucene 4.0. Use
IndexReader.open(Directory,int)
instead - open_direct(String, boolean) - Static method in class org.apache.lucene.store.NativePosixUtil
- OpenBitSet - Class in org.apache.lucene.util
-
An "open" BitSet implementation that allows direct access to the array of words storing the bits.
- OpenBitSet() - Constructor for class org.apache.lucene.util.OpenBitSet
- OpenBitSet(long) - Constructor for class org.apache.lucene.util.OpenBitSet
-
Constructs an OpenBitSet large enough to hold numBits.
- OpenBitSet(long[], int) - Constructor for class org.apache.lucene.util.OpenBitSet
-
Constructs an OpenBitSet from an existing long[].
- OpenBitSetDISI - Class in org.apache.lucene.util
-
OpenBitSet with added methods to bulk-update the bits from a
DocIdSetIterator
. - OpenBitSetDISI(int) - Constructor for class org.apache.lucene.util.OpenBitSetDISI
-
Construct an OpenBitSetDISI with no bits set, and a given maximum size one larger than the largest doc id for which a bit may ever be set on this OpenBitSetDISI.
- OpenBitSetDISI(DocIdSetIterator, int) - Constructor for class org.apache.lucene.util.OpenBitSetDISI
-
Construct an OpenBitSetDISI with its bits set from the doc ids of the given DocIdSetIterator.
- OpenBitSetIterator - Class in org.apache.lucene.util
-
An iterator to iterate over set bits in an OpenBitSet.
- OpenBitSetIterator(long[], int) - Constructor for class org.apache.lucene.util.OpenBitSetIterator
- OpenBitSetIterator(OpenBitSet) - Constructor for class org.apache.lucene.util.OpenBitSetIterator
- openIfChanged(IndexReader) - Static method in class org.apache.lucene.index.IndexReader
-
If the index has changed since the provided reader was opened, open and return a new reader; else, return null.
- openIfChanged(IndexReader, boolean) - Static method in class org.apache.lucene.index.IndexReader
-
Deprecated.Write support will be removed in Lucene 4.0. Use
IndexReader.openIfChanged(IndexReader)
instead - openIfChanged(IndexReader, IndexCommit) - Static method in class org.apache.lucene.index.IndexReader
-
If the IndexCommit differs from what the provided reader is searching, or the provided reader is not already read-only, open and return a new
readOnly=true
reader; else, return null. - openIfChanged(IndexReader, IndexWriter, boolean) - Static method in class org.apache.lucene.index.IndexReader
-
Expert: If there changes (committed or not) in the
IndexWriter
versus what the provided reader is searching, then open and return a new read-only IndexReader searching both committed and uncommitted changes from the writer; else, return null (though, the current implementation never returns null). - openIndexReader(Directory) - 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.
- openInput(String) - Method in class org.apache.lucene.store.Directory
-
Returns a stream reading an existing file.
- openInput(String) - Method in class org.apache.lucene.store.FileSwitchDirectory
- openInput(String) - Method in class org.apache.lucene.store.FSDirectory
- openInput(String) - Method in class org.apache.lucene.store.MockDirectoryWrapper
- openInput(String) - Method in class org.apache.lucene.store.NRTCachingDirectory
- openInput(String) - Method in class org.apache.lucene.store.RAMDirectory
-
Returns a stream reading an existing file.
- openInput(String, int) - Method in class org.apache.lucene.store.DirectIOLinuxDirectory
- openInput(String, int) - Method in class org.apache.lucene.store.Directory
-
Returns a stream reading an existing file, with the specified read buffer size.
- openInput(String, int) - Method in class org.apache.lucene.store.MMapDirectory
-
Creates an IndexInput for the file with the given name.
- openInput(String, int) - Method in class org.apache.lucene.store.NIOFSDirectory
-
Creates an IndexInput for the file with the given name.
- openInput(String, int) - Method in class org.apache.lucene.store.NRTCachingDirectory
- openInput(String, int) - Method in class org.apache.lucene.store.SimpleFSDirectory
-
Creates an IndexInput for the file with the given name.
- openInput(String, int) - Method in class org.apache.lucene.store.WindowsDirectory
- openReader() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
-
Open an
IndexReader
from the internalIndexWriter
, by callingIndexReader.open(IndexWriter, boolean)
. - openReaderPassed - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
-
True if we were able to open a SegmentReader 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
- 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(char[], int) - Constructor for class org.apache.lucene.analysis.util.OpenStringBuilder
- OpenStringBuilder(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
- optimize() - Method in class org.apache.lucene.index.IndexWriter
-
Deprecated.
- optimize(boolean) - Method in class org.apache.lucene.index.IndexWriter
-
Deprecated.
- optimize(int) - Method in class org.apache.lucene.index.IndexWriter
-
Deprecated.
- 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.
- OptionalFields() - Method in class org.apache.lucene.queryParser.surround.parser.QueryParser
- OptionalWeights(SrndQuery) - Method in class org.apache.lucene.queryParser.surround.parser.QueryParser
- or(DocIdSetIterator) - Method in class org.apache.lucene.util.FixedBitSet
-
Does in-place OR of the bits provided by the iterator.
- or(FixedBitSet) - Method in class org.apache.lucene.util.FixedBitSet
-
this = this OR other
- or(OpenBitSet) - Method in class org.apache.lucene.util.OpenBitSet
- OR - org.apache.lucene.queryParser.QueryParser.Operator
- OR - org.apache.lucene.queryParser.standard.config.DefaultOperatorAttribute.Operator
-
Deprecated.
- OR - org.apache.lucene.queryParser.standard.config.StandardQueryConfigHandler.Operator
- OR - org.apache.lucene.queryParser.standard.QueryParserWrapper.Operator
-
Deprecated.
- OR - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
-
RegularExpression Id.
- OR - Static variable in interface org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- OR - Static variable in interface org.apache.lucene.queryParser.surround.parser.QueryParserConstants
-
RegularExpression Id.
- OR - Static variable in class org.apache.lucene.search.ChainedFilter
- OR_OPERATOR - Static variable in class org.apache.lucene.queryParser.QueryParser
-
Alternative form of QueryParser.Operator.OR
- OR_OPERATOR - Static variable in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.Alternative form of QueryParser.Operator.OR
- order - Variable in class org.apache.lucene.search.FieldCache.StringIndex
-
For each document, an index into the lookup array.
- OrdFieldSource - Class in org.apache.lucene.search.function
-
Expert: obtains the ordinal of the field value from the default Lucene
Fieldcache
using getStringIndex(). - OrdFieldSource(String) - Constructor for class org.apache.lucene.search.function.OrdFieldSource
-
Constructor for a certain field.
- ordinal - Variable in class org.apache.lucene.facet.index.attributes.OrdinalProperty
- ordinal - Variable in class org.apache.lucene.util.encoding.ChunksIntEncoder
-
Counts the current ordinal of the encoded value.
- ORDINAL - org.apache.lucene.facet.search.params.FacetRequest.SortBy
-
sort by category ordinal with the taxonomy
- OrdinalPolicy - Interface in org.apache.lucene.facet.index.categorypolicy
-
Filtering category ordinals in
CategoryParentsStream
, where a given category ordinal is added to the stream, and than its parents are being added one after the other usingTaxonomyWriter.getParent(int)
. - ordinalProperty - Variable in class org.apache.lucene.facet.index.streaming.CategoryParentsStream
-
A category property containing the category ordinal
- OrdinalProperty - Class in org.apache.lucene.facet.index.attributes
-
A
CategoryProperty
holding the ordinal from the taxonomy of the current category inCategoryAttribute
. - OrdinalProperty() - Constructor for class org.apache.lucene.facet.index.attributes.OrdinalProperty
- org.apache.lucene - package org.apache.lucene
-
Top-level package.
- org.apache.lucene.analysis - package org.apache.lucene.analysis
-
API and code to convert text into indexable/searchable tokens.
- 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.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
-
CharFilters: process text before the Tokenizer
- org.apache.lucene.analysis.cjk - package org.apache.lucene.analysis.cjk
-
Analyzer for Chinese, Japanese, and Korean, which indexes bigrams (overlapping groups of two adjacent Han characters).
- org.apache.lucene.analysis.cn - package org.apache.lucene.analysis.cn
-
Analyzer for Chinese, which indexes unigrams (individual chinese characters).
- 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.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
-
The code for the compound word hyphenation is taken from the Apache FOP project.
- 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
-
Analysis 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
-
Stemming TokenFilter using a Java implementation of the Hunspell stemming algorithm.
- 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
-
Analysis components 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.lv - package org.apache.lucene.analysis.lv
-
Analyzer for Latvian.
- org.apache.lucene.analysis.miscellaneous - package org.apache.lucene.analysis.miscellaneous
-
Miscellaneous TokenStreams
- 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.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.position - package org.apache.lucene.analysis.position
-
Filter for assigning position increments.
- 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
-
Implementations of the SinkTokenizer that might be useful.
- org.apache.lucene.analysis.snowball - package org.apache.lucene.analysis.snowball
-
TokenFilter
andAnalyzer
implementations that use Snowball stemmers. - org.apache.lucene.analysis.standard - package org.apache.lucene.analysis.standard
-
Standards-based analyzers implemented with JFlex.
- org.apache.lucene.analysis.standard.std31 - package org.apache.lucene.analysis.standard.std31
-
Backwards-compatible implementation to match
Version.LUCENE_31
- org.apache.lucene.analysis.standard.std34 - package org.apache.lucene.analysis.standard.std34
-
Backwards-compatible implementation to match
Version.LUCENE_34
- 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
-
Useful
Attribute
s for text analysis. - org.apache.lucene.analysis.tr - package org.apache.lucene.analysis.tr
-
Analyzer for Turkish.
- 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
- 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.feeds.demohtml - package org.apache.lucene.benchmark.byTask.feeds.demohtml
-
Example html parser based on JavaCC
- 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.collation - package org.apache.lucene.collation
-
CollationKeyFilter
converts each token into its binaryCollationKey
using the providedCollator
, and then encode theCollationKey
as a String usingIndexableBinaryStringTools
, to allow it to be stored as an index term. - org.apache.lucene.demo - package org.apache.lucene.demo
-
Demo applications for indexing and searching.
- org.apache.lucene.document - package org.apache.lucene.document
-
The logical representation of a
Document
for indexing and searching. - org.apache.lucene.facet - package org.apache.lucene.facet
-
Provides faceted indexing and search capabilities.
- org.apache.lucene.facet.enhancements - package org.apache.lucene.facet.enhancements
-
Enhanced category features
- org.apache.lucene.facet.enhancements.association - package org.apache.lucene.facet.enhancements.association
-
Association category enhancements
- org.apache.lucene.facet.enhancements.params - package org.apache.lucene.facet.enhancements.params
-
Enhanced category features
- org.apache.lucene.facet.index - package org.apache.lucene.facet.index
-
Indexing of document categories
- org.apache.lucene.facet.index.attributes - package org.apache.lucene.facet.index.attributes
-
Category attributes and their properties for indexing
- org.apache.lucene.facet.index.categorypolicy - package org.apache.lucene.facet.index.categorypolicy
-
Policies for indexing categories
- org.apache.lucene.facet.index.params - package org.apache.lucene.facet.index.params
-
Indexing-time specifications for handling facets
- org.apache.lucene.facet.index.streaming - package org.apache.lucene.facet.index.streaming
-
Expert: attributes streaming definition for indexing facets
- org.apache.lucene.facet.search - package org.apache.lucene.facet.search
-
Faceted Search API
- org.apache.lucene.facet.search.aggregator - package org.apache.lucene.facet.search.aggregator
-
Aggregating Facets during Faceted Search
- org.apache.lucene.facet.search.aggregator.association - package org.apache.lucene.facet.search.aggregator.association
-
Association-based aggregators.
- org.apache.lucene.facet.search.cache - package org.apache.lucene.facet.search.cache
-
Caching to speed up facets accumulation.
- org.apache.lucene.facet.search.params - package org.apache.lucene.facet.search.params
-
Parameters for Faceted Search
- org.apache.lucene.facet.search.params.association - package org.apache.lucene.facet.search.params.association
-
Association-based Parameters for Faceted Search.
- org.apache.lucene.facet.search.results - package org.apache.lucene.facet.search.results
-
Results of Faceted Search
- org.apache.lucene.facet.search.sampling - package org.apache.lucene.facet.search.sampling
-
Sampling for facets accumulation
- 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 implemented using a Lucene-Index
- 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.facet.taxonomy.writercache.cl2o - package org.apache.lucene.facet.taxonomy.writercache.cl2o
-
Category->Ordinal caching implementation using an optimized data-structures
- org.apache.lucene.facet.taxonomy.writercache.lru - package org.apache.lucene.facet.taxonomy.writercache.lru
-
An LRU cache implementation for the CategoryPath to Ordinal map
- org.apache.lucene.facet.util - package org.apache.lucene.facet.util
-
Various utilities for faceted search
- 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.index.pruning - package org.apache.lucene.index.pruning
-
Static Index Pruning Tools
- org.apache.lucene.messages - package org.apache.lucene.messages
-
For Native Language Support (NLS), system of software internationalization.
- org.apache.lucene.misc - package org.apache.lucene.misc
-
Miscellaneous index tools.
- org.apache.lucene.queryParser - package org.apache.lucene.queryParser
-
A simple query parser implemented with JavaCC.
- org.apache.lucene.queryParser.analyzing - package org.apache.lucene.queryParser.analyzing
-
QueryParser that passes Fuzzy-, Prefix-, Range-, and WildcardQuerys through the given analyzer.
- 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.core - package org.apache.lucene.queryParser.core
-
Contains the core classes of the flexible query parser framework
- org.apache.lucene.queryParser.core.builders - package org.apache.lucene.queryParser.core.builders
-
Contains the necessary classes to implement query builders
- org.apache.lucene.queryParser.core.config - package org.apache.lucene.queryParser.core.config
-
Contains the base classes used to configure the query processing
- org.apache.lucene.queryParser.core.messages - package org.apache.lucene.queryParser.core.messages
-
Contains messages usually used by query parser implementations
- org.apache.lucene.queryParser.core.nodes - package org.apache.lucene.queryParser.core.nodes
-
Contains query nodes that are commonly used by query parser implementations
- org.apache.lucene.queryParser.core.parser - package org.apache.lucene.queryParser.core.parser
-
Contains the necessary interfaces to implement text parsers
- org.apache.lucene.queryParser.core.processors - package org.apache.lucene.queryParser.core.processors
-
Interfaces and implementations used by query node processors
- org.apache.lucene.queryParser.core.util - package org.apache.lucene.queryParser.core.util
-
Utility classes to used with the Query Parser
- 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.precedence - package org.apache.lucene.queryParser.precedence
-
This package contains the Precedence Query Parser Implementation
- org.apache.lucene.queryParser.precedence.processors - package org.apache.lucene.queryParser.precedence.processors
-
This package contains the processors used by Precedence Query Parser
- org.apache.lucene.queryParser.standard - package org.apache.lucene.queryParser.standard
-
Contains the implementation of the Lucene query parser using the flexible query parser frameworks
- org.apache.lucene.queryParser.standard.builders - package org.apache.lucene.queryParser.standard.builders
-
Standard Lucene Query Node Builders
- org.apache.lucene.queryParser.standard.config - package org.apache.lucene.queryParser.standard.config
-
Standard Lucene Query Configuration
- org.apache.lucene.queryParser.standard.nodes - package org.apache.lucene.queryParser.standard.nodes
-
Standard Lucene Query Nodes
- org.apache.lucene.queryParser.standard.parser - package org.apache.lucene.queryParser.standard.parser
-
Lucene Query Parser
- org.apache.lucene.queryParser.standard.processors - package org.apache.lucene.queryParser.standard.processors
-
Lucene Query Node Processors
- 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.search - package org.apache.lucene.search
-
Code to search indices.
- org.apache.lucene.search.function - package org.apache.lucene.search.function
-
Programmatic control over documents scores.
- org.apache.lucene.search.grouping - package org.apache.lucene.search.grouping
-
This module enables search result grouping with Lucene, where hits with the same value in the specified single-valued group field are grouped together.
- org.apache.lucene.search.highlight - package org.apache.lucene.search.highlight
-
The highlight package contains classes to provide "keyword in context" features typically used to highlight search terms in the text of results pages.
- org.apache.lucene.search.join - package org.apache.lucene.search.join
-
This modules support index-time and query-time joins.
- org.apache.lucene.search.payloads - package org.apache.lucene.search.payloads
-
The payloads package provides Query mechanisms for finding and using payloads.
- org.apache.lucene.search.regex - package org.apache.lucene.search.regex
-
Regular expression Query.
- org.apache.lucene.search.similar - package org.apache.lucene.search.similar
-
Document similarity query generators.
- 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.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.vectorhighlight - package org.apache.lucene.search.vectorhighlight
-
This is an another highlighter implementation.
- org.apache.lucene.spatial - package org.apache.lucene.spatial
-
Support for geospatial search.
- org.apache.lucene.spatial.geohash - package org.apache.lucene.spatial.geohash
-
Support for Geohash encoding, decoding, and filtering.
- org.apache.lucene.spatial.geometry - package org.apache.lucene.spatial.geometry
-
Coordinate and distance representations.
- org.apache.lucene.spatial.geometry.shape - package org.apache.lucene.spatial.geometry.shape
-
Shape representations.
- org.apache.lucene.spatial.tier - package org.apache.lucene.spatial.tier
-
Support for filtering based upon geographic location.
- org.apache.lucene.spatial.tier.projections - package org.apache.lucene.spatial.tier.projections
-
Spatial projections.
- org.apache.lucene.store - package org.apache.lucene.store
-
Binary i/o API, used for all index data.
- org.apache.lucene.store.instantiated - package org.apache.lucene.store.instantiated
-
InstantiatedIndex, alternative RAM store for small corpora.
- org.apache.lucene.util - package org.apache.lucene.util
-
Some utility classes.
- org.apache.lucene.util.collections - package org.apache.lucene.util.collections
-
Various optimized Collections implementations.
- org.apache.lucene.util.encoding - package org.apache.lucene.util.encoding
-
Offers various encoders and decoders for integers, as well as the mechanisms to create new ones.
- org.apache.lucene.util.fst - package org.apache.lucene.util.fst
-
Finite state transducers
- org.apache.lucene.util.packed - package org.apache.lucene.util.packed
-
The packed package provides random access capable arrays of positive longs.
- org.apache.lucene.xmlparser - package org.apache.lucene.xmlparser
-
Parser that produces Lucene Query objects from XML streams.
- org.apache.lucene.xmlparser.builders - package org.apache.lucene.xmlparser.builders
-
Builders to support various Lucene queries.
- 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.
- OrQuery - Class in org.apache.lucene.queryParser.surround.query
- OrQuery(List<SrndQuery>, boolean, String) - Constructor for class org.apache.lucene.queryParser.surround.query.OrQuery
- OrQuery() - Method in class org.apache.lucene.queryParser.surround.parser.QueryParser
- OrQueryNode - Class in org.apache.lucene.queryParser.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.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 - Variable in class org.apache.lucene.search.CachingCollector
- 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.util.encoding.IntEncoder
- 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.util.fst.Builder.Arc
- output - Variable in class org.apache.lucene.util.fst.Builder.UnCompiledNode
- output - Variable in class org.apache.lucene.util.fst.BytesRefFSTEnum.InputOutput
- output - Variable in class org.apache.lucene.util.fst.FST.Arc
- output - Variable in class org.apache.lucene.util.fst.IntsRefFSTEnum.InputOutput
- output - Variable in class org.apache.lucene.util.fst.Util.MinResult
- output1 - Variable in class org.apache.lucene.util.fst.PairOutputs.Pair
- output2 - Variable in class org.apache.lucene.util.fst.PairOutputs.Pair
- 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
- outputStream(File) - Static method in class org.apache.lucene.benchmark.byTask.utils.StreamUtils
-
Returns an
OutputStream
over the requested file, identifying the appropriateOutputStream
instance similar toStreamUtils.inputStream(File)
. - OutputStreamDataOutput - Class in org.apache.lucene.store
-
A
DataOutput
wrapping a plainOutputStream
. - OutputStreamDataOutput(OutputStream) - Constructor for class org.apache.lucene.store.OutputStreamDataOutput
- outputToString(Long) - Method in class org.apache.lucene.util.fst.PositiveIntOutputs
- outputToString(Object) - Method in class org.apache.lucene.util.fst.NoOutputs
- outputToString(Object) - Method in class org.apache.lucene.util.fst.UpToTwoPositiveIntOutputs
- outputToString(BytesRef) - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
- outputToString(PairOutputs.Pair<A, B>) - Method in class org.apache.lucene.util.fst.PairOutputs
- outputToString(IntsRef) - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
- outputToString(T) - Method in class org.apache.lucene.util.fst.Outputs
- OUTSIDE - org.apache.lucene.spatial.geometry.shape.IntersectCase
-
Deprecated.
- overSampledSearchParams(FacetSearchParams) - Method in class org.apache.lucene.facet.search.sampling.Sampler
-
Over-sampled search params, wrapping each request with an over-sampled one.
- oversize(int, int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Returns an array size >= minTargetSize, generally over-allocating exponentially to achieve amortized linear-time cost as the array grows.
P
- pack(int, int) - Method in class org.apache.lucene.util.fst.FST
-
Expert: creates an FST by packing this one.
- packCount - Variable in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
- 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.Mutable - Interface in org.apache.lucene.util.packed
-
A packed integer array that can be modified.
- PackedInts.Reader - Interface in org.apache.lucene.util.packed
-
A read-only random access array of positive integers.
- PackedInts.ReaderImpl - Class in org.apache.lucene.util.packed
-
A simple base for Readers that keeps track of valueCount and bitsPerValue.
- PackedInts.Writer - Class in org.apache.lucene.util.packed
-
A write-once Writer.
- 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<
- 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
- 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 FSTOutputs
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.- PARAGRAPH - org.apache.lucene.queryParser.core.nodes.ProximityQueryNode.Type
- ParallelMultiSearcher - Class in org.apache.lucene.search
Deprecated.Please pass an ExecutorService toIndexSearcher
, instead.- ParallelMultiSearcher(ExecutorService, Searchable...) - Constructor for class org.apache.lucene.search.ParallelMultiSearcher
Deprecated.Creates aSearchable
which searches searchables with the specified ExecutorService.- ParallelMultiSearcher(Searchable...) - Constructor for class org.apache.lucene.search.ParallelMultiSearcher
Deprecated.Creates aSearchable
which searches searchables with the default executor service (a cached thread pool).- ParallelReader - Class in org.apache.lucene.index
An IndexReader which reads multiple, parallel indexes.- ParallelReader() - Constructor for class org.apache.lucene.index.ParallelReader
Construct a ParallelReader.- ParallelReader(boolean) - Constructor for class org.apache.lucene.index.ParallelReader
Construct a ParallelReader.- Parameter - Class in org.apache.lucene.util
Deprecated.Use Java 5 enum, will be removed in a later Lucene 3.x release.- Parameter(String) - Constructor for class org.apache.lucene.util.Parameter
Deprecated.- PARAMETER_VALUE_NOT_SUPPORTED - Static variable in class org.apache.lucene.queryParser.core.messages.QueryParserMessages
- ParametricQueryNode - Class in org.apache.lucene.queryParser.core.nodes
Deprecated.this class will be removed in future.FieldQueryNode
should be used instead.- ParametricQueryNode(CharSequence, ParametricQueryNode.CompareOperator, CharSequence, int, int) - Constructor for class org.apache.lucene.queryParser.core.nodes.ParametricQueryNode
Deprecated.- ParametricQueryNode.CompareOperator - Enum in org.apache.lucene.queryParser.core.nodes
Deprecated.- ParametricRangeQueryNode - Class in org.apache.lucene.queryParser.core.nodes
AParametricRangeQueryNode
represents LE, LT, GE, GT, EQ, NE query.- ParametricRangeQueryNode(ParametricQueryNode, ParametricQueryNode) - Constructor for class org.apache.lucene.queryParser.core.nodes.ParametricRangeQueryNode
- ParametricRangeQueryNodeProcessor - Class in org.apache.lucene.queryParser.standard.processors
This processor convertsParametricRangeQueryNode
objects toRangeQueryNode
objects.- ParametricRangeQueryNodeProcessor() - Constructor for class org.apache.lucene.queryParser.standard.processors.ParametricRangeQueryNodeProcessor
- paramFields - Variable in class org.apache.lucene.benchmark.byTask.tasks.SearchTravRetHighlightTask
- paramFields - Variable in class org.apache.lucene.benchmark.byTask.tasks.SearchTravRetVectorHighlightTask
- params - Variable in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
- PARENT - Static variable in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie.TSTNode
Index values for accessing relatives array.- parse(File) - Method in class org.apache.lucene.analysis.compound.hyphenation.PatternParser
Parses a hyphenation pattern file.- parse(InputStream) - Method in class org.apache.lucene.xmlparser.CoreParser
Parses the given stream as XML file and returns aQuery
.- parse(CharSequence, CharSequence) - Method in interface org.apache.lucene.queryParser.core.parser.SyntaxParser
- parse(CharSequence, CharSequence) - Method in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParser
Parses a query string, returning aQueryNode
.- 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(String) - 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) - Method in class org.apache.lucene.queryParser.complexPhrase.ComplexPhraseQueryParser
- parse(String) - Method in class org.apache.lucene.queryParser.QueryParser
Parses a query string, returning aQuery
.- parse(String) - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
Deprecated.- parse(String) - Static method in class org.apache.lucene.queryParser.surround.parser.QueryParser
- parse(String[], String[], Analyzer) - Static method in class org.apache.lucene.queryParser.standard.MultiFieldQueryParserWrapper
Deprecated.Parses a query which searches on the fields specified.- parse(String[], String[], Analyzer) - Static method in class org.apache.lucene.queryParser.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.standard.MultiFieldQueryParserWrapper
Deprecated.Parses a query, searching on the fields specified.- parse(String[], String[], BooleanClause.Occur[], Analyzer) - Static method in class org.apache.lucene.queryParser.standard.QueryParserUtil
Parses a query, searching on the fields specified.- parse(String, String) - Method in class org.apache.lucene.queryParser.core.QueryParserHelper
Parses a query string to an object, usually some query object.- parse(String, String) - Method in class org.apache.lucene.queryParser.standard.StandardQueryParser
OverridesQueryParserHelper.parse(String, String)
so it casts the return object toQuery
.- parse(String, String[], BooleanClause.Occur[], Analyzer) - Static method in class org.apache.lucene.queryParser.standard.MultiFieldQueryParserWrapper
Deprecated.Parses a query, searching on the fields specified.- parse(String, String[], BooleanClause.Occur[], Analyzer) - Static method in class org.apache.lucene.queryParser.standard.QueryParserUtil
Parses a query, searching on the fields specified.- parse(String, ParsePosition) - Method in class org.apache.lucene.queryParser.standard.config.NumberDateFormat
- parse(DocData, String, Date, String, Reader, DateFormat) - Method in class org.apache.lucene.benchmark.byTask.feeds.DemoHTMLParser
- parse(DocData, String, Date, String, Reader, DateFormat) - 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(ExtensionQuery) - Method in class org.apache.lucene.queryParser.ext.ParserExtension
Processes the givenExtensionQuery
and returns a correspondingQuery
instance.- parse(Version, String[], String[], Analyzer) - Static method in class org.apache.lucene.queryParser.MultiFieldQueryParser
Parses a query which searches on the fields specified.- parse(Version, String[], String[], BooleanClause.Occur[], Analyzer) - Static method in class org.apache.lucene.queryParser.MultiFieldQueryParser
Parses a query, searching on the fields specified.- parse(Version, String, String[], BooleanClause.Occur[], Analyzer) - Static method in class org.apache.lucene.queryParser.MultiFieldQueryParser
Parses a query, searching on the fields specified.- parse(InputSource) - Method in class org.apache.lucene.analysis.compound.hyphenation.PatternParser
Parses a hyphenation pattern file.- parse2(String) - Method in class org.apache.lucene.queryParser.surround.parser.QueryParser
- parseByte(String) - Method in interface org.apache.lucene.search.FieldCache.ByteParser
Return a single Byte representation of this field's value.- parseDate(String) - Method in class org.apache.lucene.benchmark.byTask.feeds.TrecContentSource
- parseDouble(String) - Method in interface org.apache.lucene.search.FieldCache.DoubleParser
Return an long representation of this field's value.- ParseException - Exception in org.apache.lucene.benchmark.byTask.feeds.demohtml
This exception is thrown when parse errors are encountered.- ParseException - Exception in org.apache.lucene.queryParser
This exception is thrown when parse errors are encountered.- ParseException - Exception in org.apache.lucene.queryParser.standard.parser
This exception is thrown when parse errors are encountered.- ParseException - Exception in org.apache.lucene.queryParser.surround.parser
This exception is thrown when parse errors are encountered.- ParseException() - Constructor for exception org.apache.lucene.benchmark.byTask.feeds.demohtml.ParseException
The following constructors are for use by you for whatever purpose you can think of.- ParseException() - Constructor for exception org.apache.lucene.queryParser.ParseException
The following constructors are for use by you for whatever purpose you can think of.- ParseException() - Constructor for exception org.apache.lucene.queryParser.standard.parser.ParseException
The following constructors are for use by you for whatever purpose you can think of.- 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.benchmark.byTask.feeds.demohtml.ParseException
Constructor with message.- ParseException(String) - Constructor for exception org.apache.lucene.queryParser.ParseException
Constructor with message.- ParseException(String) - Constructor for exception org.apache.lucene.queryParser.surround.parser.ParseException
Constructor with message.- ParseException(Token, int[][], String[]) - Constructor for exception org.apache.lucene.benchmark.byTask.feeds.demohtml.ParseException
This constructor is used by the method "generateParseException" in the generated parser.- ParseException(Message) - Constructor for exception org.apache.lucene.queryParser.standard.parser.ParseException
Constructor with message.- ParseException(Token, int[][], String[]) - Constructor for exception org.apache.lucene.queryParser.standard.parser.ParseException
This constructor is used by the method "generateParseException" in the generated parser.- 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(Token, int[][], String[]) - Constructor for exception org.apache.lucene.queryParser.ParseException
This constructor is used by the method "generateParseException" in the generated parser.- parseFloat(String) - Method in interface org.apache.lucene.search.FieldCache.FloatParser
Return an float representation of this field's value.- parseInt(char[]) - Static method in class org.apache.lucene.util.ArrayUtil
Parses the string argument as if it was an int value and returns the result.- parseInt(char[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
Parses a char array into an int.- parseInt(char[], int, int, int) - Static method in class org.apache.lucene.util.ArrayUtil
Parses the string argument as if it was an int value and returns the result.- parseInt(String) - Method in interface org.apache.lucene.search.FieldCache.IntParser
Return an integer representation of this field's value.- parseLatitudeLongitude(double[], String) - Static method in class org.apache.lucene.spatial.DistanceUtils
Deprecated.extract (by callingDistanceUtils.parsePoint(String[], String, int)
and validate the latitude and longitude contained in the String by making sure the latitude is between 90 & -90 and longitude is between -180 and 180.- parseLatitudeLongitude(String) - Static method in class org.apache.lucene.spatial.DistanceUtils
Deprecated.- 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
- parseLong(String) - Method in interface org.apache.lucene.search.FieldCache.LongParser
Return an long representation of this field's value.- parsePoint(String[], String, int) - Static method in class org.apache.lucene.spatial.DistanceUtils
Deprecated.Given a string containing dimension values encoded in it, separated by commas, return a String array of length dimension containing the values.- parsePointDouble(double[], String, int) - Static method in class org.apache.lucene.spatial.DistanceUtils
Deprecated.Given a string containing dimension values encoded in it, separated by commas, return a double array of length dimension containing the values.- parser - Variable in class org.apache.lucene.benchmark.byTask.feeds.LongToEnglishQueryMaker
- parser - Variable in class org.apache.lucene.xmlparser.CoreParser
- ParserException - Exception in org.apache.lucene.xmlparser
- ParserException() - Constructor for exception org.apache.lucene.xmlparser.ParserException
- ParserException(String) - Constructor for exception org.apache.lucene.xmlparser.ParserException
- ParserException(String, Throwable) - Constructor for exception org.apache.lucene.xmlparser.ParserException
- ParserException(Throwable) - Constructor for exception org.apache.lucene.xmlparser.ParserException
- ParserExtension - Class in org.apache.lucene.queryParser.ext
This class represents an extension base class to the Lucene standardQueryParser
.- ParserExtension() - Constructor for class org.apache.lucene.queryParser.ext.ParserExtension
- parseShort(String) - Method in interface org.apache.lucene.search.FieldCache.ShortParser
Return a short representation of this field's value.- partial - Variable in class org.apache.lucene.index.CheckIndex.Status
True if we checked only specific segments (CheckIndex.checkIndex(List)
) was called with non-null argument).- partitionName(CategoryListParams, int) - Static method in class org.apache.lucene.facet.util.PartitionsUtils
Partition name by its number- partitionNameByOrdinal(FacetIndexingParams, CategoryListParams, int) - Static method in class org.apache.lucene.facet.util.PartitionsUtils
Partition name by category ordinal- partitionNumber(FacetIndexingParams, int) - Static method in class org.apache.lucene.facet.util.PartitionsUtils
Partition number of an ordinal.- partitionNumber(FacetSearchParams, int) - Static method in class org.apache.lucene.facet.util.PartitionsUtils
- partitionOffset(FacetIndexingParams, int, TaxonomyReader) - Static method in class org.apache.lucene.facet.util.PartitionsUtils
Get the offset for a given partition.- partitionOffset(FacetSearchParams, int, TaxonomyReader) - Static method in class org.apache.lucene.facet.util.PartitionsUtils
- partitionSize - Variable in class org.apache.lucene.facet.search.StandardFacetsAccumulator
- partitionSize(FacetIndexingParams, TaxonomyReader) - Static method in class org.apache.lucene.facet.util.PartitionsUtils
Get the partition size in this parameter, or return the size of the taxonomy, which is smaller.- partitionSize(FacetSearchParams, TaxonomyReader) - Static method in class org.apache.lucene.facet.util.PartitionsUtils
- PartitionsUtils - Class in org.apache.lucene.facet.util
Utilities for partitions - sizes and such- PartitionsUtils() - Constructor for class org.apache.lucene.facet.util.PartitionsUtils
- PartOfSpeechAttribute - Interface in org.apache.lucene.analysis.ja.tokenattributes
Attribute forToken.getPartOfSpeech()
.- PartOfSpeechAttributeImpl - Class in org.apache.lucene.analysis.ja.tokenattributes
Attribute forToken.getPartOfSpeech()
.- PartOfSpeechAttributeImpl() - Constructor for class org.apache.lucene.analysis.ja.tokenattributes.PartOfSpeechAttributeImpl
- PathHierarchyTokenizer - Class in org.apache.lucene.analysis.path
Tokenizer for path-like hierarchies.- PathHierarchyTokenizer(Reader) - Constructor for class org.apache.lucene.analysis.path.PathHierarchyTokenizer
- PathHierarchyTokenizer(Reader, char, char) - Constructor for class org.apache.lucene.analysis.path.PathHierarchyTokenizer
- PathHierarchyTokenizer(Reader, char, char, int) - Constructor for class org.apache.lucene.analysis.path.PathHierarchyTokenizer
- PathHierarchyTokenizer(Reader, int) - Constructor for class org.apache.lucene.analysis.path.PathHierarchyTokenizer
- PathHierarchyTokenizer(Reader, int, char) - Constructor for class org.apache.lucene.analysis.path.PathHierarchyTokenizer
- PathHierarchyTokenizer(Reader, int, char, char, int) - Constructor for class org.apache.lucene.analysis.path.PathHierarchyTokenizer
- PathPolicy - Interface in org.apache.lucene.facet.index.categorypolicy
Filtering category paths inCategoryParentsStream
, where a given category is added to the stream, and than all its parents are being added one after the other by successively removing the last component.- PathQueryNode - Class in org.apache.lucene.queryParser.core.nodes
APathQueryNode
is used to store queries like /company/USA/California /product/shoes/brown.- PathQueryNode(List<PathQueryNode.QueryText>) - Constructor for class org.apache.lucene.queryParser.core.nodes.PathQueryNode
- PathQueryNode.QueryText - Class in org.apache.lucene.queryParser.core.nodes
- pathType(File) - 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- PatternAnalyzer - Class in org.apache.lucene.analysis.miscellaneous
Efficient Lucene analyzer/tokenizer that preferably operates on a String rather than aReader
, that can flexibly separate text into terms via a regular expressionPattern
(with behaviour identical toString.split(String)
), and that combines the functionality ofLetterTokenizer
,LowerCaseTokenizer
,WhitespaceTokenizer
,StopFilter
into a single efficient multi-purpose class.- PatternAnalyzer(Version, Pattern, boolean, Set<?>) - Constructor for class org.apache.lucene.analysis.miscellaneous.PatternAnalyzer
Constructs a new instance with the given parameters.- PatternConsumer - Interface in org.apache.lucene.analysis.compound.hyphenation
This interface is used to connect the XML pattern file parser to the hyphenation tree.- 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
- payload - Variable in class org.apache.lucene.facet.index.streaming.CategoryTokenizerBase
The object used for constructing payloads.- payload - Variable in class org.apache.lucene.search.payloads.PayloadTermQuery.PayloadTermWeight.PayloadTermSpanScorer
- Payload - Class in org.apache.lucene.index
A Payload is metadata that can be stored together with each occurrence of a term.- Payload() - Constructor for class org.apache.lucene.index.Payload
Creates an empty payload and does not allocate a byte array.- Payload(byte[]) - Constructor for class org.apache.lucene.index.Payload
Creates a new payload with the the given array as data.- Payload(byte[], int, int) - Constructor for class org.apache.lucene.index.Payload
Creates a new payload with the the given array as data.- payloadAttribute - Variable in class org.apache.lucene.facet.index.streaming.CategoryTokenizerBase
The stream's payload attribute.- PayloadAttribute - Interface in org.apache.lucene.analysis.tokenattributes
The payload of a Token.- PayloadAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
The payload of a Token.- PayloadAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
Initialize this attribute with no payload.- PayloadAttributeImpl(Payload) - Constructor for class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
Initialize this attribute with the given payload.- payloadBytes - Variable in class org.apache.lucene.facet.enhancements.EnhancementsCategoryTokenizer
The data buffer used for payload instance.- PayloadEncoder - Interface in org.apache.lucene.analysis.payloads
Mainly for use with the DelimitedPayloadTokenFilter, converts char buffers to Payload.- PayloadFunction - Class in org.apache.lucene.search.payloads
An abstract class that defines a way for Payload*Query instances to transform the cumulative effects of payload scores for a document.- PayloadFunction() - Constructor for class org.apache.lucene.search.payloads.PayloadFunction
- PayloadHelper - Class in org.apache.lucene.analysis.payloads
Utility methods for encoding payloads.- PayloadHelper() - Constructor for class org.apache.lucene.analysis.payloads.PayloadHelper
- PayloadIntDecodingIterator - Class in org.apache.lucene.facet.search
A payload deserializer comes with its own working space (buffer).- PayloadIntDecodingIterator(IndexReader, Term, IntDecoder) - Constructor for class org.apache.lucene.facet.search.PayloadIntDecodingIterator
- PayloadIntDecodingIterator(IndexReader, Term, IntDecoder, byte[]) - Constructor for class org.apache.lucene.facet.search.PayloadIntDecodingIterator
- PayloadIterator - Class in org.apache.lucene.facet.search
A utility class for iterating through a posting list of a given term and retrieving the payload of the first occurrence in every document.- PayloadIterator(IndexReader, Term) - Constructor for class org.apache.lucene.facet.search.PayloadIterator
- PayloadIterator(IndexReader, Term, byte[]) - Constructor for class org.apache.lucene.facet.search.PayloadIterator
- payloadLength - Variable in class org.apache.lucene.facet.search.PayloadIterator
- payloadLength() - Method in class org.apache.lucene.facet.index.FacetsPayloadProcessorProvider.FacetsPayloadProcessor
- payloadLength() - Method in class org.apache.lucene.index.PayloadProcessorProvider.PayloadProcessor
Returns the length of the payload that was returned byPayloadProcessorProvider.PayloadProcessor.processPayload(byte[], int, int)
.- PayloadNearQuery - Class in org.apache.lucene.search.payloads
This class is very similar toSpanNearQuery
except that it factors in the value of the payloads located at each of the positions where theTermSpans
occurs.- PayloadNearQuery(SpanQuery[], int, boolean) - Constructor for class org.apache.lucene.search.payloads.PayloadNearQuery
- PayloadNearQuery(SpanQuery[], int, boolean, PayloadFunction) - Constructor for class org.apache.lucene.search.payloads.PayloadNearQuery
- PayloadNearQuery.PayloadNearSpanScorer - Class in org.apache.lucene.search.payloads
- PayloadNearQuery.PayloadNearSpanWeight - Class in org.apache.lucene.search.payloads
- PayloadNearSpanScorer(Spans, Weight, Similarity, byte[]) - Constructor for class org.apache.lucene.search.payloads.PayloadNearQuery.PayloadNearSpanScorer
- PayloadNearSpanWeight(SpanQuery, Searcher) - Constructor for class org.apache.lucene.search.payloads.PayloadNearQuery.PayloadNearSpanWeight
- PayloadProcessor() - Constructor for class org.apache.lucene.index.PayloadProcessorProvider.PayloadProcessor
- PayloadProcessorProvider - Class in org.apache.lucene.index
Provides aPayloadProcessorProvider.ReaderPayloadProcessor
to be used for aDirectory
.- PayloadProcessorProvider() - Constructor for class org.apache.lucene.index.PayloadProcessorProvider
- PayloadProcessorProvider.DirPayloadProcessor - Class in org.apache.lucene.index
Deprecated.UsePayloadProcessorProvider.ReaderPayloadProcessor
instead.- PayloadProcessorProvider.PayloadProcessor - Class in org.apache.lucene.index
Processes the given payload.- PayloadProcessorProvider.ReaderPayloadProcessor - Class in org.apache.lucene.index
Returns aPayloadProcessorProvider.PayloadProcessor
for a givenTerm
which allows processing the payloads of different terms differently.- payloadScore - Variable in class org.apache.lucene.search.payloads.PayloadNearQuery.PayloadNearSpanScorer
- payloadScore - Variable in class org.apache.lucene.search.payloads.PayloadTermQuery.PayloadTermWeight.PayloadTermSpanScorer
- PayloadSpanUtil - Class in org.apache.lucene.search.payloads
Experimental class to get set of payloads for most standard Lucene queries.- PayloadSpanUtil(IndexReader) - Constructor for class org.apache.lucene.search.payloads.PayloadSpanUtil
- payloadsSeen - Variable in class org.apache.lucene.search.payloads.PayloadTermQuery.PayloadTermWeight.PayloadTermSpanScorer
- payloadStream - Variable in class org.apache.lucene.facet.enhancements.association.AssociationListTokenizer
- payloadStreamIterator - Variable in class org.apache.lucene.facet.index.streaming.CountingListTokenizer
An iterator over the payload streams- payloadStreamsByName - Variable in class org.apache.lucene.facet.index.streaming.CountingListTokenizer
A table for retrieving payload streams by category-list name.- PayloadTermQuery - Class in org.apache.lucene.search.payloads
This class is very similar toSpanTermQuery
except that it factors in the value of the payload located at each of the positions where theTerm
occurs.- PayloadTermQuery(Term, PayloadFunction) - Constructor for class org.apache.lucene.search.payloads.PayloadTermQuery
- PayloadTermQuery(Term, PayloadFunction, boolean) - Constructor for class org.apache.lucene.search.payloads.PayloadTermQuery
- PayloadTermQuery.PayloadTermWeight - Class in org.apache.lucene.search.payloads
- PayloadTermQuery.PayloadTermWeight.PayloadTermSpanScorer - Class in org.apache.lucene.search.payloads
- PayloadTermSpanScorer(TermSpans, Weight, Similarity, byte[]) - Constructor for class org.apache.lucene.search.payloads.PayloadTermQuery.PayloadTermWeight.PayloadTermSpanScorer
- PayloadTermWeight(PayloadTermQuery, Searcher) - Constructor for class org.apache.lucene.search.payloads.PayloadTermQuery.PayloadTermWeight
- payloadToMatch - Variable in class org.apache.lucene.search.spans.SpanNearPayloadCheckQuery
- payloadToMatch - Variable in class org.apache.lucene.search.spans.SpanPayloadCheckQuery
- peekToken() - Method in class org.apache.lucene.analysis.LookaheadTokenFilter
Returns true if there is a new token.- PER_NODE_IN_TREE - org.apache.lucene.facet.search.params.FacetRequest.ResultMode
Limits are applied per node, and the result has a full tree structure.- PerDimensionIndexingParams - Class in org.apache.lucene.facet.index.params
A FacetIndexingParams that utilizes different category lists, defined by the dimension specified CategoryPaths (seePerDimensionIndexingParams.addCategoryListParams(CategoryPath, CategoryListParams)
- PerDimensionIndexingParams() - Constructor for class org.apache.lucene.facet.index.params.PerDimensionIndexingParams
Construct with the defaultCategoryListParams
as the default CategoryListParams for unspecified CategoryPaths.- PerDimensionIndexingParams(CategoryListParams) - Constructor for class org.apache.lucene.facet.index.params.PerDimensionIndexingParams
Construct with the included categoryListParams as the default CategoryListParams for unspecified CategoryPaths.- PerFieldAnalyzerWrapper - Class in org.apache.lucene.analysis
This analyzer is used to facilitate scenarios where different fields require different analysis techniques.- PerFieldAnalyzerWrapper(Analyzer) - Constructor for class org.apache.lucene.analysis.PerFieldAnalyzerWrapper
Constructs with default analyzer.- PerFieldAnalyzerWrapper(Analyzer, Map<String, Analyzer>) - Constructor for class org.apache.lucene.analysis.PerFieldAnalyzerWrapper
Constructs with default analyzer and a map of analyzers to use for specific fields.- 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
- permutationIterator() - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.Matrix
Deprecated.- PersianAnalyzer - Class in org.apache.lucene.analysis.fa
Analyzer
for Persian.- PersianAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.fa.PersianAnalyzer
Builds an analyzer with the default stop words:PersianAnalyzer.DEFAULT_STOPWORD_FILE
.- PersianAnalyzer(Version, File) - Constructor for class org.apache.lucene.analysis.fa.PersianAnalyzer
Deprecated.usePersianAnalyzer(Version, Set)
instead- PersianAnalyzer(Version, String...) - Constructor for class org.apache.lucene.analysis.fa.PersianAnalyzer
Deprecated.usePersianAnalyzer(Version, Set)
instead- PersianAnalyzer(Version, Hashtable<?, ?>) - Constructor for class org.apache.lucene.analysis.fa.PersianAnalyzer
Deprecated.usePersianAnalyzer(Version, Set)
instead- PersianAnalyzer(Version, Set<?>) - 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(CharStream) - Constructor for class org.apache.lucene.analysis.fa.PersianCharFilter
- PersianNormalizationFilter - Class in org.apache.lucene.analysis.fa
ATokenFilter
that appliesPersianNormalizer
to normalize the orthography.- PersianNormalizationFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.fa.PersianNormalizationFilter
- 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
ASnapshotDeletionPolicy
which adds a persistence layer so that snapshots can be maintained across the life of an application.- PersistentSnapshotDeletionPolicy(IndexDeletionPolicy, Directory, IndexWriterConfig.OpenMode, Version) - Constructor for class org.apache.lucene.index.PersistentSnapshotDeletionPolicy
PersistentSnapshotDeletionPolicy
wraps anotherIndexDeletionPolicy
to enable flexible snapshotting.- 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
- PHRASE_SLOP - Static variable in class org.apache.lucene.queryParser.standard.config.StandardQueryConfigHandler.ConfigurationKeys
Key used to set the default phrase slop- PhraseQuery - Class in org.apache.lucene.search
A Query that matches documents containing a particular sequence of terms.- PhraseQuery() - Constructor for class org.apache.lucene.search.PhraseQuery
Constructs an empty phrase query.- PhraseQueryNodeBuilder - Class in org.apache.lucene.queryParser.standard.builders
Builds aPhraseQuery
object from aTokenizedPhraseQueryNode
object.- PhraseQueryNodeBuilder() - Constructor for class org.apache.lucene.queryParser.standard.builders.PhraseQueryNodeBuilder
- PhraseSlopQueryNode - Class in org.apache.lucene.queryParser.core.nodes
- PhraseSlopQueryNode(QueryNode, int) - Constructor for class org.apache.lucene.queryParser.core.nodes.PhraseSlopQueryNode
- PhraseSlopQueryNodeProcessor - Class in org.apache.lucene.queryParser.standard.processors
This processor removes invalidSlopQueryNode
objects in the query node tree.- PhraseSlopQueryNodeProcessor() - Constructor for class org.apache.lucene.queryParser.standard.processors.PhraseSlopQueryNodeProcessor
- PKIndexSplitter - Class in org.apache.lucene.index
Split an index based on aFilter
.- PKIndexSplitter(Directory, Directory, Directory, Term) - Constructor for class org.apache.lucene.index.PKIndexSplitter
Deprecated.usePKIndexSplitter(Version, Directory, Directory, Directory, Term)
instead. This constructor will be removed in Lucene 4.0.- PKIndexSplitter(Directory, Directory, Directory, Term, IndexWriterConfig, IndexWriterConfig) - Constructor for class org.apache.lucene.index.PKIndexSplitter
- PKIndexSplitter(Directory, Directory, Directory, Filter) - Constructor for class org.apache.lucene.index.PKIndexSplitter
Deprecated.usePKIndexSplitter(Version, Directory, Directory, Directory, Filter)
instead. This constructor will be removed in Lucene 4.0.- PKIndexSplitter(Directory, Directory, Directory, Filter, IndexWriterConfig, IndexWriterConfig) - Constructor for class org.apache.lucene.index.PKIndexSplitter
- PKIndexSplitter(Version, 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(Version, Directory, Directory, Directory, Filter) - Constructor for class org.apache.lucene.index.PKIndexSplitter
Split an index based on aFilter
.- PLAIN - org.apache.lucene.benchmark.byTask.utils.StreamUtils.Type
Plain text is used for anything which is not GZIP or BZIP.- PLAIN_NORMS_EXTENSION - Static variable in class org.apache.lucene.index.IndexFileNames
Extension of plain norms- PLAINTEXT_FIELD_NAME - Static variable in class org.apache.lucene.queryParser.core.nodes.QueryNodeImpl
- PlainTextDictionary - Class in org.apache.lucene.search.spell
Dictionary represented by a text file.- PlainTextDictionary(File) - Constructor for class org.apache.lucene.search.spell.PlainTextDictionary
- PlainTextDictionary(InputStream) - Constructor for class org.apache.lucene.search.spell.PlainTextDictionary
- PlainTextDictionary(Reader) - Constructor for class org.apache.lucene.search.spell.PlainTextDictionary
Creates a dictionary based on a reader.- PLUS - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
RegularExpression Id.- PLUS - Static variable in interface org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserConstants
RegularExpression Id.- PM_FAST_INVALIDATION - Static variable in class org.apache.lucene.search.DuplicateFilter
- PM_FULL_VALIDATION - Static variable in class org.apache.lucene.search.DuplicateFilter
- Point2D - Class in org.apache.lucene.spatial.geometry.shape
Deprecated.- Point2D() - Constructor for class org.apache.lucene.spatial.geometry.shape.Point2D
Deprecated.- Point2D(double, double) - Constructor for class org.apache.lucene.spatial.geometry.shape.Point2D
Deprecated.- Point2D(Point2D) - Constructor for class org.apache.lucene.spatial.geometry.shape.Point2D
Deprecated.- pointOnBearing(double, double, double, double, double[], double) - Static method in class org.apache.lucene.spatial.DistanceUtils
Deprecated.Given a start point (startLat, startLon) and a bearing on a sphere of radius sphereRadius, return the destination point.- 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.- PolishAnalyzer - Class in org.apache.lucene.analysis.pl
Analyzer
for Polish.- PolishAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.pl.PolishAnalyzer
Builds an analyzer with the default stop words:PolishAnalyzer.DEFAULT_STOPWORD_FILE
.- PolishAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.pl.PolishAnalyzer
Builds an analyzer with the given stop words.- PolishAnalyzer(Version, Set<?>, Set<?>) - Constructor for class org.apache.lucene.analysis.pl.PolishAnalyzer
Builds an analyzer with the given stop words.- pop() - Method in interface org.apache.lucene.facet.search.Heap
Get and remove the top of the Heap
NOTE: OnceHeap.pop()
is called no otherHeap.add(Object)
orHeap.insertWithOverflow(Object)
should be called.- pop() - Method in class org.apache.lucene.search.vectorhighlight.FieldTermStack
- pop() - Method in class org.apache.lucene.util.PriorityQueue
Removes and returns the least element of the PriorityQueue in log(size) time.- pop() - Method in class org.apache.lucene.util.ScorerDocQueue
Deprecated.Removes and returns the least scorer of the ScorerDocQueue in log(size) time.- pop(long) - Static method in class org.apache.lucene.util.BitUtil
Returns the number of bits set in the long- pop_andnot(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.- 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
- 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
Transforms the token stream as per the Porter stemming algorithm.- PorterStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.PorterStemFilter
- PorterStemmer - Class in org.tartarus.snowball.ext
Generated class implementing code defined by a snowball script.- PorterStemmer() - Constructor for class org.tartarus.snowball.ext.PorterStemmer
- PortugueseAnalyzer - Class in org.apache.lucene.analysis.pt
Analyzer
for Portuguese.- PortugueseAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.pt.PortugueseAnalyzer
Builds an analyzer with the default stop words:PortugueseAnalyzer.DEFAULT_STOPWORD_FILE
.- PortugueseAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.pt.PortugueseAnalyzer
Builds an analyzer with the given stop words.- PortugueseAnalyzer(Version, Set<?>, Set<?>) - 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
ATokenFilter
that appliesPortugueseLightStemmer
to stem Portuguese words.- PortugueseLightStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.pt.PortugueseLightStemFilter
- 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
ATokenFilter
that appliesPortugueseMinimalStemmer
to stem Portuguese words.- PortugueseMinimalStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.pt.PortugueseMinimalStemFilter
- 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
ATokenFilter
that appliesPortugueseStemmer
to stem Portuguese words.- PortugueseStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.pt.PortugueseStemFilter
- PortugueseStemmer - Class in org.apache.lucene.analysis.pt
Portuguese stemmer implementing the RSLP (Removedor de Sufixos da Lingua Portuguesa) algorithm.- PortugueseStemmer - Class in org.tartarus.snowball.ext
Generated class implementing code defined by a snowball script.- PortugueseStemmer() - Constructor for class org.apache.lucene.analysis.pt.PortugueseStemmer
- PortugueseStemmer() - Constructor for class org.tartarus.snowball.ext.PortugueseStemmer
- pos - Variable in class org.apache.lucene.util.fst.FST.BytesReader
- pos - Variable in class org.apache.lucene.util.Vint8.Position
The value passed by reference.- POSDICT_FILENAME_SUFFIX - Static variable in class org.apache.lucene.analysis.ja.dict.BinaryDictionary
- POSDICT_HEADER - Static variable in class org.apache.lucene.analysis.ja.dict.BinaryDictionary
- posIncAtt - Variable in class org.apache.lucene.analysis.LookaheadTokenFilter
- position - Variable in class org.apache.lucene.search.spans.TermSpans
- Position() - Constructor for class org.apache.lucene.analysis.LookaheadTokenFilter.Position
- Position() - Constructor for class org.apache.lucene.util.Vint8.Position
Creates a position value set to zero.- Position(int) - Constructor for class org.apache.lucene.util.Vint8.Position
Creates a position set toinitialPosition
.- PositionBasedTermVectorMapper - Class in org.apache.lucene.index
For each Field, store position by position information.- PositionBasedTermVectorMapper() - Constructor for class org.apache.lucene.index.PositionBasedTermVectorMapper
- PositionBasedTermVectorMapper(boolean) - Constructor for class org.apache.lucene.index.PositionBasedTermVectorMapper
- PositionBasedTermVectorMapper.TVPositionInfo - Class in org.apache.lucene.index
Container for a term at a position- PositionCheckingMap() - Constructor for class org.apache.lucene.search.highlight.WeightedSpanTermExtractor.PositionCheckingMap
- PositionCheckSpan(IndexReader) - Constructor for class org.apache.lucene.search.spans.SpanPositionCheckQuery.PositionCheckSpan
- PositionFilter - Class in org.apache.lucene.analysis.position
Set the positionIncrement of all tokens to the "positionIncrement", except the first return token which retains its original positionIncrement value.- PositionFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.position.PositionFilter
Constructs a PositionFilter that assigns a position increment of zero to all but the first token from the given input stream.- PositionFilter(TokenStream, int) - Constructor for class org.apache.lucene.analysis.position.PositionFilter
Constructs a PositionFilter that assigns the given position increment to all but the first token from the given input stream.- positionIncrement - Variable in class org.apache.lucene.queryParser.core.nodes.FieldQueryNode
The term's position increment.- PositionIncrementAttribute - Interface in org.apache.lucene.analysis.tokenattributes
The positionIncrement 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
The positionIncrement determines the position of this token relative to the previous Token in aTokenStream
, used in phrase searching.- PositionIncrementAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
- PositionIncrementsAttribute - Interface in org.apache.lucene.queryParser.standard.config
Deprecated.- PositionIncrementsAttributeImpl - Class in org.apache.lucene.queryParser.standard.config
Deprecated.- PositionIncrementsAttributeImpl() - Constructor for class org.apache.lucene.queryParser.standard.config.PositionIncrementsAttributeImpl
Deprecated.- PositionInfo(int) - Constructor for class org.apache.lucene.search.SpanFilterResult.PositionInfo
- PositionLengthAttribute - Interface in org.apache.lucene.analysis.tokenattributes
The positionLength 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
- positions - Variable in class org.apache.lucene.analysis.LookaheadTokenFilter
- positions - Variable in class org.apache.lucene.search.payloads.PayloadTermQuery.PayloadTermWeight.PayloadTermSpanScorer
- positions - Variable 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 FSTOutputs
implementation where each output is a non-negative long value.- PositiveScoresOnlyCollector - Class in org.apache.lucene.search
- 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
- postBreak - Variable in class org.apache.lucene.analysis.compound.hyphenation.Hyphen
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.core.processors.NoChildOptimizationQueryNodeProcessor
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorImpl
This method is invoked for every node when walking up the tree.- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.core.processors.RemoveDeletedQueryNodesProcessor
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.precedence.processors.BooleanModifiersQueryNodeProcessor
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.AllowLeadingWildcardProcessor
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.AnalyzerQueryNodeProcessor
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.BooleanQuery2ModifierNodeProcessor
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.BooleanSingleChildOptimizationQueryNodeProcessor
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.BoostQueryNodeProcessor
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.DefaultPhraseSlopQueryNodeProcessor
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.FuzzyQueryNodeProcessor
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.LowercaseExpandedTermsQueryNodeProcessor
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.MatchAllDocsQueryNodeProcessor
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.MultiFieldQueryNodeProcessor
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.MultiTermRewriteMethodProcessor
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.NumericQueryNodeProcessor
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.NumericRangeQueryNodeProcessor
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.ParametricRangeQueryNodeProcessor
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.PhraseSlopQueryNodeProcessor
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.RemoveEmptyNonLeafQueryNodeProcessor
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.WildcardQueryNodeProcessor
- postTags - Variable in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
- 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
- PrecedenceQueryNodeProcessorPipeline - Class in org.apache.lucene.queryParser.precedence.processors
This processor pipeline extendsStandardQueryNodeProcessorPipeline
and enables boolean precedence on it.- PrecedenceQueryNodeProcessorPipeline(QueryConfigHandler) - Constructor for class org.apache.lucene.queryParser.precedence.processors.PrecedenceQueryNodeProcessorPipeline
- PrecedenceQueryParser - Class in org.apache.lucene.queryParser.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.precedence.PrecedenceQueryParser
- PrecedenceQueryParser(Analyzer) - Constructor for class org.apache.lucene.queryParser.precedence.PrecedenceQueryParser
- precise - Variable in class org.apache.lucene.spatial.tier.DistanceFilter
Deprecated.- PRECISION_STEP_DEFAULT - Static variable in class org.apache.lucene.util.NumericUtils
The default precision step used byNumericField
,NumericTokenStream
,NumericRangeQuery
, andNumericRangeFilter
as default- prefix - Variable in class org.apache.lucene.benchmark.byTask.tasks.RepSumByPrefTask
- prefix() - Method in class org.apache.lucene.search.regex.JakartaRegexpCapabilities
- prefix() - Method in class org.apache.lucene.search.regex.JavaUtilRegexCapabilities
- prefix() - Method in interface org.apache.lucene.search.regex.RegexCapabilities
A wise prefix implementation can reduce the term enumeration (and thus increase performance) of RegexQuery dramatically!- PrefixAndSuffixAwareTokenFilter - Class in org.apache.lucene.analysis.miscellaneous
Links twoPrefixAwareTokenFilter
.- PrefixAndSuffixAwareTokenFilter(TokenStream, TokenStream, TokenStream) - Constructor for class org.apache.lucene.analysis.miscellaneous.PrefixAndSuffixAwareTokenFilter
- PrefixAwareTokenFilter - Class in org.apache.lucene.analysis.miscellaneous
Joins two token streams and leaves the last token of the first stream available to be used when updating the token values in the second stream based on that token.- PrefixAwareTokenFilter(TokenStream, TokenStream) - Constructor for class org.apache.lucene.analysis.miscellaneous.PrefixAwareTokenFilter
- prefixCodedToDouble(String) - Static method in class org.apache.lucene.util.NumericUtils
- prefixCodedToFloat(String) - Static method in class org.apache.lucene.util.NumericUtils
- prefixCodedToInt(String) - Static method in class org.apache.lucene.util.NumericUtils
- prefixCodedToLong(String) - Static method in class org.apache.lucene.util.NumericUtils
- 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.- prefixes - Static variable in class org.apache.lucene.analysis.ar.ArabicStemmer
- PrefixFilter - Class in org.apache.lucene.search
A Filter that restricts search results to values that have a matching prefix in a given field.- PrefixFilter(Term) - Constructor for class org.apache.lucene.search.PrefixFilter
- 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 withprefix
.- PREFIXTERM - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
RegularExpression Id.- PrefixTermEnum - Class in org.apache.lucene.search
Subclass of FilteredTermEnum for enumerating all terms that match the specified prefix filter term.- PrefixTermEnum(IndexReader, Term) - Constructor for class org.apache.lucene.search.PrefixTermEnum
- prefixToString(StringBuilder) - Method in class org.apache.lucene.queryParser.surround.query.ComposedQuery
- PrefixWildcardQueryNode - Class in org.apache.lucene.queryParser.standard.nodes
APrefixWildcardQueryNode
represents wildcardquery that matches abc* or *.- PrefixWildcardQueryNode(CharSequence, CharSequence, int, int) - Constructor for class org.apache.lucene.queryParser.standard.nodes.PrefixWildcardQueryNode
- PrefixWildcardQueryNode(FieldQueryNode) - Constructor for class org.apache.lucene.queryParser.standard.nodes.PrefixWildcardQueryNode
- PrefixWildcardQueryNodeBuilder - Class in org.apache.lucene.queryParser.standard.builders
Builds aPrefixQuery
object from aPrefixWildcardQueryNode
object.- PrefixWildcardQueryNodeBuilder() - Constructor for class org.apache.lucene.queryParser.standard.builders.PrefixWildcardQueryNodeBuilder
- 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 class org.apache.lucene.store.ChecksumIndexOutput
Starts but does not complete the commit of this file (= writing of the final checksum at the end).- prepareCommit() - Method in interface org.apache.lucene.util.TwoPhaseCommit
The first stage of a 2-phase commit.- prepareCommit() - Method in class org.apache.lucene.util.TwoPhaseCommitTool.TwoPhaseCommitWrapper
- prepareCommit(Map<String, String>) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
Like above, and also prepares to store user data with the index.- prepareCommit(Map<String, String>) - Method in class org.apache.lucene.index.IndexWriter
Expert: prepare for commit, specifying commitUserData Map (String -> String).- prepareCommit(Map<String, String>) - Method in interface org.apache.lucene.util.TwoPhaseCommit
LikeTwoPhaseCommit.commit()
, but takes an additional commit data to be included w/ the commit.- prepareCommit(Map<String, String>) - Method in class org.apache.lucene.util.TwoPhaseCommitTool.TwoPhaseCommitWrapper
- PrepareCommitFailException(Throwable, TwoPhaseCommit) - Constructor for exception org.apache.lucene.util.TwoPhaseCommitTool.PrepareCommitFailException
- 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
- prependOutput(T) - Method in class org.apache.lucene.util.fst.Builder.UnCompiledNode
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.core.processors.NoChildOptimizationQueryNodeProcessor
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorImpl
This method is invoked for every node when walking down the tree.- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.core.processors.RemoveDeletedQueryNodesProcessor
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.precedence.processors.BooleanModifiersQueryNodeProcessor
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.AllowLeadingWildcardProcessor
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.AnalyzerQueryNodeProcessor
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.BooleanQuery2ModifierNodeProcessor
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.BooleanSingleChildOptimizationQueryNodeProcessor
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.BoostQueryNodeProcessor
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.DefaultPhraseSlopQueryNodeProcessor
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.FuzzyQueryNodeProcessor
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.LowercaseExpandedTermsQueryNodeProcessor
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.MatchAllDocsQueryNodeProcessor
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.MultiFieldQueryNodeProcessor
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.MultiTermRewriteMethodProcessor
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.NumericQueryNodeProcessor
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.NumericRangeQueryNodeProcessor
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.ParametricRangeQueryNodeProcessor
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.PhraseSlopQueryNodeProcessor
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.RemoveEmptyNonLeafQueryNodeProcessor
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.WildcardQueryNodeProcessor
- preTags - Variable in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
- prevCharIsCR - Variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
- prevCharIsCR - Variable in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
- prevCharIsLF - Variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
- prevCharIsLF - Variable in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
- previous() - Method in class org.apache.lucene.analysis.icu.segmentation.LaoBreakIterator
- previous() - Method in class org.apache.lucene.analysis.util.CharArrayIterator
- prevSetBit(int) - Method in class org.apache.lucene.util.FixedBitSet
Returns the index of the last set bit before or on the index specified.- prevSetBit(int) - Method in class org.apache.lucene.util.OpenBitSet
Returns the index of the first set bit starting downwards at the index specified.- prevSetBit(long) - Method in class org.apache.lucene.util.OpenBitSet
Returns the index of the first set bit starting downwards at the index specified.- PrimaryQuery() - Method in class org.apache.lucene.queryParser.surround.parser.QueryParser
- print() - Method in class org.egothor.stemmer.Row
Write the contents of this Row to stdout.- printBaseHash() - Method in class org.apache.lucene.util.collections.IntHashSet
Prints the baseHash array, used for debug purposes.- printInfo(CharSequence) - Method in class org.egothor.stemmer.MultiTrie
Print the given prefix and the position(s) in the Trie where it appears.- printInfo(CharSequence) - Method in class org.egothor.stemmer.Trie
- 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() - Method in class org.apache.lucene.analysis.compound.hyphenation.HyphenationTree
- printStats() - Method in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
- 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() - Constructor for class org.apache.lucene.util.PriorityQueue
- process(String) - Method in class org.apache.lucene.analysis.cn.smart.hhmm.HHMMSegmenter
Return a list ofSegToken
representing the best segmentation of a sentence- process(QueryNode) - Method in interface org.apache.lucene.queryParser.core.processors.QueryNodeProcessor
Processes a query node tree.- process(QueryNode) - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorImpl
- process(QueryNode) - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorPipeline
For reference about this method check:QueryNodeProcessor.process(QueryNode)
.- process(QueryNode) - Method in class org.apache.lucene.queryParser.core.processors.RemoveDeletedQueryNodesProcessor
- process(QueryNode) - Method in class org.apache.lucene.queryParser.precedence.processors.BooleanModifiersQueryNodeProcessor
- process(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.AllowLeadingWildcardProcessor
- process(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.AnalyzerQueryNodeProcessor
- process(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.BooleanQuery2ModifierNodeProcessor
- process(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.DefaultPhraseSlopQueryNodeProcessor
- process(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.GroupQueryNodeProcessor
Deprecated.- process(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.LowercaseExpandedTermsQueryNodeProcessor
- process(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.RemoveEmptyNonLeafQueryNodeProcessor
- processChildren(QueryNode) - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorImpl
This method is called every time a child is processed.- processChildren(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.BooleanQuery2ModifierNodeProcessor
- processChildren(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.DefaultPhraseSlopQueryNodeProcessor
- processChildren(QueryNode) - Method in class org.apache.lucene.queryParser.standard.processors.MultiFieldQueryNodeProcessor
- processPayload(byte[], int, int) - Method in class org.apache.lucene.facet.index.FacetsPayloadProcessorProvider.FacetsPayloadProcessor
- processPayload(byte[], int, int) - Method in class org.apache.lucene.index.PayloadProcessorProvider.PayloadProcessor
Process the incoming payload and returns the resulting byte[].- processPayload(Similarity) - Method in class org.apache.lucene.search.payloads.PayloadTermQuery.PayloadTermWeight.PayloadTermSpanScorer
- processPayloads(Collection<byte[]>, int, int) - Method in class org.apache.lucene.search.payloads.PayloadNearQuery.PayloadNearSpanScorer
By default, uses thePayloadFunction
to score the payloads, but can be overridden to do other things.- properties - Variable in class org.apache.lucene.facet.index.attributes.CategoryAttributeImpl
A map of properties associated to the current category path.- PROX_EXTENSION - Static variable in class org.apache.lucene.index.IndexFileNames
Extension of prox postings file- ProximityQueryNode - Class in org.apache.lucene.queryParser.core.nodes
AProximityQueryNode
represents a query where the terms should meet specific distance conditions.- ProximityQueryNode(List<QueryNode>, CharSequence, ProximityQueryNode.Type, boolean) - Constructor for class org.apache.lucene.queryParser.core.nodes.ProximityQueryNode
- ProximityQueryNode(List<QueryNode>, CharSequence, ProximityQueryNode.Type, int, boolean) - Constructor for class org.apache.lucene.queryParser.core.nodes.ProximityQueryNode
- ProximityQueryNode.ProximityType - Class in org.apache.lucene.queryParser.core.nodes
- ProximityQueryNode.Type - Enum in org.apache.lucene.queryParser.core.nodes
- ProximityType(ProximityQueryNode.Type) - Constructor for class org.apache.lucene.queryParser.core.nodes.ProximityQueryNode.ProximityType
- ProximityType(ProximityQueryNode.Type, int) - Constructor for class org.apache.lucene.queryParser.core.nodes.ProximityQueryNode.ProximityType
- prune(SearcherLifetimeManager.Pruner) - Method in class org.apache.lucene.search.SearcherLifetimeManager
Calls providedSearcherLifetimeManager.Pruner
to prune entries.- pruneAllFieldPostings(String) - Method in class org.apache.lucene.index.pruning.TermPruningPolicy
Pruning of all postings for a field- pruneAllPositions(TermPositions, Term) - Method in class org.apache.lucene.index.pruning.CarmelTopKTermPruningPolicy
- pruneAllPositions(TermPositions, Term) - Method in class org.apache.lucene.index.pruning.CarmelUniformTermPruningPolicy
- pruneAllPositions(TermPositions, Term) - Method in class org.apache.lucene.index.pruning.RIDFTermPruningPolicy
- pruneAllPositions(TermPositions, Term) - Method in class org.apache.lucene.index.pruning.TermPruningPolicy
Prune all postings per term (invoked once per term per doc)- pruneAllPositions(TermPositions, Term) - Method in class org.apache.lucene.index.pruning.TFTermPruningPolicy
- PruneByAge(double) - Constructor for class org.apache.lucene.search.SearcherLifetimeManager.PruneByAge
- pruneDeletedSegments() - Method in class org.apache.lucene.index.SegmentInfos
Prunes any segment whose docs are all deleted.- pruneDocument(int, FieldSelector) - Method in class org.apache.lucene.index.pruning.StorePruningPolicy
Prune stored fields of a document.- prunedVecCount - Variable in class org.apache.lucene.index.PruningReader
- prunePayload(TermPositions, Term) - Method in class org.apache.lucene.index.pruning.TermPruningPolicy
Called when checking for the presence of payload for the current term at a current position- pruneSomePositions(int, int[], Term) - Method in class org.apache.lucene.index.pruning.CarmelTopKTermPruningPolicy
- pruneSomePositions(int, int[], Term) - Method in class org.apache.lucene.index.pruning.CarmelUniformTermPruningPolicy
- pruneSomePositions(int, int[], Term) - Method in class org.apache.lucene.index.pruning.RIDFTermPruningPolicy
- pruneSomePositions(int, int[], Term) - Method in class org.apache.lucene.index.pruning.TermPruningPolicy
Prune some postings per term (invoked once per term per doc).- pruneSomePositions(int, int[], Term) - Method in class org.apache.lucene.index.pruning.TFTermPruningPolicy
- pruneTermEnum(TermEnum) - Method in class org.apache.lucene.index.pruning.CarmelTopKTermPruningPolicy
- pruneTermEnum(TermEnum) - Method in class org.apache.lucene.index.pruning.CarmelUniformTermPruningPolicy
- pruneTermEnum(TermEnum) - Method in class org.apache.lucene.index.pruning.RIDFTermPruningPolicy
- pruneTermEnum(TermEnum) - Method in class org.apache.lucene.index.pruning.TermPruningPolicy
Pruning of all postings for a term (invoked once per term).- pruneTermEnum(TermEnum) - Method in class org.apache.lucene.index.pruning.TFTermPruningPolicy
- pruneTermVectorTerms(int, String, String[], int[], TermFreqVector) - Method in class org.apache.lucene.index.pruning.CarmelTopKTermPruningPolicy
- pruneTermVectorTerms(int, String, String[], int[], TermFreqVector) - Method in class org.apache.lucene.index.pruning.CarmelUniformTermPruningPolicy
- pruneTermVectorTerms(int, String, String[], int[], TermFreqVector) - Method in class org.apache.lucene.index.pruning.RIDFTermPruningPolicy
- pruneTermVectorTerms(int, String, String[], int[], TermFreqVector) - Method in class org.apache.lucene.index.pruning.TermPruningPolicy
Pruning of individual terms in term vectors.- pruneTermVectorTerms(int, String, String[], int[], TermFreqVector) - Method in class org.apache.lucene.index.pruning.TFTermPruningPolicy
- pruneWholeTermVector(int, String) - Method in class org.apache.lucene.index.pruning.TermPruningPolicy
Term vector pruning.- PruningPolicy - Class in org.apache.lucene.index.pruning
General Definitions for Index Pruning, such as operations to be performed on field data.- PruningPolicy() - Constructor for class org.apache.lucene.index.pruning.PruningPolicy
- PruningReader - Class in org.apache.lucene.index
This class produces a subset of the input index, by removing some postings data according to rules implemented in aTermPruningPolicy
, and optionally it can also remove stored fields of documents according to rules implemented in aStorePruningPolicy
.- PruningReader(IndexReader, StorePruningPolicy, TermPruningPolicy) - Constructor for class org.apache.lucene.index.PruningReader
Constructor.- PruningTool - Class in org.apache.lucene.index.pruning
A command-line tool to configure and run aPruningReader
on an input index and produce a pruned output index usingIndexWriter.addIndexes(IndexReader...)
.- PruningTool() - Constructor for class org.apache.lucene.index.pruning.PruningTool
- PUA_EC00_MARKER - Static variable in class org.apache.lucene.analysis.reverse.ReverseStringFilter
Example marker character: U+EC00 (PRIVATE USE AREA: EC00)- Punct - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
RegularExpression Id.- purge(IndexReader) - Method in interface org.apache.lucene.search.FieldCache
Expert: drops all cache entries associated with this reader.- purgeAllCaches() - Method in interface org.apache.lucene.search.FieldCache
EXPERT: Instructs the FieldCache to forcibly expunge all entries from the underlying caches.- purgeFieldCache(FieldCache) - Method in class org.apache.lucene.util.LuceneTestCase
Forcible purges all cache entries from the FieldCache.- push(FieldTermStack.TermInfo) - Method in class org.apache.lucene.search.vectorhighlight.FieldTermStack
- put(char[], V) - Method in class org.apache.lucene.analysis.CharArrayMap
Add the given mapping.- put(float, T) - Method in class org.apache.lucene.util.collections.FloatToObjectMap
Inserts the <key,value> pair into the map.- put(int) - Method in class org.apache.lucene.search.grouping.SentinelIntSet
- 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(int, double) - Method in class org.apache.lucene.util.collections.IntToDoubleMap
Inserts the <key,value> pair into the map.- put(int, int) - Method in class org.apache.lucene.util.collections.IntToIntMap
Inserts the <key,value> pair into the map.- put(int, T) - Method in class org.apache.lucene.util.collections.IntToObjectMap
Inserts the <key,value> pair into the map.- put(CharSequence, Object) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
Stores a value in the trie.- put(CharSequence, V) - Method in class org.apache.lucene.analysis.CharArrayMap
Add the given mapping.- put(Object, V) - Method in class org.apache.lucene.analysis.CharArrayMap
- put(String, V) - Method in class org.apache.lucene.analysis.CharArrayMap
Add the given mapping.- put(K, float) - Method in class org.apache.lucene.util.collections.ObjectToFloatMap
Inserts the <key,value> pair into the map.- put(K, int) - Method in class org.apache.lucene.util.collections.ObjectToIntMap
Inserts the <key,value> pair into the map.- put(K, WeightedSpanTerm) - Method in class org.apache.lucene.search.highlight.WeightedSpanTermExtractor.PositionCheckingMap
- put(K, V) - Method in class org.apache.lucene.util.collections.ArrayHashMap
Inserts the <key,value> pair into the map.- put(K, V) - Method in class org.apache.lucene.util.DoubleBarrelLRUCache
- put(K, V) - Method in class org.apache.lucene.util.MapOfSets
Adds val to the Set associated with key in the Map.- put(K, V) - Method in class org.apache.lucene.util.WeakIdentityMap
- put(CategoryPath, int) - Method in class org.apache.lucene.facet.taxonomy.writercache.cl2o.Cl2oTaxonomyWriterCache
- put(CategoryPath, int) - Method in class org.apache.lucene.facet.taxonomy.writercache.lru.LruTaxonomyWriterCache
- put(CategoryPath, 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(CategoryPath, int, int) - Method in class org.apache.lucene.facet.taxonomy.writercache.cl2o.Cl2oTaxonomyWriterCache
- put(CategoryPath, int, int) - Method in class org.apache.lucene.facet.taxonomy.writercache.lru.LruTaxonomyWriterCache
- put(CategoryPath, int, int) - Method in interface org.apache.lucene.facet.taxonomy.writercache.TaxonomyWriterCache
LikeTaxonomyWriterCache.put(CategoryPath, int)
, but for a given prefix of the category path.- put(Scorer) - Method in class org.apache.lucene.util.ScorerDocQueue
Deprecated.Adds a Scorer to a ScorerDocQueue in log(size) time.- 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.Q
- qnum - Variable in class org.apache.lucene.benchmark.byTask.feeds.AbstractQueryMaker
- qpAnalyzer - Static variable in class org.apache.lucene.queryParser.QueryParserTestBase
- QPTestAnalyzer() - Constructor for class org.apache.lucene.queryParser.QueryParserTestBase.QPTestAnalyzer
- QPTestFilter(TokenStream) - Constructor for class org.apache.lucene.queryParser.QueryParserTestBase.QPTestFilter
- QPTestParser(String, Analyzer) - Constructor for class org.apache.lucene.queryParser.QueryParserTestBase.QPTestParser
- qqParser - Variable in class org.apache.lucene.benchmark.quality.QualityBenchmark
-
Parser for turning QualityQueries into Lucene Queries.
- QualityBenchmark - Class in org.apache.lucene.benchmark.quality
-
Main entry point for running a quality benchmark.
- QualityBenchmark(QualityQuery[], QualityQueryParser, IndexSearcher, String) - Constructor for class org.apache.lucene.benchmark.quality.QualityBenchmark
-
Create a QualityBenchmark.
- qualityQueries - Variable in class org.apache.lucene.benchmark.quality.QualityBenchmark
-
Quality Queries that this quality benchmark would execute.
- QualityQueriesFinder - Class in org.apache.lucene.benchmark.quality.utils
-
Suggest Quality queries based on an index contents.
- QualityQuery - Class in org.apache.lucene.benchmark.quality
-
A QualityQuery has an ID and some name-value pairs.
- QualityQuery(String, Map<String, String>) - Constructor for class org.apache.lucene.benchmark.quality.QualityQuery
-
Create a QualityQuery with given ID and name-value pairs.
- QualityQueryParser - Interface in org.apache.lucene.benchmark.quality
-
Parse a QualityQuery into a Lucene query.
- QualityStats - Class in org.apache.lucene.benchmark.quality
-
Results of quality benchmark run for a single query or for a set of queries.
- QualityStats(double, long) - Constructor for class org.apache.lucene.benchmark.quality.QualityStats
-
Construct a QualityStats object with anticipated maximal number of relevant hits.
- QualityStats.RecallPoint - Class in org.apache.lucene.benchmark.quality
-
A certain rank in which a relevant doc was found.
- queries - Variable in class org.apache.lucene.benchmark.byTask.feeds.AbstractQueryMaker
- query - Variable in class org.apache.lucene.search.ConstantScoreQuery
- query - Variable in class org.apache.lucene.search.MultiTermQueryWrapperFilter
- query - Variable in class org.apache.lucene.search.SpanQueryFilter
- query - Variable in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper
- query - Variable in class org.apache.lucene.search.spans.SpanWeight
- query(FacetIndexingParams, CategoryPath...) - Static method in class org.apache.lucene.facet.search.DrillDown
-
Return a query for drilling down into all given categories (AND).
- query(FacetIndexingParams, Query, CategoryPath...) - Static method in class org.apache.lucene.facet.search.DrillDown
-
Turn a base query into a drilling-down query for all given category paths (AND).
- query(FacetSearchParams, CategoryPath...) - Static method in class org.apache.lucene.facet.search.DrillDown
-
Return a query for drilling down into all given categories (AND).
- query(FacetSearchParams, Query, CategoryPath...) - Static method in class org.apache.lucene.facet.search.DrillDown
-
Turn a base query into a drilling-down query for all given category paths (AND).
- query(Query, CategoryPath...) - Static method in class org.apache.lucene.facet.search.DrillDown
-
Turn a base query into a drilling-down query using the default
FacetSearchParams
- Query - Class in org.apache.lucene.search
-
The abstract base class for queries.
- Query() - Constructor for class org.apache.lucene.search.Query
- Query(CharSequence) - Method in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParser
- Query(String) - Method in class org.apache.lucene.queryParser.QueryParser
- QUERY_TREE_BUILDER_TAGID - Static variable in class org.apache.lucene.queryParser.core.builders.QueryTreeBuilder
-
This tag is used to tag the nodes in a query tree with the built objects produced from their own associated builder.
- QueryAutoStopWordAnalyzer - Class in org.apache.lucene.analysis.query
-
An
Analyzer
used primarily at query time to wrap another analyzer and provide a layer of protection which prevents very common words from being passed into queries. - QueryAutoStopWordAnalyzer(Version, Analyzer) - Constructor for class org.apache.lucene.analysis.query.QueryAutoStopWordAnalyzer
-
Deprecated.Stopwords should be calculated at instantiation using one of the other constructors
- QueryAutoStopWordAnalyzer(Version, Analyzer, IndexReader) - Constructor for class org.apache.lucene.analysis.query.QueryAutoStopWordAnalyzer
-
Creates a new QueryAutoStopWordAnalyzer with stopwords calculated for all indexed fields from terms with a document frequency percentage greater than
QueryAutoStopWordAnalyzer.defaultMaxDocFreqPercent
- QueryAutoStopWordAnalyzer(Version, Analyzer, IndexReader, float) - Constructor for class org.apache.lucene.analysis.query.QueryAutoStopWordAnalyzer
-
Creates a new QueryAutoStopWordAnalyzer with stopwords calculated for all indexed fields from terms with a document frequency percentage greater than the given maxPercentDocs
- QueryAutoStopWordAnalyzer(Version, Analyzer, IndexReader, int) - Constructor for class org.apache.lucene.analysis.query.QueryAutoStopWordAnalyzer
-
Creates a new QueryAutoStopWordAnalyzer with stopwords calculated for all indexed fields from terms with a document frequency greater than the given maxDocFreq
- QueryAutoStopWordAnalyzer(Version, Analyzer, IndexReader, Collection<String>, float) - Constructor for class org.apache.lucene.analysis.query.QueryAutoStopWordAnalyzer
-
Creates a new QueryAutoStopWordAnalyzer with stopwords calculated for the given selection of fields from terms with a document frequency percentage greater than the given maxPercentDocs
- QueryAutoStopWordAnalyzer(Version, Analyzer, IndexReader, Collection<String>, int) - Constructor for class org.apache.lucene.analysis.query.QueryAutoStopWordAnalyzer
-
Creates a new QueryAutoStopWordAnalyzer with stopwords calculated for the given selection of fields from terms with a document frequency greater than the given maxDocFreq
- QueryBuilder - Interface in org.apache.lucene.queryParser.core.builders
-
This interface is used by implementors classes that builds some kind of object from a query tree.
- QueryBuilder - Interface in org.apache.lucene.xmlparser
-
Implemented by objects that produce Lucene Query objects from XML streams.
- QueryBuilderFactory - Class in org.apache.lucene.xmlparser
- QueryBuilderFactory() - Constructor for class org.apache.lucene.xmlparser.QueryBuilderFactory
- QueryConfigHandler - Class in org.apache.lucene.queryParser.core.config
-
This class can be used to hold any query configuration and no field configuration.
- QueryConfigHandler() - Constructor for class org.apache.lucene.queryParser.core.config.QueryConfigHandler
- QueryDriver - Class in org.apache.lucene.benchmark.quality.trec
-
Command-line tool for doing a TREC evaluation run.
- QueryDriver() - Constructor for class org.apache.lucene.benchmark.quality.trec.QueryDriver
- queryFactory - Variable in class org.apache.lucene.xmlparser.CoreParser
- QueryMaker - Interface in org.apache.lucene.benchmark.byTask.feeds
-
Create queries for the test.
- QueryNode - Interface in org.apache.lucene.queryParser.core.nodes
-
A
QueryNode
is a interface implemented by all nodes on a QueryNode tree. - QueryNodeError - Error in org.apache.lucene.queryParser.core
-
Error class with NLS support
- QueryNodeError(Throwable) - Constructor for error org.apache.lucene.queryParser.core.QueryNodeError
- QueryNodeError(Message) - Constructor for error org.apache.lucene.queryParser.core.QueryNodeError
- QueryNodeError(Message, Throwable) - Constructor for error org.apache.lucene.queryParser.core.QueryNodeError
- QueryNodeException - Exception in org.apache.lucene.queryParser.core
-
This exception should be thrown if something wrong happens when dealing with
QueryNode
s. - QueryNodeException(Throwable) - Constructor for exception org.apache.lucene.queryParser.core.QueryNodeException
- QueryNodeException(Message) - Constructor for exception org.apache.lucene.queryParser.core.QueryNodeException
- QueryNodeException(Message, Throwable) - Constructor for exception org.apache.lucene.queryParser.core.QueryNodeException
- QueryNodeImpl - Class in org.apache.lucene.queryParser.core.nodes
-
A
QueryNodeImpl
is the default implementation of the interfaceQueryNode
- QueryNodeImpl() - Constructor for class org.apache.lucene.queryParser.core.nodes.QueryNodeImpl
- QueryNodeOperation - Class in org.apache.lucene.queryParser.core.util
-
Allow joining 2 QueryNode Trees, into one.
- QueryNodeParseException - Exception in org.apache.lucene.queryParser.core
-
This should be thrown when an exception happens during the query parsing from string to the query node tree.
- QueryNodeParseException(Throwable) - Constructor for exception org.apache.lucene.queryParser.core.QueryNodeParseException
- QueryNodeParseException(Message) - Constructor for exception org.apache.lucene.queryParser.core.QueryNodeParseException
- QueryNodeParseException(Message, Throwable) - Constructor for exception org.apache.lucene.queryParser.core.QueryNodeParseException
- QueryNodeProcessor - Interface in org.apache.lucene.queryParser.core.processors
-
A
QueryNodeProcessor
is an interface for classes that process aQueryNode
tree. - QueryNodeProcessorImpl - Class in org.apache.lucene.queryParser.core.processors
-
This is a default implementation for the
QueryNodeProcessor
interface, it's an abstract class, so it should be extended by classes that want to process aQueryNode
tree. - QueryNodeProcessorImpl() - Constructor for class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorImpl
- QueryNodeProcessorImpl(QueryConfigHandler) - Constructor for class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorImpl
- QueryNodeProcessorPipeline - Class in org.apache.lucene.queryParser.core.processors
-
A
QueryNodeProcessorPipeline
class should be used to build a query node processor pipeline. - QueryNodeProcessorPipeline() - Constructor for class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorPipeline
-
Constructs an empty query node processor pipeline.
- QueryNodeProcessorPipeline(QueryConfigHandler) - Constructor for class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorPipeline
-
Constructs with a
QueryConfigHandler
object. - queryNorm - Variable in class org.apache.lucene.search.spans.SpanWeight
- queryNorm(float) - Method in class org.apache.lucene.search.DefaultSimilarity
-
Implemented as
1/sqrt(sumOfSquaredWeights)
. - queryNorm(float) - Method in class org.apache.lucene.search.Similarity
-
Computes the normalization value for a query given the sum of the squared weights of each of the query terms.
- queryNorm(float) - Method in class org.apache.lucene.search.SimilarityDelegator
-
Deprecated.
- QueryParser - Class in org.apache.lucene.queryParser
-
This class is generated by JavaCC.
- QueryParser - Class in org.apache.lucene.queryParser.surround.parser
-
This class is generated by JavaCC.
- QueryParser() - Constructor for class org.apache.lucene.queryParser.surround.parser.QueryParser
- QueryParser(CharStream) - Constructor for class org.apache.lucene.queryParser.QueryParser
-
Constructor with user supplied CharStream.
- QueryParser(QueryParserTokenManager) - Constructor for class org.apache.lucene.queryParser.QueryParser
-
Constructor with generated Token Manager.
- QueryParser(CharStream) - Constructor for class org.apache.lucene.queryParser.surround.parser.QueryParser
-
Constructor with user supplied CharStream.
- QueryParser(QueryParserTokenManager) - Constructor for class org.apache.lucene.queryParser.surround.parser.QueryParser
-
Constructor with generated Token Manager.
- QueryParser(Version, String, Analyzer) - Constructor for class org.apache.lucene.queryParser.QueryParser
-
Constructs a query parser.
- QueryParser.Operator - Enum in org.apache.lucene.queryParser
-
The default operator for parsing queries.
- QueryParserConstants - Interface in org.apache.lucene.queryParser
-
Token literal values and constants.
- QueryParserConstants - Interface in org.apache.lucene.queryParser.surround.parser
-
Token literal values and constants.
- QueryParserHelper - Class in org.apache.lucene.queryParser.core
-
This class is a helper for the query parser framework, it does all the three query parser phrases at once: text parsing, query processing and query building.
- QueryParserHelper(QueryConfigHandler, SyntaxParser, QueryNodeProcessor, QueryBuilder) - Constructor for class org.apache.lucene.queryParser.core.QueryParserHelper
-
Creates a query parser helper object using the specified configuration, text parser, processor and builder.
- QueryParserMessages - Class in org.apache.lucene.queryParser.core.messages
-
Flexible Query Parser message bundle class
- QueryParserTestBase - Class in org.apache.lucene.queryParser
-
Base Test class for QueryParser subclasses
- QueryParserTestBase() - Constructor for class org.apache.lucene.queryParser.QueryParserTestBase
- QueryParserTestBase.QPTestAnalyzer - Class in org.apache.lucene.queryParser
-
Filters LowerCaseTokenizer with QPTestFilter.
- QueryParserTestBase.QPTestFilter - Class in org.apache.lucene.queryParser
-
Filter which discards the token 'stop' and which expands the token 'phrase' into 'phrase1 phrase2'
- QueryParserTestBase.QPTestParser - Class in org.apache.lucene.queryParser
-
Test QueryParser that does not allow fuzzy or wildcard queries.
- QueryParserTokenManager - Class in org.apache.lucene.queryParser
-
Token Manager.
- QueryParserTokenManager - Class in org.apache.lucene.queryParser.surround.parser
-
Token Manager.
- QueryParserTokenManager(CharStream) - Constructor for class org.apache.lucene.queryParser.QueryParserTokenManager
-
Constructor.
- QueryParserTokenManager(CharStream, int) - Constructor for class org.apache.lucene.queryParser.QueryParserTokenManager
-
Constructor.
- QueryParserTokenManager(CharStream) - Constructor for class org.apache.lucene.queryParser.surround.parser.QueryParserTokenManager
-
Constructor.
- QueryParserTokenManager(CharStream, int) - Constructor for class org.apache.lucene.queryParser.surround.parser.QueryParserTokenManager
-
Constructor.
- QueryParserUtil - Class in org.apache.lucene.queryParser.standard
-
This class defines utility methods to (help) parse query strings into
Query
objects. - QueryParserUtil() - Constructor for class org.apache.lucene.queryParser.standard.QueryParserUtil
- QueryParserWrapper - Class in org.apache.lucene.queryParser.standard
-
Deprecated.this class will be removed soon, it's a temporary class to be used along the transition from the old query parser to the new one
- QueryParserWrapper(String, Analyzer) - Constructor for class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.
- QueryParserWrapper.Operator - Enum in org.apache.lucene.queryParser.standard
-
Deprecated.The default operator for parsing queries.
- QueryPhraseMap(FieldQuery) - Constructor for class org.apache.lucene.search.vectorhighlight.FieldQuery.QueryPhraseMap
- QueryScorer - Class in org.apache.lucene.search.highlight
-
Scorer
implementation which scores text fragments by the number of unique query terms found. - QueryScorer(WeightedSpanTerm[]) - Constructor for class org.apache.lucene.search.highlight.QueryScorer
- QueryScorer(Query) - Constructor for class org.apache.lucene.search.highlight.QueryScorer
- QueryScorer(Query, String) - Constructor for class org.apache.lucene.search.highlight.QueryScorer
- QueryScorer(Query, String, String) - Constructor for class org.apache.lucene.search.highlight.QueryScorer
- QueryScorer(Query, IndexReader, String) - Constructor for class org.apache.lucene.search.highlight.QueryScorer
- QueryScorer(Query, IndexReader, String, String) - Constructor for class org.apache.lucene.search.highlight.QueryScorer
- QueryTemplateManager - Class in org.apache.lucene.xmlparser
-
Provides utilities for turning query form input (such as from a web page or Swing gui) into Lucene XML queries by using XSL templates.
- QueryTemplateManager() - Constructor for class org.apache.lucene.xmlparser.QueryTemplateManager
- QueryTemplateManager(InputStream) - Constructor for class org.apache.lucene.xmlparser.QueryTemplateManager
- QueryTermExtractor - Class in org.apache.lucene.search.highlight
-
Utility class used to extract the terms used in a query, plus any weights.
- QueryTermExtractor() - Constructor for class org.apache.lucene.search.highlight.QueryTermExtractor
- QueryTermScorer - Class in org.apache.lucene.search.highlight
-
Scorer
implementation which scores text fragments by the number of unique query terms found. - QueryTermScorer(WeightedTerm[]) - Constructor for class org.apache.lucene.search.highlight.QueryTermScorer
- QueryTermScorer(Query) - Constructor for class org.apache.lucene.search.highlight.QueryTermScorer
- QueryTermScorer(Query, String) - Constructor for class org.apache.lucene.search.highlight.QueryTermScorer
- QueryTermScorer(Query, IndexReader, String) - Constructor for class org.apache.lucene.search.highlight.QueryTermScorer
- QueryTermVector - Class in org.apache.lucene.search
- QueryTermVector(String[]) - Constructor for class org.apache.lucene.search.QueryTermVector
- QueryTermVector(String, Analyzer) - Constructor for class org.apache.lucene.search.QueryTermVector
- QueryText(CharSequence, int, int) - Constructor for class org.apache.lucene.queryParser.core.nodes.PathQueryNode.QueryText
- QueryTreeBuilder - Class in org.apache.lucene.queryParser.core.builders
-
This class should be used when there is a builder for each type of node.
- QueryTreeBuilder() - Constructor for class org.apache.lucene.queryParser.core.builders.QueryTreeBuilder
-
QueryTreeBuilder
constructor. - QueryUtils - Class in org.apache.lucene.search
-
Utility class for sanity-checking queries.
- QueryUtils() - Constructor for class org.apache.lucene.search.QueryUtils
- queryWeight - Variable in class org.apache.lucene.search.spans.SpanWeight
- QueryWrapperFilter - Class in org.apache.lucene.search
-
Constrains search results to only match those which also match a provided query.
- QueryWrapperFilter(Query) - Constructor for class org.apache.lucene.search.QueryWrapperFilter
-
Constructs a filter which only matches documents matching
query
. - quickSort(int, int) - Method in class org.apache.lucene.util.SorterTemplate
-
Sorts via in-place, but unstable, QuickSort algorithm.
- quickSort(List<T>) - Static method in class org.apache.lucene.util.CollectionUtil
-
Sorts the given random access
List
in natural order. - quickSort(List<T>, Comparator<? super T>) - Static method in class org.apache.lucene.util.CollectionUtil
-
Sorts the given random access
List
using theComparator
. - quickSort(T[]) - Static method in class org.apache.lucene.util.ArrayUtil
-
Sorts the given array in natural order.
- quickSort(T[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Sorts the given array slice in natural order.
- quickSort(T[], int, int, Comparator<? super T>) - Static method in class org.apache.lucene.util.ArrayUtil
-
Sorts the given array slice using the
Comparator
. - quickSort(T[], Comparator<? super T>) - Static method in class org.apache.lucene.util.ArrayUtil
-
Sorts the given array using the
Comparator
. - Quote1Text - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
RegularExpression Id.
- Quote2Text - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
RegularExpression Id.
- QUOTED - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
-
RegularExpression Id.
- QUOTED - Static variable in interface org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- QUOTED - Static variable in interface org.apache.lucene.queryParser.surround.parser.QueryParserConstants
-
RegularExpression Id.
- QuotedFieldQueryNode - Class in org.apache.lucene.queryParser.core.nodes
-
A
QuotedFieldQueryNode
represents phrase query. - QuotedFieldQueryNode(CharSequence, CharSequence, int, int) - Constructor for class org.apache.lucene.queryParser.core.nodes.QuotedFieldQueryNode
- quoteEscape(String) - Static method in class org.apache.lucene.analysis.ja.util.CSVUtil
-
Quote and escape input value for CSV
R
- RADIANS_TO_DEGREES - Static variable in class org.apache.lucene.spatial.DistanceUtils
-
Deprecated.
- RAMDirectory - Class in org.apache.lucene.store
-
A memory-resident
Directory
implementation. - RAMDirectory() - Constructor for class org.apache.lucene.store.RAMDirectory
-
Constructs an empty
Directory
. - RAMDirectory(Directory) - Constructor for class org.apache.lucene.store.RAMDirectory
-
Creates a new
RAMDirectory
instance from a differentDirectory
implementation. - RAMFile - Class in org.apache.lucene.store
- RAMFile() - Constructor for class org.apache.lucene.store.RAMFile
- RAMInputStream - Class in org.apache.lucene.store
-
A memory-resident
IndexInput
implementation. - RAMInputStream(String, RAMFile) - Constructor for class org.apache.lucene.store.RAMInputStream
- RAMInputStream(RAMFile) - Constructor for class org.apache.lucene.store.RAMInputStream
-
Deprecated.
- RAMOutputStream - Class in org.apache.lucene.store
-
A memory-resident
IndexOutput
implementation. - RAMOutputStream() - Constructor for class org.apache.lucene.store.RAMOutputStream
-
Construct an empty output buffer.
- RAMOutputStream(RAMFile) - Constructor for class org.apache.lucene.store.RAMOutputStream
- ramSizeInBytes() - Method in class org.apache.lucene.index.IndexWriter
-
Expert: Return the total size of all index files currently cached in memory.
- RamUsageEstimator - Class in org.apache.lucene.util
-
Estimates the size (memory representation) of Java objects.
- RamUsageEstimator() - Constructor for class org.apache.lucene.util.RamUsageEstimator
-
Deprecated.Don't create instances of this class, instead use the static
RamUsageEstimator.sizeOf(Object)
method that has no intern checking, too. - RamUsageEstimator(boolean) - Constructor for class org.apache.lucene.util.RamUsageEstimator
-
Deprecated.Don't create instances of this class, instead use the static
RamUsageEstimator.sizeOf(Object)
method. - RamUsageEstimator.JvmFeature - Enum in org.apache.lucene.util
-
JVM diagnostic features.
- random - Static variable in class org.apache.lucene.util.LuceneTestCase
- RANDOM - Static variable in class org.apache.lucene.store.NativePosixUtil
- 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
- randomDirectory(Random) - Static method in class org.apache.lucene.util.LuceneTestCase
- 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
- 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 TEST_VERSION_CURRENT and Whitespace+LowercasingAnalyzer
- RandomIndexWriter(Random, Directory, Analyzer) - Constructor for class org.apache.lucene.index.RandomIndexWriter
-
create a RandomIndexWriter with a random config: Uses TEST_VERSION_CURRENT
- RandomIndexWriter(Random, Directory, IndexWriterConfig) - Constructor for class org.apache.lucene.index.RandomIndexWriter
-
create a RandomIndexWriter with the provided config
- RandomIndexWriter(Random, Directory, Version, Analyzer) - Constructor for class org.apache.lucene.index.RandomIndexWriter
-
create a RandomIndexWriter with a random config
- 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
- 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.
- 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!
- RandomSampler - Class in org.apache.lucene.facet.search.sampling
-
Simple random sampler
- RandomSampler() - Constructor for class org.apache.lucene.facet.search.sampling.RandomSampler
- RandomSampler(SamplingParams, Random) - Constructor for class org.apache.lucene.facet.search.sampling.RandomSampler
- randomSimpleString(Random) - Static method in class org.apache.lucene.util._TestUtil
- randomSimpleString(Random, int) - 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
- 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(int, int) - Method in class org.apache.lucene.index.SegmentInfos
-
Deprecated.use
asList().subList(first, last)
instead. - RANGE_COLLATOR - Static variable in class org.apache.lucene.queryParser.standard.config.StandardQueryConfigHandler.ConfigurationKeys
-
Key used to set the
Collator
used when creatingTermRangeQuery
s. - RangeCollatorAttribute - Interface in org.apache.lucene.queryParser.standard.config
-
Deprecated.
- RangeCollatorAttributeImpl - Class in org.apache.lucene.queryParser.standard.config
-
Deprecated.
- RangeCollatorAttributeImpl() - Constructor for class org.apache.lucene.queryParser.standard.config.RangeCollatorAttributeImpl
-
Deprecated.
- RangeEx - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
-
Lexical state.
- RangeEx - Static variable in interface org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserConstants
-
Lexical state.
- RANGEEX_END - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
-
RegularExpression Id.
- RANGEEX_END - Static variable in interface org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- RANGEEX_GOOP - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
-
RegularExpression Id.
- RANGEEX_GOOP - Static variable in interface org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- RANGEEX_QUOTED - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
-
RegularExpression Id.
- RANGEEX_QUOTED - Static variable in interface org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- RANGEEX_START - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
-
RegularExpression Id.
- RANGEEX_START - Static variable in interface org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- RANGEEX_TO - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
-
RegularExpression Id.
- RANGEEX_TO - Static variable in interface org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- RangeFilterBuilder - Class in org.apache.lucene.xmlparser.builders
- RangeFilterBuilder() - Constructor for class org.apache.lucene.xmlparser.builders.RangeFilterBuilder
- RangeIn - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
-
Lexical state.
- RangeIn - Static variable in interface org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserConstants
-
Lexical state.
- RANGEIN_END - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
-
RegularExpression Id.
- RANGEIN_END - Static variable in interface org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- RANGEIN_GOOP - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
-
RegularExpression Id.
- RANGEIN_GOOP - Static variable in interface org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- RANGEIN_QUOTED - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
-
RegularExpression Id.
- RANGEIN_QUOTED - Static variable in interface org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- RANGEIN_START - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
-
RegularExpression Id.
- RANGEIN_START - Static variable in interface org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- RANGEIN_TO - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
-
RegularExpression Id.
- RANGEIN_TO - Static variable in interface org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- RangeQueryNode - Class in org.apache.lucene.queryParser.standard.nodes
-
Deprecated.this class will be removed in future,
TermRangeQueryNode
should be used instead - RangeQueryNode<T extends FieldValuePairQueryNode<?>> - Interface in org.apache.lucene.queryParser.core.nodes
-
This interface should be implemented by a
QueryNode
that represents some kind of range query. - RangeQueryNode(ParametricQueryNode, ParametricQueryNode, Collator) - Constructor for class org.apache.lucene.queryParser.standard.nodes.RangeQueryNode
-
Deprecated.
- RangeQueryNodeBuilder - Class in org.apache.lucene.queryParser.standard.builders
-
Deprecated.this builder will be removed in future together with
RangeQueryNode
- RangeQueryNodeBuilder() - Constructor for class org.apache.lucene.queryParser.standard.builders.RangeQueryNodeBuilder
-
Deprecated.
- rarely() - Static method in class org.apache.lucene.util.LuceneTestCase
- rarely(Random) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Returns true if something should happen rarely,
- rawTermDocs(Term) - Method in class org.apache.lucene.index.SegmentReader
-
Expert: returns an enumeration of the documents that contain
term
, including deleted documents (which are normally filtered out). - RawTermFilter - Class in org.apache.lucene.search.join
-
Expert: creates a filter accepting all documents containing the provided term, disregarding deleted documents.
- RawTermFilter(Term) - Constructor for class org.apache.lucene.search.join.RawTermFilter
- read() - Method in class org.apache.lucene.analysis.charfilter.HTMLStripCharFilter
- read() - Method in class org.apache.lucene.analysis.MappingCharFilter
- read() - Method in class org.apache.lucene.analysis.MockCharFilter
- read() - Method in class org.apache.lucene.benchmark.byTask.utils.StringBuilderReader
- read() - Method in class org.apache.lucene.search.suggest.fst.Sort.ByteSequencesReader
-
Reads the next entry and returns it if successful.
- read() - Method in class org.apache.lucene.util.UnsafeByteArrayInputStream
-
Read a byte.
- read(char[], int, int) - Method in class org.apache.lucene.analysis.charfilter.HTMLStripCharFilter
- read(char[], int, int) - Method in class org.apache.lucene.analysis.CharFilter
- read(char[], int, int) - Method in class org.apache.lucene.analysis.CharReader
- read(char[], int, int) - Method in class org.apache.lucene.analysis.fa.PersianCharFilter
- read(char[], int, int) - Method in class org.apache.lucene.analysis.MappingCharFilter
- 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.benchmark.byTask.utils.StringBuilderReader
- read(int[], int[]) - Method in class org.apache.lucene.index.AbstractAllTermDocs
- read(int[], int[]) - Method in class org.apache.lucene.index.FilterIndexReader.FilterTermDocs
- read(int[], int[]) - Method in class org.apache.lucene.index.MultipleTermPositions
-
Not implemented.
- read(int[], int[]) - Method in interface org.apache.lucene.index.TermDocs
-
Attempts to read multiple entries from the enumeration, up to length of docs.
- read(int[], int[]) - Method in class org.apache.lucene.store.instantiated.InstantiatedTermDocs
- read(File, Outputs<T>) - Static method in class org.apache.lucene.util.fst.FST
-
Reads an automaton from a file.
- read(DataInput) - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
- read(DataInput) - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
- 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
- read(Directory) - Method in class org.apache.lucene.index.SegmentInfos
-
This version of read uses the retry logic (for lock-less commits) to find the right segments file to load.
- read(Directory, String) - Method in class org.apache.lucene.index.SegmentInfos
-
Read a particular segmentFileName.
- read(BytesRef) - Method in class org.apache.lucene.search.suggest.fst.Sort.ByteSequencesReader
-
Reads the next entry into the provided
BytesRef
. - readByte() - Method in class org.apache.lucene.store.BufferedIndexInput
- readByte() - Method in class org.apache.lucene.store.ByteArrayDataInput
- readByte() - Method in class org.apache.lucene.store.ChecksumIndexInput
- 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
- readByte() - Method in class org.apache.lucene.util.PagedBytes.PagedBytesDataInput
- ReadByte() - Method in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
- readBytes(byte[], int, int) - Method in class org.apache.lucene.store.BufferedIndexInput
- readBytes(byte[], int, int) - Method in class org.apache.lucene.store.ByteArrayDataInput
- readBytes(byte[], int, int) - Method in class org.apache.lucene.store.ChecksumIndexInput
- readBytes(byte[], int, int) - Method in class org.apache.lucene.store.DataInput
-
Reads a specified number of bytes into an array at the specified offset.
- readBytes(byte[], int, int) - Method in class org.apache.lucene.store.InputStreamDataInput
- readBytes(byte[], int, int) - Method in class org.apache.lucene.store.MockIndexInputWrapper
- readBytes(byte[], int, int) - Method in class org.apache.lucene.store.RAMInputStream
- readBytes(byte[], int, int) - Method in class org.apache.lucene.util.PagedBytes.PagedBytesDataInput
- readBytes(byte[], int, int, boolean) - Method in class org.apache.lucene.store.BufferedIndexInput
- readBytes(byte[], int, int, boolean) - Method in class org.apache.lucene.store.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, boolean) - Method in class org.apache.lucene.store.MockIndexInputWrapper
- readChar() - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
-
Read a character.
- readChar() - Method in interface org.apache.lucene.queryParser.CharStream
-
Returns the next character from the selected input.
- readChar() - Method in class org.apache.lucene.queryParser.FastCharStream
- readChar() - Method in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
-
Read a character.
- 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
- readChars(char[], int, int) - Method in class org.apache.lucene.store.DataInput
-
Deprecated.-- please use readString or readBytes instead, and construct the string from those utf8 bytes
- readChars(char[], int, int) - Method in class org.apache.lucene.store.MockIndexInputWrapper
- readCodePoint() - Method in class org.apache.lucene.analysis.MockTokenizer
- readCurrentVersion(Directory) - Static method in class org.apache.lucene.index.SegmentInfos
-
Deprecated.Load the SegmentInfos and then call
SegmentInfos.getVersion()
. - reader - Variable in class org.apache.lucene.search.FieldCacheDocIdSet
- reader - Variable in class org.apache.lucene.search.function.CustomScoreProvider
- reader - Static variable in class org.apache.lucene.search.SearchEquivalenceTestBase
- Reader(PagedBytes) - Constructor for class org.apache.lucene.util.PagedBytes.Reader
- ReaderImpl(int, int) - Constructor for class org.apache.lucene.util.packed.PackedInts.ReaderImpl
- readerIndex(int) - Method in class org.apache.lucene.index.MultiReader
- ReaderPayloadProcessor() - Constructor for class org.apache.lucene.index.PayloadProcessorProvider.ReaderPayloadProcessor
- ReaderUtil - Class in org.apache.lucene.util
-
Common util methods for dealing with
IndexReader
s. - ReaderUtil.Gather - Class in org.apache.lucene.util
-
Recursively visits all sub-readers of a reader.
- readerValue() - Method in class org.apache.lucene.document.Field
-
The value of the field as a Reader, or null.
- readerValue() - Method in interface org.apache.lucene.document.Fieldable
-
The value of the field as a Reader, which can be used at index time to generate indexed tokens.
- readerValue() - Method in class org.apache.lucene.document.NumericField
-
Returns always
null
for numeric fields - readFirstRealTargetArc(int, FST.Arc<T>, FST.BytesReader) - Method in class org.apache.lucene.util.fst.FST
- readFirstTargetArc(FST.Arc<T>, FST.Arc<T>) - Method in class org.apache.lucene.util.fst.FST
-
Follow the
follow
arc and read the first arc of its target; this changes the providedarc
(2nd arg) in-place and returns it. - ReadingAttribute - Interface in org.apache.lucene.analysis.ja.tokenattributes
-
Attribute for Kuromoji 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
- readInt() - Method in class org.apache.lucene.store.BufferedIndexInput
- readInt() - Method in class org.apache.lucene.store.ByteArrayDataInput
- readInt() - Method in class org.apache.lucene.store.DataInput
-
Reads four bytes and returns an int.
- readInt() - Method in class org.apache.lucene.store.MockIndexInputWrapper
- readInternal(byte[], int, int) - Method in class org.apache.lucene.index.MockIndexInput
- readInternal(byte[], int, int) - Method in class org.apache.lucene.store.BufferedIndexInput
-
Expert: implements buffer refill.
- readInternal(byte[], int, int) - Method in class org.apache.lucene.store.NIOFSDirectory.NIOFSIndexInput
- readInternal(byte[], int, int) - Method in class org.apache.lucene.store.SimpleFSDirectory.SimpleFSIndexInput
-
IndexInput methods
- readInternal(byte[], int, int) - Method in class org.apache.lucene.store.WindowsDirectory.WindowsIndexInput
- readLastTargetArc(FST.Arc<T>, FST.Arc<T>) - Method in class org.apache.lucene.util.fst.FST
-
Follows the
follow
arc and reads the last arc of its target; this changes the providedarc
(2nd arg) in-place and returns it. - readLong() - Method in class org.apache.lucene.store.BufferedIndexInput
- readLong() - Method in class org.apache.lucene.store.ByteArrayDataInput
- readLong() - Method in class org.apache.lucene.store.DataInput
-
Reads eight bytes and returns a long.
- readLong() - Method in class org.apache.lucene.store.MockIndexInputWrapper
- readNextArc(FST.Arc<T>) - Method in class org.apache.lucene.util.fst.FST
-
In-place read; returns the arc.
- readNextArcLabel(FST.Arc<T>) - 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.
- readOnly - Variable in class org.apache.lucene.index.SegmentReader
-
Deprecated.
- 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.
- readResolve() - Method in class org.apache.lucene.util.Parameter
-
Deprecated.Resolves the deserialized instance to the local reference for accurate equals() and == comparisons.
- readShort() - Method in class org.apache.lucene.store.BufferedIndexInput
- readShort() - Method in class org.apache.lucene.store.ByteArrayDataInput
- readShort() - Method in class org.apache.lucene.store.DataInput
-
Reads two bytes and returns a short.
- readSnapshotsInfo(Directory) - Static method in class org.apache.lucene.index.PersistentSnapshotDeletionPolicy
-
Reads the snapshots information from the given
Directory
. - readString() - Method in class org.apache.lucene.store.DataInput
-
Reads a string.
- readString() - Method in class org.apache.lucene.store.MockIndexInputWrapper
- readStringStringMap() - Method in class org.apache.lucene.store.DataInput
- readStringStringMap() - Method in class org.apache.lucene.store.MockIndexInputWrapper
- 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
- readTime - Variable in class org.apache.lucene.search.suggest.fst.Sort.SortInfo
- readToken(StringBuffer) - 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.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.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
- ready() - Method in class org.apache.lucene.benchmark.byTask.utils.StringBuilderReader
- rearrangeFacetResult(FacetResult) - Method in class org.apache.lucene.facet.search.FacetResultsHandler
-
Perform any rearrangement as required on a facet result that has changed after it was rendered.
- rearrangeFacetResult(FacetResult) - Method in class org.apache.lucene.facet.search.TopKFacetResultsHandler
- rearrangeFacetResult(FacetResult) - Method in class org.apache.lucene.facet.search.TopKInEachNodeHandler
- RECACHE - org.apache.lucene.search.CachingWrapperFilter.DeletesMode
- RECCNT - Static variable in class org.apache.lucene.benchmark.byTask.tasks.ReportTask
- recompose(List) - 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.
- RECSEC - Static variable in class org.apache.lucene.benchmark.byTask.tasks.ReportTask
- Rectangle - Class in org.apache.lucene.spatial.geometry.shape
-
Deprecated.
- Rectangle() - Constructor for class org.apache.lucene.spatial.geometry.shape.Rectangle
-
Deprecated.
- Rectangle(double, double, double, double) - Constructor for class org.apache.lucene.spatial.geometry.shape.Rectangle
-
Deprecated.
- Rectangle(Point2D, Point2D) - Constructor for class org.apache.lucene.spatial.geometry.shape.Rectangle
-
Deprecated.
- recycleByteBlocks(byte[][], int, int) - Method in class org.apache.lucene.util.ByteBlockPool.Allocator
- recycleByteBlocks(byte[][], int, int) - Method in class org.apache.lucene.util.ByteBlockPool.DirectAllocator
- recycleByteBlocks(byte[][], int, int) - Method in class org.apache.lucene.util.ByteBlockPool.DirectTrackingAllocator
- recycleByteBlocks(byte[][], int, int) - Method in class org.apache.lucene.util.RecyclingByteBlockAllocator
- recycleByteBlocks(List<byte[]>) - Method in class org.apache.lucene.util.ByteBlockPool.Allocator
- RecyclingByteBlockAllocator - Class in org.apache.lucene.util
-
A
ByteBlockPool.Allocator
implementation that recycles unused byte blocks in a buffer and reuses them in subsequent calls toRecyclingByteBlockAllocator.getByteBlock()
. - RecyclingByteBlockAllocator() - Constructor for class org.apache.lucene.util.RecyclingByteBlockAllocator
-
Creates a new
RecyclingByteBlockAllocator
with a block size ofByteBlockPool.BYTE_BLOCK_SIZE
, upper buffered docs limit ofRecyclingByteBlockAllocator.DEFAULT_BUFFERED_BLOCKS
(64) and aDummyConcurrentLock
instance. - RecyclingByteBlockAllocator(int, int) - Constructor for class org.apache.lucene.util.RecyclingByteBlockAllocator
-
Creates a new
RecyclingByteBlockAllocator
with aDummyConcurrentLock
instance. - RecyclingByteBlockAllocator(int, int, AtomicLong) - Constructor for class org.apache.lucene.util.RecyclingByteBlockAllocator
-
Creates a new
RecyclingByteBlockAllocator
- 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(Reduce) - Method in class org.egothor.stemmer.Trie
-
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.
- reduceOpenFiles(IndexWriter) - Static method in class org.apache.lucene.util._TestUtil
-
just tries to configure things to keep the open file count lowish
- 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
- reflect(Class<? extends Attribute>, String, Object) - Method in interface org.apache.lucene.util.AttributeReflector
-
This method gets called for every property in an
AttributeImpl
/AttributeSource
passing the class name of theAttribute
, a key and the actual value. - reflectAsString(boolean) - Method in class org.apache.lucene.util.AttributeImpl
-
This method returns the current attribute values as a string in the following format by calling the
AttributeImpl.reflectWith(AttributeReflector)
method: iffprependAttClass=true
:"AttributeClass#key=value,AttributeClass#key=value"
iffprependAttClass=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: iffprependAttClass=true
:"AttributeClass#key=value,AttributeClass#key=value"
iffprependAttClass=false
:"key=value,key=value"
- 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.Token
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
- 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.facet.taxonomy.directory.DirectoryTaxonomyReader
- refresh() - Method in interface org.apache.lucene.facet.taxonomy.TaxonomyReader
-
refresh() re-reads the taxonomy information if there were any changes to the taxonomy since this instance was opened or last refreshed.
- 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.NRTManager
- refreshIfNeeded(IndexSearcher) - Method in class org.apache.lucene.search.SearcherManager
- RegexCapabilities - Interface in org.apache.lucene.search.regex
-
Defines basic operations needed by
RegexQuery
for a regular expression implementation. - RegexQuery - Class in org.apache.lucene.search.regex
-
Implements the regular expression term search query.
- RegexQuery(Term) - Constructor for class org.apache.lucene.search.regex.RegexQuery
-
Constructs a query for terms matching
term
. - RegexQueryCapable - Interface in org.apache.lucene.search.regex
-
Defines methods for regular expression supporting Querys to use.
- RegexTermEnum - Class in org.apache.lucene.search.regex
-
Subclass of FilteredTermEnum for enumerating all terms that match the specified regular expression term using the specified regular expression implementation.
- RegexTermEnum(IndexReader, Term, RegexCapabilities) - Constructor for class org.apache.lucene.search.regex.RegexTermEnum
- register(CategoryListParams, CategoryListData) - Method in class org.apache.lucene.facet.search.cache.CategoryListCache
-
Register a pre-computed
CategoryListData
. - registerSnapshotInfo(String, String, IndexCommit) - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
-
Registers the given snapshot information.
- rehash() - Method in class org.apache.lucene.search.grouping.SentinelIntSet
- rehashCount - Variable in class org.apache.lucene.search.grouping.SentinelIntSet
- reinit() - Method in class org.apache.lucene.util.BytesRefHash
-
reinitializes the
BytesRefHash
after a previousBytesRefHash.clear()
call. - reinit(boolean) - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
- reinit(char[], int, int, int, int) - Method in class org.apache.lucene.analysis.Token
-
Shorthand for calling
Token.clear()
,CharTermAttributeImpl.copyBuffer(char[], int, int)
,Token.setStartOffset(int)
,Token.setEndOffset(int)
Token.setType(java.lang.String)
on Token.DEFAULT_TYPE - reinit(char[], int, int, int, int, String) - Method in class org.apache.lucene.analysis.Token
- reinit(String, int, int) - Method in class org.apache.lucene.analysis.Token
-
Shorthand for calling
Token.clear()
,CharTermAttributeImpl.append(CharSequence)
,Token.setStartOffset(int)
,Token.setEndOffset(int)
Token.setType(java.lang.String)
on Token.DEFAULT_TYPE - reinit(String, int, int, int, int) - Method in class org.apache.lucene.analysis.Token
-
Shorthand for calling
Token.clear()
,CharTermAttributeImpl.append(CharSequence, int, int)
,Token.setStartOffset(int)
,Token.setEndOffset(int)
Token.setType(java.lang.String)
on Token.DEFAULT_TYPE - reinit(String, int, int, int, int, String) - Method in class org.apache.lucene.analysis.Token
- reinit(String, int, int, String) - Method in class org.apache.lucene.analysis.Token
- reinit(Token) - Method in class org.apache.lucene.analysis.Token
-
Copy the prototype token's fields into this one.
- reinit(Token, char[], int, int) - Method in class org.apache.lucene.analysis.Token
-
Copy the prototype token's fields into this one, with a different term.
- reinit(Token, String) - Method in class org.apache.lucene.analysis.Token
-
Copy the prototype token's fields into this one, with a different term.
- reInit(byte[]) - Method in class org.apache.lucene.util.UnsafeByteArrayInputStream
-
Initialize the stream with a given buffer, using the default limits of [0, buffer.length)
- reInit(byte[]) - Method in class org.apache.lucene.util.UnsafeByteArrayOutputStream
-
For reuse-ability, this stream object can be re-initialized with another given buffer, using 0 as default starting position.
- reInit(byte[], int) - Method in class org.apache.lucene.util.UnsafeByteArrayOutputStream
-
For reuse-ability, this stream object can be re-initialized with another given buffer and starting position.
- reInit(byte[], int, int) - Method in class org.apache.lucene.util.UnsafeByteArrayInputStream
-
Initialize the stream with a given byte array as the source of the stream, at the specific range: [startPos, endPos)
- reInit(InputStream) - Method in class org.apache.lucene.util.encoding.DGapIntDecoder
- reInit(InputStream) - Method in class org.apache.lucene.util.encoding.EightFlagsIntDecoder
- reInit(InputStream) - Method in class org.apache.lucene.util.encoding.FourFlagsIntDecoder
- reInit(InputStream) - Method in class org.apache.lucene.util.encoding.IntDecoder
-
Sets the input stream from which the encoded data is read.
- reInit(InputStream) - Method in class org.apache.lucene.util.encoding.NOnesIntDecoder
- reInit(OutputStream) - Method in class org.apache.lucene.util.encoding.ChunksIntEncoder
- reInit(OutputStream) - Method in class org.apache.lucene.util.encoding.DGapIntEncoder
- reInit(OutputStream) - Method in class org.apache.lucene.util.encoding.IntEncoder
-
Reinitializes the encoder with the give
OutputStream
. - reInit(OutputStream) - Method in class org.apache.lucene.util.encoding.IntEncoderFilter
- reInit(OutputStream) - Method in class org.apache.lucene.util.encoding.NOnesIntEncoder
- reInit(OutputStream) - Method in class org.apache.lucene.util.encoding.SortingIntEncoder
- reInit(OutputStream) - Method in class org.apache.lucene.util.encoding.UniqueValuesIntEncoder
- ReInit(InputStream) - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParser
-
Reinitialise.
- ReInit(InputStream) - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
-
Reinitialise.
- ReInit(InputStream) - Method in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
-
Reinitialise.
- ReInit(InputStream) - Method in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParser
-
Reinitialise.
- ReInit(InputStream, int, int) - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
-
Reinitialise.
- ReInit(InputStream, int, int) - Method in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
-
Reinitialise.
- ReInit(InputStream, int, int, int) - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
-
Reinitialise.
- ReInit(InputStream, int, int, int) - Method in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
-
Reinitialise.
- ReInit(InputStream, String) - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParser
-
Reinitialise.
- ReInit(InputStream, String) - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
-
Reinitialise.
- ReInit(InputStream, String) - Method in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
-
Reinitialise.
- ReInit(InputStream, String) - Method in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParser
-
Reinitialise.
- ReInit(InputStream, String, int, int) - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
-
Reinitialise.
- ReInit(InputStream, String, int, int) - Method in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
-
Reinitialise.
- ReInit(InputStream, String, int, int, int) - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
-
Reinitialise.
- ReInit(InputStream, String, int, int, int) - Method in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
-
Reinitialise.
- ReInit(Reader) - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParser
-
Reinitialise.
- ReInit(Reader) - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
-
Reinitialise.
- ReInit(Reader) - Method in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
-
Reinitialise.
- ReInit(Reader) - Method in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParser
-
Reinitialise.
- ReInit(Reader, int, int) - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
-
Reinitialise.
- ReInit(Reader, int, int) - Method in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
-
Reinitialise.
- ReInit(Reader, int, int, int) - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
-
Reinitialise.
- ReInit(Reader, int, int, int) - Method in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
-
Reinitialise.
- ReInit(HTMLParserTokenManager) - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParser
-
Reinitialise.
- ReInit(SimpleCharStream) - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserTokenManager
-
Reinitialise parser.
- ReInit(SimpleCharStream, int) - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserTokenManager
-
Reinitialise parser.
- ReInit(CharStream) - Method in class org.apache.lucene.queryParser.QueryParser
-
Reinitialise.
- ReInit(CharStream) - Method in class org.apache.lucene.queryParser.QueryParserTokenManager
-
Reinitialise parser.
- ReInit(CharStream, int) - Method in class org.apache.lucene.queryParser.QueryParserTokenManager
-
Reinitialise parser.
- ReInit(QueryParserTokenManager) - Method in class org.apache.lucene.queryParser.QueryParser
-
Reinitialise.
- ReInit(JavaCharStream) - Method in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserTokenManager
-
Reinitialise parser.
- ReInit(JavaCharStream, int) - Method in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserTokenManager
-
Reinitialise parser.
- ReInit(StandardSyntaxParserTokenManager) - Method in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParser
-
Reinitialise.
- ReInit(CharStream) - 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(QueryParserTokenManager) - Method in class org.apache.lucene.queryParser.surround.parser.QueryParser
-
Reinitialise.
- relatives - Variable in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie.TSTNode
-
The relative nodes.
- release() - Method in class org.apache.lucene.store.Lock
-
Releases exclusive access.
- release(G) - Method in class org.apache.lucene.search.ReferenceManager
-
Release the refernce previously obtained via
ReferenceManager.acquire()
. - release(String) - Method in class org.apache.lucene.index.PersistentSnapshotDeletionPolicy
-
Deletes a snapshotted commit by ID.
- release(String) - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
-
Release a snapshotted commit by ID.
- release(IndexSearcher) - Method in class org.apache.lucene.search.SearcherLifetimeManager
-
Release a searcher previously obtained from
SearcherLifetimeManager.acquire(long)
. - 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.
- RemoteCachingWrapperFilter - Class in org.apache.lucene.search
-
Deprecated.This package (all of contrib/remote) will be removed in 4.0.
- RemoteCachingWrapperFilter(Filter) - Constructor for class org.apache.lucene.search.RemoteCachingWrapperFilter
-
Deprecated.
- RemoteSearchable - Class in org.apache.lucene.search
-
Deprecated.This package (all of contrib/remote) will be removed in 4.0.
- RemoteSearchable(Searchable) - Constructor for class org.apache.lucene.search.RemoteSearchable
-
Deprecated.Constructs and exports a remote searcher.
- remove() - Method in class org.apache.lucene.analysis.CharArrayMap.EntryIterator
- remove() - Method in class org.apache.lucene.analysis.CharArraySet.CharArraySetIterator
-
Deprecated.
- remove() - Method in class org.apache.lucene.benchmark.byTask.feeds.DirContentSource.Iterator
- remove() - Method in interface org.apache.lucene.util.collections.DoubleIterator
- remove() - Method in interface org.apache.lucene.util.collections.FloatIterator
- remove() - Method in interface org.apache.lucene.util.collections.IntIterator
- remove(float) - Method in class org.apache.lucene.util.collections.FloatToObjectMap
-
Removes a <key,value> pair from the map and returns the mapped value, or null if the none existed.
- remove(int) - Method in class org.apache.lucene.index.SegmentInfos
- remove(int) - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorPipeline
- remove(int) - Method in class org.apache.lucene.util.collections.IntHashSet
-
Remove a pair from the map, specified by it's key.
- remove(int) - Method in class org.apache.lucene.util.collections.IntToDoubleMap
-
Removes a <key,value> pair from the map and returns the mapped value, or
Double.NaN
if the none existed. - remove(int) - Method in class org.apache.lucene.util.collections.IntToIntMap
-
Removes a <key,value> pair from the map and returns the mapped value, or 0 if the none existed.
- remove(int) - Method in class org.apache.lucene.util.collections.IntToObjectMap
-
Removes a <key,value> pair from the map and returns the mapped value, or null if the none existed.
- remove(Class<? extends CategoryProperty>) - Method in interface org.apache.lucene.facet.index.attributes.CategoryAttribute
-
Remove an property of a certain property class.
- remove(Class<? extends CategoryProperty>) - Method in class org.apache.lucene.facet.index.attributes.CategoryAttributeImpl
- remove(Object) - Method in class org.apache.lucene.analysis.CharArrayMap.EntrySet
- remove(Object) - Method in class org.apache.lucene.analysis.CharArrayMap
- remove(Object) - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorPipeline
- remove(Object) - Method in class org.apache.lucene.util.MapBackedSet
- remove(Object) - Method in class org.apache.lucene.util.WeakIdentityMap
- remove(String) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Removes the value indexed by key.
- remove(String[]) - Method in class org.apache.lucene.index.IndexSplitter
- remove(K) - Method in class org.apache.lucene.util.collections.ArrayHashMap
-
Removes a <key,value> pair from the map and returns the mapped value, or null if the none existed.
- remove(K) - Method in class org.apache.lucene.util.collections.ObjectToFloatMap
-
Removes a <key,value> pair from the map and returns the mapped value, or
Float.NaN
if the none existed. - remove(K) - Method in class org.apache.lucene.util.collections.ObjectToIntMap
-
Removes a <key,value> pair from the map and returns the mapped value, or 0 if the none existed.
- remove(SegmentInfo) - Method in class org.apache.lucene.index.SegmentInfos
- remove(OpenBitSet) - Method in class org.apache.lucene.util.OpenBitSet
-
Remove all elements set in other.
- removeAccents(char[], int) - Method in class org.apache.lucene.analysis.ISOLatin1AccentFilter
-
Deprecated.To replace accented characters in a String by unaccented equivalents.
- removeAll(Collection<?>) - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorPipeline
- removeCoreClosedListener(SegmentReader.CoreClosedListener) - Method in class org.apache.lucene.index.SegmentReader
-
Expert: removes a CoreClosedListener from this reader's shared core
- RemoveDeletedQueryNodesProcessor - Class in org.apache.lucene.queryParser.core.processors
-
A
QueryNodeProcessorPipeline
class removes every instance ofDeletedQueryNode
from a query node tree. - RemoveDeletedQueryNodesProcessor() - Constructor for class org.apache.lucene.queryParser.core.processors.RemoveDeletedQueryNodesProcessor
- removeEldestEntry(Map.Entry<K, V>) - Method in class org.apache.lucene.util.collections.LRUHashMap
- RemoveEmptyNonLeafQueryNodeProcessor - Class in org.apache.lucene.queryParser.standard.processors
-
This processor removes every
QueryNode
that is not a leaf and has not children. - RemoveEmptyNonLeafQueryNodeProcessor() - Constructor for class org.apache.lucene.queryParser.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.
- removeIndexInput(IndexInput, String) - Method in class org.apache.lucene.store.MockDirectoryWrapper
- removeIndexOutput(IndexOutput, String) - Method in class org.apache.lucene.store.MockDirectoryWrapper
- removeReaderClosedListener(IndexReader.ReaderClosedListener) - Method in class org.apache.lucene.index.IndexReader
-
Expert: remove a previously added
IndexReader.ReaderClosedListener
. - removeWaitingListener(NRTManager.WaitingListener) - Method in class org.apache.lucene.search.NRTManager
-
Remove a listener added with
NRTManager.addWaitingListener(org.apache.lucene.search.NRTManager.WaitingListener)
. - renderFacetResult(IntermediateFacetResult) - Method in class org.apache.lucene.facet.search.FacetResultsHandler
-
Create a facet result from the temporary result.
- renderFacetResult(IntermediateFacetResult) - Method in class org.apache.lucene.facet.search.TopKFacetResultsHandler
- renderFacetResult(IntermediateFacetResult) - Method in class org.apache.lucene.facet.search.TopKInEachNodeHandler
- reopen() - Method in class org.apache.lucene.index.IndexReader
-
Deprecated.Use
IndexReader.openIfChanged(IndexReader)
instead - reopen(boolean) - Method in class org.apache.lucene.index.IndexReader
-
Deprecated.Write support will be removed in Lucene 4.0. Use
IndexReader.openIfChanged(IndexReader)
instead - reopen(IndexCommit) - Method in class org.apache.lucene.index.IndexReader
-
Deprecated.
- reopen(IndexWriter, boolean) - Method in class org.apache.lucene.index.IndexReader
-
Deprecated.
- 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_EXHAUST - Static variable in class org.apache.lucene.benchmark.byTask.tasks.TaskSequence
- RepeatableSampler - Class in org.apache.lucene.facet.search.sampling
-
Take random samples of large collections.
- RepeatableSampler(SamplingParams) - Constructor for class org.apache.lucene.facet.search.sampling.RepeatableSampler
- 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
- replace_s(int, int, String) - Method in class org.tartarus.snowball.SnowballProgram
-
Deprecated.for binary back compat. Will be removed in Lucene 4.0
- replaceLast(int, Builder.Node, T, boolean) - Method in class org.apache.lucene.util.fst.Builder.UnCompiledNode
- replacement - Variable in class org.apache.lucene.analysis.pt.RSLPStemmerBase.Rule
- replay(Collector) - Method in class org.apache.lucene.search.CachingCollector
-
Replays the cached doc IDs (and scores) to the given Collector.
- report(QualityQuery, TopDocs, String, IndexSearcher) - Method in class org.apache.lucene.benchmark.quality.utils.SubmissionReport
-
Report a search result for a certain quality query.
- 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
- reportAdditionalFailureInfo() - Method in class org.apache.lucene.util.LuceneTestCase
- reportAll(List<TaskStats>) - Method in class org.apache.lucene.benchmark.byTask.tasks.RepAllTask
-
Report detailed statistics as a string
- reportPartialFailureInfo() - Static method in class org.apache.lucene.util.LuceneTestCase
- 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
- requireDocumentScore() - Method in class org.apache.lucene.facet.search.params.association.AssociationFloatSumFacetRequest
- requireDocumentScore() - Method in class org.apache.lucene.facet.search.params.association.AssociationIntSumFacetRequest
- requireDocumentScore() - Method in class org.apache.lucene.facet.search.params.CountFacetRequest
- requireDocumentScore() - Method in class org.apache.lucene.facet.search.params.FacetRequest
-
Indicates whether the results of this request depends on each result document's score
- requireDocumentScore() - Method in class org.apache.lucene.facet.search.params.ScoreFacetRequest
- reserve(int) - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
- reset() - Method in class org.apache.lucene.analysis.CachingTokenFilter
- reset() - Method in class org.apache.lucene.analysis.CharFilter
- reset() - Method in class org.apache.lucene.analysis.CharReader
- reset() - Method in class org.apache.lucene.analysis.cjk.CJKBigramFilter
- reset() - Method in class org.apache.lucene.analysis.cjk.CJKTokenizer
-
Deprecated.
- reset() - Method in class org.apache.lucene.analysis.cn.ChineseTokenizer
-
Deprecated.
- reset() - Method in class org.apache.lucene.analysis.cn.smart.SentenceTokenizer
- reset() - Method in class org.apache.lucene.analysis.cn.smart.WordTokenFilter
- reset() - Method in class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
- reset() - Method in class org.apache.lucene.analysis.FilteringTokenFilter
- reset() - Method in class org.apache.lucene.analysis.hunspell.HunspellStemFilter
-
Reset the filter as well as the input TokenStream.
- reset() - Method in class org.apache.lucene.analysis.icu.segmentation.ICUTokenizer
- reset() - Method in class org.apache.lucene.analysis.ja.JapaneseTokenizer
- reset() - Method in class org.apache.lucene.analysis.LimitTokenCountFilter
- 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.miscellaneous.PrefixAndSuffixAwareTokenFilter
- reset() - Method in class org.apache.lucene.analysis.miscellaneous.PrefixAwareTokenFilter
- reset() - Method in class org.apache.lucene.analysis.miscellaneous.SingleTokenTokenStream
- 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.MockTokenizer
- reset() - Method in class org.apache.lucene.analysis.ngram.EdgeNGramTokenFilter
- reset() - Method in class org.apache.lucene.analysis.ngram.EdgeNGramTokenizer
- 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.NumericTokenStream
- 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.phonetic.BeiderMorseFilter
- 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.position.PositionFilter
- reset() - Method in class org.apache.lucene.analysis.shingle.ShingleFilter
- reset() - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter
-
Deprecated.
- reset() - Method in class org.apache.lucene.analysis.sinks.TokenRangeSinkFilter
- reset() - Method in class org.apache.lucene.analysis.synonym.SynonymFilter
- reset() - Method in class org.apache.lucene.analysis.TeeSinkTokenFilter.SinkFilter
-
Called by
TeeSinkTokenFilter.SinkTokenStream.reset()
. - reset() - Method in class org.apache.lucene.analysis.TeeSinkTokenFilter.SinkTokenStream
- reset() - Method in class org.apache.lucene.analysis.th.ThaiWordFilter
- reset() - Method in class org.apache.lucene.analysis.TokenFilter
-
Reset the filter as well as the input TokenStream.
- reset() - Method in class org.apache.lucene.analysis.TokenStream
-
Resets this stream to the beginning.
- reset() - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
- 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.benchmark.byTask.utils.StringBuilderReader
- reset() - Method in class org.apache.lucene.facet.index.CategoryListPayloadStream
-
Resets this stream to begin building a new payload.
- reset() - Method in class org.apache.lucene.facet.index.streaming.CategoryAttributesStream
- reset() - Method in class org.apache.lucene.facet.index.streaming.CategoryListTokenizer
- reset() - Method in class org.apache.lucene.search.highlight.OffsetLimitTokenFilter
- reset() - Method in class org.apache.lucene.search.highlight.TokenStreamFromTermPositionVector
- reset() - Method in class org.apache.lucene.spatial.tier.DistanceFilter
-
Deprecated.You must call this before re-using this DistanceFilter across searches
- 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
-
Resets this to an empty file.
- reset() - Method in class org.apache.lucene.util.ByteBlockPool
- reset() - Method in class org.apache.lucene.util.CharacterUtils.CharacterBuffer
-
Resets the CharacterBuffer.
- reset() - Method in class org.apache.lucene.util.RollingBuffer
- reset() - Method in interface org.apache.lucene.util.RollingBuffer.Resettable
- reset() - Method in class org.apache.lucene.util.UnsafeByteArrayInputStream
-
Resets the stream back to its original state.
- reset(byte[]) - Method in class org.apache.lucene.store.ByteArrayDataInput
- reset(byte[]) - Method in class org.apache.lucene.store.ByteArrayDataOutput
- reset(byte[], int, int) - Method in class org.apache.lucene.store.ByteArrayDataInput
- reset(byte[], int, int) - Method in class org.apache.lucene.store.ByteArrayDataOutput
- reset(int, double) - Method in class org.apache.lucene.facet.search.results.MutableFacetResultNode
-
Reset a facet Result Node.
- reset(Reader) - Method in class org.apache.lucene.analysis.CharTokenizer
- reset(Reader) - Method in class org.apache.lucene.analysis.cjk.CJKTokenizer
-
Deprecated.
- reset(Reader) - Method in class org.apache.lucene.analysis.cn.ChineseTokenizer
-
Deprecated.
- reset(Reader) - Method in class org.apache.lucene.analysis.cn.smart.SentenceTokenizer
- reset(Reader) - Method in class org.apache.lucene.analysis.icu.segmentation.ICUTokenizer
- reset(Reader) - Method in class org.apache.lucene.analysis.ja.JapaneseTokenizer
- reset(Reader) - Method in class org.apache.lucene.analysis.KeywordTokenizer
- reset(Reader) - Method in class org.apache.lucene.analysis.MockTokenizer
- reset(Reader) - Method in class org.apache.lucene.analysis.ReusableAnalyzerBase.TokenStreamComponents
-
Resets the encapsulated components with the given reader.
- reset(Reader) - Method in class org.apache.lucene.analysis.standard.ClassicTokenizer
- reset(Reader) - Method in class org.apache.lucene.analysis.standard.StandardTokenizer
- reset(Reader) - Method in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
- reset(Reader) - Method in class org.apache.lucene.analysis.Tokenizer
-
Expert: Reset the tokenizer to a new reader.
- reset(Reader) - Method in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
- reset(Reader) - Method in class org.apache.lucene.util.RollingCharBuffer
-
Clear array and switch to new reader.
- reset(Random) - Method in class org.apache.lucene.util.LineFileDocs
- 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
- reSetNorms(String) - Method in class org.apache.lucene.index.FieldNormModifier
-
Deprecated.Resets the norms for the specified field.
- 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(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
- resizeTermBuffer(int) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
-
Deprecated.
- resizeTermBuffer(int) - Method in interface org.apache.lucene.analysis.tokenattributes.TermAttribute
-
Deprecated.Grows the termBuffer to at least size newSize, preserving the existing content.
- resolveEntity(String, String) - Method in class org.apache.lucene.analysis.compound.hyphenation.PatternParser
- 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 - Variable in class org.apache.lucene.util.UnicodeUtil.UTF16Result
- result - Variable in class org.apache.lucene.util.UnicodeUtil.UTF8Result
- result - Variable in class org.tartarus.snowball.Among
- ResultSortUtils - Class in org.apache.lucene.facet.util
-
Utilities for generating facet results sorted as required
- ResultSortUtils() - Constructor for class org.apache.lucene.facet.util.ResultSortUtils
- retainAll(Collection<?>) - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorPipeline
- rethrow(Throwable) - Static method in class org.apache.lucene.util.Rethrow
-
Rethrows
t
(identical object). - Rethrow - Class in org.apache.lucene.util
-
Sneaky: rethrowing checked exceptions as unchecked ones.
- Rethrow() - Constructor for class org.apache.lucene.util.Rethrow
- 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
- retrieveGroup(int) - Method in class org.apache.lucene.search.grouping.AbstractSecondPassGroupingCollector
-
Returns the group the specified doc belongs to or
null
if no group could be retrieved. - retrieveGroup(int) - Method in class org.apache.lucene.search.grouping.TermSecondPassGroupingCollector
- retrieveGroupHeadAndAddIfNotExist(int) - Method in class org.apache.lucene.search.grouping.AbstractAllGroupHeadsCollector
-
Returns the group head and puts it into
AbstractAllGroupHeadsCollector.temporalResult
. - retrieveGroupHeads() - Method in class org.apache.lucene.search.grouping.AbstractAllGroupHeadsCollector
- retrieveGroupHeads(int) - Method in class org.apache.lucene.search.grouping.AbstractAllGroupHeadsCollector
- retrieveInterestingTerms(int) - Method in class org.apache.lucene.search.similar.MoreLikeThis
- retrieveInterestingTerms(Reader) - Method in class org.apache.lucene.search.similar.MoreLikeThis
-
Deprecated.
- retrieveInterestingTerms(Reader, String) - Method in class org.apache.lucene.search.similar.MoreLikeThis
-
Convenience routine to make it easy to return the most interesting words in a document.
- retrieveTerms(int) - Method in class org.apache.lucene.search.similar.MoreLikeThis
-
Find words for a more-like-this query former.
- retrieveTerms(Reader) - Method in class org.apache.lucene.search.similar.MoreLikeThis
-
Deprecated.use
MoreLikeThis.retrieveTerms(Reader, String)
instead - retrieveTerms(Reader, String) - Method in class org.apache.lucene.search.similar.MoreLikeThis
-
Find words for a more-like-this query former.
- ReusableAnalyzerBase - Class in org.apache.lucene.analysis
-
An convenience subclass of Analyzer that makes it easy to implement
TokenStream
reuse. - ReusableAnalyzerBase() - Constructor for class org.apache.lucene.analysis.ReusableAnalyzerBase
- ReusableAnalyzerBase.TokenStreamComponents - Class in org.apache.lucene.analysis
-
This class encapsulates the outer components of a token stream.
- reusableTokenStream(String, Reader) - Method in class org.apache.lucene.analysis.Analyzer
-
Creates a TokenStream that is allowed to be re-used from the previous time that the same thread called this method.
- reusableTokenStream(String, Reader) - Method in class org.apache.lucene.analysis.cn.smart.SmartChineseAnalyzer
- reusableTokenStream(String, Reader) - Method in class org.apache.lucene.analysis.LimitTokenCountAnalyzer
- reusableTokenStream(String, Reader) - Method in class org.apache.lucene.analysis.MockAnalyzer
- reusableTokenStream(String, Reader) - Method in class org.apache.lucene.analysis.PerFieldAnalyzerWrapper
- reusableTokenStream(String, Reader) - Method in class org.apache.lucene.analysis.query.QueryAutoStopWordAnalyzer
- reusableTokenStream(String, Reader) - Method in class org.apache.lucene.analysis.ReusableAnalyzerBase
-
This method uses
ReusableAnalyzerBase.createComponents(String, Reader)
to obtain an instance ofReusableAnalyzerBase.TokenStreamComponents
. - reusableTokenStream(String, Reader) - Method in class org.apache.lucene.analysis.shingle.ShingleAnalyzerWrapper
- reusableTokenStream(String, Reader) - Method in class org.apache.lucene.analysis.snowball.SnowballAnalyzer
-
Deprecated.Returns a (possibly reused)
StandardTokenizer
filtered by aStandardFilter
, aLowerCaseFilter
, aStopFilter
, and aSnowballFilter
- reusableTokenStream(String, Reader) - Method in class org.apache.lucene.collation.CollationKeyAnalyzer
- reusableTokenStream(String, Reader) - Method in class org.apache.lucene.collation.ICUCollationKeyAnalyzer
- reuseFields - Variable in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
- ReutersContentSource - Class in org.apache.lucene.benchmark.byTask.feeds
-
A
ContentSource
reading from the Reuters collection. - 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(char[]) - Static method in class org.apache.lucene.analysis.reverse.ReverseStringFilter
-
Deprecated.use
ReverseStringFilter.reverse(Version, char[])
instead. This method will be removed in Lucene 4.0 - reverse(char[], int) - Static method in class org.apache.lucene.analysis.reverse.ReverseStringFilter
-
Deprecated.use
ReverseStringFilter.reverse(Version, char[], int)
instead. This method will be removed in Lucene 4.0 - reverse(char[], int, int) - Static method in class org.apache.lucene.analysis.reverse.ReverseStringFilter
-
Deprecated.use
ReverseStringFilter.reverse(Version, char[], int, int)
instead. This method will be removed in Lucene 4.0 - reverse(String) - Static method in class org.apache.lucene.analysis.reverse.ReverseStringFilter
-
Deprecated.use
ReverseStringFilter.reverse(Version, String)
instead. This method will be removed in Lucene 4.0 - reverse(Version, char[]) - Static method in class org.apache.lucene.analysis.reverse.ReverseStringFilter
-
Reverses the given input buffer in-place
- reverse(Version, 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(Version, 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(Version, String) - Static method in class org.apache.lucene.analysis.reverse.ReverseStringFilter
-
Reverses the given input string
- reversed - Variable in class org.apache.lucene.search.grouping.AbstractAllGroupHeadsCollector
- reverseMul - Variable in class org.apache.lucene.search.FieldValueHitQueue
- ReverseOrdFieldSource - Class in org.apache.lucene.search.function
-
Expert: obtains the ordinal of the field value from the default Lucene
FieldCache
using getStringIndex() and reverses the order. - ReverseOrdFieldSource(String) - Constructor for class org.apache.lucene.search.function.ReverseOrdFieldSource
-
Contructor for a certain field.
- ReversePathHierarchyTokenizer - Class in org.apache.lucene.analysis.path
-
Tokenizer for domain-like hierarchies.
- ReversePathHierarchyTokenizer(Reader) - Constructor for class org.apache.lucene.analysis.path.ReversePathHierarchyTokenizer
- ReversePathHierarchyTokenizer(Reader, char, char) - Constructor for class org.apache.lucene.analysis.path.ReversePathHierarchyTokenizer
- ReversePathHierarchyTokenizer(Reader, char, char, int) - Constructor for class org.apache.lucene.analysis.path.ReversePathHierarchyTokenizer
- ReversePathHierarchyTokenizer(Reader, char, int) - Constructor for class org.apache.lucene.analysis.path.ReversePathHierarchyTokenizer
- ReversePathHierarchyTokenizer(Reader, int) - Constructor for class org.apache.lucene.analysis.path.ReversePathHierarchyTokenizer
- ReversePathHierarchyTokenizer(Reader, int, char) - Constructor for class org.apache.lucene.analysis.path.ReversePathHierarchyTokenizer
- ReversePathHierarchyTokenizer(Reader, int, char, char) - Constructor for class org.apache.lucene.analysis.path.ReversePathHierarchyTokenizer
- ReversePathHierarchyTokenizer(Reader, 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
-
Deprecated.use
ReverseStringFilter(Version, TokenStream)
instead. This constructor will be removed in Lucene 4.0 - ReverseStringFilter(TokenStream, char) - Constructor for class org.apache.lucene.analysis.reverse.ReverseStringFilter
-
Deprecated.use
ReverseStringFilter(Version, TokenStream, char)
instead. This constructor will be removed in Lucene 4.0 - ReverseStringFilter(Version, TokenStream) - Constructor for class org.apache.lucene.analysis.reverse.ReverseStringFilter
-
Create a new ReverseStringFilter that reverses all tokens in the supplied
TokenStream
. - ReverseStringFilter(Version, 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
. - rewind() - Method in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree.Iterator
- rewrite(IndexReader) - Method in class org.apache.lucene.search.BooleanQuery
- rewrite(IndexReader) - Method in class org.apache.lucene.search.BoostingQuery
- rewrite(IndexReader) - Method in class org.apache.lucene.search.ConstantScoreQuery
- rewrite(IndexReader) - Method in class org.apache.lucene.search.DisjunctionMaxQuery
-
Optimize our representation and our subqueries representations
- rewrite(IndexReader) - Method in class org.apache.lucene.search.FilteredQuery
-
Rewrites the wrapped query.
- rewrite(IndexReader) - Method in class org.apache.lucene.search.function.CustomScoreQuery
- rewrite(IndexReader) - Method in class org.apache.lucene.search.function.ValueSourceQuery
- rewrite(IndexReader) - Method in class org.apache.lucene.search.FuzzyLikeThisQuery
- rewrite(IndexReader) - Method in class org.apache.lucene.search.join.ToChildBlockJoinQuery
- rewrite(IndexReader) - Method in class org.apache.lucene.search.join.ToParentBlockJoinQuery
- rewrite(IndexReader) - Method in class org.apache.lucene.search.MultiPhraseQuery
- rewrite(IndexReader) - Method in class org.apache.lucene.search.MultiTermQuery
-
To rewrite to a simpler form, instead return a simpler enum from
MultiTermQuery.getEnum(IndexReader)
. - 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.similar.MoreLikeThisQuery
- rewrite(IndexReader) - Method in class org.apache.lucene.search.spans.FieldMaskingSpanQuery
- rewrite(IndexReader) - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper
- rewrite(IndexReader) - Method in class org.apache.lucene.search.spans.SpanNearQuery
- rewrite(IndexReader) - Method in class org.apache.lucene.search.spans.SpanNotQuery
- rewrite(IndexReader) - Method in class org.apache.lucene.search.spans.SpanOrQuery
- rewrite(IndexReader) - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery
- rewrite(IndexReader, MultiTermQuery) - Method in class org.apache.lucene.search.MultiTermQuery.RewriteMethod
- rewrite(IndexReader, MultiTermQuery) - Method in class org.apache.lucene.search.ScoringRewrite
- 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, MultiTermQuery) - Method in class org.apache.lucene.search.TopTermsRewrite
- rewrite(Query) - Method in class org.apache.lucene.search.IndexSearcher
-
Expert: called to re-write queries into primitive queries.
- rewrite(Query) - Method in class org.apache.lucene.search.MultiSearcher
-
Deprecated.
- rewrite(Query) - Method in class org.apache.lucene.search.RemoteSearchable
-
Deprecated.
- rewrite(Query) - Method in interface org.apache.lucene.search.Searchable
-
Deprecated.Expert: called to re-write queries into primitive queries.
- rewrite(Query) - Method in class org.apache.lucene.search.Searcher
-
Deprecated.
- rewriteMethod - Variable in class org.apache.lucene.search.MultiTermQuery
- RewriteMethod() - Constructor for class org.apache.lucene.search.MultiTermQuery.RewriteMethod
- RIDFTermPruningPolicy - Class in org.apache.lucene.index.pruning
-
Implementation of
TermPruningPolicy
that uses "residual IDF" metric to determine the postings of terms to keep/remove, as defined in http://www.dc.fi.udc.es/~barreiro/publications/blanco_barreiro_ecir2007.pdf. - RIDFTermPruningPolicy(IndexReader, Map<String, Integer>, Map<String, Double>, double) - Constructor for class org.apache.lucene.index.pruning.RIDFTermPruningPolicy
- RIGHT_ID - Static variable in class org.apache.lucene.analysis.ja.dict.UserDictionary
- rmDir(File) - Static method in class org.apache.lucene.util._TestUtil
-
Deletes a directory and everything underneath it.
- RMIRemoteSearchable - Interface in org.apache.lucene.search
-
Deprecated.This package (all of contrib/remote) will be removed in 4.0.
- 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.util.TwoPhaseCommit
-
Discards any changes that have occurred since the last commit.
- rollback() - Method in class org.apache.lucene.util.TwoPhaseCommitTool.TwoPhaseCommitWrapper
- 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
- RollingCharBuffer - Class in org.apache.lucene.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.util.RollingCharBuffer
- RomanianAnalyzer - Class in org.apache.lucene.analysis.ro
-
Analyzer
for Romanian. - RomanianAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.ro.RomanianAnalyzer
-
Builds an analyzer with the default stop words:
RomanianAnalyzer.DEFAULT_STOPWORD_FILE
. - RomanianAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.ro.RomanianAnalyzer
-
Builds an analyzer with the given stop words.
- RomanianAnalyzer(Version, Set<?>, Set<?>) - Constructor for class org.apache.lucene.analysis.ro.RomanianAnalyzer
-
Builds an analyzer with the given stop words.
- RomanianStemmer - Class in org.tartarus.snowball.ext
-
Generated class implementing code 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 interface 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.
- round(long, DateTools.Resolution) - Static method in class org.apache.lucene.document.DateTools
-
Limit a date's resolution.
- round(Date, DateTools.Resolution) - Static method in class org.apache.lucene.document.DateTools
-
Limit a date's resolution.
- ROUND - Static variable in class org.apache.lucene.benchmark.byTask.tasks.ReportTask
- Row - Class in org.egothor.stemmer
-
The Row class represents a row in a matrix representation of a trie.
- Row() - Constructor for class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.Matrix.Column.Row
-
Deprecated.
- Row() - Constructor for class org.egothor.stemmer.Row
-
The default constructor for the Row object.
- Row(DataInput) - Constructor for class org.egothor.stemmer.Row
-
Construct a Row object from input carried in via the given input stream.
- Row(Row) - Constructor for class org.egothor.stemmer.Row
-
Construct a Row using the cells of the given Row.
- RPAREN - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
-
RegularExpression Id.
- RPAREN - Static variable in interface org.apache.lucene.queryParser.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.
- 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() - Method in class org.apache.lucene.search.FilterManager.FilterCleaner
-
Deprecated.
- run() - Method in class org.apache.lucene.search.NRTManagerReopenThread
- run() - Method in class org.apache.lucene.search.TimeLimitingCollector.TimerThread
- run() - Method in class org.apache.lucene.store.Lock.With
-
Calls
Lock.With.doBody()
while lock is obtained. - run() - Method in class org.apache.lucene.util.ReaderUtil.Gather
- run(int) - Method in class org.apache.lucene.util.ReaderUtil.Gather
- run(String[]) - Static method in class org.apache.lucene.index.pruning.PruningTool
- run(IndexCommit) - Method in class org.apache.lucene.index.SegmentInfos.FindSegmentsFile
- runAndMaybeStats(boolean) - Method in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
-
Run the task, record statistics.
- runChild(FrameworkMethod, RunNotifier) - Method in class org.apache.lucene.util.LuceneTestCaseRunner
- RUNCNT - Static variable in class org.apache.lucene.benchmark.byTask.tasks.ReportTask
- runSearchThreads(long) - Method in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
- runTest(String) - Method in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
- RussianAnalyzer - Class in org.apache.lucene.analysis.ru
-
Analyzer
for Russian language. - RussianAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.ru.RussianAnalyzer
- RussianAnalyzer(Version, String...) - Constructor for class org.apache.lucene.analysis.ru.RussianAnalyzer
-
Deprecated.use
RussianAnalyzer(Version, Set)
instead - RussianAnalyzer(Version, Map<?, ?>) - Constructor for class org.apache.lucene.analysis.ru.RussianAnalyzer
-
Deprecated.use
RussianAnalyzer(Version, Set)
instead - RussianAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.ru.RussianAnalyzer
-
Builds an analyzer with the given stop words
- RussianAnalyzer(Version, Set<?>, Set<?>) - Constructor for class org.apache.lucene.analysis.ru.RussianAnalyzer
-
Builds an analyzer with the given stop words
- RussianLetterTokenizer - Class in org.apache.lucene.analysis.ru
-
Deprecated.Use
StandardTokenizer
instead, which has the same functionality. This filter will be removed in Lucene 5.0 - RussianLetterTokenizer(Reader) - Constructor for class org.apache.lucene.analysis.ru.RussianLetterTokenizer
-
Deprecated.use
RussianLetterTokenizer(Version, Reader)
instead. This will be removed in Lucene 4.0. - RussianLetterTokenizer(AttributeSource.AttributeFactory, Reader) - Constructor for class org.apache.lucene.analysis.ru.RussianLetterTokenizer
-
Deprecated.use
RussianLetterTokenizer(Version, AttributeSource.AttributeFactory, Reader)
instead. This will be removed in Lucene 4.0. - RussianLetterTokenizer(AttributeSource, Reader) - Constructor for class org.apache.lucene.analysis.ru.RussianLetterTokenizer
-
Deprecated.use
RussianLetterTokenizer(Version, AttributeSource, Reader)
instead. This will be removed in Lucene 4.0. - RussianLetterTokenizer(Version, Reader) - Constructor for class org.apache.lucene.analysis.ru.RussianLetterTokenizer
-
Deprecated.Construct a new RussianLetterTokenizer.
- RussianLetterTokenizer(Version, AttributeSource.AttributeFactory, Reader) - Constructor for class org.apache.lucene.analysis.ru.RussianLetterTokenizer
-
Deprecated.Construct a new RussianLetterTokenizer using a given
AttributeSource.AttributeFactory
. - RussianLetterTokenizer(Version, AttributeSource, Reader) - Constructor for class org.apache.lucene.analysis.ru.RussianLetterTokenizer
-
Deprecated.Construct a new RussianLetterTokenizer using a given
AttributeSource
. - RussianLightStemFilter - Class in org.apache.lucene.analysis.ru
-
A
TokenFilter
that appliesRussianLightStemmer
to stem Russian words. - RussianLightStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.ru.RussianLightStemFilter
- RussianLightStemmer - Class in org.apache.lucene.analysis.ru
-
Light Stemmer for Russian.
- RussianLightStemmer() - Constructor for class org.apache.lucene.analysis.ru.RussianLightStemmer
- RussianLowerCaseFilter - Class in org.apache.lucene.analysis.ru
-
Deprecated.Use
LowerCaseFilter
instead, which has the same functionality. This filter will be removed in Lucene 4.0 - RussianLowerCaseFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.ru.RussianLowerCaseFilter
-
Deprecated.
- RussianStemFilter - Class in org.apache.lucene.analysis.ru
-
Deprecated.Use
SnowballFilter
withRussianStemmer
instead, which has the same functionality. This filter will be removed in Lucene 4.0 - RussianStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.ru.RussianStemFilter
-
Deprecated.
- RussianStemmer - Class in org.tartarus.snowball.ext
-
Generated class implementing code defined by a snowball script.
- RussianStemmer() - Constructor for class org.tartarus.snowball.ext.RussianStemmer
S
- s - Variable in class org.tartarus.snowball.Among
- s_size - Variable in class org.tartarus.snowball.Among
- s1 - Static variable in class org.apache.lucene.search.SearchEquivalenceTestBase
- s2 - Static variable in class org.apache.lucene.search.SearchEquivalenceTestBase
- sameRow - Static variable in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.TokenPositioner
-
Deprecated.
- 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
- SampleFixer - Interface in org.apache.lucene.facet.search.sampling
-
Fixer of sample facet accumulation results
- Sampler - Class in org.apache.lucene.facet.search.sampling
-
Sampling definition for facets accumulation
- Sampler() - Constructor for class org.apache.lucene.facet.search.sampling.Sampler
-
Construct with
SamplingParams
- Sampler(SamplingParams) - Constructor for class org.apache.lucene.facet.search.sampling.Sampler
-
Construct with certain
SamplingParams
- Sampler.SampleResult - Class in org.apache.lucene.facet.search.sampling
-
Result of sample computation
- SampleResult(ScoredDocIDs, double) - Constructor for class org.apache.lucene.facet.search.sampling.Sampler.SampleResult
- SamplingAccumulator - Class in org.apache.lucene.facet.search.sampling
-
Facets accumulation with sampling.
- SamplingAccumulator(Sampler, FacetSearchParams, IndexReader, TaxonomyReader) - Constructor for class org.apache.lucene.facet.search.sampling.SamplingAccumulator
-
Constructor...
- SamplingAccumulator(Sampler, FacetSearchParams, IndexReader, TaxonomyReader, IntArrayAllocator, FloatArrayAllocator) - Constructor for class org.apache.lucene.facet.search.sampling.SamplingAccumulator
-
Constructor...
- samplingParams - Variable in class org.apache.lucene.facet.search.sampling.Sampler
- SamplingParams - Class in org.apache.lucene.facet.search.sampling
-
Parameters for sampling, dictating whether sampling is to take place and how.
- SamplingParams() - Constructor for class org.apache.lucene.facet.search.sampling.SamplingParams
- SamplingWrapper - Class in org.apache.lucene.facet.search
-
Wrap any Facets Accumulator with sampling.
- SamplingWrapper(FacetsAccumulator, Sampler) - Constructor for class org.apache.lucene.facet.search.SamplingWrapper
- save - Variable in class org.apache.lucene.analysis.phonetic.PhoneticFilter
- save(File) - Method in class org.apache.lucene.util.fst.FST
-
Writes an automaton to a file.
- save(DataOutput) - Method in class org.apache.lucene.util.fst.FST
- sc - Variable in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
-
The character stored in this node: splitchar.
- SCALE_FACTOR - Static variable in class org.apache.lucene.spatial.geometry.FixedLatLng
-
Deprecated.
- SCALE_FACTOR_INT - Static variable in class org.apache.lucene.spatial.geometry.FixedLatLng
-
Deprecated.
- score - Variable in class org.apache.lucene.search.ScoreDoc
-
The score of this document for the query.
- score - Variable in class org.apache.lucene.search.spell.SuggestWord
-
the score of the word
- score() - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantScorer
- score() - Method in class org.apache.lucene.search.payloads.PayloadNearQuery.PayloadNearSpanScorer
- score() - Method in class org.apache.lucene.search.payloads.PayloadTermQuery.PayloadTermWeight.PayloadTermSpanScorer
- score() - Method in class org.apache.lucene.search.ScoreCachingWrappingScorer
- score() - Method in class org.apache.lucene.search.Scorer
-
Returns the score of the current document matching the query.
- score() - Method in class org.apache.lucene.search.spans.SpanScorer
- score(List<SegmentInfo>, boolean, long) - Method in class org.apache.lucene.index.TieredMergePolicy
-
Expert: scores one merge; subclasses can override.
- score(Collector) - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantScorer
- score(Collector) - Method in class org.apache.lucene.search.ScoreCachingWrappingScorer
- score(Collector) - Method in class org.apache.lucene.search.Scorer
-
Scores and collects all matching documents.
- score(Collector, int, int) - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantScorer
- score(Collector, int, int) - Method in class org.apache.lucene.search.ScoreCachingWrappingScorer
- score(Collector, int, int) - Method in class org.apache.lucene.search.Scorer
-
Expert: Collects matching documents in a range.
- SCORE - Static variable in class org.apache.lucene.search.SortField
-
Sort by document score (relevance).
- SCORE_TOLERANCE_DELTA - Static variable in class org.apache.lucene.search.CheckHits.ExplanationAsserter
-
Deprecated.
- 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
- ScoredDocIdCollector - Class in org.apache.lucene.facet.search
-
A
Collector
which stores all docIDs and their scores in aScoredDocIDs
instance. - ScoredDocIDs - Interface in org.apache.lucene.facet.search
-
Document IDs with scores for each, driving facets accumulation.
- scoredDocIdsIterator() - Method in class org.apache.lucene.facet.search.ScoredDocIdCollector
- ScoredDocIDsIterator - Interface in org.apache.lucene.facet.search
-
Iterator over document IDs and their scores.
- ScoredDocIdsUtils - Class in org.apache.lucene.facet.util
-
Utility methods for Scored Doc IDs.
- ScoredDocIdsUtils() - Constructor for class org.apache.lucene.facet.util.ScoredDocIdsUtils
- ScoreDoc - Class in org.apache.lucene.search
-
Holds one hit in
TopDocs
. - ScoreDoc(int, float) - Constructor for class org.apache.lucene.search.ScoreDoc
-
Constructs a ScoreDoc.
- ScoreDoc(int, float, int) - Constructor for class org.apache.lucene.search.ScoreDoc
-
Constructs a ScoreDoc.
- scoreDocs - Variable in class org.apache.lucene.search.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.
- ScoreFacetRequest - Class in org.apache.lucene.facet.search.params
-
Facet request for weighting facets according to document scores.
- ScoreFacetRequest(CategoryPath, int) - Constructor for class org.apache.lucene.facet.search.params.ScoreFacetRequest
-
Create a score facet request for a given node in the taxonomy.
- 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(String[], String[], BoundaryScanner) - Constructor for class org.apache.lucene.search.vectorhighlight.ScoreOrderFragmentsBuilder
- ScoreOrderFragmentsBuilder(BoundaryScanner) - Constructor for class org.apache.lucene.search.vectorhighlight.ScoreOrderFragmentsBuilder
- ScoreOrderFragmentsBuilder.ScoreComparator - Class in org.apache.lucene.search.vectorhighlight
- scorePayload(int, String, int, int, byte[], int, int) - Method in class org.apache.lucene.search.Similarity
-
Calculate a scoring factor based on the data in the payload.
- scorePayload(int, String, int, int, byte[], int, int) - Method in class org.apache.lucene.search.SimilarityDelegator
-
Deprecated.
- scorer(IndexReader, boolean, boolean) - Method in class org.apache.lucene.search.BooleanQuery.BooleanWeight
- scorer(IndexReader, boolean, boolean) - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantWeight
- scorer(IndexReader, boolean, boolean) - Method in class org.apache.lucene.search.DisjunctionMaxQuery.DisjunctionMaxWeight
-
Create the scorer used to score our associated DisjunctionMaxQuery
- scorer(IndexReader, boolean, boolean) - Method in class org.apache.lucene.search.payloads.PayloadNearQuery.PayloadNearSpanWeight
- scorer(IndexReader, boolean, boolean) - Method in class org.apache.lucene.search.payloads.PayloadTermQuery.PayloadTermWeight
- scorer(IndexReader, boolean, boolean) - Method in class org.apache.lucene.search.spans.SpanWeight
- scorer(IndexReader, boolean, boolean) - Method in class org.apache.lucene.search.Weight
-
Returns a
Scorer
which scores documents in/out-of order according toscoreDocsInOrder
. - Scorer - Class in org.apache.lucene.search
-
Expert: Common scoring functionality for different types of queries.
- Scorer - Interface in org.apache.lucene.search.highlight
-
A Scorer is responsible for scoring a stream of tokens.
- Scorer(Similarity) - Constructor for class org.apache.lucene.search.Scorer
-
Deprecated.Use
Scorer(Weight)
instead. - Scorer(Similarity, Weight) - Constructor for class org.apache.lucene.search.Scorer
-
Deprecated.Use
Scorer(Weight)
instead. - Scorer(Weight) - Constructor for class org.apache.lucene.search.Scorer
-
Constructs a Scorer
- Scorer.ScorerVisitor<P extends Query,C extends Query,S extends Scorer> - Class in org.apache.lucene.search
-
A callback to gather information from a scorer and its sub-scorers.
- ScorerDocQueue - Class in org.apache.lucene.util
-
Deprecated.
- ScorerDocQueue(int) - Constructor for class org.apache.lucene.util.ScorerDocQueue
-
Deprecated.Create a ScorerDocQueue with a maximum size.
- ScorerVisitor() - Constructor for class org.apache.lucene.search.Scorer.ScorerVisitor
- scoresDocsOutOfOrder() - Method in class org.apache.lucene.search.BooleanQuery.BooleanWeight
- scoresDocsOutOfOrder() - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantWeight
- scoresDocsOutOfOrder() - Method in class org.apache.lucene.search.Weight
-
Returns true iff this implementation scores docs only out of order.
- SCORING_BOOLEAN_QUERY_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_QUERY_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. - ScoringAggregator - Class in org.apache.lucene.facet.search.aggregator
-
An
Aggregator
which updates the weight of a category according to the scores of the documents it was found in. - ScoringAggregator(float[]) - Constructor for class org.apache.lucene.facet.search.aggregator.ScoringAggregator
- ScoringRewrite<Q extends Query> - Class in org.apache.lucene.search
- 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
-
Implementation of
ScriptAttribute
that stores the script as an integer. - ScriptAttributeImpl() - Constructor for class org.apache.lucene.analysis.icu.tokenattributes.ScriptAttributeImpl
- ScriptEnd - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
RegularExpression Id.
- ScriptStart - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
RegularExpression Id.
- ScriptTag() - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParser
- ScriptText - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
RegularExpression Id.
- 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(Query, int) - Method in class org.apache.lucene.search.IndexSearcher
-
Finds the top
n
hits forquery
. - search(Query, int) - Method in class org.apache.lucene.search.Searcher
-
Deprecated.Finds the top
n
hits forquery
. - search(Query, int, Sort) - Method in class org.apache.lucene.search.IndexSearcher
-
Search implementation with arbitrary sorting and no filter.
- search(Query, int, Sort) - Method in class org.apache.lucene.search.Searcher
-
Deprecated.Search implementation with arbitrary sorting and no filter.
- search(Query, Collector) - Method in class org.apache.lucene.search.CheckHits.ExplanationAssertingSearcher
- search(Query, Collector) - Method in class org.apache.lucene.search.IndexSearcher
-
Lower-level search API.
- search(Query, Collector) - Method in class org.apache.lucene.search.Searcher
-
Deprecated.Lower-level search API.
- search(Query, Filter, int) - Method in class org.apache.lucene.search.CheckHits.ExplanationAssertingSearcher
- search(Query, Filter, int) - Method in class org.apache.lucene.search.IndexSearcher
-
Finds the top
n
hits forquery
, applyingfilter
if non-null. - search(Query, Filter, int) - Method in class org.apache.lucene.search.Searcher
-
Deprecated.Finds the top
n
hits forquery
, applyingfilter
if non-null. - search(Query, Filter, int, Sort) - Method in class org.apache.lucene.search.CheckHits.ExplanationAssertingSearcher
- search(Query, Filter, int, Sort) - Method in class org.apache.lucene.search.IndexSearcher
-
Search implementation with arbitrary sorting.
- search(Query, Filter, int, Sort) - Method in class org.apache.lucene.search.Searcher
-
Deprecated.Search implementation with arbitrary sorting.
- search(Query, Filter, Collector) - Method in class org.apache.lucene.search.CheckHits.ExplanationAssertingSearcher
- search(Query, Filter, Collector) - Method in class org.apache.lucene.search.IndexSearcher
-
Lower-level search API.
- search(Query, Filter, Collector) - Method in class org.apache.lucene.search.Searcher
-
Deprecated.Lower-level search API.
- search(Weight, Filter, int) - Method in class org.apache.lucene.search.IndexSearcher
-
Expert: Low-level search implementation.
- search(Weight, Filter, int) - Method in class org.apache.lucene.search.MultiSearcher
-
Deprecated.
- search(Weight, Filter, int) - Method in class org.apache.lucene.search.ParallelMultiSearcher
-
Deprecated.A search implementation which executes each
Searchable
in its own thread and waits for each search to complete and merge the results back together. - search(Weight, Filter, int) - Method in class org.apache.lucene.search.RemoteSearchable
-
Deprecated.
- search(Weight, Filter, int) - Method in interface org.apache.lucene.search.Searchable
-
Deprecated.Expert: Low-level search implementation.
- search(Weight, Filter, int) - Method in class org.apache.lucene.search.Searcher
-
Deprecated.
- search(Weight, Filter, int, Sort) - Method in class org.apache.lucene.search.IndexSearcher
-
Expert: Low-level search implementation with arbitrary sorting.
- search(Weight, Filter, int, Sort) - Method in class org.apache.lucene.search.MultiSearcher
-
Deprecated.
- search(Weight, Filter, int, Sort) - Method in class org.apache.lucene.search.ParallelMultiSearcher
-
Deprecated.A search implementation allowing sorting which spans a new thread for each Searchable, waits for each search to complete and merges the results back together.
- search(Weight, Filter, int, Sort) - Method in class org.apache.lucene.search.RemoteSearchable
-
Deprecated.
- search(Weight, Filter, int, Sort) - Method in interface org.apache.lucene.search.Searchable
-
Deprecated.Expert: Low-level search implementation with arbitrary sorting.
- search(Weight, Filter, int, Sort) - Method in class org.apache.lucene.search.Searcher
-
Deprecated.
- search(Weight, Filter, int, Sort, boolean) - Method in class org.apache.lucene.search.IndexSearcher
-
Just like
IndexSearcher.search(Weight, Filter, int, Sort)
, but you choose whether or not the fields in the returnedFieldDoc
instances should be set by specifying fillFields. - search(Weight, Filter, Collector) - Method in class org.apache.lucene.search.IndexSearcher
-
Lower-level search API.
- search(Weight, Filter, Collector) - Method in class org.apache.lucene.search.MultiSearcher
-
Deprecated.
- search(Weight, Filter, Collector) - Method in class org.apache.lucene.search.ParallelMultiSearcher
-
Deprecated.Lower-level search API.
- search(Weight, Filter, Collector) - Method in class org.apache.lucene.search.RemoteSearchable
-
Deprecated.
- search(Weight, Filter, Collector) - Method in interface org.apache.lucene.search.Searchable
-
Deprecated.Lower-level search API.
- search(Weight, Filter, Collector) - Method in class org.apache.lucene.search.Searcher
-
Deprecated.
- search(Weight, Filter, ScoreDoc, int) - Method in class org.apache.lucene.search.IndexSearcher
-
Expert: Low-level search implementation.
- SEARCH - org.apache.lucene.analysis.ja.JapaneseTokenizer.Mode
-
Segmentation geared towards search: this includes a decompounding process for long nouns, also including the full compound token as a synonym.
- Searchable - Interface in org.apache.lucene.search
-
Deprecated.In 4.0 this interface is removed/absorbed into IndexSearcher
- searchAfter(ScoreDoc, Query, int) - Method in class org.apache.lucene.search.IndexSearcher
-
Finds the top
n
hits forquery
where all results are after a previous result (after
). - searchAfter(ScoreDoc, Query, Filter, int) - Method in class org.apache.lucene.search.IndexSearcher
-
Finds the top
n
hits forquery
, applyingfilter
if non-null, where all results are after a previous result (after
). - 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 - Class in org.apache.lucene.search
-
Deprecated.In 4.0 this abstract class is removed/absorbed into IndexSearcher
- Searcher() - Constructor for class org.apache.lucene.search.Searcher
-
Deprecated.
- SearcherFactory - Class in org.apache.lucene.search
-
Factory class used by
SearcherManager
andNRTManager
to create new IndexSearchers. - SearcherFactory() - Constructor for class org.apache.lucene.search.SearcherFactory
- SearcherLifetimeManager - Class in org.apache.lucene.search
-
Keeps track of current plus old IndexSearchers, closing the old ones once they have timed out.
- SearcherLifetimeManager() - Constructor for class org.apache.lucene.search.SearcherLifetimeManager
- SearcherLifetimeManager.PruneByAge - Class in org.apache.lucene.search
-
Simple pruner that drops any searcher older by more than the specified seconds, than the newest searcher.
- SearcherLifetimeManager.Pruner - Interface in org.apache.lucene.search
- SearcherManager - Class in org.apache.lucene.search
-
Utility class to safely share
IndexSearcher
instances across multiple threads, while periodically reopening. - SearcherManager(IndexWriter, boolean, SearcherFactory) - Constructor for class org.apache.lucene.search.SearcherManager
-
Creates and returns a new SearcherManager from the given
IndexWriter
. - SearcherManager(Directory, SearcherFactory) - Constructor for class org.apache.lucene.search.SearcherManager
-
Creates and returns a new SearcherManager from the given
Directory
. - SearchFiles - Class in org.apache.lucene.demo
-
Simple command-line based search demo.
- SearchGroup<GROUP_VALUE_TYPE> - 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
- SearchGroupDocs(GROUP_VALUE_TYPE, TopDocsCollector<?>) - Constructor for class org.apache.lucene.search.grouping.AbstractSecondPassGroupingCollector.SearchGroupDocs
- searchParams - Variable in class org.apache.lucene.facet.search.FacetsAccumulator
- 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(String, List<FieldTermStack.TermInfo>) - Method in class org.apache.lucene.search.vectorhighlight.FieldQuery
- searchPhrase(List<FieldTermStack.TermInfo>) - Method in class org.apache.lucene.search.vectorhighlight.FieldQuery.QueryPhraseMap
- 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 SetBasedFieldSelector.
- 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
- SearchTravRetVectorHighlightTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Search and Traverse and Retrieve docs task.
- SearchTravRetVectorHighlightTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.SearchTravRetVectorHighlightTask
- 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 - org.apache.lucene.document.DateTools.Resolution
- secondRangeBeginningOriginal - Variable in class org.apache.lucene.analysis.CollationTestBase
- secondRangeEndOriginal - Variable in class org.apache.lucene.analysis.CollationTestBase
- seek(long) - Method in class org.apache.lucene.store.BufferedIndexInput
- seek(long) - Method in class org.apache.lucene.store.BufferedIndexOutput
-
Sets current position in this file, where the next write will occur.
- seek(long) - Method in class org.apache.lucene.store.ChecksumIndexInput
- seek(long) - Method in class org.apache.lucene.store.ChecksumIndexOutput
- seek(long) - Method in class org.apache.lucene.store.FSDirectory.FSIndexOutput
-
Random-access methods
- 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.IndexOutput
-
Sets current position in this file, where the next write will occur.
- seek(long) - Method in class org.apache.lucene.store.MockIndexInputWrapper
- seek(long) - Method in class org.apache.lucene.store.MockIndexOutputWrapper
- seek(long) - Method in class org.apache.lucene.store.RAMInputStream
- seek(long) - Method in class org.apache.lucene.store.RAMOutputStream
- seek(long) - Method in class org.apache.lucene.util.ThrottledIndexOutput
- seek(Term) - Method in class org.apache.lucene.index.AbstractAllTermDocs
- seek(Term) - Method in class org.apache.lucene.index.FilterIndexReader.FilterTermDocs
- seek(Term) - Method in class org.apache.lucene.index.MultipleTermPositions
-
Not implemented.
- seek(Term) - Method in interface org.apache.lucene.index.TermDocs
-
Sets this to the data for a term.
- seek(Term) - Method in class org.apache.lucene.store.instantiated.InstantiatedTermDocs
- seek(TermEnum) - Method in class org.apache.lucene.index.AbstractAllTermDocs
- seek(TermEnum) - Method in class org.apache.lucene.index.FilterIndexReader.FilterTermDocs
- seek(TermEnum) - Method in class org.apache.lucene.index.MultipleTermPositions
-
Not implemented.
- seek(TermEnum) - Method in interface org.apache.lucene.index.TermDocs
-
Sets this to the data for the current term in a
TermEnum
. - seek(TermEnum) - Method in class org.apache.lucene.store.instantiated.InstantiatedTermDocs
- 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.
- seekCeilingDocumentInformationIndex(int) - Method in class org.apache.lucene.store.instantiated.InstantiatedTerm
-
Finds index to the first beyond the current whose document number is greater than or equal to target, -1 if there is no such element.
- seekCeilingDocumentInformationIndex(int, int) - Method in class org.apache.lucene.store.instantiated.InstantiatedTerm
-
Finds index to the first beyond the current whose document number is greater than or equal to target, -1 if there is no such element.
- seekCeilingDocumentInformationIndex(int, int, int) - Method in class org.apache.lucene.store.instantiated.InstantiatedTerm
-
Finds index to the first beyond the current whose document number is greater than or equal to target, -1 if there is no such element.
- 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.index.MockIndexInput
- seekInternal(long) - Method in class org.apache.lucene.store.BufferedIndexInput
-
Expert: implements seek.
- seekInternal(long) - Method in class org.apache.lucene.store.SimpleFSDirectory.SimpleFSIndexInput
- seekInternal(long) - Method in class org.apache.lucene.store.WindowsDirectory.WindowsIndexInput
- segDeletes - Variable in class org.apache.lucene.index.SegmentWriteState
- segmentFileName(String, String) - Static method in class org.apache.lucene.index.IndexFileNames
-
Returns the file name that matches the given segment name and extension.
- segmentFormat - Variable in class org.apache.lucene.index.CheckIndex.Status
-
String description of the version of the index.
- SegmentInfo - Class in org.apache.lucene.index
-
Information about a segment such as it's name, directory, and files related to the segment.
- SegmentInfo(String, int, Directory, boolean, boolean, boolean, boolean) - Constructor for class org.apache.lucene.index.SegmentInfo
- segmentInfos - Variable in class org.apache.lucene.index.CheckIndex.Status
-
List of
CheckIndex.Status.SegmentInfoStatus
instances, detailing status of each segment. - SegmentInfos - Class in org.apache.lucene.index
-
A collection of segmentInfo objects with methods for operating on those segments in relation to the file system.
- SegmentInfos() - Constructor for class org.apache.lucene.index.SegmentInfos
- SegmentInfos.FindSegmentsFile - Class in org.apache.lucene.index
-
Utility class for executing code that needs to do something with the current segments file.
- SegmentInfoStatus() - Constructor for class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
- segmentName - Variable in class org.apache.lucene.index.SegmentWriteState
- SegmentReader - Class in org.apache.lucene.index
-
IndexReader implementation over a single segment.
- SegmentReader() - Constructor for class org.apache.lucene.index.SegmentReader
- SegmentReader.CoreClosedListener - Interface in org.apache.lucene.index
-
Called when the shared core for this SegmentReader is closed.
- segments - Variable in class org.apache.lucene.index.MergePolicy.OneMerge
- SEGMENTS - Static variable in class org.apache.lucene.index.IndexFileNames
-
Name of the index segment file
- SEGMENTS_GEN - Static variable in class org.apache.lucene.index.IndexFileNames
-
Name of the generation reference file name
- 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.
- SegmentWriteState - Class in org.apache.lucene.index
-
Holder class for common parameters used during write.
- SegmentWriteState(PrintStream, Directory, String, FieldInfos, int, int, BufferedDeletes) - Constructor for class org.apache.lucene.index.SegmentWriteState
- segString() - Method in class org.apache.lucene.index.IndexWriter
- segString(Iterable<SegmentInfo>) - Method in class org.apache.lucene.index.IndexWriter
- segString(SegmentInfo) - Method in class org.apache.lucene.index.IndexWriter
- segString(Directory) - Method in class org.apache.lucene.index.MergePolicy.MergeSpecification
- segString(Directory) - Method in class org.apache.lucene.index.MergePolicy.OneMerge
- 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
- SENTENCE - org.apache.lucene.queryParser.core.nodes.ProximityQueryNode.Type
- 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
- SentenceTokenizer - Class in org.apache.lucene.analysis.cn.smart
-
Tokenizes input text into sentences.
- SentenceTokenizer(Reader) - Constructor for class org.apache.lucene.analysis.cn.smart.SentenceTokenizer
- SentenceTokenizer(AttributeSource.AttributeFactory, Reader) - Constructor for class org.apache.lucene.analysis.cn.smart.SentenceTokenizer
- SentenceTokenizer(AttributeSource, Reader) - Constructor for class org.apache.lucene.analysis.cn.smart.SentenceTokenizer
- SentinelIntSet - Class in org.apache.lucene.search.grouping
-
A native int set where one value is reserved to mean "EMPTY"
- SentinelIntSet(int, int) - Constructor for class org.apache.lucene.search.grouping.SentinelIntSet
- SEP - Static variable in class org.apache.lucene.benchmark.byTask.tasks.WriteLineDocTask
- SEPARATE_NORMS_EXTENSION - Static variable in class org.apache.lucene.index.IndexFileNames
-
Extension of separate norms
- SEQUENTIAL - Static variable in class org.apache.lucene.store.NativePosixUtil
- serializeAppendTo(int, Appendable) - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
-
Just like
CategoryPath.serializeAppendTo(Appendable)
, but writes only a prefix of the CategoryPath. - serializeAppendTo(Appendable) - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
-
Write out a serialized (as a character sequence) representation of the path to a given Appendable (e.g., a StringBuilder, CharBuffer, Writer, or something similar.
- serializeCategoryAttribute(ObjectOutputStream, CategoryAttribute) - Method in class org.apache.lucene.facet.index.CategoryContainer
-
Serialize each of the
CategoryAttribute
s to the givenObjectOutputStream
.
NOTE:CategoryProperty
s areSerializable
, but do not assume that Lucene'sAttribute
s are as well - serializeToStreamWriter(OutputStreamWriter) - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
-
Serializes the content of this CategoryPath to a byte stream, using UTF-8 encoding to convert characters to bytes, and treating the ends as 16-bit characters.
- 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
- set(char[], int) - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
- set(double, double) - Method in class org.apache.lucene.spatial.geometry.shape.Point2D
-
Deprecated.
- set(double, double) - Method in class org.apache.lucene.spatial.geometry.shape.Vector2D
-
Deprecated.
- set(int) - Method in class org.apache.lucene.util.BitVector
-
Sets the value of
bit
to one. - set(int) - Method in class org.apache.lucene.util.FixedBitSet
- set(int, int) - Method in class org.apache.lucene.util.collections.IntArray
- set(int, int) - Method in class org.apache.lucene.util.FixedBitSet
-
Sets a range of bits
- set(int, long) - Method in class org.apache.lucene.util.packed.GrowableWriter
- set(int, long) - Method in interface org.apache.lucene.util.packed.PackedInts.Mutable
-
Set the value at the given index in the array.
- set(int, QueryNodeProcessor) - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorPipeline
- set(long) - Method in class org.apache.lucene.util.OpenBitSet
-
sets a bit, expanding the set size if necessary
- set(long, long) - Method in class org.apache.lucene.util.OpenBitSet
-
Sets a range of bits, expanding the set size if necessary
- set(StringBuilder) - Method in class org.apache.lucene.benchmark.byTask.utils.StringBuilderReader
- set(String, String) - Method in class org.apache.lucene.benchmark.byTask.utils.Config
-
Set a property.
- set(List<QueryNode>) - Method in interface org.apache.lucene.queryParser.core.nodes.QueryNode
- set(List<QueryNode>) - Method in class org.apache.lucene.queryParser.core.nodes.QueryNodeImpl
- set(CategoryAttribute) - Method in interface org.apache.lucene.facet.index.attributes.CategoryAttribute
-
Set the content of this
CategoryAttribute
from anotherCategoryAttribute
object. - set(CategoryAttribute) - Method in class org.apache.lucene.facet.index.attributes.CategoryAttributeImpl
- set(ConfigurationKey<T>, T) - Method in class org.apache.lucene.queryParser.core.config.AbstractQueryConfig
-
Sets a key and its value.
- set(Point2D) - Method in class org.apache.lucene.spatial.geometry.shape.Point2D
-
Deprecated.
- set(Vector2D) - Method in class org.apache.lucene.spatial.geometry.shape.Point2D
-
Deprecated.
- set(T) - Method in class org.apache.lucene.util.CloseableThreadLocal
- set(T) - Method in class org.apache.lucene.util.SetOnce
-
Sets the given object.
- setAccuracy(float) - Method in class org.apache.lucene.search.spell.SpellChecker
-
Sets the accuracy 0 < minScore < 1; default
SpellChecker.DEFAULT_ACCURACY
- setAllowArrayArcs(boolean) - Method in class org.apache.lucene.util.fst.Builder
-
Pass false to disable the array arc optimization while building the FST; this will make the resulting FST smaller but slower to traverse.
- setAllowArrayArcs(boolean) - Method in class org.apache.lucene.util.fst.FST
- setAllowLabeling(boolean) - Method in class org.apache.lucene.facet.search.FacetsAccumulator
-
Set whether labeling is allowed for this accumulator.
- setAllowLabeling(boolean) - Method in class org.apache.lucene.facet.search.SamplingWrapper
- setAllowLeadingWildcard(boolean) - Method in class org.apache.lucene.queryParser.QueryParser
-
Set to
true
to allow leading wildcard characters. - setAllowLeadingWildcard(boolean) - Method in interface org.apache.lucene.queryParser.standard.config.AllowLeadingWildcardAttribute
-
Deprecated.
- setAllowLeadingWildcard(boolean) - Method in class org.apache.lucene.queryParser.standard.config.AllowLeadingWildcardAttributeImpl
-
Deprecated.
- setAllowLeadingWildcard(boolean) - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.
- setAllowLeadingWildcard(boolean) - Method in class org.apache.lucene.queryParser.standard.StandardQueryParser
-
Set to
true
to allow leading wildcard characters. - setAnalyzer(Analyzer) - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
- setAnalyzer(Analyzer) - Method in interface org.apache.lucene.queryParser.standard.config.AnalyzerAttribute
-
Deprecated.
- setAnalyzer(Analyzer) - Method in class org.apache.lucene.queryParser.standard.config.AnalyzerAttributeImpl
-
Deprecated.
- setAnalyzer(Analyzer) - Method in class org.apache.lucene.queryParser.standard.StandardQueryParser
- setAnalyzer(Analyzer) - Method in class org.apache.lucene.search.similar.MoreLikeThis
-
Sets the analyzer to use.
- setAnalyzer(Analyzer) - Method in class org.apache.lucene.search.similar.MoreLikeThisQuery
- setAppend(String) - Method in class org.apache.lucene.analysis.hunspell.HunspellAffix
-
Sets the append defined for the affix
- setAppendFlags(char[]) - Method in class org.apache.lucene.analysis.hunspell.HunspellAffix
-
Sets the flags defined for the affix append
- setArticles(Set<?>) - Method in class org.apache.lucene.analysis.fr.ElisionFilter
-
Deprecated.use
ElisionFilter.setArticles(Version, Set)
instead - setArticles(Version, Set<?>) - Method in class org.apache.lucene.analysis.fr.ElisionFilter
-
Deprecated.use
ElisionFilter(Version, TokenStream, Set)
instead - setAssertNoUnrefencedFilesOnClose(boolean) - Method in class org.apache.lucene.store.MockDirectoryWrapper
- setAutoGeneratePhraseQueries(boolean) - Method in class org.apache.lucene.queryParser.QueryParser
-
Set to true if phrase queries will be automatically generated when the analyzer returns more than one term from whitespace delimited text.
- SetBasedFieldSelector - Class in org.apache.lucene.document
-
Declare what fields to load normally and what fields to load lazily
- SetBasedFieldSelector(Set<String>, Set<String>) - Constructor for class org.apache.lucene.document.SetBasedFieldSelector
- setBaseline() - Method in class org.apache.lucene.search.TimeLimitingCollector
-
Syntactic sugar for
TimeLimitingCollector.setBaseline(long)
usingCounter.get()
on the clock passed to the construcutor. - setBaseline(long) - Method in class org.apache.lucene.search.TimeLimitingCollector
-
Sets the baseline for this collector.
- 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.core.nodes.FieldQueryNode
- setBeginColumn(int) - Method in exception org.apache.lucene.queryParser.core.QueryNodeParseException
- setBeginLine(int) - Method in exception org.apache.lucene.queryParser.core.QueryNodeParseException
- setBits(long[]) - Method in class org.apache.lucene.util.OpenBitSet
-
Expert: sets a new long[] to use as the bit storage
- setBody(String) - Method in class org.apache.lucene.benchmark.byTask.feeds.DocData
- setBoost(boolean) - Method in class org.apache.lucene.search.similar.MoreLikeThis
-
Sets whether to boost terms in query based on "score" or not.
- setBoost(float) - Method in class org.apache.lucene.document.AbstractField
-
Sets the boost factor hits on this field.
- setBoost(float) - Method in class org.apache.lucene.document.Document
-
Sets a boost factor for hits on any field of this document.
- setBoost(float) - Method in interface org.apache.lucene.document.Fieldable
-
Sets the boost factor hits on this field.
- setBoost(float) - Method in class org.apache.lucene.index.FieldInvertState
- setBoost(float) - Method in interface org.apache.lucene.queryParser.standard.config.BoostAttribute
-
Deprecated.
- setBoost(float) - Method in class org.apache.lucene.queryParser.standard.config.BoostAttributeImpl
-
Deprecated.
- setBoost(float) - Method in class org.apache.lucene.search.Query
-
Sets the boost for this query clause to
b
. - setBoostFactor(float) - Method in class org.apache.lucene.search.similar.MoreLikeThis
-
Sets the boost factor to use when boosting terms
- setBottom(int) - Method in class org.apache.lucene.search.FieldComparator.ByteComparator
- 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
-
Set the bottom slot, ie the "weakest" (sorted last) entry in the queue.
- setBottom(int) - Method in class org.apache.lucene.search.FieldComparator.ShortComparator
- setBottom(int) - Method in class org.apache.lucene.search.FieldComparator.StringComparatorLocale
- setBottom(int) - Method in class org.apache.lucene.search.FieldComparator.StringOrdValComparator
- setBottom(int) - Method in class org.apache.lucene.search.FieldComparator.StringValComparator
- setBounds(FieldQueryNode, FieldQueryNode, boolean, boolean) - Method in class org.apache.lucene.queryParser.standard.nodes.RangeQueryNode
-
Deprecated.Sets lower and upper bounds.
- setBounds(NumericQueryNode, NumericQueryNode, boolean, boolean, NumericConfig) - Method in class org.apache.lucene.queryParser.standard.nodes.NumericRangeQueryNode
-
Sets the upper and lower bounds of this range query node and the
NumericConfig
associated with these bounds. - setBounds(T, T, boolean, boolean) - Method in class org.apache.lucene.queryParser.standard.nodes.AbstractRangeQueryNode
-
Sets the lower and upper bounds.
- 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.core.builders.QueryTreeBuilder
-
Deprecated.
- setBuilder(Class<? extends QueryNode>, QueryBuilder) - Method in class org.apache.lucene.queryParser.core.builders.QueryTreeBuilder
-
Associates a class with a builder
- setBuilder(String, QueryBuilder) - Method in class org.apache.lucene.queryParser.core.builders.QueryTreeBuilder
-
Associates a field name with a builder.
- setBytesRef(BytesRef, int) - Method in class org.apache.lucene.util.ByteBlockPool
- 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.search.TotalFacetCountsCache
-
Set the number of TotalFacetCounts arrays that will remain in memory cache.
- setCacheSize(int) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyReader
-
setCacheSize controls the maximum allowed size of each of the caches used by
DirectoryTaxonomyReader.getPath(int)
andDirectoryTaxonomyReader.getOrdinal(CategoryPath)
. - setCacheSize(int) - Method in class org.apache.lucene.search.FilterManager
-
Deprecated.Sets the max size that cache should reach before it is cleaned up
- 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.
- setCategories(Iterable<CategoryAttribute>) - Method in class org.apache.lucene.facet.index.CategoryDocumentBuilder
-
Set the categories of the document builder from an
Iterable
ofCategoryAttribute
objects. - setCategoryPath(CategoryPath) - Method in interface org.apache.lucene.facet.index.attributes.CategoryAttribute
-
Sets the category path value of this attribute.
- setCategoryPath(CategoryPath) - Method in class org.apache.lucene.facet.index.attributes.CategoryAttributeImpl
- setCategoryPaths(Iterable<CategoryPath>) - Method in class org.apache.lucene.facet.index.CategoryDocumentBuilder
-
Set the categories of the document builder from an
Iterable
ofCategoryPath
objects. - setCharAt(int, char) - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
- setCheckIndexOnClose(boolean) - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
Set whether or not checkindex should be run on close
- setChild(QueryNode) - Method in class org.apache.lucene.queryParser.core.nodes.GroupQueryNode
- setChild(QueryNode) - Method in class org.apache.lucene.queryParser.core.nodes.ModifierQueryNode
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryParser.core.processors.NoChildOptimizationQueryNodeProcessor
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryParser.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.core.processors.RemoveDeletedQueryNodesProcessor
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryParser.precedence.processors.BooleanModifiersQueryNodeProcessor
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryParser.standard.processors.AllowLeadingWildcardProcessor
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryParser.standard.processors.AnalyzerQueryNodeProcessor
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryParser.standard.processors.BooleanSingleChildOptimizationQueryNodeProcessor
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryParser.standard.processors.BoostQueryNodeProcessor
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryParser.standard.processors.DefaultPhraseSlopQueryNodeProcessor
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryParser.standard.processors.FuzzyQueryNodeProcessor
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryParser.standard.processors.LowercaseExpandedTermsQueryNodeProcessor
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryParser.standard.processors.MatchAllDocsQueryNodeProcessor
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryParser.standard.processors.MultiFieldQueryNodeProcessor
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryParser.standard.processors.MultiTermRewriteMethodProcessor
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryParser.standard.processors.NumericQueryNodeProcessor
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryParser.standard.processors.NumericRangeQueryNodeProcessor
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryParser.standard.processors.ParametricRangeQueryNodeProcessor
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryParser.standard.processors.PhraseSlopQueryNodeProcessor
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryParser.standard.processors.RemoveEmptyNonLeafQueryNodeProcessor
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryParser.standard.processors.WildcardQueryNodeProcessor
- setClCache(CategoryListCache) - Method in class org.apache.lucene.facet.search.params.FacetSearchParams
-
Set Cached Category Lists data to be used in Faceted search.
- setCleanThreadSleepTime(long) - Method in class org.apache.lucene.search.FilterManager
-
Deprecated.Sets the cache cleaning frequency in milliseconds.
- 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
- 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.
- SetCollector(Set<Integer>) - Constructor for class org.apache.lucene.search.CheckHits.SetCollector
- setComparator(Comparator<SuggestWord>) - Method in class org.apache.lucene.search.spell.SpellChecker
-
Sets the
Comparator
for theSuggestWordQueue
. - setComplementThreshold(double) - Method in class org.apache.lucene.facet.search.FacetsAccumulator
-
Set the complement threshold.
- setComplementThreshold(double) - Method in class org.apache.lucene.facet.search.SamplingWrapper
- setCondition(String, String) - Method in class org.apache.lucene.analysis.hunspell.HunspellAffix
-
Sets the condition that must be met before the affix can be applied
- 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) - 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) - 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
- setCrossProduct(boolean) - Method in class org.apache.lucene.analysis.hunspell.HunspellAffix
-
Sets whether the affix is defined as cross product
- setCurrent(char[], int) - Method in class org.tartarus.snowball.SnowballProgram
-
Set the current string.
- setCurrent(String) - 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
- setData(byte[]) - Method in class org.apache.lucene.index.Payload
-
Sets this payloads data.
- setData(byte[], int, int) - Method in class org.apache.lucene.index.Payload
-
Sets this payloads data.
- setDate(String) - Method in class org.apache.lucene.benchmark.byTask.feeds.DocData
- setDate(Date) - Method in class org.apache.lucene.benchmark.byTask.feeds.DocData
- setDateResolution(String, DateTools.Resolution) - Method in class org.apache.lucene.queryParser.QueryParser
-
Sets the date resolution used by RangeQueries for a specific field.
- setDateResolution(String, DateTools.Resolution) - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.
- setDateResolution(Collator) - Method in interface org.apache.lucene.queryParser.standard.config.RangeCollatorAttribute
-
Deprecated.
- setDateResolution(Collator) - Method in class org.apache.lucene.queryParser.standard.config.RangeCollatorAttributeImpl
-
Deprecated.
- setDateResolution(Map<CharSequence, DateTools.Resolution>) - Method in class org.apache.lucene.queryParser.standard.StandardQueryParser
-
Deprecated.this method was renamed to
StandardQueryParser.setDateResolutionMap(Map)
- setDateResolution(DateTools.Resolution) - Method in class org.apache.lucene.queryParser.QueryParser
-
Sets the default date resolution used by RangeQueries for fields for which no specific date resolutions has been set.
- setDateResolution(DateTools.Resolution) - Method in interface org.apache.lucene.queryParser.standard.config.DateResolutionAttribute
-
Deprecated.Sets the default date resolution used by
RangeQueryNode
s for fields for which no specific date resolutions has been set. - setDateResolution(DateTools.Resolution) - Method in class org.apache.lucene.queryParser.standard.config.DateResolutionAttributeImpl
-
Deprecated.
- setDateResolution(DateTools.Resolution) - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.
- setDateResolution(DateTools.Resolution) - Method in class org.apache.lucene.queryParser.standard.StandardQueryParser
-
Sets the default
DateTools.Resolution
used for certain field when noDateTools.Resolution
is defined for this field. - setDateResolutionMap(Map<CharSequence, DateTools.Resolution>) - Method in class org.apache.lucene.queryParser.standard.StandardQueryParser
-
Sets the
DateTools.Resolution
used for each field - setDebugStream(PrintStream) - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserTokenManager
-
Set debug output.
- setDebugStream(PrintStream) - Method in class org.apache.lucene.queryParser.QueryParserTokenManager
-
Set debug output.
- setDebugStream(PrintStream) - Method in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserTokenManager
-
Set debug output.
- setDebugStream(PrintStream) - Method in class org.apache.lucene.queryParser.surround.parser.QueryParserTokenManager
-
Set debug output.
- setDefault(Similarity) - Static method in class org.apache.lucene.search.Similarity
-
Set the default Similarity implementation used by indexing and search code.
- setDefaultFieldSortScoring(boolean, boolean) - Method in class org.apache.lucene.search.IndexSearcher
-
By default, no scores are computed when sorting by field (using
IndexSearcher.search(Query,Filter,int,Sort)
). - setDefaultGenLookaheadCount(int) - Static method in class org.apache.lucene.index.SegmentInfos
-
Advanced: set how many times to try incrementing the gen when loading the segments file.
- setDefaultInfoStream(PrintStream) - Static method in class org.apache.lucene.index.IndexWriter
-
If non-null, this will be the default infoStream used by a newly instantiated IndexWriter.
- setDefaultOperator(QueryParser.Operator) - Method in class org.apache.lucene.queryParser.QueryParser
-
Sets the boolean operator of the QueryParser.
- setDefaultOperator(DefaultOperatorAttribute.Operator) - Method in class org.apache.lucene.queryParser.standard.StandardQueryParser
-
Deprecated.
- setDefaultOperator(StandardQueryConfigHandler.Operator) - Method in class org.apache.lucene.queryParser.standard.StandardQueryParser
-
Sets the boolean operator of the QueryParser.
- setDefaultOperator(QueryParserWrapper.Operator) - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.
- setDefaultPhraseSlop(int) - Method in interface org.apache.lucene.queryParser.standard.config.DefaultPhraseSlopAttribute
-
Deprecated.
- setDefaultPhraseSlop(int) - Method in class org.apache.lucene.queryParser.standard.config.DefaultPhraseSlopAttributeImpl
-
Deprecated.
- setDefaultPhraseSlop(int) - Method in class org.apache.lucene.queryParser.standard.StandardQueryParser
-
Deprecated.renamed to
StandardQueryParser.setPhraseSlop(int)
- setDefaultScore(float) - Method in class org.apache.lucene.facet.search.ScoredDocIdCollector
-
Set the default score.
- setDefaultWriteLockTimeout(long) - Static method in class org.apache.lucene.index.IndexWriter
-
Deprecated.
- setDefaultWriteLockTimeout(long) - Static method in class org.apache.lucene.index.IndexWriterConfig
-
Sets the default (for any instance) maximum time to wait for a write lock (in milliseconds).
- setDelimiter(char) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyReader
-
setDelimiter changes the character that the taxonomy uses in its internal storage as a delimiter between category components.
- setDelimiter(char) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
-
setDelimiter changes the character that the taxonomy uses in its internal storage as a delimiter between category components.
- setDepth(int) - Method in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
- setDepth(int) - Method in class org.apache.lucene.facet.search.params.FacetRequest
- setDescription(String) - Method in class org.apache.lucene.search.Explanation
-
Sets the description of this explanation node.
- 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.DefaultSimilarity
-
Determines whether overlap tokens (Tokens with 0 position increment) are ignored when computing norm.
- setDistances(Map<Integer, Double>) - Method in class org.apache.lucene.spatial.tier.DistanceFilter
-
Deprecated.
- setdoc(int) - Method in class org.apache.lucene.facet.enhancements.EnhancementsPayloadIterator
- setdoc(int) - Method in class org.apache.lucene.facet.search.PayloadIterator
-
Skip forward to document docId.
- setDocStoreSegment(String) - Method in class org.apache.lucene.index.SegmentInfo
- setDocumentNumber(int) - Method in class org.apache.lucene.index.TermVectorMapper
-
Passes down the index of the document whose term vector is currently being mapped, once for each top level call to a term vector reader.
- setDoFail() - Method in class org.apache.lucene.store.MockDirectoryWrapper.Failure
- 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.analysis.NumericTokenStream
-
Initializes the token stream with the supplied
double
value. - setDoubleValue(double) - Method in class org.apache.lucene.document.NumericField
-
Initializes the field with the supplied
double
value. - 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.
- setEnablePositionIncrements(boolean) - Method in class org.apache.lucene.analysis.FilteringTokenFilter
-
If
true
, this TokenFilter will preserve positions of the incoming tokens (ie, accumulate and set position increments of the removed tokens). - setEnablePositionIncrements(boolean) - Method in class org.apache.lucene.queryParser.QueryParser
-
Set to
true
to enable position increments in result query. - setEnablePositionIncrements(boolean) - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.
- setEnablePositionIncrements(boolean) - Method in class org.apache.lucene.queryParser.standard.StandardQueryParser
-
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.core.nodes.FieldQueryNode
- setEndOffset(int) - Method in class org.apache.lucene.analysis.Token
-
Set the ending offset.
- setEndOffset(int) - Method in class org.apache.lucene.index.TermVectorOffsetInfo
- setEndOffset(int) - Method in class org.apache.lucene.search.vectorhighlight.FieldPhraseList.WeightedPhraseInfo.Toffs
- setEnum(TermEnum) - Method in class org.apache.lucene.search.FilteredTermEnum
-
use this method to set the actual TermEnum (e.g.
- setErrorToken(String) - Method in exception org.apache.lucene.queryParser.core.QueryNodeParseException
- setEstimatedSize(String) - Method in class org.apache.lucene.search.FieldCache.CacheEntry
- setExclusionSet(Set<?>) - Method in class org.apache.lucene.analysis.de.GermanStemFilter
-
Deprecated.use
KeywordAttribute
withKeywordMarkerFilter
instead. - setExclusionTable(HashSet<?>) - Method in class org.apache.lucene.analysis.nl.DutchStemFilter
-
Deprecated.use
KeywordAttribute
withKeywordMarkerFilter
instead. - setExclusionTable(Map<?, ?>) - Method in class org.apache.lucene.analysis.fr.FrenchStemFilter
-
Deprecated.use
KeywordAttribute
withKeywordMarkerFilter
instead. - setExpandMultiTermQuery(boolean) - Method in class org.apache.lucene.search.highlight.QueryScorer
-
Controls whether or not multi-term queries are expanded against a
MemoryIndex
IndexReader
. - setExpandMultiTermQuery(boolean) - Method in class org.apache.lucene.search.highlight.WeightedSpanTermExtractor
- setExpectations(String, int, boolean, boolean) - Method in class org.apache.lucene.index.FieldSortedTermVectorMapper
- setExpectations(String, int, boolean, boolean) - Method in class org.apache.lucene.index.PositionBasedTermVectorMapper
-
Callback mechanism used by the TermVectorReader
- setExpectations(String, int, boolean, boolean) - Method in class org.apache.lucene.index.SortedTermVectorMapper
- setExpectations(String, int, boolean, boolean) - Method in class org.apache.lucene.index.TermVectorMapper
-
Tell the mapper what to expect in regards to field, number of terms, offset and position storage.
- setFailOnCreateOutput(boolean) - Method in class org.apache.lucene.store.MockDirectoryWrapper
- setFailOnOpenInput(boolean) - Method in class org.apache.lucene.store.MockDirectoryWrapper
- setField(CharSequence) - Method in class org.apache.lucene.queryParser.core.nodes.AnyQueryNode
- setField(CharSequence) - Method in interface org.apache.lucene.queryParser.core.nodes.FieldableNode
-
Associates the node to a field.
- setField(CharSequence) - Method in class org.apache.lucene.queryParser.core.nodes.FieldQueryNode
- setField(CharSequence) - Method in class org.apache.lucene.queryParser.core.nodes.ParametricRangeQueryNode
- setField(CharSequence) - Method in class org.apache.lucene.queryParser.core.nodes.PhraseSlopQueryNode
- setField(CharSequence) - Method in class org.apache.lucene.queryParser.core.nodes.ProximityQueryNode
- setField(CharSequence) - Method in class org.apache.lucene.queryParser.core.nodes.SlopQueryNode
- setField(CharSequence) - Method in class org.apache.lucene.queryParser.core.nodes.TokenizedPhraseQueryNode
- setField(CharSequence) - Method in class org.apache.lucene.queryParser.standard.nodes.AbstractRangeQueryNode
-
Sets the field associated with this node.
- setField(CharSequence) - Method in class org.apache.lucene.queryParser.standard.nodes.MultiPhraseQueryNode
- setField(CharSequence) - Method in class org.apache.lucene.queryParser.standard.nodes.NumericQueryNode
-
Sets the field associated with this node.
- setFieldBoostMap(Map<String, Float>) - Method in interface org.apache.lucene.queryParser.standard.config.FieldBoostMapAttribute
-
Deprecated.
- setFieldBoostMap(Map<String, Float>) - Method in class org.apache.lucene.queryParser.standard.config.FieldBoostMapAttributeImpl
-
Deprecated.
- setFieldDateResolutionMap(Map<CharSequence, DateTools.Resolution>) - Method in interface org.apache.lucene.queryParser.standard.config.FieldDateResolutionMapAttribute
-
Deprecated.
- setFieldDateResolutionMap(Map<CharSequence, DateTools.Resolution>) - Method in class org.apache.lucene.queryParser.standard.config.FieldDateResolutionMapAttributeImpl
-
Deprecated.
- setFieldName(String) - Method in class org.apache.lucene.search.DuplicateFilter
- setFieldNames(String[]) - Method in class org.apache.lucene.search.similar.MoreLikeThis
-
Sets the field names that will be used when generating the 'More Like This' query.
- setFields(CharSequence[]) - Method in interface org.apache.lucene.queryParser.standard.config.MultiFieldAttribute
-
Deprecated.
- setFields(CharSequence[]) - Method in class org.apache.lucene.queryParser.standard.config.MultiFieldAttributeImpl
-
Deprecated.
- setFieldsBoost(Map<String, Float>) - Method in class org.apache.lucene.queryParser.standard.StandardQueryParser
-
Sets the boost used for each field.
- setFirst(boolean) - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.Matrix.Column
-
Deprecated.
- setFlag(char) - Method in class org.apache.lucene.analysis.hunspell.HunspellAffix
-
Sets the affix flag
- setFlags(int) - Method in class org.apache.lucene.analysis.Token
- setFlags(int) - Method in interface org.apache.lucene.analysis.tokenattributes.FlagsAttribute
- setFlags(int) - Method in class org.apache.lucene.analysis.tokenattributes.FlagsAttributeImpl
- setFloatValue(float) - Method in class org.apache.lucene.analysis.NumericTokenStream
-
Initializes the token stream with the supplied
float
value. - setFloatValue(float) - Method in class org.apache.lucene.document.NumericField
-
Initializes the field with the supplied
float
value. - 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.
- setFormat(int) - Method in class org.apache.lucene.index.SegmentInfos
- 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.payloads.PayloadNearQuery.PayloadNearSpanScorer
- setFreqCurrentDoc() - Method in class org.apache.lucene.search.payloads.PayloadTermQuery.PayloadTermWeight.PayloadTermSpanScorer
- setFreqCurrentDoc() - Method in class org.apache.lucene.search.spans.SpanScorer
- setFromSerialized(CharSequence, int) - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
-
Set a CategoryPath from a character-sequence representation written by
CategoryPath.serializeAppendTo(Appendable)
. - setFuzzyMinSim(float) - Method in class org.apache.lucene.queryParser.QueryParser
-
Set the minimum similarity for fuzzy queries.
- setFuzzyMinSim(float) - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.
- setFuzzyMinSim(float) - Method in class org.apache.lucene.queryParser.standard.StandardQueryParser
-
Set the minimum similarity for fuzzy queries.
- setFuzzyMinSimilarity(float) - Method in interface org.apache.lucene.queryParser.standard.config.FuzzyAttribute
-
Deprecated.
- setFuzzyMinSimilarity(float) - Method in class org.apache.lucene.queryParser.standard.config.FuzzyAttributeImpl
-
Deprecated.
- setFuzzyPrefixLength(int) - Method in class org.apache.lucene.queryParser.QueryParser
-
Set the prefix length for fuzzy queries.
- setFuzzyPrefixLength(int) - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.
- setFuzzyPrefixLength(int) - Method in class org.apache.lucene.queryParser.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
- setGreedy(boolean) - Method in class org.apache.lucene.search.TimeLimitingCollector
-
Sets whether this time limited collector is greedy.
- setHasVectors(boolean) - Method in class org.apache.lucene.index.SegmentInfo
- 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.search.FuzzyLikeThisQuery
- setIgnoringSinglePrefixOrSuffixShingle(boolean) - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter
-
Deprecated.
- 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.
- setIndexDeletionPolicy(IndexDeletionPolicy) - Method in class org.apache.lucene.index.IndexWriterConfig
-
Expert: allows an optional
IndexDeletionPolicy
implementation to be specified. - setIndexOptions(FieldInfo.IndexOptions) - Method in class org.apache.lucene.document.AbstractField
-
Expert: If set, omit term freq, and optionally also positions and payloads from postings for this field.
- setIndexOptions(FieldInfo.IndexOptions) - Method in interface org.apache.lucene.document.Fieldable
-
Expert: If set, omit term freq, and optionally positions and payloads from postings for this field.
- setIndexReader(IndexReader) - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
-
Set the index reader.
- setIndexWriter(IndexWriter) - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
- setIndexWriter(IndexWriter) - Method in class org.apache.lucene.index.MergePolicy
-
Sets the
IndexWriter
to use by this merge policy. - setIndexWriter(IndexWriter) - Method in class org.apache.lucene.index.NoMergePolicy
- setIndexWriter(IndexWriter) - Method in class org.apache.lucene.index.UpgradeIndexMergePolicy
- setInfoStream(PrintStream) - Method in class org.apache.lucene.index.CheckIndex
-
Set infoStream where messages should go.
- setInfoStream(PrintStream) - Method in class org.apache.lucene.index.IndexWriter
-
If non-null, information about merges, deletes and a message when maxFieldLength is reached will be printed to this.
- setInfoStream(PrintStream) - Static method in class org.apache.lucene.index.SegmentInfos
-
If non-null, information about retries when loading the segments file will be printed to this.
- setInfoStream(PrintStream) - Method in interface org.apache.lucene.search.FieldCache
-
If non-null, FieldCacheImpl will warn whenever entries are created that are not sane according to
FieldCacheSanityChecker
. - setInfoStream(PrintStream) - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexWriter
-
Deprecated.If non-null, information about merges and a message when maxFieldLength is reached could be printed to this -- currently not yet implemented.
- setIntValue(int) - Method in class org.apache.lucene.analysis.NumericTokenStream
-
Initializes the token stream with the supplied
int
value. - setIntValue(int) - Method in class org.apache.lucene.document.NumericField
-
Initializes the field with the supplied
int
value. - setKeepMode(int) - Method in class org.apache.lucene.search.DuplicateFilter
- setKeyword(boolean) - Method in interface org.apache.lucene.analysis.tokenattributes.KeywordAttribute
-
Marks the current token as keyword iff set to
true
. - setKeyword(boolean) - Method in class org.apache.lucene.analysis.tokenattributes.KeywordAttributeImpl
-
Marks the current token as keyword iff set to
true
. - setLabel(CategoryPath) - Method in class org.apache.lucene.facet.search.results.MutableFacetResultNode
-
Set the label of the category of this result.
- setLast(boolean) - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.Matrix.Column
-
Deprecated.
- setLastModified(long) - Method in class org.apache.lucene.store.RAMFile
- setLastOutput(int, T) - Method in class org.apache.lucene.util.fst.Builder.UnCompiledNode
- setLat(int) - Method in class org.apache.lucene.spatial.geometry.FixedLatLng
-
Deprecated.
- setLeaf(boolean) - Method in class org.apache.lucene.queryParser.core.nodes.QueryNodeImpl
- 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
- setLength(int) - Method in class org.apache.lucene.util.UnicodeUtil.UTF16Result
- setLength(int) - Method in class org.apache.lucene.util.UnicodeUtil.UTF8Result
- setLength(long) - Method in class org.apache.lucene.store.FSDirectory.FSIndexOutput
- setLength(long) - Method in class org.apache.lucene.store.IndexOutput
-
Set the file length.
- setLength(long) - Method in class org.apache.lucene.store.MockIndexOutputWrapper
- setLength(long) - Method in class org.apache.lucene.store.RAMFile
- setLength(long) - Method in class org.apache.lucene.util.ThrottledIndexOutput
- setLengthNormFactors(int, int, float) - Method in class org.apache.lucene.misc.SweetSpotSimilarity
-
Sets the default function variables used by lengthNorm when no field specific variables have been set.
- setLengthNormFactors(String, int, int, float, boolean) - Method in class org.apache.lucene.misc.SweetSpotSimilarity
-
Sets the function variables used by lengthNorm for a specific named field.
- setLikeText(String) - Method in class org.apache.lucene.search.similar.MoreLikeThisQuery
- setLng(int) - Method in class org.apache.lucene.spatial.geometry.FixedLatLng
-
Deprecated.
- setLocale(Locale) - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
- setLocale(Locale) - Method in class org.apache.lucene.queryParser.QueryParser
-
Set locale used by date range parsing.
- setLocale(Locale) - Method in interface org.apache.lucene.queryParser.standard.config.LocaleAttribute
-
Deprecated.
- setLocale(Locale) - Method in class org.apache.lucene.queryParser.standard.config.LocaleAttributeImpl
-
Deprecated.
- setLocale(Locale) - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.
- setLocale(Locale) - Method in class org.apache.lucene.queryParser.standard.StandardQueryParser
-
Set locale used by date range parsing.
- setLockDir(File) - Method in class org.apache.lucene.store.FSLockFactory
-
Set the lock directory.
- setLockFactory(LockFactory) - Method in class org.apache.lucene.store.Directory
-
Set the LockFactory that this Directory instance should use for its locking implementation.
- setLockFactory(LockFactory) - Method in class org.apache.lucene.store.FSDirectory
- setLockFactory(LockFactory) - Method in class org.apache.lucene.store.MockDirectoryWrapper
- setLockFactory(LockFactory) - Method in class org.apache.lucene.store.NRTCachingDirectory
- setLockPrefix(String) - Method in class org.apache.lucene.store.LockFactory
-
Set the prefix in use for all locks created in this LockFactory.
- setLockPrefix(String) - Method in class org.apache.lucene.store.MockLockFactoryWrapper
- setLongValue(long) - Method in class org.apache.lucene.analysis.NumericTokenStream
-
Initializes the token stream with the supplied
long
value. - setLongValue(long) - Method in class org.apache.lucene.document.NumericField
-
Initializes the field with the supplied
long
value. - setLowercaseExpandedTerms(boolean) - Method in class org.apache.lucene.queryParser.QueryParser
-
Whether terms of wildcard, prefix, fuzzy and range queries are to be automatically lower-cased or not.
- setLowercaseExpandedTerms(boolean) - Method in interface org.apache.lucene.queryParser.standard.config.LowercaseExpandedTermsAttribute
-
Deprecated.
- setLowercaseExpandedTerms(boolean) - Method in class org.apache.lucene.queryParser.standard.config.LowercaseExpandedTermsAttributeImpl
-
Deprecated.
- setLowercaseExpandedTerms(boolean) - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.
- setLowercaseExpandedTerms(boolean) - Method in class org.apache.lucene.queryParser.standard.StandardQueryParser
-
Set to
true
to allow leading wildcard characters. - setMatch(Boolean) - Method in class org.apache.lucene.search.ComplexExplanation
-
Sets the match status assigned to this explanation node.
- setMatchAlmostDiff(int) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Sets the number of characters by which words can differ from target word when calling the
matchAlmost
method. - setMatrix(ShingleMatrixFilter.Matrix) - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter
-
Deprecated.
- setMaxBufferedDeleteTerms(int) - Method in class org.apache.lucene.index.IndexWriter
-
Deprecated.use
IndexWriterConfig.setMaxBufferedDeleteTerms(int)
instead. - setMaxBufferedDeleteTerms(int) - Method in class org.apache.lucene.index.IndexWriterConfig
-
Determines the minimal number of delete terms required before the buffered in-memory delete terms are applied and flushed.
- setMaxBufferedDocs(int) - Method in class org.apache.lucene.index.IndexWriter
-
Deprecated.use
IndexWriterConfig.setMaxBufferedDocs(int)
instead. - setMaxBufferedDocs(int) - Method in class org.apache.lucene.index.IndexWriterConfig
-
Determines the minimal number of documents required before the buffered in-memory documents are flushed as a new Segment.
- setMaxChunkSize(int) - Method in class org.apache.lucene.store.MMapDirectory
-
Sets the maximum chunk size (default is 1 GiBytes for 64 bit JVMs and 256 MiBytes for 32 bit JVMs) used for memory mapping.
- setMaxClauseCount(int) - Static method in class org.apache.lucene.search.BooleanQuery
-
Set the maximum number of clauses permitted per BooleanQuery.
- 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
- setMaxDocFreq(int) - Method in class org.apache.lucene.search.similar.MoreLikeThis
-
Set the maximum frequency in which words may still appear.
- setMaxDocFreqPct(int) - Method in class org.apache.lucene.search.similar.MoreLikeThis
-
Set the maximum percentage in which words may still appear.
- setMaxFieldLength(int) - Method in class org.apache.lucene.index.IndexWriter
-
Deprecated.use
LimitTokenCountAnalyzer
instead. Note that the behvaior slightly changed - the analyzer limits the number of tokens per token stream created, while this setting limits the total number of tokens to index. This only matters if you index many multi-valued fields though. - setMaxFieldLength(int) - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexWriter
-
Deprecated.
- setMaximumShingleSize(int) - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter
-
Deprecated.
- 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.
- setMaxMergeCount(int) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
-
Sets the max # simultaneous merges that are allowed.
- setMaxMergeDocs(int) - Method in class org.apache.lucene.index.BalancedSegmentMergePolicy.MergePolicyParams
-
Deprecated.
- setMaxMergeDocs(int) - Method in class org.apache.lucene.index.IndexWriter
-
Deprecated.use
LogMergePolicy.setMaxMergeDocs(int)
directly. - 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.
- setMaxMergeMBForOptimize(double) - Method in class org.apache.lucene.index.LogByteSizeMergePolicy
-
Deprecated.
- setMaxNumTokensParsed(int) - Method in class org.apache.lucene.search.similar.MoreLikeThis
- setMaxQueries(int) - Method in class org.apache.lucene.benchmark.quality.QualityBenchmark
-
Set the maximum number of quality queries to run.
- setMaxQueryTerms(int) - Method in class org.apache.lucene.search.similar.MoreLikeThis
-
Sets the maximum number of query terms that will be included in any generated query.
- setMaxQueryTerms(int) - Method in class org.apache.lucene.search.similar.MoreLikeThisQuery
- setMaxResults(int) - Method in class org.apache.lucene.benchmark.quality.QualityBenchmark
-
set the maximum number of results to collect for each quality query.
- setMaxSampleSize(int) - Method in class org.apache.lucene.facet.search.sampling.SamplingParams
- 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.ShingleAnalyzerWrapper
-
Deprecated.Setting maxShingleSize after Analyzer instantiation prevents reuse. Confgure maxShingleSize during construction.
- 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.util.collections.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
- setMaxSmallSegments(int) - Method in class org.apache.lucene.index.BalancedSegmentMergePolicy.MergePolicyParams
-
Deprecated.
- setMaxSmallSegments(int) - Method in class org.apache.lucene.index.BalancedSegmentMergePolicy
-
Deprecated.
- setMaxThreadCount(int) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
-
Sets the max # simultaneous merge threads that should be running at once.
- setMaxThreadStates(int) - Method in class org.apache.lucene.index.IndexWriterConfig
-
Sets the max number of simultaneous threads that may be indexing documents at once in IndexWriter.
- 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 maximum 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 maximum 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.search.similar.MoreLikeThis
-
Sets the maximum word length above which words will be ignored.
- setMergedSegmentWarmer(IndexWriter.IndexReaderWarmer) - Method in class org.apache.lucene.index.IndexWriter
-
Deprecated.
- setMergedSegmentWarmer(IndexWriter.IndexReaderWarmer) - Method in class org.apache.lucene.index.IndexWriterConfig
-
Set the merged segment warmer.
- setMergeFactor(int) - Method in class org.apache.lucene.index.BalancedSegmentMergePolicy.MergePolicyParams
-
Deprecated.
- setMergeFactor(int) - Method in class org.apache.lucene.index.BalancedSegmentMergePolicy
-
Deprecated.
- setMergeFactor(int) - Method in class org.apache.lucene.index.IndexWriter
-
Deprecated.use
LogMergePolicy.setMergeFactor(int)
directly. - setMergeFactor(int) - Method in class org.apache.lucene.index.LogMergePolicy
-
Determines how often segment indices are merged by addDocument().
- setMergeFactor(int) - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexWriter
-
Deprecated.The sweetspot for this implementation is somewhere around 2500 at 2K text large documents.
- setMergeFactor(MergePolicy, int) - Static method in class org.apache.lucene.util.LuceneTestCase
- setMergePolicy(MergePolicy) - Method in class org.apache.lucene.index.IndexWriter
-
Deprecated.use
IndexWriterConfig.setMergePolicy(MergePolicy)
instead. - setMergePolicy(MergePolicy) - Method in class org.apache.lucene.index.IndexWriterConfig
-
Expert:
MergePolicy
is invoked whenever there are changes to the segments in the index. - setMergePolicyParams(BalancedSegmentMergePolicy.MergePolicyParams) - Method in class org.apache.lucene.index.BalancedSegmentMergePolicy
-
Deprecated.
- setMergeScheduler(MergeScheduler) - Method in class org.apache.lucene.index.IndexWriter
-
Deprecated.
- setMergeScheduler(MergeScheduler) - Method in class org.apache.lucene.index.IndexWriterConfig
-
Expert: sets the merge scheduler used by this writer.
- setMergeThreadPriority(int) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
-
Set the base priority that merge threads run at.
- setMinDocFreq(int) - Method in class org.apache.lucene.search.similar.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.search.similar.MoreLikeThisQuery
- setMinimumNumberShouldMatch(int) - Method in class org.apache.lucene.search.BooleanQuery
-
Specifies a minimum number of the optional BooleanClauses which must be satisfied.
- setMinimumShingleSize(int) - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter
-
Deprecated.
- 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.
- setMinSampleSize(int) - Method in class org.apache.lucene.facet.search.sampling.SamplingParams
- setMinShingleSize(int) - Method in class org.apache.lucene.analysis.shingle.ShingleAnalyzerWrapper
-
Deprecated.Setting minShingleSize after Analyzer instantiation prevents reuse. Confgure minShingleSize during construction.
- 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.standard.config.FuzzyConfig
- setMinTermFreq(int) - Method in class org.apache.lucene.search.similar.MoreLikeThis
-
Sets the frequency below which terms will be ignored in the source doc.
- setMinTermFrequency(int) - Method in class org.apache.lucene.search.similar.MoreLikeThisQuery
- setMinWordLen(int) - Method in class org.apache.lucene.search.similar.MoreLikeThis
-
Sets the minimum word length below which words will be ignored.
- setMissingValue(Object) - Method in class org.apache.lucene.search.SortField
-
Set a default sorting value for documents which lacks one
- setModifiedUTF8StringsMode() - Method in class org.apache.lucene.store.DataInput
-
Call this if readString should read characters stored in the old modified UTF8 format (length in java chars and java's modified UTF8 encoding).
- setModifiedUTF8StringsMode() - Method in class org.apache.lucene.store.MockIndexInputWrapper
- setMoreLikeFields(String[]) - Method in class org.apache.lucene.search.similar.MoreLikeThisQuery
- setMultiFields(CharSequence[]) - Method in class org.apache.lucene.queryParser.standard.StandardQueryParser
-
Set the fields a query should be expanded to when the field is
null
- setMultiTermRewriteMethod(MultiTermQuery.RewriteMethod) - Method in class org.apache.lucene.queryParser.QueryParser
-
By default QueryParser uses
MultiTermQuery.CONSTANT_SCORE_AUTO_REWRITE_DEFAULT
when creating a PrefixQuery, WildcardQuery or RangeQuery. - setMultiTermRewriteMethod(MultiTermQuery.RewriteMethod) - Method in interface org.apache.lucene.queryParser.standard.config.MultiTermRewriteMethodAttribute
-
Deprecated.
- setMultiTermRewriteMethod(MultiTermQuery.RewriteMethod) - Method in class org.apache.lucene.queryParser.standard.config.MultiTermRewriteMethodAttributeImpl
-
Deprecated.
- setMultiTermRewriteMethod(MultiTermQuery.RewriteMethod) - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.
- setMultiTermRewriteMethod(MultiTermQuery.RewriteMethod) - Method in class org.apache.lucene.queryParser.standard.StandardQueryParser
-
By default, it uses
MultiTermQuery.CONSTANT_SCORE_AUTO_REWRITE_DEFAULT
when creating a prefix, wildcard and range queries. - 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
- setNextDoc(int) - Method in class org.apache.lucene.facet.enhancements.association.AssociationsPayloadIterator
-
Skipping to the next document, fetching its associations & populating the map.
- setNextDoc(int, float) - Method in interface org.apache.lucene.facet.search.aggregator.Aggregator
-
Specify the document (and its score in the search) that the following
Aggregator.aggregate(int)
calls will pertain to. - setNextDoc(int, float) - Method in class org.apache.lucene.facet.search.aggregator.association.AssociationFloatSumAggregator
- setNextDoc(int, float) - Method in class org.apache.lucene.facet.search.aggregator.association.AssociationIntSumAggregator
- setNextDoc(int, float) - Method in class org.apache.lucene.facet.search.aggregator.CountingAggregator
- setNextDoc(int, float) - Method in class org.apache.lucene.facet.search.aggregator.ScoringAggregator
- setNextReader(IndexReader, int) - Method in class org.apache.lucene.facet.search.FacetsCollector
- setNextReader(IndexReader, int) - Method in class org.apache.lucene.facet.search.ScoredDocIdCollector
- setNextReader(IndexReader, int) - Method in class org.apache.lucene.search.CachingCollector
- setNextReader(IndexReader, int) - Method in class org.apache.lucene.search.CheckHits.ExplanationAsserter
- setNextReader(IndexReader, int) - Method in class org.apache.lucene.search.CheckHits.SetCollector
- setNextReader(IndexReader, int) - Method in class org.apache.lucene.search.Collector
-
Called before collecting from each IndexReader.
- setNextReader(IndexReader, int) - Method in class org.apache.lucene.search.FieldComparator.ByteComparator
- setNextReader(IndexReader, int) - Method in class org.apache.lucene.search.FieldComparator.DocComparator
- setNextReader(IndexReader, int) - Method in class org.apache.lucene.search.FieldComparator.DoubleComparator
- setNextReader(IndexReader, int) - Method in class org.apache.lucene.search.FieldComparator.FloatComparator
- setNextReader(IndexReader, int) - Method in class org.apache.lucene.search.FieldComparator.IntComparator
- setNextReader(IndexReader, int) - Method in class org.apache.lucene.search.FieldComparator.LongComparator
- setNextReader(IndexReader, int) - Method in class org.apache.lucene.search.FieldComparator.NumericComparator
- setNextReader(IndexReader, int) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
- setNextReader(IndexReader, int) - Method in class org.apache.lucene.search.FieldComparator
-
Set a new Reader.
- setNextReader(IndexReader, int) - Method in class org.apache.lucene.search.FieldComparator.ShortComparator
- setNextReader(IndexReader, int) - Method in class org.apache.lucene.search.FieldComparator.StringComparatorLocale
- setNextReader(IndexReader, int) - Method in class org.apache.lucene.search.FieldComparator.StringOrdValComparator
- setNextReader(IndexReader, int) - Method in class org.apache.lucene.search.FieldComparator.StringValComparator
- setNextReader(IndexReader, int) - Method in class org.apache.lucene.search.grouping.AbstractFirstPassGroupingCollector
- setNextReader(IndexReader, int) - Method in class org.apache.lucene.search.grouping.AbstractSecondPassGroupingCollector
- setNextReader(IndexReader, int) - Method in class org.apache.lucene.search.grouping.BlockGroupingCollector
- setNextReader(IndexReader, int) - Method in class org.apache.lucene.search.grouping.TermAllGroupsCollector
- setNextReader(IndexReader, int) - Method in class org.apache.lucene.search.grouping.TermFirstPassGroupingCollector
- setNextReader(IndexReader, int) - Method in class org.apache.lucene.search.grouping.TermSecondPassGroupingCollector
- setNextReader(IndexReader, int) - Method in class org.apache.lucene.search.join.ToParentBlockJoinCollector
- setNextReader(IndexReader, int) - Method in class org.apache.lucene.search.MultiCollector
- setNextReader(IndexReader, int) - Method in class org.apache.lucene.search.PositiveScoresOnlyCollector
- setNextReader(IndexReader, int) - Method in class org.apache.lucene.search.TimeLimitingCollector
- setNextReader(IndexReader, int) - Method in class org.apache.lucene.search.TopScoreDocCollector
- setNextReader(IndexReader, int) - Method in class org.apache.lucene.search.TotalHitCountCollector
- setNoCFSRatio(double) - Method in class org.apache.lucene.index.LogMergePolicy
-
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.TieredMergePolicy
-
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.
- 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.
- setNoDeleteOpenFile(boolean) - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
Emulate windows whereby deleting an open file is not allowed (raise IOException).
- setNonLocalizedMessage(Message) - Method in exception org.apache.lucene.queryParser.core.QueryNodeParseException
- setNorm(int, String, byte) - Method in class org.apache.lucene.index.IndexReader
-
Deprecated.Write support will be removed in Lucene 4.0. There will be no replacement for this method.
- setNorm(int, String, float) - Method in class org.apache.lucene.index.IndexReader
-
Deprecated.Write support will be removed in Lucene 4.0. There will be no replacement for this method.
- setNumberFormat(NumberFormat) - Method in class org.apache.lucene.queryParser.standard.config.NumericConfig
- setNumberFormat(NumberFormat) - Method in class org.apache.lucene.queryParser.standard.nodes.NumericQueryNode
-
Sets the
NumberFormat
used to convert the value toString
. - setNumericConfigMap(Map<String, NumericConfig>) - Method in class org.apache.lucene.queryParser.standard.StandardQueryParser
- setNumLabel(int) - Method in class org.apache.lucene.facet.search.params.FacetRequest
- setNumLargeSegments(int) - Method in class org.apache.lucene.index.BalancedSegmentMergePolicy.MergePolicyParams
-
Deprecated.
- setNumLargeSegments(int) - Method in class org.apache.lucene.index.BalancedSegmentMergePolicy
-
Deprecated.
- setNumOverlap(int) - Method in class org.apache.lucene.index.FieldInvertState
- setNumReturnValues(int) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Sets the default maximum number of values returned from the
matchPrefix
andmatchAlmost
methods. - setNumWords(int) - Method in class org.apache.lucene.util.OpenBitSet
-
Expert: sets the number of longs in the array that are in use
- setOccur(BooleanClause.Occur) - Method in class org.apache.lucene.search.BooleanClause
- setOffset(int, int) - Method in class org.apache.lucene.analysis.Token
-
Set the starting and ending offset.
- 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
-
Set the starting and ending offset.
- setOmitNorms(boolean) - Method in class org.apache.lucene.document.AbstractField
-
Expert: If set, omit normalization factors associated with this indexed field.
- setOmitNorms(boolean) - Method in interface org.apache.lucene.document.Fieldable
-
Expert: If set, omit normalization factors associated with this indexed field.
- setOmitTermFreqAndPositions(boolean) - Method in class org.apache.lucene.document.AbstractField
-
Deprecated.
- SetOnce<T> - Class in org.apache.lucene.util
-
A convenient class which offers a semi-immutable object wrapper implementation which allows one to set the value of an object exactly once, and retrieve it many times.
- SetOnce() - Constructor for class org.apache.lucene.util.SetOnce
-
A default constructor which does not set the internal object, and allows setting it by calling
SetOnce.set(Object)
. - SetOnce(T) - Constructor for class org.apache.lucene.util.SetOnce
-
Creates a new instance with the internal object set to the given object.
- SetOnce.AlreadySetException - Exception in org.apache.lucene.util
-
Thrown when
SetOnce.set(Object)
is called more than once. - setOpenMode(IndexWriterConfig.OpenMode) - Method in class org.apache.lucene.index.IndexWriterConfig
-
Specifies
IndexWriterConfig.OpenMode
of the index. - setOperator(DefaultOperatorAttribute.Operator) - Method in interface org.apache.lucene.queryParser.standard.config.DefaultOperatorAttribute
-
Deprecated.
- setOperator(DefaultOperatorAttribute.Operator) - Method in class org.apache.lucene.queryParser.standard.config.DefaultOperatorAttributeImpl
-
Deprecated.
- setOrdinal(int) - Method in class org.apache.lucene.facet.index.attributes.OrdinalProperty
- setOutput(OutputStream) - Method in class org.apache.lucene.util.LuceneJUnitResultFormatter
-
Sets the stream the formatter is supposed to write its results to.
- setOutputUnigrams(boolean) - Method in class org.apache.lucene.analysis.shingle.ShingleAnalyzerWrapper
-
Deprecated.Setting outputUnigrams after Analyzer instantiation prevents reuse. Confgure outputUnigrams during construction.
- 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.ShingleAnalyzerWrapper
-
Deprecated.Setting outputUnigramsIfNoShingles after Analyzer instantiation prevents reuse. Confgure outputUnigramsIfNoShingles during construction.
- 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.)
- setOversampleFactor(double) - Method in class org.apache.lucene.facet.search.sampling.SamplingParams
- setParameters(Parameter[]) - Method in class org.apache.lucene.util.LuceneJUnitDividingSelector
- 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.CloseIndexTask
- setParams(String) - Method in class org.apache.lucene.benchmark.byTask.tasks.CommitIndexTask
- setParams(String) - Method in class org.apache.lucene.benchmark.byTask.tasks.DeleteByPercentTask
- setParams(String) - Method in class org.apache.lucene.benchmark.byTask.tasks.DeleteDocTask
-
Set the params (docid only)
- setParams(String) - Method in class org.apache.lucene.benchmark.byTask.tasks.FlushReaderTask
- 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 (analyzerClassName 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.NewShingleAnalyzerTask
- 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.SearchTravRetVectorHighlightTask
- 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)
- setPartialExpunge(boolean) - Method in class org.apache.lucene.index.BalancedSegmentMergePolicy.MergePolicyParams
-
Deprecated.
- setPartialExpunge(boolean) - Method in class org.apache.lucene.index.BalancedSegmentMergePolicy
-
Deprecated.
- setPathElements(List<PathQueryNode.QueryText>) - Method in class org.apache.lucene.queryParser.core.nodes.PathQueryNode
-
Returns the a List with all QueryText elements
- setPause(boolean) - Method in class org.apache.lucene.index.MergePolicy.OneMerge
- setPayload() - Method in class org.apache.lucene.facet.enhancements.EnhancementsCategoryTokenizer
- setPayload() - Method in class org.apache.lucene.facet.index.streaming.CategoryTokenizer
-
Set the payload of the current category token.
- setPayload(Payload) - Method in class org.apache.lucene.analysis.Token
-
Sets this Token's payload.
- setPayload(Payload) - Method in interface org.apache.lucene.analysis.tokenattributes.PayloadAttribute
-
Sets this Token's payload.
- setPayload(Payload) - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
-
Sets this Token's payload.
- setPayloadProcessorProvider(PayloadProcessorProvider) - Method in class org.apache.lucene.index.IndexWriter
-
Sets the
PayloadProcessorProvider
to use when merging payloads. - setPercentTermsToMatch(float) - Method in class org.apache.lucene.search.similar.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 givenkey
. - 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.QueryParser
-
Sets the default slop for phrases.
- setPhraseSlop(int) - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.
- setPhraseSlop(int) - Method in class org.apache.lucene.queryParser.standard.StandardQueryParser
-
Sets the default slop for phrases.
- setPivot(int) - Method in class org.apache.lucene.util.SorterTemplate
-
Implement this method, that stores the value of slot
i
as pivot value - setPosition(long) - Method in class org.apache.lucene.util.PagedBytes.PagedBytesDataInput
-
Seek to a position previously obtained from
PagedBytes.PagedBytesDataInput.getPosition()
. - setPositionIncrement(int) - Method in class org.apache.lucene.analysis.Token
-
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
-
Set the position increment.
- setPositionIncrement(int) - Method in class org.apache.lucene.queryParser.core.nodes.FieldQueryNode
- setPositionIncrementGap(int) - Method in class org.apache.lucene.analysis.MockAnalyzer
- setPositionIncrementsEnabled(boolean) - Method in interface org.apache.lucene.queryParser.standard.config.PositionIncrementsAttribute
-
Deprecated.
- setPositionIncrementsEnabled(boolean) - Method in class org.apache.lucene.queryParser.standard.config.PositionIncrementsAttributeImpl
-
Deprecated.
- 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.Token
-
Set the position length.
- setPositionLength(int) - Method in interface org.apache.lucene.analysis.tokenattributes.PositionLengthAttribute
- setPositionLength(int) - Method in class org.apache.lucene.analysis.tokenattributes.PositionLengthAttributeImpl
- setPositionSensitive(boolean) - Method in class org.apache.lucene.search.highlight.WeightedSpanTerm
- setPrecisionStep(int) - Method in class org.apache.lucene.queryParser.standard.config.NumericConfig
-
Sets the precision used to index the numeric values
- setPrefix(String) - Method in class org.apache.lucene.benchmark.byTask.tasks.RepSumByPrefTask
- setPrefix(TokenStream) - Method in class org.apache.lucene.analysis.miscellaneous.PrefixAwareTokenFilter
- setPrefixLength(int) - Method in class org.apache.lucene.queryParser.core.nodes.FuzzyQueryNode
- setPrefixLength(int) - Method in interface org.apache.lucene.queryParser.standard.config.FuzzyAttribute
-
Deprecated.
- setPrefixLength(int) - Method in class org.apache.lucene.queryParser.standard.config.FuzzyAttributeImpl
-
Deprecated.
- setPrefixLength(int) - Method in class org.apache.lucene.queryParser.standard.config.FuzzyConfig
- setPreventDoubleWrite(boolean) - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
If set to true, we throw an IOException if the same file is opened by createOutput, ever.
- setPreviousTokenStream(Object) - Method in class org.apache.lucene.analysis.Analyzer
-
Used by Analyzers that implement reusableTokenStream to save a TokenStream for later re-use by the same thread.
- setProcessingMode(int) - Method in class org.apache.lucene.search.DuplicateFilter
- 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
- setQuery(CharSequence) - Method in exception org.apache.lucene.queryParser.core.QueryNodeParseException
- setQuery(Query) - Method in class org.apache.lucene.search.BooleanClause
- setQueryBuilder(QueryBuilder) - Method in class org.apache.lucene.queryParser.core.QueryParserHelper
-
The query builder that will be used to build an object from the query node tree.
- setQueryBuilder(StandardQueryBuilder) - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.Sets the
StandardQueryBuilder
used to generate aQuery
object from the parsed and processed query node tree. - setQueryConfig(StandardQueryConfigHandler) - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.Sets the
QueryConfigHandler
used by theQueryNodeProcessor
set to this object. - setQueryConfigHandler(AbstractQueryConfig) - Method in interface org.apache.lucene.queryParser.core.config.ConfigAttribute
-
Deprecated.
- setQueryConfigHandler(AbstractQueryConfig) - Method in class org.apache.lucene.queryParser.standard.config.AllowLeadingWildcardAttributeImpl
-
Deprecated.
- setQueryConfigHandler(AbstractQueryConfig) - Method in class org.apache.lucene.queryParser.standard.config.AnalyzerAttributeImpl
-
Deprecated.
- setQueryConfigHandler(AbstractQueryConfig) - Method in class org.apache.lucene.queryParser.standard.config.BoostAttributeImpl
-
Deprecated.
- setQueryConfigHandler(AbstractQueryConfig) - Method in class org.apache.lucene.queryParser.standard.config.DateResolutionAttributeImpl
-
Deprecated.
- setQueryConfigHandler(AbstractQueryConfig) - Method in class org.apache.lucene.queryParser.standard.config.DefaultOperatorAttributeImpl
-
Deprecated.
- setQueryConfigHandler(AbstractQueryConfig) - Method in class org.apache.lucene.queryParser.standard.config.DefaultPhraseSlopAttributeImpl
-
Deprecated.
- setQueryConfigHandler(AbstractQueryConfig) - Method in class org.apache.lucene.queryParser.standard.config.FieldBoostMapAttributeImpl
-
Deprecated.
- setQueryConfigHandler(AbstractQueryConfig) - Method in class org.apache.lucene.queryParser.standard.config.FieldDateResolutionMapAttributeImpl
-
Deprecated.
- setQueryConfigHandler(AbstractQueryConfig) - Method in class org.apache.lucene.queryParser.standard.config.FuzzyAttributeImpl
-
Deprecated.
- setQueryConfigHandler(AbstractQueryConfig) - Method in class org.apache.lucene.queryParser.standard.config.LocaleAttributeImpl
-
Deprecated.
- setQueryConfigHandler(AbstractQueryConfig) - Method in class org.apache.lucene.queryParser.standard.config.LowercaseExpandedTermsAttributeImpl
-
Deprecated.
- setQueryConfigHandler(AbstractQueryConfig) - Method in class org.apache.lucene.queryParser.standard.config.MultiFieldAttributeImpl
-
Deprecated.
- setQueryConfigHandler(AbstractQueryConfig) - Method in class org.apache.lucene.queryParser.standard.config.MultiTermRewriteMethodAttributeImpl
-
Deprecated.
- setQueryConfigHandler(AbstractQueryConfig) - Method in class org.apache.lucene.queryParser.standard.config.PositionIncrementsAttributeImpl
-
Deprecated.
- setQueryConfigHandler(AbstractQueryConfig) - Method in class org.apache.lucene.queryParser.standard.config.RangeCollatorAttributeImpl
-
Deprecated.
- setQueryConfigHandler(QueryConfigHandler) - Method in interface org.apache.lucene.queryParser.core.processors.QueryNodeProcessor
-
Sets the
QueryConfigHandler
associated to the query tree. - setQueryConfigHandler(QueryConfigHandler) - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorImpl
-
For reference about this method check:
QueryNodeProcessor.setQueryConfigHandler(QueryConfigHandler)
. - setQueryConfigHandler(QueryConfigHandler) - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorPipeline
-
For reference about this method check:
QueryNodeProcessor.setQueryConfigHandler(QueryConfigHandler)
. - setQueryConfigHandler(QueryConfigHandler) - Method in class org.apache.lucene.queryParser.core.QueryParserHelper
-
Sets the query configuration handler that will be used during query processing.
- setQueryConfigHandler(QueryConfigHandler) - Method in class org.apache.lucene.queryParser.standard.processors.BooleanQuery2ModifierNodeProcessor
- setQueryConfigHandler(QueryConfigHandler) - Method in class org.apache.lucene.queryParser.standard.processors.GroupQueryNodeProcessor
-
Deprecated.
- setQueryNodeProcessor(QueryNodeProcessor) - Method in class org.apache.lucene.queryParser.core.QueryParserHelper
-
Sets the processor that will be used to process the query node tree.
- setQueryProcessor(QueryNodeProcessor) - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.Sets the
QueryNodeProcessor
used to process the query node tree generated by theStandardSyntaxParser
. - setRAMBufferSizeMB(double) - Method in class org.apache.lucene.index.IndexWriter
-
Deprecated.use
IndexWriterConfig.setRAMBufferSizeMB(double)
instead. - setRAMBufferSizeMB(double) - Method in class org.apache.lucene.index.IndexWriterConfig
-
Determines the amount of RAM that may be used for buffering added documents and deletions before they are flushed to the Directory.
- setRamUsageEstimator(boolean) - Method in class org.apache.lucene.util.FieldCacheSanityChecker
-
If set, estimate size for all CacheEntry objects will be calculateed.
- setRandomIOExceptionRate(double) - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
If 0.0, no exceptions will be thrown.
- setRangeCollator(Collator) - Method in class org.apache.lucene.queryParser.QueryParser
-
Sets the collator used to determine index term inclusion in ranges for RangeQuerys.
- setRangeCollator(Collator) - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.
- setRangeCollator(Collator) - Method in class org.apache.lucene.queryParser.standard.StandardQueryParser
-
Sets the collator used to determine index term inclusion in ranges for RangeQuerys.
- setRate(int, boolean) - Method in class org.apache.lucene.benchmark.byTask.tasks.TaskSequence
- setReadChunkSize(int) - Method in class org.apache.lucene.store.FSDirectory
-
Sets the maximum number of bytes read at once from the underlying file during
DataInput.readBytes(byte[], int, int)
. - 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
IndexWriter.getReader()
. - setReaderTermsIndexDivisor(int) - Method in class org.apache.lucene.index.IndexWriter
-
Deprecated.use
IndexWriterConfig.setReaderTermsIndexDivisor(int)
instead. - setReaderTermsIndexDivisor(int) - Method in class org.apache.lucene.index.IndexWriterConfig
-
Sets the termsIndexDivisor passed to any readers that IndexWriter opens, for example when applying deletes or creating a near-real-time reader in
IndexWriter.getReader()
. - setReclaimDeletesWeight(double) - Method in class org.apache.lucene.index.TieredMergePolicy
-
Controls how aggressively merges that reclaim more deletions are favored.
- 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.
- setRegexImplementation(RegexCapabilities) - Method in class org.apache.lucene.search.regex.RegexQuery
-
Defines which
RegexCapabilities
implementation is used by this instance. - setRegexImplementation(RegexCapabilities) - Method in interface org.apache.lucene.search.regex.RegexQueryCapable
- setRegexImplementation(RegexCapabilities) - Method in class org.apache.lucene.search.regex.SpanRegexQuery
-
Deprecated.
- setRepetitions(int) - Method in class org.apache.lucene.benchmark.byTask.tasks.TaskSequence
- setReplaceInvalidAcronym(boolean) - Method in class org.apache.lucene.analysis.standard.ClassicTokenizer
-
Deprecated.Remove in 3.X and make true the only valid value See https://issues.apache.org/jira/browse/LUCENE-1068
- setReplaceInvalidAcronym(boolean) - Method in class org.apache.lucene.analysis.standard.StandardTokenizer
-
Deprecated.Remove in 3.X and make true the only valid value See https://issues.apache.org/jira/browse/LUCENE-1068
- setResidue(double) - Method in class org.apache.lucene.facet.search.results.MutableFacetResultNode
-
Set the residue.
- setResolution(long) - Method in class org.apache.lucene.search.TimeLimitingCollector.TimerThread
-
Set the timer resolution.
- setResultMode(FacetRequest.ResultMode) - Method in class org.apache.lucene.facet.search.params.FacetRequest
- 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
- setRunningMerge(MergePolicy.OneMerge) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler.MergeThread
- setRunTime(double) - Method in class org.apache.lucene.benchmark.byTask.tasks.TaskSequence
- setSampingThreshold(int) - Method in class org.apache.lucene.facet.search.sampling.SamplingParams
-
Set a sampling-threshold
- setSampler(Sampler) - Method in class org.apache.lucene.facet.search.AdaptiveFacetsAccumulator
-
Set the sampler.
- setSampleRatio(double) - Method in class org.apache.lucene.facet.search.sampling.SamplingParams
- setScorer(Scorer) - Method in class org.apache.lucene.facet.search.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.Collector
-
Called before successive calls to
Collector.collect(int)
. - setScorer(Scorer) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
- setScorer(Scorer) - Method in class org.apache.lucene.search.FieldComparator
-
Sets the Scorer to use in case a document's score is needed.
- setScorer(Scorer) - Method in class org.apache.lucene.search.grouping.AbstractAllGroupsCollector
- setScorer(Scorer) - Method in class org.apache.lucene.search.grouping.AbstractFirstPassGroupingCollector
- setScorer(Scorer) - Method in class org.apache.lucene.search.grouping.AbstractSecondPassGroupingCollector
- setScorer(Scorer) - Method in class org.apache.lucene.search.grouping.BlockGroupingCollector
- setScorer(Scorer) - Method in class org.apache.lucene.search.join.ToParentBlockJoinCollector
- setScorer(Scorer) - Method in class org.apache.lucene.search.MultiCollector
- setScorer(Scorer) - Method in class org.apache.lucene.search.PositiveScoresOnlyCollector
- setScorer(Scorer) - Method in class org.apache.lucene.search.TimeLimitingCollector
- setScorer(Scorer) - Method in class org.apache.lucene.search.TopScoreDocCollector
- setScorer(Scorer) - Method in class org.apache.lucene.search.TotalHitCountCollector
- setSegmentsPerTier(double) - Method in class org.apache.lucene.index.TieredMergePolicy
-
Sets the allowed number of segments per tier.
- setShouldHaveCache(boolean) - Method in class org.apache.lucene.search.CachingWrapperFilterHelper
- setSimilarity(float) - Method in class org.apache.lucene.queryParser.core.nodes.FuzzyQueryNode
- setSimilarity(Similarity) - Method in class org.apache.lucene.index.IndexWriter
-
Deprecated.use
IndexWriterConfig.setSimilarity(Similarity)
instead - setSimilarity(Similarity) - Method in class org.apache.lucene.index.IndexWriterConfig
-
Expert: set the
Similarity
implementation used by this IndexWriter. - setSimilarity(Similarity) - Method in class org.apache.lucene.search.IndexSearcher
-
Expert: Set the Similarity implementation used by this Searcher.
- setSimilarity(Similarity) - Method in class org.apache.lucene.search.Searcher
-
Deprecated.Expert: Set the Similarity implementation used by this Searcher.
- setSimilarity(Similarity) - Method in class org.apache.lucene.search.similar.MoreLikeThis
- setSimilarity(Similarity) - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexWriter
-
Deprecated.
- 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
-
Sets the phrase slop for this query.
- setSlop(int) - Method in class org.apache.lucene.search.PhraseQuery
-
Sets the number of other words permitted between words in query phrase.
- 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.
- setSortBy(FacetRequest.SortBy) - Method in class org.apache.lucene.facet.search.params.FacetRequest
- setSortOrder(FacetRequest.SortOrder) - Method in class org.apache.lucene.facet.search.params.FacetRequest
- setSpacerCharacter(Character) - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter
-
Deprecated.
- 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. - setStartOffset(int) - Method in class org.apache.lucene.analysis.Token
-
Set the starting offset.
- setStartOffset(int) - Method in class org.apache.lucene.index.TermVectorOffsetInfo
- setStartTimeMillis() - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
- setStemDictionary(File) - Method in class org.apache.lucene.analysis.nl.DutchAnalyzer
-
Deprecated.This prevents reuse of TokenStreams. If you wish to use a custom stem dictionary, create your own Analyzer with
StemmerOverrideFilter
- setStemDictionary(HashMap<?, ?>) - Method in class org.apache.lucene.analysis.nl.DutchStemFilter
-
Deprecated.Set dictionary for stemming, this dictionary overrules the algorithm, so you can correct for a particular unwanted word-stem pair.
- setStemExclusionTable(File) - Method in class org.apache.lucene.analysis.br.BrazilianAnalyzer
-
Deprecated.use
BrazilianAnalyzer(Version, Set, Set)
instead - setStemExclusionTable(File) - Method in class org.apache.lucene.analysis.de.GermanAnalyzer
-
Deprecated.use
GermanAnalyzer(Version, Set, Set)
instead - setStemExclusionTable(File) - Method in class org.apache.lucene.analysis.fr.FrenchAnalyzer
-
Deprecated.use
FrenchAnalyzer(Version, Set, Set)
instead - setStemExclusionTable(File) - Method in class org.apache.lucene.analysis.nl.DutchAnalyzer
-
Deprecated.use
DutchAnalyzer(Version, Set, Set)
instead - setStemExclusionTable(String...) - Method in class org.apache.lucene.analysis.br.BrazilianAnalyzer
-
Deprecated.use
BrazilianAnalyzer(Version, Set, Set)
instead - setStemExclusionTable(String[]) - Method in class org.apache.lucene.analysis.de.GermanAnalyzer
-
Deprecated.use
GermanAnalyzer(Version, Set, Set)
instead - setStemExclusionTable(String...) - Method in class org.apache.lucene.analysis.fr.FrenchAnalyzer
-
Deprecated.use
FrenchAnalyzer(Version, Set, Set)
instead - setStemExclusionTable(String...) - Method in class org.apache.lucene.analysis.nl.DutchAnalyzer
-
Deprecated.use
DutchAnalyzer(Version, Set, Set)
instead - setStemExclusionTable(HashSet<?>) - Method in class org.apache.lucene.analysis.nl.DutchAnalyzer
-
Deprecated.use
DutchAnalyzer(Version, Set, Set)
instead - setStemExclusionTable(Map<?, ?>) - Method in class org.apache.lucene.analysis.br.BrazilianAnalyzer
-
Deprecated.use
BrazilianAnalyzer(Version, Set, Set)
instead - setStemExclusionTable(Map<?, ?>) - Method in class org.apache.lucene.analysis.de.GermanAnalyzer
-
Deprecated.use
GermanAnalyzer(Version, Set, Set)
instead - setStemExclusionTable(Map<?, ?>) - Method in class org.apache.lucene.analysis.fr.FrenchAnalyzer
-
Deprecated.use
FrenchAnalyzer(Version, Set, Set)
instead - setStemmer(GermanStemmer) - Method in class org.apache.lucene.analysis.de.GermanStemFilter
-
Set a alternative/custom
GermanStemmer
for this filter. - setStemmer(FrenchStemmer) - Method in class org.apache.lucene.analysis.fr.FrenchStemFilter
-
Deprecated.Set a alternative/custom
FrenchStemmer
for this filter. - setStemmer(DutchStemmer) - Method in class org.apache.lucene.analysis.nl.DutchStemFilter
-
Deprecated.Set a alternative/custom
DutchStemmer
for this filter. - setStemmer(RussianStemmer) - Method in class org.apache.lucene.analysis.ru.RussianStemFilter
-
Deprecated.Set a alternative/custom
RussianStemmer
for this filter. - setStopWords(Set<?>) - Method in class org.apache.lucene.search.similar.MoreLikeThis
-
Set the set of stopwords.
- setStopWords(Set<?>) - Method in class org.apache.lucene.search.similar.MoreLikeThisQuery
- setStoreTermVector(Field.TermVector) - Method in class org.apache.lucene.document.AbstractField
- setStrict(boolean) - Method in class org.apache.lucene.search.function.CustomScoreQuery
-
Set the strict mode of this query.
- setStrictMode(boolean) - Method in class org.apache.lucene.xmlparser.builders.NumericRangeFilterBuilder
-
Specifies how this
NumericRangeFilterBuilder
will handle errors. - setStringDistance(StringDistance) - Method in class org.apache.lucene.search.spell.SpellChecker
-
Sets the
StringDistance
implementation for thisSpellChecker
instance. - setStrip(String) - Method in class org.apache.lucene.analysis.hunspell.HunspellAffix
-
Sets the stripping characters defined for the affix
- setSubResults(List<FacetResultNode>) - Method in class org.apache.lucene.facet.search.results.MutableFacetResultNode
-
Set the sub results.
- setSuffix(TokenStream) - Method in class org.apache.lucene.analysis.miscellaneous.PrefixAwareTokenFilter
- setSyntaxParser(SyntaxParser) - Method in class org.apache.lucene.queryParser.core.QueryParserHelper
-
Sets the text parser that will be used to parse the query string, it cannot be
null
. - setSystemError(String) - Method in class org.apache.lucene.util.LuceneJUnitResultFormatter
-
.
- setSystemOutput(String) - Method in class org.apache.lucene.util.LuceneJUnitResultFormatter
-
.
- setTabSize(int) - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
- setTabSize(int) - Method in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
- setTag(CharSequence, Object) - Method in interface org.apache.lucene.queryParser.core.nodes.QueryNode
-
Deprecated.use
QueryNode.setTag(String, Object)
instead - setTag(CharSequence, Object) - Method in class org.apache.lucene.queryParser.core.nodes.QueryNodeImpl
-
Deprecated.use
QueryNodeImpl.setTag(String, Object)
instead - setTag(String, Object) - Method in interface org.apache.lucene.queryParser.core.nodes.QueryNode
-
Associate the specified value with the specified tagName.
- setTag(String, Object) - Method in class org.apache.lucene.queryParser.core.nodes.QueryNodeImpl
- 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
- setTermBuffer(char[], int, int) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
-
Deprecated.
- setTermBuffer(char[], int, int) - Method in interface org.apache.lucene.analysis.tokenattributes.TermAttribute
-
Deprecated.Copies the contents of buffer, starting at offset for length characters, into the termBuffer array.
- setTermBuffer(String) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
-
Deprecated.
- setTermBuffer(String) - Method in interface org.apache.lucene.analysis.tokenattributes.TermAttribute
-
Deprecated.Copies the contents of buffer into the termBuffer array.
- setTermBuffer(String, int, int) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
-
Deprecated.
- setTermBuffer(String, int, int) - Method in interface org.apache.lucene.analysis.tokenattributes.TermAttribute
-
Deprecated.Copies the contents of buffer, starting at offset and continuing for length characters, into the termBuffer array.
- setTermIndex(int) - Method in class org.apache.lucene.store.instantiated.InstantiatedTerm
- setTermIndexInterval(int) - Method in class org.apache.lucene.index.IndexWriter
-
Deprecated.
- setTermIndexInterval(int) - Method in class org.apache.lucene.index.IndexWriterConfig
-
Expert: set the interval between indexed terms.
- setTermLength(int) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
-
Deprecated.
- setTermLength(int) - Method in interface org.apache.lucene.analysis.tokenattributes.TermAttribute
-
Deprecated.Set number of valid characters (length of the term) in the termBuffer array.
- setTestMode() - Static method in class org.apache.lucene.index.ConcurrentMergeScheduler
-
Deprecated.this test mode code will be removed in a future release
- setTestPoint(double, double) - Method in class org.apache.lucene.spatial.geometry.shape.DistanceApproximation
-
Deprecated.
- 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.core.nodes.FieldQueryNode
- setText(CharSequence) - Method in interface org.apache.lucene.queryParser.core.nodes.TextableQueryNode
- setText(String) - Method in class org.apache.lucene.analysis.icu.segmentation.LaoBreakIterator
- setText(CharacterIterator) - Method in class org.apache.lucene.analysis.icu.segmentation.LaoBreakIterator
- setTextFragmenter(Fragmenter) - Method in class org.apache.lucene.search.highlight.Highlighter
- setThreadPriority(int) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler.MergeThread
- setThreshold(float) - Method in class org.apache.lucene.search.spell.JaroWinklerDistance
-
Sets the threshold used to determine when Winkler bonus should be used.
- setThrottling(MockDirectoryWrapper.Throttling) - Method in class org.apache.lucene.store.MockDirectoryWrapper
- 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 class org.apache.lucene.analysis.miscellaneous.SingleTokenTokenStream
- setTokenPositioner(Token, ShingleMatrixFilter.TokenPositioner) - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.OneDimensionalNonWeightedTokenSettingsCodec
-
Deprecated.
- setTokenPositioner(Token, ShingleMatrixFilter.TokenPositioner) - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.SimpleThreeDimensionalTokenSettingsCodec
-
Deprecated.Sets the TokenPositioner as token flags int value.
- setTokenPositioner(Token, ShingleMatrixFilter.TokenPositioner) - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.TokenSettingsCodec
-
Deprecated.Sets information on how a
Token
is to be inserted to aShingleMatrixFilter.Matrix
. - setTokenPositioner(Token, ShingleMatrixFilter.TokenPositioner) - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.TwoDimensionalNonWeightedSynonymTokenSettingsCodec
-
Deprecated.
- setTokens(List<Token>) - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.Matrix.Column.Row
-
Deprecated.
- setTokenSeparator(String) - Method in class org.apache.lucene.analysis.shingle.ShingleAnalyzerWrapper
-
Deprecated.Setting tokenSeparator after Analyzer instantiation prevents reuse. Confgure tokenSeparator during construction.
- 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.
- setTrackDiskUsage(boolean) - Method in class org.apache.lucene.store.MockDirectoryWrapper
- setType(String) - Method in class org.apache.lucene.analysis.Token
-
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
-
Set the lexical type.
- setType(NumericField.DataType) - Method in class org.apache.lucene.queryParser.standard.config.NumericConfig
-
Sets the numeric type used to index the numeric values
- 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.DeleteByPercentTask
- setup() - Method in class org.apache.lucene.benchmark.byTask.tasks.DeleteDocTask
- 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.SearchTravRetVectorHighlightTask
- 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.queryParser.QueryParserTestBase
- setUp() - Method in class org.apache.lucene.util.LuceneTestCase
-
For subclassing only.
- setUseCompoundFile(boolean) - Method in class org.apache.lucene.index.BalancedSegmentMergePolicy.MergePolicyParams
-
Deprecated.
- setUseCompoundFile(boolean) - Method in class org.apache.lucene.index.IndexWriter
-
Deprecated.
- setUseCompoundFile(boolean) - Method in class org.apache.lucene.index.LogMergePolicy
-
Sets whether compound file format should be used for newly flushed and newly merged segments.
- setUseCompoundFile(boolean) - Method in class org.apache.lucene.index.TieredMergePolicy
-
Sets whether compound file format should be used for newly flushed and newly merged segments.
- setUseCompoundFile(MergePolicy, boolean) - Static method in class org.apache.lucene.util._TestUtil
- setUseCompoundFile(MergePolicy, boolean) - Static method in class org.apache.lucene.util.LuceneTestCase
- setUseOldRangeQuery(boolean) - Method in class org.apache.lucene.queryParser.standard.QueryParserWrapper
-
Deprecated.
- 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(byte[]) - Method in class org.apache.lucene.document.Field
-
Expert: change the value of this field.
- setValue(byte[], int, int) - Method in class org.apache.lucene.document.Field
-
Expert: change the value of this field.
- setValue(double) - Method in interface org.apache.lucene.facet.search.results.FacetResultNode
-
Expert: Set a new value for this result node.
- setValue(double) - Method in class org.apache.lucene.facet.search.results.MutableFacetResultNode
-
Set the value of this result.
- setValue(float) - Method in class org.apache.lucene.search.Explanation
-
Sets the value assigned to this explanation node.
- setValue(Reader) - Method in class org.apache.lucene.document.Field
-
Expert: change the value of this field.
- setValue(CharSequence) - Method in class org.apache.lucene.queryParser.core.nodes.FieldQueryNode
- setValue(Number) - Method in class org.apache.lucene.queryParser.standard.nodes.NumericQueryNode
-
Sets the numeric value.
- setValue(String) - Method in class org.apache.lucene.document.Field
-
Expert: change the value of this field.
- setValue(T) - Method in interface org.apache.lucene.queryParser.core.nodes.ValueQueryNode
- setValue(V) - Method in class org.apache.lucene.analysis.CharArrayMap.EntryIterator
-
sets the value associated with the last key returned
- setVectorSpace(Map<String, List<InstantiatedTermDocumentInformation>>) - Method in class org.apache.lucene.store.instantiated.InstantiatedDocument
- setWeight(float) - Method in class org.apache.lucene.queryParser.surround.query.SrndQuery
- setWeight(float) - Method in class org.apache.lucene.search.highlight.WeightedTerm
- setWeight(Token, float) - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.OneDimensionalNonWeightedTokenSettingsCodec
-
Deprecated.
- setWeight(Token, float) - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.SimpleThreeDimensionalTokenSettingsCodec
-
Deprecated.Stores a 32 bit float in the payload, or set it to null if 1f;
- setWeight(Token, float) - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.TokenSettingsCodec
-
Deprecated.Have this method do nothing in order to 'disable' weights.
- setWeight(Token, float) - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.TwoDimensionalNonWeightedSynonymTokenSettingsCodec
-
Deprecated.
- setWrapIfNotCachingTokenFilter(boolean) - Method in class org.apache.lucene.search.highlight.QueryScorer
-
By default,
TokenStream
s that are not of the typeCachingTokenFilter
are wrapped in aCachingTokenFilter
to ensure an efficient reset - if you are already using a different cachingTokenStream
impl and you don't want it to be wrapped, set this to false. - setWrapIfNotCachingTokenFilter(boolean) - Method in class org.apache.lucene.search.highlight.WeightedSpanTermExtractor
-
By default,
TokenStream
s that are not of the typeCachingTokenFilter
are wrapped in aCachingTokenFilter
to ensure an efficient reset - if you are already using a different cachingTokenStream
impl and you don't want it to be wrapped, set this to false. - setWriteLockTimeout(long) - Method in class org.apache.lucene.index.IndexWriter
-
Deprecated.use
IndexWriterConfig.setWriteLockTimeout(long)
instead - setWriteLockTimeout(long) - Method in class org.apache.lucene.index.IndexWriterConfig
-
Sets the maximum time to wait for a write lock (in milliseconds) for this instance.
- setX(double) - Method in class org.apache.lucene.spatial.geometry.shape.Point2D
-
Deprecated.
- setX(double) - Method in class org.apache.lucene.spatial.geometry.shape.Vector2D
-
Deprecated.
- setY(double) - Method in class org.apache.lucene.spatial.geometry.shape.Point2D
-
Deprecated.
- setY(double) - Method in class org.apache.lucene.spatial.geometry.shape.Vector2D
-
Deprecated.
- SHADDA - Static variable in class org.apache.lucene.analysis.ar.ArabicNormalizer
- 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 - Class in org.apache.lucene.spatial.tier
-
Deprecated.
- Shape(String) - Constructor for class org.apache.lucene.spatial.tier.Shape
-
Deprecated.
- shardIndex - Variable in class org.apache.lucene.search.ScoreDoc
- SHIFT_START_INT - Static variable in class org.apache.lucene.util.NumericUtils
-
Expert: Integers are stored at lower precision by shifting off lower bits.
- SHIFT_START_LONG - Static variable in class org.apache.lucene.util.NumericUtils
-
Expert: Longs are stored at lower precision by shifting off lower bits.
- ShingleAnalyzerWrapper - Class in org.apache.lucene.analysis.shingle
-
A ShingleAnalyzerWrapper wraps a
ShingleFilter
around anotherAnalyzer
. - 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) - Constructor for class org.apache.lucene.analysis.shingle.ShingleAnalyzerWrapper
-
Creates a new ShingleAnalyzerWrapper
- ShingleAnalyzerWrapper(Version) - Constructor for class org.apache.lucene.analysis.shingle.ShingleAnalyzerWrapper
-
Wraps
StandardAnalyzer
. - ShingleAnalyzerWrapper(Version, int, int) - Constructor for class org.apache.lucene.analysis.shingle.ShingleAnalyzerWrapper
-
Wraps
StandardAnalyzer
. - ShingleFilter - Class in org.apache.lucene.analysis.shingle
-
A ShingleFilter constructs shingles (token n-grams) from a token stream.
- ShingleFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.shingle.ShingleFilter
-
Construct a ShingleFilter with default shingle size: 2.
- 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, 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, 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
- ShingleMatrixFilter - Class in org.apache.lucene.analysis.shingle
-
Deprecated.Will be removed in Lucene 4.0. This filter is unmaintained and might not behave correctly if used with custom Attributes, i.e. Attributes other than the ones located in
org.apache.lucene.analysis.tokenattributes
. It also uses hardcoded payload encoders which makes it not easily adaptable to other use-cases. - ShingleMatrixFilter(ShingleMatrixFilter.Matrix, int, int, Character, boolean, ShingleMatrixFilter.TokenSettingsCodec) - Constructor for class org.apache.lucene.analysis.shingle.ShingleMatrixFilter
-
Deprecated.Creates a shingle filter based on a user defined matrix.
- ShingleMatrixFilter(TokenStream, int, int) - Constructor for class org.apache.lucene.analysis.shingle.ShingleMatrixFilter
-
Deprecated.Creates a shingle filter using default settings.
- ShingleMatrixFilter(TokenStream, int, int, Character) - Constructor for class org.apache.lucene.analysis.shingle.ShingleMatrixFilter
-
Deprecated.Creates a shingle filter using default settings.
- ShingleMatrixFilter(TokenStream, int, int, Character, boolean) - Constructor for class org.apache.lucene.analysis.shingle.ShingleMatrixFilter
-
Deprecated.Creates a shingle filter using the default
ShingleMatrixFilter.TokenSettingsCodec
. - ShingleMatrixFilter(TokenStream, int, int, Character, boolean, ShingleMatrixFilter.TokenSettingsCodec) - Constructor for class org.apache.lucene.analysis.shingle.ShingleMatrixFilter
-
Deprecated.Creates a shingle filter with ad hoc parameter settings.
- ShingleMatrixFilter.Matrix - Class in org.apache.lucene.analysis.shingle
-
Deprecated.A column focused matrix in three dimensions:
- ShingleMatrixFilter.Matrix.Column - Class in org.apache.lucene.analysis.shingle
-
Deprecated.
- ShingleMatrixFilter.Matrix.Column.Row - Class in org.apache.lucene.analysis.shingle
-
Deprecated.
- ShingleMatrixFilter.OneDimensionalNonWeightedTokenSettingsCodec - Class in org.apache.lucene.analysis.shingle
-
Deprecated.Using this codec makes a
ShingleMatrixFilter
act likeShingleFilter
. - ShingleMatrixFilter.SimpleThreeDimensionalTokenSettingsCodec - Class in org.apache.lucene.analysis.shingle
-
Deprecated.A full featured codec not to be used for something serious.
- ShingleMatrixFilter.TokenPositioner - Class in org.apache.lucene.analysis.shingle
-
Deprecated.Used to describe how a
Token
is to be inserted to aShingleMatrixFilter.Matrix
. - ShingleMatrixFilter.TokenSettingsCodec - Class in org.apache.lucene.analysis.shingle
-
Deprecated.Strategy used to code and decode meta data of the tokens from the input stream regarding how to position the tokens in the matrix, set and retreive weight, et c.
- ShingleMatrixFilter.TwoDimensionalNonWeightedSynonymTokenSettingsCodec - Class in org.apache.lucene.analysis.shingle
-
Deprecated.A codec that creates a two dimensional matrix by treating tokens from the input stream with 0 position increment as new rows to the current column.
- SHORT - Static variable in class org.apache.lucene.search.function.FieldScoreQuery.Type
-
field values are interpreted as numeric short values.
- SHORT - Static variable in class org.apache.lucene.search.SortField
-
Sort using term values as encoded Shorts.
- shortestPaths(FST<T>, FST.Arc<T>, Comparator<T>, int) - Static method in class org.apache.lucene.util.fst.Util
-
Starting from node, find the top N min cost completions to a final node.
- ShortFieldSource - Class in org.apache.lucene.search.function
-
Expert: obtains short field values from the
FieldCache
usinggetShorts()
and makes those values available as other numeric types, casting as needed. - ShortFieldSource(String) - Constructor for class org.apache.lucene.search.function.ShortFieldSource
-
Create a cached short field source with default string-to-short parser.
- ShortFieldSource(String, FieldCache.ShortParser) - Constructor for class org.apache.lucene.search.function.ShortFieldSource
-
Create a cached short field source with a specific string-to-short parser.
- SHOULD - org.apache.lucene.search.BooleanClause.Occur
-
Use this operator for clauses that should appear in the matching documents.
- shouldAdd(int) - Method in class org.apache.lucene.facet.index.categorypolicy.DefaultOrdinalPolicy
-
Filters out (returns false) ordinals equal or less than
TaxonomyReader.ROOT_ORDINAL
. - shouldAdd(int) - Method in class org.apache.lucene.facet.index.categorypolicy.NonTopLevelOrdinalPolicy
-
Filters out ordinal which are ROOT or who's parent is ROOT.
- shouldAdd(int) - Method in interface org.apache.lucene.facet.index.categorypolicy.OrdinalPolicy
-
Check whether a given category ordinal should be added to the stream.
- shouldAdd(CategoryPath) - Method in class org.apache.lucene.facet.index.categorypolicy.DefaultPathPolicy
-
Filters out (returns false) CategoryPaths equal or less than
TaxonomyReader.ROOT_ORDINAL
. - shouldAdd(CategoryPath) - Method in class org.apache.lucene.facet.index.categorypolicy.NonTopLevelPathPolicy
-
Filters out (returns false) CategoryPaths equal or less than
TaxonomyReader.ROOT_ORDINAL
. - shouldAdd(CategoryPath) - Method in interface org.apache.lucene.facet.index.categorypolicy.PathPolicy
-
Check whether a given category path should be added to the stream.
- shouldComplement(ScoredDocIDs) - Method in class org.apache.lucene.facet.search.StandardFacetsAccumulator
-
Check if it is worth to use complements
- shouldDelete(String) - Method in class org.apache.lucene.index.SnapshotDeletionPolicy.SnapshotCommitPoint
-
Returns true if this segment can be deleted.
- 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
- shouldSample(ScoredDocIDs) - Method in class org.apache.lucene.facet.search.sampling.Sampler
-
Check if this sampler would complement for the input docIds
- shouldUpgradeSegment(SegmentInfo) - Method in class org.apache.lucene.index.UpgradeIndexMergePolicy
-
Returns if the given segment should be upgraded.
- shrink(boolean[], int) - Static method in class org.apache.lucene.util.ArrayUtil
- shrink(byte[], int) - Static method in class org.apache.lucene.util.ArrayUtil
- shrink(char[], int) - Static method in class org.apache.lucene.util.ArrayUtil
- shrink(float[][], int) - Static method in class org.apache.lucene.util.ArrayUtil
- shrink(int[][], int) - Static method in class org.apache.lucene.util.ArrayUtil
- shrink(int[], int) - Static method in class org.apache.lucene.util.ArrayUtil
- shrink(long[], int) - Static method in class org.apache.lucene.util.ArrayUtil
- shrink(short[], int) - Static method in class org.apache.lucene.util.ArrayUtil
- similarity - Variable in class org.apache.lucene.search.BooleanQuery.BooleanWeight
-
The Similarity implementation.
- similarity - Variable in class org.apache.lucene.search.DisjunctionMaxQuery.DisjunctionMaxWeight
-
The Similarity implementation.
- similarity - Variable in class org.apache.lucene.search.spans.SpanWeight
- Similarity - Class in org.apache.lucene.search
-
Expert: Scoring API.
- Similarity() - Constructor for class org.apache.lucene.search.Similarity
- SimilarityDelegator - Class in org.apache.lucene.search
-
Deprecated.this class will be removed in 4.0. Please subclass
Similarity
orDefaultSimilarity
instead. - SimilarityDelegator(Similarity) - Constructor for class org.apache.lucene.search.SimilarityDelegator
-
Deprecated.Construct a
Similarity
that delegates all methods to another. - SimilarityQueries - Class in org.apache.lucene.search.similar
-
Simple similarity measures.
- SIMPLE - Static variable in class org.apache.lucene.analysis.MockTokenizer
-
Acts like LetterTokenizer.
- SimpleAnalyzer - Class in org.apache.lucene.analysis
- SimpleAnalyzer() - Constructor for class org.apache.lucene.analysis.SimpleAnalyzer
-
Deprecated.use
SimpleAnalyzer(Version)
instead - SimpleAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.SimpleAnalyzer
-
Creates a new
SimpleAnalyzer
- SimpleBoundaryScanner - Class in org.apache.lucene.search.vectorhighlight
- SimpleBoundaryScanner() - Constructor for class org.apache.lucene.search.vectorhighlight.SimpleBoundaryScanner
- SimpleBoundaryScanner(int) - 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
- SimpleBoundaryScanner(Character[]) - Constructor for class org.apache.lucene.search.vectorhighlight.SimpleBoundaryScanner
- SimpleCharStream - Class in org.apache.lucene.benchmark.byTask.feeds.demohtml
-
An implementation of interface CharStream, where the stream is assumed to contain only ASCII characters (without unicode processing).
- SimpleCharStream(InputStream) - Constructor for class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
-
Constructor.
- SimpleCharStream(InputStream, int, int) - Constructor for class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
-
Constructor.
- SimpleCharStream(InputStream, int, int, int) - Constructor for class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
-
Constructor.
- SimpleCharStream(InputStream, String) - Constructor for class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
-
Constructor.
- SimpleCharStream(InputStream, String, int, int) - Constructor for class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
-
Constructor.
- SimpleCharStream(InputStream, String, int, int, int) - Constructor for class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
-
Constructor.
- SimpleCharStream(Reader) - Constructor for class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
-
Constructor.
- SimpleCharStream(Reader, int, int) - Constructor for class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
-
Constructor.
- SimpleCharStream(Reader, int, int, int) - Constructor for class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
-
Constructor.
- SimpleFragListBuilder - Class in org.apache.lucene.search.vectorhighlight
-
A simple implementation of
FragListBuilder
. - 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(String[], String[], BoundaryScanner) - Constructor for class org.apache.lucene.search.vectorhighlight.SimpleFragmentsBuilder
- SimpleFragmentsBuilder(BoundaryScanner) - Constructor for class org.apache.lucene.search.vectorhighlight.SimpleFragmentsBuilder
- SimpleFSDirectory - Class in org.apache.lucene.store
-
A straightforward implementation of
FSDirectory
using java.io.RandomAccessFile. - SimpleFSDirectory(File) - Constructor for class org.apache.lucene.store.SimpleFSDirectory
-
Create a new SimpleFSDirectory for the named location and
NativeFSLockFactory
. - SimpleFSDirectory(File, LockFactory) - Constructor for class org.apache.lucene.store.SimpleFSDirectory
-
Create a new SimpleFSDirectory for the named location.
- SimpleFSDirectory.SimpleFSIndexInput - Class in org.apache.lucene.store
- SimpleFSDirectory.SimpleFSIndexInput.Descriptor - Class in org.apache.lucene.store
- SimpleFSIndexInput(File, int, int) - Constructor for class org.apache.lucene.store.SimpleFSDirectory.SimpleFSIndexInput
-
Deprecated.please pass resourceDesc
- SimpleFSIndexInput(String, File, int, int) - Constructor for class org.apache.lucene.store.SimpleFSDirectory.SimpleFSIndexInput
- SimpleFSLockFactory - Class in org.apache.lucene.store
-
Implements
LockFactory
usingFile.createNewFile()
. - SimpleFSLockFactory() - Constructor for class org.apache.lucene.store.SimpleFSLockFactory
-
Create a SimpleFSLockFactory instance, with null (unset) lock directory.
- SimpleFSLockFactory(File) - Constructor for class org.apache.lucene.store.SimpleFSLockFactory
-
Instantiate using the provided directory (as a File instance).
- SimpleFSLockFactory(String) - Constructor for class org.apache.lucene.store.SimpleFSLockFactory
-
Instantiate using the provided directory name (String).
- 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() - Constructor for class org.apache.lucene.search.highlight.SimpleHTMLFormatter
-
Default constructor uses HTML: <B> tags to markup terms.
- SimpleHTMLFormatter(String, String) - Constructor for class org.apache.lucene.search.highlight.SimpleHTMLFormatter
- SimpleIntDecoder - Class in org.apache.lucene.util.encoding
-
A simple stream decoder which can decode values encoded with
SimpleIntEncoder
. - SimpleIntDecoder() - Constructor for class org.apache.lucene.util.encoding.SimpleIntDecoder
- SimpleIntEncoder - Class in org.apache.lucene.util.encoding
-
A simple
IntEncoder
, writing an integer as 4 raw bytes. - SimpleIntEncoder() - Constructor for class org.apache.lucene.util.encoding.SimpleIntEncoder
- SimpleLineParser(String[]) - Constructor for class org.apache.lucene.benchmark.byTask.feeds.LineDocSource.SimpleLineParser
- 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
- 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
- SimpleSpanFragmenter - Class in org.apache.lucene.search.highlight
-
Fragmenter
implementation which breaks text up into same-size fragments but does not split upSpans
. - SimpleSpanFragmenter(QueryScorer) - Constructor for class org.apache.lucene.search.highlight.SimpleSpanFragmenter
- SimpleSpanFragmenter(QueryScorer, int) - Constructor for class org.apache.lucene.search.highlight.SimpleSpanFragmenter
- SimpleStringInterner - Class in org.apache.lucene.util
-
Simple lockless and memory barrier free String intern cache that is guaranteed to return the same String instance as String.intern() does.
- SimpleStringInterner(int, int) - Constructor for class org.apache.lucene.util.SimpleStringInterner
- SimpleTerm - Class in org.apache.lucene.queryParser.surround.query
- SimpleTerm(boolean) - Constructor for class org.apache.lucene.queryParser.surround.query.SimpleTerm
- SimpleTerm() - Method in class org.apache.lucene.queryParser.surround.parser.QueryParser
- SimpleTerm.MatchingTermVisitor - Interface in org.apache.lucene.queryParser.surround.query
- SimpleThreeDimensionalTokenSettingsCodec() - Constructor for class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.SimpleThreeDimensionalTokenSettingsCodec
-
Deprecated.
- SIN_45_AS_RADS - Static variable in class org.apache.lucene.spatial.DistanceUtils
-
Deprecated.
- SINGLE_TYPE - Static variable in class org.apache.lucene.analysis.cjk.CJKBigramFilter
-
when we emit a unigram, its then marked as this type
- SingleDocSource - Class in org.apache.lucene.benchmark.byTask.feeds
-
Creates the same document each time
SingleDocSource.getNextDocData(DocData)
is called. - SingleDocSource() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.SingleDocSource
- SingleFragListBuilder - Class in org.apache.lucene.search.vectorhighlight
-
An implementation class of
FragListBuilder
that generates oneFieldFragList.WeightedFragInfo
object. - SingleFragListBuilder() - Constructor for class org.apache.lucene.search.vectorhighlight.SingleFragListBuilder
- 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
- SingleTermEnum - Class in org.apache.lucene.search
-
Subclass of FilteredTermEnum for enumerating a single term.
- SingleTermEnum(IndexReader, Term) - Constructor for class org.apache.lucene.search.SingleTermEnum
-
Creates a new
SingleTermEnum
. - SingleTokenTokenStream - Class in org.apache.lucene.analysis.miscellaneous
-
A
TokenStream
containing a single token. - SingleTokenTokenStream(Token) - Constructor for class org.apache.lucene.analysis.miscellaneous.SingleTokenTokenStream
- sink - Variable in class org.apache.lucene.analysis.ReusableAnalyzerBase.TokenStreamComponents
- SinkFilter() - Constructor for class org.apache.lucene.analysis.TeeSinkTokenFilter.SinkFilter
- SinusoidalProjector - Class in org.apache.lucene.spatial.tier.projections
-
Deprecated.Until we can put in place proper tests and a proper fix.
- SinusoidalProjector() - Constructor for class org.apache.lucene.spatial.tier.projections.SinusoidalProjector
-
Deprecated.
- 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.facet.index.CategoryContainer
-
Get the number of categories in the container.
- size() - Method in interface org.apache.lucene.facet.search.Heap
-
Return the amount of objects currently in the heap
- size() - Method in interface org.apache.lucene.facet.search.ScoredDocIDs
-
Returns the number of scored documents.
- size() - Method in class org.apache.lucene.facet.taxonomy.writercache.cl2o.CollisionMap
- size() - Method in class org.apache.lucene.index.FieldInfos
- size() - Method in class org.apache.lucene.index.SegmentInfos
- size() - Method in interface org.apache.lucene.index.TermFreqVector
- size() - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorPipeline
- size() - Method in class org.apache.lucene.queryParser.surround.query.SpanNearClauseFactory
- size() - Method in class org.apache.lucene.search.grouping.SentinelIntSet
- size() - Method in class org.apache.lucene.search.QueryTermVector
- size() - Method in class org.apache.lucene.search.suggest.BytesRefList
-
Returns the current size of this
BytesRefList
- size() - Method in class org.apache.lucene.store.instantiated.InstantiatedTermFreqVector
- size() - Method in class org.apache.lucene.util.BitVector
-
Returns the number of bits in this vector.
- size() - Method in class org.apache.lucene.util.BytesRefHash
-
Returns the number of
BytesRef
values in thisBytesRefHash
. - size() - Method in class org.apache.lucene.util.collections.ArrayHashMap
-
Returns number of pairs currently in the map.
- size() - Method in class org.apache.lucene.util.collections.FloatToObjectMap
- size() - Method in class org.apache.lucene.util.collections.IntArray
-
Return the size of the Array.
- size() - Method in class org.apache.lucene.util.collections.IntHashSet
- size() - Method in class org.apache.lucene.util.collections.IntToDoubleMap
- size() - Method in class org.apache.lucene.util.collections.IntToIntMap
- size() - Method in class org.apache.lucene.util.collections.IntToObjectMap
- size() - Method in class org.apache.lucene.util.collections.ObjectToFloatMap
- size() - Method in class org.apache.lucene.util.collections.ObjectToIntMap
- size() - Method in class org.apache.lucene.util.MapBackedSet
- size() - Method in class org.apache.lucene.util.OpenBitSet
-
Returns the current capacity of this set.
- size() - Method in class org.apache.lucene.util.packed.GrowableWriter
- size() - Method in interface org.apache.lucene.util.packed.PackedInts.Reader
- size() - Method in class org.apache.lucene.util.packed.PackedInts.ReaderImpl
- 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.ScorerDocQueue
-
Deprecated.Returns the number of scorers currently stored in the ScorerDocQueue.
- size() - Method in class org.apache.lucene.util.SortedVIntList
- size() - Method in class org.apache.lucene.util.WeakIdentityMap
- size(SegmentInfo) - Method in class org.apache.lucene.index.BalancedSegmentMergePolicy
-
Deprecated.
- size(SegmentInfo) - Method in class org.apache.lucene.index.LogByteSizeMergePolicy
- size(SegmentInfo) - Method in class org.apache.lucene.index.LogDocMergePolicy
- size(SegmentInfo) - Method in class org.apache.lucene.index.LogMergePolicy
- SIZE - org.apache.lucene.document.FieldSelectorResult
-
Expert: Load the size of this
Field
rather than its value. - SIZE_AND_BREAK - org.apache.lucene.document.FieldSelectorResult
-
Expert: Like
FieldSelectorResult.SIZE
but immediately break from the field loading loop, i.e., stop loading further fields, after the size is loaded - sizeBytes(SegmentInfo) - Method in class org.apache.lucene.index.LogMergePolicy
- sizeDocs(SegmentInfo) - Method in class org.apache.lucene.index.LogMergePolicy
- sizeInBytes - Variable in class org.apache.lucene.store.RAMDirectory
- sizeInBytes - Variable in class org.apache.lucene.store.RAMFile
- sizeInBytes() - Method in class org.apache.lucene.store.MockDirectoryWrapper
- sizeInBytes() - Method in class org.apache.lucene.store.NRTCachingDirectory
-
Returns how many bytes are being used by the RAMDirectory cache
- sizeInBytes() - Method in class org.apache.lucene.store.RAMDirectory
-
Return total size in bytes of all files in this directory.
- sizeInBytes() - Method in class org.apache.lucene.store.RAMOutputStream
-
Returns byte usage of all buffers.
- sizeInBytes() - Method in class org.apache.lucene.util.fst.FST
-
Returns bytes used to represent the FST
- sizeInBytes(boolean) - Method in class org.apache.lucene.index.SegmentInfo
-
Returns total size in bytes of all of files used by this segment (if
includeDocStores
is true), or the size of all files except the store files otherwise. - sizeMB - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
-
Net size (MB) of the files referenced by this segment.
- sizeOf(boolean[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
-
Returns the size in bytes of the boolean[] object.
- sizeOf(byte[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
-
Returns the size in bytes of the byte[] object.
- sizeOf(char[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
-
Returns the size in bytes of the char[] object.
- sizeOf(double[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
-
Returns the size in bytes of the double[] object.
- sizeOf(float[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
-
Returns the size in bytes of the float[] object.
- sizeOf(int[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
-
Returns the size in bytes of the int[] object.
- sizeOf(long[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
-
Returns the size in bytes of the long[] object.
- sizeOf(short[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
-
Returns the size in bytes of the short[] object.
- sizeOf(Object) - Static method in class org.apache.lucene.util.RamUsageEstimator
-
Estimates the RAM usage by the given object.
- sizeOfMap() - Method in class org.apache.lucene.facet.taxonomy.writercache.cl2o.CompactLabelToOrdinal
- skip(long) - Method in class org.apache.lucene.benchmark.byTask.utils.StringBuilderReader
- skipBytes(int) - Method in class org.apache.lucene.store.ByteArrayDataInput
- skipChars(int) - Method in class org.apache.lucene.store.IndexInput
-
Deprecated.this method operates on old "modified utf8" encoded strings
- skipChars(int) - Method in class org.apache.lucene.store.MockIndexInputWrapper
- skipInterval - Variable in class org.apache.lucene.index.SegmentWriteState
-
Expert: The fraction of TermDocs entries stored in skip tables, used to accelerate
TermDocs.skipTo(int)
. - skipTo(int) - Method in interface org.apache.lucene.facet.search.CategoryListIterator
-
Skips forward to document docId.
- skipTo(int) - Method in class org.apache.lucene.facet.search.PayloadIntDecodingIterator
- skipTo(int) - Method in class org.apache.lucene.facet.util.MultiCategoryListIterator
-
Fails only if skipTo on all the provided iterators returned
false
- skipTo(int) - Method in class org.apache.lucene.index.AbstractAllTermDocs
- skipTo(int) - Method in class org.apache.lucene.index.FilterIndexReader.FilterTermDocs
- skipTo(int) - Method in class org.apache.lucene.index.MultipleTermPositions
- skipTo(int) - Method in interface org.apache.lucene.index.TermDocs
-
Skips entries to the first beyond the current whose document number is greater than or equal to target.
- skipTo(int) - Method in class org.apache.lucene.search.spans.NearSpansOrdered
- skipTo(int) - Method in class org.apache.lucene.search.spans.NearSpansUnordered
- skipTo(int) - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery.PositionCheckSpan
- skipTo(int) - Method in class org.apache.lucene.search.spans.Spans
-
Skips to the first match beyond the current, whose document number is greater than or equal to target.
- skipTo(int) - Method in class org.apache.lucene.search.spans.TermSpans
- skipTo(int) - Method in class org.apache.lucene.store.instantiated.InstantiatedTermDocs
-
Skips entries to the first beyond the current whose document number is greater than or equal to target.
- skipTo(int) - Method in class org.apache.lucene.store.instantiated.InstantiatedTermPositions
-
Skips entries to the first beyond the current whose document number is greater than or equal to
target . - 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_from(String) - Method in class org.tartarus.snowball.SnowballProgram
-
Deprecated.for binary back compat. Will be removed in Lucene 4.0
- slice_from(StringBuilder) - Method in class org.tartarus.snowball.SnowballProgram
-
Deprecated.for binary back compat. Will be removed in Lucene 4.0
- slice_to(StringBuilder) - Method in class org.tartarus.snowball.SnowballProgram
- slop - Variable in class org.apache.lucene.search.spans.SpanNearQuery
- sloppyFreq(int) - Method in class org.apache.lucene.search.DefaultSimilarity
-
Implemented as
1 / (distance + 1)
. - sloppyFreq(int) - Method in class org.apache.lucene.search.Similarity
-
Computes the amount of a sloppy phrase match, based on an edit distance.
- sloppyFreq(int) - Method in class org.apache.lucene.search.SimilarityDelegator
-
Deprecated.
- SlopQueryNode - Class in org.apache.lucene.queryParser.core.nodes
-
A
SlopQueryNode
represents phrase query with a slop. - SlopQueryNode(QueryNode, int) - Constructor for class org.apache.lucene.queryParser.core.nodes.SlopQueryNode
- SlopQueryNodeBuilder - Class in org.apache.lucene.queryParser.standard.builders
-
This builder basically reads the
Query
object set on theSlopQueryNode
child usingQueryTreeBuilder.QUERY_TREE_BUILDER_TAGID
and applies the slop value defined in theSlopQueryNode
. - SlopQueryNodeBuilder() - Constructor for class org.apache.lucene.queryParser.standard.builders.SlopQueryNodeBuilder
- slot - Variable in class org.apache.lucene.search.FieldValueHitQueue.Entry
- SlowMultiReaderWrapper - Class in org.apache.lucene.index
-
Acts like Lucene 4.x's SlowMultiReaderWrapper for testing of top-level MultiTermEnum, MultiTermDocs, ...
- SlowMultiReaderWrapper(IndexReader) - Constructor for class org.apache.lucene.index.SlowMultiReaderWrapper
- SmallFloat - Class in org.apache.lucene.util
-
Floating point numbers smaller than 32 bits.
- SmallFloat() - Constructor for class org.apache.lucene.util.SmallFloat
- SmartChineseAnalyzer - Class in org.apache.lucene.analysis.cn.smart
-
SmartChineseAnalyzer is an analyzer for Chinese or mixed Chinese-English text.
- SmartChineseAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.cn.smart.SmartChineseAnalyzer
-
Create a new SmartChineseAnalyzer, using the default stopword list.
- SmartChineseAnalyzer(Version, boolean) - Constructor for class org.apache.lucene.analysis.cn.smart.SmartChineseAnalyzer
-
Create a new SmartChineseAnalyzer, optionally using the default stopword list.
- SmartChineseAnalyzer(Version, Set) - Constructor for class org.apache.lucene.analysis.cn.smart.SmartChineseAnalyzer
-
Create a new SmartChineseAnalyzer, using the provided
Set
of stopwords. - SmartRandom - Class in org.apache.lucene.util
-
A random that tracks if its been initialized properly, and throws an exception if it hasn't.
- smokeTestSearcher(IndexSearcher) - Method in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
- snapshot(String) - Method in class org.apache.lucene.index.PersistentSnapshotDeletionPolicy
-
Snapshots the last commit using the given ID.
- snapshot(String) - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
-
Snapshots the last commit.
- SnapshotCommitPoint(IndexCommit) - Constructor for class org.apache.lucene.index.SnapshotDeletionPolicy.SnapshotCommitPoint
- SnapshotDeletionPolicy - Class in org.apache.lucene.index
-
An
IndexDeletionPolicy
that wraps around any otherIndexDeletionPolicy
and adds the ability to hold and later release snapshots of an index. - SnapshotDeletionPolicy(IndexDeletionPolicy) - Constructor for class org.apache.lucene.index.SnapshotDeletionPolicy
- SnapshotDeletionPolicy(IndexDeletionPolicy, Map<String, String>) - Constructor for class org.apache.lucene.index.SnapshotDeletionPolicy
-
SnapshotDeletionPolicy
wraps anotherIndexDeletionPolicy
to enable flexible snapshotting. - SnapshotDeletionPolicy.SnapshotCommitPoint - Class in org.apache.lucene.index
- SnowballAnalyzer - Class in org.apache.lucene.analysis.snowball
-
Deprecated.Use the language-specific analyzer in contrib/analyzers instead. This analyzer will be removed in Lucene 5.0
- SnowballAnalyzer(Version, String) - Constructor for class org.apache.lucene.analysis.snowball.SnowballAnalyzer
-
Deprecated.Builds the named analyzer with no stop words.
- SnowballAnalyzer(Version, String, String[]) - Constructor for class org.apache.lucene.analysis.snowball.SnowballAnalyzer
-
Deprecated.Use
SnowballAnalyzer(Version, String, Set)
instead. - SnowballAnalyzer(Version, String, Set<?>) - Constructor for class org.apache.lucene.analysis.snowball.SnowballAnalyzer
-
Deprecated.Builds the named analyzer with the given stop words.
- SnowballFilter - Class in org.apache.lucene.analysis.snowball
-
A filter that stems words using a Snowball-generated stemmer.
- SnowballFilter(TokenStream, String) - Constructor for class org.apache.lucene.analysis.snowball.SnowballFilter
-
Construct the named stemming filter.
- SnowballFilter(TokenStream, SnowballProgram) - Constructor for class org.apache.lucene.analysis.snowball.SnowballFilter
- SnowballProgram - Class in org.tartarus.snowball
-
This is the rev 502 of the Snowball SVN trunk, but modified: made abstract and introduced abstract method stem to avoid expensive reflection in filter class.
- SnowballProgram() - Constructor for class org.tartarus.snowball.SnowballProgram
- 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
- SOMETIMES - org.apache.lucene.store.MockDirectoryWrapper.Throttling
-
sometimes (2% of the time) emulate a slow hard disk.
- sort() - Method in class org.apache.lucene.util.collections.IntArray
-
Sorts the data.
- sort(File, File) - Method in class org.apache.lucene.search.suggest.fst.Sort
-
Sort input to output, explicit hint for the buffer size.
- sort(Comparator<BytesRef>) - Method in class org.apache.lucene.util.BytesRefHash
-
Returns the values array sorted by the referenced byte values.
- sort(Directory, Directory, String) - Method in class org.apache.lucene.index.IndexSorter
- Sort - Class in org.apache.lucene.search
-
Encapsulates sort criteria for returned hits.
- Sort - Class in org.apache.lucene.search.suggest.fst
-
On-disk sorting of byte arrays.
- Sort() - Constructor for class org.apache.lucene.search.Sort
-
Sorts by computed relevance.
- Sort() - Constructor for class org.apache.lucene.search.suggest.fst.Sort
-
Defaults constructor.
- Sort(Comparator<BytesRef>) - Constructor for class org.apache.lucene.search.suggest.fst.Sort
- Sort(Comparator<BytesRef>, Sort.BufferSize, File, int) - Constructor for class org.apache.lucene.search.suggest.fst.Sort
-
All-details constructor.
- 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
-
Sorts in succession by the criteria in each SortField.
- Sort.BufferSize - Class in org.apache.lucene.search.suggest.fst
-
A bit more descriptive unit for constructors.
- Sort.ByteSequencesReader - Class in org.apache.lucene.search.suggest.fst
-
Utility class to read length-prefixed byte[] entries from an input.
- Sort.ByteSequencesWriter - Class in org.apache.lucene.search.suggest.fst
-
Utility class to emit length-prefixed byte[] entries to an output stream for sorting.
- Sort.SortInfo - Class in org.apache.lucene.search.suggest.fst
-
Sort info (debugging mostly).
- sortableIntToFloat(int) - Static method in class org.apache.lucene.util.NumericUtils
-
Converts a sortable
int
back to afloat
. - sortableLongToDouble(long) - Static method in class org.apache.lucene.util.NumericUtils
-
Converts a sortable
long
back to adouble
. - 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
- sortByTotalTermFreq(IndexReader, TermStats[]) - Static method in class org.apache.lucene.misc.HighFreqTerms
-
Takes array of TermStats.
- SortedTermFreqIteratorWrapper - Class in org.apache.lucene.search.suggest
-
This wrapper buffers incoming elements and makes sure they are sorted based on given comparator.
- SortedTermFreqIteratorWrapper(TermFreqIterator, Comparator<BytesRef>) - Constructor for class org.apache.lucene.search.suggest.SortedTermFreqIteratorWrapper
- SortedTermFreqIteratorWrapper(TermFreqIterator, Comparator<BytesRef>, boolean) - Constructor for class org.apache.lucene.search.suggest.SortedTermFreqIteratorWrapper
- SortedTermVectorMapper - Class in org.apache.lucene.index
-
Store a sorted collection of
TermVectorEntry
s. - SortedTermVectorMapper(boolean, boolean, Comparator<TermVectorEntry>) - Constructor for class org.apache.lucene.index.SortedTermVectorMapper
- SortedTermVectorMapper(Comparator<TermVectorEntry>) - Constructor for class org.apache.lucene.index.SortedTermVectorMapper
- SortedVIntList - Class in org.apache.lucene.util
-
Stores and iterate on sorted integers in compressed form in RAM.
- SortedVIntList(int...) - Constructor for class org.apache.lucene.util.SortedVIntList
-
Create a SortedVIntList from all elements of an array of integers.
- SortedVIntList(int[], int) - Constructor for class org.apache.lucene.util.SortedVIntList
-
Create a SortedVIntList from an array of integers.
- SortedVIntList(BitSet) - Constructor for class org.apache.lucene.util.SortedVIntList
-
Create a SortedVIntList from a BitSet.
- SortedVIntList(DocIdSetIterator) - Constructor for class org.apache.lucene.util.SortedVIntList
-
Create a SortedVIntList.
- SorterTemplate - Class in org.apache.lucene.util
-
This class was inspired by CGLIB, but provides a better QuickSort algorithm without additional InsertionSort at the end.
- SorterTemplate() - Constructor for class org.apache.lucene.util.SorterTemplate
- SortField - Class in org.apache.lucene.search
-
Stores information about how to sort documents by terms in an individual field.
- SortField(String, int) - 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, int, 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, Locale) - Constructor for class org.apache.lucene.search.SortField
-
Creates a sort by terms in the given field sorted according to the given locale.
- SortField(String, Locale, boolean) - Constructor for class org.apache.lucene.search.SortField
-
Creates a sort, possibly in reverse, by terms in the given field sorted according to the given locale.
- SortField(String, FieldCache.Parser) - Constructor for class org.apache.lucene.search.SortField
-
Creates a sort by terms in the given field, parsed to numeric values using a custom
FieldCache.Parser
. - SortField(String, FieldCache.Parser, boolean) - Constructor for class org.apache.lucene.search.SortField
-
Creates a sort, possibly in reverse, by terms in the given field, parsed to numeric values using a custom
FieldCache.Parser
. - 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.
- SortInfo() - Constructor for class org.apache.lucene.search.suggest.fst.Sort.SortInfo
- SortingIntEncoder - Class in org.apache.lucene.util.encoding
-
An
IntEncoderFilter
which sorts the values to encode in ascending order before encoding them. - SortingIntEncoder(IntEncoder) - Constructor for class org.apache.lucene.util.encoding.SortingIntEncoder
-
Initializes with the given encoder.
- sortKeys(JaspellTernarySearchTrie.TSTNode, int) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Returns keys sorted in alphabetical order.
- sortPartition(int) - Method in class org.apache.lucene.search.suggest.fst.Sort
-
Sort a single partition in-memory.
- sortTime - Variable in class org.apache.lucene.search.suggest.fst.Sort.SortInfo
- sortValues - Variable in class org.apache.lucene.search.grouping.SearchGroup
-
The sort values used during sorting.
- source - Variable in class org.apache.lucene.analysis.ReusableAnalyzerBase.TokenStreamComponents
- source - Variable in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
- 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.std31.StandardTokenizerImpl31
-
Deprecated.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.std31.UAX29URLEmailTokenizerImpl31
-
Deprecated.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.std34.UAX29URLEmailTokenizerImpl34
-
Deprecated.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.UAX29URLEmailTokenizer
-
Deprecated.use
UAX29URLEmailTokenizer.TOKEN_TYPES
instead - 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.).
- SOUTHEAST_ASIAN - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
- SOUTHEAST_ASIAN - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
- SP - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
RegularExpression Id.
- Space - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
RegularExpression Id.
- SPACE - Static variable in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
- 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.
- SpanBuilderBase - Class in org.apache.lucene.xmlparser.builders
- SpanBuilderBase() - Constructor for class org.apache.lucene.xmlparser.builders.SpanBuilderBase
- SpanFilter - Class in org.apache.lucene.search
-
Abstract base class providing a mechanism to restrict searches to a subset of an index and also maintains and returns position information.
- SpanFilter() - Constructor for class org.apache.lucene.search.SpanFilter
- SpanFilterResult - Class in org.apache.lucene.search
-
The results of a SpanQueryFilter.
- SpanFilterResult(DocIdSet, List<SpanFilterResult.PositionInfo>) - Constructor for class org.apache.lucene.search.SpanFilterResult
- SpanFilterResult.PositionInfo - Class in org.apache.lucene.search
- SpanFilterResult.StartEnd - Class in org.apache.lucene.search
- SpanFirstBuilder - Class in org.apache.lucene.xmlparser.builders
- SpanFirstBuilder(SpanQueryBuilder) - Constructor for class org.apache.lucene.xmlparser.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 toend
. - 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
-
Analyzer
for Spanish. - SpanishAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.es.SpanishAnalyzer
-
Builds an analyzer with the default stop words:
SpanishAnalyzer.DEFAULT_STOPWORD_FILE
. - SpanishAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.es.SpanishAnalyzer
-
Builds an analyzer with the given stop words.
- SpanishAnalyzer(Version, Set<?>, Set<?>) - 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
-
A
TokenFilter
that appliesSpanishLightStemmer
to stem Spanish words. - SpanishLightStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.es.SpanishLightStemFilter
- 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
-
Generated class implementing code 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
-
Wraps any
MultiTermQuery
as aSpanQuery
, so it can be nested within other SpanQuery classes. - SpanMultiTermQueryWrapper(Q) - Constructor for class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper
-
Create a new SpanMultiTermQueryWrapper.
- SpanMultiTermQueryWrapper.SpanRewriteMethod - Class in org.apache.lucene.search.spans
-
Abstract class that defines how the query is rewritten.
- SpanMultiTermQueryWrapper.TopTermsSpanBooleanQueryRewrite - Class in org.apache.lucene.search.spans
-
A rewrite method that first translates each term into a SpanTermQuery in a
BooleanClause.Occur.SHOULD
clause in a BooleanQuery, and keeps the scores as computed by the query. - SpanNearBuilder - Class in org.apache.lucene.xmlparser.builders
- SpanNearBuilder(SpanQueryBuilder) - Constructor for class org.apache.lucene.xmlparser.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
- SpanNearPayloadCheckQuery - Class in org.apache.lucene.search.spans
-
Only return those matches that have a specific payload at the given position.
- SpanNearPayloadCheckQuery(SpanNearQuery, Collection<byte[]>) - Constructor for class org.apache.lucene.search.spans.SpanNearPayloadCheckQuery
- SpanNearQuery - Class in org.apache.lucene.search.spans
-
Matches spans which are near one another.
- SpanNearQuery(SpanQuery[], int, boolean) - Constructor for class org.apache.lucene.search.spans.SpanNearQuery
-
Construct a SpanNearQuery.
- SpanNearQuery(SpanQuery[], int, boolean, boolean) - Constructor for class org.apache.lucene.search.spans.SpanNearQuery
- SpanNotBuilder - Class in org.apache.lucene.xmlparser.builders
- SpanNotBuilder(SpanQueryBuilder) - Constructor for class org.apache.lucene.xmlparser.builders.SpanNotBuilder
- SpanNotQuery - Class in org.apache.lucene.search.spans
-
Removes matches which overlap with 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 fromexclude
. - SpanOrBuilder - Class in org.apache.lucene.xmlparser.builders
- SpanOrBuilder(SpanQueryBuilder) - Constructor for class org.apache.lucene.xmlparser.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.
- SpanOrTermsBuilder - Class in org.apache.lucene.xmlparser.builders
- SpanOrTermsBuilder(Analyzer) - Constructor for class org.apache.lucene.xmlparser.builders.SpanOrTermsBuilder
- SpanPayloadCheckQuery - Class in org.apache.lucene.search.spans
-
Only return those matches that have a specific payload at the given position.
- SpanPayloadCheckQuery(SpanQuery, Collection<byte[]>) - Constructor for class org.apache.lucene.search.spans.SpanPayloadCheckQuery
- 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.AcceptStatus - Enum in org.apache.lucene.search.spans
-
Return value if the match should be accepted
YES
, rejectedNO
, or rejected and enumeration should advance to the next documentNO_AND_ADVANCE
. - SpanPositionCheckQuery.PositionCheckSpan - Class in org.apache.lucene.search.spans
- SpanPositionRangeQuery - Class in org.apache.lucene.search.spans
-
Checks to see if the
SpanPositionCheckQuery.getMatch()
lies between a start and end position - SpanPositionRangeQuery(SpanQuery, int, int) - Constructor for class org.apache.lucene.search.spans.SpanPositionRangeQuery
- SpanQuery - Class in org.apache.lucene.search.spans
-
Base class for span-based queries.
- SpanQuery() - Constructor for class org.apache.lucene.search.spans.SpanQuery
- SpanQueryBuilder - Interface in org.apache.lucene.xmlparser.builders
- SpanQueryBuilderFactory - Class in org.apache.lucene.xmlparser.builders
- SpanQueryBuilderFactory() - Constructor for class org.apache.lucene.xmlparser.builders.SpanQueryBuilderFactory
- SpanQueryFilter - Class in org.apache.lucene.search
-
Constrains search results to only match those which also match a provided query.
- SpanQueryFilter() - Constructor for class org.apache.lucene.search.SpanQueryFilter
- SpanQueryFilter(SpanQuery) - Constructor for class org.apache.lucene.search.SpanQueryFilter
-
Constructs a filter which only matches documents matching
query
. - SpanRegexQuery - Class in org.apache.lucene.search.regex
-
Deprecated.Use
new SpanMultiTermQueryWrapper<RegexQuery>(new RegexQuery())
instead. This query will be removed in Lucene 4.0 - SpanRegexQuery(Term) - Constructor for class org.apache.lucene.search.regex.SpanRegexQuery
-
Deprecated.
- SpanRewriteMethod() - Constructor for class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper.SpanRewriteMethod
- spans - Variable in class org.apache.lucene.search.spans.SpanScorer
- Spans - Class in org.apache.lucene.search.spans
-
Expert: an enumeration of span matches.
- Spans() - Constructor for class org.apache.lucene.search.spans.Spans
- SpanScorer - Class in org.apache.lucene.search.spans
-
Public for extension only.
- SpanScorer(Spans, Weight, Similarity, byte[]) - Constructor for class org.apache.lucene.search.spans.SpanScorer
- SpanTermBuilder - Class in org.apache.lucene.xmlparser.builders
- SpanTermBuilder() - Constructor for class org.apache.lucene.xmlparser.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.
- SpanWeight - Class in org.apache.lucene.search.spans
-
Expert-only.
- SpanWeight(SpanQuery, Searcher) - Constructor for class org.apache.lucene.search.spans.SpanWeight
- specialToken - Variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.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.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.
- specialToken - Variable in class org.apache.lucene.queryParser.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) - Constructor for class org.apache.lucene.search.spell.SpellChecker
-
Use the given directory as a spell checker index with a
LevensteinDistance
as the defaultStringDistance
. - SpellChecker(Directory, StringDistance) - Constructor for class org.apache.lucene.search.spell.SpellChecker
-
Use the given directory as a spell checker index.
- 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 givenComparator
for sorting the results. - split() - Method in class org.apache.lucene.index.PKIndexSplitter
- split(File, String[]) - Method in class org.apache.lucene.index.IndexSplitter
- split(IndexReader, Directory[], boolean) - Method in class org.apache.lucene.index.MultiPassIndexSplitter
-
Deprecated.use
MultiPassIndexSplitter.split(Version, IndexReader, Directory[], boolean)
instead. This method will be removed in Lucene 4.0. - split(Version, IndexReader, Directory[], boolean) - Method in class org.apache.lucene.index.MultiPassIndexSplitter
-
Split source index into multiple parts.
- splitchar - Variable in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie.TSTNode
-
The char used in the split.
- 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
. - splitIntRange(NumericUtils.IntRangeBuilder, int, int, int) - Static method in class org.apache.lucene.util.NumericUtils
-
Expert: Splits an int range recursively.
- splitLongRange(NumericUtils.LongRangeBuilder, int, long, long) - Static method in class org.apache.lucene.util.NumericUtils
-
Expert: Splits a long range recursively.
- squaredEuclideanDistance(double[], double[]) - Static method in class org.apache.lucene.spatial.DistanceUtils
-
Deprecated.The square of the Euclidean Distance.
- SrndPrefixQuery - Class in org.apache.lucene.queryParser.surround.query
- SrndPrefixQuery(String, boolean, char) - Constructor for class org.apache.lucene.queryParser.surround.query.SrndPrefixQuery
- SrndQuery - Class in org.apache.lucene.queryParser.surround.query
- SrndQuery() - Constructor for class org.apache.lucene.queryParser.surround.query.SrndQuery
- SrndTermQuery - Class in org.apache.lucene.queryParser.surround.query
- SrndTermQuery(String, boolean) - Constructor for class org.apache.lucene.queryParser.surround.query.SrndTermQuery
- SrndTruncQuery - Class in org.apache.lucene.queryParser.surround.query
- SrndTruncQuery(String, char, char) - Constructor for class org.apache.lucene.queryParser.surround.query.SrndTruncQuery
- staleFiles - Variable in class org.apache.lucene.store.FSDirectory
- StaleReaderException - Exception in org.apache.lucene.index
-
This exception is thrown when an
IndexReader
tries to make changes to the index (viaIndexReader.deleteDocument(int)
,IndexReader.undeleteAll()
orIndexReader.setNorm(int, java.lang.String, byte)
) but changes have already been committed to the index since this reader was instantiated. - StaleReaderException(String) - Constructor for exception org.apache.lucene.index.StaleReaderException
- StandardAnalyzer - Class in org.apache.lucene.analysis.standard
-
Filters
StandardTokenizer
withStandardFilter
,LowerCaseFilter
andStopFilter
, using a list of English stop words. - StandardAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.standard.StandardAnalyzer
-
Builds an analyzer with the default stop words (
StandardAnalyzer.STOP_WORDS_SET
). - StandardAnalyzer(Version, File) - Constructor for class org.apache.lucene.analysis.standard.StandardAnalyzer
-
Deprecated.Use
StandardAnalyzer(Version, Reader)
instead. - StandardAnalyzer(Version, Reader) - Constructor for class org.apache.lucene.analysis.standard.StandardAnalyzer
-
Builds an analyzer with the stop words from the given reader.
- StandardAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.standard.StandardAnalyzer
-
Builds an analyzer with the given stop words.
- StandardBooleanQueryNode - Class in org.apache.lucene.queryParser.standard.nodes
-
A
StandardBooleanQueryNode
has the same behavior asBooleanQueryNode
. - StandardBooleanQueryNode(List<QueryNode>, boolean) - Constructor for class org.apache.lucene.queryParser.standard.nodes.StandardBooleanQueryNode
- StandardBooleanQueryNodeBuilder - Class in org.apache.lucene.queryParser.standard.builders
-
This builder does the same as the
BooleanQueryNodeBuilder
, but this considers if the builtBooleanQuery
should have its coord disabled or not. - StandardBooleanQueryNodeBuilder() - Constructor for class org.apache.lucene.queryParser.standard.builders.StandardBooleanQueryNodeBuilder
- StandardFacetsAccumulator - Class in org.apache.lucene.facet.search
-
Standard implementation for
FacetsAccumulator
, utilizing partitions to save on memory. - StandardFacetsAccumulator(FacetSearchParams, IndexReader, TaxonomyReader) - Constructor for class org.apache.lucene.facet.search.StandardFacetsAccumulator
- StandardFacetsAccumulator(FacetSearchParams, IndexReader, TaxonomyReader, IntArrayAllocator, FloatArrayAllocator) - Constructor for class org.apache.lucene.facet.search.StandardFacetsAccumulator
- StandardFilter - Class in org.apache.lucene.analysis.standard
-
Normalizes tokens extracted with
StandardTokenizer
. - StandardFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.standard.StandardFilter
-
Deprecated.Use
StandardFilter(Version, TokenStream)
instead. - StandardFilter(Version, TokenStream) - Constructor for class org.apache.lucene.analysis.standard.StandardFilter
- StandardQueryBuilder - Interface in org.apache.lucene.queryParser.standard.builders
- StandardQueryConfigHandler - Class in org.apache.lucene.queryParser.standard.config
-
This query configuration handler is used for almost every processor defined in the
StandardQueryNodeProcessorPipeline
processor pipeline. - StandardQueryConfigHandler() - Constructor for class org.apache.lucene.queryParser.standard.config.StandardQueryConfigHandler
- StandardQueryConfigHandler.ConfigurationKeys - Class in org.apache.lucene.queryParser.standard.config
- StandardQueryConfigHandler.Operator - Enum in org.apache.lucene.queryParser.standard.config
- StandardQueryNodeProcessorPipeline - Class in org.apache.lucene.queryParser.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.standard.processors.StandardQueryNodeProcessorPipeline
- StandardQueryParser - Class in org.apache.lucene.queryParser.standard
-
This class is a helper that enables users to easily use the Lucene query parser.
- StandardQueryParser() - Constructor for class org.apache.lucene.queryParser.standard.StandardQueryParser
-
Constructs a
StandardQueryParser
object. - StandardQueryParser(Analyzer) - Constructor for class org.apache.lucene.queryParser.standard.StandardQueryParser
-
Constructs a
StandardQueryParser
object and sets anAnalyzer
to it. - StandardQueryTreeBuilder - Class in org.apache.lucene.queryParser.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.standard.builders.StandardQueryTreeBuilder
- StandardSyntaxParser - Class in org.apache.lucene.queryParser.standard.parser
- StandardSyntaxParser() - Constructor for class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParser
- StandardSyntaxParser(InputStream) - Constructor for class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParser
-
Constructor with InputStream.
- StandardSyntaxParser(InputStream, String) - Constructor for class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParser
-
Constructor with InputStream and supplied encoding
- StandardSyntaxParser(Reader) - Constructor for class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParser
-
Constructor.
- StandardSyntaxParser(StandardSyntaxParserTokenManager) - Constructor for class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParser
-
Constructor with generated Token Manager.
- StandardSyntaxParserConstants - Interface in org.apache.lucene.queryParser.standard.parser
-
Token literal values and constants.
- StandardSyntaxParserTokenManager - Class in org.apache.lucene.queryParser.standard.parser
-
Token Manager.
- StandardSyntaxParserTokenManager(JavaCharStream) - Constructor for class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserTokenManager
-
Constructor.
- StandardSyntaxParserTokenManager(JavaCharStream, int) - Constructor for class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserTokenManager
-
Constructor.
- StandardTokenizer - Class in org.apache.lucene.analysis.standard
-
A grammar-based tokenizer constructed with JFlex.
- StandardTokenizer(Version, Reader) - Constructor for class org.apache.lucene.analysis.standard.StandardTokenizer
-
Creates a new instance of the
StandardTokenizer
. - StandardTokenizer(Version, AttributeSource.AttributeFactory, Reader) - Constructor for class org.apache.lucene.analysis.standard.StandardTokenizer
-
Creates a new StandardTokenizer with a given
AttributeSource.AttributeFactory
- StandardTokenizer(Version, AttributeSource, Reader) - Constructor for class org.apache.lucene.analysis.standard.StandardTokenizer
-
Creates a new StandardTokenizer with a given
AttributeSource
. - StandardTokenizerImpl - Class in org.apache.lucene.analysis.standard
-
This class implements Word Break rules from the Unicode Text Segmentation algorithm, as specified in Unicode Standard Annex #29
- StandardTokenizerImpl(InputStream) - Constructor for class org.apache.lucene.analysis.standard.StandardTokenizerImpl
-
Creates a new scanner.
- StandardTokenizerImpl(Reader) - Constructor for class org.apache.lucene.analysis.standard.StandardTokenizerImpl
-
Creates a new scanner There is also a java.io.InputStream version of this constructor.
- StandardTokenizerImpl31 - Class in org.apache.lucene.analysis.standard.std31
-
Deprecated.This class is only for exact backwards compatibility
- StandardTokenizerImpl31(InputStream) - Constructor for class org.apache.lucene.analysis.standard.std31.StandardTokenizerImpl31
-
Deprecated.Creates a new scanner.
- StandardTokenizerImpl31(Reader) - Constructor for class org.apache.lucene.analysis.standard.std31.StandardTokenizerImpl31
-
Deprecated.Creates a new scanner There is also a java.io.InputStream version of this constructor.
- StandardTokenizerInterface - Interface in org.apache.lucene.analysis.standard
-
Internal interface for supporting versioned grammars.
- STAR - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
-
RegularExpression Id.
- start - Variable in class org.apache.lucene.search.spans.SpanPositionRangeQuery
- start() - Method in class org.apache.lucene.search.spans.NearSpansOrdered
- start() - Method in class org.apache.lucene.search.spans.NearSpansUnordered
- start() - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery.PositionCheckSpan
- start() - Method in class org.apache.lucene.search.spans.Spans
-
Returns the start position of the current match.
- start() - Method in class org.apache.lucene.search.spans.TermSpans
- 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_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)
- startElement(String, String, String, Attributes) - Method in class org.apache.lucene.analysis.compound.hyphenation.PatternParser
- StartEnd(int, int) - Constructor for class org.apache.lucene.search.SpanFilterResult.StartEnd
- 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.
- startingFilter - Variable in class org.apache.lucene.spatial.tier.DistanceFilter
-
Deprecated.
- 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 class org.apache.lucene.analysis.Token
-
Returns this Token's starting offset, the position of the first character corresponding to this token in the source text.
- 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
-
Returns this Token's starting offset, the position of the first character corresponding to this token in the source text.
- starts - Variable in class org.apache.lucene.index.MultiReader
- 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(BytesRef) - Method in class org.apache.lucene.util.BytesRef
- startTest(Test) - Method in class org.apache.lucene.util.LuceneJUnitResultFormatter
-
A test started.
- startTestSuite(JUnitTest) - Method in class org.apache.lucene.util.LuceneJUnitResultFormatter
-
The whole testsuite started.
- State() - Constructor for class org.apache.lucene.util.AttributeSource.State
- staticFlag - Static variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
-
Whether parser is static.
- staticFlag - Static variable in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
-
Whether parser is static.
- Status() - Constructor for class org.apache.lucene.index.CheckIndex.Status
- 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.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(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.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(char[], int) - Method in class org.apache.lucene.analysis.el.GreekStemmer
- 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) - Method in class org.apache.lucene.analysis.hunspell.HunspellStemmer
-
Find the stem(s) of the provided word
- 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(char[], int) - Method in class org.apache.lucene.analysis.sv.SwedishLightStemmer
- stem(char[], int, boolean) - Method in class org.apache.lucene.analysis.id.IndonesianStemmer
-
Stem a term (returning its new length).
- stem(CharSequence) - Method in class org.apache.lucene.analysis.stempel.StempelStemmer
-
Stem a word.
- stem(String) - Method in class org.apache.lucene.analysis.br.BrazilianStemmer
-
Stems the given term to an unique discriminator.
- stem(String) - Method in class org.apache.lucene.analysis.de.GermanStemmer
-
Stemms the given term to an unique discriminator.
- stem(String) - Method in class org.apache.lucene.analysis.fr.FrenchStemmer
-
Deprecated.Stems the given term to a unique discriminator.
- stem(String) - Method in class org.apache.lucene.analysis.hunspell.HunspellStemmer
-
Find the stem(s) of the provided word
- stem(String) - Method in class org.apache.lucene.analysis.nl.DutchStemmer
-
Deprecated.
- Stem(char[], int) - Constructor for class org.apache.lucene.analysis.hunspell.HunspellStemmer.Stem
-
Creates a new Stem wrapping the given word stem
- StemmerOverrideFilter - Class in org.apache.lucene.analysis.miscellaneous
-
Provides the ability to override any
KeywordAttribute
aware stemmer with custom dictionary-based stemming. - StemmerOverrideFilter(Version, TokenStream, Map<?, String>) - Constructor for class org.apache.lucene.analysis.miscellaneous.StemmerOverrideFilter
-
Create a new StemmerOverrideFilter, performing dictionary-based stemming with the provided
dictionary
. - StemmerUtil - Class in org.apache.lucene.analysis.util
-
Some commonly-used stemming functions
- StemmerUtil() - Constructor for class org.apache.lucene.analysis.util.StemmerUtil
- 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.
- 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
- stop - Variable in class org.apache.lucene.search.grouping.AbstractAllGroupHeadsCollector.TemporalResult
- STOP_WORDS - Static variable in class org.apache.lucene.analysis.cjk.CJKAnalyzer
-
Deprecated.use
CJKAnalyzer.getDefaultStopSet()
instead - STOP_WORDS - Static variable in class org.apache.lucene.analysis.cn.ChineseFilter
-
Deprecated.
- 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
-
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.UAX29URLEmailAnalyzer
-
An unmodifiable set containing some common English words that are usually not useful for searching.
- StopAnalyzer - Class in org.apache.lucene.analysis
- StopAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.StopAnalyzer
-
Builds an analyzer which removes words in
StopAnalyzer.ENGLISH_STOP_WORDS_SET
. - StopAnalyzer(Version, File) - Constructor for class org.apache.lucene.analysis.StopAnalyzer
-
Builds an analyzer with the stop words from the given file.
- StopAnalyzer(Version, Reader) - Constructor for class org.apache.lucene.analysis.StopAnalyzer
-
Builds an analyzer with the stop words from the given reader.
- StopAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.StopAnalyzer
-
Builds an analyzer with the stop words from the given set.
- StopFilter - Class in org.apache.lucene.analysis
-
Removes stop words from a token stream.
- StopFilter(boolean, TokenStream, Set<?>) - Constructor for class org.apache.lucene.analysis.StopFilter
-
Deprecated.use
StopFilter(Version, TokenStream, Set)
instead - StopFilter(boolean, TokenStream, Set<?>, boolean) - Constructor for class org.apache.lucene.analysis.StopFilter
-
Deprecated.Use
StopFilter(Version, TokenStream, Set)
instead - StopFilter(Version, TokenStream, Set<?>) - Constructor for class org.apache.lucene.analysis.StopFilter
-
Constructs a filter which removes words from the input TokenStream that are named in the Set.
- StopFilter(Version, TokenStream, Set<?>, boolean) - Constructor for class org.apache.lucene.analysis.StopFilter
-
Deprecated.Use
StopFilter(Version, TokenStream, Set)
instead - 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
- 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(Version) - Constructor for class org.apache.lucene.analysis.StopwordAnalyzerBase
-
Creates a new Analyzer with an empty stopword set
- StopwordAnalyzerBase(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.StopwordAnalyzerBase
-
Creates a new instance initialized with the given stopword set
- stopwords - Variable in class org.apache.lucene.analysis.StopwordAnalyzerBase
-
An immutable stopword set
- STOPWORDS_COMMENT - Static variable in class org.apache.lucene.analysis.ar.ArabicAnalyzer
-
Deprecated.use
WordlistLoader.getWordSet(Reader, String, Version)
directly - STOPWORDS_COMMENT - Static variable in class org.apache.lucene.analysis.bg.BulgarianAnalyzer
-
Deprecated.use
WordlistLoader.getWordSet(Reader, String, Version)
directly - 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.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.
- store(File, IndexReader, TaxonomyReader, FacetIndexingParams, CategoryListCache) - Method in class org.apache.lucene.facet.search.TotalFacetCountsCache
-
Store the
TotalFacetCounts
matching input parameters into the provided outputFile, making them available for a later call toTotalFacetCountsCache.load(File, IndexReader, TaxonomyReader, FacetIndexingParams)
. - store(OutputStream) - Method in class org.apache.lucene.search.suggest.fst.FSTCompletionLookup
- store(OutputStream) - Method in class org.apache.lucene.search.suggest.fst.FSTLookup
-
Deprecated.
- store(OutputStream) - Method in class org.apache.lucene.search.suggest.fst.WFSTCompletionLookup
- store(OutputStream) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellLookup
- store(OutputStream) - Method in class org.apache.lucene.search.suggest.Lookup
-
Persist the constructed lookup data to a directory.
- store(OutputStream) - Method in class org.apache.lucene.search.suggest.tst.TSTLookup
- STORE_INDEX_EXTENSIONS - Static variable in class org.apache.lucene.index.IndexFileNames
- StoreClassNameRule - Class in org.apache.lucene.util
- StoreClassNameRule() - Constructor for class org.apache.lucene.util.StoreClassNameRule
- 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).
- StoredFieldStatus() - Constructor for class org.apache.lucene.index.CheckIndex.Status.StoredFieldStatus
- storeOffsetWithTermVector - Variable in class org.apache.lucene.document.AbstractField
- storePayloads - Variable in class org.apache.lucene.index.FieldInfo
- storePolicy - Variable in class org.apache.lucene.index.PruningReader
- storePositionWithTermVector - Variable in class org.apache.lucene.document.AbstractField
- StorePruningPolicy - Class in org.apache.lucene.index.pruning
-
Pruning policy for removing stored fields from documents.
- StorePruningPolicy(IndexReader, Map<String, Integer>) - Constructor for class org.apache.lucene.index.pruning.StorePruningPolicy
-
Constructs a policy.
- stores - Static variable in class org.apache.lucene.util.LuceneTestCase
- storeTermVector - Variable in class org.apache.lucene.document.AbstractField
- storeTermVector - Variable in class org.apache.lucene.index.FieldInfo
- storeVal - Variable in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
- STR_SIZE - Static variable in class org.apache.lucene.document.NumberTools
-
Deprecated.The length of (all) strings returned by
NumberTools.longToString(long)
- 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
- 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
- string - Variable in class org.apache.lucene.search.spell.SuggestWord
-
the suggested word
- STRING - org.apache.lucene.queryParser.core.parser.EscapeQuerySyntax.Type
- STRING - Static variable in class org.apache.lucene.analysis.cn.smart.WordType
-
ASCII String
- STRING - Static variable in class org.apache.lucene.search.SortField
-
Sort using term values as Strings.
- STRING_CHAR_ARRAY - Static variable in class org.apache.lucene.analysis.cn.smart.Utility
- STRING_INDEX - Static variable in interface org.apache.lucene.search.FieldCache
-
Indicator for StringIndex values in the cache.
- STRING_VAL - Static variable in class org.apache.lucene.search.SortField
-
Sort using term values as Strings, but comparing by value (using String.compareTo) for all comparisons.
- StringBuilderReader - Class in org.apache.lucene.benchmark.byTask.utils
-
Implements a
Reader
over aStringBuilder
instance. - StringBuilderReader(StringBuilder) - Constructor for class org.apache.lucene.benchmark.byTask.utils.StringBuilderReader
- StringDistance - Interface in org.apache.lucene.search.spell
-
Interface for string distances.
- StringHelper - Class in org.apache.lucene.util
-
Methods for manipulating strings.
- StringIndex(int[], String[]) - Constructor for class org.apache.lucene.search.FieldCache.StringIndex
-
Creates one of these objects
- StringInterner - Class in org.apache.lucene.util
-
Subclasses of StringInterner are required to return the same single String object for all equal strings.
- StringInterner() - Constructor for class org.apache.lucene.util.StringInterner
- stringIterator() - Method in class org.apache.lucene.analysis.CharArraySet
-
Deprecated.Use
CharArraySet.iterator()
, which returnschar[]
instances. - StringOrdValComparator(int, String, int, boolean) - Constructor for class org.apache.lucene.search.FieldComparator.StringOrdValComparator
- stringToCharSequence(String, Random) - Static method in class org.apache.lucene.util._TestUtil
- stringToDate(String) - Static method in class org.apache.lucene.document.DateField
-
Deprecated.Converts a string-encoded date into a Date object.
- stringToDate(String) - Static method in class org.apache.lucene.document.DateTools
-
Converts a string produced by
timeToString
ordateToString
back to a time, represented as a Date object. - stringToLong(String) - Static method in class org.apache.lucene.document.NumberTools
-
Deprecated.Converts a String that was returned by
NumberTools.longToString(long)
back to a long. - stringToTime(String) - Static method in class org.apache.lucene.document.DateField
-
Deprecated.Converts a string-encoded date into a millisecond time.
- stringToTime(String) - Static method in class org.apache.lucene.document.DateTools
-
Converts a string produced by
timeToString
ordateToString
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.core.util
-
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
- StringUtils() - Constructor for class org.apache.lucene.queryParser.core.util.StringUtils
- stringValue() - Method in class org.apache.lucene.document.Field
-
The value of the field as a String, or null.
- stringValue() - Method in interface org.apache.lucene.document.Fieldable
-
The value of the field as a String, or null.
- stringValue() - Method in class org.apache.lucene.document.NumericField
-
Returns the numeric value as a string.
- stripSegmentName(String) - Static method in class org.apache.lucene.index.IndexFileNames
-
Strips the segment file name out of the given one.
- 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[]) - Static method in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
- strlen(char[], int) - Static method in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
- strVal(int) - Method in class org.apache.lucene.search.function.DocValues
-
Return doc value as a string.
- 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
- subDoc(int) - Method in class org.apache.lucene.search.MultiSearcher
-
Deprecated.Returns the document number of document
n
within its sub-index. - subIndex(int, int[]) - Static method in class org.apache.lucene.util.ReaderUtil
-
Returns index of the searcher/reader for document
n
in the array used to construct this searcher/reader. - subList(int, int) - Method in class org.apache.lucene.queryParser.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.
- subQueriesOrdered() - Method in class org.apache.lucene.queryParser.surround.query.DistanceQuery
- SUBREADER - Static variable in class org.apache.lucene.util.FieldCacheSanityChecker.InsanityType
-
Indicates an overlap in cache usage on a given field in sub/super readers.
- subReaders - Variable in class org.apache.lucene.index.MultiReader
- subReaders - Variable in class org.apache.lucene.search.IndexSearcher
- subSearcher(int) - Method in class org.apache.lucene.search.MultiSearcher
-
Deprecated.Returns index of the searcher for document
n
in the array used to construct this searcher. - subSearchers - Variable in class org.apache.lucene.search.IndexSearcher
- 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.core.util.UnescapedCharSequence
- subSequence(int, int) - Method in class org.apache.lucene.util.CharsRef
- substring_i - Variable in class org.tartarus.snowball.Among
- subtract(Long, Long) - Method in class org.apache.lucene.util.fst.PositiveIntOutputs
- subtract(Object, Object) - Method in class org.apache.lucene.util.fst.NoOutputs
- subtract(Object, Object) - Method in class org.apache.lucene.util.fst.UpToTwoPositiveIntOutputs
- subtract(BytesRef, BytesRef) - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
- subtract(PairOutputs.Pair<A, B>, PairOutputs.Pair<A, B>) - Method in class org.apache.lucene.util.fst.PairOutputs
- subtract(IntsRef, IntsRef) - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
- subtract(T, T) - Method in class org.apache.lucene.util.fst.Outputs
-
Eg subtract("foobar", "foo") -> "bar"
- suffix - Variable in class org.apache.lucene.analysis.pt.RSLPStemmerBase.Rule
- 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_ALWAYS - org.apache.lucene.search.spell.SuggestMode
-
Always attempt to offer suggestions (however, other parameters may limit suggestions.)
- SUGGEST_MORE_POPULAR - org.apache.lucene.search.spell.SuggestMode
-
Return only suggested words that are as frequent or more frequent than the searched word
- SUGGEST_WHEN_NOT_IN_INDEX - org.apache.lucene.search.spell.SuggestMode
-
Generate suggestions only for terms not in the index (default)
- SuggestMode - Enum in org.apache.lucene.search.spell
-
Set of strategies for suggesting related terms
- 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, boolean) - Method in class org.apache.lucene.search.spell.SpellChecker
-
Deprecated.use suggestSimilar(String, int, IndexReader, String, SuggestMode)
- SuggestMode.SUGGEST_WHEN_NOT_IN_INDEX instead of morePopular=false
- SuggestMode.SuGGEST_MORE_POPULAR instead of morePopular=true
- suggestSimilar(String, int, IndexReader, String, boolean, float) - Method in class org.apache.lucene.search.spell.SpellChecker
-
Deprecated.use suggestSimilar(String, int, IndexReader, String, SuggestMode, float)
- SuggestMode.SUGGEST_WHEN_NOT_IN_INDEX instead of morePopular=false
- SuggestMode.SuGGEST_MORE_POPULAR instead of morePopular=true
- 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).
- 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
- 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
- SUKUN - Static variable in class org.apache.lucene.analysis.ar.ArabicNormalizer
- sumArray - Variable in class org.apache.lucene.facet.search.aggregator.association.AssociationFloatSumAggregator
- sumArray - Variable in class org.apache.lucene.facet.search.aggregator.association.AssociationIntSumAggregator
- SUMMARY_LENGTH - Static variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParser
- sumOfSquaredWeights() - Method in class org.apache.lucene.search.BooleanQuery.BooleanWeight
- sumOfSquaredWeights() - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantWeight
- sumOfSquaredWeights() - Method in class org.apache.lucene.search.DisjunctionMaxQuery.DisjunctionMaxWeight
-
Compute the sub of squared weights of us applied to our subqueries.
- sumOfSquaredWeights() - Method in class org.apache.lucene.search.spans.SpanWeight
- sumOfSquaredWeights() - Method in class org.apache.lucene.search.Weight
-
The sum of squared weights of contained query clauses.
- SUN_OS - Static variable in class org.apache.lucene.util.Constants
-
True iff running on SunOS.
- supportsComplements() - Method in class org.apache.lucene.facet.search.params.association.AssociationFloatSumFacetRequest
- supportsComplements() - Method in class org.apache.lucene.facet.search.params.association.AssociationIntSumFacetRequest
- supportsComplements() - Method in class org.apache.lucene.facet.search.params.CountFacetRequest
- supportsComplements() - Method in class org.apache.lucene.facet.search.params.FacetRequest
-
Indicates whether this facet request is eligible for applying the complements optimization.
- supportsComplements() - Method in class org.apache.lucene.facet.search.params.ScoreFacetRequest
- supportsParams() - Method in class org.apache.lucene.benchmark.byTask.tasks.AddDocTask
- 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.DeleteByPercentTask
- supportsParams() - Method in class org.apache.lucene.benchmark.byTask.tasks.DeleteDocTask
- supportsParams() - Method in class org.apache.lucene.benchmark.byTask.tasks.FlushReaderTask
- 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.NewShingleAnalyzerTask
- 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
- swap(int, int) - Method in class org.apache.lucene.util.SorterTemplate
-
Implement this method, that swaps slots
i
andj
in your data - SwedishAnalyzer - Class in org.apache.lucene.analysis.sv
-
Analyzer
for Swedish. - SwedishAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.sv.SwedishAnalyzer
-
Builds an analyzer with the default stop words:
SwedishAnalyzer.DEFAULT_STOPWORD_FILE
. - SwedishAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.sv.SwedishAnalyzer
-
Builds an analyzer with the given stop words.
- SwedishAnalyzer(Version, Set<?>, Set<?>) - 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
-
A
TokenFilter
that appliesSwedishLightStemmer
to stem Swedish words. - SwedishLightStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.sv.SwedishLightStemFilter
- 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
-
Generated class implementing code 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.benchmark.byTask.feeds.demohtml.HTMLParserTokenManager
-
Switch to specified lex state.
- SwitchTo(int) - Method in class org.apache.lucene.queryParser.QueryParserTokenManager
-
Switch to specified lex state.
- SwitchTo(int) - Method in class org.apache.lucene.queryParser.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
- sync() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
-
Wait for any running merge threads to finish
- sync(String) - Method in class org.apache.lucene.store.Directory
-
Deprecated.use
Directory.sync(Collection)
instead. For easy migration you can change your code to call sync(Collections.singleton(name)) - sync(String) - Method in class org.apache.lucene.store.FileSwitchDirectory
-
Deprecated.
- sync(String) - Method in class org.apache.lucene.store.FSDirectory
-
Deprecated.
- sync(String) - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
Deprecated.
- sync(Collection<String>) - Method in class org.apache.lucene.store.Directory
-
Ensure that any writes to these files are moved to stable storage.
- sync(Collection<String>) - Method in class org.apache.lucene.store.FileSwitchDirectory
- sync(Collection<String>) - Method in class org.apache.lucene.store.FSDirectory
- sync(Collection<String>) - Method in class org.apache.lucene.store.MockDirectoryWrapper
- sync(Collection<String>) - Method in class org.apache.lucene.store.NRTCachingDirectory
- syncConcurrentMerges(IndexWriter) - Static method in class org.apache.lucene.util._TestUtil
- syncConcurrentMerges(MergeScheduler) - Static method in class org.apache.lucene.util._TestUtil
- SynonymFilter - Class in org.apache.lucene.analysis.synonym
-
Matches single or multi word synonyms in a token stream.
- SynonymFilter(TokenStream, SynonymMap, boolean) - Constructor for class org.apache.lucene.analysis.synonym.SynonymFilter
- 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.
- SyntaxParser - Interface in org.apache.lucene.queryParser.core.parser
-
A parser needs to implement
SyntaxParser
interface - SystemPropertiesInvariantRule - Class in org.apache.lucene.util
- SystemPropertiesInvariantRule() - Constructor for class org.apache.lucene.util.SystemPropertiesInvariantRule
-
Cares about all properties.
- SystemPropertiesInvariantRule(String...) - Constructor for class org.apache.lucene.util.SystemPropertiesInvariantRule
-
Don't care about the given set of properties.
- SystemPropertiesInvariantRule(Set<String>) - Constructor for class org.apache.lucene.util.SystemPropertiesInvariantRule
-
Don't care about the given set of properties.
- SystemPropertiesRestoreRule - Class in org.apache.lucene.util
-
Restore system properties from before the nested
Statement
. - SystemPropertiesRestoreRule() - Constructor for class org.apache.lucene.util.SystemPropertiesRestoreRule
-
Restores all properties.
- SystemPropertiesRestoreRule(String...) - Constructor for class org.apache.lucene.util.SystemPropertiesRestoreRule
- SystemPropertiesRestoreRule(Set<String>) - Constructor for class org.apache.lucene.util.SystemPropertiesRestoreRule
T
- tableTitle(String) - Method in class org.apache.lucene.benchmark.byTask.tasks.ReportTask
-
Compute a title line for a report table
- tabSize - Variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
- tabSize - Variable in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
- Tag() - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParser
- TAG_ID - Static variable in interface org.apache.lucene.queryParser.standard.config.MultiTermRewriteMethodAttribute
-
Deprecated.
- TAG_ID - Static variable in class org.apache.lucene.queryParser.standard.processors.MultiTermRewriteMethodProcessor
- TagEnd - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
RegularExpression Id.
- tagModifierButDoNotOverride(QueryNode, ModifierQueryNode.Modifier) - Method in class org.apache.lucene.queryParser.standard.processors.BooleanQuery2ModifierNodeProcessor
- TagName - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
RegularExpression Id.
- Tags - Class in org.apache.lucene.benchmark.byTask.feeds.demohtml
- Tags() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.demohtml.Tags
- target - Variable in class org.apache.lucene.util.fst.Builder.Arc
- target - Variable in class org.apache.lucene.util.fst.FST.Arc
- targetHasArcs(FST.Arc<T>) - Static method in class org.apache.lucene.util.fst.FST
- TARGETMAP_FILENAME_SUFFIX - Static variable in class org.apache.lucene.analysis.ja.dict.BinaryDictionary
- TARGETMAP_HEADER - Static variable in class org.apache.lucene.analysis.ja.dict.BinaryDictionary
- 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
- taxonomyReader - Variable in class org.apache.lucene.facet.search.FacetResultsHandler
-
Taxonomy for which facets are handled
- taxonomyReader - Variable in class org.apache.lucene.facet.search.FacetsAccumulator
- TaxonomyReader - Interface 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.ChildrenArrays - Interface in org.apache.lucene.facet.taxonomy
-
Equivalent representations of the taxonomy's parent info, used internally for efficient computation of facet results: "youngest child" and "oldest sibling"
- taxonomyWriter - Variable in class org.apache.lucene.facet.index.CategoryDocumentBuilder
-
A
TaxonomyWriter
for adding categories and retrieving their ordinals. - taxonomyWriter - Variable in class org.apache.lucene.facet.index.streaming.CategoryParentsStream
-
A
TaxonomyWriter
for adding categories and retrieving their ordinals. - 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
). - tearDown() - Method in class org.apache.lucene.benchmark.byTask.tasks.AddDocTask
- 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.queryParser.QueryParserTestBase
- tearDown() - Method in class org.apache.lucene.util.LuceneTestCase
-
For subclassing only.
- TeeSinkTokenFilter - Class in org.apache.lucene.analysis
-
This TokenFilter provides the ability to set aside attribute states that have already been analyzed.
- TeeSinkTokenFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.TeeSinkTokenFilter
-
Instantiates a new TeeSinkTokenFilter.
- TeeSinkTokenFilter.SinkFilter - Class in org.apache.lucene.analysis
-
A filter that decides which
AttributeSource
states to store in the sink. - TeeSinkTokenFilter.SinkTokenStream - Class in org.apache.lucene.analysis
-
TokenStream output from a tee with optional filtering.
- 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
- TEMP_DIR - Static variable in class org.apache.lucene.util.LuceneTestCase
-
Create indexes in this directory, optimally use a subdir, named after the test
- tempMergeFiles - Variable in class org.apache.lucene.search.suggest.fst.Sort.SortInfo
- temporalResult - Variable in class org.apache.lucene.search.grouping.AbstractAllGroupHeadsCollector
- TemporalResult() - Constructor for class org.apache.lucene.search.grouping.AbstractAllGroupHeadsCollector.TemporalResult
- TemporaryObjectAllocator<T> - Class in org.apache.lucene.facet.search
-
An TemporaryObjectAllocator is an object which manages large, reusable, temporary objects needed during multiple concurrent computations.
- TemporaryObjectAllocator(int) - Constructor for class org.apache.lucene.facet.search.TemporaryObjectAllocator
-
Construct an allocator for objects of a certain type, keeping around a pool of up to
maxObjects
old objects. - term - Variable in class org.apache.lucene.search.FuzzyQuery
- 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.WildcardQuery
- term() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
-
Deprecated.
- term() - Method in interface org.apache.lucene.analysis.tokenattributes.TermAttribute
-
Deprecated.Returns the Token's term text.
- term() - Method in class org.apache.lucene.index.FilterIndexReader.FilterTermEnum
- term() - Method in class org.apache.lucene.index.TermEnum
-
Returns the current Term in the enumeration.
- term() - Method in class org.apache.lucene.search.FilteredTermEnum
-
Returns the current Term in the enumeration.
- term() - Method in class org.apache.lucene.store.instantiated.InstantiatedTermEnum
-
Returns the current Term in the enumeration.
- term(FacetIndexingParams, CategoryPath) - Static method in class org.apache.lucene.facet.search.DrillDown
-
Return a term for drilling down into a category.
- term(FacetSearchParams, CategoryPath) - Static method in class org.apache.lucene.facet.search.DrillDown
- Term - Class in org.apache.lucene.index
-
A Term represents a word from text.
- Term(String) - Constructor for class org.apache.lucene.index.Term
-
Constructs a Term with the given field and empty text.
- Term(String, String) - Constructor for class org.apache.lucene.index.Term
-
Constructs a Term with the given field and text.
- Term(CharSequence) - Method in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParser
- Term(String) - Method in class org.apache.lucene.queryParser.QueryParser
- TERM - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
-
RegularExpression Id.
- TERM - Static variable in interface org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- TERM - Static variable in interface org.apache.lucene.queryParser.surround.parser.QueryParserConstants
-
RegularExpression Id.
- TermAllGroupHeadsCollector<GH extends AbstractAllGroupHeadsCollector.GroupHead> - Class in org.apache.lucene.search.grouping
-
A base implementation of
AbstractAllGroupHeadsCollector
for retrieving the most relevant groups when grouping on a string based group field. - TermAllGroupHeadsCollector(String, int) - Constructor for class org.apache.lucene.search.grouping.TermAllGroupHeadsCollector
- TermAllGroupsCollector - Class in org.apache.lucene.search.grouping
-
A collector that collects all groups that match the query.
- TermAllGroupsCollector(String) - Constructor for class org.apache.lucene.search.grouping.TermAllGroupsCollector
-
Constructs a
AbstractAllGroupsCollector
. - TermAllGroupsCollector(String, int) - Constructor for class org.apache.lucene.search.grouping.TermAllGroupsCollector
-
Expert: Constructs a
AbstractAllGroupsCollector
- termAtt - Variable in class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
- termAtt - Variable in class org.apache.lucene.analysis.sinks.DateRecognizerSinkFilter
- termAttribute - Variable in class org.apache.lucene.facet.index.streaming.CategoryTokenizerBase
-
The stream's term attribute.
- TermAttribute - Interface in org.apache.lucene.analysis.tokenattributes
-
Deprecated.Use
CharTermAttribute
instead. - TermAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
-
Deprecated.This class is not used anymore. The backwards layer in AttributeFactory uses the replacement implementation.
- TermAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.TermAttributeImpl
-
Deprecated.
- termBuffer() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
-
Deprecated.
- termBuffer() - Method in interface org.apache.lucene.analysis.tokenattributes.TermAttribute
-
Deprecated.Returns the internal termBuffer character array which you can then directly alter.
- termComparator - Static variable in class org.apache.lucene.store.instantiated.InstantiatedTerm
- termComparator - Static variable in class org.apache.lucene.store.instantiated.InstantiatedTermDocumentInformation
- termCompare(Term) - Method in class org.apache.lucene.search.FilteredTermEnum
-
Equality compare on the term
- termCompare(Term) - Method in class org.apache.lucene.search.FuzzyTermEnum
-
The termCompare method in FuzzyTermEnum uses Levenshtein distance to calculate the distance between the given term and the comparing term.
- termCompare(Term) - Method in class org.apache.lucene.search.PrefixTermEnum
- termCompare(Term) - Method in class org.apache.lucene.search.regex.RegexTermEnum
- termCompare(Term) - Method in class org.apache.lucene.search.SingleTermEnum
- termCompare(Term) - Method in class org.apache.lucene.search.TermRangeTermEnum
- termCompare(Term) - Method in class org.apache.lucene.search.WildcardTermEnum
- termCount - Variable in class org.apache.lucene.index.CheckIndex.Status.TermIndexStatus
-
Total term count
- termCount - Variable in class org.apache.lucene.index.PruningReader
- termDocs() - Method in class org.apache.lucene.index.FilterIndexReader
- termDocs() - Method in class org.apache.lucene.index.IndexReader
-
Returns an unpositioned
TermDocs
enumerator. - termDocs() - Method in class org.apache.lucene.index.MultiReader
- termDocs() - Method in class org.apache.lucene.index.ParallelReader
- termDocs() - Method in class org.apache.lucene.index.SegmentReader
- termDocs() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexReader
-
Deprecated.
- termDocs(Term) - Method in class org.apache.lucene.index.FilterIndexReader
- termDocs(Term) - Method in class org.apache.lucene.index.IndexReader
-
Returns an enumeration of all the documents which contain
term
. - termDocs(Term) - Method in class org.apache.lucene.index.MultiReader
- termDocs(Term) - Method in class org.apache.lucene.index.ParallelReader
- termDocs(Term) - Method in class org.apache.lucene.index.SegmentReader
- termDocs(Term) - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexReader
-
Deprecated.
- TermDocs - Interface in org.apache.lucene.index
-
TermDocs provides an interface for enumerating <document, frequency> pairs for a term.
- TermEnum - Class in org.apache.lucene.index
-
Abstract class for enumerating terms.
- TermEnum() - Constructor for class org.apache.lucene.index.TermEnum
- TermFirstPassGroupingCollector - Class in org.apache.lucene.search.grouping
-
Concrete implementation of
AbstractFirstPassGroupingCollector
that groups based on field values and more specifically usesFieldCache.StringIndex
to collect groups. - TermFirstPassGroupingCollector(String, Sort, int) - Constructor for class org.apache.lucene.search.grouping.TermFirstPassGroupingCollector
-
Create the first pass collector.
- TermFreqIterator - Interface in org.apache.lucene.search.spell
-
Interface for enumerating term,weight pairs.
- TermFreqIterator.TermFreqIteratorWrapper - Class in org.apache.lucene.search.spell
-
Wraps a BytesRefIterator as a TermFreqIterator, with all weights set to
1
- TermFreqIteratorWrapper(BytesRefIterator) - Constructor for class org.apache.lucene.search.spell.TermFreqIterator.TermFreqIteratorWrapper
- TermFreqVector - Interface in org.apache.lucene.index
-
Provides access to stored term vector of a document field.
- 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
- termIndexInterval - Variable in class org.apache.lucene.index.SegmentWriteState
-
Expert: The fraction of terms in the "dictionary" which should be stored in RAM.
- 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).
- TermIndexStatus() - Constructor for class org.apache.lucene.index.CheckIndex.Status.TermIndexStatus
- termLength() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
-
Deprecated.
- termLength() - Method in interface org.apache.lucene.analysis.tokenattributes.TermAttribute
-
Deprecated.Return number of valid characters (length of the term) in the termBuffer array.
- termPolicy - Variable in class org.apache.lucene.index.PruningReader
- termPositions() - Method in class org.apache.lucene.index.FilterIndexReader
- termPositions() - Method in class org.apache.lucene.index.IndexReader
-
Returns an unpositioned
TermPositions
enumerator. - termPositions() - Method in class org.apache.lucene.index.MultiReader
- termPositions() - Method in class org.apache.lucene.index.ParallelReader
- termPositions() - Method in class org.apache.lucene.index.PruningReader
-
Applies
TermPruningPolicy
to term positions. - termPositions() - Method in class org.apache.lucene.index.SegmentReader
- termPositions() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexReader
-
Deprecated.
- termPositions(Term) - Method in class org.apache.lucene.index.IndexReader
-
Returns an enumeration of all the documents which contain
term
. - TermPositions - Interface in org.apache.lucene.index
-
TermPositions provides an interface for enumerating the <document, frequency, <position>* > tuples for a term.
- TermPositionVector - Interface in org.apache.lucene.index
-
Extends
TermFreqVector
to provide additional information about positions in which each of the terms is found. - TermPruningPolicy - Class in org.apache.lucene.index.pruning
-
Policy for producing smaller index out of an input index, by examining its terms and removing from the index some or all of their data as follows: all terms of a certain field - see
TermPruningPolicy.pruneAllFieldPostings(String)
all data of a certain term - seeTermPruningPolicy.pruneTermEnum(TermEnum)
all positions of a certain term in a certain document - see #pruneAllPositions(TermPositions, Term) some positions of a certain term in a certain document - see #pruneSomePositions(int, int[], Term) - TermPruningPolicy(IndexReader, Map<String, Integer>) - Constructor for class org.apache.lucene.index.pruning.TermPruningPolicy
-
Construct a policy.
- 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
. - TermQueryBuilder - Class in org.apache.lucene.xmlparser.builders
- TermQueryBuilder() - Constructor for class org.apache.lucene.xmlparser.builders.TermQueryBuilder
- TermRangeFilter - Class in org.apache.lucene.search
-
A Filter that restricts search results to a range of term values in a given field.
- TermRangeFilter(String, String, String, boolean, boolean) - Constructor for class org.apache.lucene.search.TermRangeFilter
- TermRangeFilter(String, String, String, boolean, boolean, Collator) - Constructor for class org.apache.lucene.search.TermRangeFilter
-
WARNING: Using this constructor and supplying a non-null value in the
collator
parameter will cause every single index Term in the Field referenced by lowerTerm and/or upperTerm to be examined. - TermRangeQuery - Class in org.apache.lucene.search
-
A Query that matches documents within an range of terms.
- TermRangeQuery(String, String, String, boolean, boolean) - Constructor for class org.apache.lucene.search.TermRangeQuery
-
Constructs a query selecting all terms greater/equal than
lowerTerm
but less/equal thanupperTerm
. - TermRangeQuery(String, String, String, boolean, boolean, Collator) - Constructor for class org.apache.lucene.search.TermRangeQuery
-
Constructs a query selecting all terms greater/equal than
lowerTerm
but less/equal thanupperTerm
. - TermRangeQueryNode - Class in org.apache.lucene.queryParser.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.standard.nodes.TermRangeQueryNode
-
Constructs a
TermRangeQueryNode
object using the givenFieldQueryNode
as its bounds. - TermRangeQueryNodeBuilder - Class in org.apache.lucene.queryParser.standard.builders
-
Builds a
TermRangeQuery
object from aTermRangeQueryNode
object. - TermRangeQueryNodeBuilder() - Constructor for class org.apache.lucene.queryParser.standard.builders.TermRangeQueryNodeBuilder
- TermRangeTermEnum - Class in org.apache.lucene.search
-
Subclass of FilteredTermEnum for enumerating all terms that match the specified range parameters.
- TermRangeTermEnum(IndexReader, String, String, String, boolean, boolean, Collator) - Constructor for class org.apache.lucene.search.TermRangeTermEnum
-
Enumerates all terms greater/equal than
lowerTerm
but less/equal thanupperTerm
. - terms - Variable in class org.apache.lucene.search.spans.SpanWeight
- terms() - Method in class org.apache.lucene.index.FilterIndexReader
- terms() - Method in class org.apache.lucene.index.IndexReader
-
Returns an enumeration of all the terms in the index.
- terms() - Method in class org.apache.lucene.index.MultiReader
- terms() - Method in class org.apache.lucene.index.ParallelReader
- terms() - Method in class org.apache.lucene.index.PruningReader
-
Applies
TermPruningPolicy
to term enum. - terms() - Method in class org.apache.lucene.index.SegmentReader
- terms() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexReader
-
Deprecated.
- terms(Term) - Method in class org.apache.lucene.index.FilterIndexReader
- terms(Term) - Method in class org.apache.lucene.index.IndexReader
-
Returns an enumeration of all terms starting at a given term.
- terms(Term) - Method in class org.apache.lucene.index.MultiReader
- terms(Term) - Method in class org.apache.lucene.index.ParallelReader
- terms(Term) - Method in class org.apache.lucene.index.SegmentReader
- terms(Term) - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexReader
-
Deprecated.
- TERMS_EXTENSION - Static variable in class org.apache.lucene.index.IndexFileNames
-
Extension of terms file
- TERMS_INDEX_EXTENSION - Static variable in class org.apache.lucene.index.IndexFileNames
-
Extension of terms index file
- TermSecondPassGroupingCollector - Class in org.apache.lucene.search.grouping
-
Concrete implementation of
AbstractSecondPassGroupingCollector
that groups based on field values and more specifically usesFieldCache.StringIndex
to collect grouped docs. - TermSecondPassGroupingCollector(String, Collection<SearchGroup<String>>, Sort, Sort, int, boolean, boolean, boolean) - Constructor for class org.apache.lucene.search.grouping.TermSecondPassGroupingCollector
- TermsFilter - Class in org.apache.lucene.search
-
Constructs a filter for docs matching any of the terms added to this class.
- TermsFilter() - Constructor for class org.apache.lucene.search.TermsFilter
- TermsFilterBuilder - Class in org.apache.lucene.xmlparser.builders
- TermsFilterBuilder(Analyzer) - Constructor for class org.apache.lucene.xmlparser.builders.TermsFilterBuilder
- TermSpans - Class in org.apache.lucene.search.spans
-
Expert: Public for extension only
- TermSpans(TermPositions, Term) - Constructor for class org.apache.lucene.search.spans.TermSpans
- TermsQueryBuilder - Class in org.apache.lucene.xmlparser.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.xmlparser.builders.TermsQueryBuilder
- TermVectorAccessor - Class in org.apache.lucene.index
-
Transparent access to the vector space model, either via TermFreqVector or by resolving it from the inverted index.
- TermVectorAccessor() - Constructor for class org.apache.lucene.index.TermVectorAccessor
- TermVectorEntry - Class in org.apache.lucene.index
-
Convenience class for holding TermVector information.
- TermVectorEntry() - Constructor for class org.apache.lucene.index.TermVectorEntry
- TermVectorEntry(String, String, int, TermVectorOffsetInfo[], int[]) - Constructor for class org.apache.lucene.index.TermVectorEntry
- TermVectorEntryFreqSortedComparator - Class in org.apache.lucene.index
-
Compares
TermVectorEntry
s first by frequency and then by the term (case-sensitive) - TermVectorEntryFreqSortedComparator() - Constructor for class org.apache.lucene.index.TermVectorEntryFreqSortedComparator
- TermVectorMapper - Class in org.apache.lucene.index
-
The TermVectorMapper can be used to map Term Vectors into your own structure instead of the parallel array structure used by
IndexReader.getTermFreqVector(int,String)
. - TermVectorMapper() - Constructor for class org.apache.lucene.index.TermVectorMapper
- TermVectorMapper(boolean, boolean) - Constructor for class org.apache.lucene.index.TermVectorMapper
- TermVectorOffsetInfo - Class in org.apache.lucene.index
-
The TermVectorOffsetInfo class holds information pertaining to a Term in a
TermPositionVector
's offset information. - TermVectorOffsetInfo() - Constructor for class org.apache.lucene.index.TermVectorOffsetInfo
- TermVectorOffsetInfo(int, int) - Constructor for class org.apache.lucene.index.TermVectorOffsetInfo
- 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).
- TermVectorStatus() - Constructor for class org.apache.lucene.index.CheckIndex.Status.TermVectorStatus
- termVecVal - Variable in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
- 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
- TEST_CLEAN_THREADS - Static variable in class org.apache.lucene.util.LuceneTestCase
-
whether or not to clean threads between test invocations: "false", "perMethod", "perClass"
- TEST_DIRECTORY - Static variable in class org.apache.lucene.util.LuceneTestCase
-
Gets the directory to run tests with
- TEST_ITER - Static variable in class org.apache.lucene.util.LuceneTestCase
-
Get the number of times to run tests
- TEST_ITER_MIN - Static variable in class org.apache.lucene.util.LuceneTestCase
-
Get the minimum number of times to run tests until a failure happens
- TEST_LINE_DOCS_FILE - Static variable in class org.apache.lucene.util.LuceneTestCase
-
the line file used by LineFileDocs
- TEST_LOCALE - Static variable in class org.apache.lucene.util.LuceneTestCase
-
Gets the locale to run tests with
- TEST_NIGHTLY - Static variable in class org.apache.lucene.util.LuceneTestCase
-
whether or not nightly tests should run
- TEST_SEED - Static variable in class org.apache.lucene.util.LuceneTestCase
-
Get the random seed for tests
- TEST_TIMEZONE - Static variable in class org.apache.lucene.util.LuceneTestCase
-
Gets the timezone to run tests with
- TEST_VERSION_CURRENT - Static variable in class org.apache.lucene.util.LuceneTestCase
-
Use this constant when creating Analyzers and any other version-dependent stuff.
- TestApp - Class in org.tartarus.snowball
- TestApp() - Constructor for class org.tartarus.snowball.TestApp
- testAutoGeneratePhraseQueriesOn() - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- testBooleanQuery() - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- testBoost() - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- testCJK() - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- testCJKBoostedPhrase() - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- testCJKBoostedTerm() - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- testCJKPhrase() - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- testCJKSloppyPhrase() - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- testCJKTerm() - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- testCollationKeySort(Analyzer, Analyzer, Analyzer, Analyzer, String, String, String, String) - Method in class org.apache.lucene.analysis.CollationTestBase
- testCustomQueryParserFuzzy() - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- testCustomQueryParserWildcard() - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- testDateRange() - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- testEscaped() - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- testException() - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- testFarsiRangeCollating() - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- testFarsiRangeFilterCollating(Analyzer, String, String, String, String) - Method in class org.apache.lucene.analysis.CollationTestBase
- testFarsiRangeQueryCollating(Analyzer, String, String, String, String) - Method in class org.apache.lucene.analysis.CollationTestBase
- testFarsiTermRangeQuery(Analyzer, String, String, String, String) - Method in class org.apache.lucene.analysis.CollationTestBase
- testLeadingWildcardType() - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- testLegacyDateRange() - Method in class org.apache.lucene.queryParser.QueryParserTestBase
-
for testing legacy DateField support
- testLocalDateFormat() - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- testMatchAllDocs() - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- testNumber() - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- testPositionIncrement() - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- testPositionIncrements() - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- testPrecedence() - Method in class org.apache.lucene.queryParser.QueryParserTestBase
-
This test differs from TestPrecedenceQueryParser
- testProtectedCtors() - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- testPunct() - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- testQPA() - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- testQueryStringEscaping() - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- testRange() - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- testsFailed - Static variable in class org.apache.lucene.util.LuceneTestCase
- testSimple() - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- testSimpleDAO() - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- testSlop() - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- testStarParsing() - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- testStopwords() - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- testTabNewlineCarriageReturn() - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- testWildcard() - Method in class org.apache.lucene.queryParser.QueryParserTestBase
- text - Variable in class org.apache.lucene.queryParser.core.nodes.FieldQueryNode
-
The term's text.
- text() - Method in class org.apache.lucene.index.Term
-
Returns the text of this term.
- text() - Method in class org.apache.lucene.store.instantiated.InstantiatedTerm
- TextableQueryNode - Interface in org.apache.lucene.queryParser.core.nodes
- 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
- TextFragment(StringBuffer, int, int) - Constructor for class org.apache.lucene.search.highlight.TextFragment
-
Deprecated.Use
TextFragment(CharSequence, int, int)
instead. This constructor will be removed in Lucene 4.0 - tf(float) - Method in class org.apache.lucene.search.DefaultSimilarity
-
Implemented as
sqrt(freq)
. - tf(float) - Method in class org.apache.lucene.search.Similarity
-
Computes a score factor based on a term or phrase's frequency in a document.
- tf(float) - Method in class org.apache.lucene.search.SimilarityDelegator
-
Deprecated.
- tf(int) - Method in class org.apache.lucene.misc.SweetSpotSimilarity
-
Delegates to baselineTf
- tf(int) - Method in class org.apache.lucene.search.Similarity
-
Computes a score factor based on a term or phrase's frequency in a document.
- TFTermPruningPolicy - Class in org.apache.lucene.index.pruning
-
Policy for producing smaller index out of an input index, by removing postings data for those terms where their in-document frequency is below a specified threshold.
- TFTermPruningPolicy(IndexReader, Map<String, Integer>, Map<String, Integer>, int) - Constructor for class org.apache.lucene.index.pruning.TFTermPruningPolicy
- ThaiAnalyzer - Class in org.apache.lucene.analysis.th
-
Analyzer
for Thai language. - ThaiAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.th.ThaiAnalyzer
-
Builds an analyzer with the default stop words.
- ThaiAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.th.ThaiAnalyzer
-
Builds an analyzer with the given stop words.
- ThaiWordFilter - Class in org.apache.lucene.analysis.th
-
TokenFilter
that useBreakIterator
to break each Token that is Thai into separate Token(s) for each Thai word. - ThaiWordFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.th.ThaiWordFilter
-
Deprecated.Use the ctor with
matchVersion
instead! - ThaiWordFilter(Version, TokenStream) - Constructor for class org.apache.lucene.analysis.th.ThaiWordFilter
-
Creates a new ThaiWordFilter with the specified match version.
- theEmptyLcnQuery - Static variable in class org.apache.lucene.queryParser.surround.query.SrndQuery
- thread - Variable in class org.apache.lucene.util.UncaughtExceptionsRule.UncaughtExceptionEntry
- 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
- thresholds - Variable in class org.apache.lucene.index.pruning.TFTermPruningPolicy
- ThrottledIndexOutput - Class in org.apache.lucene.util
-
Intentionally slow IndexOutput for testing.
- 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
- ThrottledIndexOutput(int, 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
- 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
- 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
- TimerThread(long, Counter) - Constructor for class org.apache.lucene.search.TimeLimitingCollector.TimerThread
- TimerThread(Counter) - Constructor for class org.apache.lucene.search.TimeLimitingCollector.TimerThread
- timestamp - Variable in class org.apache.lucene.search.FilterManager.FilterItem
-
Deprecated.
- timeToString(long) - Static method in class org.apache.lucene.document.DateField
-
Deprecated.Converts a millisecond time to a string suitable for indexing.
- timeToString(long, DateTools.Resolution) - Static method in class org.apache.lucene.document.DateTools
-
Converts a millisecond time to a string suitable for indexing.
- TITLE_FIELD - Static variable in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
- toArray() - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorPipeline
- toArray() - Method in class org.apache.lucene.util.collections.ArrayHashMap
-
Translates the mapped pairs' values into an array of Objects
- toArray() - Method in class org.apache.lucene.util.collections.FloatToObjectMap
-
Translates the mapped pairs' values into an array of Objects
- toArray() - Method in class org.apache.lucene.util.collections.IntHashSet
-
Translates the mapped pairs' values into an array of Objects
- toArray() - Method in class org.apache.lucene.util.collections.IntToDoubleMap
-
Translates the mapped pairs' values into an array of Objects
- toArray() - Method in class org.apache.lucene.util.collections.IntToIntMap
-
Translates the mapped pairs' values into an array of Objects
- toArray() - Method in class org.apache.lucene.util.collections.IntToObjectMap
-
Translates the mapped pairs' values into an array of Objects
- toArray() - Method in class org.apache.lucene.util.collections.ObjectToFloatMap
-
Translates the mapped pairs' values into an array of Objects
- toArray() - Method in class org.apache.lucene.util.collections.ObjectToIntMap
-
Translates the mapped pairs' values into an array of Objects
- toArray(double[]) - Method in class org.apache.lucene.util.collections.IntToDoubleMap
-
Translates the mapped pairs' values into an array of T
- toArray(float[]) - Method in class org.apache.lucene.util.collections.ObjectToFloatMap
-
Translates the mapped pairs' values into an array of T
- toArray(int[]) - Method in class org.apache.lucene.util.collections.IntHashSet
-
Translates the mapped pairs' values into an array of ints
- toArray(int[]) - Method in class org.apache.lucene.util.collections.IntToIntMap
-
Translates the mapped pairs' values into an array of ints
- toArray(int[]) - Method in class org.apache.lucene.util.collections.ObjectToIntMap
-
Translates the mapped pairs' values into an array of T
- toArray(T[]) - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorPipeline
- toArray(T[]) - Method in class org.apache.lucene.util.collections.FloatToObjectMap
-
Translates the mapped pairs' values into an array of T
- toArray(T[]) - Method in class org.apache.lucene.util.collections.IntToObjectMap
-
Translates the mapped pairs' values into an array of T
- toArray(V[]) - Method in class org.apache.lucene.util.collections.ArrayHashMap
-
Translates the mapped pairs' values into an array of V
- toByteArray() - Method in class org.apache.lucene.index.Payload
-
Allocates a new byte array, copies the payload data into it and returns it.
- toByteArray() - Method in class org.apache.lucene.util.UnsafeByteArrayOutputStream
-
Returns the byte array saved within the buffer AS IS.
- toBytesRef(IntsRef, BytesRef) - 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.
- toCartesian() - Method in class org.apache.lucene.spatial.geometry.LatLng
-
Deprecated.Convert the lat/lng into the cartesian coordinate plane such that all world coordinates are represented in the first quadrant.
- toCharArray() - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
- 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, Filter, boolean) - Constructor for class org.apache.lucene.search.join.ToChildBlockJoinQuery
- toDigitString() - Method in enum org.apache.lucene.queryParser.core.nodes.ModifierQueryNode.Modifier
- toDot() - Method in class org.apache.lucene.analysis.TokenStreamToDot
- toDot(Analyzer, String) - Method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
- toDot(FST<T>, Writer, boolean, boolean) - Static method in class org.apache.lucene.util.fst.Util
-
Dumps an
FST
to a GraphViz'sdot
language description for visualization. - toDotFile(Analyzer, String, String) - Method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
- Toffs(int, int) - Constructor for class org.apache.lucene.search.vectorhighlight.FieldPhraseList.WeightedPhraseInfo.Toffs
- toFixed() - Method in class org.apache.lucene.spatial.geometry.FixedLatLng
-
Deprecated.
- toFixed() - Method in class org.apache.lucene.spatial.geometry.FloatLatLng
-
Deprecated.
- toFixed() - Method in class org.apache.lucene.spatial.geometry.LatLng
-
Deprecated.
- toFloat() - Method in class org.apache.lucene.spatial.geometry.FixedLatLng
-
Deprecated.
- toFloat() - Method in class org.apache.lucene.spatial.geometry.FloatLatLng
-
Deprecated.
- toFloat() - Method in class org.apache.lucene.spatial.geometry.LatLng
-
Deprecated.
- toHashString() - Method in class org.apache.lucene.util.collections.IntHashSet
- toHtml() - Method in class org.apache.lucene.search.Explanation
-
Render an explanation as HTML.
- toImpl(FacetResultNode) - Static method in class org.apache.lucene.facet.search.results.MutableFacetResultNode
-
Internal utility: turn a result node into an implementation class with richer API that allows modifying it.
- toIndex(boolean, boolean) - Static method in enum org.apache.lucene.document.Field.Index
-
Get the best representation of the index given the flags.
- toIndex(boolean, boolean, boolean) - Static method in enum org.apache.lucene.document.Field.Index
-
Expert: Get the best representation of the index given the flags.
- toIntArray(Collection<Integer>) - Static method in class org.apache.lucene.util.ArrayUtil
- toIntsRef(BytesRef, IntsRef) - Static method in class org.apache.lucene.util.fst.Util
-
Just takes unsigned byte values from the BytesRef and converts into an IntsRef.
- token - Variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParser
-
Current token.
- token - Variable in class org.apache.lucene.queryParser.QueryParser
-
Current token.
- token - Variable in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParser
-
Current token.
- token - Variable in class org.apache.lucene.queryParser.surround.parser.QueryParser
-
Current token.
- Token - Class in org.apache.lucene.analysis.ja
-
Analyzed token with morphological data from its dictionary.
- Token - Class in org.apache.lucene.analysis
-
A Token is an occurrence of a term from the text of a field.
- Token - Class in org.apache.lucene.benchmark.byTask.feeds.demohtml
-
Describes the input token stream.
- Token - Class in org.apache.lucene.queryParser.standard.parser
-
Describes the input token stream.
- Token - Class in org.apache.lucene.queryParser.surround.parser
-
Describes the input token stream.
- Token - Class in org.apache.lucene.queryParser
-
Describes the input token stream.
- Token() - Constructor for class org.apache.lucene.analysis.Token
-
Constructs a Token will null text.
- Token() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.demohtml.Token
-
No-argument constructor
- Token() - Constructor for class org.apache.lucene.queryParser.standard.parser.Token
-
No-argument constructor
- Token() - Constructor for class org.apache.lucene.queryParser.surround.parser.Token
-
No-argument constructor
- Token() - Constructor for class org.apache.lucene.queryParser.Token
-
No-argument constructor
- Token(char[], int, int, int, int) - Constructor for class org.apache.lucene.analysis.Token
-
Constructs a Token with the given term buffer (offset & length), start and end offsets
- Token(int) - Constructor for class org.apache.lucene.benchmark.byTask.feeds.demohtml.Token
-
Constructs a new token for the specified Image.
- Token(int) - Constructor for class org.apache.lucene.queryParser.standard.parser.Token
-
Constructs a new token for the specified Image.
- Token(int) - Constructor for class org.apache.lucene.queryParser.surround.parser.Token
-
Constructs a new token for the specified Image.
- Token(int) - Constructor for class org.apache.lucene.queryParser.Token
-
Constructs a new token for the specified Image.
- Token(int, char[], int, int, JapaneseTokenizer.Type, int, Dictionary) - Constructor for class org.apache.lucene.analysis.ja.Token
- Token(int, int) - Constructor for class org.apache.lucene.analysis.Token
-
Constructs a Token with null text and start & end offsets.
- Token(int, int, int) - Constructor for class org.apache.lucene.analysis.Token
-
Constructs a Token with null text and start & end offsets plus flags.
- Token(int, int, String) - Constructor for class org.apache.lucene.analysis.Token
-
Constructs a Token with null text and start & end offsets plus the Token type.
- Token(int, String) - Constructor for class org.apache.lucene.benchmark.byTask.feeds.demohtml.Token
-
Constructs a new token for the specified Image and Kind.
- Token(int, String) - Constructor for class org.apache.lucene.queryParser.standard.parser.Token
-
Constructs a new token for the specified Image and Kind.
- Token(int, String) - Constructor for class org.apache.lucene.queryParser.surround.parser.Token
-
Constructs a new token for the specified Image and Kind.
- Token(int, String) - Constructor for class org.apache.lucene.queryParser.Token
-
Constructs a new token for the specified Image and Kind.
- Token(String, int, int) - Constructor for class org.apache.lucene.analysis.Token
-
Constructs a Token with the given term text, and start & end offsets.
- Token(String, int, int, int) - Constructor for class org.apache.lucene.analysis.Token
-
Constructs a Token with the given text, start and end offsets, & type.
- Token(String, int, int, String) - Constructor for class org.apache.lucene.analysis.Token
-
Constructs a Token with the given text, start and end offsets, & type.
- 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_SEPARATOR - Static variable in class org.apache.lucene.analysis.shingle.ShingleFilter
-
The default string to use when joining adjacent tokens to form a shingle
- token_source - Variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParser
-
Generated Token Manager.
- token_source - Variable in class org.apache.lucene.queryParser.QueryParser
-
Generated Token Manager.
- token_source - Variable in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParser
-
Generated Token Manager.
- token_source - Variable in class org.apache.lucene.queryParser.surround.parser.QueryParser
-
Generated Token Manager.
- TOKEN_TYPE_FULL_PREC - Static variable in class org.apache.lucene.analysis.NumericTokenStream
-
The full precision token gets this token type assigned.
- TOKEN_TYPE_LOWER_PREC - Static variable in class org.apache.lucene.analysis.NumericTokenStream
-
The lower precision tokens gets this token type assigned.
- 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
- Token.TokenAttributeFactory - Class in org.apache.lucene.analysis
-
Expert: Creates a TokenAttributeFactory returning
Token
as instance for the basic attributes and for all other attributes calls the given delegate factory. - TokenAttributeFactory(AttributeSource.AttributeFactory) - Constructor for class org.apache.lucene.analysis.Token.TokenAttributeFactory
-
Expert: Creates an AttributeFactory returning
Token
as instance for the basic attributes and for all other attributes calls the given delegate factory. - 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.
- 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 - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
Literal token values.
- tokenImage - Variable in exception org.apache.lucene.benchmark.byTask.feeds.demohtml.ParseException
-
This is a reference to the "tokenImage" array of the generated parser within which the parse error occurred.
- tokenImage - Variable in exception org.apache.lucene.queryParser.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.QueryParserConstants
-
Literal token values.
- tokenImage - Variable in exception org.apache.lucene.queryParser.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.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.
- 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
- TokenizedPhraseQueryNode - Class in org.apache.lucene.queryParser.core.nodes
-
A
TokenizedPhraseQueryNode
represents a node created by a code that tokenizes/lemmatizes/analyzes. - TokenizedPhraseQueryNode() - Constructor for class org.apache.lucene.queryParser.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
-
Deprecated.use
Tokenizer(Reader)
instead. - Tokenizer(Reader) - Constructor for class org.apache.lucene.analysis.Tokenizer
-
Construct a token stream processing the given input.
- Tokenizer(AttributeSource) - Constructor for class org.apache.lucene.analysis.Tokenizer
-
Deprecated.use
Tokenizer(AttributeSource, Reader)
instead. - Tokenizer(AttributeSource.AttributeFactory) - Constructor for class org.apache.lucene.analysis.Tokenizer
-
Deprecated.use
Tokenizer(AttributeSource.AttributeFactory, Reader)
instead. - Tokenizer(AttributeSource.AttributeFactory, Reader) - Constructor for class org.apache.lucene.analysis.Tokenizer
-
Construct a token stream processing the given input using the given AttributeFactory.
- Tokenizer(AttributeSource, Reader) - Constructor for class org.apache.lucene.analysis.Tokenizer
-
Construct a token stream processing the given input using the given AttributeSource.
- TokenMgrError - Error in org.apache.lucene.benchmark.byTask.feeds.demohtml
-
Token Manager Error.
- TokenMgrError - Error in org.apache.lucene.queryParser.standard.parser
-
Token Manager Error.
- TokenMgrError - Error in org.apache.lucene.queryParser.surround.parser
-
Token Manager Error.
- TokenMgrError - Error in org.apache.lucene.queryParser
-
Token Manager Error.
- TokenMgrError() - Constructor for error org.apache.lucene.benchmark.byTask.feeds.demohtml.TokenMgrError
-
No arg constructor.
- TokenMgrError() - Constructor for error org.apache.lucene.queryParser.standard.parser.TokenMgrError
-
No arg constructor.
- TokenMgrError() - Constructor for error org.apache.lucene.queryParser.surround.parser.TokenMgrError
-
No arg constructor.
- TokenMgrError() - Constructor for error org.apache.lucene.queryParser.TokenMgrError
-
No arg constructor.
- TokenMgrError(boolean, int, int, int, String, char, int) - Constructor for error org.apache.lucene.benchmark.byTask.feeds.demohtml.TokenMgrError
-
Full Constructor.
- TokenMgrError(boolean, int, int, int, String, char, int) - Constructor for error org.apache.lucene.queryParser.standard.parser.TokenMgrError
-
Full Constructor.
- TokenMgrError(boolean, int, int, int, String, char, int) - Constructor for error org.apache.lucene.queryParser.surround.parser.TokenMgrError
-
Full Constructor.
- TokenMgrError(boolean, int, int, int, String, char, int) - Constructor for error org.apache.lucene.queryParser.TokenMgrError
-
Full Constructor.
- TokenMgrError(String, int) - Constructor for error org.apache.lucene.benchmark.byTask.feeds.demohtml.TokenMgrError
-
Constructor with message and reason.
- TokenMgrError(String, int) - Constructor for error org.apache.lucene.queryParser.standard.parser.TokenMgrError
-
Constructor with message and reason.
- TokenMgrError(String, int) - Constructor for error org.apache.lucene.queryParser.surround.parser.TokenMgrError
-
Constructor with message and reason.
- TokenMgrError(String, int) - Constructor for error org.apache.lucene.queryParser.TokenMgrError
-
Constructor with message and reason.
- TokenOffsetPayloadTokenFilter - Class in org.apache.lucene.analysis.payloads
-
Adds the
Token.setStartOffset(int)
andToken.setEndOffset(int)
First 4 bytes are the start - TokenOffsetPayloadTokenFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.payloads.TokenOffsetPayloadTokenFilter
- TokenRangeSinkFilter - Class in org.apache.lucene.analysis.sinks
-
Counts the tokens as they go by and saves to the internal list those between the range of lower and upper, exclusive of upper
- TokenRangeSinkFilter(int, int) - Constructor for class org.apache.lucene.analysis.sinks.TokenRangeSinkFilter
- 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
- TokenSettingsCodec() - Constructor for class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.TokenSettingsCodec
-
Deprecated.
- TokenSources - Class in org.apache.lucene.search.highlight
-
Hides implementation issues associated with obtaining a TokenStream for use with the higlighter - can obtain from TermFreqVectors with offsets and (optionally) positions or from Analyzer class reparsing the stored content.
- TokenSources() - Constructor for class org.apache.lucene.search.highlight.TokenSources
- tokenStream - Variable in class org.apache.lucene.document.AbstractField
- tokenStream(String, Reader) - Method in class org.apache.lucene.analysis.Analyzer
-
Creates a TokenStream which tokenizes all the text in the provided Reader.
- tokenStream(String, Reader) - Method in class org.apache.lucene.analysis.cn.smart.SmartChineseAnalyzer
- tokenStream(String, Reader) - Method in class org.apache.lucene.analysis.LimitTokenCountAnalyzer
- tokenStream(String, Reader) - Method in class org.apache.lucene.analysis.MockAnalyzer
- tokenStream(String, Reader) - Method in class org.apache.lucene.analysis.PerFieldAnalyzerWrapper
- tokenStream(String, Reader) - Method in class org.apache.lucene.analysis.query.QueryAutoStopWordAnalyzer
- tokenStream(String, Reader) - Method in class org.apache.lucene.analysis.ReusableAnalyzerBase
-
This method uses
ReusableAnalyzerBase.createComponents(String, Reader)
to obtain an instance ofReusableAnalyzerBase.TokenStreamComponents
and returns the sink of the components. - tokenStream(String, Reader) - Method in class org.apache.lucene.analysis.shingle.ShingleAnalyzerWrapper
- tokenStream(String, Reader) - Method in class org.apache.lucene.analysis.snowball.SnowballAnalyzer
-
Deprecated.Constructs a
StandardTokenizer
filtered by aStandardFilter
, aLowerCaseFilter
, aStopFilter
, and aSnowballFilter
- tokenStream(String, Reader) - Method in class org.apache.lucene.collation.CollationKeyAnalyzer
- tokenStream(String, Reader) - Method in class org.apache.lucene.collation.ICUCollationKeyAnalyzer
- tokenStream(String, Reader) - Method in class org.apache.lucene.queryParser.QueryParserTestBase.QPTestAnalyzer
- TokenStream - Class in org.apache.lucene.analysis
- 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(AttributeSource.AttributeFactory) - Constructor for class org.apache.lucene.analysis.TokenStream
-
A TokenStream using the supplied AttributeFactory for creating new
Attribute
instances. - TokenStreamComponents(Tokenizer) - Constructor for class org.apache.lucene.analysis.ReusableAnalyzerBase.TokenStreamComponents
-
Creates a new
ReusableAnalyzerBase.TokenStreamComponents
instance. - TokenStreamComponents(Tokenizer, TokenStream) - Constructor for class org.apache.lucene.analysis.ReusableAnalyzerBase.TokenStreamComponents
-
Creates a new
ReusableAnalyzerBase.TokenStreamComponents
instance. - TokenStreamFromTermPositionVector - Class in org.apache.lucene.search.highlight
- TokenStreamFromTermPositionVector(TermPositionVector) - Constructor for class org.apache.lucene.search.highlight.TokenStreamFromTermPositionVector
-
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.
- tokenStreamValue() - Method in class org.apache.lucene.document.Field
-
The TokesStream for this field to be used when indexing, or null.
- tokenStreamValue() - Method in interface org.apache.lucene.document.Fieldable
-
The TokenStream for this field to be used when indexing, or null.
- tokenStreamValue() - Method in class org.apache.lucene.document.NumericField
-
Returns a
NumericTokenStream
for indexing the numeric value. - TokenTypeSinkFilter - Class in org.apache.lucene.analysis.sinks
-
Adds a token to the sink if it has a specific type.
- TokenTypeSinkFilter(String) - Constructor for class org.apache.lucene.analysis.sinks.TokenTypeSinkFilter
- toLargeString() - Method in enum org.apache.lucene.queryParser.core.nodes.ModifierQueryNode.Modifier
- toLowerCase(CharSequence) - Static method in class org.apache.lucene.queryParser.core.util.UnescapedCharSequence
- TOO_MANY_BOOLEAN_CLAUSES - Static variable in class org.apache.lucene.queryParser.core.messages.QueryParserMessages
- 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.
- 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 interface org.apache.lucene.facet.search.Heap
-
Get (But not remove) the top of the Heap
- top() - Method in class org.apache.lucene.util.PriorityQueue
-
Returns the least element of the PriorityQueue in constant time.
- top() - Method in class org.apache.lucene.util.ScorerDocQueue
-
Deprecated.Returns the least Scorer of the ScorerDocQueue in constant time.
- ToParentBlockJoinCollector - Class in org.apache.lucene.search.join
-
Collects parent document hits for a Query containing one more more BlockJoinQuery clauses, sorted by the specified parent Sort.
- ToParentBlockJoinCollector(Sort, int, boolean, boolean) - Constructor for class org.apache.lucene.search.join.ToParentBlockJoinCollector
- ToParentBlockJoinQuery - Class in org.apache.lucene.search.join
-
This query requires that you index children and parent docs as a single block, using the
IndexWriter.addDocuments(java.util.Collection<org.apache.lucene.document.Document>)
orIndexWriter.updateDocuments(org.apache.lucene.index.Term, java.util.Collection<org.apache.lucene.document.Document>)
API. - ToParentBlockJoinQuery(Query, Filter, ToParentBlockJoinQuery.ScoreMode) - Constructor for class org.apache.lucene.search.join.ToParentBlockJoinQuery
-
Create a ToParentBlockJoinQuery.
- ToParentBlockJoinQuery.ScoreMode - Enum in org.apache.lucene.search.join
-
How to aggregate multiple child hit scores into a single parent score.
- topDoc() - Method in class org.apache.lucene.util.ScorerDocQueue
-
Deprecated.Returns document number of the least Scorer of the ScorerDocQueue in constant time.
- 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 rage [start ..
- topDocs(int, int) - Method in class org.apache.lucene.search.TopDocsCollector
-
Returns the documents in the rage [start ..
- TopDocs - Class in org.apache.lucene.search
-
Represents hits returned by
Searcher.search(Query,Filter,int)
andSearcher.search(Query,int)
. - TopDocs(int, ScoreDoc[], float) - Constructor for class org.apache.lucene.search.TopDocs
- TopDocsCollector<T extends ScoreDoc> - Class in org.apache.lucene.search
-
A base class for all collectors that return a
TopDocs
output. - TopDocsCollector(PriorityQueue<T>) - Constructor for class org.apache.lucene.search.TopDocsCollector
- topDocsSize() - Method in class org.apache.lucene.search.TopDocsCollector
-
The number of valid PQ entries
- 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
-
Represents hits returned by
Searcher.search(Query,Filter,int,Sort)
. - TopFieldDocs(int, ScoreDoc[], SortField[], float) - Constructor for class org.apache.lucene.search.TopFieldDocs
-
Creates one of these objects.
- TopGroups<GROUP_VALUE_TYPE> - Class in org.apache.lucene.search.grouping
-
Represents result returned by a grouping search.
- TopGroups(TopGroups<GROUP_VALUE_TYPE>, Integer) - Constructor for class org.apache.lucene.search.grouping.TopGroups
- TopGroups(SortField[], SortField[], int, int, GroupDocs<GROUP_VALUE_TYPE>[]) - Constructor for class org.apache.lucene.search.grouping.TopGroups
- TopKFacetResultsHandler - Class in org.apache.lucene.facet.search
-
Generate Top-K results for a particular FacetRequest.
- TopKFacetResultsHandler(TaxonomyReader, FacetRequest) - Constructor for class org.apache.lucene.facet.search.TopKFacetResultsHandler
-
Construct top-K results handler.
- TopKInEachNodeHandler - Class in org.apache.lucene.facet.search
-
Generates
FacetResult
from the count arrays aggregated for a particularFacetRequest
. - TopKInEachNodeHandler(TaxonomyReader, FacetRequest) - Constructor for class org.apache.lucene.facet.search.TopKInEachNodeHandler
- TopKInEachNodeHandler.IntermediateFacetResultWithHash - Class in org.apache.lucene.facet.search
-
Intermediate result to hold counts from one or more partitions processed thus far.
- TopLevelQuery(CharSequence) - Method in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParser
- TopLevelQuery(String) - Method in class org.apache.lucene.queryParser.QueryParser
- topNextAndAdjustElsePop() - Method in class org.apache.lucene.util.ScorerDocQueue
-
Deprecated.
- topScore() - Method in class org.apache.lucene.util.ScorerDocQueue
-
Deprecated.
- TopScoreDocCollector - Class in org.apache.lucene.search
- topSkipToAndAdjustElsePop(int) - Method in class org.apache.lucene.util.ScorerDocQueue
-
Deprecated.
- TopSrndQuery() - Method in class org.apache.lucene.queryParser.surround.parser.QueryParser
- TopTermsBoostOnlyBooleanQueryRewrite(int) - Constructor for class org.apache.lucene.search.MultiTermQuery.TopTermsBoostOnlyBooleanQueryRewrite
-
Create a TopTermsBoostOnlyBooleanQueryRewrite for at most
size
terms. - TopTermsRewrite<Q extends Query> - 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. - toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryParser.core.nodes.AndQueryNode
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryParser.core.nodes.AnyQueryNode
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryParser.core.nodes.BooleanQueryNode
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryParser.core.nodes.BoostQueryNode
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryParser.core.nodes.DeletedQueryNode
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryParser.core.nodes.FieldQueryNode
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryParser.core.nodes.FuzzyQueryNode
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryParser.core.nodes.GroupQueryNode
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryParser.core.nodes.MatchAllDocsQueryNode
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryParser.core.nodes.ModifierQueryNode
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryParser.core.nodes.NoTokenFoundQueryNode
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryParser.core.nodes.OpaqueQueryNode
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryParser.core.nodes.OrQueryNode
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryParser.core.nodes.ParametricQueryNode
-
Deprecated.
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryParser.core.nodes.ParametricRangeQueryNode
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryParser.core.nodes.PathQueryNode
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryParser.core.nodes.PhraseSlopQueryNode
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryParser.core.nodes.ProximityQueryNode
- toQueryString(EscapeQuerySyntax) - Method in interface org.apache.lucene.queryParser.core.nodes.QueryNode
-
convert to a query string understood by the query parser
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryParser.core.nodes.QuotedFieldQueryNode
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryParser.core.nodes.SlopQueryNode
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryParser.core.nodes.TokenizedPhraseQueryNode
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryParser.standard.nodes.AbstractRangeQueryNode
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryParser.standard.nodes.MultiPhraseQueryNode
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryParser.standard.nodes.NumericQueryNode
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryParser.standard.nodes.WildcardQueryNode
- toQueryStringIgnoreFields - Variable in class org.apache.lucene.queryParser.core.nodes.QueryNodeImpl
-
If set to true the the method toQueryString will not write field names
- toRectangle() - Method in class org.apache.lucene.spatial.geometry.shape.LLRect
-
Deprecated.Returns a rectangle shape for the bounding box
- 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.ja.Token
- toString() - Method in class org.apache.lucene.analysis.LimitTokenCountAnalyzer
- toString() - Method in class org.apache.lucene.analysis.NumericTokenStream
- toString() - Method in class org.apache.lucene.analysis.PerFieldAnalyzerWrapper
- toString() - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.Matrix.Column.Row
-
Deprecated.
- toString() - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.Matrix.Column
-
Deprecated.
- toString() - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.Matrix
-
Deprecated.
- 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.feeds.demohtml.Token
-
Returns the image.
- 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.document.AbstractField
-
Prints a Field for human consumption.
- 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.facet.enhancements.association.AssociationFloatProperty
- toString() - Method in class org.apache.lucene.facet.enhancements.association.AssociationProperty
- toString() - Method in class org.apache.lucene.facet.index.CategoryContainer
- toString() - Method in class org.apache.lucene.facet.search.params.FacetRequest
- toString() - Method in class org.apache.lucene.facet.search.params.FacetSearchParams
- toString() - Method in class org.apache.lucene.facet.search.results.FacetResult
- toString() - Method in class org.apache.lucene.facet.search.results.MutableFacetResultNode
- toString() - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
-
This method, an implementation of the
Object.toString()
interface, is to allow simple printing of a CategoryPath, for debugging purposes. - toString() - Method in class org.apache.lucene.index.FilterIndexReader
- toString() - Method in class org.apache.lucene.index.IndexReader
- toString() - Method in class org.apache.lucene.index.IndexWriter.MaxFieldLength
-
Deprecated.
- toString() - Method in class org.apache.lucene.index.IndexWriterConfig
- toString() - Method in class org.apache.lucene.index.LogMergePolicy
- toString() - Method in class org.apache.lucene.index.memory.MemoryIndex
-
Returns a String representation of the index data for debugging purposes.
- toString() - Method in class org.apache.lucene.index.NoMergePolicy
- toString() - Method in class org.apache.lucene.index.ParallelReader
- toString() - Method in class org.apache.lucene.index.SegmentInfo
- toString() - Method in class org.apache.lucene.index.SegmentReader
- toString() - Method in class org.apache.lucene.index.SlowMultiReaderWrapper
- toString() - Method in class org.apache.lucene.index.SnapshotDeletionPolicy.SnapshotCommitPoint
- toString() - Method in class org.apache.lucene.index.Term
- toString() - Method in class org.apache.lucene.index.TermVectorEntry
- toString() - Method in class org.apache.lucene.index.TieredMergePolicy
- toString() - Method in class org.apache.lucene.index.UpgradeIndexMergePolicy
- toString() - Method in class org.apache.lucene.messages.MessageImpl
-
Deprecated.
- toString() - Method in class org.apache.lucene.queryParser.core.config.FieldConfig
- toString() - Method in class org.apache.lucene.queryParser.core.nodes.AndQueryNode
- toString() - Method in class org.apache.lucene.queryParser.core.nodes.AnyQueryNode
- toString() - Method in class org.apache.lucene.queryParser.core.nodes.BooleanQueryNode
- toString() - Method in class org.apache.lucene.queryParser.core.nodes.BoostQueryNode
- toString() - Method in class org.apache.lucene.queryParser.core.nodes.DeletedQueryNode
- toString() - Method in class org.apache.lucene.queryParser.core.nodes.FieldQueryNode
- toString() - Method in class org.apache.lucene.queryParser.core.nodes.FuzzyQueryNode
- toString() - Method in class org.apache.lucene.queryParser.core.nodes.GroupQueryNode
- toString() - Method in class org.apache.lucene.queryParser.core.nodes.MatchAllDocsQueryNode
- toString() - Method in class org.apache.lucene.queryParser.core.nodes.MatchNoDocsQueryNode
- toString() - Method in enum org.apache.lucene.queryParser.core.nodes.ModifierQueryNode.Modifier
- toString() - Method in class org.apache.lucene.queryParser.core.nodes.ModifierQueryNode
- toString() - Method in class org.apache.lucene.queryParser.core.nodes.NoTokenFoundQueryNode
- toString() - Method in class org.apache.lucene.queryParser.core.nodes.OpaqueQueryNode
- toString() - Method in class org.apache.lucene.queryParser.core.nodes.OrQueryNode
- toString() - Method in class org.apache.lucene.queryParser.core.nodes.ParametricQueryNode
-
Deprecated.
- toString() - Method in class org.apache.lucene.queryParser.core.nodes.ParametricRangeQueryNode
- toString() - Method in class org.apache.lucene.queryParser.core.nodes.PathQueryNode.QueryText
- toString() - Method in class org.apache.lucene.queryParser.core.nodes.PathQueryNode
- toString() - Method in class org.apache.lucene.queryParser.core.nodes.PhraseSlopQueryNode
- toString() - Method in class org.apache.lucene.queryParser.core.nodes.ProximityQueryNode
- toString() - Method in interface org.apache.lucene.queryParser.core.nodes.QueryNode
-
for printing
- toString() - Method in class org.apache.lucene.queryParser.core.nodes.QueryNodeImpl
-
Every implementation of this class should return pseudo xml like this: For FieldQueryNode:
- toString() - Method in class org.apache.lucene.queryParser.core.nodes.QuotedFieldQueryNode
- toString() - Method in class org.apache.lucene.queryParser.core.nodes.SlopQueryNode
- toString() - Method in class org.apache.lucene.queryParser.core.nodes.TokenizedPhraseQueryNode
- toString() - Method in exception org.apache.lucene.queryParser.core.QueryNodeException
- toString() - Method in class org.apache.lucene.queryParser.core.util.UnescapedCharSequence
- toString() - Method in class org.apache.lucene.queryParser.standard.config.AllowLeadingWildcardAttributeImpl
-
Deprecated.
- toString() - Method in class org.apache.lucene.queryParser.standard.config.AnalyzerAttributeImpl
-
Deprecated.
- toString() - Method in class org.apache.lucene.queryParser.standard.config.BoostAttributeImpl
-
Deprecated.
- toString() - Method in class org.apache.lucene.queryParser.standard.config.DateResolutionAttributeImpl
-
Deprecated.
- toString() - Method in class org.apache.lucene.queryParser.standard.config.DefaultOperatorAttributeImpl
-
Deprecated.
- toString() - Method in class org.apache.lucene.queryParser.standard.config.DefaultPhraseSlopAttributeImpl
-
Deprecated.
- toString() - Method in class org.apache.lucene.queryParser.standard.config.FieldBoostMapAttributeImpl
-
Deprecated.
- toString() - Method in class org.apache.lucene.queryParser.standard.config.FieldDateResolutionMapAttributeImpl
-
Deprecated.
- toString() - Method in class org.apache.lucene.queryParser.standard.config.FuzzyAttributeImpl
-
Deprecated.
- toString() - Method in class org.apache.lucene.queryParser.standard.config.LocaleAttributeImpl
-
Deprecated.
- toString() - Method in class org.apache.lucene.queryParser.standard.config.LowercaseExpandedTermsAttributeImpl
-
Deprecated.
- toString() - Method in class org.apache.lucene.queryParser.standard.config.MultiFieldAttributeImpl
-
Deprecated.
- toString() - Method in class org.apache.lucene.queryParser.standard.config.MultiTermRewriteMethodAttributeImpl
-
Deprecated.
- toString() - Method in class org.apache.lucene.queryParser.standard.config.PositionIncrementsAttributeImpl
-
Deprecated.
- toString() - Method in class org.apache.lucene.queryParser.standard.config.RangeCollatorAttributeImpl
-
Deprecated.
- toString() - Method in class org.apache.lucene.queryParser.standard.nodes.MultiPhraseQueryNode
- toString() - Method in class org.apache.lucene.queryParser.standard.nodes.NumericQueryNode
- toString() - Method in class org.apache.lucene.queryParser.standard.nodes.NumericRangeQueryNode
- toString() - Method in class org.apache.lucene.queryParser.standard.nodes.PrefixWildcardQueryNode
- toString() - Method in class org.apache.lucene.queryParser.standard.nodes.RangeQueryNode
-
Deprecated.
- toString() - Method in class org.apache.lucene.queryParser.standard.nodes.WildcardQueryNode
- toString() - Method in class org.apache.lucene.queryParser.standard.parser.Token
-
Returns the image.
- toString() - Method in class org.apache.lucene.queryParser.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.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.queryParser.Token
-
Returns the image.
- toString() - Method in class org.apache.lucene.search.BooleanClause
- toString() - Method in class org.apache.lucene.search.BooleanFilter
-
Prints a user-readable version of this Filter.
- toString() - Method in class org.apache.lucene.search.CachingSpanFilter
- toString() - Method in class org.apache.lucene.search.CachingWrapperFilter
- toString() - Method in class org.apache.lucene.search.CachingWrapperFilterHelper
- toString() - Method in class org.apache.lucene.search.ChainedFilter
- toString() - Method in class org.apache.lucene.search.Explanation
-
Render an explanation as text.
- toString() - Method in class org.apache.lucene.search.FieldCache.CacheEntry
- toString() - Method in class org.apache.lucene.search.FieldCacheRangeFilter
- toString() - Method in class org.apache.lucene.search.FieldDoc
- toString() - Method in class org.apache.lucene.search.FieldValueFilter
- toString() - Method in class org.apache.lucene.search.FieldValueHitQueue.Entry
- toString() - Method in class org.apache.lucene.search.FilterClause
- toString() - Method in class org.apache.lucene.search.function.FieldScoreQuery.Type
- toString() - Method in class org.apache.lucene.search.function.ValueSource
- toString() - Method in class org.apache.lucene.search.grouping.SearchGroup
- toString() - Method in class org.apache.lucene.search.highlight.TextFragment
- toString() - Method in class org.apache.lucene.search.IndexSearcher
- toString() - Method in class org.apache.lucene.search.MultiTermQueryWrapperFilter
- toString() - Method in class org.apache.lucene.search.PrefixFilter
-
Prints a user-readable version of this query.
- toString() - Method in class org.apache.lucene.search.Query
-
Prints a query to a string.
- toString() - Method in class org.apache.lucene.search.QueryTermVector
- toString() - Method in class org.apache.lucene.search.QueryWrapperFilter
- toString() - Method in class org.apache.lucene.search.ScoreDoc
- toString() - Method in class org.apache.lucene.search.Sort
- toString() - Method in class org.apache.lucene.search.SortField
- toString() - Method in class org.apache.lucene.search.SpanQueryFilter
- toString() - Method in class org.apache.lucene.search.spans.NearSpansOrdered
- toString() - Method in class org.apache.lucene.search.spans.NearSpansUnordered
- toString() - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery.PositionCheckSpan
- toString() - Method in class org.apache.lucene.search.spans.TermSpans
- toString() - Method in class org.apache.lucene.search.suggest.fst.FSTCompletion.Completion
- toString() - Method in class org.apache.lucene.search.suggest.fst.Sort.SortInfo
- toString() - Method in class org.apache.lucene.search.suggest.Lookup.LookupResult
- 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() - Method in class org.apache.lucene.spatial.geometry.CartesianPoint
-
Deprecated.
- toString() - Method in class org.apache.lucene.spatial.geometry.LatLng
-
Deprecated.
- toString() - Method in class org.apache.lucene.spatial.geometry.shape.LLRect
-
Deprecated.
- toString() - Method in class org.apache.lucene.spatial.geometry.shape.Point2D
-
Deprecated.
- toString() - Method in class org.apache.lucene.spatial.geometry.shape.Rectangle
-
Deprecated.
- toString() - Method in class org.apache.lucene.spatial.tier.DistanceQueryBuilder
-
Deprecated.
- toString() - Method in class org.apache.lucene.store.Directory
- toString() - Method in class org.apache.lucene.store.FSDirectory
-
For debug output.
- toString() - Method in class org.apache.lucene.store.IndexInput
- toString() - Method in class org.apache.lucene.store.instantiated.InstantiatedDocument
- toString() - Method in class org.apache.lucene.store.instantiated.InstantiatedTerm
- toString() - Method in class org.apache.lucene.store.instantiated.InstantiatedTermFreqVector
- toString() - Method in class org.apache.lucene.store.MockDirectoryWrapper
- toString() - Method in class org.apache.lucene.store.MockLockFactoryWrapper
- toString() - Method in class org.apache.lucene.store.NRTCachingDirectory
- toString() - Method in class org.apache.lucene.util.AttributeImpl
-
Returns a string representation of the object.
- toString() - Method in class org.apache.lucene.util.AttributeSource
-
Returns a string representation of the object.
- 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.collections.ArrayHashMap
- toString() - Method in class org.apache.lucene.util.collections.FloatToObjectMap
- toString() - Method in class org.apache.lucene.util.collections.IntArray
-
toString or not toString.
- toString() - Method in class org.apache.lucene.util.collections.IntHashSet
-
I have no idea why would anyone call it - but for debug purposes.
Prints the entire map, including the index, key, object, next and prev. - toString() - Method in class org.apache.lucene.util.collections.IntToDoubleMap
- toString() - Method in class org.apache.lucene.util.collections.IntToIntMap
- toString() - Method in class org.apache.lucene.util.collections.IntToObjectMap
- toString() - Method in class org.apache.lucene.util.collections.ObjectToFloatMap
- toString() - Method in class org.apache.lucene.util.collections.ObjectToIntMap
- toString() - Method in class org.apache.lucene.util.encoding.DGapIntDecoder
- toString() - Method in class org.apache.lucene.util.encoding.DGapIntEncoder
- toString() - Method in class org.apache.lucene.util.encoding.EightFlagsIntDecoder
- toString() - Method in class org.apache.lucene.util.encoding.EightFlagsIntEncoder
- toString() - Method in class org.apache.lucene.util.encoding.FourFlagsIntDecoder
- toString() - Method in class org.apache.lucene.util.encoding.FourFlagsIntEncoder
- toString() - Method in class org.apache.lucene.util.encoding.NOnesIntDecoder
- toString() - Method in class org.apache.lucene.util.encoding.NOnesIntEncoder
- toString() - Method in class org.apache.lucene.util.encoding.SimpleIntDecoder
- toString() - Method in class org.apache.lucene.util.encoding.SimpleIntEncoder
- toString() - Method in class org.apache.lucene.util.encoding.SortingIntEncoder
- toString() - Method in class org.apache.lucene.util.encoding.UniqueValuesIntEncoder
- toString() - Method in class org.apache.lucene.util.encoding.VInt8IntDecoder
- toString() - Method in class org.apache.lucene.util.encoding.VInt8IntEncoder
- toString() - Method in class org.apache.lucene.util.FieldCacheSanityChecker.Insanity
-
Multi-Line representation of this Insanity object, starting with the Type and Msg, followed by each CacheEntry.toString() on it's own line prefaced by a tab character
- toString() - Method in class org.apache.lucene.util.FieldCacheSanityChecker.InsanityType
- toString() - Method in class org.apache.lucene.util.fst.FST.Arc
- 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.IntsRef
- toString() - Method in class org.apache.lucene.util.Parameter
-
Deprecated.
- toString() - Method in enum org.apache.lucene.util.RamUsageEstimator.JvmFeature
- toString(char) - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
-
Build a string representation of the path, with its components separated by the given delimiter character.
- toString(char, int) - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
-
like
CategoryPath.toString(char)
, but takes only a prefix with a given number of components, rather than the whole path. - toString(char, int, int) - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
-
like
CategoryPath.toString(char)
, but takes only a part of the path, rather than the whole path. - toString(int) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyReader
- toString(int) - Method in class org.apache.lucene.search.Explanation
- toString(int) - Method in class org.apache.lucene.search.function.DocValues
-
Return a string representation of a doc value, as required for Explanations.
- toString(Object) - Static method in class org.apache.lucene.queryParser.core.util.StringUtils
- toString(String) - Method in class org.apache.lucene.facet.search.results.FacetResult
-
String representation of this facet result.
- toString(String) - Method in interface org.apache.lucene.facet.search.results.FacetResultNode
-
String representation of this facet result node.
- toString(String) - Method in class org.apache.lucene.facet.search.results.MutableFacetResultNode
- 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.BoostingQuery
- toString(String) - Method in class org.apache.lucene.search.ConstantScoreQuery
- toString(String) - Method in class org.apache.lucene.search.DisjunctionMaxQuery
-
Prettyprint us.
- toString(String) - Method in class org.apache.lucene.search.FilteredQuery
-
Prints a user-readable version of this query.
- toString(String) - Method in class org.apache.lucene.search.function.CustomScoreQuery
- toString(String) - Method in class org.apache.lucene.search.function.ValueSourceQuery
- toString(String) - Method in class org.apache.lucene.search.FuzzyLikeThisQuery
- toString(String) - Method in class org.apache.lucene.search.FuzzyQuery
- toString(String) - Method in class org.apache.lucene.search.join.ToChildBlockJoinQuery
- toString(String) - Method in class org.apache.lucene.search.join.ToParentBlockJoinQuery
- toString(String) - Method in class org.apache.lucene.search.MatchAllDocsQuery
- 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.NumericRangeQuery
- toString(String) - Method in class org.apache.lucene.search.payloads.PayloadNearQuery
- 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.PrefixQuery
-
Prints a user-readable version of this query.
- toString(String) - Method in class org.apache.lucene.search.Query
-
Prints a query to a string, with
field
assumed to be the default field and omitted. - toString(String) - Method in class org.apache.lucene.search.regex.RegexQuery
- toString(String) - Method in class org.apache.lucene.search.similar.MoreLikeThisQuery
- toString(String) - Method in class org.apache.lucene.search.spans.FieldMaskingSpanQuery
- 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.SpanNearPayloadCheckQuery
- 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.SpanPayloadCheckQuery
- toString(String) - Method in class org.apache.lucene.search.spans.SpanPositionRangeQuery
- toString(String) - Method in class org.apache.lucene.search.spans.SpanTermQuery
- toString(String) - Method in class org.apache.lucene.search.TermQuery
-
Prints a user-readable version of this query.
- toString(String) - Method in class org.apache.lucene.search.TermRangeQuery
-
Prints a user-readable version of this query.
- toString(String) - Method in class org.apache.lucene.search.WildcardQuery
-
Prints a user-readable version of this query.
- toString(Directory) - Method in class org.apache.lucene.index.SegmentInfos
- toString(Directory, int) - Method in class org.apache.lucene.index.SegmentInfo
-
Used for debugging.
- toStringEscaped() - Method in class org.apache.lucene.queryParser.core.util.UnescapedCharSequence
-
Return a escaped String
- toStringEscaped(char[]) - Method in class org.apache.lucene.queryParser.core.util.UnescapedCharSequence
-
Return a escaped String
- 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()
. - Total - org.apache.lucene.search.join.ToParentBlockJoinQuery.ScoreMode
-
Parent hit's score is the sum of all child scores.
- totalBytesSize() - Method in class org.apache.lucene.index.MergePolicy.OneMerge
-
Returns the total size in bytes of this merge.
- totalDocCount - Variable in class org.apache.lucene.index.MergePolicy.OneMerge
- totalDocCount() - Method in class org.apache.lucene.index.SegmentInfos
-
Returns sum of all segment's docCounts.
- TotalFacetCounts - Class in org.apache.lucene.facet.search
-
Maintain Total Facet Counts per partition, for given parameters: Index reader of an index Taxonomy index reader Facet indexing params (and particularly the category list params) The total facet counts are maintained as an array of arrays of integers, where a separate array is kept for each partition.
- TotalFacetCountsCache - Class in org.apache.lucene.facet.search
-
Manage an LRU cache for
TotalFacetCounts
per index, taxonomy, and facet indexing params. - 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.TopGroups
-
Number of documents grouped into the topN groups
- 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.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.
- totalNumDocs() - Method in class org.apache.lucene.index.MergePolicy.OneMerge
-
Returns the total number of documents that are included with this merge.
- totalTime - Variable in class org.apache.lucene.search.suggest.fst.Sort.SortInfo
- toTermVector(boolean, boolean, boolean) - Static method in enum org.apache.lucene.document.Field.TermVector
-
Get the best representation of a TermVector given the flags.
- 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.
- touchFile(String) - Method in class org.apache.lucene.store.Directory
-
Deprecated.Lucene never uses this API; it will be removed in 4.0.
- touchFile(String) - Method in class org.apache.lucene.store.FileSwitchDirectory
-
Deprecated.
- touchFile(String) - Method in class org.apache.lucene.store.FSDirectory
-
Deprecated.Lucene never uses this API; it will be removed in 4.0.
- touchFile(String) - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
Deprecated.
- touchFile(String) - Method in class org.apache.lucene.store.NRTCachingDirectory
-
Deprecated.
- touchFile(String) - Method in class org.apache.lucene.store.RAMDirectory
-
Deprecated.Lucene never uses this API; it will be removed in 4.0.
- toUTF32(char[], int, int, IntsRef) - Static method in class org.apache.lucene.util.fst.Util
-
Decodes the Unicode codepoints from the provided char[] and places them in the provided scratch IntsRef, which must not be null, returning it.
- toUTF32(CharSequence, IntsRef) - 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.
- TrackingDirectBytesStartArray(int, AtomicLong) - Constructor for class org.apache.lucene.util.BytesRefHash.TrackingDirectBytesStartArray
- TrackingIndexWriter(IndexWriter) - Constructor for class org.apache.lucene.search.NRTManager.TrackingIndexWriter
- transformCriteria(Properties, InputStream, Result) - Static method in class org.apache.lucene.xmlparser.QueryTemplateManager
-
Slower transformation using an uncompiled stylesheet (suitable for development environment)
- transformCriteria(Properties, Templates, Result) - Static method in class org.apache.lucene.xmlparser.QueryTemplateManager
-
Fast transformation using a pre-compiled stylesheet (suitable for production environments)
- transformCriteria(Properties, Transformer, Result) - Static method in class org.apache.lucene.xmlparser.QueryTemplateManager
- translate(int, int) - Method in class org.apache.lucene.spatial.geometry.CartesianPoint
-
Deprecated.Return a new point translated in the x and y dimensions
- translate(Vector2D) - Method in class org.apache.lucene.spatial.geometry.shape.Ellipse
-
Deprecated.
- translate(Vector2D) - Method in interface org.apache.lucene.spatial.geometry.shape.Geometry2D
-
Deprecated.Translate according to the vector
- translate(Vector2D) - Method in class org.apache.lucene.spatial.geometry.shape.Rectangle
-
Deprecated.
- traversalSize - Variable in class org.apache.lucene.benchmark.byTask.tasks.SearchTravTask
- traversalSize() - Method in class org.apache.lucene.benchmark.byTask.tasks.ReadTask
-
Specify the number of hits to traverse.
- 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
-
Implements a
ContentSource
over the TREC collection. - 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
and 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
- Trie - Class in org.egothor.stemmer
-
A Trie is used to store a dictionary of words and their stems.
- 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.
- Trie(DataInput) - Constructor for class org.egothor.stemmer.Trie
-
Constructor for the Trie object.
- trim(int) - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
-
Trim the last components from the path.
- trimResult(FacetResult) - Method in class org.apache.lucene.facet.search.sampling.Sampler
-
Trim the input facet result.
Note: It is only valid to call this method with result obtained for a facet request created throughSampler.overSampledSearchParams(FacetSearchParams)
. - trimSubResults(int) - Method in class org.apache.lucene.facet.search.results.MutableFacetResultNode
-
Trim sub results to a given size.
- 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).
- trimTrailingZeros() - Method in class org.apache.lucene.util.OpenBitSet
-
Lowers numWords, the number of words in use, by checking for trailing zero words.
- truncatedToPrefixAndPattern() - Method in class org.apache.lucene.queryParser.surround.query.SrndTruncQuery
- 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.
- 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, otherwisefalse
. - 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.NRTManager
- tryIncRef(IndexSearcher) - Method in class org.apache.lucene.search.SearcherManager
- tryLock() - Method in class org.apache.lucene.util.DummyConcurrentLock
- tryLock(long, TimeUnit) - Method in class org.apache.lucene.util.DummyConcurrentLock
- TSTAutocomplete - Class in org.apache.lucene.search.suggest.tst
- TSTAutocomplete() - Constructor for class org.apache.lucene.search.suggest.tst.TSTAutocomplete
- TSTLookup - Class in org.apache.lucene.search.suggest.tst
- TSTLookup() - Constructor for class org.apache.lucene.search.suggest.tst.TSTLookup
- TSTNode(char, JaspellTernarySearchTrie.TSTNode) - Constructor for class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie.TSTNode
-
Constructor method.
- TurkishAnalyzer - Class in org.apache.lucene.analysis.tr
-
Analyzer
for Turkish. - TurkishAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.tr.TurkishAnalyzer
-
Builds an analyzer with the default stop words:
TurkishAnalyzer.DEFAULT_STOPWORD_FILE
. - TurkishAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.tr.TurkishAnalyzer
-
Builds an analyzer with the given stop words.
- TurkishAnalyzer(Version, Set<?>, Set<?>) - 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.
- TurkishStemmer - Class in org.tartarus.snowball.ext
-
Generated class implementing code defined by a snowball script.
- TurkishStemmer() - Constructor for class org.tartarus.snowball.ext.TurkishStemmer
- TVPositionInfo(int, boolean) - Constructor for class org.apache.lucene.index.PositionBasedTermVectorMapper.TVPositionInfo
- TWENTYFEET - org.apache.lucene.spatial.tier.DistanceHandler.Precision
-
Deprecated.
- TwoDimensionalNonWeightedSynonymTokenSettingsCodec() - Constructor for class org.apache.lucene.analysis.shingle.ShingleMatrixFilter.TwoDimensionalNonWeightedSynonymTokenSettingsCodec
-
Deprecated.
- TWOFEET - org.apache.lucene.spatial.tier.DistanceHandler.Precision
-
Deprecated.
- TWOHUNDREDFEET - org.apache.lucene.spatial.tier.DistanceHandler.Precision
-
Deprecated.
- TwoLongs(long, long) - Constructor for class org.apache.lucene.util.fst.UpToTwoPositiveIntOutputs.TwoLongs
- TwoPhaseCommit - Interface in org.apache.lucene.util
-
An interface for implementations that support 2-phase commit.
- TwoPhaseCommitTool - Class in org.apache.lucene.util
-
A utility for executing 2-phase commit on several objects.
- TwoPhaseCommitTool() - Constructor for class org.apache.lucene.util.TwoPhaseCommitTool
- TwoPhaseCommitTool.CommitFailException - Exception in org.apache.lucene.util
-
Thrown by
TwoPhaseCommitTool.execute(TwoPhaseCommit...)
when an object fails to commit(). - TwoPhaseCommitTool.PrepareCommitFailException - Exception in org.apache.lucene.util
-
Thrown by
TwoPhaseCommitTool.execute(TwoPhaseCommit...)
when an object fails to prepareCommit(). - TwoPhaseCommitTool.TwoPhaseCommitWrapper - Class in org.apache.lucene.util
-
A wrapper of a
TwoPhaseCommit
, which delegates all calls to the wrapped object, passing the specified commitData. - TwoPhaseCommitWrapper(TwoPhaseCommit, Map<String, String>) - Constructor for class org.apache.lucene.util.TwoPhaseCommitTool.TwoPhaseCommitWrapper
- txt - Variable in class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase.CompoundToken
- type() - Method in class org.apache.lucene.analysis.Token
-
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
-
Returns this Token's lexical type.
- TYPE_SYNONYM - Static variable in class org.apache.lucene.analysis.synonym.SynonymFilter
- TypeAsPayloadTokenFilter - Class in org.apache.lucene.analysis.payloads
-
Makes the
Token.type()
a payload. - TypeAsPayloadTokenFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.payloads.TypeAsPayloadTokenFilter
- TypeAttribute - Interface in org.apache.lucene.analysis.tokenattributes
-
A Token's lexical type.
- TypeAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
-
A Token's lexical type.
- TypeAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
- TypeAttributeImpl(String) - Constructor for class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
- TypeTokenFilter - Class in org.apache.lucene.analysis
-
Removes tokens whose types appear in a set of blocked types from a token stream.
- TypeTokenFilter(boolean, TokenStream, Set<String>) - Constructor for class org.apache.lucene.analysis.TypeTokenFilter
- TypeTokenFilter(boolean, TokenStream, Set<String>, boolean) - Constructor for class org.apache.lucene.analysis.TypeTokenFilter
U
- UAX29URLEmailAnalyzer - Class in org.apache.lucene.analysis.standard
-
Filters
UAX29URLEmailTokenizer
withStandardFilter
,LowerCaseFilter
andStopFilter
, using a list of English stop words. - UAX29URLEmailAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.standard.UAX29URLEmailAnalyzer
-
Builds an analyzer with the default stop words (
UAX29URLEmailAnalyzer.STOP_WORDS_SET
). - UAX29URLEmailAnalyzer(Version, Reader) - Constructor for class org.apache.lucene.analysis.standard.UAX29URLEmailAnalyzer
-
Builds an analyzer with the stop words from the given reader.
- UAX29URLEmailAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.standard.UAX29URLEmailAnalyzer
-
Builds an analyzer with the given stop words.
- UAX29URLEmailTokenizer - Class in org.apache.lucene.analysis.standard
-
This class implements Word Break rules from the Unicode Text Segmentation algorithm, as specified in Unicode Standard Annex #29 URLs and email addresses are also tokenized according to the relevant RFCs.
- UAX29URLEmailTokenizer(InputStream) - Constructor for class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
-
Deprecated.use
UAX29URLEmailTokenizer(Version, Reader)
instead. - UAX29URLEmailTokenizer(Reader) - Constructor for class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
-
Deprecated.use
UAX29URLEmailTokenizer(Version, Reader)
instead. - UAX29URLEmailTokenizer(AttributeSource.AttributeFactory, Reader) - Constructor for class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
-
Deprecated.
- UAX29URLEmailTokenizer(AttributeSource, Reader) - Constructor for class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
-
Deprecated.
- UAX29URLEmailTokenizer(Version, Reader) - Constructor for class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
-
Creates a new instance of the UAX29URLEmailTokenizer.
- UAX29URLEmailTokenizer(Version, AttributeSource.AttributeFactory, Reader) - Constructor for class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
-
Creates a new UAX29URLEmailTokenizer with a given
AttributeSource.AttributeFactory
- UAX29URLEmailTokenizer(Version, AttributeSource, Reader) - Constructor for class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
-
Creates a new UAX29URLEmailTokenizer with a given
AttributeSource
. - UAX29URLEmailTokenizerImpl - Class in org.apache.lucene.analysis.standard
-
This class implements Word Break rules from the Unicode Text Segmentation algorithm, as specified in Unicode Standard Annex #29 URLs and email addresses are also tokenized according to the relevant RFCs.
- UAX29URLEmailTokenizerImpl(InputStream) - Constructor for class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizerImpl
-
Creates a new scanner.
- UAX29URLEmailTokenizerImpl(Reader) - Constructor for class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizerImpl
-
Creates a new scanner There is also a java.io.InputStream version of this constructor.
- UAX29URLEmailTokenizerImpl31 - Class in org.apache.lucene.analysis.standard.std31
-
Deprecated.This class is only for exact backwards compatibility
- UAX29URLEmailTokenizerImpl31(InputStream) - Constructor for class org.apache.lucene.analysis.standard.std31.UAX29URLEmailTokenizerImpl31
-
Deprecated.Creates a new scanner.
- UAX29URLEmailTokenizerImpl31(Reader) - Constructor for class org.apache.lucene.analysis.standard.std31.UAX29URLEmailTokenizerImpl31
-
Deprecated.Creates a new scanner There is also a java.io.InputStream version of this constructor.
- UAX29URLEmailTokenizerImpl34 - Class in org.apache.lucene.analysis.standard.std34
-
Deprecated.This class is only for exact backwards compatibility
- UAX29URLEmailTokenizerImpl34(InputStream) - Constructor for class org.apache.lucene.analysis.standard.std34.UAX29URLEmailTokenizerImpl34
-
Deprecated.Creates a new scanner.
- UAX29URLEmailTokenizerImpl34(Reader) - Constructor for class org.apache.lucene.analysis.standard.std34.UAX29URLEmailTokenizerImpl34
-
Deprecated.Creates a new scanner There is also a java.io.InputStream version of this constructor.
- UncaughtExceptionEntry(Thread, Throwable) - Constructor for class org.apache.lucene.util.UncaughtExceptionsRule.UncaughtExceptionEntry
- UncaughtExceptionsRule - Class in org.apache.lucene.util
-
Subscribes to
Thread.setDefaultUncaughtExceptionHandler(java.lang.Thread.UncaughtExceptionHandler)
and causes test/ suite failures if uncaught exceptions are detected. - UncaughtExceptionsRule(LuceneTestCase) - Constructor for class org.apache.lucene.util.UncaughtExceptionsRule
- UncaughtExceptionsRule.UncaughtExceptionEntry - Class in org.apache.lucene.util
- UnCompiledNode(Builder<T>, int) - Constructor for class org.apache.lucene.util.fst.Builder.UnCompiledNode
- undeleteAll() - Method in class org.apache.lucene.index.IndexReader
-
Deprecated.Write support will be removed in Lucene 4.0. There will be no replacement for this method.
- UnescapedCharSequence - Class in org.apache.lucene.queryParser.core.util
-
CharsSequence with escaped chars information.
- UnescapedCharSequence(char[], boolean[], int, int) - Constructor for class org.apache.lucene.queryParser.core.util.UnescapedCharSequence
-
Create a escaped CharSequence
- UnescapedCharSequence(CharSequence) - Constructor for class org.apache.lucene.queryParser.core.util.UnescapedCharSequence
-
Create a non-escaped CharSequence
- UNI_REPLACEMENT_CHAR - Static variable in class org.apache.lucene.util.UnicodeUtil
- UNI_SUR_HIGH_END - Static variable in class org.apache.lucene.util.UnicodeUtil
- UNI_SUR_HIGH_START - Static variable in class org.apache.lucene.util.UnicodeUtil
- UNI_SUR_LOW_END - Static variable in class org.apache.lucene.util.UnicodeUtil
- UNI_SUR_LOW_START - Static variable in class org.apache.lucene.util.UnicodeUtil
- UnicodeUtil - Class in org.apache.lucene.util
-
Class to encode java's UTF16 char[] into UTF8 byte[] without always allocating a new byte[] as String.getBytes("UTF-8") does.
- UnicodeUtil.UTF16Result - Class in org.apache.lucene.util
-
Holds decoded UTF16 code units.
- UnicodeUtil.UTF8Result - Class in org.apache.lucene.util
-
Holds decoded UTF8 code units.
- uniformCmd(boolean) - Method in class org.egothor.stemmer.Row
-
Return the number of identical Cells (containing patch commands) in this Row.
- union(OpenBitSet) - Method in class org.apache.lucene.util.OpenBitSet
-
this = this OR other
- unionCount(OpenBitSet, OpenBitSet) - Static method in class org.apache.lucene.util.OpenBitSet
-
Returns the popcount or cardinality of the union of the two sets.
- uniqueStems(char[], int) - Method in class org.apache.lucene.analysis.hunspell.HunspellStemmer
-
Find the unique stem(s) of the provided word
- UniqueValuesIntEncoder - Class in org.apache.lucene.util.encoding
-
An
IntEncoderFilter
which ensures only unique values are encoded. - UniqueValuesIntEncoder(IntEncoder) - Constructor for class org.apache.lucene.util.encoding.UniqueValuesIntEncoder
-
Constructs a new instance with the given encoder.
- UnknownDictionary - Class in org.apache.lucene.analysis.ja.dict
-
Dictionary for unknown-word handling.
- UNLIMITED - Static variable in class org.apache.lucene.index.IndexWriter.MaxFieldLength
-
Deprecated.Sets the maximum field length to
Integer.MAX_VALUE
. - unlock() - Method in class org.apache.lucene.util.DummyConcurrentLock
- unlock(Directory) - Static method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
-
Forcibly unlocks the taxonomy in the named directory.
- unlock(Directory) - Static method in class org.apache.lucene.index.IndexWriter
-
Forcibly unlocks the index in the named directory.
- UNMAP_SUPPORTED - Static variable in class org.apache.lucene.store.MMapDirectory
-
true
, if this platform supports unmapping mmapped files. - unmodifiableMap(CharArrayMap<V>) - Static method in class org.apache.lucene.analysis.CharArrayMap
-
Returns an unmodifiable
CharArrayMap
. - unmodifiableSet(CharArraySet) - Static method in class org.apache.lucene.analysis.CharArraySet
-
Returns an unmodifiable
CharArraySet
. - unpackValues(int) - Method in class org.apache.lucene.analysis.compound.hyphenation.HyphenationTree
- UnsafeByteArrayInputStream - Class in org.apache.lucene.util
-
This class, much like
ByteArrayInputStream
uses a given buffer as a source of an InputStream. - UnsafeByteArrayInputStream() - Constructor for class org.apache.lucene.util.UnsafeByteArrayInputStream
-
Creates a new instance by not using any byte[] up front.
- UnsafeByteArrayInputStream(byte[]) - Constructor for class org.apache.lucene.util.UnsafeByteArrayInputStream
-
Creates an UnsafeByteArrayInputStream which uses a given byte array as the source of the stream.
- UnsafeByteArrayInputStream(byte[], int, int) - Constructor for class org.apache.lucene.util.UnsafeByteArrayInputStream
-
Creates an UnsafeByteArrayInputStream which uses a given byte array as the source of the stream, at the specific range: [startPos, endPos)
- UnsafeByteArrayOutputStream - Class in org.apache.lucene.util
-
This class is used as a wrapper to a byte array, extending
OutputStream
. - UnsafeByteArrayOutputStream() - Constructor for class org.apache.lucene.util.UnsafeByteArrayOutputStream
-
Constructs a new output stream, with a default allocated buffer which can later be obtained via
UnsafeByteArrayOutputStream.toByteArray()
. - UnsafeByteArrayOutputStream(byte[]) - Constructor for class org.apache.lucene.util.UnsafeByteArrayOutputStream
-
Constructs a new output stream, with a given buffer.
- UnsafeByteArrayOutputStream(byte[], int) - Constructor for class org.apache.lucene.util.UnsafeByteArrayOutputStream
-
Constructs a new output stream, with a given buffer.
- unsafeWrite(char) - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
- unsafeWrite(char[], int, int) - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
- unsafeWrite(int) - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
- unset(ConfigurationKey<T>) - Method in class org.apache.lucene.queryParser.core.config.AbstractQueryConfig
-
Unsets the given key and its value.
- unsetTag(CharSequence) - Method in interface org.apache.lucene.queryParser.core.nodes.QueryNode
-
Deprecated.use
QueryNode.unsetTag(String)
instead - unsetTag(CharSequence) - Method in class org.apache.lucene.queryParser.core.nodes.QueryNodeImpl
-
Deprecated.
- unsetTag(String) - Method in interface org.apache.lucene.queryParser.core.nodes.QueryNode
-
Unset a tag.
- unsetTag(String) - Method in class org.apache.lucene.queryParser.core.nodes.QueryNodeImpl
- UnsortedTermFreqIteratorWrapper - Class in org.apache.lucene.search.suggest
-
This wrapper buffers the incoming elements and makes sure they are in random order.
- UnsortedTermFreqIteratorWrapper(TermFreqIterator) - Constructor for class org.apache.lucene.search.suggest.UnsortedTermFreqIteratorWrapper
- UNSUPPORTED_NUMERIC_DATA_TYPE - Static variable in class org.apache.lucene.queryParser.core.messages.QueryParserMessages
- UNTOKENIZED_ONLY - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
-
Only output untokenized tokens, which are tokens that would normally be split into several tokens
- UNTOKENIZED_TOKEN_FLAG - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
-
This flag is used to indicate that the produced "Token" would, if
WikipediaTokenizer.TOKENS_ONLY
was used, produce multiple tokens. - unzip(File, File) - Static method in class org.apache.lucene.util._TestUtil
-
Convenience method: Unzip zipName + ".zip" under destDir, removing destDir first
- updateDocHead(int) - Method in class org.apache.lucene.search.grouping.AbstractAllGroupHeadsCollector.GroupHead
-
Updates the current most relevant document with the specified document.
- UpdateDocTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Update a document, using IndexWriter.updateDocument, optionally with of a certain size.
- UpdateDocTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.UpdateDocTask
- updateDocument(Term, Document) - Method in class org.apache.lucene.index.IndexWriter
-
Updates a document by first deleting the document(s) containing
term
and then adding the new document. - updateDocument(Term, Document) - Method in class org.apache.lucene.index.RandomIndexWriter
-
Updates a document.
- updateDocument(Term, Document) - Method in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
- updateDocument(Term, Document) - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
- updateDocument(Term, Document) - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexWriter
-
Deprecated.
- updateDocument(Term, Document, Analyzer) - Method in class org.apache.lucene.index.IndexWriter
-
Updates a document by first deleting the document(s) containing
term
and then adding the new document. - updateDocument(Term, Document, Analyzer) - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
- updateDocument(Term, Document, Analyzer) - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexWriter
-
Deprecated.
- updateDocuments(Term, Collection<Document>) - Method in class org.apache.lucene.index.IndexWriter
-
Atomically deletes documents matching the provided delTerm and adds a block of documents with sequentially assigned document IDs, such that an external reader will see all or none of the documents.
- updateDocuments(Term, Collection<Document>) - Method in class org.apache.lucene.index.RandomIndexWriter
- updateDocuments(Term, Collection<Document>) - Method in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
- updateDocuments(Term, Collection<Document>) - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
- updateDocuments(Term, Collection<Document>, Analyzer) - Method in class org.apache.lucene.index.IndexWriter
-
Atomically deletes documents matching the provided delTerm and adds a block of documents, analyzed using the provided analyzer, with sequentially assigned document IDs, such that an external reader will see all or none of the documents.
- updateDocuments(Term, Collection<Document>, Analyzer) - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
- updateInputToken(Token, Token) - Method in class org.apache.lucene.analysis.miscellaneous.PrefixAndSuffixAwareTokenFilter
- UpdateLineColumn(char) - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
- UpdateLineColumn(char) - Method in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
- updateMergeThreads() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
-
Called whenever the running merges have changed, to pause & unpause threads.
- updateSuffixToken(Token, Token) - Method in class org.apache.lucene.analysis.miscellaneous.PrefixAndSuffixAwareTokenFilter
- updateSuffixToken(Token, Token) - Method in class org.apache.lucene.analysis.miscellaneous.PrefixAwareTokenFilter
-
The default implementation adds last prefix token end offset to the suffix token start and end offsets.
- updateToken(Token, List<Token>, int, List<ShingleMatrixFilter.Matrix.Column.Row>, List<Token>) - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter
-
Deprecated.Final touch of a shingle token before it is passed on to the consumer from method
ShingleMatrixFilter.incrementToken()
. - updateTop() - Method in class org.apache.lucene.util.PriorityQueue
-
Should be called when the Object at top changes values.
- upgrade() - Method in class org.apache.lucene.index.IndexUpgrader
- UpgradeIndexMergePolicy - Class in org.apache.lucene.index
-
This
MergePolicy
is used for upgrading all existing segments of an index when callingIndexWriter.forceMerge(int)
. - UpgradeIndexMergePolicy(MergePolicy) - Constructor for class org.apache.lucene.index.UpgradeIndexMergePolicy
-
Wrap the given
MergePolicy
and intercept forceMerge requests to only upgrade segments written with previous Lucene versions. - upto - Variable in class org.apache.lucene.search.CachingCollector
- UpToTwoPositiveIntOutputs - Class in org.apache.lucene.util.fst
-
An FST
Outputs
implementation where each output is one or two non-negative long values. - UpToTwoPositiveIntOutputs.TwoLongs - Class in org.apache.lucene.util.fst
-
Holds two long outputs.
- URL - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
- URL_TYPE - Static variable in class org.apache.lucene.analysis.standard.std31.UAX29URLEmailTokenizerImpl31
-
Deprecated.
- URL_TYPE - Static variable in class org.apache.lucene.analysis.standard.std34.UAX29URLEmailTokenizerImpl34
-
Deprecated.
- URL_TYPE - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
-
Deprecated.use
UAX29URLEmailTokenizer.TOKEN_TYPES
instead - URL_TYPE - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizerImpl
- useCompoundFile - Variable in class org.apache.lucene.index.LogMergePolicy
- useCompoundFile(SegmentInfos, SegmentInfo) - Method in class org.apache.lucene.index.LogMergePolicy
- useCompoundFile(SegmentInfos, SegmentInfo) - Method in class org.apache.lucene.index.MergePolicy
-
Returns true if a new segment (regardless of its origin) should use the compound file format.
- useCompoundFile(SegmentInfos, SegmentInfo) - Method in class org.apache.lucene.index.MockRandomMergePolicy
- useCompoundFile(SegmentInfos, SegmentInfo) - Method in class org.apache.lucene.index.NoMergePolicy
- useCompoundFile(SegmentInfos, SegmentInfo) - Method in class org.apache.lucene.index.TieredMergePolicy
- useCompoundFile(SegmentInfos, SegmentInfo) - Method in class org.apache.lucene.index.UpgradeIndexMergePolicy
- USEDMEM - Static variable in class org.apache.lucene.benchmark.byTask.tasks.ReportTask
- USER_DATA - Static variable in class org.apache.lucene.benchmark.byTask.tasks.OpenReaderTask
- userData - Variable in class org.apache.lucene.index.CheckIndex.Status
-
Holds the userData of the last commit in the index
- UserDictionary - Class in org.apache.lucene.analysis.ja.dict
-
Class for building a User Dictionary.
- UserDictionary(Reader) - Constructor for class org.apache.lucene.analysis.ja.dict.UserDictionary
- UserInputQueryBuilder - Class in org.apache.lucene.xmlparser.builders
-
UserInputQueryBuilder uses 1 of 2 strategies for thread-safe parsing: 1) Synchronizing access to "parse" calls on a previously supplied QueryParser or..
- UserInputQueryBuilder(String, Analyzer) - Constructor for class org.apache.lucene.xmlparser.builders.UserInputQueryBuilder
- UserInputQueryBuilder(QueryParser) - Constructor for class org.apache.lucene.xmlparser.builders.UserInputQueryBuilder
-
This constructor has the disadvantage of not being able to change choice of default field name
- usually() - Static method in class org.apache.lucene.util.LuceneTestCase
- usually(Random) - Static method in class org.apache.lucene.util.LuceneTestCase
- UTF_8 - Static variable in class org.apache.lucene.util.IOUtils
-
UTF-8 charset string
- UTF16Result() - Constructor for class org.apache.lucene.util.UnicodeUtil.UTF16Result
- UTF16toUTF8(char[], int, int, BytesRef) - Static method in class org.apache.lucene.util.UnicodeUtil
-
Encode characters from a char[] source, starting at offset for length chars.
- UTF16toUTF8(char[], int, int, UnicodeUtil.UTF8Result) - Static method in class org.apache.lucene.util.UnicodeUtil
-
Encode characters from a char[] source, starting at offset for length chars.
- UTF16toUTF8(char[], int, UnicodeUtil.UTF8Result) - Static method in class org.apache.lucene.util.UnicodeUtil
-
Encode characters from a char[] source, starting at offset and stopping when the character 0xffff is seen.
- UTF16toUTF8(CharSequence, int, int, BytesRef) - Static method in class org.apache.lucene.util.UnicodeUtil
-
Encode characters from this String, starting at offset for length characters.
- UTF16toUTF8(String, int, int, UnicodeUtil.UTF8Result) - Static method in class org.apache.lucene.util.UnicodeUtil
-
Encode characters from this String, starting at offset for length characters.
- UTF16toUTF8WithHash(char[], int, int, BytesRef) - Static method in class org.apache.lucene.util.UnicodeUtil
-
Encode characters from a char[] source, starting at offset for length chars.
- utf8 - Variable in class org.apache.lucene.search.suggest.fst.FSTCompletion.Completion
- UTF8Result() - Constructor for class org.apache.lucene.util.UnicodeUtil.UTF8Result
- utf8ToString() - Method in class org.apache.lucene.util.BytesRef
-
Interprets stored bytes as UTF8 bytes, returning the resulting string
- UTF8toUTF16(byte[], int, int, CharsRef) - Static method in class org.apache.lucene.util.UnicodeUtil
-
Interprets the given byte array as UTF-8 and converts to UTF-16.
- UTF8toUTF16(byte[], int, int, UnicodeUtil.UTF16Result) - Static method in class org.apache.lucene.util.UnicodeUtil
-
Convert UTF8 bytes into UTF16 characters.
- UTF8toUTF16(BytesRef, CharsRef) - Static method in class org.apache.lucene.util.UnicodeUtil
-
Utility method for
UnicodeUtil.UTF8toUTF16(byte[], int, int, CharsRef)
- Util - Class in org.apache.lucene.util.fst
-
Static helper methods.
- Util.MinResult<T> - Class in org.apache.lucene.util.fst
-
Holds a single input (IntsRef) + output, returned by
Util.shortestPaths(org.apache.lucene.util.fst.FST<T>, org.apache.lucene.util.fst.FST.Arc<T>, java.util.Comparator<T>, int)
. - Utility - Class in org.apache.lucene.analysis.cn.smart
-
SmartChineseAnalyzer utility constants and methods
- Utility() - Constructor for class org.apache.lucene.analysis.cn.smart.Utility
V
- validate() - Method in class org.apache.lucene.facet.search.sampling.SamplingParams
-
Check validity of sampling settings, making sure that
minSampleSize <= maxSampleSize <= samplingThreshold
0 < samplingRatio <= 1
- validateData(QualityQuery[], PrintWriter) - Method in interface org.apache.lucene.benchmark.quality.Judge
-
Validate that queries and this Judge match each other.
- validateData(QualityQuery[], PrintWriter) - Method in class org.apache.lucene.benchmark.quality.trec.TrecJudge
- ValidatingTokenFilter - Class in org.apache.lucene.analysis
-
A TokenFilter that checks consistency of the tokens (eg offsets are consistent with one another).
- ValidatingTokenFilter(TokenStream, String, boolean) - Constructor for class org.apache.lucene.analysis.ValidatingTokenFilter
-
The name arg is used to identify this stage when throwing exceptions (useful if you have more than one instance in your chain).
- validCounter - Variable in class org.apache.lucene.index.CheckIndex.Status
-
Whether the SegmentInfos.counter is greater than any of the segments' names.
- validUTF16String(CharSequence) - Static method in class org.apache.lucene.util.UnicodeUtil
- value - Variable in class org.apache.lucene.search.spans.SpanScorer
- value - Variable in class org.apache.lucene.search.spans.SpanWeight
- value - Variable in class org.apache.lucene.search.suggest.Lookup.LookupResult
- value(int) - Method in class org.apache.lucene.search.FieldComparator.ByteComparator
- value(int) - Method in class org.apache.lucene.search.FieldComparator.DocComparator
- value(int) - Method in class org.apache.lucene.search.FieldComparator.DoubleComparator
- value(int) - Method in class org.apache.lucene.search.FieldComparator.FloatComparator
- value(int) - Method in class org.apache.lucene.search.FieldComparator.IntComparator
- value(int) - Method in class org.apache.lucene.search.FieldComparator.LongComparator
- value(int) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
- value(int) - Method in class org.apache.lucene.search.FieldComparator.ShortComparator
- value(int) - Method in class org.apache.lucene.search.FieldComparator.StringComparatorLocale
- value(int) - Method in class org.apache.lucene.search.FieldComparator.StringOrdValComparator
- value(int) - Method in class org.apache.lucene.search.FieldComparator.StringValComparator
- value(int) - Method in class org.apache.lucene.search.FieldComparator
-
Return the actual value in the slot.
- VALUE - org.apache.lucene.facet.search.params.FacetRequest.SortBy
-
sort by computed category value
- valueCount - Variable in class org.apache.lucene.util.packed.PackedInts.ReaderImpl
- valueCount - Variable in class org.apache.lucene.util.packed.PackedInts.Writer
- valueIterator() - Method in class org.apache.lucene.util.WeakIdentityMap
-
Returns an iterator over all values of this map.
- VALUEMISMATCH - Static variable in class org.apache.lucene.util.FieldCacheSanityChecker.InsanityType
-
Indicates entries have the same reader+fieldname but different cached values.
- valueOf(String) - Static method in enum org.apache.lucene.analysis.ja.JapaneseTokenizer.Mode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.analysis.ngram.EdgeNGramTokenFilter.Side
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.analysis.ngram.EdgeNGramTokenizer.Side
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.benchmark.byTask.feeds.TrecDocParser.ParsePathType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.benchmark.byTask.tasks.NewCollationAnalyzerTask.Implementation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.benchmark.byTask.utils.StreamUtils.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.document.DateTools.Resolution
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.document.Field.Index
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.document.Field.Store
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.document.Field.TermVector
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.document.FieldSelectorResult
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.document.NumericField.DataType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.facet.search.params.FacetRequest.ResultMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.facet.search.params.FacetRequest.SortBy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.facet.search.params.FacetRequest.SortOrder
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.facet.taxonomy.writercache.lru.LruTaxonomyWriterCache.LRUType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.index.FieldInfo.IndexOptions
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.index.IndexWriterConfig.OpenMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.queryParser.core.nodes.ModifierQueryNode.Modifier
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.queryParser.core.nodes.ParametricQueryNode.CompareOperator
-
Deprecated.Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.queryParser.core.nodes.ProximityQueryNode.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.queryParser.core.parser.EscapeQuerySyntax.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.queryParser.QueryParser.Operator
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.queryParser.standard.config.DefaultOperatorAttribute.Operator
-
Deprecated.Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.queryParser.standard.config.StandardQueryConfigHandler.Operator
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.queryParser.standard.QueryParserWrapper.Operator
-
Deprecated.Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.search.BooleanClause.Occur
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.search.CachingWrapperFilter.DeletesMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.search.join.ToParentBlockJoinQuery.ScoreMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.search.spans.SpanPositionCheckQuery.AcceptStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.search.spell.SuggestMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.spatial.geometry.DistanceUnits
-
Deprecated.Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.spatial.geometry.shape.IntersectCase
-
Deprecated.Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.spatial.tier.DistanceHandler.Precision
-
Deprecated.Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.store.MockDirectoryWrapper.Throttling
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.util.fst.FST.INPUT_TYPE
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.util.RamUsageEstimator.JvmFeature
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.lucene.util.Version
-
Returns the enum constant of this type with the specified name.
- ValueQueryNode<T> - Interface in org.apache.lucene.queryParser.core.nodes
-
This interface should be implemented by a
QueryNode
that holds an arbitrary value. - values() - Static method in enum org.apache.lucene.analysis.ja.JapaneseTokenizer.Mode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.analysis.ngram.EdgeNGramTokenFilter.Side
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.analysis.ngram.EdgeNGramTokenizer.Side
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.benchmark.byTask.feeds.TrecDocParser.ParsePathType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.benchmark.byTask.tasks.NewCollationAnalyzerTask.Implementation
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.benchmark.byTask.utils.StreamUtils.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.document.DateTools.Resolution
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.document.Field.Index
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.document.Field.Store
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.document.Field.TermVector
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.document.FieldSelectorResult
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.document.NumericField.DataType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.facet.search.params.FacetRequest.ResultMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.facet.search.params.FacetRequest.SortBy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.facet.search.params.FacetRequest.SortOrder
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.facet.taxonomy.writercache.lru.LruTaxonomyWriterCache.LRUType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.index.FieldInfo.IndexOptions
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.index.IndexWriterConfig.OpenMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.queryParser.core.nodes.ModifierQueryNode.Modifier
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.queryParser.core.nodes.ParametricQueryNode.CompareOperator
-
Deprecated.Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.queryParser.core.nodes.ProximityQueryNode.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.queryParser.core.parser.EscapeQuerySyntax.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.queryParser.QueryParser.Operator
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.queryParser.standard.config.DefaultOperatorAttribute.Operator
-
Deprecated.Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.queryParser.standard.config.StandardQueryConfigHandler.Operator
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.queryParser.standard.QueryParserWrapper.Operator
-
Deprecated.Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.search.BooleanClause.Occur
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.search.CachingWrapperFilter.DeletesMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.search.join.ToParentBlockJoinQuery.ScoreMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.search.spans.SpanPositionCheckQuery.AcceptStatus
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.search.spell.SuggestMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.spatial.geometry.DistanceUnits
-
Deprecated.Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.spatial.geometry.shape.IntersectCase
-
Deprecated.Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.spatial.tier.DistanceHandler.Precision
-
Deprecated.Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.store.MockDirectoryWrapper.Throttling
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.util.fst.FST.INPUT_TYPE
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.util.RamUsageEstimator.JvmFeature
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.lucene.util.Version
-
Returns an array containing the constants of this enum type, in the order they are declared.
- ValueSource - Class in org.apache.lucene.search.function
-
Expert: source of values for basic function queries.
- ValueSource() - Constructor for class org.apache.lucene.search.function.ValueSource
- ValueSourceQuery - Class in org.apache.lucene.search.function
-
Expert: A Query that sets the scores of document to the values obtained from a
ValueSource
. - ValueSourceQuery(ValueSource) - Constructor for class org.apache.lucene.search.function.ValueSourceQuery
-
Create a value source query
- vecCount - Variable in class org.apache.lucene.index.PruningReader
- VECTOR_EXTENSIONS - Static variable in class org.apache.lucene.index.IndexFileNames
-
File extensions for term vector support
- Vector2D - Class in org.apache.lucene.spatial.geometry.shape
-
Deprecated.
- Vector2D() - Constructor for class org.apache.lucene.spatial.geometry.shape.Vector2D
-
Deprecated.
- Vector2D(double, double) - Constructor for class org.apache.lucene.spatial.geometry.shape.Vector2D
-
Deprecated.Create a vector from the origin of the coordinate system to the given point
- Vector2D(Point2D) - Constructor for class org.apache.lucene.spatial.geometry.shape.Vector2D
-
Deprecated.Create a vector from the origin of the coordinate system to the given point
- Vector2D(Point2D, Point2D) - Constructor for class org.apache.lucene.spatial.geometry.shape.Vector2D
-
Deprecated.Create a vector from one point to another
- Vector2D(Vector2D) - Constructor for class org.apache.lucene.spatial.geometry.shape.Vector2D
-
Deprecated.
- vectorBoxCorner(double[], double[], double, boolean) - Static method in class org.apache.lucene.spatial.DistanceUtils
-
Deprecated.Return the coordinates of a vector that is the corner of a box (upper right or lower left), assuming a Rectangular coordinate system.
- vectorDistance(double[], double[], double) - Static method in class org.apache.lucene.spatial.DistanceUtils
-
Deprecated.Calculate the p-norm (i.e.
- vectorDistance(double[], double[], double, double) - Static method in class org.apache.lucene.spatial.DistanceUtils
-
Deprecated.Calculate the p-norm (i.e.
- VECTORS_DOCUMENTS_EXTENSION - Static variable in class org.apache.lucene.index.IndexFileNames
-
Extension of vectors documents file
- VECTORS_FIELDS_EXTENSION - Static variable in class org.apache.lucene.index.IndexFileNames
-
Extension of vectors fields file
- VECTORS_INDEX_EXTENSION - Static variable in class org.apache.lucene.index.IndexFileNames
-
Extension of vectors index file
- verbose - Variable in class org.apache.lucene.benchmark.byTask.feeds.ContentItemsSource
- verbose() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
-
Returns true if verbosing is enabled.
- verbose() - Method in class org.apache.lucene.index.IndexWriter
-
Returns true if verbosing is enabled (i.e., infoStream != null).
- verbose() - Method in class org.apache.lucene.index.LogMergePolicy
- VERBOSE - Static variable in class org.apache.lucene.util.LuceneTestCase
-
true iff tests are run in verbose mode.
- verifyExplanation(String, int, float, boolean, Explanation) - Static method in class org.apache.lucene.search.CheckHits
-
Assert that an explanation has the expected score, and optionally that its sub-details max/sum/factor match to that score.
- VerifyingLockFactory - Class in org.apache.lucene.store
-
A
LockFactory
that wraps anotherLockFactory
and verifies that each lock obtain/release is "correct" (never results in two processes holding the lock at the same time). - VerifyingLockFactory(byte, LockFactory, String, int) - Constructor for class org.apache.lucene.store.VerifyingLockFactory
- verifySettings() - Method in class org.apache.lucene.util.LuceneJUnitDividingSelector
- Version - Enum in org.apache.lucene.util
-
Use by certain classes to match version compatibility across releases of Lucene.
- VERSION - Static variable in class org.apache.lucene.analysis.ja.dict.BinaryDictionary
- VERSION - Static variable in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
- VERSION - Static variable in class org.apache.lucene.analysis.ja.dict.ConnectionCosts
- Vint8 - Class in org.apache.lucene.util
-
Variable-length encoding of 32-bit integers, into 8-bit bytes.
- Vint8.Position - Class in org.apache.lucene.util
-
Because Java lacks call-by-reference, this class boxes the decoding position, which is initially set by the caller, and returned after decoding, incremented by the number of bytes processed.
- VInt8IntDecoder - Class in org.apache.lucene.util.encoding
-
An
IntDecoder
which can decode values encoded byVInt8IntEncoder
. - VInt8IntDecoder() - Constructor for class org.apache.lucene.util.encoding.VInt8IntDecoder
- VInt8IntEncoder - Class in org.apache.lucene.util.encoding
-
An
IntEncoder
which implements variable length encoding. - VInt8IntEncoder() - Constructor for class org.apache.lucene.util.encoding.VInt8IntEncoder
- VirtualMethod<C> - Class in org.apache.lucene.util
-
A utility for keeping backwards compatibility on previously abstract methods (or similar replacements).
- VirtualMethod(Class<C>, String, Class<?>...) - Constructor for class org.apache.lucene.util.VirtualMethod
-
Creates a new instance for the given
baseClass
and method declaration. - visitMatchingTerm(Term) - Method in interface org.apache.lucene.queryParser.surround.query.SimpleTerm.MatchingTermVisitor
- visitMatchingTerms(IndexReader, String, SimpleTerm.MatchingTermVisitor) - Method in class org.apache.lucene.queryParser.surround.query.SimpleTerm
- visitMatchingTerms(IndexReader, String, SimpleTerm.MatchingTermVisitor) - Method in class org.apache.lucene.queryParser.surround.query.SrndPrefixQuery
- visitMatchingTerms(IndexReader, String, SimpleTerm.MatchingTermVisitor) - Method in class org.apache.lucene.queryParser.surround.query.SrndTermQuery
- visitMatchingTerms(IndexReader, String, SimpleTerm.MatchingTermVisitor) - Method in class org.apache.lucene.queryParser.surround.query.SrndTruncQuery
- visitOptional(P, C, S) - Method in class org.apache.lucene.search.Scorer.ScorerVisitor
-
Invoked for all optional scorer
- visitProhibited(P, C, S) - Method in class org.apache.lucene.search.Scorer.ScorerVisitor
-
Invoked for all prohibited scorer
- visitRequired(P, C, S) - Method in class org.apache.lucene.search.Scorer.ScorerVisitor
-
Invoked for all required scorer
- visitScorers(Scorer.ScorerVisitor<Query, Query, Scorer>) - Method in class org.apache.lucene.search.Scorer
-
Expert: call this to gather details for all sub-scorers for this query.
- visitSubScorers(Query, BooleanClause.Occur, Scorer.ScorerVisitor<Query, Query, Scorer>) - Method in class org.apache.lucene.search.Scorer
-
Scorer
subclasses should implement this method if the subclass itself contains multiple scorers to support gathering details for sub-scorers viaScorer.ScorerVisitor
- VocabularyAssert - Class in org.apache.lucene.analysis
-
Utility class for doing vocabulary-based stemming tests
- VocabularyAssert() - Constructor for class org.apache.lucene.analysis.VocabularyAssert
- vspace - Variable in class org.apache.lucene.analysis.compound.hyphenation.HyphenationTree
-
value space: stores the interletter values
W
- w - Variable in class org.apache.lucene.index.RandomIndexWriter
- W - Static variable in interface org.apache.lucene.queryParser.surround.parser.QueryParserConstants
-
RegularExpression Id.
- waitForGeneration(long) - Method in class org.apache.lucene.search.NRTManager
-
Waits for the target generation to become visible in the searcher.
- waitForGeneration(long, long, TimeUnit) - Method in class org.apache.lucene.search.NRTManager
-
Waits for the target generation to become visible in the searcher.
- waitForMerges() - Method in class org.apache.lucene.index.IndexWriter
-
Wait for any currently outstanding merges to finish.
- WaitForMergesTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Waits for merges to finish.
- WaitForMergesTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.WaitForMergesTask
- waiting(long) - Method in interface org.apache.lucene.search.NRTManager.WaitingListener
- waiting(long) - Method in class org.apache.lucene.search.NRTManagerReopenThread
- WaitTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Simply waits for the specified (via the parameter) amount of time.
- WaitTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.WaitTask
- warm(IndexReader) - Method in class org.apache.lucene.index.IndexWriter.IndexReaderWarmer
- WarmTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Warm reader task: retrieve all reader documents.
- WarmTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.WarmTask
- wasEscaped(int) - Method in class org.apache.lucene.queryParser.core.util.UnescapedCharSequence
- wasEscaped(CharSequence, int) - Static method in class org.apache.lucene.queryParser.core.util.UnescapedCharSequence
- WAW - Static variable in class org.apache.lucene.analysis.ar.ArabicStemmer
- WeakIdentityMap<K,V> - Class in org.apache.lucene.util
-
Implements a combination of
WeakHashMap
andIdentityHashMap
. - weight - Variable in class org.apache.lucene.analysis.cn.smart.hhmm.SegToken
-
word frequency
- weight - Variable in class org.apache.lucene.search.Scorer
- weight() - Method in class org.apache.lucene.search.spell.TermFreqIterator.TermFreqIteratorWrapper
- weight() - Method in interface org.apache.lucene.search.spell.TermFreqIterator
- weight() - Method in class org.apache.lucene.search.suggest.BufferingTermFreqIteratorWrapper
- weight() - Method in class org.apache.lucene.search.suggest.SortedTermFreqIteratorWrapper
- weight() - Method in class org.apache.lucene.search.suggest.UnsortedTermFreqIteratorWrapper
- weight(Searcher) - Method in class org.apache.lucene.search.Query
-
Deprecated.never ever use this method in
Weight
implementations. Subclasses ofQuery
should useQuery.createWeight(org.apache.lucene.search.Searcher)
, instead. - Weight - Class in org.apache.lucene.search
-
Expert: Calculate query weights and build query scorers.
- Weight() - Constructor for class org.apache.lucene.search.Weight
- WeightedFragInfo(int, int, List<FieldPhraseList.WeightedPhraseInfo>) - Constructor for class org.apache.lucene.search.vectorhighlight.FieldFragList.WeightedFragInfo
- WeightedPhraseInfo(LinkedList<FieldTermStack.TermInfo>, float) - Constructor for class org.apache.lucene.search.vectorhighlight.FieldPhraseList.WeightedPhraseInfo
- WeightedPhraseInfo(LinkedList<FieldTermStack.TermInfo>, float, int) - Constructor for class org.apache.lucene.search.vectorhighlight.FieldPhraseList.WeightedPhraseInfo
- WeightedSpanTerm - Class in org.apache.lucene.search.highlight
-
Lightweight class to hold term, weight, and positions used for scoring this term.
- WeightedSpanTerm(float, String) - Constructor for class org.apache.lucene.search.highlight.WeightedSpanTerm
- WeightedSpanTerm(float, String, boolean) - Constructor for class org.apache.lucene.search.highlight.WeightedSpanTerm
- WeightedSpanTermExtractor - Class in org.apache.lucene.search.highlight
-
Class used to extract
WeightedSpanTerm
s from aQuery
based on whetherTerm
s from theQuery
are contained in a suppliedTokenStream
. - WeightedSpanTermExtractor() - Constructor for class org.apache.lucene.search.highlight.WeightedSpanTermExtractor
- WeightedSpanTermExtractor(String) - Constructor for class org.apache.lucene.search.highlight.WeightedSpanTermExtractor
- WeightedSpanTermExtractor.PositionCheckingMap<K> - Class in org.apache.lucene.search.highlight
-
This class makes sure that if both position sensitive and insensitive versions of the same term are added, the position insensitive one wins.
- WeightedTerm - Class in org.apache.lucene.search.highlight
-
Lightweight class to hold term and a weight value used for scoring this term
- WeightedTerm(float, String) - Constructor for class org.apache.lucene.search.highlight.WeightedTerm
- weights - Variable in class org.apache.lucene.search.BooleanQuery.BooleanWeight
- weights - Variable in class org.apache.lucene.search.DisjunctionMaxQuery.DisjunctionMaxWeight
-
The Weights for our subqueries, in 1-1 correspondence with disjuncts
- weightToString(StringBuilder) - Method in class org.apache.lucene.queryParser.surround.query.SrndQuery
- WFSTCompletionLookup - Class in org.apache.lucene.search.suggest.fst
-
Suggester based on a weighted FST: it first traverses the prefix, then walks the n shortest paths to retrieve top-ranked suggestions.
- WFSTCompletionLookup() - Constructor for class org.apache.lucene.search.suggest.fst.WFSTCompletionLookup
- WFSTCompletionLookup(boolean) - Constructor for class org.apache.lucene.search.suggest.fst.WFSTCompletionLookup
-
Creates a new suggester.
- WHITESPACE - Static variable in class org.apache.lucene.analysis.MockTokenizer
-
Acts Similar to WhitespaceTokenizer
- WHITESPACE_PATTERN - Static variable in class org.apache.lucene.analysis.miscellaneous.PatternAnalyzer
-
"\\s+"
; Divides text at whitespaces (Character.isWhitespace(c)) - WhitespaceAnalyzer - Class in org.apache.lucene.analysis
-
An Analyzer that uses
WhitespaceTokenizer
. - WhitespaceAnalyzer() - Constructor for class org.apache.lucene.analysis.WhitespaceAnalyzer
-
Deprecated.use
WhitespaceAnalyzer(Version)
instead - WhitespaceAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.WhitespaceAnalyzer
-
Creates a new
WhitespaceAnalyzer
- WhitespaceTokenizer - Class in org.apache.lucene.analysis
-
A WhitespaceTokenizer is a tokenizer that divides text at whitespace.
- WhitespaceTokenizer(Reader) - Constructor for class org.apache.lucene.analysis.WhitespaceTokenizer
-
Deprecated.use
WhitespaceTokenizer(Version, Reader)
instead. This will be removed in Lucene 4.0. - WhitespaceTokenizer(AttributeSource.AttributeFactory, Reader) - Constructor for class org.apache.lucene.analysis.WhitespaceTokenizer
-
Deprecated.use
WhitespaceTokenizer(Version, AttributeSource.AttributeFactory, Reader)
instead. This will be removed in Lucene 4.0. - WhitespaceTokenizer(AttributeSource, Reader) - Constructor for class org.apache.lucene.analysis.WhitespaceTokenizer
-
Deprecated.use
WhitespaceTokenizer(Version, AttributeSource, Reader)
instead. This will be removed in Lucene 4.0. - WhitespaceTokenizer(Version, Reader) - Constructor for class org.apache.lucene.analysis.WhitespaceTokenizer
-
Construct a new WhitespaceTokenizer.
- WhitespaceTokenizer(Version, AttributeSource.AttributeFactory, Reader) - Constructor for class org.apache.lucene.analysis.WhitespaceTokenizer
-
Construct a new WhitespaceTokenizer using a given
AttributeSource.AttributeFactory
. - WhitespaceTokenizer(Version, AttributeSource, Reader) - Constructor for class org.apache.lucene.analysis.WhitespaceTokenizer
-
Construct a new WhitespaceTokenizer using a given
AttributeSource
. - WikipediaTokenizer - Class in org.apache.lucene.analysis.wikipedia
-
Extension of StandardTokenizer that is aware of Wikipedia syntax.
- WikipediaTokenizer(Reader) - Constructor for class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
-
Creates a new instance of the
WikipediaTokenizer
. - WikipediaTokenizer(Reader, int, Set<String>) - Constructor for class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
-
Creates a new instance of the
WikipediaTokenizer
. - WikipediaTokenizer(AttributeSource.AttributeFactory, Reader, int, Set<String>) - Constructor for class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
-
Creates a new instance of the
WikipediaTokenizer
. - WikipediaTokenizer(AttributeSource, Reader, int, Set<String>) - Constructor for class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
-
Creates a new instance of the
WikipediaTokenizer
. - WILDCARD_CHAR - Static variable in class org.apache.lucene.search.WildcardTermEnum
- WILDCARD_NOT_SUPPORTED - Static variable in class org.apache.lucene.queryParser.core.messages.QueryParserMessages
- WILDCARD_STRING - Static variable in class org.apache.lucene.search.WildcardTermEnum
-
String equality with support for wildcards
- wildcardEquals(String, int, String, int) - Static method in class org.apache.lucene.search.WildcardTermEnum
-
Determines if a word matches a wildcard pattern.
- WildcardQuery - Class in org.apache.lucene.search
-
Implements the wildcard search query.
- WildcardQuery(Term) - Constructor for class org.apache.lucene.search.WildcardQuery
- WildcardQueryNode - Class in org.apache.lucene.queryParser.standard.nodes
-
A
WildcardQueryNode
represents wildcard query This does not apply to phrases. - WildcardQueryNode(CharSequence, CharSequence, int, int) - Constructor for class org.apache.lucene.queryParser.standard.nodes.WildcardQueryNode
- WildcardQueryNode(FieldQueryNode) - Constructor for class org.apache.lucene.queryParser.standard.nodes.WildcardQueryNode
- WildcardQueryNodeBuilder - Class in org.apache.lucene.queryParser.standard.builders
-
Builds a
WildcardQuery
object from aWildcardQueryNode
object. - WildcardQueryNodeBuilder() - Constructor for class org.apache.lucene.queryParser.standard.builders.WildcardQueryNodeBuilder
- WildcardQueryNodeProcessor - Class in org.apache.lucene.queryParser.standard.processors
-
The
StandardSyntaxParser
createsPrefixWildcardQueryNode
nodes which have values containing the prefixed wildcard. - WildcardQueryNodeProcessor() - Constructor for class org.apache.lucene.queryParser.standard.processors.WildcardQueryNodeProcessor
- WildcardTermEnum - Class in org.apache.lucene.search
-
Subclass of FilteredTermEnum for enumerating all terms that match the specified wildcard filter term.
- WildcardTermEnum(IndexReader, Term) - Constructor for class org.apache.lucene.search.WildcardTermEnum
-
Creates a new
WildcardTermEnum
. - WILDTERM - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
-
RegularExpression Id.
- WILLNEED - Static variable in class org.apache.lucene.store.NativePosixUtil
- WINDOWS - Static variable in class org.apache.lucene.util.Constants
-
True iff running on Windows.
- WindowsDirectory - Class in org.apache.lucene.store
-
Native
Directory
implementation for Microsoft Windows. - WindowsDirectory(File) - Constructor for class org.apache.lucene.store.WindowsDirectory
-
Create a new WindowsDirectory for the named location and
NativeFSLockFactory
. - WindowsDirectory(File, LockFactory) - Constructor for class org.apache.lucene.store.WindowsDirectory
-
Create a new WindowsDirectory for the named location.
- WindowsDirectory.WindowsIndexInput - Class in org.apache.lucene.store
- WindowsIndexInput(File, int) - Constructor for class org.apache.lucene.store.WindowsDirectory.WindowsIndexInput
- With(Lock, long) - Constructor for class org.apache.lucene.store.Lock.With
-
Constructs an executor that will grab the named lock.
- WITH_OFFSETS - org.apache.lucene.document.Field.TermVector
-
Store the term vector + Token offset information
- WITH_POSITIONS - org.apache.lucene.document.Field.TermVector
-
Store the term vector + token position information
- WITH_POSITIONS_OFFSETS - org.apache.lucene.document.Field.TermVector
-
Store the term vector + Token position and offset information
- withCollector() - Method in class org.apache.lucene.benchmark.byTask.tasks.ReadTask
- withCollector() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchWithCollectorTask
- WITHIN - org.apache.lucene.spatial.geometry.shape.IntersectCase
-
Deprecated.
- WithinComment1 - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
Lexical state.
- WithinComment2 - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
Lexical state.
- withinGroupSort - Variable in class org.apache.lucene.search.grouping.TopGroups
-
How docs are sorted within each group
- WithinQuote1 - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
Lexical state.
- WithinQuote2 - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
Lexical state.
- WithinScript - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
Lexical state.
- WithinTag - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
Lexical state.
- withMaxScore() - Method in class org.apache.lucene.benchmark.byTask.tasks.ReadTask
-
Whether maxScores should be computed (only useful with field sort)
- withMaxScore() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchWithSortTask
- withOffsets() - Method in enum org.apache.lucene.document.Field.TermVector
- withPositions() - Method in enum org.apache.lucene.document.Field.TermVector
- withRetrieve() - Method in class org.apache.lucene.benchmark.byTask.tasks.ReadTask
-
Return true if, with search & results traversing, docs should be retrieved.
- withRetrieve() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchTask
- withRetrieve() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchTravRetHighlightTask
- withRetrieve() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchTravRetLoadFieldSelectorTask
- withRetrieve() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchTravRetTask
- withRetrieve() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchTravRetVectorHighlightTask
- withRetrieve() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchTravTask
- withRetrieve() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchWithCollectorTask
- withRetrieve() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchWithSortTask
- withRetrieve() - Method in class org.apache.lucene.benchmark.byTask.tasks.WarmTask
- withScore() - Method in class org.apache.lucene.benchmark.byTask.tasks.ReadTask
-
Whether scores should be computed (only useful with field sort)
- withScore() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchWithSortTask
- withSearch() - Method in class org.apache.lucene.benchmark.byTask.tasks.ReadTask
-
Return true if search should be performed.
- withSearch() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchTask
- withSearch() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchTravTask
- withSearch() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchWithCollectorTask
- withSearch() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchWithSortTask
- withSearch() - Method in class org.apache.lucene.benchmark.byTask.tasks.WarmTask
- withTraverse() - Method in class org.apache.lucene.benchmark.byTask.tasks.ReadTask
-
Return true if, with search, results should be traversed.
- withTraverse() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchTask
- withTraverse() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchTravTask
- withTraverse() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchWithCollectorTask
- withTraverse() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchWithSortTask
- withTraverse() - Method in class org.apache.lucene.benchmark.byTask.tasks.WarmTask
- withWarm() - Method in class org.apache.lucene.benchmark.byTask.tasks.ReadTask
-
Return true if warming should be performed.
- withWarm() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchTask
- withWarm() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchTravTask
- withWarm() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchWithCollectorTask
- withWarm() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchWithSortTask
- withWarm() - Method in class org.apache.lucene.benchmark.byTask.tasks.WarmTask
- wlen - Variable in class org.apache.lucene.util.OpenBitSet
- Word - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
-
RegularExpression Id.
- WORD_COST - Static variable in class org.apache.lucene.analysis.ja.dict.UserDictionary
- WORD_HANGUL - Static variable in class org.apache.lucene.analysis.icu.segmentation.DefaultICUTokenizerConfig
-
Token type for words containing Korean hangul
- WORD_HIRAGANA - Static variable in class org.apache.lucene.analysis.icu.segmentation.DefaultICUTokenizerConfig
-
Token type for words containing Japanese hiragana
- WORD_IDEO - Static variable in class org.apache.lucene.analysis.icu.segmentation.DefaultICUTokenizerConfig
-
Token type for words containing ideographic characters
- WORD_KATAKANA - Static variable in class org.apache.lucene.analysis.icu.segmentation.DefaultICUTokenizerConfig
-
Token type for words containing Japanese katakana
- WORD_LETTER - Static variable in class org.apache.lucene.analysis.icu.segmentation.DefaultICUTokenizerConfig
-
Token type for words that contain letters
- WORD_NUMBER - Static variable in class org.apache.lucene.analysis.icu.segmentation.DefaultICUTokenizerConfig
-
Token type for words that appear to be numbers
- WORD_SEPARATOR - Static variable in class org.apache.lucene.analysis.synonym.SynonymMap
-
for multiword support, you must separate words with this separator
- WORD_TYPE - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
-
Alphanumeric sequences
- WORD_TYPE - Static variable in class org.apache.lucene.analysis.standard.std31.StandardTokenizerImpl31
-
Deprecated.Alphanumeric sequences
- WORD_TYPE - Static variable in class org.apache.lucene.analysis.standard.std31.UAX29URLEmailTokenizerImpl31
-
Deprecated.Alphanumeric sequences
- WORD_TYPE - Static variable in class org.apache.lucene.analysis.standard.std34.UAX29URLEmailTokenizerImpl34
-
Deprecated.Alphanumeric sequences
- WORD_TYPE - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
-
Deprecated.use
UAX29URLEmailTokenizer.TOKEN_TYPES
instead - WORD_TYPE - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizerImpl
-
Alphanumeric sequences
- WordlistLoader - Class in org.apache.lucene.analysis
-
Loader for text files that represent a list of stopwords.
- WordlistLoader() - Constructor for class org.apache.lucene.analysis.WordlistLoader
- WordnetSynonymParser - Class in org.apache.lucene.analysis.synonym
-
Parser for wordnet prolog format
- WordnetSynonymParser(boolean, boolean, Analyzer) - Constructor for class org.apache.lucene.analysis.synonym.WordnetSynonymParser
- words - Variable in class org.apache.lucene.analysis.synonym.SynonymMap
-
map
- WordTokenFilter - Class in org.apache.lucene.analysis.cn.smart
-
A
TokenFilter
that breaks sentences into words. - WordTokenFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.cn.smart.WordTokenFilter
-
Construct a new WordTokenizer.
- wordType - Variable in class org.apache.lucene.analysis.cn.smart.hhmm.SegToken
-
WordType
of the text - WordType - Class in org.apache.lucene.analysis.cn.smart
-
Internal SmartChineseAnalyzer token type constants
- WordType() - Constructor for class org.apache.lucene.analysis.cn.smart.WordType
- WQuery() - Method in class org.apache.lucene.queryParser.surround.parser.QueryParser
- wrap(Collector...) - Static method in class org.apache.lucene.search.MultiCollector
-
Wraps a list of
Collector
s with aMultiCollector
. - wrapCommits(List<? extends IndexCommit>) - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
- wrapSearcher(Random, Searcher, int) - Static method in class org.apache.lucene.search.QueryUtils
-
Given a Searcher, returns a new MultiSearcher wrapping the the original Searcher, as well as several "empty" IndexSearchers -- some of which will have deleted documents in them.
- wrapUnderlyingReader(Random, IndexSearcher, int) - Static method in class org.apache.lucene.search.QueryUtils
-
Given an IndexSearcher, returns a new IndexSearcher whose IndexReader is a MultiReader containing the Reader of the original IndexSearcher, as well as several "empty" IndexReaders -- some of which will have deleted documents in them.
- write(byte[]) - Method in class org.apache.lucene.search.suggest.fst.Sort.ByteSequencesWriter
- write(byte[], int, int) - Method in class org.apache.lucene.search.suggest.fst.Sort.ByteSequencesWriter
- write(byte[], int, int) - Method in class org.apache.lucene.util.UnsafeByteArrayOutputStream
-
writes a given byte[], with offset and length to the buffer.
- write(char) - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
- write(char[]) - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
- write(char[], int, int) - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
- write(int) - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
- write(int) - Method in class org.apache.lucene.util.UnsafeByteArrayOutputStream
-
writes a given byte(at the form of an int) to the buffer.
- write(Long, DataOutput) - Method in class org.apache.lucene.util.fst.PositiveIntOutputs
- write(Object, DataOutput) - Method in class org.apache.lucene.util.fst.NoOutputs
- write(Object, DataOutput) - Method in class org.apache.lucene.util.fst.UpToTwoPositiveIntOutputs
- write(String) - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
- write(OpenStringBuilder) - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
- write(Directory, String) - Method in class org.apache.lucene.index.FieldInfos
- write(Directory, String) - Method in class org.apache.lucene.util.BitVector
-
Writes this vector to the file
name
in Directoryd
, in a format that can be read by the constructorBitVector(Directory, String)
. - write(IndexOutput) - Method in class org.apache.lucene.index.FieldInfos
- write(BytesRef) - Method in class org.apache.lucene.search.suggest.fst.Sort.ByteSequencesWriter
- write(BytesRef, DataOutput) - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
- write(PairOutputs.Pair<A, B>, DataOutput) - Method in class org.apache.lucene.util.fst.PairOutputs
- write(IntsRef, DataOutput) - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
- write(T, DataOutput) - Method in class org.apache.lucene.util.fst.Outputs
- WRITE_LOCK_NAME - Static variable in class org.apache.lucene.index.IndexWriter
-
Name of the write lock in the index.
- WRITE_LOCK_TIMEOUT - Static variable in class org.apache.lucene.index.IndexWriter
-
Deprecated.use
IndexWriterConfig.WRITE_LOCK_TIMEOUT
instead - WRITE_LOCK_TIMEOUT - Static variable in class org.apache.lucene.index.IndexWriterConfig
-
Default value for the write lock timeout (1,000 ms).
- writeArc(int, int, String, String) - Method in class org.apache.lucene.analysis.TokenStreamToDot
- writeByte(byte) - Method in class org.apache.lucene.store.BufferedIndexOutput
-
Writes a single byte.
- writeByte(byte) - Method in class org.apache.lucene.store.ByteArrayDataOutput
- writeByte(byte) - Method in class org.apache.lucene.store.ChecksumIndexOutput
- writeByte(byte) - Method in class org.apache.lucene.store.DataOutput
-
Writes a single byte.
- writeByte(byte) - Method in class org.apache.lucene.store.MockIndexOutputWrapper
- writeByte(byte) - Method in class org.apache.lucene.store.OutputStreamDataOutput
- writeByte(byte) - Method in class org.apache.lucene.store.RAMOutputStream
- writeByte(byte) - Method in class org.apache.lucene.util.PagedBytes.PagedBytesDataOutput
- writeByte(byte) - Method in class org.apache.lucene.util.ThrottledIndexOutput
- writeBytes(byte[], int) - Method in class org.apache.lucene.store.DataOutput
-
Writes an array of bytes.
- writeBytes(byte[], int, int) - Method in class org.apache.lucene.store.BufferedIndexOutput
-
Writes an array of bytes.
- writeBytes(byte[], int, int) - Method in class org.apache.lucene.store.ByteArrayDataOutput
- writeBytes(byte[], int, int) - Method in class org.apache.lucene.store.ChecksumIndexOutput
- writeBytes(byte[], int, int) - Method in class org.apache.lucene.store.DataOutput
-
Writes an array of bytes.
- writeBytes(byte[], int, int) - Method in class org.apache.lucene.store.MockIndexOutputWrapper
- writeBytes(byte[], int, int) - Method in class org.apache.lucene.store.OutputStreamDataOutput
- writeBytes(byte[], int, int) - Method in class org.apache.lucene.store.RAMOutputStream
- writeBytes(byte[], int, int) - Method in class org.apache.lucene.util.PagedBytes.PagedBytesDataOutput
- writeBytes(byte[], int, int) - Method in class org.apache.lucene.util.ThrottledIndexOutput
- writeChars(char[], int, int) - Method in class org.apache.lucene.store.DataOutput
-
Deprecated.-- please pre-convert to utf8 bytes instead or use
DataOutput.writeString(java.lang.String)
- writeChars(String, int, int) - Method in class org.apache.lucene.store.DataOutput
-
Deprecated.-- please pre-convert to utf8 bytes instead or use
DataOutput.writeString(java.lang.String)
- writeHeader() - Method in class org.apache.lucene.analysis.TokenStreamToDot
-
Override to customize.
- writeHeader(DataOutput, String, int) - Static method in class org.apache.lucene.util.CodecUtil
- writeInt(int) - Method in class org.apache.lucene.store.DataOutput
-
Writes an int as four bytes.
- WriteLineDocTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
A task which writes documents, one line per document.
- WriteLineDocTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.WriteLineDocTask
- writeLong(long) - Method in class org.apache.lucene.store.DataOutput
-
Writes a long as eight bytes.
- writeNode(int, String) - Method in class org.apache.lucene.analysis.TokenStreamToDot
- writePool(DataOutput) - Method in class org.apache.lucene.util.ByteBlockPool
-
Writes the pools content to the given
DataOutput
- writer - Variable in class org.apache.lucene.index.ConcurrentMergeScheduler
- writer - Variable in class org.apache.lucene.index.MergePolicy
- writer - Variable in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
- Writer(DataOutput, int, int) - Constructor for class org.apache.lucene.util.packed.PackedInts.Writer
- writeShort(short) - Method in class org.apache.lucene.store.DataOutput
-
Writes a short as two bytes.
- writeString(String) - Method in class org.apache.lucene.store.DataOutput
-
Writes a string.
- writeStringStringMap(Map<String, String>) - Method in class org.apache.lucene.store.DataOutput
- writeTo(IndexOutput) - Method in class org.apache.lucene.store.RAMOutputStream
-
Copy the current contents of this buffer to the named output.
- writeTrailer() - Method in class org.apache.lucene.analysis.TokenStreamToDot
-
Override to customize.
- writeVInt(int) - Method in class org.apache.lucene.store.DataOutput
-
Writes an int in a variable-length format.
- writeVLong(long) - Method in class org.apache.lucene.store.DataOutput
-
Writes an long in a variable-length format.
- WS_ELEMS - Static variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.Tags
-
contains all tags for which whitespaces have to be inserted for proper tokenization
X
- x() - Method in class org.apache.lucene.spatial.geometry.shape.Point2D
-
Deprecated.
- x(double) - Method in class org.apache.lucene.spatial.geometry.shape.Point2D
-
Deprecated.
- xor(OpenBitSet) - Method in class org.apache.lucene.util.OpenBitSet
-
this = this XOR other
- XOR - Static variable in class org.apache.lucene.search.ChainedFilter
- xorCount(OpenBitSet, OpenBitSet) - Static method in class org.apache.lucene.util.OpenBitSet
-
Returns the popcount or cardinality of the exclusive-or of the two sets.
Y
- y() - Method in class org.apache.lucene.spatial.geometry.shape.Point2D
-
Deprecated.
- y(double) - Method in class org.apache.lucene.spatial.geometry.shape.Point2D
-
Deprecated.
- YEAR - org.apache.lucene.document.DateTools.Resolution
- YEH - Static variable in class org.apache.lucene.analysis.ar.ArabicNormalizer
- YEH - Static variable in class org.apache.lucene.analysis.ar.ArabicStemmer
- YEH - Static variable in class org.apache.lucene.analysis.fa.PersianNormalizer
- YEH_BARREE - Static variable in class org.apache.lucene.analysis.fa.PersianNormalizer
- YES - org.apache.lucene.document.Field.Store
-
Store the original field value in the index.
- YES - org.apache.lucene.document.Field.TermVector
-
Store the term vectors of each document.
- YES - org.apache.lucene.search.spans.SpanPositionCheckQuery.AcceptStatus
- yybegin(int) - Method in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
-
Enters a new lexical state
- yybegin(int) - Method in class org.apache.lucene.analysis.standard.std31.StandardTokenizerImpl31
-
Deprecated.Enters a new lexical state
- yybegin(int) - Method in class org.apache.lucene.analysis.standard.std31.UAX29URLEmailTokenizerImpl31
-
Deprecated.Enters a new lexical state
- yybegin(int) - Method in class org.apache.lucene.analysis.standard.std34.UAX29URLEmailTokenizerImpl34
-
Deprecated.Enters a new lexical state
- yybegin(int) - Method in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizerImpl
-
Enters a new lexical state
- yychar() - Method in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
- yychar() - Method in interface org.apache.lucene.analysis.standard.StandardTokenizerInterface
-
Returns the current position.
- yychar() - Method in class org.apache.lucene.analysis.standard.std31.StandardTokenizerImpl31
-
Deprecated.
- yychar() - Method in class org.apache.lucene.analysis.standard.std31.UAX29URLEmailTokenizerImpl31
-
Deprecated.
- yychar() - Method in class org.apache.lucene.analysis.standard.std34.UAX29URLEmailTokenizerImpl34
-
Deprecated.
- yychar() - Method in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizerImpl
- yycharat(int) - Method in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
-
Returns the character at position pos from the matched text.
- yycharat(int) - Method in class org.apache.lucene.analysis.standard.std31.StandardTokenizerImpl31
-
Deprecated.Returns the character at position pos from the matched text.
- yycharat(int) - Method in class org.apache.lucene.analysis.standard.std31.UAX29URLEmailTokenizerImpl31
-
Deprecated.Returns the character at position pos from the matched text.
- yycharat(int) - Method in class org.apache.lucene.analysis.standard.std34.UAX29URLEmailTokenizerImpl34
-
Deprecated.Returns the character at position pos from the matched text.
- yycharat(int) - Method in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizerImpl
-
Returns the character at position pos from the matched text.
- yyclose() - Method in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
-
Closes the input stream.
- yyclose() - Method in class org.apache.lucene.analysis.standard.std31.StandardTokenizerImpl31
-
Deprecated.Closes the input stream.
- yyclose() - Method in class org.apache.lucene.analysis.standard.std31.UAX29URLEmailTokenizerImpl31
-
Deprecated.Closes the input stream.
- yyclose() - Method in class org.apache.lucene.analysis.standard.std34.UAX29URLEmailTokenizerImpl34
-
Deprecated.Closes the input stream.
- yyclose() - Method in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizerImpl
-
Closes the input stream.
- YYEOF - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
-
This character denotes the end of file
- YYEOF - Static variable in interface org.apache.lucene.analysis.standard.StandardTokenizerInterface
-
This character denotes the end of file
- YYEOF - Static variable in class org.apache.lucene.analysis.standard.std31.StandardTokenizerImpl31
-
Deprecated.This character denotes the end of file
- YYEOF - Static variable in class org.apache.lucene.analysis.standard.std31.UAX29URLEmailTokenizerImpl31
-
Deprecated.This character denotes the end of file
- YYEOF - Static variable in class org.apache.lucene.analysis.standard.std34.UAX29URLEmailTokenizerImpl34
-
Deprecated.This character denotes the end of file
- YYEOF - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizerImpl
-
This character denotes the end of file
- YYINITIAL - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
-
lexical states
- YYINITIAL - Static variable in class org.apache.lucene.analysis.standard.std31.StandardTokenizerImpl31
-
Deprecated.lexical states
- YYINITIAL - Static variable in class org.apache.lucene.analysis.standard.std31.UAX29URLEmailTokenizerImpl31
-
Deprecated.lexical states
- YYINITIAL - Static variable in class org.apache.lucene.analysis.standard.std34.UAX29URLEmailTokenizerImpl34
-
Deprecated.lexical states
- YYINITIAL - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizerImpl
-
lexical states
- yylength() - Method in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
-
Returns the length of the matched text region.
- yylength() - Method in interface org.apache.lucene.analysis.standard.StandardTokenizerInterface
-
Returns the length of the matched text region.
- yylength() - Method in class org.apache.lucene.analysis.standard.std31.StandardTokenizerImpl31
-
Deprecated.Returns the length of the matched text region.
- yylength() - Method in class org.apache.lucene.analysis.standard.std31.UAX29URLEmailTokenizerImpl31
-
Deprecated.Returns the length of the matched text region.
- yylength() - Method in class org.apache.lucene.analysis.standard.std34.UAX29URLEmailTokenizerImpl34
-
Deprecated.Returns the length of the matched text region.
- yylength() - Method in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizerImpl
-
Returns the length of the matched text region.
- yypushback(int) - Method in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
-
Pushes the specified amount of characters back into the input stream.
- yypushback(int) - Method in class org.apache.lucene.analysis.standard.std31.StandardTokenizerImpl31
-
Deprecated.Pushes the specified amount of characters back into the input stream.
- yypushback(int) - Method in class org.apache.lucene.analysis.standard.std31.UAX29URLEmailTokenizerImpl31
-
Deprecated.Pushes the specified amount of characters back into the input stream.
- yypushback(int) - Method in class org.apache.lucene.analysis.standard.std34.UAX29URLEmailTokenizerImpl34
-
Deprecated.Pushes the specified amount of characters back into the input stream.
- yypushback(int) - Method in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizerImpl
-
Pushes the specified amount of characters back into the input stream.
- yyreset(Reader) - Method in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
-
Resets the scanner to read from a new input stream.
- yyreset(Reader) - Method in interface org.apache.lucene.analysis.standard.StandardTokenizerInterface
-
Resets the scanner to read from a new input stream.
- yyreset(Reader) - Method in class org.apache.lucene.analysis.standard.std31.StandardTokenizerImpl31
-
Deprecated.Resets the scanner to read from a new input stream.
- yyreset(Reader) - Method in class org.apache.lucene.analysis.standard.std31.UAX29URLEmailTokenizerImpl31
-
Deprecated.Resets the scanner to read from a new input stream.
- yyreset(Reader) - Method in class org.apache.lucene.analysis.standard.std34.UAX29URLEmailTokenizerImpl34
-
Deprecated.Resets the scanner to read from a new input stream.
- yyreset(Reader) - Method in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizerImpl
-
Resets the scanner to read from a new input stream.
- yystate() - Method in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
-
Returns the current lexical state.
- yystate() - Method in class org.apache.lucene.analysis.standard.std31.StandardTokenizerImpl31
-
Deprecated.Returns the current lexical state.
- yystate() - Method in class org.apache.lucene.analysis.standard.std31.UAX29URLEmailTokenizerImpl31
-
Deprecated.Returns the current lexical state.
- yystate() - Method in class org.apache.lucene.analysis.standard.std34.UAX29URLEmailTokenizerImpl34
-
Deprecated.Returns the current lexical state.
- yystate() - Method in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizerImpl
-
Returns the current lexical state.
- yytext() - Method in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
-
Returns the text matched by the current regular expression.
- yytext() - Method in class org.apache.lucene.analysis.standard.std31.StandardTokenizerImpl31
-
Deprecated.Returns the text matched by the current regular expression.
- yytext() - Method in class org.apache.lucene.analysis.standard.std31.UAX29URLEmailTokenizerImpl31
-
Deprecated.Returns the text matched by the current regular expression.
- yytext() - Method in class org.apache.lucene.analysis.standard.std34.UAX29URLEmailTokenizerImpl34
-
Deprecated.Returns the text matched by the current regular expression.
- yytext() - Method in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizerImpl
-
Returns the text matched by the current regular expression.
_
- _DISTOP_NUM - Static variable in interface org.apache.lucene.queryParser.surround.parser.QueryParserConstants
-
RegularExpression Id.
- _ESCAPED_CHAR - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
-
RegularExpression Id.
- _ESCAPED_CHAR - Static variable in interface org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- _innerIter - Variable in class org.apache.lucene.search.FilteredDocIdSetIterator
- _NUM_CHAR - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
-
RegularExpression Id.
- _NUM_CHAR - Static variable in interface org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- _NUM_CHAR - Static variable in interface org.apache.lucene.queryParser.surround.parser.QueryParserConstants
-
RegularExpression Id.
- _ONE_CHAR - Static variable in interface org.apache.lucene.queryParser.surround.parser.QueryParserConstants
-
RegularExpression Id.
- _QUOTED_CHAR - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
-
RegularExpression Id.
- _QUOTED_CHAR - Static variable in interface org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- _STAR - Static variable in interface org.apache.lucene.queryParser.surround.parser.QueryParserConstants
-
RegularExpression Id.
- _TERM_CHAR - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
-
RegularExpression Id.
- _TERM_CHAR - Static variable in interface org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- _TERM_CHAR - Static variable in interface org.apache.lucene.queryParser.surround.parser.QueryParserConstants
-
RegularExpression Id.
- _TERM_START_CHAR - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
-
RegularExpression Id.
- _TERM_START_CHAR - Static variable in interface org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- _TestHelper - Class in org.apache.lucene.store
-
This class provides access to package-level features defined in the store package.
- _TestHelper() - Constructor for class org.apache.lucene.store._TestHelper
- _TestUtil - Class in org.apache.lucene.util
-
General utility methods for Lucene unit tests.
- _TestUtil() - Constructor for class org.apache.lucene.util._TestUtil
- _WHITESPACE - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
-
RegularExpression Id.
- _WHITESPACE - Static variable in interface org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- _WHITESPACE - Static variable in interface org.apache.lucene.queryParser.surround.parser.QueryParserConstants
-
RegularExpression Id.
All Classes All Packages