Package | Description |
---|---|
org.apache.lucene.analysis.hunspell |
Stemming TokenFilter using a Java implementation of the
Hunspell stemming algorithm.
|
org.apache.lucene.benchmark.byTask |
Benchmarking Lucene By Tasks
|
org.apache.lucene.benchmark.byTask.tasks |
Extendable benchmark tasks.
|
org.apache.lucene.classification.utils |
Utilities for evaluation, data preparation, etc.
|
org.apache.lucene.codecs |
Codecs API: API for customization of the encoding and structure of the index.
|
org.apache.lucene.codecs.asserting |
Codec for testing that asserts various contracts of the codec apis.
|
org.apache.lucene.codecs.compressing |
StoredFieldsFormat that allows cross-document and cross-field compression of stored fields.
|
org.apache.lucene.codecs.lucene50 |
Components from the Lucene 5.0 index format
See
org.apache.lucene.codecs.lucene50 for an overview
of the index format. |
org.apache.lucene.codecs.lucene60 |
Components from the Lucene 6.0 index format.
|
org.apache.lucene.codecs.lucene62 |
Components from the Lucene 6.2 index format
See
org.apache.lucene.codecs.lucene70 for an overview
of the current index format. |
org.apache.lucene.codecs.lucene70 |
Lucene 7.0 file format.
|
org.apache.lucene.codecs.simpletext |
Simpletext Codec: writes human readable postings.
|
org.apache.lucene.facet.taxonomy |
Taxonomy of Categories.
|
org.apache.lucene.facet.taxonomy.directory |
Taxonomy index implementation using on top of a Directory.
|
org.apache.lucene.index |
Code to maintain and access indices.
|
org.apache.lucene.misc |
Miscellaneous index tools.
|
org.apache.lucene.replicator |
Files replication framework
|
org.apache.lucene.replicator.nrt |
Near-real-time replication framework
|
org.apache.lucene.search |
Code to search indices.
|
org.apache.lucene.search.spell |
Suggest alternate spellings for words.
|
org.apache.lucene.search.suggest |
Support for Autocomplete/Autosuggest
|
org.apache.lucene.search.suggest.analyzing |
Analyzer based autosuggest.
|
org.apache.lucene.search.suggest.fst |
Finite-state based autosuggest.
|
org.apache.lucene.search.suggest.tst |
Ternary Search Tree based autosuggest.
|
org.apache.lucene.store |
Binary i/o API, used for all index data.
|
org.apache.lucene.util |
Some utility classes.
|
org.apache.lucene.util.bkd |
Block KD-tree, implementing the generic spatial data structure described in
this paper.
|
org.apache.lucene.util.fst |
Finite state transducers
|
Constructor and Description |
---|
Dictionary(Directory tempDir,
java.lang.String tempFileNamePrefix,
java.io.InputStream affix,
java.io.InputStream dictionary)
Creates a new Dictionary containing the information read from the provided InputStreams to hunspell affix
and dictionary files.
|
Dictionary(Directory tempDir,
java.lang.String tempFileNamePrefix,
java.io.InputStream affix,
java.util.List<java.io.InputStream> dictionaries,
boolean ignoreCase)
Creates a new Dictionary containing the information read from the provided InputStreams to hunspell affix
and dictionary files.
|
Modifier and Type | Method and Description |
---|---|
Directory |
PerfRunData.getDirectory() |
Directory |
PerfRunData.getTaxonomyDir() |
Modifier and Type | Method and Description |
---|---|
void |
PerfRunData.setDirectory(Directory directory) |
Modifier and Type | Method and Description |
---|---|
static IndexCommit |
OpenReaderTask.findIndexCommit(Directory dir,
java.lang.String userData) |
Modifier and Type | Method and Description |
---|---|
void |
DatasetSplitter.split(IndexReader originalIndex,
Directory trainingIndex,
Directory testIndex,
Directory crossValidationIndex,
Analyzer analyzer,
boolean termVectors,
java.lang.String classFieldName,
java.lang.String... fieldNames)
Split a given index into 3 indexes for training, test and cross validation tasks respectively
|
Modifier and Type | Method and Description |
---|---|
abstract Directory |
CompoundFormat.getCompoundReader(Directory dir,
SegmentInfo si,
IOContext context)
Returns a Directory view (read-only) for the compound files in this segment
|
Modifier and Type | Method and Description |
---|---|
abstract StoredFieldsReader |
StoredFieldsFormat.fieldsReader(Directory directory,
SegmentInfo si,
FieldInfos fn,
IOContext context)
Returns a
StoredFieldsReader to load stored
fields. |
abstract StoredFieldsWriter |
StoredFieldsFormat.fieldsWriter(Directory directory,
SegmentInfo si,
IOContext context)
Returns a
StoredFieldsWriter to write stored
fields. |
abstract Directory |
CompoundFormat.getCompoundReader(Directory dir,
SegmentInfo si,
IOContext context)
Returns a Directory view (read-only) for the compound files in this segment
|
abstract FieldInfos |
FieldInfosFormat.read(Directory directory,
SegmentInfo segmentInfo,
java.lang.String segmentSuffix,
IOContext iocontext)
|
abstract SegmentInfo |
SegmentInfoFormat.read(Directory directory,
java.lang.String segmentName,
byte[] segmentID,
IOContext context)
Read
SegmentInfo data from a directory. |
abstract Bits |
LiveDocsFormat.readLiveDocs(Directory dir,
SegmentCommitInfo info,
IOContext context)
Read live docs bits.
|
abstract TermVectorsReader |
TermVectorsFormat.vectorsReader(Directory directory,
SegmentInfo segmentInfo,
FieldInfos fieldInfos,
IOContext context)
Returns a
TermVectorsReader to read term
vectors. |
abstract TermVectorsWriter |
TermVectorsFormat.vectorsWriter(Directory directory,
SegmentInfo segmentInfo,
IOContext context)
Returns a
TermVectorsWriter to write term
vectors. |
abstract void |
CompoundFormat.write(Directory dir,
SegmentInfo si,
IOContext context)
Packs the provided segment's files into a compound format.
|
abstract void |
SegmentInfoFormat.write(Directory dir,
SegmentInfo info,
IOContext ioContext)
Write
SegmentInfo data. |
abstract void |
FieldInfosFormat.write(Directory directory,
SegmentInfo segmentInfo,
java.lang.String segmentSuffix,
FieldInfos infos,
IOContext context)
Writes the provided
FieldInfos to the
directory. |
abstract void |
LiveDocsFormat.writeLiveDocs(Bits bits,
Directory dir,
SegmentCommitInfo info,
int newDelCount,
IOContext context)
Persist live docs bits.
|
Modifier and Type | Method and Description |
---|---|
StoredFieldsReader |
AssertingStoredFieldsFormat.fieldsReader(Directory directory,
SegmentInfo si,
FieldInfos fn,
IOContext context) |
StoredFieldsWriter |
AssertingStoredFieldsFormat.fieldsWriter(Directory directory,
SegmentInfo si,
IOContext context) |
Bits |
AssertingLiveDocsFormat.readLiveDocs(Directory dir,
SegmentCommitInfo info,
IOContext context) |
TermVectorsReader |
AssertingTermVectorsFormat.vectorsReader(Directory directory,
SegmentInfo segmentInfo,
FieldInfos fieldInfos,
IOContext context) |
TermVectorsWriter |
AssertingTermVectorsFormat.vectorsWriter(Directory directory,
SegmentInfo segmentInfo,
IOContext context) |
void |
AssertingLiveDocsFormat.writeLiveDocs(Bits bits,
Directory dir,
SegmentCommitInfo info,
int newDelCount,
IOContext context) |
Modifier and Type | Method and Description |
---|---|
StoredFieldsReader |
CompressingStoredFieldsFormat.fieldsReader(Directory directory,
SegmentInfo si,
FieldInfos fn,
IOContext context) |
StoredFieldsWriter |
CompressingStoredFieldsFormat.fieldsWriter(Directory directory,
SegmentInfo si,
IOContext context) |
TermVectorsReader |
CompressingTermVectorsFormat.vectorsReader(Directory directory,
SegmentInfo segmentInfo,
FieldInfos fieldInfos,
IOContext context) |
TermVectorsWriter |
CompressingTermVectorsFormat.vectorsWriter(Directory directory,
SegmentInfo segmentInfo,
IOContext context) |
Constructor and Description |
---|
CompressingStoredFieldsReader(Directory d,
SegmentInfo si,
java.lang.String segmentSuffix,
FieldInfos fn,
IOContext context,
java.lang.String formatName,
CompressionMode compressionMode)
Sole constructor.
|
CompressingStoredFieldsWriter(Directory directory,
SegmentInfo si,
java.lang.String segmentSuffix,
IOContext context,
java.lang.String formatName,
CompressionMode compressionMode,
int chunkSize,
int maxDocsPerChunk,
int blockSize)
Sole constructor.
|
CompressingTermVectorsReader(Directory d,
SegmentInfo si,
java.lang.String segmentSuffix,
FieldInfos fn,
IOContext context,
java.lang.String formatName,
CompressionMode compressionMode)
Sole constructor.
|
CompressingTermVectorsWriter(Directory directory,
SegmentInfo si,
java.lang.String segmentSuffix,
IOContext context,
java.lang.String formatName,
CompressionMode compressionMode,
int chunkSize,
int blockSize)
Sole constructor.
|
Modifier and Type | Method and Description |
---|---|
Directory |
Lucene50CompoundFormat.getCompoundReader(Directory dir,
SegmentInfo si,
IOContext context) |
Modifier and Type | Method and Description |
---|---|
StoredFieldsReader |
Lucene50StoredFieldsFormat.fieldsReader(Directory directory,
SegmentInfo si,
FieldInfos fn,
IOContext context) |
StoredFieldsWriter |
Lucene50StoredFieldsFormat.fieldsWriter(Directory directory,
SegmentInfo si,
IOContext context) |
Directory |
Lucene50CompoundFormat.getCompoundReader(Directory dir,
SegmentInfo si,
IOContext context) |
FieldInfos |
Lucene50FieldInfosFormat.read(Directory directory,
SegmentInfo segmentInfo,
java.lang.String segmentSuffix,
IOContext context) |
SegmentInfo |
Lucene50SegmentInfoFormat.read(Directory dir,
java.lang.String segment,
byte[] segmentID,
IOContext context)
Deprecated.
|
Bits |
Lucene50LiveDocsFormat.readLiveDocs(Directory dir,
SegmentCommitInfo info,
IOContext context) |
void |
Lucene50SegmentInfoFormat.write(Directory dir,
SegmentInfo si,
IOContext ioContext)
Deprecated.
|
void |
Lucene50CompoundFormat.write(Directory dir,
SegmentInfo si,
IOContext context) |
void |
Lucene50FieldInfosFormat.write(Directory directory,
SegmentInfo segmentInfo,
java.lang.String segmentSuffix,
FieldInfos infos,
IOContext context) |
void |
Lucene50LiveDocsFormat.writeLiveDocs(Bits bits,
Directory dir,
SegmentCommitInfo info,
int newDelCount,
IOContext context) |
Modifier and Type | Method and Description |
---|---|
FieldInfos |
Lucene60FieldInfosFormat.read(Directory directory,
SegmentInfo segmentInfo,
java.lang.String segmentSuffix,
IOContext context) |
void |
Lucene60FieldInfosFormat.write(Directory directory,
SegmentInfo segmentInfo,
java.lang.String segmentSuffix,
FieldInfos infos,
IOContext context) |
Modifier and Type | Method and Description |
---|---|
SegmentInfo |
Lucene62SegmentInfoFormat.read(Directory dir,
java.lang.String segment,
byte[] segmentID,
IOContext context) |
void |
Lucene62SegmentInfoFormat.write(Directory dir,
SegmentInfo info,
IOContext ioContext) |
Modifier and Type | Method and Description |
---|---|
SegmentInfo |
Lucene70SegmentInfoFormat.read(Directory dir,
java.lang.String segment,
byte[] segmentID,
IOContext context) |
void |
Lucene70SegmentInfoFormat.write(Directory dir,
SegmentInfo si,
IOContext ioContext) |
Modifier and Type | Method and Description |
---|---|
Directory |
SimpleTextCompoundFormat.getCompoundReader(Directory dir,
SegmentInfo si,
IOContext context) |
Modifier and Type | Method and Description |
---|---|
StoredFieldsReader |
SimpleTextStoredFieldsFormat.fieldsReader(Directory directory,
SegmentInfo si,
FieldInfos fn,
IOContext context) |
StoredFieldsWriter |
SimpleTextStoredFieldsFormat.fieldsWriter(Directory directory,
SegmentInfo si,
IOContext context) |
Directory |
SimpleTextCompoundFormat.getCompoundReader(Directory dir,
SegmentInfo si,
IOContext context) |
FieldInfos |
SimpleTextFieldInfosFormat.read(Directory directory,
SegmentInfo segmentInfo,
java.lang.String segmentSuffix,
IOContext iocontext) |
SegmentInfo |
SimpleTextSegmentInfoFormat.read(Directory directory,
java.lang.String segmentName,
byte[] segmentID,
IOContext context) |
Bits |
SimpleTextLiveDocsFormat.readLiveDocs(Directory dir,
SegmentCommitInfo info,
IOContext context) |
TermVectorsReader |
SimpleTextTermVectorsFormat.vectorsReader(Directory directory,
SegmentInfo segmentInfo,
FieldInfos fieldInfos,
IOContext context) |
TermVectorsWriter |
SimpleTextTermVectorsFormat.vectorsWriter(Directory directory,
SegmentInfo segmentInfo,
IOContext context) |
void |
SimpleTextSegmentInfoFormat.write(Directory dir,
SegmentInfo si,
IOContext ioContext) |
void |
SimpleTextCompoundFormat.write(Directory dir,
SegmentInfo si,
IOContext context) |
void |
SimpleTextFieldInfosFormat.write(Directory directory,
SegmentInfo segmentInfo,
java.lang.String segmentSuffix,
FieldInfos infos,
IOContext context) |
void |
SimpleTextLiveDocsFormat.writeLiveDocs(Bits bits,
Directory dir,
SegmentCommitInfo info,
int newDelCount,
IOContext context) |
Constructor and Description |
---|
SimpleTextStoredFieldsReader(Directory directory,
SegmentInfo si,
FieldInfos fn,
IOContext context) |
SimpleTextStoredFieldsWriter(Directory directory,
java.lang.String segment,
IOContext context) |
SimpleTextTermVectorsReader(Directory directory,
SegmentInfo si,
IOContext context) |
SimpleTextTermVectorsWriter(Directory directory,
java.lang.String segment,
IOContext context) |
Modifier and Type | Method and Description |
---|---|
static void |
TaxonomyMergeUtils.merge(Directory srcIndexDir,
Directory srcTaxoDir,
DirectoryTaxonomyWriter.OrdinalMap map,
IndexWriter destIndexWriter,
DirectoryTaxonomyWriter destTaxoWriter,
FacetsConfig srcConfig)
Merges the given taxonomy and index directories and commits the changes to
the given writers.
|
Constructor and Description |
---|
SearcherTaxonomyManager(Directory indexDir,
Directory taxoDir,
SearcherFactory searcherFactory)
Creates search and taxonomy readers over the corresponding directories.
|
Modifier and Type | Method and Description |
---|---|
Directory |
DirectoryTaxonomyWriter.getDirectory()
Returns the
Directory of this taxonomy writer. |
Modifier and Type | Method and Description |
---|---|
void |
DirectoryTaxonomyWriter.addTaxonomy(Directory taxoDir,
DirectoryTaxonomyWriter.OrdinalMap map)
Takes the categories from the given taxonomy directory, and adds the
missing ones to this taxonomy.
|
protected DirectoryReader |
DirectoryTaxonomyReader.openIndexReader(Directory directory)
Open the
DirectoryReader from this Directory . |
protected IndexWriter |
DirectoryTaxonomyWriter.openIndexWriter(Directory directory,
IndexWriterConfig config)
Open internal index writer, which contains the taxonomy data.
|
void |
DirectoryTaxonomyWriter.replaceTaxonomy(Directory taxoDir)
Replaces the current taxonomy with the given one.
|
Constructor and Description |
---|
DirectoryTaxonomyReader(Directory directory)
Open for reading a taxonomy stored in a given
Directory . |
DirectoryTaxonomyWriter(Directory d)
Create this with
OpenMode.CREATE_OR_APPEND . |
DirectoryTaxonomyWriter(Directory directory,
IndexWriterConfig.OpenMode openMode)
Creates a new instance with a default cache as defined by
DirectoryTaxonomyWriter.defaultTaxonomyWriterCache() . |
DirectoryTaxonomyWriter(Directory directory,
IndexWriterConfig.OpenMode openMode,
TaxonomyWriterCache cache)
Construct a Taxonomy writer.
|
Modifier and Type | Field and Description |
---|---|
protected Directory |
ThreadedIndexingAndSearchingTestCase.dir |
Directory |
CheckIndex.Status.dir
Directory index is in.
|
Directory |
SegmentInfo.dir
Where this segment resides.
|
protected Directory |
DirectoryReader.directory
The index directory.
|
Directory |
SegmentReadState.directory
Directory where this segment is read from. |
Directory |
SegmentWriteState.directory
Directory where this segment will be written
to. |
Modifier and Type | Method and Description |
---|---|
protected static Directory |
BaseCompoundFormatTestCase.createLargeCFS(Directory dir)
Setup a large compound file with a number of components, each of
which is a sequential file (so that we can easily tell that we are
reading in the right byte).
|
Directory |
DirectoryReader.directory()
Returns the directory this index resides in.
|
Directory |
SegmentReader.directory()
Returns the directory this index resides in.
|
Directory |
MergePolicy.MergeException.getDirectory()
Returns the
Directory of the index that hit
the exception. |
Directory |
IndexWriter.getDirectory()
Returns the Directory used by this index.
|
abstract Directory |
IndexCommit.getDirectory()
Returns the
Directory for the index. |
protected Directory |
ThreadedIndexingAndSearchingTestCase.getDirectory(Directory in) |
Directory |
MergeScheduler.wrapForMerge(MergePolicy.OneMerge merge,
Directory in)
Wraps the incoming
Directory so that we can merge-throttle it
using RateLimitedIndexOutput . |
Directory |
NoMergeScheduler.wrapForMerge(MergePolicy.OneMerge merge,
Directory in) |
Directory |
ConcurrentMergeScheduler.wrapForMerge(MergePolicy.OneMerge merge,
Directory in) |
Modifier and Type | Method and Description |
---|---|
long |
RandomIndexWriter.addIndexes(Directory... dirs) |
long |
IndexWriter.addIndexes(Directory... dirs)
Adds all segments from an array of indexes into this index.
|
FieldsProducer |
RandomPostingsTester.buildIndex(Codec codec,
Directory dir,
IndexOptions maxAllowed,
boolean allowPayloads,
boolean alwaysTestMax) |
void |
SegmentInfos.commit(Directory dir)
Writes and syncs to the Directory dir, taking care to
remove the segments file on exception
|
protected static Directory |
BaseCompoundFormatTestCase.createLargeCFS(Directory dir)
Setup a large compound file with a number of components, each of
which is a sequential file (so that we can easily tell that we are
reading in the right byte).
|
protected static void |
BaseCompoundFormatTestCase.createRandomFile(Directory dir,
java.lang.String name,
int size,
byte[] segId)
Creates a file of the specified size with random data.
|
protected static void |
BaseCompoundFormatTestCase.createSequenceFile(Directory dir,
java.lang.String name,
byte start,
int size,
byte[] segID,
java.lang.String segSuffix)
Creates a file of the specified size with sequential data.
|
protected Directory |
ThreadedIndexingAndSearchingTestCase.getDirectory(Directory in) |
static long |
SegmentInfos.getLastCommitGeneration(Directory directory)
Get the generation of the most recent commit to the
index in this directory (N in the segments_N file).
|
static java.lang.String |
SegmentInfos.getLastCommitSegmentsFileName(Directory directory)
Get the filename of the segments_N file for the most
recent commit to the index in this Directory.
|
protected void |
SuppressingConcurrentMergeScheduler.handleMergeException(Directory dir,
java.lang.Throwable exc) |
protected void |
ConcurrentMergeScheduler.handleMergeException(Directory dir,
java.lang.Throwable exc)
Called when an exception is hit in a background merge
thread
|
static boolean |
DirectoryReader.indexExists(Directory directory)
Returns
true if an index likely exists at
the specified directory. |
static java.util.List<IndexCommit> |
DirectoryReader.listCommits(Directory dir)
Returns all commit points that exist in the Directory.
|
static IndexWriter |
RandomIndexWriter.mockIndexWriter(Directory dir,
IndexWriterConfig conf,
java.util.Random r)
Returns an indexwriter that randomly mixes up thread scheduling (by yielding at test points)
|
static IndexWriter |
RandomIndexWriter.mockIndexWriter(java.util.Random r,
Directory dir,
IndexWriterConfig conf,
RandomIndexWriter.TestPoint testPoint)
Returns an indexwriter that enables the specified test point
|
protected static SegmentInfo |
BaseCompoundFormatTestCase.newSegmentInfo(Directory dir,
java.lang.String name)
Returns a new fake segment
|
protected static SegmentInfo |
BaseFieldInfoFormatTestCase.newSegmentInfo(Directory dir,
java.lang.String name)
Returns a new fake segment
|
static DirectoryReader |
DirectoryReader.open(Directory directory)
Returns a IndexReader reading the index in the given
Directory
|
static DirectoryReader |
StandardDirectoryReader.open(Directory directory,
SegmentInfos infos,
java.util.List<? extends LeafReader> oldReaders)
This constructor is only used for
StandardDirectoryReader.doOpenIfChanged(SegmentInfos) , as well as NRT replication. |
static SegmentInfos |
SegmentInfos.readCommit(Directory directory,
ChecksumIndexInput input,
long generation)
Read the commit from the provided
ChecksumIndexInput . |
static SegmentInfos |
SegmentInfos.readCommit(Directory directory,
java.lang.String segmentFileName)
Read a particular segmentFileName.
|
static SegmentInfos |
SegmentInfos.readLatestCommit(Directory directory)
Find the latest commit (
segments_N file ) and
load all SegmentCommitInfo s. |
java.lang.String |
MergePolicy.MergeSpecification.segString(Directory dir)
Returns a description of the merges in this specification.
|
void |
MultiPassIndexSplitter.split(IndexReader in,
Directory[] outputs,
boolean seq)
Split source index into multiple parts.
|
void |
BaseTestCheckIndex.testChecksumsOnly(Directory dir) |
void |
BaseTestCheckIndex.testChecksumsOnlyVerbose(Directory dir) |
void |
BaseTestCheckIndex.testDeletedDocs(Directory dir) |
void |
BaseTestCheckIndex.testObtainsLock(Directory dir) |
Directory |
MergeScheduler.wrapForMerge(MergePolicy.OneMerge merge,
Directory in)
Wraps the incoming
Directory so that we can merge-throttle it
using RateLimitedIndexOutput . |
Directory |
NoMergeScheduler.wrapForMerge(MergePolicy.OneMerge merge,
Directory in) |
Directory |
ConcurrentMergeScheduler.wrapForMerge(MergePolicy.OneMerge merge,
Directory in) |
void |
SegmentInfos.write(Directory directory,
IndexOutput out)
Write ourselves to the provided
IndexOutput |
Constructor and Description |
---|
CheckIndex(Directory dir)
Create a new CheckIndex on the directory.
|
CheckIndex(Directory dir,
Lock writeLock)
Expert: create a directory with the specified lock.
|
DirectoryReader(Directory directory,
LeafReader[] segmentReaders)
Expert: Constructs a
DirectoryReader on the given subReaders. |
FindSegmentsFile(Directory directory)
Sole constructor.
|
IndexUpgrader(Directory dir)
Creates index upgrader on the given directory, using an
IndexWriter using the given
matchVersion . |
IndexUpgrader(Directory dir,
IndexWriterConfig iwc,
boolean deletePriorCommits)
Creates index upgrader on the given directory, using an
IndexWriter using the given
config. |
IndexUpgrader(Directory dir,
InfoStream infoStream,
boolean deletePriorCommits)
Creates index upgrader on the given directory, using an
IndexWriter using the given
matchVersion . |
IndexWriter(Directory d,
IndexWriterConfig conf)
Constructs a new IndexWriter per the settings given in
conf . |
MergeException(java.lang.String message,
Directory dir)
Create a
MergeException . |
MergeException(java.lang.Throwable exc,
Directory dir)
Create a
MergeException . |
PersistentSnapshotDeletionPolicy(IndexDeletionPolicy primary,
Directory dir)
PersistentSnapshotDeletionPolicy wraps another
IndexDeletionPolicy to enable flexible
snapshotting, passing IndexWriterConfig.OpenMode.CREATE_OR_APPEND
by default. |
PersistentSnapshotDeletionPolicy(IndexDeletionPolicy primary,
Directory dir,
IndexWriterConfig.OpenMode mode)
PersistentSnapshotDeletionPolicy wraps another
IndexDeletionPolicy to enable flexible snapshotting. |
PKIndexSplitter(Directory input,
Directory dir1,
Directory dir2,
Query docsInFirstIndex)
Split an index based on a
Query . |
PKIndexSplitter(Directory input,
Directory dir1,
Directory dir2,
Query docsInFirstIndex,
IndexWriterConfig config1,
IndexWriterConfig config2) |
PKIndexSplitter(Directory input,
Directory dir1,
Directory dir2,
Term midTerm)
Split an index based on a given primary key term
and a 'middle' term.
|
PKIndexSplitter(Directory input,
Directory dir1,
Directory dir2,
Term midTerm,
IndexWriterConfig config1,
IndexWriterConfig config2) |
RandomIndexWriter(java.util.Random r,
Directory dir)
create a RandomIndexWriter with a random config: Uses MockAnalyzer
|
RandomIndexWriter(java.util.Random r,
Directory dir,
Analyzer a)
create a RandomIndexWriter with a random config
|
RandomIndexWriter(java.util.Random r,
Directory dir,
IndexWriterConfig c)
create a RandomIndexWriter with the provided config
|
RandomIndexWriter(java.util.Random r,
Directory dir,
IndexWriterConfig c,
boolean useSoftDeletes)
create a RandomIndexWriter with the provided config
|
ReaderManager(Directory dir)
Creates and returns a new ReaderManager from the given
Directory . |
SegmentInfo(Directory dir,
Version version,
Version minVersion,
java.lang.String name,
int maxDoc,
boolean isCompoundFile,
Codec codec,
java.util.Map<java.lang.String,java.lang.String> diagnostics,
byte[] id,
java.util.Map<java.lang.String,java.lang.String> attributes,
Sort indexSort)
Construct a new complete SegmentInfo instance from input.
|
SegmentReadState(Directory dir,
SegmentInfo info,
FieldInfos fieldInfos,
IOContext context)
Create a
SegmentReadState . |
SegmentReadState(Directory dir,
SegmentInfo info,
FieldInfos fieldInfos,
IOContext context,
java.lang.String segmentSuffix)
Create a
SegmentReadState . |
SegmentWriteState(InfoStream infoStream,
Directory directory,
SegmentInfo segmentInfo,
FieldInfos fieldInfos,
org.apache.lucene.index.BufferedUpdates segUpdates,
IOContext context)
Sole constructor.
|
SegmentWriteState(InfoStream infoStream,
Directory directory,
SegmentInfo segmentInfo,
FieldInfos fieldInfos,
org.apache.lucene.index.BufferedUpdates segUpdates,
IOContext context,
java.lang.String segmentSuffix)
Constructor which takes segment suffix.
|
Modifier and Type | Method and Description |
---|---|
static void |
GetTermInfo.getTermInfo(Directory dir,
Term term) |
Modifier and Type | Method and Description |
---|---|
Directory |
ReplicationClient.SourceDirectoryFactory.getDirectory(java.lang.String sessionID,
java.lang.String source)
Returns the
Directory to use for the given session and source. |
Directory |
PerSessionDirectoryFactory.getDirectory(java.lang.String sessionID,
java.lang.String source) |
Modifier and Type | Method and Description |
---|---|
static void |
IndexReplicationHandler.cleanupFilesOnFailure(Directory dir,
java.util.List<java.lang.String> files)
Cleanup the index directory by deleting all given files.
|
static void |
IndexReplicationHandler.cleanupOldIndexFiles(Directory dir,
java.lang.String segmentsFile,
InfoStream infoStream)
Cleans up the index directory from old index files.
|
static void |
IndexReplicationHandler.copyFiles(Directory source,
Directory target,
java.util.List<java.lang.String> files)
Copies the files from the source directory to the target one, if they are
not the same.
|
static IndexCommit |
IndexReplicationHandler.getLastCommit(Directory dir)
|
protected IndexWriter |
IndexAndTaxonomyRevision.SnapshotDirectoryTaxonomyWriter.openIndexWriter(Directory directory,
IndexWriterConfig config) |
Modifier and Type | Method and Description |
---|---|
void |
IndexReplicationHandler.revisionReady(java.lang.String version,
java.util.Map<java.lang.String,java.util.List<RevisionFile>> revisionFiles,
java.util.Map<java.lang.String,java.util.List<java.lang.String>> copiedFiles,
java.util.Map<java.lang.String,Directory> sourceDirectory) |
void |
ReplicationClient.ReplicationHandler.revisionReady(java.lang.String version,
java.util.Map<java.lang.String,java.util.List<RevisionFile>> revisionFiles,
java.util.Map<java.lang.String,java.util.List<java.lang.String>> copiedFiles,
java.util.Map<java.lang.String,Directory> sourceDirectory)
Called when a new revision was obtained and is available (i.e.
|
void |
IndexAndTaxonomyReplicationHandler.revisionReady(java.lang.String version,
java.util.Map<java.lang.String,java.util.List<RevisionFile>> revisionFiles,
java.util.Map<java.lang.String,java.util.List<java.lang.String>> copiedFiles,
java.util.Map<java.lang.String,Directory> sourceDirectory) |
Constructor and Description |
---|
IndexAndTaxonomyReplicationHandler(Directory indexDir,
Directory taxoDir,
java.util.concurrent.Callable<java.lang.Boolean> callback)
Constructor with the given index directory and callback to notify when the
indexes were updated.
|
IndexReplicationHandler(Directory indexDir,
java.util.concurrent.Callable<java.lang.Boolean> callback)
Constructor with the given index directory and callback to notify when the
indexes were updated.
|
SnapshotDirectoryTaxonomyWriter(Directory d) |
SnapshotDirectoryTaxonomyWriter(Directory directory,
IndexWriterConfig.OpenMode openMode) |
SnapshotDirectoryTaxonomyWriter(Directory directory,
IndexWriterConfig.OpenMode openMode,
TaxonomyWriterCache cache) |
Modifier and Type | Field and Description |
---|---|
protected Directory |
Node.dir |
Modifier and Type | Method and Description |
---|---|
Directory |
Node.getDirectory()
Returns the
Directory this node is writing to |
Constructor and Description |
---|
Node(int id,
Directory dir,
SearcherFactory searcherFactory,
java.io.PrintStream printStream) |
ReplicaNode(int id,
Directory dir,
SearcherFactory searcherFactory,
java.io.PrintStream printStream) |
Modifier and Type | Field and Description |
---|---|
Directory |
ShardSearchingTestBase.NodeState.dir |
protected static Directory |
SearchEquivalenceTestBase.directory |
protected static Directory |
BaseExplanationTestCase.directory |
Constructor and Description |
---|
SearcherManager(Directory dir,
SearcherFactory searcherFactory)
Creates and returns a new SearcherManager from the given
Directory . |
Modifier and Type | Method and Description |
---|---|
void |
SpellChecker.setSpellIndex(Directory spellIndexDir)
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. |
Constructor and Description |
---|
SpellChecker(Directory spellIndex)
Use the given directory as a spell checker index with a
LevenshteinDistance as the default StringDistance . |
SpellChecker(Directory spellIndex,
StringDistance sd)
Use the given directory as a spell checker index.
|
SpellChecker(Directory spellIndex,
StringDistance sd,
java.util.Comparator<SuggestWord> comparator)
Use the given directory as a spell checker index with the given
StringDistance measure
and the given Comparator for sorting the results. |
Constructor and Description |
---|
SortedInputIterator(Directory tempDir,
java.lang.String tempFileNamePrefix,
InputIterator source)
Creates a new sorted wrapper, using natural order
for sorting.
|
SortedInputIterator(Directory tempDir,
java.lang.String tempFileNamePrefix,
InputIterator source,
java.util.Comparator<BytesRef> comparator)
Creates a new sorted wrapper, sorting by BytesRef
(ascending) then cost (ascending).
|
Modifier and Type | Method and Description |
---|---|
protected Directory |
AnalyzingInfixSuggester.getDirectory(java.nio.file.Path path)
Subclass can override to choose a specific
Directory implementation. |
Constructor and Description |
---|
AnalyzingInfixSuggester(Directory dir,
Analyzer analyzer)
Create a new instance, loading from a previously built
AnalyzingInfixSuggester directory, if it exists.
|
AnalyzingInfixSuggester(Directory dir,
Analyzer indexAnalyzer,
Analyzer queryAnalyzer,
int minPrefixChars,
boolean commitOnBuild)
Create a new instance, loading from a previously built
AnalyzingInfixSuggester directory, if it exists.
|
AnalyzingInfixSuggester(Directory dir,
Analyzer indexAnalyzer,
Analyzer queryAnalyzer,
int minPrefixChars,
boolean commitOnBuild,
boolean allTermsRequired,
boolean highlight)
Create a new instance, loading from a previously built
AnalyzingInfixSuggester directory, if it exists.
|
AnalyzingInfixSuggester(Directory dir,
Analyzer indexAnalyzer,
Analyzer queryAnalyzer,
int minPrefixChars,
boolean commitOnBuild,
boolean allTermsRequired,
boolean highlight,
boolean closeIndexWriterOnBuild)
Create a new instance, loading from a previously built
AnalyzingInfixSuggester directory, if it exists.
|
AnalyzingSuggester(Directory tempDir,
java.lang.String tempFileNamePrefix,
Analyzer analyzer)
|
AnalyzingSuggester(Directory tempDir,
java.lang.String tempFileNamePrefix,
Analyzer indexAnalyzer,
Analyzer queryAnalyzer)
|
AnalyzingSuggester(Directory tempDir,
java.lang.String tempFileNamePrefix,
Analyzer indexAnalyzer,
Analyzer queryAnalyzer,
int options,
int maxSurfaceFormsPerAnalyzedForm,
int maxGraphExpansions,
boolean preservePositionIncrements)
Creates a new suggester.
|
BlendedInfixSuggester(Directory dir,
Analyzer analyzer)
Create a new instance, loading from a previously built
directory, if it exists.
|
BlendedInfixSuggester(Directory dir,
Analyzer indexAnalyzer,
Analyzer queryAnalyzer,
int minPrefixChars,
BlendedInfixSuggester.BlenderType blenderType,
int numFactor,
boolean commitOnBuild)
Create a new instance, loading from a previously built
directory, if it exists.
|
BlendedInfixSuggester(Directory dir,
Analyzer indexAnalyzer,
Analyzer queryAnalyzer,
int minPrefixChars,
BlendedInfixSuggester.BlenderType blenderType,
int numFactor,
java.lang.Double exponent,
boolean commitOnBuild,
boolean allTermsRequired,
boolean highlight)
Create a new instance, loading from a previously built
directory, if it exists.
|
FuzzySuggester(Directory tempDir,
java.lang.String tempFileNamePrefix,
Analyzer analyzer)
Creates a
FuzzySuggester instance initialized with default values. |
FuzzySuggester(Directory tempDir,
java.lang.String tempFileNamePrefix,
Analyzer indexAnalyzer,
Analyzer queryAnalyzer)
Creates a
FuzzySuggester instance with an index and query analyzer initialized with default values. |
FuzzySuggester(Directory tempDir,
java.lang.String tempFileNamePrefix,
Analyzer indexAnalyzer,
Analyzer queryAnalyzer,
int options,
int maxSurfaceFormsPerAnalyzedForm,
int maxGraphExpansions,
boolean preservePositionIncrements,
int maxEdits,
boolean transpositions,
int nonFuzzyPrefix,
int minFuzzyLength,
boolean unicodeAware)
Creates a
FuzzySuggester instance. |
Constructor and Description |
---|
FSTCompletionLookup(Directory tempDir,
java.lang.String tempFileNamePrefix)
This constructor prepares for creating a suggested FST using the
FSTCompletionLookup.build(InputIterator) method. |
FSTCompletionLookup(Directory tempDir,
java.lang.String tempFileNamePrefix,
FSTCompletion completion,
boolean exactMatchFirst)
This constructor takes a pre-built automaton.
|
FSTCompletionLookup(Directory tempDir,
java.lang.String tempFileNamePrefix,
int buckets,
boolean exactMatchFirst)
This constructor prepares for creating a suggested FST using the
FSTCompletionLookup.build(InputIterator) method. |
WFSTCompletionLookup(Directory tempDir,
java.lang.String tempFileNamePrefix)
|
WFSTCompletionLookup(Directory tempDir,
java.lang.String tempFileNamePrefix,
boolean exactFirst)
Creates a new suggester.
|
Constructor and Description |
---|
TSTLookup(Directory tempDir,
java.lang.String tempFileNamePrefix)
Creates a new TSTLookup, for building.
|
Modifier and Type | Class and Description |
---|---|
class |
BaseDirectory
Base implementation for a concrete
Directory that uses a LockFactory for locking. |
class |
BaseDirectoryWrapper
Calls check index on close.
|
class |
ByteBuffersDirectory
A
ByteBuffer -based Directory implementation that
can be used to store index files on the heap. |
class |
FileSwitchDirectory
Expert: A Directory instance that switches files between
two other Directory instances.
|
class |
FilterDirectory
Directory implementation that delegates calls to another directory.
|
class |
FSDirectory
Base class for Directory implementations that store index
files in the file system.
|
class |
HardlinkCopyDirectoryWrapper
This directory wrapper overrides
copyFrom(Directory, String, String, IOContext) in order
to optionally use a hard-link instead of a full byte by byte file copy if applicable. |
class |
LockValidatingDirectoryWrapper
This class makes a best-effort check that a provided
Lock
is valid before any destructive filesystem operation. |
class |
MMapDirectory
File-based
Directory implementation that uses
mmap for reading, and FSDirectory.FSIndexOutput for writing. |
class |
MockDirectoryWrapper
This is a Directory Wrapper that adds methods
intended to be used only by unit tests.
|
class |
NativeUnixDirectory
A
Directory implementation for all Unixes that uses
DIRECT I/O to bypass OS level IO caching during
merging. |
class |
NIOFSDirectory
An
FSDirectory implementation that uses java.nio's FileChannel's
positional read, which allows multiple threads to read from the same file
without synchronizing. |
class |
NRTCachingDirectory
Wraps a
RAMDirectory
around any provided delegate directory, to
be used during NRT search. |
class |
RAFDirectory
A straightforward implementation of
FSDirectory
using java.io.RandomAccessFile. |
class |
RAMDirectory
Deprecated.
This class uses inefficient synchronization and is discouraged
in favor of
MMapDirectory . It will be removed in future versions
of Lucene. |
class |
RawDirectoryWrapper
Delegates all operations, even optional ones, to the wrapped directory.
|
class |
SimpleFSDirectory
A straightforward implementation of
FSDirectory
using Files.newByteChannel(Path, java.nio.file.OpenOption...) . |
class |
SleepingLockWrapper
Directory that wraps another, and that sleeps and retries
if obtaining the lock fails.
|
class |
TrackingDirectoryWrapper
A delegating Directory that records which files were
written to and deleted.
|
class |
WindowsDirectory
Native
Directory implementation for Microsoft Windows. |
Modifier and Type | Field and Description |
---|---|
protected Directory |
FilterDirectory.in |
Modifier and Type | Method and Description |
---|---|
Directory |
FilterDirectory.getDelegate()
Return the wrapped
Directory . |
protected abstract Directory |
BaseLockFactoryTestCase.getDirectory(java.nio.file.Path path)
Subclass returns the Directory to be tested; if it's
an FS-based directory it should point to the specified
path, else it can ignore it.
|
protected abstract Directory |
BaseDirectoryTestCase.getDirectory(java.nio.file.Path path)
A subclass returns the Directory to be tested; if it's
an FS-based directory it should point to the specified
path, else it can ignore it.
|
Directory |
FileSwitchDirectory.getPrimaryDir()
Return the primary directory
|
Directory |
FileSwitchDirectory.getSecondaryDir()
Return the secondary directory
|
static Directory |
FilterDirectory.unwrap(Directory dir)
Get the wrapped instance by
dir as long as this reader is
an instance of FilterDirectory . |
Modifier and Type | Method and Description |
---|---|
void |
HardlinkCopyDirectoryWrapper.copyFrom(Directory from,
java.lang.String srcFile,
java.lang.String destFile,
IOContext context) |
void |
MockDirectoryWrapper.copyFrom(Directory from,
java.lang.String src,
java.lang.String dest,
IOContext context) |
void |
RawDirectoryWrapper.copyFrom(Directory from,
java.lang.String src,
java.lang.String dest,
IOContext context) |
void |
TrackingDirectoryWrapper.copyFrom(Directory from,
java.lang.String src,
java.lang.String dest,
IOContext context) |
void |
Directory.copyFrom(Directory from,
java.lang.String src,
java.lang.String dest,
IOContext context)
Copies an existing
src file from directory from
to a non-existent file dest in this directory. |
void |
LockValidatingDirectoryWrapper.copyFrom(Directory from,
java.lang.String src,
java.lang.String dest,
IOContext context) |
abstract Lock |
LockFactory.obtainLock(Directory dir,
java.lang.String lockName)
Return a new obtained Lock instance identified by lockName.
|
Lock |
VerifyingLockFactory.obtainLock(Directory dir,
java.lang.String lockName) |
Lock |
NoLockFactory.obtainLock(Directory dir,
java.lang.String lockName) |
Lock |
SingleInstanceLockFactory.obtainLock(Directory dir,
java.lang.String lockName) |
Lock |
FSLockFactory.obtainLock(Directory dir,
java.lang.String lockName) |
static Directory |
FilterDirectory.unwrap(Directory dir)
Get the wrapped instance by
dir as long as this reader is
an instance of FilterDirectory . |
Constructor and Description |
---|
BaseDirectoryWrapper(Directory delegate) |
CorruptingIndexOutput(Directory dir,
long byteToCorrupt,
IndexOutput out) |
FileSwitchDirectory(java.util.Set<java.lang.String> primaryExtensions,
Directory primaryDir,
Directory secondaryDir,
boolean doClose) |
FilterDirectory(Directory in)
Sole constructor, typically called from sub-classes.
|
HardlinkCopyDirectoryWrapper(Directory in)
Creates a new HardlinkCopyDirectoryWrapper delegating to the given directory
|
LockValidatingDirectoryWrapper(Directory in,
Lock writeLock) |
MockDirectoryWrapper(java.util.Random random,
Directory delegate) |
NativeUnixDirectory(java.nio.file.Path path,
Directory delegate)
Create a new NIOFSDirectory for the named location with
FSLockFactory.getDefault() . |
NativeUnixDirectory(java.nio.file.Path path,
int mergeBufferSize,
long minBytesDirect,
LockFactory lockFactory,
Directory delegate)
Create a new NIOFSDirectory for the named location.
|
NativeUnixDirectory(java.nio.file.Path path,
LockFactory lockFactory,
Directory delegate)
Create a new NIOFSDirectory for the named location.
|
NRTCachingDirectory(Directory delegate,
double maxMergeSizeMB,
double maxCachedMB)
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 |
RawDirectoryWrapper(Directory delegate) |
SleepingLockWrapper(Directory delegate,
long lockWaitTimeout)
Create a new SleepingLockFactory
|
SleepingLockWrapper(Directory delegate,
long lockWaitTimeout,
long pollInterval)
Create a new SleepingLockFactory
|
TrackingDirectoryWrapper(Directory in) |
Modifier and Type | Method and Description |
---|---|
Directory |
OfflineSorter.getDirectory()
Returns the
Directory we use to create temp files. |
Modifier and Type | Method and Description |
---|---|
static java.lang.Class<? extends Directory> |
CommandLineUtil.loadDirectoryClass(java.lang.String clazzName)
Loads a specific Directory implementation
|
Modifier and Type | Method and Description |
---|---|
static boolean |
TestUtil.anyFilesExceptWriteLock(Directory dir) |
static CheckIndex.Status |
TestUtil.checkIndex(Directory dir)
This runs the CheckIndex tool on the index in.
|
static CheckIndex.Status |
TestUtil.checkIndex(Directory dir,
boolean crossCheckTermVectors) |
static CheckIndex.Status |
TestUtil.checkIndex(Directory dir,
boolean crossCheckTermVectors,
boolean failFast,
java.io.ByteArrayOutputStream output)
If failFast is true, then throw the first exception when index corruption is hit, instead of moving on to other fields/segments to
look for any other corruption.
|
static void |
IOUtils.deleteFiles(Directory dir,
java.util.Collection<java.lang.String> names)
Deletes all given file names.
|
static void |
IOUtils.deleteFilesIgnoringExceptions(Directory dir,
java.util.Collection<java.lang.String> files)
Deletes all given files, suppressing all thrown IOExceptions.
|
static void |
IOUtils.deleteFilesIgnoringExceptions(Directory dir,
java.lang.String... files) |
static boolean |
TestUtil.disableVirusChecker(Directory in)
Returns true if VirusCheckingFS is in use and was in fact already enabled
|
static void |
TestUtil.enableVirusChecker(Directory in) |
static boolean |
TestUtil.hasVirusChecker(Directory dir) |
static boolean |
TestUtil.hasWindowsFS(Directory dir) |
static BaseDirectoryWrapper |
LuceneTestCase.newDirectory(Directory d)
Returns a new Directory instance, with contents copied from the
provided directory.
|
static BaseDirectoryWrapper |
LuceneTestCase.newDirectory(java.util.Random r,
Directory d)
Returns a new Directory instance, using the specified random
with contents copied from the provided directory.
|
static RAMDirectory |
TestUtil.ramCopyOf(Directory dir)
Returns a copy of directory, entirely in RAM
|
static boolean |
LuceneTestCase.slowFileExists(Directory dir,
java.lang.String fileName)
Returns true if the file exists (can be opened), false
if it cannot be opened, and (unlike Java's
File.exists) throws IOException if there's some
unexpected error.
|
static boolean |
IOUtils.spins(Directory dir)
If the dir is an
FSDirectory or wraps one via possibly
nested FilterDirectory or FileSwitchDirectory ,
this returns IOUtils.spins(Path) for the wrapped directory,
else, true. |
Constructor and Description |
---|
OfflineSorter(Directory dir,
java.lang.String tempFileNamePrefix)
Defaults constructor.
|
OfflineSorter(Directory dir,
java.lang.String tempFileNamePrefix,
java.util.Comparator<BytesRef> comparator)
Defaults constructor with a custom comparator.
|
OfflineSorter(Directory dir,
java.lang.String tempFileNamePrefix,
java.util.Comparator<BytesRef> comparator,
OfflineSorter.BufferSize ramBufferSize,
int maxTempfiles,
int valueLength,
java.util.concurrent.ExecutorService exec,
int maxPartitionsInRAM)
All-details constructor.
|
Constructor and Description |
---|
BKDWriter(int maxDoc,
Directory tempDir,
java.lang.String tempFileNamePrefix,
int numDataDims,
int numIndexDims,
int bytesPerDim,
int maxPointsInLeafNode,
double maxMBSortInHeap,
long totalPointCount,
boolean singleValuePerDoc) |
BKDWriter(int maxDoc,
Directory tempDir,
java.lang.String tempFileNamePrefix,
int numDataDims,
int numIndexDims,
int bytesPerDim,
int maxPointsInLeafNode,
double maxMBSortInHeap,
long totalPointCount,
boolean singleValuePerDoc,
boolean longOrds,
long offlineSorterBufferMB,
int offlineSorterMaxTempFiles) |
OfflinePointReader(Directory tempDir,
java.lang.String tempFileName,
int packedBytesLength,
long start,
long length,
boolean longOrds,
boolean singleValuePerDoc) |
OfflinePointWriter(Directory tempDir,
java.lang.String tempFileNamePrefix,
int packedBytesLength,
boolean longOrds,
java.lang.String desc,
long expectedCount,
boolean singleValuePerDoc)
Create a new writer with an unknown number of incoming points
|
OfflinePointWriter(Directory tempDir,
java.lang.String name,
int packedBytesLength,
long count,
boolean longOrds,
boolean singleValuePerDoc)
Initializes on an already written/closed file, just so consumers can use
OfflinePointWriter.getReader(long, long) to read the file. |
Constructor and Description |
---|
FSTTester(java.util.Random random,
Directory dir,
int inputMode,
java.util.List<FSTTester.InputOutput<T>> pairs,
Outputs<T> outputs,
boolean doReverseLookup) |
Copyright © 2000–2019 The Apache Software Foundation. All rights reserved.