All Classes Interface Summary Class Summary Enum Summary Exception Summary Annotation Types Summary
Class |
Description |
AbstractAccessControlList |
Abstract base implementation of the JackrabbitAccessControlList
interface.
|
AbstractAccessControlManager |
Default implementation of the JackrabbitAccessControlManager interface.
|
AbstractAuthorizableAction |
Abstract implementation of the AuthorizableAction interface that
doesn't perform any action.
|
AbstractAzureDataStoreService |
|
AbstractBlob |
Abstract base class for Blob implementations.
|
AbstractBlobStore |
An abstract data store that splits the binaries in relatively small blocks,
so that each block fits in memory.
|
AbstractBlobStore.BlockId |
A block id.
|
AbstractBlobStore.Data |
The data for a block.
|
AbstractCacheStats |
|
AbstractCheckpointMBean |
Abstract base class for CheckpointMBean implementations.
|
AbstractChildNodeEntry |
|
AbstractConfig |
Abstract configuration class that is based on a bean map.
|
AbstractCredentials |
|
AbstractDataRecord |
|
AbstractDataStoreService |
|
AbstractDecoratedNodeState |
|
AbstractDocumentNodeState |
|
AbstractFileStore |
The storage implementation for tar files.
|
AbstractGroupAction |
Abstract implementation of the GroupAction interface that
doesn't perform any action.
|
AbstractLoginModule |
Abstract implementation of the LoginModule interface that can act
as base class for login modules that aim to authenticate subjects against
information stored in the content repository.
|
AbstractMutableTree |
AbstractMutableTree extends AbstractTree with implementations
for most write methods of Tree .
|
AbstractNodeState |
Abstract base class for NodeState implementations.
|
AbstractPersistentCache |
|
AbstractPropertyState |
|
AbstractRebaseDiff |
AbstractRebaseDiff serves as base for rebase implementations.
|
AbstractRemoteSegmentArchiveReader |
|
AbstractRemoteSegmentArchiveWriter |
|
AbstractRestrictionProvider |
|
AbstractS3DataStoreService |
|
AbstractSegmentTarExplorerBackend |
Abstraction for Segment-Tar based backends.
|
AbstractServiceTracker<T> |
AbstractServiceTracker is a base class for composite components
that dynamically look up the available component services from the
whiteboard.
|
AbstractSharedBackend |
|
AbstractSharedCachingDataStore |
Cache files locally and stage files locally for async uploads.
|
AbstractTree |
AbstractTree provides default implementations for most
read methods of Tree .
|
AcceptHeader |
|
AccessControlAction |
The AccessControlAction allows to setup permissions upon creation
of a new authorizable; namely the privileges the new authorizable should be
granted on it's own 'home directory' being represented by the new node
associated with that new authorizable.
|
AccessControlConstants |
Constants for the default access control management implementation and
and for built-in access control related node types.
|
AccessControlImporter |
|
AccessControlManagerDelegator |
This implementation of AccessControlManager delegates back to a
delegatee wrapping each call into a SessionOperation closure.
|
AccessControlManagerImpl |
Default implementation of the JackrabbitAccessControlManager interface.
|
AccessControlValidatorProvider |
AccessControlValidatorProvider aimed to provide a root validator
that makes sure access control related content modifications (adding, modifying
and removing access control policies) are valid according to the
constraints defined by this access control implementation.
|
AccessManager |
AccessManager
|
ACE |
Default implementation of the JackrabbitAccessControlEntry interface.
|
ACFilter |
EventTypeFilter filters based on the access rights of the observing session.
|
AddSubtreeFilter |
This EventFilter implementation excludes events for child nodes
of added nodes.
|
AdminPrincipal |
Principal used to mark an administrator.
|
AfterEffect |
This class acts as the base class for the implementations of the first
normalization of the informative content in the DFR framework.
|
AfterEffect.NoAfterEffect |
Implementation used when there is no aftereffect.
|
AfterEffectB |
Model of the information gain based on the ratio of two Bernoulli processes.
|
AfterEffectL |
Model of the information gain based on Laplace's law of succession.
|
AggregatedPermissionProvider |
Extension of the PermissionProvider interface that allows it to be
used in combination with other provider implementations.
|
AggregatingDescriptors |
An AggregatingDescriptors is an implementation of Descriptors
that allows to aggregate multiple Descriptors (which are
provided dynamically via a whiteboard tracker).
|
AggregationAware |
Marker interface intended to extend a RestrictionProvider to make it aware of it's aggregated
nature in a composite when it comes to evaluate the validity of restrictions.
|
AggregationFilter |
|
AggregationFilterImpl |
|
AheadOfTimeBlobDownloader |
|
AheadOfTimeBlobDownloaderThrottler |
Tracks a prefetch window for the AOT downloader.
|
AheadOfTimeBlobDownloadingFlatFileStore |
|
AllPermissionProviderImpl |
Implementation of the PermissionProvider interface that grants full
permission everywhere.
|
AlreadyClosedException |
This exception is thrown when there is an attempt to
access something that has already been closed.
|
Analyzer |
An Analyzer builds TokenStreams, which analyze text.
|
Analyzer.GlobalReuseStrategy |
Deprecated.
|
Analyzer.PerFieldReuseStrategy |
Deprecated.
|
Analyzer.ReuseStrategy |
|
Analyzer.TokenStreamComponents |
This class encapsulates the outer components of a token stream.
|
AnalyzerWrapper |
Extension to Analyzer suitable for Analyzers which wrap
other Analyzers.
|
AndImpl |
The implementation of the corresponding JCR interface.
|
AndImpl |
An AND condition.
|
AnnotatedStandardMBean |
The extension of StandardMBean that will automatically provide JMX
metadata through annotations.
|
AnnotatingConflictHandler |
|
AppendingDeltaPackedLongBuffer |
Utility class to buffer a list of signed longs in memory.
|
AppendingPackedLongBuffer |
Utility class to buffer a list of signed longs in memory.
|
ApplyDiff |
A node state diff handler that applies all reported changes
as-is to the given node builder.
|
ArrayBasedBlob |
This Blob implementations is based on an array of bytes.
|
ArrayUtil |
Methods for manipulating arrays.
|
AstElementFactory |
A factory for syntax tree elements.
|
AstVisitor |
A visitor to access all elements.
|
AstVisitorBase |
The base class to visit all elements.
|
AsyncCheckpointCreator |
This class is responsible for creating and deleting checkpoints asynchronously.
|
AsyncCheckpointService |
|
AsyncDocumentProcessor |
Base class for DocumentProcessor implementations that create tasks
executed by an executor service.
|
AsyncIndexerBase |
|
AsyncIndexerLucene |
|
AsyncIndexerService |
|
AsyncIndexInfo |
|
AsyncIndexInfoService |
|
AsyncIndexInfoServiceImpl |
|
AsyncIndexUpdate |
|
AsyncIndexUpdate.AsyncUpdateCallback |
Index update callback that tries to raise the async status flag when
the first index change is detected.
|
AsyncNodeStateProcessor |
|
AtomicCounterEditor |
|
AtomicCounterEditor.ConsolidatorTask |
|
AtomicCounterEditorProvider |
|
AtomicReader |
AtomicReader is an abstract class, providing an interface for accessing an
index.
|
AtomicReaderContext |
|
Attribute |
Base interface for attributes.
|
AttributeImpl |
|
AttributeReflector |
|
AttributeSource |
An AttributeSource contains a list of different AttributeImpl s,
and methods to add and get them.
|
AttributeSource.AttributeFactory |
|
AttributeSource.State |
This class holds the state of an AttributeSource.
|
Authentication |
The Authentication interface defines methods to validate
Credentials during the
login step of the
authentication process.
|
AuthenticationConfiguration |
Interface for the authentication setup.
|
AuthenticationConfigurationImpl |
Default implementation of the AuthenticationConfiguration with the
following characteristics:
LoginContextProvider : Returns the default implementation of
LoginContextProvider that handles standard JAAS based logins and
deals with pre-authenticated subjects.
|
AuthInfo |
AuthInfo instances provide access to information related
to authentication and authorization of a given content session.
|
AuthInfoImpl |
Default implementation of the AuthInfo interface.
|
Authorizable |
The Authorizable is the common base interface for User and
Group .
|
AuthorizableAction |
|
AuthorizableActionProvider |
AuthorizableActionProvider is used to provide AuthorizableAction s
for each instance of UserManager .
|
AuthorizableExistsException |
AuthorizableExistsException
|
AuthorizableNodeName |
The AuthorizableNodeName is in charge of generating a valid node
name from a given authorizable ID.
|
AuthorizableNodeName.Default |
Default implementation of the AuthorizableNodeName interface
that uses the specified authorizable identifier as node name
escaping
any illegal JCR chars.
|
AuthorizableType |
The different authorizable types.
|
AuthorizableTypeException |
The AuthorizableTypeException signals an Authorizable type mismatch.
|
AuthorizationConfiguration |
Configuration for access control management and permission evaluation.
|
AuthorizationConfigurationImpl |
Default implementation of the AccessControlConfiguration .
|
AuthorizationMonitor |
|
AuthorizationMonitorImpl |
|
Automaton |
Finite-state automaton with regular expression operations.
|
AutomatonProvider |
|
AutomatonQuery |
A Query that will match terms against a finite-state machine.
|
AutoMembershipAware |
|
AutoMembershipConfig |
|
AutomembershipService |
|
AutoSaveEnabledManager |
Implementation of the user management that allows to set the autosave flag.
|
AvailableModes |
|
AveragePayloadFunction |
Calculate the final score as the average score of all payloads seen.
|
AwsArchiveManager |
|
AwsCompact |
Perform an offline compaction of an existing AWS Segment Store.
|
AwsCompact.Builder |
Collect options for the Compact command.
|
AwsContext |
|
AwsGCJournalFile |
|
AwsJournalFile |
|
AwsManifestFile |
|
AwsPersistence |
|
AwsRepositoryLock |
|
AwsSegmentArchiveReader |
|
AwsSegmentArchiveWriter |
|
AwsSegmentCopy |
Perform a full-copy of repository data at segment level.
|
AwsSegmentCopy.Builder |
|
AwsSegmentStoreMigrator |
|
AwsSegmentStoreMigrator.Builder |
|
AwsSegmentStoreService |
|
AwsToolUtils |
Utility class for common stuff pertaining to tooling.
|
AwsToolUtils.SegmentStoreType |
|
AzureArchiveManager |
|
AzureBlobContainerProvider |
|
AzureBlobContainerProvider.Builder |
|
AzureBlobMetadata |
Provides access to the blob metadata.
|
AzureBlobStoreBackend |
|
AzureCheck |
|
AzureCheck.Builder |
Collect options for the Check command.
|
AzureCompact |
Perform an offline compaction of an existing Azure Segment Store.
|
AzureCompact.Builder |
Collect options for the Compact command.
|
AzureConfigurationParserUtils |
Utility class for parsing Oak Segment Azure configuration (e.g.
|
AzureConfigurationParserUtils.AzureConnectionKey |
|
AzureConstants |
|
AzureDataStore |
|
AzureDataStoreService |
|
AzureGCJournalFile |
|
AzureJournalFile |
|
AzureManifestFile |
|
AzurePersistence |
|
AzureRepositoryLock |
|
AzureRequestOptions |
|
AzureSegmentArchiveReader |
|
AzureSegmentArchiveWriter |
|
AzureSegmentStoreExplorerBackend |
Backend using a a remote Azure Segment Store.
|
AzureSegmentStoreService |
|
AzureStorageCredentialManager |
|
AzureUtilities |
|
BackgroundObserver |
An observer that uses a change queue and a background thread to forward
content changes to another observer.
|
BackgroundObserverMBean |
|
Backup |
Perform a backup of a segment store into a specified folder.
|
Backup.Builder |
Collect options for the Backup command.
|
Base64BlobSerializer |
|
BaseCompositeReader<R extends IndexReader> |
Base class for implementing CompositeReader s based on an array
of sub-readers.
|
BaseDirectory |
Base implementation for a concrete Directory .
|
BasicAutomata |
Construction of basic automata.
|
BasicModel |
This class acts as the base class for the specific basic model
implementations in the DFR framework.
|
BasicModelBE |
Limiting form of the Bose-Einstein model.
|
BasicModelD |
Implements the approximation of the binomial model with the divergence
for DFR.
|
BasicModelG |
Geometric as limiting form of the Bose-Einstein model.
|
BasicModelIF |
An approximation of the I(ne) model.
|
BasicModelIn |
The basic tf-idf model of randomness.
|
BasicModelIne |
Tf-idf model of randomness, based on a mixture of Poisson and inverse
document frequency.
|
BasicModelP |
Implements the Poisson approximation for the binomial model for DFR.
|
BasicOperations |
Basic automata operations.
|
BasicReadOnlyBlobStore |
Utility BlobStore implementation to be used in tooling that can work with a
FileStore without the need of the DataStore being present locally
|
BasicStats |
Stores all statistics commonly used ranking methods.
|
BinaryBasedBlob |
This Blob implementation is based on an underlying Binary .
|
BinaryConstraint |
|
BinaryDocValues |
A per-document byte[]
|
BinaryDocValuesField |
Field that stores a per-document BytesRef value.
|
BinaryDownload |
This extension interface provides a mechanism whereby a client can download
a Binary directly from a storage location.
|
BinaryDownloadOptions |
|
BinaryDownloadOptions.BinaryDownloadOptionsBuilder |
|
BinaryId |
A binary id.
|
BinaryPropertyState |
|
BinaryReferencesIndex |
An index of binary references.
|
BinaryReferencesIndex.EntryConsumer |
A consumer of entries from a binary references index.
|
BinaryReferencesIndexLoader |
|
BinaryReferencesIndexWriter |
Maintains the transient state of a binary references index, formats it and
serializes it.
|
BinarySize |
Collects the total binary size (references to the datastore) per path.
|
BinarySizeHistogram |
Collects the histogram of binary sizes (embedded binaries and references to
the datastore).
|
BinaryUpload |
Describes uploading a binary through HTTP requests in a single or multiple
parts.
|
BinaryUploadOptions |
|
BinaryUploadOptions.BinaryUploadOptionsBuilder |
Used to build an instance of BinaryUploadOptions with the options
set as desired by the caller.
|
BindVariableValueImpl |
The implementation of the corresponding JCR interface.
|
BindVariableValueImpl |
A bind variable.
|
BiStatsConsumer |
|
Bits |
Interface for Bitset-like structures.
|
Bits.MatchAllBits |
Bits impl of the specified length with all bits set.
|
Bits.MatchNoBits |
Bits impl of the specified length with no bits set.
|
BitsFilteredDocIdSet |
This implementation supplies a filtered DocIdSet, that excludes all
docids which are not in a Bits instance.
|
BitUtil |
A variety of high efficiency bit twiddling routines.
|
Blob |
Immutable representation of a binary value of finite length.
|
BlobAccessProvider |
Extension interface applied to a class that indicates that the class
implements the direct upload and direct download feature for Blob s.
|
BlobCollector |
|
BlobDeserializer |
|
BlobDownloadOptions |
|
BlobFetchTimeoutException |
|
BlobGarbageCollector |
Interface for blob garbage collector
|
BlobGC |
|
BlobGCMBean |
MBean for starting and monitoring the progress of
blob garbage collection.
|
BlobIdSerializer |
Blob serializer which serializes blobs depending on type
In memory blobs (having contentIdentity as null) would be serialized as base64
encoded string.
|
BlobIdTracker |
Tracks the blob ids available or added in the blob store using the BlobIdTracker.BlobIdStore .
|
BlobIdTracker.ActiveDeletionTracker |
Tracking any active deletions store for managing the blob reference
|
BlobMigration |
|
BlobMigrationMBean |
|
BlobMigrator |
|
BlobOptions |
Options while writing blobs to the blob store / data store.
|
BlobOptions.UploadType |
Specifies the upload type for the blob.
|
BlobReferenceIterator |
An iterator over all referenced binaries.
|
BlobReferenceRetriever |
Interface to abstract out the low-level details of retrieving blob references from different
NodeStore
|
BlobSerializer |
Customizable mechanism for mapping Blob instances to corresponding
serialization identifiers.
|
BlobStatsCollector |
BlobStoreStatsCollector receives callback when blobs are written and read
from BlobStore
|
BlobStore |
An interface to store and read large binary objects.
|
BlobStoreBlob |
A blob implementation.
|
BlobStoreFixture |
|
BlobStoreFixture |
|
BlobStoreFixtureProvider |
|
BlobStoreInputStream |
An input stream to simplify reading from a store.
|
BlobStoreOptions |
|
BlobStoreOptions.Type |
|
BlobStoreStats |
|
BlobStoreStatsMBean |
|
BlobStoreWrapper |
|
BlobTracker |
Track the blob ids.
|
BlobTracker.Options |
|
BlobTrackingStore |
Interface to be implemented by a data store which can support local blob id tracking.
|
BlobTypeUnknownException |
|
BlobUpload |
An object containing information needed to complete a direct binary upload.
|
BlobUploadOptions |
|
BlockPackedReader |
|
BlockPackedReaderIterator |
|
BlockPackedWriter |
A writer for large sequences of longs.
|
BlockTermState |
|
BlockTreeTermsReader |
A block-based terms index and dictionary that assigns
terms to variable length blocks according to how they
share prefixes.
|
BlockTreeTermsReader.Stats |
|
BlockTreeTermsWriter |
Block-based terms index and dictionary writer.
|
BloomFilter |
A Bloom filter implementation.
|
BM25Similarity |
BM25 Similarity.
|
BnfRailroad |
A BNF visitor that generates HTML railroad diagrams.
|
BnfSyntax |
A BNF visitor that generates BNF in HTML form.
|
BooleanClause |
A clause in a BooleanQuery.
|
BooleanClause.Occur |
Specifies how clauses are to occur in matching documents.
|
BooleanConstraint |
|
BooleanPropertyState |
|
BooleanQuery |
A Query that matches documents matching boolean combinations of other
queries, e.g.
|
BooleanQuery.TooManyClauses |
|
BoostAttribute |
|
BoostAttributeImpl |
|
BootstrapConfig |
The bootstrap configuration hold information about initial startup
parameters like repository config and home.
|
BoundedHistogram |
A histogram that keeps a maximum number of buckets (entries).
|
BranchNodeStore |
|
BreadthFirstTrace |
A breadth first traversal trace.
|
Broadcaster |
A broadcast mechanism that is able to send and receive commands.
|
Broadcaster.Listener |
A listener for new messages.
|
BroadWord |
Methods and constants inspired by the article
"Broadword Implementation of Rank/Select Queries" by Sebastiano Vigna, January 30, 2012:
algorithm 1: BroadWord.bitCount(long) , count of set bits in a long
algorithm 2: BroadWord.select(long, int) , selection of a set bit in a long ,
bytewise signed smaller < 8 operator: BroadWord.smallerUpTo7_8(long,long) .
|
Buffer |
|
BufferedIndexInput |
Base implementation class for buffered IndexInput .
|
BufferedIndexOutput |
|
Builder<T> |
Builds a minimal FST (maps an IntsRef term to an arbitrary
output) from pre-sorted terms with outputs.
|
Builder.Arc<T> |
Expert: holds a pending (seen but not yet serialized) arc.
|
Builder.FreezeTail<T> |
Expert: this is invoked by Builder whenever a suffix
is serialized.
|
Builder.UnCompiledNode<T> |
Expert: holds a pending (seen but not yet serialized) Node.
|
BundledDocumentDiffer |
|
BundledTypesRegistry |
|
BundledTypesRegistry.BundledTypesRegistryBuilder |
|
BundledTypesRegistry.BundledTypesRegistryBuilder.TypeBuilder |
|
BundlingConfigHandler |
|
BundlingConfigInitializer |
|
BundlingHandler |
|
BundlorUtils |
|
BurnOnCloseFileIterator<T> |
Implements a Closeable wrapper over a LineIterator .
|
ByteArrayDataInput |
DataInput backed by a byte array.
|
ByteArrayDataOutput |
DataOutput backed by a byte array.
|
ByteBlockPool |
Class that Posting and PostingVector use to write byte
streams into shared fixed-size byte[] arrays.
|
ByteBlockPool.Allocator |
Abstract class for allocating and freeing byte
blocks.
|
ByteBlockPool.DirectAllocator |
|
ByteBlockPool.DirectTrackingAllocator |
|
ByteDocValuesField |
Deprecated.
|
ByteRunAutomaton |
Automaton representation for matching UTF-8 byte[].
|
ByteSequenceOutputs |
An FST Outputs implementation where each output
is a sequence of bytes.
|
BytesRef |
Represents byte[], as a slice (offset + length) into an
existing byte[].
|
BytesRefFSTEnum<T> |
Enumerates all input (BytesRef) + output pairs in an
FST.
|
BytesRefFSTEnum.InputOutput<T> |
Holds a single input (BytesRef) + output pair.
|
BytesRefHash |
|
BytesRefHash.BytesStartArray |
Manages allocation of the per-term addresses.
|
BytesRefHash.DirectBytesStartArray |
|
BytesRefHash.MaxBytesLengthExceededException |
|
BytesRefIterator |
A simple iterator interface for BytesRef iteration.
|
Cache<K,V extends Cache.Value> |
|
Cache<K,V> |
Partial mapping of keys of type K to values of type Cache .
|
Cache.Backend<K,V> |
A cache backend that can load objects from persistent storage.
|
Cache.Value |
A cacheable object.
|
CacheAccessTracker<K,V> |
Cache wrapper exposing the number of read accesses and the
number of misses ot the underlying cache via the StatisticsProvider .
|
CacheActionDispatcher |
An asynchronous buffer of the CacheAction objects.
|
CacheChangesTracker |
|
CacheChangesTracker.LazyBloomFilter |
|
CacheInvalidationStats |
|
CacheLIRS<K,V> |
For Oak internal use only.
|
CacheLIRS.Builder<K,V> |
A builder for the cache.
|
CacheLIRS.EvictionCallback<K,V> |
Listener for items that are evicted from the cache.
|
CacheMap<K,V> |
A cache map.
|
CacheMetadata<K> |
In order to avoid leaking values from the metadataMap, following order should
be maintained for combining the cache and CacheMetadata:
1.
|
CacheStats |
Cache statistics.
|
CacheStatsMBean |
|
CacheStatsMBeanWrapper |
|
CacheStatsMetrics |
An OSGi component that binds to all CacheStatsMBean instances and
exposes their counters as Metric s.
|
CacheType |
|
CacheValue |
A cache value.
|
CacheWarming |
|
CacheWeights |
|
CacheWeights.NodeCacheWeigher |
|
CacheWeights.OneWeigher<K,V> |
|
CacheWeights.ReaderStringCacheWeigher |
|
CacheWeights.ReaderTemplateCacheWeigher |
|
CacheWeights.SegmentCacheWeigher |
|
CacheWeights.StringCacheWeigher |
|
CacheWeights.TemplateCacheWeigher |
|
CacheWriteQueue<K extends CacheValue,V extends CacheValue> |
|
CachingArchiveManager |
|
CachingBlobStore |
A blob store with a cache.
|
CachingCollector |
Caches all docs, and optionally also scores, coming from
a search, and is then able to replay them to another
collector.
|
CachingFileDataStore |
|
CachingPersistence |
|
CachingSegmentArchiveReader |
|
CachingSegmentReader |
This SegmentReader implementation implements caching for
strings and templates.
|
CachingTokenFilter |
This class can be used if the token attributes of a TokenStream
are intended to be consumed more than once.
|
CachingWrapperFilter |
Wraps another Filter 's result and caches it.
|
CancelableDiff |
A NodeStateDiff that cancels itself when a condition occurs.
|
Cancellation |
The result of a check for a pending cancellation request.
|
Canceller |
Represents a way to check for a cancellation request.
|
CaseInsensitiveKeysMapAccess |
Wrapper around the map that allows accessing the map with case-insensitive keys.
|
ChangeCollectorProvider |
A ChangeCollectorProvider can be hooked into Oak thus enabling the collection
of ChangeSets of changed items of a commit, which downstream Observers can
then use at their convenience.
|
ChangeDispatcher |
A ChangeDispatcher instance dispatches content changes
to registered Observer s.
|
ChangeProcessorMBean |
|
ChangeSet |
A ChangeSet is a collection of items that have been changed as part of a
commit.
|
ChangeSetBuilder |
Builder of a ChangeSet - only used by ChangeCollectorProvider (and tests..)
|
ChangeSetFilter |
A ChangeSetFilter is capable of inspecting a ChangeSet
and deciding if the corresponding consumer
(eg EventListener) is possibly interested in it
or definitely not.
|
ChangeSetFilterImpl |
|
CharacterRunAutomaton |
Automaton representation for matching char[].
|
CharFilter |
Subclasses of CharFilter can be chained to filter a Reader
They can be used as Reader with additional offset
correction.
|
CharSequenceOutputs |
An FST Outputs implementation where each output
is a sequence of characters.
|
CharsetEncodingUtils |
Utility class related to encoding characters into (UTF-8) byte sequences.
|
CharsRef |
Represents char[], as a slice (offset + length) into an existing char[].
|
CharTermAttribute |
The term text of a Token.
|
CharTermAttributeImpl |
|
Check |
Perform a consistency check on an existing segment store.
|
Check.Builder |
Collect options for the Check command.
|
Check.RepositoryStatistics |
|
CheckHelper |
|
CheckHelper.Builder |
Collect options for the Check command.
|
CheckIndex |
Basic tool and API to check the health of an index and
write a new segments file that removes reference to
problematic segments.
|
CheckIndex.Status |
|
CheckIndex.Status.DocValuesStatus |
Status from testing DocValues
|
CheckIndex.Status.FieldNormStatus |
Status from testing field norms.
|
CheckIndex.Status.SegmentInfoStatus |
Holds the status of each segment in the index.
|
CheckIndex.Status.StoredFieldStatus |
Status from testing stored fields.
|
CheckIndex.Status.TermIndexStatus |
Status from testing term index.
|
CheckIndex.Status.TermVectorStatus |
Status from testing stored fields.
|
CheckpointCompactor |
This compactor implementation is aware of the checkpoints in the repository.
|
CheckpointMBean |
MBean for managing org.apache.jackrabbit.oak.spi.state.NodeStore#checkpoint checkpoints .
|
Checkpoints |
A helper class to manage checkpoints on TarMK and DocumentMK.
|
Checkpoints.CP |
|
CheckpointsHelper |
Helper class to access package private functionality.
|
ChecksumIndexInput |
Reads bytes through to a primary IndexInput, computing
checksum as it goes.
|
ChecksumIndexOutput |
Writes bytes through to a primary IndexOutput, computing
checksum.
|
ChildNodeEntry |
A ChildNodeEntry instance represents the child node states of a
NodeState .
|
ChildNodeImpl |
The implementation of the corresponding JCR interface.
|
ChildNodeImpl |
The "ischildnode(...)" condition.
|
ChildNodeJoinConditionImpl |
The implementation of the corresponding JCR interface.
|
ChildNodeJoinConditionImpl |
The "ischildnode(...)" join condition.
|
ChildOrderConflictHandler |
This conflict handler instance takes care of properly merging conflicts
occurring by concurrent reorder operations.
|
ChunkedBlobStream |
|
ClassicCompactor |
Instances of this class can be used to compact a node state.
|
CleanupContext |
Initial data and logic needed for the cleanup of unused TAR entries.
|
ClearMembershipAction |
Authorizable action attempting to clear all group membership before removing
the specified authorizable.
|
ClientStandbyStatusMBean |
|
Clock |
Mechanism for keeping track of time at millisecond accuracy.
|
Clock.Fast |
Fast clock implementation whose Clock.Fast.getTime() method returns
instantaneously thanks to a background task that takes care of the
actual time-keeping work.
|
Clock.Virtual |
A virtual clock that has no connection to the actual system time.
|
CloseableIterable<T> |
|
CloseableIterator<T> |
|
CloseableThreadLocal<T> |
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.
|
CloudBlobStore |
Implementation of the BlobStore to store blobs in a cloud blob store.
|
Clusterable |
Interface for bearing cluster node specific information.
|
ClusterNodeInfo |
Information about a cluster node.
|
ClusterNodeInfo.ClusterNodeState |
|
ClusterNodeInfo.RecoverLockState |
|
ClusterNodeInfoDocument |
A document storing cluster node info.
|
ClusterRepositoryInfo |
Utility class to manage a unique cluster/repository id for the cluster.
|
ClusterStateChangeListener |
DocumentNS-internal listener that gets invoked when a change in the
clusterNodes collection (active/inactive/timed out/recovering) is detected.
|
CoalesceImpl |
The function "coalesce(..)".
|
Codec |
Encodes/decodes an inverted index segment.
|
CodecUtil |
Utility class for reading and writing versioned headers.
|
Collection<T extends Document> |
The collection types.
|
CollectionStatistics |
Contains statistics for a collection (field)
|
CollectionTerminatedException |
|
CollectionUtil |
Methods for manipulating (sorting) collections.
|
CollectionUtils |
Utility methods for collections conversions.
|
Collector |
Expert: Collectors are primarily meant to be used to
gather raw results from a search, and implement sorting
or custom result filtering, collation, etc.
|
ColumnImpl |
The implementation of the corresponding JCR interface.
|
ColumnImpl |
A result column expression.
|
Command |
|
CommandLineUtil |
Class containing some useful methods used by command line tools
|
Commit |
A higher level object representing a commit.
|
Commit |
A Commit instance represents a set of related changes, which when
applied to a base node state result in a new node state.
|
CommitContext |
A CommitContext instance can be obtained from CommitInfo.getInfo()
if it has been set before the merge call.
|
CommitFailedException |
Main exception thrown by methods defined on the ContentSession
interface indicating that committing a given set of changes failed.
|
CommitHook |
Extension point for validating and modifying content changes.
|
CommitInfo |
Commit info instances associate some meta data with a commit.
|
CommitRateLimiter |
This CommitHook can be used to block or delay commits for any length of time.
|
CommitValueResolver |
Resolves the commit value for a given change revision on a document.
|
CommonOptions |
|
CommunicationObserver |
|
Compact |
Perform an offline compaction of an existing segment store.
|
Compact.Builder |
Collect options for the Compact command.
|
CompactedNodeState |
Simple wrapper class for SegmentNodeState to keep track of fully and partially compacted nodes.
|
CompactionWriter |
The CompactionWriter delegates compaction calls to the correct SegmentWriter based on GCGeneration.
|
Compactor |
|
ComparisonImpl |
The implementation of the corresponding JCR interface.
|
ComparisonImpl |
A comparison operation (including "like").
|
CompiledAutomaton |
Immutable class holding compiled details for a given
Automaton.
|
CompiledAutomaton.AUTOMATON_TYPE |
Automata are compiled into different internal forms for the
most efficient execution depending upon the language they accept.
|
ComplexExplanation |
Expert: Describes the score computation for document and query, and
can distinguish a match independent of a positive value.
|
CompositeActionProvider |
|
CompositeAuthorizationConfiguration |
|
CompositeAuthorizationConfiguration.CompositionType |
|
CompositeCheckpointMBean |
|
CompositeConfiguration<T extends SecurityConfiguration> |
|
CompositeConflictHandler |
A CompositeConflictHandler delegates conflict handling
to multiple backing handlers.
|
CompositeCredentialsSupport |
Composite implementation of the
CredentialsSupport
interface that handles multiple providers.
|
CompositeDataStoreCache |
|
CompositeDocumentProcessor |
CompositeDocumentProcessor ...
|
CompositeEditor |
Aggregation of a list of editors into a single editor.
|
CompositeEditorProvider |
Aggregation of a list of editor providers into a single provider.
|
CompositeException |
|
CompositeHook |
Composite commit hook.
|
CompositeIndexEditorProvider |
Aggregation of a list of editor providers into a single provider.
|
CompositeIndexer |
Many methods in this class call themselves recursively, and are susceptible to infinite recursion if a composite
indexer contains itself, directly or indirectly.
|
CompositeInitializer |
|
CompositeIOMonitor |
This IOMonitor instance delegates all calls to all
IOMonitor instances registered.
|
CompositeNodeStore |
|
CompositeNodeStore.Builder |
|
CompositeNodeStoreMonitor |
|
CompositeNodeStoreService |
|
CompositeNodeStoreStats |
|
CompositeNodeStoreStatsMBean |
|
CompositeObserver |
Composite observer that delegates all content changes to the set of
currently registered component observers.
|
CompositePattern |
|
CompositePrepareCommand |
|
CompositePrepareCommand.OakResourceTransformer |
|
CompositePrincipalConfiguration |
PrincipalConfiguration that combines different principal provider
implementations that share a common principal manager implementation.
|
CompositePrincipalProvider |
PrincipalProvider implementation that aggregates a list of principal
providers into a single.
|
CompositeQueryIndexProvider |
This QueryIndexProvider aggregates a list of query index providers
into a single query index provider.
|
CompositeReader |
Instances of this reader type can only
be used to get stored fields from the underlying AtomicReaders,
but it is not possible to directly retrieve postings.
|
CompositeReaderContext |
|
CompositeRegistration |
|
CompositeRestrictionProvider |
|
CompositeTokenConfiguration |
|
CompositeTokenProvider |
Aggregates a collection of TokenProvider s into a single
provider.
|
CompositeWorkspaceInitializer |
|
CompoundFileDirectory |
Class for accessing a compound stream.
|
CompoundFileDirectory.FileEntry |
Offset/Length for a slice inside of a compound file
|
CompressedDocumentPropertyState |
PropertyState compression implementation with lazy parsing of the JSOP encoded value.
|
CompressingStoredFieldsFormat |
|
CompressingStoredFieldsIndexReader |
|
CompressingStoredFieldsIndexWriter |
Efficient index format for block-based Codec s.
|
CompressingStoredFieldsReader |
|
CompressingStoredFieldsWriter |
|
CompressingTermVectorsFormat |
A TermVectorsFormat that compresses chunks of documents together in
order to improve the compression ratio.
|
CompressingTermVectorsReader |
|
CompressingTermVectorsWriter |
|
Compression |
This interface provides a default list of support compression algorithms and some utility functions.
|
Compression |
The enum allows to disable or enable compression of the storage files.
|
CompressionMode |
A compression mode.
|
CompressionTools |
Simple utility class providing static methods to
compress and decompress binary data for stored fields.
|
Compressor |
A data compressor.
|
ConcurrentLRUCache<K,V extends MemoryObject> |
A synchronized LRU cache.
|
ConcurrentMergeScheduler |
|
ConfigHelper |
|
ConfigurableDataRecordAccessProvider |
|
Configuration |
|
Configuration |
|
ConfigurationBase |
Abstract base implementation for the various security configurations.
|
ConfigurationParameters |
ConfigurationParameters is a convenience class that allows typed access to configuration properties.
|
ConfigurationParameters.Milliseconds |
Helper class for configuration parameters that denote a "duration", such
as a timeout or expiration time.
|
ConfigurationUtil |
Utility to create Configuration s for built-in LoginModule implementations.
|
ConflictAnnotatingRebaseDiff |
This implementation of AbstractRebaseDiff implements a NodeStateDiff ,
which performs the conflict handling as defined in NodeStore.rebase(NodeBuilder)
on the Oak SPI state level by annotating conflicting items with conflict
markers.
|
ConflictHandler |
Deprecated.
|
ConflictHandlers |
|
ConflictHook |
This commit hook implementation is responsible for resolving
conflicts.
|
ConflictType |
Enum to define various types of conflicts.
|
ConflictValidator |
Validator which checks the presence of conflict markers
in the tree in fails the commit if any are found.
|
ConflictValidatorProvider |
TODO document
|
Consistency |
Consistency check on a NodeDocument .
|
Consistency.Result |
Callback interface for result of a consistency check.
|
ConsistencyCheck |
ConsistencyCheck ...
|
ConsistencyChecker |
|
ConsistencyChecker.ConsistencyCheckResult |
|
ConsistencyChecker.Revision |
|
Console |
A command line console.
|
ConsoleIndexingReporter |
|
ConsoleSession |
Light weight session to a NodeStore, holding context information.
|
ConsolidatedCacheStats |
|
ConsolidatedCacheStatsMBean |
|
ConsolidatedDataStoreCacheStats |
Stats for caching data store.
|
ConsolidatedDataStoreCacheStatsMBean |
|
ConsolidatedListenerMBean |
|
ConsolidatedListenerMBeanImpl |
|
ConstantFilter |
TODO document
|
Constants |
Some useful constants.
|
ConstantScoreQuery |
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.
|
ConstraintImpl |
The implementation of the corresponding JCR interface.
|
ConstraintImpl |
The base class for constraints.
|
Constraints |
|
ContentRepository |
Oak content repository.
|
ContentRepositoryImpl |
|
ContentSession |
Authentication session for accessing a content repository.
|
Context |
|
Context.Default |
Default implementation of the Context interface that always returns
false .
|
ContextAwareCallback |
Extension to IndexUpdateCallback which also provides access to
IndexingContext
|
ControlledRealTimeReopenThread<T> |
Utility class that runs a thread to manage periodicc
reopens of a ReferenceManager , with methods to wait for a specific
index changes to become visible.
|
Conversions |
Utility class defining the conversion that take place between PropertyState s
of different types.
|
Conversions.Converter |
A converter converts a value to its representation as a specific target type.
|
CopyOnWriteStoreMBean |
MBean for managing the copy-on-write node store
|
CorruptIndexException |
This exception is thrown when Lucene detects
an inconsistency in the index.
|
CorruptIndexHandler |
|
Counter |
Simple counter class
|
CounterStats |
|
Counting |
|
CountingDiff |
A NodeStateDiff implementation that counts the differences between
two node states, including their sub tree.
|
CountMinSketch |
A count-min sketch implementation.
|
COWNodeStore |
The copy-on-write (COW) node store implementation allows to temporarily
switch the repository into the "testing" mode, in which all the changes are
stored in a volatile storage, namely the MemoryNodeStore.
|
COWNodeStoreService |
|
CreateMetricUpdater |
|
CredentialsCallback |
Callback implementation to retrieve Credentials .
|
CredentialsSupport |
Simple helper interface that allows to easily plug support for additional or
custom Credentials implementations during authentication.
|
CrossMountReferenceValidator |
|
CrossMountReferenceValidatorProvider |
Validator which detects references crossing the mount boundaries
|
CSVFileGenerator |
|
CugConfiguration |
|
CugExclude |
Interface that allows to exclude certain principals from the CUG evaluation.
|
CugExclude.Default |
|
CugExcludeImpl |
Extension of the default CugExclude
implementation that allow to specify additional principal names to be excluded
from CUG evaluation.
|
CugPolicy |
Denies read access for all principals except for the specified principals.
|
Cursor |
A cursor to read a number of nodes sequentially.
|
CustomExternalIdentityProvider |
|
CustomLoginModule |
A custom login module for test purposes.
|
CustomLoginModuleFactory |
Implements a LoginModuleFactory that creates CustomLoginModule s
and allows to configure login modules via OSGi config.
|
CustomPrincipalConfiguration |
Custom principal configuration that is disabled by default.
|
CustomRestrictionProvider |
EXERCISE: complete the implementation
|
DataInput |
Abstract base class for performing read operations of Lucene's low-level
data types.
|
DataOutput |
Abstract base class for performing write operations of Lucene's low-level
data types.
|
DataRecordAccessProvider |
|
DataRecordDownloadOptions |
Contains download options for downloading a data record directly from a
storage location using the direct download feature.
|
DataRecordUpload |
|
DataRecordUploadException |
|
DataRecordUploadOptions |
|
DataRecordUploadToken |
|
DataStoreBlobStore |
BlobStore wrapper for DataStore.
|
DataStoreBlobStore.BlobId |
|
DataStoreCacheStatsMBean |
|
DataStoreCacheUpgradeCommand |
Command to upgrade JR2 DataStore cache.
|
DataStoreCacheUpgradeUtils |
|
DataStoreCacheUtils |
Common utility methods used for DataStore caches.
|
DataStoreCheckCommand |
Command to check data store consistency and also optionally retrieve ids
and references.
|
DataStoreCommand |
Command to check data store consistency and also optionally retrieve ids
and references.
|
DataStoreCopyCommand |
Command to concurrently download blobs from an azure datastore using sas token authentication.
|
DataStoreGarbageCollector |
Garbage collector for DataStore.
|
DataStoreOptions |
|
DataStoreUtils |
Extension to DataStoreUtils to enable S3 / AzureBlob extensions for cleaning and initialization.
|
DateConstraint |
|
DateTools |
Provides support for converting dates to strings and vice-versa.
|
DateTools.Resolution |
Specifies the time granularity.
|
DbDataStoreService |
|
DebugSegments |
Print debugging information about segments, node records and node record
ranges.
|
DebugSegments.Builder |
|
DebugStore |
Print debugging information about a segment store.
|
DebugStore.Builder |
|
DebugTars |
Print information about one or more TAR files from an existing segment store.
|
DebugTars.Builder |
|
DebugTimer |
DebugTimer ...
|
DecimalConstraint |
|
DecimalPropertyState |
|
DeclaredMembershipPredicate |
Predicate used to filter authorizables based on their declared group membership.
|
Decompressor |
A decompressor.
|
DefaultAheadOfTimeBlobDownloader |
Scans a FlatFileStore for non-inlined blobs in nodes matching a given pattern and downloads them from the blob store.
|
DefaultAuthorizableActionProvider |
|
DefaultConflictHandler |
Deprecated.
|
DefaultEditor |
Editor that does nothing by default and doesn't recurse into subtrees.
|
DefaultEventHandler |
Default implementation of EventHandler that
does nothing.
|
DefaultIOTraceWriter |
This IOTraceWriter implementation implements persistence
through a Writer instance.
|
DefaultMoveValidator |
MoveValidator that does nothing by default and doesn't recurse into subtrees.
|
DefaultNodeStateDiff |
Node state diff handler that by default does nothing.
|
DefaultSegmentWriter |
Converts nodes, properties, values, etc.
|
DefaultSegmentWriterBuilder |
|
DefaultSimilarity |
Expert: Default scoring implementation which encodes norm values as a single byte before being stored.
|
DefaultSplitBlobStore |
|
DefaultStatisticsProvider |
|
DefaultSyncConfig |
DefaultSyncConfig defines how users and groups from an external source are synced into the repository using
the DefaultSyncHandler .
|
DefaultSyncConfig.Authorizable |
Base config class for users and groups
|
DefaultSyncConfig.Group |
Group specific config
|
DefaultSyncConfig.User |
User specific config.
|
DefaultSyncConfigImpl |
DefaultSyncConfig defines how users and groups from an external source are synced into the repository using
the DefaultSyncHandler .
|
DefaultSyncContext |
Internal implementation of the sync context
|
DefaultSyncedIdentity |
Implements a simple synced identity that maps an authorizable id to an external ref.
|
DefaultSyncHandler |
DefaultSyncHandler implements an sync handler that synchronizes users and groups from an external identity
provider with the repository users.
|
DefaultSyncResultImpl |
Implements a simple sync result with and id and a status.
|
DefaultThreeWayConflictHandler |
|
DefaultValidator |
Validator that does nothing by default and doesn't recurse into subtrees.
|
DefaultWhiteboard |
|
DefinitionProvider |
DefinitionProvider...
|
DelegatingDocumentNodeState |
NodeState wrapper which wraps another NodeState (mostly SegmentNodeState)
so as to expose it as an AbstractDocumentNodeState by extracting
the meta properties which are stored as hidden properties
|
DelegatingGCMonitor |
This GCMonitor implementation simply delegates all its call
to registered monitors.
|
DeleteSubtreeFilter |
This EventFilter implementation excludes events for child nodes
of removed nodes.
|
DepthFirstNodeIterator |
|
DepthFirstTrace |
A depth first traversal trace.
|
DerefBytesDocValuesField |
Deprecated.
|
DescendantNodeImpl |
The implementation of the corresponding JCR interface.
|
DescendantNodeImpl |
The "isdescendantnode(...)" condition.
|
DescendantNodeJoinConditionImpl |
The implementation of the corresponding JCR interface.
|
DescendantNodeJoinConditionImpl |
The "isdescendantnode(...)" join condition.
|
DescendantsIterator |
|
Description |
Produces a description that will be used by JMX metadata.
|
Descriptors |
Repository descriptors interface that is used to support providing the repository descriptors of
Repository
|
DFRSimilarity |
Implements the divergence from randomness (DFR) framework
introduced in Gianni Amati and Cornelis Joost Van Rijsbergen.
|
Diff |
Shows the differences between two head states.
|
Diff.Builder |
Collect options for the Diff command.
|
DiffObserver |
Abstract base class for observers that use a content diff to determine
what changed between two consecutive observed states of the repository.
|
Directory |
A Directory is a flat list of files.
|
DirectoryReader |
|
DisjunctionMaxQuery |
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.
|
DiskCacheIOMonitor |
|
DistinctBinarySize |
Collects the number and size of distinct binaries.
|
DistinctBinarySizeHistogram |
A histogram of distinct binaries.
|
Distribution |
The probabilistic distribution used to model term occurrence
in information-based models.
|
DistributionLL |
Log-logistic distribution.
|
DistributionSPL |
The smoothed power-law (SPL) distribution for the information-based framework
that is described in the original paper.
|
DocIdBitSet |
Simple DocIdSet and DocIdSetIterator backed by a BitSet
|
DocIdSet |
A DocIdSet contains a set of doc ids.
|
DocIdSetIterator |
This abstract class defines methods to iterate over a set of non-decreasing
doc ids.
|
DocsAndPositionsEnum |
Also iterates through positions.
|
DocsEnum |
Iterates through the documents and term freqs.
|
DocTermOrds |
This class enables fast access to multiple term ords for
a specified field across all docIDs.
|
DocTermOrdsRangeFilter |
A range filter built on top of a cached multi-valued term field (in FieldCache ).
|
DocTermOrdsRewriteMethod |
Rewrites MultiTermQueries into a filter, using DocTermOrds for term enumeration.
|
Document |
A document corresponds to a node stored in the DocumentNodeStore.
|
Document |
Documents are the unit of indexing and search.
|
DocumentBlobReferenceRetriever |
|
DocumentBroadcastConfig |
|
DocumentBuilderCustomizer |
Extension point which needs to be registered with the Whiteboard
attached to Options
|
DocumentBundlor |
|
DocumentCheckpointMBean |
CheckpointMBean implementation for the DocumentNodeStore .
|
DocumentDiscoveryLiteService |
The DocumentDiscoveryLiteService is taking care of providing a repository
descriptor that contains the current cluster-view details.
|
DocumentNodeState |
|
DocumentNodeState.BundlingContext |
|
DocumentNodeState.Children |
A list of children for a node.
|
DocumentNodeStateCache |
|
DocumentNodeStore |
|
DocumentNodeStoreBuilder<T extends DocumentNodeStoreBuilder<T>> |
|
DocumentNodeStoreHelper |
Helper class to access package private method of DocumentNodeStore and other
classes in this package.
|
DocumentNodeStoreMBean |
|
DocumentNodeStoreOptions |
|
DocumentNodeStoreService |
The OSGi service to start/stop a DocumentNodeStore instance.
|
DocumentNodeStoreService.Preset |
|
DocumentNodeStoreStats |
|
DocumentNodeStoreStatsCollector |
|
DocumentProcessor |
|
DocumentPropertyStateFactory |
|
DocumentStore |
The interface for the backend storage for documents.
|
DocumentStoreCheck |
DocumentStoreCheck ...
|
DocumentStoreCheck.Builder |
|
DocumentStoredFieldVisitor |
|
DocumentStoreException |
DocumentStoreException is a runtime exception for
DocumentStore implementations to signal unexpected problems like
a communication exception.
|
DocumentStoreException.Type |
|
DocumentStoreIndexer |
|
DocumentStoreIndexerBase |
|
DocumentStoreStats |
Document Store statistics helper class.
|
DocumentStoreStatsCollector |
|
DocumentStoreStatsMBean |
|
DocumentStoreStatsPrinter |
|
DocValuesConsumer |
Abstract API that consumes numeric, binary and
sorted docvalues.
|
DocValuesFormat |
Encodes/decodes per-document values.
|
DocValuesProducer |
Abstract API that produces numeric, binary and
sorted docvalues.
|
DocValuesProducer.SortedDocsWithField |
|
DocValuesProducer.SortedSetDocsWithField |
|
DoubleBarrelLRUCache<K extends DoubleBarrelLRUCache.CloneableKey,V> |
Simple concurrent LRU cache, using a "double barrel"
approach where two ConcurrentHashMaps record entries.
|
DoubleBarrelLRUCache.CloneableKey |
Object providing clone(); the key class must subclass this.
|
DoubleConstraint |
|
DoubleDocValuesField |
|
DoubleField |
Field that indexes double values
for efficient range filtering and sorting.
|
DoublePropertyState |
|
Downloader |
Generic concurrent file downloader which uses Java NIO channels to potentially leverage OS internal optimizations.
|
Downloader.DownloadReport |
|
Downloader.Item |
|
DownloadRange |
|
DownloadStageStatistics |
Aggregates statistics when downloading from Mongo with two threads
|
DummyDataStore |
DataStore implementation which creates empty files matching given identifier.
|
DynamicBroadcastConfig |
Broadcast configuration.
|
DynamicMembershipProvider |
|
DynamicMembershipService |
|
DynamicMembershipTracker |
|
DynamicOperandImpl |
The base class for dynamic operands.
|
DynamicOperandImpl |
The base class for dynamic operands (such as a function or property).
|
DynamicSyncContext |
Extension of the DefaultSyncContext that doesn't synchronize group
membership of new external users into the user management of the repository.
|
DynamoDBClient |
|
DynamoDBProvisioningData |
|
Editor |
|
Editor |
Content change editor.
|
EditorDiff |
|
EditorHook |
This commit hook implementation processes changes to be committed
using the Editor instance provided by the EditorProvider
passed to the constructor.
|
EditorProvider |
Extension point for content change editors.
|
EffectiveNodeType |
|
EffectiveNodeTypeProvider |
EffectiveNodeTypeProvider...
|
EliasFanoDecoder |
|
EliasFanoDocIdSet |
A DocIdSet in Elias-Fano encoding.
|
EliasFanoEncoder |
Encode a non decreasing sequence of non negative whole numbers in the Elias-Fano encoding
that was introduced in the 1970's by Peter Elias and Robert Fano.
|
EmpiricalWeigher |
Determines the weight of object based on the memory taken by them.
|
EmptyHook |
Basic commit hook implementation that by default doesn't do anything.
|
EmptyNodeState |
Singleton instances of empty and non-existent node states, i.e.
|
EmptyObserver |
Basic content change observer that doesn't do anything.
|
EmptyPermissionProvider |
Permission provider implementation that does not grant any permissions.
|
EmptyPrincipalProvider |
Implementation of the PrincipalProvider interface that never
returns any principals.
|
EmptyPropertyState |
Abstract base class for PropertyState implementations
providing default implementation which correspond to a property
without any value.
|
EntryRecovery |
|
Environment |
|
EqualsDiff |
Helper class for comparing the equality of node states based on the
content diff mechanism.
|
EquiJoinConditionImpl |
The implementation of the corresponding JCR interface.
|
EquiJoinConditionImpl |
The "a.x = b.y" join condition.
|
ErrorValue |
Instances of this class represent a Value which couldn't be retrieved.
|
EscapeUtils |
Utility class to escape '\n', '\r', '\' char
while being written to file and unescape then upon getting
read from file.
|
ETA |
ETA ...
|
EventAggregator |
An EventAggregator can be provided via a FilterProvider
and is then used to 'aggregate' an event at creation time
(ie after filtering).
|
EventFactory |
Event factory for generating JCR event instances that are optimized
for minimum memory overhead.
|
EventFilter |
Filter for determining what changes to report the the event listener.
|
EventGenerator |
Continuation-based content diff implementation that generates
EventHandler callbacks by recursing down a content diff
in a way that guarantees that only a finite number of callbacks
will be made during a EventGenerator.generate() method call, regardless
of how large or complex the content diff is.
|
EventHandler |
Handler of content change events.
|
EventListenerMBean |
MBean interface for exposing information about a registered observation
listener.
|
EventTypeFilter |
|
EveryoneFilter |
|
EveryonePrincipal |
Built-in principal group that has every other principal as member.
|
EvictionListener<K,V> |
A listener that gets notified of entries that were removed from the cache.
|
ExceptionResult |
ExceptionResult ...
|
ExcludeExternal |
The presence of this marker interface on a EventListener
indicates that cluster external observation events must not be reported to that
event listener.
|
ExecutionContext |
An instance of this class provides the context for the execution of a query,
which in essence captures a stable state of the content tree from the time
the execution context was created.
|
ExecutionPlan |
An execution plan for a join or a selector.
|
ExecutorCloser |
Utility class to properly close any ExecutorService.
|
Explanation |
Expert: Describes the score computation for document and query.
|
Explorer |
NodeStore explorer
|
ExtendedBlobStatsCollector |
|
ExtendedIndexHelper |
|
ExternalAuthorizableActionProvider |
|
ExternalGroup |
ExternalGroup defines a group that is provided by an external system.
|
ExternalGroupRef |
Deprecated. |
ExternalIdentity |
ExternalIdentity defines an identity provided by an external system.
|
ExternalIdentityConstants |
Constants used by the external identity management.
|
ExternalIdentityException |
ExternalIdentityException is used to notify about errors when dealing with external identities.
|
ExternalIdentityMonitor |
|
ExternalIdentityMonitorImpl |
|
ExternalIdentityProvider |
ExternalIdentityProvider defines an interface to an external system that provides users and groups that
can be synced with local ones.
|
ExternalIdentityProviderManager |
The external identity provider management.
|
ExternalIdentityRef |
ExternalIdentityRef defines a reference to an external identity.
|
ExternalIDPManagerImpl |
ExternalIDPManagerImpl is used to manage registered external identity provider.
|
ExternalLoginModule |
|
ExternalLoginModuleFactory |
Implements a LoginModuleFactory that creates ExternalLoginModule s and allows to configure login modules
via OSGi config.
|
ExternalPrincipalConfiguration |
Implementation of the PrincipalConfiguration interface that provides
principal management for Group principals associated with
external identities
managed outside of the scope of the repository by an
ExternalIdentityProvider .
|
ExternalSort |
Source copied from a publicly available library.
|
ExternalSortByteArray |
Variation of ExternalSort that stores the lines read from intermediate files as byte arrays to avoid the conversion
from byte[] to String and then back.
|
ExternalUser |
ExternalUser defines a user provided by an external system.
|
FacetColumnImpl |
A facet result column expression.
|
FacetResult |
A facet result is a wrapper for QueryResult capable of returning information about facets
stored in the query result Row s.
|
FacetResult.Facet |
A query result facet, composed by its label and count.
|
FacetResult.FacetResultRow |
|
FailingValidator |
Validator that rejects all changes.
|
Feature |
A feature toggle to control new functionality.
|
FeatureToggle |
A feature toggle is registered with the Whiteboard and can be
discovered by third party code to control the state of feature toggles.
|
Field |
Expert: directly create a field for a document.
|
Field.Index |
Deprecated.
|
Field.Store |
Specifies whether and how a field should be stored.
|
Field.TermVector |
Deprecated.
|
FieldCache |
Expert: Maintains caches of term values.
|
FieldCache.ByteParser |
Deprecated. |
FieldCache.Bytes |
Field values as 8-bit signed bytes
|
FieldCache.CacheEntry |
EXPERT: A unique Identifier/Description for each item in the FieldCache.
|
FieldCache.CreationPlaceholder |
Placeholder indicating creation of this cache is currently in-progress.
|
FieldCache.DoubleParser |
Interface to parse doubles from document fields.
|
FieldCache.Doubles |
Field values as 64-bit doubles
|
FieldCache.FloatParser |
Interface to parse floats from document fields.
|
FieldCache.Floats |
Field values as 32-bit floats
|
FieldCache.IntParser |
Interface to parse ints from document fields.
|
FieldCache.Ints |
Field values as 32-bit signed integers
|
FieldCache.LongParser |
Interface to parse long from document fields.
|
FieldCache.Longs |
Field values as 64-bit signed long integers
|
FieldCache.Parser |
Marker interface as super-interface to all parsers.
|
FieldCache.ShortParser |
Deprecated. |
FieldCache.Shorts |
Field values as 16-bit signed shorts
|
FieldCacheDocIdSet |
Base class for DocIdSet to be used with FieldCache.
|
FieldCacheRangeFilter<T> |
A range filter built on top of a cached single term field (in FieldCache ).
|
FieldCacheRewriteMethod |
Rewrites MultiTermQueries into a filter, using the FieldCache for term enumeration.
|
FieldCacheSanityChecker |
Provides methods for sanity checking that entries in the FieldCache
are not wasteful or inconsistent.
|
FieldCacheSanityChecker.Insanity |
Simple container for a collection of related CacheEntry objects that
in conjunction with each other represent some "insane" usage of the
FieldCache.
|
FieldCacheSanityChecker.InsanityType |
An Enumeration of the different types of "insane" behavior that
may be detected in a FieldCache.
|
FieldCacheTermsFilter |
A Filter that only accepts documents whose single
term value in the specified field is contained in the
provided set of allowed terms.
|
FieldComparator<T> |
Expert: a FieldComparator compares hits so as to determine their
sort order when collecting the top results with TopFieldCollector .
|
FieldComparator.ByteComparator |
Deprecated. |
FieldComparator.DocComparator |
Sorts by ascending docID
|
FieldComparator.DoubleComparator |
|
FieldComparator.FloatComparator |
|
FieldComparator.IntComparator |
|
FieldComparator.LongComparator |
|
FieldComparator.NumericComparator<T extends Number> |
Base FieldComparator class for numeric types
|
FieldComparator.RelevanceComparator |
Sorts by descending relevance.
|
FieldComparator.ShortComparator |
Deprecated. |
FieldComparator.TermOrdValComparator |
Sorts by field's natural Term sort order, using
ordinals.
|
FieldComparator.TermValComparator |
Sorts by field's natural Term sort order.
|
FieldComparatorSource |
|
FieldDoc |
Expert: A ScoreDoc which also contains information about
how to sort the referenced document.
|
FieldInfo |
Access to the Field Info file that describes document fields and whether or
not they are indexed.
|
FieldInfo.DocValuesType |
DocValues types.
|
FieldInfo.IndexOptions |
Controls how much information is stored in the postings lists.
|
FieldInfos |
Collection of FieldInfo s (accessible by number or by name).
|
FieldInfosFormat |
|
FieldInfosReader |
|
FieldInfosWriter |
|
FieldInvertState |
This class tracks the number and position / offset parameters of terms
being added to the index.
|
FieldMaskingSpanQuery |
Wrapper to allow SpanQuery objects participate in composite
single-field SpanQueries by 'lying' about their search field.
|
Fields |
Flex API for access to fields and terms
|
FieldsConsumer |
Abstract API that consumes terms, doc, freq, prox, offset and
payloads postings.
|
FieldsProducer |
Abstract API that produces terms, doc, freq, prox, offset and
payloads postings.
|
FieldType |
Describes the properties of a field.
|
FieldType.NumericType |
Data type of the numeric value
|
FieldValueFilter |
A Filter that accepts all documents that have one or more values in a
given field.
|
FieldValueHitQueue<T extends FieldValueHitQueue.Entry> |
Expert: A hit queue for sorting by hits by terms in more than one field.
|
FieldValueHitQueue.Entry |
|
FileBlobStore |
A file blob store.
|
FileBlobStoreService |
|
FileCache |
|
FileDataStoreService |
|
FileIOUtils |
Simple File utils
|
FileIOUtils.TransformingComparator |
Decorates the given comparator and applies the function before delegating to the decorated
comparator.
|
FileLineDifferenceIterator |
FileLineDifferenceIterator class which iterates over the difference of 2 files line by line.
|
FilePacker |
A utility class that allows converting the files of a tree store into one
file (pack the files), and back from a file to a list of files (unpack the
files).
|
FilePacker.FileEntry |
|
FileReaper |
Thread-safe class tracking files to be removed.
|
FileStore |
A storage backend for the tree store that stores files on the local file
system.
|
FileStore |
The storage implementation for tar files.
|
FileStoreBackup |
|
FileStoreBackupImpl |
|
FileStoreBackupRestoreImpl |
|
FileStoreBackupRestoreMBean |
MBean for backing up and restoring a NodeStore .
|
FileStoreBuilder |
|
FileStoreBuilderCustomizer |
|
FileStoreGCMonitor |
GCMonitor implementation providing the file store gc status.
|
FileStoreHelper |
|
FileStoreMonitor |
FileStoreMonitor are notified for any writes or deletes
performed by FileStore
|
FileStoreMonitorAdapter |
|
FileStoreRestore |
|
FileStoreRestoreImpl |
|
FileStoreStats |
|
FileStoreStatsMBean |
|
FileStoreTarBuilderCustomizer |
|
FileStoreUtil |
|
FileSwitchDirectory |
Expert: A Directory instance that switches files between
two other Directory instances.
|
FileTreeTraverser |
|
Filter |
A filter is used by the FilteringObserver to decide whether or not a content
change should be forwarded.
|
Filter |
The filter for an index lookup that contains a number of restrictions that
are combined with AND.
|
Filter |
Interface that allows to define the principals for which principal based access control management and permission
evaluation can be executed.
|
Filter |
Abstract base class for restricting which documents may
be returned during searching.
|
Filter.PathRestriction |
The path restriction type.
|
Filter.PropertyRestriction |
A restriction for a property.
|
FilterAtomicReader |
A FilterAtomicReader contains another AtomicReader, which it
uses as its basic source of data, possibly transforming the data along the
way or providing additional functionality.
|
FilterAtomicReader.FilterDocsAndPositionsEnum |
|
FilterAtomicReader.FilterDocsEnum |
Base class for filtering DocsEnum implementations.
|
FilterAtomicReader.FilterFields |
Base class for filtering Fields
implementations.
|
FilterAtomicReader.FilterTerms |
Base class for filtering Terms implementations.
|
FilterAtomicReader.FilterTermsEnum |
Base class for filtering TermsEnum implementations.
|
FilterBuilder |
|
FilterBuilder.AddSubtreeTreeCondition |
|
FilterBuilder.Condition |
|
FilterBuilder.DeleteSubtreeTreeCondition |
|
FilterBuilder.MoveCondition |
|
FilterCodec |
A codec that forwards all its method calls to another codec.
|
FilterConfigMBean |
|
FilterDirectory |
Directory implementation that delegates calls to another directory.
|
FilterDirectoryReader |
A FilterDirectoryReader wraps another DirectoryReader, allowing implementations
to transform or extend it.
|
FilterDirectoryReader.StandardReaderWrapper |
A no-op SubReaderWrapper that simply returns the parent
DirectoryReader's original subreaders.
|
FilterDirectoryReader.SubReaderWrapper |
Factory class passed to FilterDirectoryReader constructor that allows
subclasses to wrap the filtered DirectoryReader's subreaders.
|
FilteredDocIdSet |
Abstract decorator class for a DocIdSet implementation
that provides on-demand filtering/validation
mechanism on a given DocIdSet.
|
FilteredDocIdSetIterator |
Abstract decorator class of a DocIdSetIterator
implementation that provides on-demand filter/validation
mechanism on an underlying DocIdSetIterator.
|
FilteredHandler |
Filtered event handler.
|
FilteredQuery |
A query that applies a filter to the results of another query.
|
FilteredQuery.FilterStrategy |
Abstract class that defines how the filter ( DocIdSet ) applied during document collection.
|
FilteredQuery.RandomAccessFilterStrategy |
|
FilteredTermsEnum |
Abstract class for enumerating a subset of all terms.
|
FilteredTermsEnum.AcceptStatus |
Return value, if term should be accepted or the iteration should
END .
|
FilterFactory |
Static factory that allows wrapping a JackrabbitEventFilter into an
OakEventFilter that contains some oak specific extensions.
|
FilterImpl |
A filter or lookup condition.
|
FilteringAwareObserver |
A FilteringAwareObserver is the stateless-variant of
an Observer which gets an explicit before as well as the
after NodeState.
|
FilteringDispatcher |
Part of the FilteringObserver: the FilteringDispatcher is used
to implement the skipping (filtering) of content changes
which the FilteringDispatcher flags as NOOP_CHANGE.
|
FilteringNodeState |
NodeState implementation that decorates another node-state instance
in order to hide subtrees or partial subtrees from the consumer of
the API.
|
FilteringObserver |
An observer that implements filtering of content changes
while at the same time supporting (wrapping) a BackgroundObserver
underneath.
|
FilterIterator<T> |
An Iterator implementation that filters elements with a boolean predicate.
|
FilterIterators |
Filtering iterators that are useful for queries with limit, offset, order by,
or distinct.
|
FilterProvider |
Instance of this class provide a EventFilter for observation
events and a filter for commits.
|
FilterProvider |
Interface that allows to define the principals for which principal based access control management and permission
evaluation can be executed.
|
FilterProviderImpl |
Implementation of the Filter interface that
consists of the following two filtering conditions:
All principals in the set must be of type SystemUserPrincipal
All principals in the set must be located in the repository below the configured path.
|
Filters |
This utility class provides common EventFilter instances
|
FirstImpl |
The function "first(..)".
|
FixedBitSet |
|
FixedBitSet.FixedBitSetIterator |
|
FlagsAttribute |
This attribute can be used to pass different flags down the Tokenizer chain,
e.g.
|
FlagsAttributeImpl |
|
FlatFileBufferLinkedList |
Linked list implementation which supports multiple iterators.
|
FlatFileCommand |
The flatfile command is an extract of the ability to create a filefile from
the index command.
|
FlatFileCommand.FlatFileOptions |
|
FlatFileNodeStoreBuilder |
This class is where the strategy being selected for building FlatFileStore.
|
FlatFileNodeStoreBuilder.SortStrategyType |
|
FlatFileSplitter |
|
FlatFileStore |
|
FlatFileStoreUtils |
Deprecated.
|
FloatDocValuesField |
|
FloatField |
Field that indexes float values
for efficient range filtering and sorting.
|
FlushInfo |
A FlushInfo provides information required for a FLUSH context.
|
FormattingUtils |
|
FormatVersion |
The format version currently in use by the DocumentNodeStore and written
to the underlying DocumentStore.
|
ForwardingListener<K,V> |
Listener which forwards the notifications to a delegate.
|
FragmentMatcher |
This utility class allows to match strings against a simple pattern language.
|
FragmentMatcher.Result |
|
FrozenNodeLogger |
Logger facility for frozen node lookups by identifier.
|
FrozenNodeRef |
Contains one particular reference to an nt:frozenNode.
|
FrozenNodeRefsByScanningCommand |
Scans and lists all references to nt:frozenNode and returns an exit code of 1 if any are found (0 otherwise).
|
FrozenNodeRefsUsingIndexCommand |
Scans and lists all references to nt:frozenNode and returns an exit code of 1 if any are found (0 otherwise).
|
FSBackend |
|
FSBlobSerializer |
Serializer which stores blobs in a FileDataStore format
|
FSDirectory |
Base class for Directory implementations that store index
files in the file system.
|
FSDirectory.FSIndexInput |
Base class for reading input from a RandomAccessFile
|
FSDirectory.FSIndexOutput |
|
FSLockFactory |
Base class for file system based locking implementation.
|
FST<T> |
Represents an finite state machine (FST), using a
compact byte[] format.
|
FST.Arc<T> |
Represents a single arc.
|
FST.BytesReader |
Reads bytes stored in an FST.
|
FST.INPUT_TYPE |
Specifies allowed range of each int input label for
this FST.
|
FullGCStatsCollector |
|
FullTextAnd |
A fulltext "and" condition.
|
FullTextContains |
A group of full-text expressions that reflects a "contains(...)" expression,
and allows to access the original (unparsed) full text term.
|
FullTextExpression |
The base class for fulltext condition expression.
|
FullTextOr |
A fulltext "or" condition.
|
FullTextParser |
A parser for fulltext condition literals.
|
FullTextSearchImpl |
The implementation of the corresponding JCR interface.
|
FullTextSearchImpl |
A fulltext "contains(...)" condition.
|
FullTextSearchScoreImpl |
The implementation of the corresponding JCR interface.
|
FullTextSearchScoreImpl |
A fulltext search score expression.
|
FullTextTerm |
A fulltext term, or a "not" term.
|
FullTextVisitor |
A visitor for full-text expressions.
|
FullTextVisitor.FullTextVisitorBase |
The base implementation of a full-text visitor.
|
FuzzyQuery |
Implements the fuzzy search query.
|
FuzzyTermsEnum |
Subclass of TermsEnum for enumerating all terms that are similar
to the specified filter term.
|
FuzzyTermsEnum.LevenshteinAutomataAttribute |
reuses compiled automata across different segments,
because they are independent of the index
|
FuzzyTermsEnum.LevenshteinAutomataAttributeImpl |
Stores compiled automata as a list (indexed by edit distance)
|
GarbageCollectableBlobStore |
A blob store that supports garbage collection.
|
GarbageCollection |
Remove unreferenced files from the store.
|
GarbageCollection.GarbageCollectionResult |
Garbage collection results.
|
GarbageCollectionRepoStats |
Garbage collection stats for the repository.
|
GarbageCollectorFileState |
Class for keeping the file system state of the garbage collection.
|
GCGeneration |
Instances of this class represent the garbage collection generation related
information of a segment.
|
GCIncrement |
Utility class to keep track of generations for incremental compaction.
|
GCJournal |
Persists the repository size and the reclaimed size following a cleanup
operation in the gc.log file with the format:
'repoSize, reclaimedSize, timestamp, gc generation, gc full generation (since Oak 1.8),
number of nodes compacted, root id (since Oak 1.8)'.
|
GCJournal.GCJournalEntry |
|
GCJournalFile |
This type abstracts the gc.log file, used to save information about
the segment garbage collection.
|
GCMemoryBarrier |
Responsible for raising the low memory flag whenever the available memory
falls under a specified threshold.
|
GCMonitor |
GCMonitor instance are used to monitor garbage collection.
|
GCMonitor.Empty |
|
GCMonitorTracker |
This GCMonitor implementation tracks GCMonitor instances registered
to the Whiteboard delegating all calls to to those.
|
GCNodeWriteMonitor |
Monitors the compaction cycle and keeps a compacted nodes counter, in order
to provide a best effort progress log based on extrapolating the previous
size and node count and current size to deduce current node count.
|
GenerateVersionInconsistencyReport |
Generate a report with the list of affected versionHistory nodes containing
empty version nodes or an incorrect primaryType.
|
GenericDescriptors |
|
GenericPropertyState |
|
GetBlobRequest |
|
GetBlobRequestEncoder |
|
GetBlobResponse |
|
GetBlobResponseEncoder |
|
GetHeadRequest |
|
GetHeadRequestEncoder |
|
GetHeadResponse |
|
GetHeadResponseEncoder |
Encodes a 'get head' response.
|
GetReferencesRequest |
|
GetReferencesRequestEncoder |
|
GetReferencesResponse |
|
GetReferencesResponseEncoder |
|
GetSegmentRequest |
|
GetSegmentRequestEncoder |
|
GetSegmentResponse |
|
GetSegmentResponseEncoder |
Encodes a 'get segment' response.
|
GlobalNameMapper |
Name mapper with no local prefix remappings.
|
GlobbingPathFilter |
This Filter implementation supports filtering on paths using
simple glob patterns.
|
GlobbingPathHelper |
|
GraphLoader |
|
Group |
|
GroupAction |
The GroupAction interface allows for implementations to be informed about and react to the following
changes to a Group 's members:
GroupAction.onMemberAdded(Group, Authorizable, Root, NamePathMapper)
GroupAction.onMembersAdded(Group, Iterable, Iterable, Root, NamePathMapper)
GroupAction.onMembersAddedContentId(Group, Iterable, Iterable, Root, NamePathMapper)
GroupAction.onMemberRemoved(Group, Authorizable, Root, NamePathMapper)
GroupAction.onMembersRemoved(Group, Iterable, Iterable, Root, NamePathMapper)
|
GroupPrincipal |
This interface is used to represent a group of principals.
|
GroupPrincipals |
Helper class to deal with the migration between the 2 types of groups
|
GrowableByteArrayDataOutput |
|
GrowableWriter |
Implements PackedInts.Mutable , but grows the
bit count of the underlying packed ints on-demand.
|
GuestLoginModule |
The GuestLoginModule is intended to provide backwards compatibility
with the login handling present in the JCR reference implementation located
in jackrabbit-core.
|
Hash |
A hash function utility class.
|
HistogramStats |
A metric which calculates the distribution of a value.
|
History |
Prints the revision history of an existing segment store.
|
History.Builder |
Collect options for the History command.
|
HyperLogLog |
A HyperLogLog implementation.
|
HyperLogLog3Linear64 |
Cardinality estimation with the HyperLogLog algorithm, using the tail cut
mechanism.
|
IBSimilarity |
Provides a framework for the family of information-based models, as described
in Stéphane Clinchant and Eric Gaussier.
|
IdentifierManager |
TODO document
|
IdentifierTracker |
Simple utility class for lazily tracking the current identifier during
a tree traversal that recurses down a subtree.
|
IllegalRepositoryStateException |
This exception can be thrown by implementers of this API to signal an error
condition caused by an invalid state of the repository.
|
ImmutableACL |
An implementation of the JackrabbitAccessControlList interface that only
allows for reading.
|
ImmutablePrivilegeDefinition |
Default implementation of the PrivilegeDefinition interface.
|
ImmutableRoot |
Simple implementation of the Root interface that only supports simple read
operations based on the NodeState (or ImmutableTree )
passed to the constructor.
|
ImmutableTree |
Immutable implementation of the Tree interface in order to provide
the much feature rich API functionality for a given NodeState .
|
ImmutableTree.DefaultParentProvider |
|
ImmutableTree.ParentProvider |
|
Impact |
|
ImpactOption |
|
Impersonation |
The Impersonation maintains Principals that are allowed to
impersonate.
|
ImpersonationCredentials |
|
ImportBehavior |
Utility class defining specific, configurable import behavior.
|
Importer |
Content importer.
|
ImporterImpl |
|
ImportHandler |
An ImportHandler instance can be used to import serialized
data in System View XML or Document View XML.
|
Include |
Include represents a single path pattern which captures the path which
needs to be included in bundling.
|
IncrementalFlatFileStore |
|
IncrementalFlatFileStoreEditor |
|
IncrementalFlatFileStoreNodeStateEntryReader |
|
IncrementalFlatFileStoreNodeStateEntryWriter |
|
IncrementalFlatFileStoreStrategy |
|
IncrementalIndexStoreMetadata |
|
IncrementalIndexStoreSortStrategy |
|
IncrementalStoreBuilder |
|
IncrementalStoreBuilder.IncrementalSortStrategyType |
|
IncrementalStoreOperand |
|
Index |
An index for the entries in a TAR file.
|
IndexableBinaryStringTools |
Deprecated.
|
IndexableField |
Represents a single field for indexing.
|
IndexableFieldType |
Describes the properties of a field.
|
IndexCommand |
|
IndexCommit |
|
IndexCommitCallback |
Implementations of this interface can be notified of progress of
commit that would update the index.
|
IndexCommitCallback.IndexProgress |
|
IndexConstants |
TODO document
|
IndexDefinitionUpdater |
|
IndexDefMergerUtils |
Utility that allows to merge index definitions.
|
IndexDeletionPolicy |
|
IndexDiff |
The index diff tools allows to compare and merge indexes
|
IndexDiffCommand |
|
IndexDumper |
|
IndexEditor |
Represents the content of a QueryIndex as well as a mechanism for keeping
this content up to date.
|
IndexEditorProvider |
Extension point for plugging in different kinds of IndexEditor providers.
|
IndexedProperty |
An indexed property.
|
IndexEntry |
An entry in the index of entries of a TAR file.
|
IndexerConfiguration |
Indexer configuration for parallel indexing
|
IndexerMBean |
|
IndexerMBeanImpl |
|
IndexerStatisticsTracker |
|
IndexerSupport |
|
IndexFileNames |
This class contains useful constants representing filenames and extensions
used by lucene, as well as convenience methods for querying whether a file
name matches an extension ( matchesExtension ), as well as generating file names from a segment name,
generation and extension (
fileNameFromGeneration ,
segmentFileName ).
|
IndexFormatTooNewException |
This exception is thrown when Lucene detects
an index that is newer than this Lucene version.
|
IndexFormatTooOldException |
This exception is thrown when Lucene detects
an index that is too old for this Lucene version
|
IndexHelper |
|
IndexImporterSupportBase |
|
IndexInfo |
Captures information related to index
|
IndexInfoProvider |
Service to be provided by various index implementations.
|
IndexInfoService |
|
IndexInfoServiceImpl |
|
IndexingContext |
|
IndexingReporter |
Stores diagnostic and performance information about indexing operations for reporting at the end of the indexing job.
|
IndexInitializer |
IndexInitializer configures the repository with required fulltext index
|
IndexInput |
Abstract base class for input from a file in a Directory .
|
IndexLoader |
Load and validate the index of a TAR file.
|
IndexMBeanRegistration |
|
IndexMerge |
Merge custom index definitions with out-of-the-box index definitions.
|
IndexMergeCommand |
|
IndexName |
An index name, which possibly contains two version numbers: the product
version number, and the customer version number.
|
IndexNotFoundException |
Signals that no index was found in the Directory.
|
IndexOptions |
|
IndexOutput |
Abstract base class for output to a file in a Directory.
|
IndexPathService |
|
IndexPathServiceImpl |
|
IndexReader |
IndexReader is an abstract class, providing an interface for accessing an
index.
|
IndexReader.ReaderClosedListener |
A custom listener that's invoked when the IndexReader
is closed.
|
IndexReaderContext |
A struct like class that represents a hierarchical relationship between
IndexReader instances.
|
IndexRow |
A row returned by the index.
|
IndexRowImpl |
A simple index row implementation.
|
IndexSearcher |
Implements search over a single IndexReader.
|
IndexSearcher.LeafSlice |
A class holding a subset of the IndexSearcher s leaf contexts to be
executed within a single thread.
|
IndexSelectionPolicy |
This class defines the index selection policy constants
|
IndexStatsMBean |
|
IndexStore |
|
IndexStoreCommand |
|
IndexStoreMetadata |
|
IndexStoreMetadataOperator<M> |
|
IndexStoreMetadataOperatorImpl<M> |
|
IndexStoreSortStrategy |
|
IndexStoreSortStrategyBase |
|
IndexStoreUtils |
|
IndexUpdate |
|
IndexUpdate.MissingIndexProviderStrategy |
|
IndexUpdateCallback |
|
IndexUpdateProvider |
|
IndexUpgrader |
This is an easy-to-use tool that upgrades all segments of an index from previous Lucene versions
to the current segment file format.
|
IndexUtils |
TODO document
|
IndexVersionOperation |
|
IndexWriter |
Builds an index incrementally in memory, and serializes its contents into a
sequence of bytes.
|
IndexWriter |
An IndexWriter creates and maintains an index.
|
IndexWriter.IndexReaderWarmer |
If DirectoryReader.open(IndexWriter,boolean) has
been called (ie, this writer is in near real-time
mode), then after a merge completes, this class can be
invoked to warm the reader on the newly merged
segment, before the merge commits.
|
IndexWriterConfig |
Holds all the configuration that is used to create an IndexWriter .
|
IndexWriterConfig.OpenMode |
|
InfoStream |
|
InImpl |
A "in" comparison operation.
|
InitialContent |
|
InitialContentMigrator |
|
InMemoryBroadcaster |
A mechanism that broadcasts to all registered consumers.
|
InMemoryDataRecord |
Represents binary data which is backed by a byte[] (in memory).
|
InPlaceMergeSorter |
Sorter implementation based on the merge-sort algorithm that merges
in place (no extra memory will be allocated).
|
InputStreamDataInput |
|
Installer |
Provides very basic installation capabilities.
|
IntBlockPool |
|
IntBlockPool.Allocator |
Abstract class for allocating and freeing int
blocks.
|
IntBlockPool.DirectAllocator |
|
IntBlockPool.SliceReader |
|
IntBlockPool.SliceWriter |
|
IntDocValuesField |
Deprecated.
|
Internal |
Elements annotated @Internal are -- although possibly exported -- intended
for Oak's internal use only.
|
IntField |
Field that indexes int values
for efficient range filtering and sorting.
|
IntroSorter |
Sorter implementation based on a variant of the quicksort algorithm
called introsort: when
the recursion level exceeds the log of the length of the array to sort, it
falls back to heapsort.
|
IntSequenceOutputs |
An FST Outputs implementation where each output
is a sequence of ints.
|
IntsRef |
Represents int[], as a slice (offset + length) into an
existing int[].
|
IntsRefFSTEnum<T> |
Enumerates all input (IntsRef) + output pairs in an
FST.
|
IntsRefFSTEnum.InputOutput<T> |
Holds a single input (IntsRef) + output pair.
|
InvalidBinaryReferencesIndexException |
|
InvalidFileStoreVersionException |
This exception can be thrown during the startup of the FileStore to
indicate an incompatible version mismatch between the code that generated the
data in the store and the current version of the FileStore .
|
InvalidIndexException |
Thrown to indicate that invalid or malformed data is encountered while
validating an index.
|
IOContext |
IOContext holds additional details on the merge/search context.
|
IOContext.Context |
Context is a enumerator which specifies the context in which the Directory
is being used for.
|
IOMonitor |
Callback interface that eases the collection of statistics about I/O
operations.
|
IOMonitorAdapter |
|
IOTraceLogWriter |
This IOTraceWriter implementation implements persistence
through a Logger instance.
|
IOTraceMonitor |
|
IOTracer |
This utility class allows collecting IO traces of read accesses to segments
caused by reading specific items.
|
IOTraceWriter |
Instances of IOTraceWriter are responsible for persisting
io traces.
|
IOUtils |
Input/output utility methods.
|
IOUtils |
This class emulates the new Java 7 "Try-With-Resources" statement.
|
ItemBasedPrincipal |
ItemBasedPrincipal is a Principal having a
corresponding item within the JCR repository.
|
ItemDelegate |
|
ItemOperation<U> |
|
ItemSaveValidatorProvider |
This validator checks that all changes are contained within the subtree
rooted at a given path.
|
JaasLoginContext |
|
JackrabbitAccessControlEntry |
JackrabbitAccessControlEntry is a Jackrabbit specific extension
of the AccessControlEntry interface.
|
JackrabbitAccessControlList |
JackrabbitAccessControlList is an extension of the AccessControlList .
|
JackrabbitAccessControlManager |
JackrabbitAccessControlManager provides extensions to the
AccessControlManager interface.
|
JackrabbitAccessControlManagerDelegator |
This implementation of JackrabbitAccessControlManager delegates back to a
delegatee wrapping each call into a SessionOperation closure.
|
JackrabbitAccessControlPolicy |
|
JackrabbitEvent |
This is an extension of the event interface which provides
a method to detect whether the changes happened on locally
or remotely in a clustered environment.
|
JackrabbitEventFilter |
A storage object for event filter configuration.
|
JackrabbitNode |
The Jackrabbit Node interface.
|
JackrabbitNodeTypeManager |
Deprecated.
|
JackrabbitObservationManager |
|
JackrabbitPrincipal |
JackrabbitPrincipal marks the principal to be the result of
authentication against the repository.
|
JackrabbitQueryResult |
The Jackrabbit query result interface.
|
JackrabbitRepository |
The Jackrabbit repository interface.
|
JackrabbitRepositoryFactory |
Classes that implement this interface additionally provide management features.
|
JackrabbitRepositoryFixture |
|
JackrabbitSession |
Jackrabbit specific extension of the JCR Session interface.
|
JackrabbitValue |
Values returned by Jackrabbit may implement this interface.
|
JackrabbitValueFactory |
Defines optional functionality that a ValueFactory may choose to
provide.
|
JackrabbitWorkspace |
The Jackrabbit workspace interface.
|
Jcr |
|
JcrAllUtil |
|
JcrApiNotFoundException |
Exception for signaling that the JCR API is not available.
|
JcrConflictHandler |
Utility class providing conflict handlers used for JCR.
|
JcrCreator |
|
JcrDescriptorsImpl |
The JcrDescriptorsImpl extend the GenericDescriptors by automatically marking some of the JCR
features as supported.
|
JcrLastModifiedConflictHandler |
Conflict Handler that merges concurrent updates to
org.apache.jackrabbit.JcrConstants.JCR_LASTMODIFIED by picking the
older of the 2 conflicting dates and
org.apache.jackrabbit.JcrConstants.JCR_CREATED by picking the newer
of the 2 conflicting dates.
|
JcrNameParser |
Parses and validates JCR names.
|
JcrPathParser |
TODO document
|
JcrPathParser.Listener |
|
JcrRemotingServlet |
JcrRemotingServlet ...
|
JCRWebdavServerServlet |
JCRWebdavServerServlet provides request/response handling for the
JCRWebdavServer.
|
JmxUtil |
Utility methods related to JMX
|
JNDIConfig |
The JNDI config hold information about JNDI connection details.
|
JoinConditionImpl |
The base class for join conditions.
|
JoinConditionImpl |
The base class for join conditions.
|
JoinExecutionPlan |
An execution plan for a join.
|
JoinImpl |
The implementation of the corresponding JCR interface.
|
JoinImpl |
A join.
|
JoinType |
Enumeration of the JCR 2.0 join types.
|
JoinType |
The enumeration of all join types.
|
JournalEntry |
Keeps track of changes performed between two consecutive background updates.
|
JournalEntry |
A value class representing an entry in the revisions journal.
|
JournalFile |
The journal is a special, atomically updated file that records the state of
the repository as a sequence of references to successive root node records.
|
JournalFileReader |
|
JournalFileWriter |
|
JournalGarbageCollector |
The JournalGarbageCollector can clean up JournalEntries that are older than a
particular age.
|
JournalProperty |
Marker interface to indicate the implementing class can be made part of JournalEntry
|
JournalPropertyBuilder<T extends JournalProperty> |
|
JournalPropertyHandlerFactory |
|
JournalPropertyService |
Each component which needs to add a property to JournalEntry
should register this service
|
JournalReader |
Iterator over the revisions in the journal in reverse order
(end of the file to beginning).
|
JsonDeserializer |
|
JsonIndexCommand |
|
JsonObject |
Simple JSON Object representation.
|
JsonSerializer |
Utility class for serializing node and property states to JSON.
|
JsopBuilder |
A builder for Json and Jsop strings.
|
JsopDiff |
TODO document
|
JsopReader |
A reader for Json and Jsop strings.
|
JsopStream |
A fast Jsop writer / reader.
|
JsopTokenizer |
A tokenizer for Json and Jsop strings.
|
JsopWriter |
A builder for Json and Json diff strings.
|
KeepOnlyLastCommitDeletionPolicy |
This IndexDeletionPolicy implementation that
keeps only the most recent commit and immediately removes
all prior commits after a new commit is done.
|
KeyDataType |
|
KeywordAttribute |
This attribute can be used to mark a token as a keyword.
|
KeywordAttributeImpl |
|
Lambda |
The lambda (λw) parameter in information-based
models.
|
LambdaDF |
Computes lambda as docFreq+1 / numberOfDocuments+1 .
|
LambdaTTF |
Computes lambda as totalTermFreq+1 / numberOfDocuments+1 .
|
LastModifiedRange |
|
LastRevRecoveryAgent |
Utility class for recovering potential missing _lastRev updates of nodes due
to crash of a node.
|
LastRevTracker |
An implementation of this interface receives callbacks about paths
that need an update of the _lastRev field on documents.
|
LazyInputStream |
* This input stream delays accessing the InputStream until the first byte is read
|
LazyValue<T> |
An instances of this class represents a lazy value of type T .
|
LdapGroup |
|
LdapIdentity |
|
LdapIdentityProperties |
LdapIdentityProperties implements a case insensitive hash map that preserves the case of the keys but
ignores the case during lookup.
|
LdapIdentityProvider |
LdapIdentityProvider implements an external identity provider that reads users and groups from an ldap
source.
|
LdapProviderConfig |
Configuration of the ldap provider.
|
LdapProviderConfig.PoolConfig |
Defines the configuration of a connection pool.
|
LdapUser |
|
LeaseCheckDocumentStoreWrapper |
Wrapper of another DocumentStore that does a lease check on any method
invocation (read or update) and fails if the lease is not valid.
|
LeaseCheckMode |
The different modes for lease checks.
|
LeaseFailureHandler |
A LeaseFailureHandler can be provided to the DocumentMK.Builder
and will be passed on to the ClusterNodeInfo for use upon
lease failure.
|
LengthImpl |
The implementation of the corresponding JCR interface.
|
LengthImpl |
The function "length(..)".
|
LevenshteinAutomata |
Class to construct DFAs that match a word within some edit distance.
|
LikePattern |
A pattern matcher.
|
ListCollector |
A collector for a list of collectors.
|
LiteralImpl |
The implementation of the corresponding JCR interface.
|
LiteralImpl |
A literal of a certain data type, possibly "cast(..)" of a literal.
|
LiveDocsFormat |
Format for live/deleted documents
|
LiveFieldValues<S,T> |
Tracks live field values across NRT reader reopens.
|
LiveIndexWriterConfig |
Holds all the configuration used by IndexWriter with few setters for
settings that can be changed on an IndexWriter instance "live".
|
LMDirichletSimilarity |
Bayesian smoothing using Dirichlet priors.
|
LMJelinekMercerSimilarity |
Language model based on the Jelinek-Mercer smoothing method.
|
LMSimilarity |
Abstract superclass for language modeling Similarities.
|
LMSimilarity.CollectionModel |
A strategy for computing the collection language model.
|
LMSimilarity.DefaultCollectionModel |
Models p(w|C) as the number of occurrences of the term in the
collection, divided by the total number of tokens + 1 .
|
LMSimilarity.LMStats |
Stores the collection distribution of the current term.
|
LocalDiffCache |
A diff cache, which is pro-actively filled after a commit.
|
LocalDiffCache.Diff |
|
LocalGCJournalFile |
|
LocalJournalFile |
|
LocalManifestFile |
|
LocalNameMapper |
Name mapper with local namespace mappings.
|
Lock |
An interprocess mutex lock.
|
Lock.With |
Utility class for executing code with exclusive access.
|
LockBasedScheduler |
|
LockBasedScheduler.LockBasedSchedulerBuilder |
|
LockConstants |
Deprecated.
|
LockConstants |
|
LockDeprecation |
Support deprecation of JCR locking as per OAK-6421.
|
LockFactory |
Base class for Locking implementation.
|
LockImpl |
|
LockManagerImpl |
Simple lock manager implementation that just keeps track of a set of lock
tokens and delegates all locking operations back to the Session
and Node implementations.
|
LockObtainFailedException |
This exception is thrown when the write.lock
could not be acquired.
|
LockOperation<T> |
Abstract base class for locking operations.
|
LockReleaseFailedException |
This exception is thrown when the write.lock
could not be released.
|
LockStressTest |
Simple standalone tool that forever acquires & releases a
lock using a specific LockFactory.
|
LockVerifyServer |
|
LogByteSizeMergePolicy |
This is a LogMergePolicy that measures size of a
segment as the total byte size of the segment's files.
|
LogDocMergePolicy |
This is a LogMergePolicy that measures size of a
segment as the number of documents (not taking deletions
into account).
|
LoggingDocumentStoreWrapper |
Implements a DocumentStore wrapper and logs all calls.
|
LoggingGCMonitor |
|
LoggingHook |
|
LoggingInitializer |
Configures the logging based on logback-{logIdentifier}.xml specified.
|
LoggingReporter |
A Reporter implementation that logs every nth node
and/or any nth property to the given logger on info
level.
|
LoginContext |
|
LoginContextProvider |
Configurable provider taking care of building login contexts for
the desired authentication mechanism.
|
LoginModuleImpl |
Default login module implementation that authenticates JCR Credentials
against the repository.
|
LoginModuleMBean |
|
LoginModuleMonitor |
|
LoginModuleMonitorImpl |
|
LoginModuleStats |
Deprecated.
|
LoginModuleStatsCollector |
Deprecated.
|
LogMergePolicy |
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.
|
LogSilencer |
Utility class to silence log output based on a specific key.
|
LogStore |
A wrapper for storage backends that allows to log store and read operations.
|
LongBitSet |
BitSet of fixed length (numBits), backed by accessible ( LongBitSet.getBits() )
long[], accessed with a long index.
|
LongConstraint |
|
LongDocValuesField |
Deprecated.
|
LongField |
Field that indexes long values
for efficient range filtering and sorting.
|
LongPropertyState |
|
LongsRef |
Represents long[], as a slice (offset + length) into an
existing long[].
|
LongUtils |
|
LongValues |
Abstraction over an array of longs.
|
LowerCaseImpl |
The implementation of the corresponding JCR interface.
|
LowerCaseImpl |
The function "lower(..)".
|
Lucene3xCodec |
Deprecated.
|
Lucene3xSegmentInfoFormat |
Deprecated.
|
Lucene3xSegmentInfoReader |
Deprecated.
|
Lucene40Codec |
Deprecated.
|
Lucene40DocValuesFormat |
Deprecated.
|
Lucene40FieldInfosFormat |
Deprecated.
|
Lucene40LiveDocsFormat |
Lucene 4.0 Live Documents Format.
|
Lucene40NormsFormat |
Deprecated.
|
Lucene40PostingsBaseFormat |
Deprecated.
|
Lucene40PostingsFormat |
Deprecated.
|
Lucene40PostingsReader |
Deprecated.
|
Lucene40SegmentInfoFormat |
Deprecated.
|
Lucene40SegmentInfoReader |
Deprecated.
|
Lucene40SegmentInfoWriter |
Deprecated. |
Lucene40SkipListReader |
Deprecated.
|
Lucene40StoredFieldsFormat |
Lucene 4.0 Stored Fields Format.
|
Lucene40StoredFieldsReader |
Class responsible for access to stored document fields.
|
Lucene40StoredFieldsWriter |
Class responsible for writing stored document fields.
|
Lucene40TermVectorsFormat |
Lucene 4.0 Term Vectors format.
|
Lucene40TermVectorsReader |
Lucene 4.0 Term Vectors reader.
|
Lucene40TermVectorsWriter |
Lucene 4.0 Term Vectors writer.
|
Lucene41Codec |
Deprecated.
|
Lucene41PostingsBaseFormat |
|
Lucene41PostingsFormat |
Lucene 4.1 postings format, which encodes postings in packed integer blocks
for fast decode.
|
Lucene41PostingsReader |
Concrete class that reads docId(maybe frq,pos,offset,payloads) list
with postings format.
|
Lucene41PostingsWriter |
Concrete class that writes docId(maybe frq,pos,offset,payloads) list
with postings format.
|
Lucene41StoredFieldsFormat |
Lucene 4.1 stored fields format.
|
Lucene42Codec |
Deprecated.
|
Lucene42DocValuesFormat |
Deprecated.
|
Lucene42FieldInfosFormat |
Deprecated.
|
Lucene42NormsFormat |
Lucene 4.2 score normalization format.
|
Lucene42TermVectorsFormat |
|
Lucene45Codec |
Deprecated.
|
Lucene45DocValuesConsumer |
|
Lucene45DocValuesFormat |
Lucene 4.5 DocValues format.
|
Lucene45DocValuesProducer |
|
Lucene45DocValuesProducer.BinaryEntry |
metadata entry for a binary docvalues field
|
Lucene45DocValuesProducer.NumericEntry |
metadata entry for a numeric docvalues field
|
Lucene45DocValuesProducer.SortedSetEntry |
metadata entry for a sorted-set docvalues field
|
Lucene46Codec |
Implements the Lucene 4.6 index format, with configurable per-field postings
and docvalues formats.
|
Lucene46FieldInfosFormat |
Lucene 4.6 Field Infos format.
|
Lucene46SegmentInfoFormat |
Lucene 4.6 Segment info format.
|
Lucene46SegmentInfoReader |
|
Lucene46SegmentInfoWriter |
|
LuceneIndexer |
|
LuceneIndexerProvider |
|
LuceneIndexHelper |
|
LuceneIndexVersionOperation |
|
LucenePackage |
Lucene's package information, including version.
|
LucenePurgeOldIndexVersion |
|
LucenePurgeOldIndexVersionCommand |
|
LZ4Compression |
|
Main |
|
ManagedRepositoryMBean |
Interface for managing a JCR repository as a JMX MBean.
|
ManagementOperation<R> |
A ManagementOperation is a background task, which can be
executed by an Executor .
|
ManagementOperation.Status |
|
ManifestChecker |
|
ManifestFile |
Manifest is a properties files, providing the information about the segment
store (eg.
|
MapDBMapFactory |
A MapFactory backed by MapDB, which stores the map in a temporary file.
|
MapFactory |
|
MapFactory |
Experimental extension point for OAK-1772 to try out alternative approaches for persisting in memory state
Not part of API
|
MapOfSets<K,V> |
Helper class for keeping Lists of Objects associated with keys.
|
MappingMultiDocsAndPositionsEnum |
Exposes flex API, merged from flex API of sub-segments,
remapping docIDs (this is used for segment merging).
|
MappingMultiDocsEnum |
Exposes flex API, merged from flex API of sub-segments,
remapping docIDs (this is used for segment merging).
|
MapRecord |
A map.
|
MarkEventListener |
The listener interface for receiving garbage collection scan events.
|
MarkSweepGarbageCollector |
Mark and sweep garbage collector.
|
MatchAllDocsQuery |
A query that matches all documents.
|
Matcher |
|
MathUtil |
Math static utility methods.
|
MaxNonCompetitiveBoostAttribute |
|
MaxNonCompetitiveBoostAttributeImpl |
|
MaxPayloadFunction |
Returns the maximum payload score seen, else 1 if there are no payloads on the doc.
|
MediaRange |
|
MembershipWriter |
|
MemoryBlobStore |
A memory blob store.
|
MemoryChildNodeEntry |
Basic JavaBean implementation of a child node entry.
|
MemoryDiffCache |
An in-memory diff cache implementation.
|
MemoryDiffCache.Key |
|
MemoryDocumentStore |
Emulates a MongoDB store (possibly consisting of multiple shards and
replicas).
|
MemoryNodeBuilder |
In-memory node state builder.
|
MemoryNodeStore |
Basic in-memory node store implementation.
|
MemoryObject |
A interface for memory-bound cache objects.
|
MemoryStore |
An in-memory storage backend for the tree store.
|
MemoryStore |
A store used for in-memory operations.
|
MemoryStoreRevisions |
This is a simple in memory Revisions implementation.
|
MergedIterator<T extends Comparable<T>> |
Provides a merged sorted view from several sorted iterators.
|
MergeIncrementalFlatFileStore |
|
MergeIncrementalStore |
|
MergeIncrementalTreeStore |
|
MergeInfo |
A MergeInfo provides information required for a MERGE context.
|
MergePolicy |
Expert: a MergePolicy determines the sequence of
primitive merge operations.
|
MergePolicy.DocMap |
A map of doc IDs.
|
MergePolicy.MergeAbortedException |
|
MergePolicy.MergeException |
Exception thrown if there are any problems while
executing a merge.
|
MergePolicy.MergeSpecification |
A MergeSpecification instance provides the information
necessary to perform multiple merges.
|
MergePolicy.MergeTrigger |
|
MergePolicy.OneMerge |
OneMerge provides the information necessary to perform
an individual primitive merge operation, resulting in
a single new segment.
|
MergeScheduler |
Expert: IndexWriter uses an instance
implementing this interface to execute the merges
selected by a MergePolicy .
|
MergeSortedIterators<T> |
MergeSortedIterators is a specialized implementation of a
merge sort of already sorted iterators of some type of comparable elements.
|
MergeState |
Holds common state used during segment merging.
|
MergeState.CheckAbort |
Class for recording units of work when merging segments.
|
MergeState.DocMap |
Remaps docids around deletes during merge
|
MergingNodeStateDiff |
MergingNodeStateDiff...
|
MeterStats |
|
MetricsExporterFixture<T> |
Fixture encapsulating metrics exporter instance of T
|
MetricsExporterFixture.ExporterType |
|
MetricsExporterFixtureProvider |
Initialize different metrics exporter fixture based on parameters used.
|
MetricsExporterFixtureProvider.ExporterType |
Exporter Type supported
|
MetricsFormatter |
|
MetricsIOMonitor |
|
MetricsRemoteStoreMonitor |
|
MetricsSupport |
|
MetricStatisticsProvider |
|
MetricsUtils |
|
MinimizationOperations |
Operations for minimizing automata.
|
MinPayloadFunction |
Calculates the minimum payload seen
|
MissingLastRevSeeker |
Utilities to retrieve _lastRev missing update candidates.
|
MMapDirectory |
|
Modes |
represent an individual Mode for running a COMMAND.
|
ModificationStamp |
|
ModifiedNodeState |
Immutable snapshot of a mutable node state.
|
ModifiedPathDiff |
|
ModifyMetricUpdater |
|
MongoBlob |
The MongoDB representation of a blob.
|
MongoBlobReferenceIterator |
|
MongoBlobStore |
|
MongoConnection |
The MongoConnection abstracts connection to the MongoDB .
|
MongoDBConfig |
|
MongoDocumentNodeStoreBuilder |
|
MongoDocumentNodeStoreBuilderBase<T extends MongoDocumentNodeStoreBuilderBase<T>> |
|
MongoDocumentStore |
A document store that uses MongoDB as the backend.
|
MongoDocumentStoreCheckHelper |
MongoDocumentStoreCheckHelper ...
|
MongoDocumentStoreHelper |
Helper class to access package private methods on MongoDocumentStore.
|
MongoDocumentStoreMetrics |
|
MongoDocumentStoreThrottlingMetricsUpdater |
Mongo Document Store throttling metric updater.
|
MongoDocumentTraverser |
|
MongoMissingLastRevSeeker |
Mongo specific version of MissingLastRevSeeker which uses mongo queries
to fetch candidates which may have missed '_lastRev' updates.
|
MongoRegexPathFilterFactory |
|
MongoRegexPathFilterFactory.MongoFilterPaths |
|
MongoStatus |
|
MongoThrottlerFactory |
Factory to create Mongo Throttlers
|
MongoVersionGCSupport |
Mongo specific version of VersionGCSupport which uses mongo queries
to fetch required NodeDocuments
|
Monitor<T> |
Marker interface for monitors that are to be registered with a Whiteboard .
|
MonotonicAppendingLongBuffer |
Utility class to buffer signed longs in memory, which is optimized for the
case where the sequence is monotonic, although it can encode any sequence of
arbitrary longs.
|
MonotonicBlockPackedReader |
|
MonotonicBlockPackedWriter |
A writer for large monotonically increasing sequences of positive longs.
|
Mount |
Refers to a set of paths from a ContentRepository x that are possibly
stored in a separate physical persistent store.
|
MountedNodeStore |
|
MountedNodeStoreChecker<T> |
Applies a category of consistency checks specific to NodeStore mounts
|
MountInfo |
Default Mount implementation for non-default mounts.
|
MountInfoConfig |
|
MountInfoConfig.Props |
|
MountInfoProvider |
Holds information related to the Mount s configured in a ContentRepository .
|
MountInfoProviderService |
|
MountPermissionProvider |
|
Mounts |
|
Mounts.Builder |
|
MoveAwarePermissionValidator |
|
MoveDetector |
|
MoveFilter |
This filter implementation excludes generating add node
events for child nodes of the destination of a move operation.
|
MoveTracker |
|
MoveValidator |
A validator that also receives notifications about moved nodes.
|
MultiBinaryPropertyState |
|
MultiBooleanPropertyState |
|
MultiCollector |
|
MultiDecimalPropertyState |
|
MultiDocsAndPositionsEnum |
Exposes flex API, merged from flex API of sub-segments.
|
MultiDocsAndPositionsEnum.EnumWithSlice |
|
MultiDocsEnum |
|
MultiDocsEnum.EnumWithSlice |
|
MultiDocValues |
A wrapper for CompositeIndexReader providing access to DocValues.
|
MultiDocValues.MultiSortedDocValues |
Implements SortedDocValues over n subs, using an OrdinalMap
|
MultiDocValues.MultiSortedSetDocValues |
Implements MultiSortedSetDocValues over n subs, using an OrdinalMap
|
MultiDocValues.OrdinalMap |
maps per-segment ordinals to/from global ordinal space
|
MultiDoublePropertyState |
|
MultiFields |
Exposes flex API, merged from flex API of sub-segments.
|
MultiGenerationMap<K,V> |
|
MultiGenericPropertyState |
|
MultiLevelSkipListReader |
This abstract class reads skip lists with multiple levels.
|
MultiLevelSkipListWriter |
This abstract class writes skip lists with multiple levels.
|
MultiLongPropertyState |
|
MultiPhraseQuery |
|
MultiReader |
|
MultiSimilarity |
Implements the CombSUM method for combining evidence from multiple
similarity values described in: Joseph A.
|
MultiStringPropertyState |
|
MultiTermQuery |
An abstract Query that matches documents
containing a subset of terms provided by a FilteredTermsEnum enumeration.
|
MultiTermQuery.ConstantScoreAutoRewrite |
A rewrite method that tries to pick the best
constant-score rewrite method based on term and
document counts from the query.
|
MultiTermQuery.RewriteMethod |
Abstract class that defines how the query is rewritten.
|
MultiTermQuery.TopTermsBoostOnlyBooleanQueryRewrite |
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 |
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> |
|
MultiTerms |
Exposes flex API, merged from flex API of
sub-segments.
|
MultiTermsEnum |
|
MutableBits |
Extension of Bits for live documents.
|
MutableValue |
Base class for all mutable values.
|
MutableValueBool |
|
MutableValueDate |
|
MutableValueDouble |
|
MutableValueFloat |
|
MutableValueInt |
|
MutableValueLong |
|
MutableValueStr |
|
Name |
|
NameConstraint |
|
NamedSPILoader<S extends NamedSPILoader.NamedSPI> |
Helper class for loading named SPIs from classpath (e.g.
|
NamedSPILoader.NamedSPI |
|
NamedThreadFactory |
A default ThreadFactory implementation that accepts the name prefix
of the created threads as a constructor argument.
|
NameMapper |
TODO document
|
NamePathMapper |
The NamePathMapper interface combines NameMapper and
PathMapper .
|
NamePathMapper.Default |
Default implementation that doesn't perform any conversions for cases
where a mapper object only deals with oak internal names and paths.
|
NamePathMapperImpl |
TODO document
|
NamePathRev |
A cache key implementation, which is a combination of a name, path and a
revision vector.
|
NamespaceConstants |
Deprecated.
|
NamespaceConstants |
TODO document
|
NamespaceEditorProvider |
Validator service that checks that all node and property names as well
as any name values are syntactically valid and that any namespace prefixes
are properly registered.
|
NamespacePrefixNodestoreChecker |
|
Namespaces |
Internal static utility class for managing the persisted namespace registry.
|
NameValidatorProvider |
Validator service that checks that all node and property names as well
as any name values are syntactically valid and that any namespace prefixes
are properly registered.
|
NativeFSLockFactory |
|
NativeFunctionImpl |
A native function condition.
|
NearSpansOrdered |
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.
|
NearSpansUnordered |
|
NGramPhraseQuery |
This is a PhraseQuery which is optimized for n-gram phrase query.
|
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.
|
NIOFSDirectory.NIOFSIndexInput |
|
NodeBuilder |
|
NodeBuilderTree |
A mutable Tree implementation based on an underlying
NodeBuilder , which tracks all changes recorded through
this tree's mutator methods.
|
NodeCount |
A collector for approximate node counts.
|
NodeCounter |
Count documents and nodes that exist.
|
NodeData |
Represents a node in a stream.
|
NodeDataReader |
A reader for node data.
|
NodeDelegate |
NodeDelegate serve as internal representations of Node s.
|
NodeDocument |
A document storing data about a node.
|
NodeDocument.SplitDocType |
A document which is created from splitting a main document can be classified
into multiple types depending on the content i.e.
|
NodeDocumentCache |
Cache for the NodeDocuments.
|
NodeDocumentCodec |
Custom codec for MongoDB to transform a stream of BSON tokens into a NodeDocument.
|
NodeDocumentCodecProvider |
|
NodeDocumentFilter |
Implements a filter to decide if a given Mongo document should be processed or ignored based on its path.
|
NodeDocumentHelper |
Helper class to access package private methods on NodeDocument.
|
NodeDocumentIdComparator |
Implements a comparator, which sorts NodeDocumentId string according to 1) their
depth (highest first) and 2) the id string itself.
|
NodeDocumentLocks |
|
NodeDocumentRevisionCleaner |
This is a prototype class of a very fine-grained revision cleaner that cleans even revisions
in-between checkpoints.
|
NodeImpl<T extends NodeDelegate> |
TODO document
|
NodeInfo |
Information about a node being imported.
|
NoDeletionPolicy |
|
NodeLineReader |
A reader for flat file stores.
|
NodeLocalNameImpl |
The implementation of the corresponding JCR interface.
|
NodeLocalNameImpl |
The function "localname(..)".
|
NodeMap<T> |
|
NodeNameFilter |
A wrapper for a collector that allows to filter for certain node names, or
children of those.
|
NodeNameImpl |
The implementation of the corresponding JCR interface.
|
NodeNameImpl |
The function "name(..)".
|
NodeObserver |
Base class for Observer instances that group changes
by node instead of tracking them down to individual properties.
|
NodeOperation<U> |
|
NodeProperty |
Represents a property of a node.
|
NodeProperty.PropertyValue |
|
NodeProperty.ValueType |
|
NodeState |
A node in a content tree consists of child nodes and properties, each
of which evolves through different states during its lifecycle.
|
NodeStateCopier |
The NodeStateCopier and NodeStateCopier.Builder classes allow
recursively copying a NodeState to a NodeBuilder.
|
NodeStateCopier.Builder |
The NodeStateCopier.Builder allows configuring a NodeState copy operation with
includePaths , excludePaths and mergePaths .
|
NodeStateDiff |
Handler of node state differences.
|
NodeStateDiffer |
|
NodeStateEntry |
|
NodeStateEntry.NodeStateEntryBuilder |
|
NodeStateEntryBatch |
|
NodeStateEntryBatch.BufferFullException |
|
NodeStateEntryList |
|
NodeStateEntryReader |
|
NodeStateEntrySorter |
|
NodeStateEntryTraverser |
|
NodeStateEntryTraverserFactory |
|
NodeStateEntryWriter |
|
NodeStateExportCommand |
|
NodeStateHelper |
|
NodeStateHolder |
|
NodeStateHolder |
|
NodeStateIndexer |
|
NodeStateIndexerProvider |
|
NodeStateNodeTypeInfoProvider |
A nodetype info provider that is based on node states.
|
NodeStateSerializer |
|
NodeStateSerializer.Format |
|
NodeStateUtils |
Utility method for code that deals with node states.
|
NodeStore |
Storage abstraction for trees.
|
NodeStoreBranch |
An instance of this class represents a private branch of the tree in a
NodeStore to which transient changes can be applied and later merged
back or discarded.
|
NodeStoreChecks |
|
NodeStoreChecksService |
|
NodeStoreFixture |
|
NodeStoreFixtureProvider |
|
NodeStoreProvider |
Provides a NodeStore instance for specific role.
|
NodeStreamConverter |
Allows to convert a flat-file store to a node stream.
|
NodeStreamConverterCompressed |
Allows to to convert a flat file store to a compressed stream of nodes.
|
NodeStreamReader |
A node stream reader.
|
NodeStreamReaderCompressed |
A node stream reader with compression for repeated strings.
|
NodeTraversalCallback |
Callback which invoked for any changed node read by IndexUpdate
as part of diff traversal
|
NodeTraversalCallback.PathSource |
Provides a way to lazily construct the path
and provides access to the current path
|
NodeTypeConstants |
Deprecated.
|
NodeTypeConstants |
NodeTypeConstants...
|
NodeTypeCount |
A collector for node types.
|
NodeTypeDefDiff |
A NodeTypeDefDiff represents the result of the comparison of
two node type definitions.
|
NodeTypeDefinitionNodeStoreChecker |
Checks that nodes present in a mount are consistent with the global node type definitions
|
NodeTypeInfo |
A nodetype info mechanism.
|
NodeTypeInfoProvider |
A nodetype info mechanism.
|
NodeTypeMountedNodeStoreChecker |
|
NodeTypeMountedNodeStoreChecker.Context |
|
NodeTypeRegistry |
BuiltInNodeTypes is a utility class that registers the built-in
node types required for a JCR repository running on Oak.
|
NoLockFactory |
|
NoMergePolicy |
A MergePolicy which never returns merges to execute (hence it's
name).
|
NoMergeScheduler |
|
NonDefaultMountWriteReportingObserver |
Reports writes to non-default mounts
|
NonDefaultMountWriteReportingObserver.Config |
|
NoopStats |
|
NoOutputs |
A null FST Outputs implementation; use this if
you just want to build an FSA.
|
Normalization |
This class acts as the base class for the implementations of the term
frequency normalization methods in the DFR framework.
|
Normalization.NoNormalization |
Implementation used when there is no normalization.
|
NormalizationH1 |
Normalization model that assumes a uniform distribution of the term frequency.
|
NormalizationH2 |
Normalization model in which the term frequency is inversely related to the
length.
|
NormalizationH3 |
Dirichlet Priors normalization
|
NormalizationZ |
Pareto-Zipf Normalization
|
NormsFormat |
Encodes/decodes per-document score normalization values.
|
NoSuchDirectoryException |
This exception is thrown when you try to list a
non-existent directory.
|
NotFullTextSearchImpl |
|
NotifyingFutureTask |
A Future that accepts completion listener.
|
NotImpl |
The implementation of the corresponding JCR interface.
|
NotImpl |
A "not" condition.
|
NRTCachingDirectory |
Wraps a RAMDirectory
around any provided delegate directory, to
be used during NRT search.
|
NumericConstraint<T> |
|
NumericDocValues |
A per-document numeric value.
|
NumericDocValuesField |
Field that stores a per-document long value for scoring,
sorting or value retrieval.
|
NumericRangeFilter<T extends Number> |
A Filter that only accepts numeric values within
a specified range.
|
NumericRangeQuery<T extends Number> |
A Query that matches numeric values within a
specified range.
|
NumericTokenStream |
|
NumericTokenStream.NumericTermAttribute |
Expert: Use this attribute to get the details of the currently generated token.
|
NumericTokenStream.NumericTermAttributeImpl |
|
NumericUtils |
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 |
|
NumericUtils.LongRangeBuilder |
|
Oak |
Builder class for constructing ContentRepository instances with
a set of specified plugin components.
|
Oak.OakDefaultComponents |
|
OakEventFilter |
Extension of the JackrabbitEventFilter that exposes Oak specific
features.
|
OakEventFilterImpl |
Implements OakEventFilter which is an extension to the JackrabbitEventFilter
with features only supported by Oak.
|
OakFileDataStore |
Oak specific extension of JR2 FileDataStore which enables
provisioning the signing key via OSGi config
|
OakFixture |
|
OakFixture.MongoFixture |
|
OakHelpFormatter |
|
OakInitializer |
|
OakJcrConstants |
|
OakOSGiRepositoryFactory |
RepositoryFactory which constructs an instance of Oak repository.
|
OakRepositoryFactory |
|
OakRepositoryFixture |
|
OakServer |
|
OakServlet |
|
OakValue |
TODO: document
|
OakVersion |
Provides version information about Oak.
|
OakVersion |
Provides version information about Oak.
|
Observable |
An Observable supports attaching Observer instances for
listening to content changes.
|
ObservablePartnerMBean |
|
ObservationManagerImpl |
|
Observer |
Extension point for observing changes in an Oak repository.
|
ObserverTracker |
|
OffsetAttribute |
The start and end character offset of a Token.
|
OffsetAttributeImpl |
|
OpenAuthenticationConfiguration |
This implementation of the authentication configuration provides login
contexts that accept any credentials and doesn't validate specified
workspace name.
|
OpenAuthorizationConfiguration |
|
OpenBitSet |
An "open" BitSet implementation that allows direct access to the array of words
storing the bits.
|
OpenBitSetDISI |
|
OpenBitSetIterator |
An iterator to iterate over set bits in an OpenBitSet.
|
OpenPermissionProvider |
Permission provider implementation that grants full access everywhere.
|
OpenSecurityProvider |
Rudimentary SecurityProvider implementation that allow every subject
to authenticate and grants it full access everywhere.
|
OperationsStatsMBean |
Interface to give useful statistics for maintenance operations.
|
OperationStatsCollector |
Implementations of this can use to mark the relevant statistics.
|
Operator |
Enumeration of the JCR 2.0 query operators.
|
Operator |
The enumeration of all operators.
|
OptionBeans |
|
Options |
|
OptionsBean |
|
OptionsBeanFactory |
|
Order |
Enumeration of the JCR 2.0 query order.
|
Order |
The enumeration of query column orders (ascending and descending).
|
OrderingImpl |
The implementation of the corresponding JCR interface.
|
OrderingImpl |
An element of an "order by" list.
|
OrdTermState |
|
OrImpl |
The implementation of the corresponding JCR interface.
|
OrImpl |
An "or" condition.
|
OrphanedNodeCheck |
OrphanedNodeCheck ...
|
OsgiRepository |
Workaround to a JAAS class loading issue in OSGi environments.
|
OsgiUtil |
Utility methods to use in an OSGi environment.
|
OsgiWhiteboard |
OSGi-based whiteboard implementation.
|
OutOfBandIndexer |
|
OutOfBandIndexerBase |
|
Outputs<T> |
Represents the outputs for an FST, providing the basic
algebra required for building and traversing the FST.
|
OutputStreamDataOutput |
|
PackedDataInput |
A DataInput wrapper to read unaligned, variable-length packed
integers.
|
PackedDataOutput |
A DataOutput wrapper to write unaligned, variable-length packed
integers.
|
PackedInts |
Simplistic compression for array of unsigned long values.
|
PackedInts.Decoder |
A decoder for packed integers.
|
PackedInts.Encoder |
An encoder for packed integers.
|
PackedInts.Format |
A format to write packed ints.
|
PackedInts.FormatAndBits |
Simple class that holds a format and a number of bits per value.
|
PackedInts.Header |
Header identifying the structure of a packed integer array.
|
PackedInts.Mutable |
A packed integer array that can be modified.
|
PackedInts.NullReader |
|
PackedInts.Reader |
A read-only random access array of positive integers.
|
PackedInts.ReaderIterator |
Run-once iterator interface, to decode previously saved PackedInts.
|
PackedInts.Writer |
A write-once Writer.
|
PackedLongDocValuesField |
Deprecated.
|
PackStore |
A store where all the entries are stored in a "Pack File" (see @FilePacker).
|
PagedBytes |
Represents a logical byte[] as a series of pages.
|
PagedBytes.Reader |
Provides methods to read BytesRefs from a frozen
PagedBytes.
|
PagedGrowableWriter |
|
PagedMutable |
|
PageFile |
A B-tree page (leaf, or inner node).
|
PairOutputs<A,B> |
An FST Outputs implementation, holding two other outputs.
|
PairOutputs.Pair<A,B> |
Holds a single pair of two outputs.
|
ParallelAtomicReader |
|
ParallelCompactor |
This compactor implementation leverages the tree structure of the repository for concurrent compaction.
|
ParallelCompositeReader |
|
ParallelIndexStore |
A parallel store has the ability to "split itself" into multiple stores that
each cover a subset of the content.
|
ParallelTreeStore |
A wrapper around the tree store that only iterates over a subset of the
nodes.
|
PartialConflictHandler |
Deprecated.
|
PartialConflictHandler.Resolution |
Resolutions for conflicts
|
PartialValueFactory |
A partial value factory implementation that only deals with in-memory values
and can wrap a Value around a PropertyState .
|
PasswordChangeAction |
|
PasswordUtil |
Utility to generate and compare password hashes.
|
PasswordValidationAction |
PasswordValidationAction provides a simple password validation
mechanism with the following configurable option:
constraint: a regular expression that can be compiled
to a Pattern defining validation rules for a password.
|
Path |
The Path class is closely modeled after the semantics of
PathUtils in oak-commons.
|
PathComparator |
Implements a comparator, which sorts paths according to 1) their depth
(highest first) and 2) the paths natural ordering.
|
PathConstraint |
|
PathElementComparator |
|
PathElementComparator |
|
PathFilter |
Filter which determines whether given path should be included for processing
or not
|
PathFilter.Result |
|
PathImpl |
The function "path(..)".
|
PathIteratorFilter |
A utility class that allows skipping nodes that are not included in the index
definition.
|
PathMapper |
PathMapper instances provide methods for mapping paths from their JCR
string representation to their Oak representation and vice versa.
|
PathRev |
A cache key implementation, which is a combination of a path and a revision
vector.
|
PathTracker |
Simple utility class for lazily tracking the current path during
a tree traversal that recurses down a subtree.
|
PathUtils |
Utility methods to parse a path.
|
PayloadAttribute |
The payload of a Token.
|
PayloadAttributeImpl |
|
PayloadFunction |
An abstract class that defines a way for Payload*Query instances to transform
the cumulative effects of payload scores for a document.
|
PayloadNearQuery |
This class is very similar to
SpanNearQuery except that it factors
in the value of the payloads located at each of the positions where the
TermSpans occurs.
|
PayloadSpanUtil |
Experimental class to get set of payloads for most standard Lucene queries.
|
PayloadTermQuery |
This class is very similar to
SpanTermQuery except that it factors
in the value of the payload located at each of the positions where the
Term occurs.
|
PerFieldDocValuesFormat |
Enables per field docvalues support.
|
PerFieldPostingsFormat |
Enables per field postings support.
|
PerFieldSimilarityWrapper |
Provides the ability to use a different Similarity for different fields.
|
PerfLogger |
PerfLogger is a simpler wrapper around a slf4j Logger which
comes with the capability to issue log statements containing
the measurement between start() and end() methods.
|
PeriodicReporter |
Abstract class that simplifies development of a Reporter
that should only report every nth event (node or property seen).
|
PermissionAware |
Interface indicating that a given object (like e.g.
|
PermissionConstants |
Implementation specific constants related to permission evaluation.
|
PermissionHook |
CommitHook implementation that processes any modification made to
access control content and updates persisted permission store associated
with access control related data stored in the repository.
|
PermissionProvider |
Main entry point for permission evaluation in Oak.
|
PermissionProviderFactory |
|
PermissionProviderImpl |
|
Permissions |
Provides constants for permissions used in the OAK access evaluation as well
as permission related utility methods.
|
PermissionStoreValidatorProvider |
Validator implementation that asserts that the permission store is read-only.
|
PermissionUtil |
Utility methods to evaluate permissions.
|
PermissionValidatorProvider |
ValidatorProvider implementation for permission evaluation associated
with write operations.
|
PersistedLinkedList |
A persistent linked list that internally uses the MVStore.
|
PersistedLinkedListV2 |
A persistent linked list that internally uses the MVStore.
|
PersistentCache |
A persistent cache for the document store.
|
PersistentCache |
This interface represents a cache which survives segment store restarts.
|
PersistentCacheCommand |
|
PersistentCacheStats |
Persistence Cache Statistics.
|
PersistentCacheStatsMBean |
|
PersistentDiskCache |
|
PersistentRedisCache |
|
PersistentSnapshotDeletionPolicy |
A SnapshotDeletionPolicy which adds a persistence layer so that
snapshots can be maintained across the life of an application.
|
PForDeltaDocIdSet |
DocIdSet implementation based on pfor-delta encoding.
|
PForDeltaDocIdSet.Builder |
|
PhraseQuery |
A Query that matches documents containing a particular sequence of terms.
|
PipelinedMergeSortTask |
Accumulates the intermediate sorted files and, when all files are generated, merges them into a single sorted file,
the flat file store
|
PipelinedMergeSortTask.Result |
|
PipelinedMetrics |
|
PipelinedMongoDownloadTask |
|
PipelinedMongoDownloadTask.Result |
|
PipelinedMongoServerSelector |
Selects a Mongo server that is available for a new connection.
|
PipelinedStrategy |
Downloads the contents of the MongoDB repository dividing the tasks in a pipeline with the following stages:
Download - Downloads from Mongo all the documents in the node store.
|
PipelinedTreeStoreStrategy |
Downloads the contents of the MongoDB repository dividing the tasks in a pipeline with the following stages:
Download - Downloads from Mongo all the documents in the node store.
|
PipelinedTreeStoreTask |
Receives batches of node state entries, sorts then in memory, and finally writes them to a tree store.
|
PipelinedUtils |
|
PolicyOwner |
Interface to improve pluggability of the AccessControlManager ,
namely the interaction of multiple managers within a
single repository.
|
PoolableUnboundConnectionFactory |
A factory for creating unbound LdapConnection objects managed by LdapConnectionPool.
|
Position |
A position of an entry in a page file.
|
PositionIncrementAttribute |
Determines the position of this token
relative to the previous Token in a TokenStream, used in phrase
searching.
|
PositionIncrementAttributeImpl |
|
PositionLengthAttribute |
Determines how many positions this
token spans.
|
PositionLengthAttributeImpl |
|
PositiveIntOutputs |
An FST Outputs implementation where each output
is a non-negative long value.
|
PositiveScoresOnlyCollector |
A Collector implementation which wraps another
Collector and makes sure only documents with
scores > 0 are collected.
|
PostingsBaseFormat |
|
PostingsConsumer |
Abstract API that consumes postings for an individual term.
|
PostingsFormat |
Encodes/decodes terms, postings, and proximity data.
|
PostingsReaderBase |
The core terms dictionaries (BlockTermsReader,
BlockTreeTermsReader) interact with a single instance
of this class to manage creation of DocsEnum and
DocsAndPositionsEnum instances.
|
PostingsWriterBase |
|
PostValidationHook |
Extension to the CommitHook interface that indicates that this
commit hook implementation must be executed after the
validation hooks.
|
PreAuthContext |
LoginContext for pre-authenticated subjects that don't require further
validation nor additional login/logout steps.
|
PreAuthenticatedLogin |
PreAuthenticatedLogin is used as marker in the shared map of the login context.
|
PredefinedAuthorizationConfiguration |
|
Prefetcher |
The prefetcher, in a separate threads, reads ahead of indexing, such that the
nodestore cache and datastore cache is filled.
|
PrefetchIterator<K> |
An iterator that pre-fetches a number of items in order to calculate the size
of the result if possible.
|
PrefetchIterator.PrefetchOptions |
The options to use for prefetching.
|
PrefetchNodeStore |
Experimental NodeStore extension that allows prefetching of node
states given a collection of paths.
|
PrefixFilter |
A Filter that restricts search results to values that have a matching prefix in a given
field.
|
PrefixQuery |
A Query that matches documents containing terms with a specified prefix.
|
PrefixTermsEnum |
Subclass of FilteredTermEnum for enumerating all terms that match the
specified prefix filter term.
|
PrincipalAccessControlList |
Extension of the JackrabbitAccessControlList that is bound to a Principal .
|
PrincipalAccessControlList.Entry |
|
PrincipalBasedAuthorizationConfiguration |
|
PrincipalConfiguration |
Configuration interface for principal management.
|
PrincipalConfigurationImpl |
Default implementation of the PrincipalConfiguration
|
PrincipalImpl |
Default implementation of the JackrabbitPrincipal interface.
|
PrincipalIterator |
|
PrincipalIteratorAdapter |
Principal specific RangeIteratorAdapter implementing the
PrincipalIterator interface.
|
PrincipalManager |
This interface defines the principal manager which is the clients view on all
principals known to the repository.
|
PrincipalManagerDelegator |
This implementation of PrincipalManager delegates back to a
delegatee wrapping each call into a SessionOperation closure.
|
PrincipalManagerImpl |
Default implementation of the PrincipalManager interface.
|
PrincipalNameResolver |
|
PrincipalProvider |
The PrincipalProvider defines methods to provide access to sources
of Principal s.
|
PrincipalProviderCallback |
|
PrincipalQueryManager |
Extension for the PrincipalManager that offers range search.
|
PrincipalRestrictionProvider |
Restriction provider implementation used for editing access control by
principal.
|
PrincipalSetPolicy |
Extension of the JCR AccessControlPolicy
intended to grant a set of Principal s the ability to perform certain
actions.
|
PrintStreamInfoStream |
InfoStream implementation over a PrintStream
such as System.out .
|
PriorityCache<K,V> |
PriorityCache implements a partial mapping from keys of type K to values
of type V .
|
PriorityQueue<T> |
A PriorityQueue maintains a partial ordering of its elements such that the
least element can always be found in constant time.
|
PrivateStoreValidatorProvider |
Validator which detects change commits to the read only mounts.
|
PrivilegeBits |
Internal representation of JCR privileges.
|
PrivilegeBitsProvider |
Allows to obtain the internal representation of privileges (or their names) and to covert the
internal representation back to privilege names.
|
PrivilegeCollection |
Wrapper around a set of Privilege s that allows to test if a given list of privilege names in included.
|
PrivilegeCollection.Default |
|
PrivilegeConfiguration |
Interface for the privilege management configuration.
|
PrivilegeConfigurationImpl |
Configuration for the privilege management component.
|
PrivilegeConstants |
Internal name constants used for the privilege management.
|
PrivilegeDefinition |
The PrivilegeDefinition interface defines the characteristics of
a JCR Privilege .
|
PrivilegeManager |
PrivilegeManager is a jackrabbit specific extensions to
JCR access control management that allows to retrieve privileges known
by this JCR implementation and to register new custom privileges according
to implementation specific rules.
|
PrivilegeManagerDelegator |
This implementation of PrivilegeManager delegates back to a
delegatee wrapping each call into a SessionOperation closure.
|
PrivilegeUtil |
Privilege management related utility methods.
|
Proc |
|
Proc.Backend |
|
Proc.Backend.Commit |
|
Proc.Backend.Record |
|
Proc.Backend.Segment |
|
Profiler |
A simple CPU profiling tool similar to java -Xrunhprof.
|
Progress |
Progress ...
|
ProgressNotificationEditor |
This Editor instance logs invocations to the logger
passed to its constructor after each 10000 calls to it
enter() method.
|
ProgressWithETA |
ProgressWithETA ...
|
PropertiesUtil |
The PropertiesUtil is a utility class providing some
useful utility methods for converting property types.
|
PropertyBuilder<T> |
PropertyBuilder for building in memory PropertyState instances.
|
PropertyDelegate |
PropertyDelegate serve as internal representations of Property s.
|
PropertyExistenceImpl |
The implementation of the corresponding JCR interface.
|
PropertyExistenceImpl |
A condition to check if the property exists ("is not null").
|
PropertyImpl |
TODO document
|
PropertyInexistenceImpl |
A condition to check if the property does not exist ("is null").
|
PropertyOperation<U> |
|
PropertyPredicate |
Predicate on property values.
|
PropertyState |
Immutable property state.
|
PropertyStates |
|
PropertyStateValue |
|
PropertyStats |
Property statistics.
|
PropertyTemplate |
A property definition within a template (the property name, the type, and the
index within the list of properties for the given node).
|
PropertyValue |
Immutable property value.
|
PropertyValueImpl |
The implementation of the corresponding JCR interface.
|
PropertyValueImpl |
A property expression.
|
PropertyValues |
|
PropInfo |
Information about a property being imported.
|
PropInfo.MultipleStatus |
Hint indicating whether the property is multi- or single-value
|
ProtectedItemImporter |
|
ProtectedNodeImporter |
ProtectedNodeImporter provides means to import protected
Node s and the subtree defined below such nodes.
|
ProtectedPropertyImporter |
ProtectedPropertyImporter is in charge of importing single
properties with a protected PropertyDefinition .
|
ProtectionConfig |
Interface to mark properties or nodes located underneath a synchronized external identity as being protected (i.e.
|
ProtectionConfigImpl |
|
ProviderCtx |
|
ProxyNodeStore |
|
PurgeOldIndexVersion |
|
PurgeOldIndexVersionCommand |
|
PurgeOldVersionUtils |
|
Query |
|
Query |
A "select" or "union" query.
|
Query |
The abstract base class for queries.
|
QueryBuilder<T> |
|
QueryBuilder |
Creates queries from the Analyzer chain.
|
QueryBuilder.Direction |
The sort order of the result set of a query.
|
QueryConstants |
|
QueryEngine |
The query engine allows to parse and execute queries.
|
QueryEngineImpl |
The query engine implementation.
|
QueryEngineImpl.QuerySelectionMode |
Used to instruct the QueryEngineImpl on how to act with respect of the SQL2
optimisation.
|
QueryEngineSettings |
Settings of the query engine.
|
QueryEngineSettingsMBean |
|
QueryEngineSettingsService |
|
QueryFormatter |
Formatter for JCR queries in order to make them easier to read.
|
QueryImpl |
The implementation of the corresponding JCR interface.
|
QueryImpl |
Represents a parsed query.
|
QueryIndex |
Represents an index.
|
QueryIndex.AdvancedQueryIndex |
A query index that may support using multiple access orders
(returning the rows in a specific order), and that can provide detailed
information about the cost.
|
QueryIndex.AdvanceFulltextQueryIndex |
|
QueryIndex.FulltextQueryIndex |
A marker interface which means this index supports may support more than
just the minimal fulltext query syntax.
|
QueryIndex.IndexPlan |
An index plan.
|
QueryIndex.IndexPlan.Builder |
A builder for index plans.
|
QueryIndex.NativeQueryIndex |
A marker interface which means this index supports executing native queries
|
QueryIndex.NodeAggregator |
|
QueryIndex.OrderEntry |
A sort order entry.
|
QueryIndex.OrderEntry.Order |
The sort order (ascending or descending).
|
QueryIndexProvider |
A mechanism to index data.
|
QueryIndexProviderAware |
Marker interface for services that need a QueryIndexProvider
|
QueryLimits |
|
QueryManagerImpl |
The implementation of the corresponding JCR interface.
|
QueryObjectModelFactoryImpl |
The implementation of the corresponding JCR interface.
|
QueryObjectModelImpl |
The implementation of the corresponding JCR interface.
|
QueryOptions |
A query options (or "hints") that are used to customize the way the query is processed.
|
QueryOptions.AutomaticQueryOptionsMapping |
|
QueryOptions.Traversal |
|
QueryParser |
Query parser interface.
|
QueryRecorder |
|
QueryResultImpl |
The implementation of the corresponding JCR interface.
|
QueryStat |
Statistics on query operations
|
QueryStatDto |
Object that holds statistical info about a query.
|
QueryStatManagerMBean |
|
QueryStatsData |
|
QueryStatsMBean |
|
QueryStatsMBeanImpl |
|
QueryStatsReporter |
|
QueryUtil |
Common utilities used for user/group queries.
|
QueryUtils |
|
QueryValidator |
A validator for query.
|
QueryWrapperFilter |
Constrains search results to only match those which also match a provided
query.
|
Railroad |
JCR 2.0 / SQL-2 railroad generator.
|
RailroadMacro |
RailroadMacro macro that prints out the content of a file or a URL.
|
RAMDirectory |
|
RAMFile |
Represents a file in RAM as a list of byte[] buffers.
|
RAMInputStream |
|
RAMOutputStream |
|
RamUsageEstimator |
Estimates the size (memory representation) of Java objects.
|
RamUsageEstimator.JvmFeature |
JVM diagnostic features.
|
RandomAccessTrace |
A random access trace
|
RandomAuthorizableNodeName |
Implementation of the AuthorizableNodeName that generates a random
node name that doesn't reveal the ID of the authorizable.
|
RateLimitedDirectoryWrapper |
|
RateLimiter |
Abstract base class to rate limit IO.
|
RateLimiter.SimpleRateLimiter |
Simple class to rate limit IO.
|
RateLimitUtils |
|
RDBBlobReferenceIterator |
|
RDBBlobStore |
|
RDBBlobStoreDB |
Defines variation in the capabilities of different RDBs.
|
RDBCommonVendorSpecificCode |
|
RDBConnectionHandler |
Utility functions for connection handling.
|
RDBCreator |
|
RDBDataSourceFactory |
Factory for creating DataSource s based on a JDBC connection URL.
|
RDBDDLDumpCommand |
|
RDBDocumentNodeStoreBuilder |
|
RDBDocumentSerializer |
Serialization/Parsing of documents.
|
RDBDocumentStore |
|
RDBDocumentStore.QueryCondition |
|
RDBDocumentStoreDB |
Defines variation in the capabilities of different RDBs.
|
RDBDocumentStoreDB.FETCHFIRSTSYNTAX |
|
RDBDocumentStoreJDBC |
|
RDBExport |
|
RDBHelper |
Convenience class that dumps the table creation statements for various
database types.
|
RDBJDBCTools |
Convenience methods dealing with JDBC specifics.
|
RDBJDBCTools.PreparedStatementComponent |
Provides a component for a PreparedStatement and a method for
setting the parameters within this component
|
RDBJSONSupport |
Utilities that provide JSON support on top of the existing
JsopTokenizer support in oak-commons.
|
RDBMissingLastRevSeeker |
RDB specific version of MissingLastRevSeeker.
|
RDBOptions |
Options applicable to RDB persistence
|
RDBRow |
Container for the information in a RDB database column.
|
RDBStoreOptions |
|
RDBVersionGCSupport |
|
Reader |
|
ReaderAtEnd |
Read raw data from the end of an underlying data source.
|
ReaderCache<T> |
A cache consisting of a fast and slow component.
|
ReaderManager |
Utility class to safely share DirectoryReader instances across
multiple threads, while periodically reopening.
|
ReaderSlice |
Subreader slice from a parent composite reader.
|
ReaderUtil |
|
ReadOnly |
Marker interface to indicate if a Tree or Root
can only be read (write operations not implemented).
|
ReadOnlyAuthorizationConfiguration |
Read Only Authorization Model
|
ReadOnlyBuilder |
|
ReadOnlyDocumentStoreWrapperFactory |
|
ReadOnlyFileStore |
A read only AbstractFileStore implementation that supports going back
to old revisions.
|
ReadOnlyNamespaceRegistry |
Read-only namespace registry.
|
ReadOnlyNodeTypeManager |
|
ReadOnlyRevisions |
|
ReadOnlyVersionManager |
ReadOnlyVersionManager provides implementations for read-only
version operations modeled after the ones available in VersionManager .
|
ReadPolicy |
|
ReadWriteNamespaceRegistry |
Writable namespace registry.
|
ReadWriteNodeTypeManager |
|
ReadWriteVersionManager |
ReadWriteVersionManager ...
|
ReadWriteVersionManager |
|
ReadyOnlyBuilderException |
Indicates that a modification operation was tried to execute on a read-only builder.
|
RecordCache<K> |
Partial mapping of keys of type K to values of type RecordId .
|
RecordCacheStats |
|
RecordId |
The record id.
|
RecordIdData |
|
RecordIdSet |
|
RecordNumbers |
A table to translate record numbers to offsets.
|
RecordNumbers.Entry |
Represents an entry in the record table.
|
RecordType |
The type of a record in a segment.
|
RecordUsageAnalyser |
This utility breaks down space usage per record type.
|
RecoverJournal |
|
RecoverJournal.Builder |
|
RecyclingByteBlockAllocator |
|
RecyclingIntBlockAllocator |
|
RedisCacheIOMonitor |
|
RefCount<T> |
Manages reference counting for a given object.
|
ReferenceBinary |
Referenceable binary.
|
ReferenceBinaryException |
|
ReferenceChangeTracker |
Helper class used to keep track of uuid mappings (e.g.
|
ReferenceCheck |
Checks if jcr:baseVersion reference properties resolve to a node.
|
ReferenceCollector |
Callback interface for collecting all blob references that are
potentially accessible.
|
ReferenceConstraint |
|
ReferencedBlob |
Exposes the blob along with the Node id from which referenced
|
ReferenceManager<G> |
Utility class to safely share instances of a certain type across multiple
threads, while periodically refreshing them.
|
ReferenceManager.RefreshListener |
Use to receive notification when a refresh has
finished.
|
RefreshStrategy |
Implementations of this interface determine whether a session needs
to be refreshed before the next session operation is performed.
|
RefreshStrategy.Composite |
Composite of zero or more RefreshStrategy instances,
each of which covers a certain strategy.
|
RefreshStrategy.Timed |
This refresh strategy refreshes after a given timeout of inactivity.
|
RegExp |
Regular Expression extension to Automaton .
|
RegexpQuery |
|
Registration |
Whiteboard service registration.
|
RegistrationConstants |
Holds the names of well-known registration properties for security-related components
|
RelativePathSelector |
A selector for selecting a node at a relative path from the node selected by
an initial selector.
|
RemoteBlobMetadata |
|
RemotePersistentCacheService |
|
RemoteSegmentArchiveEntry |
|
RemoteStoreMonitor |
|
RemoteStoreMonitorAdapter |
|
RemoteUtilities |
|
RemotingInitializer |
Configures the Webdav and Davex servlet to enabled remote
access to the repository
|
RemoveMetricUpdater |
|
ReplicaSetStatus |
Keeps track of the status of a replica set based on information provided
by heartbeat events.
|
Reporter |
A Reporter receives callbacks for every NodeState
and PropertyState that was accessed via a {ReportingNodeState}
instance.
|
ReportingNodeState |
A decoration layer for NodeState instances that intercepts
all accesses to NodeStates and PropertyStates (getters) and
informs a Reporter via its callbacks that the respective
NodeStates or PropertyStates have been accessed.
|
RepositoryAccessServlet |
This Class implements a servlet that is used as unified mechanism to retrieve
a jcr repository either through JNDI.
|
RepositoryCallback |
Callback implementation used to access the repository.
|
RepositoryFixture |
|
RepositoryImpl |
TODO document
|
RepositoryInitializer |
Initializer of repository content.
|
RepositoryInitializer |
|
RepositoryLock |
This type represents the lock that has been already acquired on the segment
store.
|
RepositoryManagementMBean |
This interface exposes repository management operations and the status
of such operations.
|
RepositoryManagementMBean.StatusCode |
Enum whose ordinals correspond to the status codes.
|
RepositoryManager |
The repository manager provides life-cycle management features for
repositories.
|
RepositoryManager |
RepositoryManager constructs the Repository instance and registers it with OSGi Service Registry.
|
RepositoryManager |
|
RepositoryNotReachableException |
This exception is thrown when the store cannot be accessed (e.g.
|
RepositoryPermission |
The RepositoryPermission allows to evaluate permissions that have
been defined on the repository level and which consequently are not bound
to a particular item.
|
RepositoryStartupServlet |
The RepositoryStartupServlet starts a jackrabbit repository and registers it
to the JNDI environment.
|
RepositoryStatistics |
Statistics on core repository operations
|
RepositoryStatistics.Type |
|
RepositoryStats |
|
RepositoryStatsMBean |
MBean for providing repository wide statistics.
|
Representation |
|
RequestDecoder |
|
ResetCommitAttributeHook |
|
ResponseDecoder |
|
Restore |
Restore a backup of a segment store into an existing segment store.
|
Restore.Builder |
Collect options for the Restore command.
|
Restriction |
A Restriction object represents a "live" restriction object that
has been created using the Jackrabbit specific extensions of the
AccessControlEntry interface.
|
RestrictionDefinition |
The RestrictionDefinition interface provides methods for
discovering the static definition of any additional policy-internal refinements
of the access control definitions.
|
RestrictionDefinitionImpl |
|
RestrictionImpl |
RestrictionImpl
|
RestrictionPattern |
Interface used to verify if a given restriction applies to a given
item or path.
|
RestrictionProvider |
Interface to manage the supported restrictions present with a given access
control and permission management implementation.
|
RestrictionProviderImpl |
|
Result |
A result from executing a query.
|
Result |
Result ...
|
Result.SizePrecision |
|
ResultImpl |
A query result.
|
ResultIterator<T> |
Implements a query result iterator which only returns a maximum number of
element from an underlying iterator starting at a given offset.
|
ResultRow |
A query result row.
|
ResultRowImpl |
A query result row that keeps all data (for this row only) in memory.
|
ResultWriter |
ResultWriter ...
|
Retrier |
|
Retrier.ThrowingRunnable |
|
Retrier.ThrowingSupplier<T> |
|
ReverseFileReader |
|
ReverseNodeStateDiff |
Implementation of a NodeStateDiff that reports the inverse operation
to the wrapped NodeStateDiff .
|
Revision |
A revision.
|
RevisionContext |
Provides revision related context.
|
RevisionContextWrapper |
Wraps an existing revision context and exposes a custom clusterId .
|
RevisionEntry |
A light-weight implementation of a MongoDB DBObject for a single revision
based map entry.
|
RevisionGC |
|
RevisionGCMBean |
MBean for starting and monitoring the progress of
revision garbage collection.
|
RevisionGCStatsCollector |
Collector interface for DocumentNodeStore revision garbage collection
statistics.
|
RevisionGCStatsMBean |
MBean exposing DocumentNodeStore revision garbage collection statistics.
|
RevisionHistory |
Utility for tracing a node back through the revision history.
|
RevisionHistory.HistoryElement |
Representation of a point in time for a given node.
|
Revisions |
Revisions instances provide read and write access to
the current head state.
|
Revisions |
Collect and print the revisions of a segment store.
|
Revisions.Builder |
|
Revisions.Option |
Implementation specific options for the setHead methods.
|
Revisions.RevisionsProcessor |
|
RevisionsCommand |
Gives information about current node revisions state.
|
RevisionsKey |
A cache key implementation which consists of two Revision s.
|
RevisionVector |
A vector of revisions.
|
RoleStatisticsProvider |
|
RollingBuffer<T extends RollingBuffer.Resettable> |
Acts like forever growing T[], but internally uses a
circular buffer to reuse instances of T.
|
RollingBuffer.Resettable |
Implement to reset an instance
|
Root |
A Root instance serves as a container for a Tree .
|
RootFactory |
Deprecated.
|
RootProvider |
|
RootProviderService |
|
RowImpl |
The implementation of the corresponding JCR interface.
|
RunAutomaton |
Finite-state automaton with fast run operation.
|
RunnableJobTracker |
|
RuntimeNodeTraversalException |
The exception thrown when traversing too many entries in the result.
|
S3Backend |
A data store backend that stores data on Amazon S3.
|
S3Constants |
Defined Amazon S3 constants.
|
S3DataStore |
|
S3DataStoreService |
|
S3DataStoreStatsMBean |
MBean for JMX statistics pertaining to an S3DataStore.
|
S3Directory |
|
S3RequestDecorator |
This class to sets encrption mode in S3 request.
|
SafeEncode |
|
SameNodeImpl |
The implementation of the corresponding JCR interface.
|
SameNodeImpl |
The function "issamenode(..)".
|
SameNodeJoinConditionImpl |
The implementation of the corresponding JCR interface.
|
SameNodeJoinConditionImpl |
The "issamenode(...)" join condition.
|
Scheduler |
A simple scheduler for executing and scheduling tasks in the background.
|
Scheduler |
A Scheduler instance transforms changes to the content tree
into a queue of commits .
|
Scheduler.SchedulerOption |
Scheduling options for parametrizing individual commits.
|
ScoreCachingWrappingScorer |
A Scorer which wraps another scorer and caches the score of the
current document.
|
ScoreDoc |
|
Scorer |
Expert: Common scoring functionality for different types of queries.
|
Scorer.ChildScorer |
A child Scorer and its relationship to its parent.
|
ScoringRewrite<Q extends Query> |
Base rewrite method that translates each term into a query, and keeps
the scores as computed by the query.
|
SearcherFactory |
|
SearcherLifetimeManager |
Keeps track of current plus old IndexSearchers, closing
the old ones once they have timed out.
|
SearcherLifetimeManager.PruneByAge |
Simple pruner that drops any searcher older by
more than the specified seconds, than the newest
searcher.
|
SearcherLifetimeManager.Pruner |
|
SearcherManager |
Utility class to safely share IndexSearcher instances across multiple
threads, while periodically reopening.
|
SearchNodes |
|
SearchNodes.Builder |
|
SearchNodes.Output |
|
SecondaryStoreBuilder |
|
SecondaryStoreCache |
|
SecondaryStoreCacheService |
|
SecondaryStoreObserver |
|
SecurityConfiguration |
Base interface for all security related configurations.
|
SecurityConfiguration.Default |
Default implementation that provides empty initializers, validators,
commit hooks and parameters.
|
SecurityProvider |
Main entry point for security related plugins to an Oak repository.
|
SecurityProviderBuilder |
|
SecurityProviderCallback |
|
SecurityProviderImpl |
Deprecated.
|
SecurityProviderRegistration |
|
Segment |
A list of records.
|
Segment.RecordConsumer |
A consumer of record data.
|
SegmentArchiveEntry |
Represents a single entry (segment) in the segment archive.
|
SegmentArchiveManager |
SegmentArchiveManager provides a low-level access to the segment files (eg.
|
SegmentArchiveReader |
This interface represents a read-only segment archive.
|
SegmentArchiveWriter |
Represents a write-enabled, append-only archive.
|
SegmentBlob |
A BLOB (stream of bytes).
|
SegmentBlobReferenceRetriever |
|
SegmentBufferMonitor |
|
SegmentBufferWriter |
This class encapsulates the state of a segment being written.
|
SegmentBufferWriterPool |
This WriteOperationHandler uses a pool of SegmentBufferWriter s,
which it passes to its execute method.
|
SegmentBufferWriterPool.PoolType |
|
SegmentBufferWriterPool.SegmentBufferWriterPoolFactory |
|
SegmentCache |
|
SegmentCacheStats |
|
SegmentCheckpointMBean |
CheckpointMBean implementation for the SegmentNodeStore .
|
SegmentCommitInfo |
Embeds a [read-only] SegmentInfo and adds per-commit
fields.
|
SegmentCopy |
Perform a full-copy of repository data at segment level.
|
SegmentCopy.Builder |
|
SegmentData |
Access the data of a segment.
|
SegmentGCOptions |
This class holds configuration options for segment store revision gc.
|
SegmentGCOptions.CompactorType |
The compactor type
|
SegmentGCOptions.GCType |
The gc type.
|
SegmentGCStatus |
|
SegmentId |
Segment identifier.
|
SegmentIdFactory |
A factory for SegmentId given their representation in MSB/LSB longs.
|
SegmentIdProvider |
Instances of this class provides SegmentId instances of a given
SegmentStore and creates new SegmentId instances on the fly
if required.
|
SegmentIdTable |
Hash table of weak references to segment identifiers.
|
SegmentInfo |
Information about a segment such as it's name, directory, and files related
to the segment.
|
SegmentInfoFormat |
Expert: Controls the format of the
SegmentInfo (segment metadata file).
|
SegmentInfoReader |
Specifies an API for classes that can read SegmentInfo information.
|
SegmentInfos |
A collection of segmentInfo objects with methods for operating on
those segments in relation to the file system.
|
SegmentInfos.FindSegmentsFile |
Utility class for executing code that needs to do
something with the current segments file.
|
SegmentInfoWriter |
Specifies an API for classes that can write out SegmentInfo data.
|
SegmentNodeBuilder |
A node builder that keeps track of the number of updates
(set property calls and so on).
|
SegmentNodeState |
A record of type "NODE".
|
SegmentNodeStateHelper |
|
SegmentNodeStore |
The top level class for the segment store.
|
SegmentNodeStore.SegmentNodeStoreBuilder |
|
SegmentNodeStoreBuilders |
|
SegmentNodeStoreFactory |
A factory allowing creation of secondary segment node stores.
|
SegmentNodeStoreMonitor |
SegmentNodeStoreMonitor is notified for commit related operations performed by SegmentNodeStore.
|
SegmentNodeStoreMonitorService |
An OSGi wrapper for segment node store monitoring configurations.
|
SegmentNodeStorePersistence |
This type is a main entry point for the segment node store persistence.
|
SegmentNodeStoreService |
An OSGi wrapper for the segment node store.
|
SegmentNodeStoreServiceDeprecationError |
This component is activated when a configuration for the deprecated
SegmentNodeStoreService from oak-segment is detected.
|
SegmentNodeStoreStats |
|
SegmentNodeStoreStatsMBean |
|
SegmentNotFoundException |
This exception is thrown when there the segment does not exist in the store
|
SegmentNotFoundExceptionListener |
Listener for SegmentNotFoundException .
|
SegmentOverflowException |
This exception is thrown by the Segment NodeStore when an internal
limit is exceeded such as too many segment references.
|
SegmentParser |
SegmentParser serves as a base class for parsing segments.
|
SegmentParser.BlobInfo |
|
SegmentParser.BlobType |
Type of blobs (and strings)
|
SegmentParser.ListBucketInfo |
|
SegmentParser.ListInfo |
|
SegmentParser.MapInfo |
|
SegmentParser.NodeInfo |
|
SegmentParser.PropertyInfo |
|
SegmentParser.TemplateInfo |
|
SegmentParser.ValueInfo |
|
SegmentPropertyIndexEditorProvider |
Editor implementation which stores the property index NodeState data in a different
SegmentNodeStore used solely for property index storage purpose
|
SegmentPropertyState |
A property, which can read a value or list record from a segment.
|
SegmentReader |
Instances of SegmentReader are responsible for reading records from segments.
|
SegmentReader |
IndexReader implementation over a single segment.
|
SegmentReader.CoreClosedListener |
Called when the shared core for this SegmentReader
is closed.
|
SegmentReadState |
Holder class for common parameters used during read.
|
SegmentReferences |
Represents a list of segment IDs referenced from a segment.
|
SegmentRevisionGC |
|
SegmentRevisionGCMBean |
|
SegmentStore |
The backend storage interface used by the segment node store.
|
SegmentStoreMigrator |
|
SegmentStoreMigrator.Builder |
|
SegmentStoreProvider |
|
SegmentStream |
For reading any record of type "VALUE" as binary streams.
|
SegmentTarFixture |
|
SegmentTarManager |
|
SegmentTarReader |
|
SegmentTarWriter |
|
SegmentTracker |
Tracker of references to segment identifiers and segment instances
that are currently kept in memory and factory for creating SegmentId
instances.
|
SegmentVersion |
Version of the segment storage format.
|
SegmentWriteAction |
|
SegmentWriteQueue |
|
SegmentWriteQueue.SegmentConsumeException |
|
SegmentWriteQueue.SegmentConsumer |
|
SegmentWriter |
Converts nodes, properties, values, etc.
|
SegmentWriterFactory |
|
SegmentWriteState |
Holder class for common parameters used during write.
|
SelectorExecutionPlan |
An execution plan for one selector in a query.
|
SelectorImpl |
The implementation of the corresponding JCR interface.
|
SelectorImpl |
A selector within a query.
|
Selectors |
Common Selector implementations
|
SentinelIntSet |
A native int hash-based set where one value is reserved to mean "EMPTY" internally.
|
SerialMergeScheduler |
A MergeScheduler that simply does each merge
sequentially, using the current thread.
|
ServiceRegistryProvider |
Provides access to the underlying ServiceRegistry.
|
ServletExceptionWithCause |
Utility class that links ServletException with support for
the exception chaining mechanism in Throwable .
|
SessionContext |
Instances of this class are passed to all JCR implementation classes
(e.g.
|
SessionDelegate |
TODO document
|
SessionImpl |
TODO document
|
SessionMBean |
MBean providing basic Session information and statistics.
|
SessionNamespaces |
SessionNamespaces implements namespace handling on the JCR
Session level.
|
SessionOperation<T> |
A SessionOperation provides an execution context for executing session scoped operations.
|
SessionQuerySettings |
User-specific settings which may be passed by the query engine to index providers during query planning and iteration
of results.
|
SessionQuerySettingsProvider |
|
SessionQuerySettingsProviderService |
Overrides oak.fastQuerySize system property when available.
|
SessionQuerySettingsProviderService.Configuration |
|
SessionStats |
|
SessionStats.Counters |
|
SetOnce<T> |
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.AlreadySetException |
|
SharedBackend |
|
SharedDataStore |
Interface to be implemented by a shared data store.
|
SharedDataStore.Type |
Explicitly identifies the type of the data store
|
SharedDataStoreUtils |
|
SharedDataStoreUtils.SharedStoreRecordType |
Encapsulates the different type of records at the data store root.
|
SharedS3DataStoreService |
|
ShortDocValuesField |
Deprecated.
|
SieveCache<K,V extends MemoryObject> |
A Sieve cache.
|
SimilarImpl |
Support for "similar(...)
|
Similarity |
Similarity defines the components of Lucene scoring.
|
Similarity.SimScorer |
|
Similarity.SimWeight |
Stores the weight for a query across the indexed collection.
|
SimilarityBase |
A subclass of Similarity that provides a simplified API for its
descendants.
|
SimpleCommitContext |
|
SimpleCredentialsSupport |
|
SimpleFlatFileUtil |
This util class can be used to export a tree (eg entire repository) to a flat
file, without index dependency/involvement.
|
SimpleFSDirectory |
A straightforward implementation of FSDirectory
using java.io.RandomAccessFile.
|
SimpleFSDirectory.SimpleFSIndexInput |
|
SimpleFSLockFactory |
|
SimpleIndexEntry |
|
SimpleMergedSegmentWarmer |
A very simple merged segment warmer that just ensures
data structures are initialized.
|
SimpleNodeStateHolder |
|
SimpleStats |
|
SimpleStats.Type |
|
SimpleWebdavServlet |
WebdavServlet provides webdav support (level 1 and 2 complient) for repository
resources.
|
SingleInstanceLockFactory |
Implements LockFactory for a single in-process instance,
meaning all locking will take place through this one instance.
|
SingleTermsEnum |
Subclass of FilteredTermsEnum for enumerating a single term.
|
SingletonSortedSetDocValues |
Exposes multi-valued view over a single-valued instance.
|
SloppyMath |
Math functions that trade off accuracy for speed.
|
SlowCompositeReaderWrapper |
|
SlowStore |
A wrapper store to simulate a slow backend store.
|
SmallFloat |
Floating point numbers smaller than 32 bits.
|
SnapshotDeletionPolicy |
|
Sort |
Encapsulates sort criteria for returned hits.
|
SortedBytesDocValuesField |
Deprecated.
|
SortedDocValues |
A per-document byte[] with presorted values.
|
SortedDocValuesField |
Field that stores
a per-document BytesRef value, indexed for
sorting.
|
SortedSetDocValues |
A per-document set of presorted byte[] values.
|
SortedSetDocValuesField |
Field that stores
a set of per-document BytesRef values, indexed for
faceting,grouping,joining.
|
SortedStream |
A helper class to iterate over key-value pairs in a tree store, in ascending
key order.
|
Sorter |
Base class for sorting algorithms implementations.
|
SortField |
Stores information about how to sort documents by terms in an individual
field.
|
SortField.Type |
Specifies the type of the terms to be sorted, or special types such as CUSTOM
|
SortKey |
|
SortKeyPath |
|
SortStrategy |
Deprecated.
|
SourceImpl |
The base class for sources.
|
SourceImpl |
The base class of a selector and a join.
|
SpanFirstQuery |
Matches spans near the beginning of a field.
|
SpanMultiTermQueryWrapper<Q extends MultiTermQuery> |
|
SpanMultiTermQueryWrapper.SpanRewriteMethod |
Abstract class that defines how the query is rewritten.
|
SpanMultiTermQueryWrapper.TopTermsSpanBooleanQueryRewrite |
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.
|
SpanNearPayloadCheckQuery |
Only return those matches that have a specific payload at
the given position.
|
SpanNearQuery |
Matches spans which are near one another.
|
SpanNotQuery |
Removes matches which overlap with another SpanQuery or
within a x tokens before or y tokens after another SpanQuery.
|
SpanOrQuery |
Matches the union of its clauses.
|
SpanPayloadCheckQuery |
Only return those matches that have a specific payload at
the given position.
|
SpanPositionCheckQuery |
Base class for filtering a SpanQuery based on the position of a match.
|
SpanPositionCheckQuery.AcceptStatus |
|
SpanPositionRangeQuery |
|
SpanQuery |
Base class for span-based queries.
|
Spans |
Expert: an enumeration of span matches.
|
SpanScorer |
Public for extension only.
|
SpanTermQuery |
Matches spans containing a term.
|
SpanWeight |
Expert-only.
|
SpecialOperations |
Special automata operations.
|
SpellcheckImpl |
Support for "spellcheck(...)
|
SPIClassIterator<S> |
Helper class for loading SPI classes from classpath (META-INF files).
|
SplitBlobStore |
|
SplitBlobStoreService |
|
SplitDocumentCleanUp |
Implements a split document cleanup.
|
SplitJournalFile |
|
SplitJournalFileReader |
|
SplitPersistence |
|
SplitPersistenceService |
|
SplitSegmentArchiveManager |
|
SQL2Parser |
The SQL2 parser can convert a JCR-SQL2 query to a query.
|
SSLSubjectMatcher |
|
StableRevisionComparator |
StableRevisionComparator implements a revision comparator, which
is only based on stable information available in the two revisions presented
to this comparator.
|
StandbyClientSync |
|
StandbyClientSync.Builder |
|
StandbyServerSync |
|
StandbyServerSync.Builder |
|
StandbyStatusMBean |
|
StandbyStoreService |
|
StandbyStoreServiceDeprecationError |
This component is activated when a configuration for the deprecated
StandbyStoreService from oak-segment is detected.
|
State |
Automaton state.
|
Statement |
An xpath statement.
|
StatePair |
Pair of states.
|
StaticOperandImpl |
The base class for static operands.
|
StaticOperandImpl |
The base class for static operands (literal, bind variables).
|
StatisticManager |
Manager for all repository wide statistics.
|
StatisticsProvider |
|
StatisticsProviderFactory |
Factory to create StatisticsProvider depending on setup.
|
Stats |
A tag interface to indicate that a class is a Stat.
|
StatsBuilder |
Builder for commonly used statistics for flat file stores.
|
StatsCollectingStreams |
|
StatsCollector |
A collector for statistics about a repository.
|
StatsCollectorUtil |
Statistics Util class.
|
StatsOptions |
|
StatsProviderUtil |
Util class to generate a name for Stats implementations that can be used for creating labels in prometheus.
|
StatsStore |
A wrapper store that allows capturing performance counters for a storage
backend.
|
StopwatchLogger |
Utility class to be used for tracking of timing within methods.
|
Storage |
An in-memory storage for collectors.
|
Store |
Storage for files in a tree store.
|
StoreBuilder |
A helper class to build storage backends for a tree store.
|
StoredField |
|
StoredFieldsFormat |
Controls the format of stored fields
|
StoredFieldsReader |
Codec API for reading stored fields.
|
StoredFieldsWriter |
Codec API for writing stored fields:
|
StoredFieldVisitor |
Expert: provides a low-level means of accessing the stored field
values in an index.
|
StoredFieldVisitor.Status |
|
StraightBytesDocValuesField |
Deprecated.
|
StrictPathRestriction |
|
StringBasedBlob |
This Blob implementations is based on a string.
|
StringCache |
This class caches the path strings used in the CompositeNodeState to avoid
keeping too many strings in the memory.
|
StringCache |
TODO document
|
StringCache |
|
StringConstraint |
|
StringData |
|
StringField |
A field that is indexed but not tokenized: the entire
String value is indexed as a single token.
|
StringHelper |
Methods for manipulating strings.
|
StringPropertyState |
|
StringSizeEstimator |
Source copied from a publicly available library.
|
StringSort |
Utility class to store a list of string and perform sort on that.
|
StringUtils |
Some string utility methods.
|
StringValue |
A cache value wrapping a simple string.
|
StripedNodeDocumentLocks |
|
SubtreeEditor |
Editor wrapper that passes only changes in the specified subtree to
the given delegate editor.
|
SubtreeExcludingValidator |
Validator that excludes a subtree from the validation process and delegates
validation of other changes to another given validator.
|
SubtreeValidator |
Validator that detects changes to a specified subtree and delegates the
validation of such changes to another given validator.
|
SuggestImpl |
Support for "suggest(...)
|
Summary |
Summary ...
|
Sweep2Helper |
Helper methods for sweep2 functionality introduced with OAK-9176.
|
Sweep2StatusDocument |
Represents the sweep2 status as recorded in the settings collection.
|
SweepHelper |
Helper class to perform a revision sweep for a given clusterId.
|
SyncContext |
SyncContext is used as scope for sync operations.
|
SyncedIdentity |
Represents a synchronized identity managed by a SyncHandler .
|
SyncException |
Exception thrown by methods defined on the SyncHandler
interface indicating that user or group synchronization failed.
|
SyncHandler |
|
SyncHandlerMapping |
|
SynchronizationMBean |
Provides utilities to manage synchronized external identities.
|
SynchronizingDocumentStoreWrapper |
Implements a DocumentStore wrapper which synchronizes on all
methods.
|
SyncManager |
The external identity synchronization management.
|
SyncManagerImpl |
SyncManagerImpl is used to manage registered sync handlers.
|
SyncMBeanImpl |
|
SyncResult |
Defines the result of a sync operation
|
SyncResult.Status |
Result codes for sync operation.
|
SyncRuntimeException |
|
SystemPrincipal |
Principal to mark an system internal subject.
|
SystemPropertySupplier<T> |
Utility class for consistent handling of system properties.
|
SystemRoot |
Internal extension of the MutableRoot to be used
when an usage of the system internal subject is needed.
|
SystemSubject |
Internal utility providing access to a system internal subject instance.
|
SystemUserPrincipal |
Principal used to mark a system user.
|
TarConstants |
|
TarFiles |
|
TarFiles.Builder |
|
TarFiles.CleanupResult |
|
TargetImportHandler |
TargetImportHandler serves as the base class for the concrete
classes {@link DocViewImportHandler} and
{@link SysViewImportHandler} .
|
TarPersistence |
|
TarPersistenceService |
|
TarPersistenceService.Configuration |
|
TarReader |
|
TarRecovery |
A strategy for the recovery of segments.
|
TarRevisions |
This implementation of Revisions is backed by a
journal file where the current head is persisted
by calling TarRevisions.tryFlush(Flusher) .
|
TCPBroadcaster |
A broadcast mechanism that uses TCP.
|
Template |
The in-memory representation of a "hidden class" of a node; inspired by the
Chrome V8 Javascript engine).
|
TemplateCache |
|
Term |
A Term represents a word from text.
|
TermContext |
|
TermQuery |
A Query that matches documents containing a term.
|
TermRangeFilter |
A Filter that restricts search results to a range of term
values in a given field.
|
TermRangeQuery |
A Query that matches documents within an range of terms.
|
TermRangeTermsEnum |
Subclass of FilteredTermEnum for enumerating all terms that match the
specified range parameters.
|
Terms |
Access to the terms in a specific field.
|
TermsConsumer |
Abstract API that consumes terms for an individual field.
|
TermsEnum |
|
TermsEnum.SeekStatus |
|
TermSpans |
Expert:
Public for extension only
|
TermState |
Encapsulates all required internal state to position the associated
TermsEnum without re-seeking.
|
TermStatistics |
Contains statistics for a specific term
|
TermStats |
Holder for per-term statistics.
|
TermToBytesRefAttribute |
This attribute is requested by TermsHashPerField to index the contents.
|
TermVectorsFormat |
Controls the format of term vectors
|
TermVectorsReader |
Codec API for reading term vectors:
|
TermVectorsWriter |
Codec API for writing term vectors:
|
TextExtractorMain |
|
TextField |
A field that is indexed and tokenized, without term
vectors.
|
TextValue |
TextValue represents a serialized property value read
from a System or Document View XML document.
|
TextWriter |
|
TFIDFSimilarity |
Implementation of Similarity with the Vector Space Model.
|
ThreadDumpCleaner |
A tool that removes uninteresting lines from stack traces.
|
ThreadDumpCommand |
|
ThreadDumpConverter |
A tool that converts full thread dumps files to the "standard" format.
|
ThreadDumpThreadNames |
A tool that converts a file with date/time and thread dumps into a list of
date/time and just the thread names.
|
ThreadInterruptedException |
Thrown by lucene on detecting that Thread.interrupt() had
been called.
|
ThreadMonitor |
Keeps track of a list of threads and prints statistics of CPU usage of the threads.
|
ThreadMonitor.AutoRegisteringThreadFactory |
Thread factory that registers all new threads with a given thread monitor.
|
ThreeRolesAuthorizationConfiguration |
|
ThreeRolesConstants |
|
ThreeWayConflictHandler |
A ThreeWayConflictHandler is responsible for handling conflicts which happen
on Root.rebase() and on the implicit rebase operation which
takes part on Root.commit() .
|
ThreeWayConflictHandler.Resolution |
Resolutions for conflicts
|
Throttler |
Interface to implement throttling for document store.
|
ThrottlingDocumentStoreWrapper |
Wrapper of another DocumentStore that does a throttling check on any method
invocation (create, update or delete) and throttled the system if under high load.
|
ThrottlingStatsCollector |
Stats Collector for throttling operation.
|
ThrottlingStatsCollectorImpl |
Throttling statistics helper class.
|
TieredMergePolicy |
Merges segments of approximately equal size, subject to
an allowed number of segments per tier.
|
TieredMergePolicy.MergeScore |
Holds score and explanation for a single candidate
merge.
|
TikaCommandOptions |
|
TimeDurationFormatter |
Format a time duration as human-readable string, inspired by
Stopwatch.toString() .
|
TimeInterval |
A class representing a time interval, with utility methods to derive related
intervals, check time stamps for containment, etc.
|
TimeLimitingCollector |
The TimeLimitingCollector is used to timeout search requests that
take longer than the maximum allowed search time limit.
|
TimeLimitingCollector.TimeExceededException |
Thrown when elapsed search time exceeds allowed search time.
|
TimeLimitingCollector.TimerThread |
Thread used to timeout search requests.
|
TimeMeasureCollector |
A collector that also measures the elapsed time.
|
TimerStats |
|
TimerStats.Context |
A timing context.
|
TimeSeries |
Interface for a time series of the measured values per
second, minute, hour and day.
|
TimeUuid |
A UUID implementation.
|
TimingDocumentStoreWrapper |
A DocumentStore wrapper that can be used to log and also time DocumentStore
calls.
|
TimSorter |
|
Token |
A Token is an occurrence of a term from the text of a field.
|
Token.TokenAttributeFactory |
Expert: Creates a TokenAttributeFactory returning Token as instance for the basic attributes
and for all other attributes calls the given delegate factory.
|
TokenConfiguration |
Configuration for token management.
|
TokenConfigurationImpl |
Default implementation for the TokenConfiguration interface.
|
TokenConstants |
|
TokenCredentials |
TokenCredentials implements the Credentials
interface and represents single token credentials.
|
TokenCredentialsExpiredException |
Subclass of CredentialException indicating that the token credentials used for repository login have expired.
|
TokenFilter |
A TokenFilter is a TokenStream whose input is another TokenStream.
|
TokenInfo |
The TokenInfo provides data associated with a login token and
basic methods to verify the validity of token credentials at given
point in time.
|
Tokenizer |
A Tokenizer is a TokenStream whose input is a Reader.
|
TokenLoginModule |
LoginModule implementation that is able to handle login request
based on TokenCredentials .
|
TokenProvider |
Interface to manage create and manage login tokens.
|
TokenProviderCallback |
Callback implementation to set and retrieve a login token provider.
|
TokenStream |
A TokenStream enumerates the sequence of tokens, either from
Field s of a Document or from query text.
|
TokenStreamToAutomaton |
Consumes a TokenStream and creates an Automaton
where the transition labels are UTF8 bytes (or Unicode
code points if unicodeArcs is true) from the TermToBytesRefAttribute .
|
ToolUtils |
Utility class for common stuff pertaining to tooling.
|
ToolUtils.SegmentStoreType |
|
TopDocs |
|
TopDocsCollector<T extends ScoreDoc> |
A base class for all collectors that return a TopDocs output.
|
TopFieldCollector |
|
TopFieldDocs |
|
TopKValues |
A class that remembers the top k entries.
|
TopLargestBinaries |
Collect the top largest binaries.
|
TopScoreDocCollector |
A Collector implementation that collects the top-scoring hits,
returning them as a TopDocs .
|
TopTermsRewrite<Q extends Query> |
Base rewrite method for collecting only the top terms
via a priority queue.
|
ToStringUtils |
|
TotalHitCountCollector |
Just counts the total number of hits.
|
Trace |
An instance of a Trace specifies a read pattern for tracing
IO reads of segments with an IOTracer instance.
|
Traces |
Utility class for running the various Trace implementations.
|
Tracker<T> |
Tracker for whiteboard services.
|
TrackingCorruptIndexHandler |
|
TrackingDirectoryWrapper |
A delegating Directory that records which files were
written to and deleted.
|
TrackingIndexWriter |
|
TransformStageStatistics |
|
Transition |
Automaton transition.
|
TraversingIndex |
An index that traverses over a given subtree.
|
TraversingRange |
|
Tree |
|
Tree.Status |
Status of an item in a Tree
|
TreeAware |
Oak internal utility interface to avoid repeated retrieval of an underlying Tree .
|
TreeConstants |
|
TreeContext |
TreeContext represents item related information in relation to a
dedicated module.
|
TreeFactory |
Deprecated.
|
TreeLocation |
A TreeLocation denotes a location inside a tree.
|
TreePermission |
The TreePermission allow to evaluate permissions defined for a given
Tree and it's properties.
|
TreeProvider |
|
TreeProviderService |
|
TreeSession |
A session that allows reading and writing keys and values in a tree store.
|
TreeStore |
The tree store is similar to the flat file store, but instead of storing all
key-value pairs in a single file, it stores the entries in multiple files
(except if there are very few nodes).
|
TreeStoreNodeState |
A node state of an Oak node that is stored in a tree store.
|
TreeStoreUtils |
A command line utility for the tree store.
|
TreeType |
Allows to distinguish different types of trees based on their name, ancestry
or primary type.
|
TreeTypeAware |
|
TreeTypeProvider |
|
TreeUtil |
Utility providing common operations for the Tree that are not provided
by the API.
|
TriStatsConsumer |
|
TwoPhaseCommit |
An interface for implementations that support 2-phase commit.
|
TwoPhaseCommitTool |
A utility for executing 2-phase commit on several objects.
|
TwoPhaseCommitTool.CommitFailException |
|
TwoPhaseCommitTool.PrepareCommitFailException |
|
Type<T> |
|
TypeAttribute |
A Token's lexical type.
|
TypeAttributeImpl |
|
TypeCodes |
TypeCodes maps between Type and the code used to prefix
its json serialisation.
|
TypedDataStore |
|
TypeEditor |
Validator implementation that check JCR node type constraints.
|
TypeEditor.ConstraintViolationCallback |
Extension point that allows pluggable handling of constraint violations
|
TypeEditorProvider |
|
TypePredicate |
|
UDPBroadcaster |
A broadcast mechanism that uses UDP.
|
UnboundConnectionValidator |
UnboundConnectionValidator ...
|
UnboundLdapConnectionPool |
A pool implementation for LdapConnection objects.
|
UnboundLookupConnectionValidator |
UnboundConnectionValidator ...
|
UnicodeUtil |
Class to encode java's UTF16 char[] into UTF8 byte[]
without always allocating a new byte[] as
String.getBytes("UTF-8") does.
|
UnionQueryImpl |
Represents a union query.
|
UniqueIndexNodeStoreChecker |
Checker that ensures the consistency of unique entries in the various mounts
|
UniversalFilter |
|
UniversalFilter.Selector |
A selector instance maps call backs on Filters to NodeState instances,
which should be used for determining inclusion or exclusion of the associated event.
|
UnrecoverableArchiveException |
|
UpdateOp |
A DocumentStore "update" operation for one document.
|
UpdateOp.Condition |
A condition to check before an update is applied.
|
UpdateOp.Condition.Type |
|
UpdateOp.Key |
A key for an operation consists of a property name and an optional
revision.
|
UpdateOp.Operation |
A DocumentStore operation for a given key within a document.
|
UpdateOp.Operation.Type |
The DocumentStore operation type.
|
UpdateUtils |
|
UpgradeIndexMergePolicy |
|
UploadStagingCache |
Cache for staging async uploads.
|
UpperCaseImpl |
The implementation of the corresponding JCR interface.
|
UpperCaseImpl |
The function "upper(..)".
|
UpsertMetricUpdater |
|
User |
User is a special Authorizable that can be authenticated and
impersonated.
|
UserAction |
|
UserAuthenticationFactory |
Provides a user management specific implementation of the
Authentication
interface to those LoginModule s that verify
a given authentication request by evaluation information exposed by the
Jackrabbit user management API.
|
UserAuthenticationFactoryImpl |
|
UserConfiguration |
Configuration interface for user management.
|
UserConfigurationImpl |
|
UserConstants |
User management related constants.
|
UserIdCredentials |
Credentials implementation that only contains a userId but no password.
|
UserIDTestLoginModule |
LoginModule implementation for UserIDTest
|
UserManager |
|
UserManagerCallback |
Callback implementation used to pass a UserManager to the
login module.
|
UserManagerDelegator |
This implementation of UserManager delegates back to a
delegatee wrapping each call into a UserManager closure.
|
UserManagerImpl |
UserManagerImpl...
|
UserManagerOperation<T> |
|
UserMonitor |
|
UserMonitorImpl |
|
UserQueryManager |
Query manager for user specific searches.
|
UserUtil |
Utility methods for user management.
|
UTF32ToUTF8 |
Converts UTF-32 automata to the equivalent UTF-8 representation.
|
UTF8Encoder |
Utility class related to encoding characters into (UTF-8) byte sequences.
|
Util |
Static helper methods.
|
Util.FSTPath<T> |
Represents a path in TopNSearcher.
|
Util.MinResult<T> |
|
Util.TopNSearcher<T> |
Utility class to find top N shortest paths from start
point(s).
|
Utils |
|
Utils |
Amazon S3 utilities.
|
Utils |
Utility methods.
|
Utils |
Utils provide some utility methods.
|
Utils |
|
Utils |
|
Utils |
|
UuidPredicate |
A predicate for matching against a list of UUIDs.
|
UUIDUtils |
|
ValidationEntry |
|
Validator |
Content change validator.
|
ValidatorProvider |
Extension point for plugging in different kinds of validation rules
for content changes.
|
ValueConverter |
|
ValueDataType |
|
ValueFactoryImpl |
|
VerifyingLockFactory |
A LockFactory that wraps another LockFactory and verifies that each lock obtain/release
is "correct" (never results in two processes holding the
lock at the same time).
|
Version |
Use by certain classes to match version compatibility
across releases of Lucene.
|
VersionableEditor |
|
VersionableEditor.Provider |
|
VersionablePathHook |
Commit hook which is responsible for storing the path of the versionable
node with every version history.
|
VersionablePropertiesEditor |
The VersionablePropertiesEditor adds missing versionable properties.
|
VersionablePropertiesEditor.Provider |
|
VersionConstants |
Deprecated.
|
VersionConstants |
VersionConstants...
|
VersionCopier |
This class allows to copy the version history, optionally filtering it with a
given date.
|
VersionCopyConfiguration |
This class allows to configure the behaviour of the version copier.
|
VersionDelegate |
VersionDelegate ...
|
VersionGarbageCollector |
|
VersionGarbageCollector.VersionGCInfo |
|
VersionGarbageCollector.VersionGCStats |
|
VersionGCOptions |
|
VersionGCRecommendations |
Gives a recommendation about parameters for the next revision garbage collection run.
|
VersionGCSupport |
|
VersionHistoryDelegate |
VersionHistoryDelegate ...
|
VersionHistoryImpl |
VersionHistoryImpl ...
|
VersionHistoryUtil |
|
VersionHook |
This class gathers together editors related to handling version storage:
VersionEditorProvider
VersionEditor - creates version history, handles
checking-in, checking-out and restoring, prevents a
checked-in node from being modified,
VersionStorageEditor - validates changes on the
version storage,
VersionableCollector - collects all existing versionable
UUIDs, so assigned histories won't be removed in the next step,
OrphanedVersionCleaner - removes all histories that are
empty and have no longer a parent versionable node.
|
VersionImpl |
|
VersionManagerDelegate |
VersionManagerDelegate ...
|
VersionManagerImpl |
|
VersionStorage |
Simple abstraction of the version storage.
|
VirtualMethod<C> |
A utility for keeping backwards compatibility on previously abstract methods
(or similar replacements).
|
VisibleEditor |
Editor wrapper that passes only changes to non-hidden nodes and properties
(i.e.
|
VisibleFilter |
Event filter that hides all non-visible content.
|
VisibleValidator |
Validator implementation that allows to exclude hidden nodes and/or properties
for the validation process.
|
WAH8DocIdSet |
DocIdSet implementation based on word-aligned hybrid encoding on
words of 8 bits.
|
WAH8DocIdSet.Builder |
|
WeakIdentityMap<K,V> |
|
WebConsoleSupport |
Integrates the Felix WebConsole support with servlet container.
|
Weight |
Expert: Calculate query weights and build query scorers.
|
Whiteboard |
|
WhiteboardAuthorizableActionProvider |
|
WhiteboardAuthorizableNodeName |
|
WhiteboardAware |
Marker interface for services than can hold a whiteboard.
|
WhiteboardCallback |
Callback implementation to set and retrieve the Whiteboard .
|
WhiteboardEditorProvider |
|
WhiteboardExecutor |
Dynamic Executor based on the available whiteboard services.
|
WhiteboardIndexEditorProvider |
|
WhiteboardIndexProvider |
|
WhiteboardRestrictionProvider |
|
WhiteboardUserAuthenticationFactory |
|
WhiteboardUtils |
|
WhiteboardUtils.ScheduleExecutionInstanceTypes |
|
WildcardQuery |
Implements the wildcard search query.
|
WorkspaceDelegate |
Delegate class for workspace operations.
|
WorkspaceImpl |
TODO document
|
WorkspaceInitializer |
Initializer of a workspace and it's initial content.
|
WrappingSplitBlobStore |
|
WriteAccessController |
|
WriterCacheManager |
Instances of this class manage the deduplication caches used by the SegmentWriter to avoid writing multiple copies of the same record.
|
WriterCacheManager.Default |
|
WriterCacheManager.Empty |
|
XASession |
Deprecated.
|
XPathToSQL2Converter |
This class can can convert a XPATH query to a SQL2 query.
|