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

A

abort() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.AbstractLoginModule
 
abort() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.GuestLoginModule
 
ABORT - Static variable in class org.apache.jackrabbit.oak.spi.xml.ImportBehavior
Aborts the import as soon as invalid values are detected throwing a ConstraintViolationException.
AbortingIndexerLock - Class in org.apache.jackrabbit.oak.plugins.index.importer
Lock implementation for single node setup like for SegmentNodeStore It works by check async indexer status via IndexStatsMBean and then aborting it if found to be running
AbortingIndexerLock(AsyncIndexInfoService) - Constructor for class org.apache.jackrabbit.oak.plugins.index.importer.AbortingIndexerLock
 
AbortingIndexerLock(AsyncIndexInfoService, Clock) - Constructor for class org.apache.jackrabbit.oak.plugins.index.importer.AbortingIndexerLock
 
abortingIterable(Iterable<T>, Predicate<T>) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
Wraps the given iterable and aborts iteration over elements when the predicate on an element evaluates to false.
AbstractAccessControlList - Class in org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol
Abstract base implementation of the JackrabbitAccessControlList interface.
AbstractAccessControlList(String, NamePathMapper) - Constructor for class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AbstractAccessControlList
 
AbstractAccessControlManager - Class in org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol
Default implementation of the JackrabbitAccessControlManager interface.
AbstractAccessControlManager(Root, NamePathMapper, SecurityProvider) - Constructor for class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AbstractAccessControlManager
 
AbstractAuthorizableAction - Class in org.apache.jackrabbit.oak.spi.security.user.action
Abstract implementation of the AuthorizableAction interface that doesn't perform any action.
AbstractAuthorizableAction() - Constructor for class org.apache.jackrabbit.oak.spi.security.user.action.AbstractAuthorizableAction
 
AbstractCursor() - Constructor for class org.apache.jackrabbit.oak.plugins.index.Cursors.AbstractCursor
 
AbstractDocumentNodeState - Class in org.apache.jackrabbit.oak.plugins.document
 
AbstractDocumentNodeState() - Constructor for class org.apache.jackrabbit.oak.plugins.document.AbstractDocumentNodeState
 
abstractFlagDiff() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeDefDiff
 
AbstractGroupAction - Class in org.apache.jackrabbit.oak.spi.security.user.action
Abstract implementation of the GroupAction interface that doesn't perform any action.
AbstractGroupAction() - Constructor for class org.apache.jackrabbit.oak.spi.security.user.action.AbstractGroupAction
 
AbstractLoginModule - Class in org.apache.jackrabbit.oak.spi.security.authentication
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.
AbstractLoginModule() - Constructor for class org.apache.jackrabbit.oak.spi.security.authentication.AbstractLoginModule
 
AbstractMutableTree - Class in org.apache.jackrabbit.oak.plugins.tree.impl
AbstractMutableTree extends AbstractTree with implementations for most write methods of Tree.
AbstractMutableTree() - Constructor for class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractMutableTree
 
AbstractRestrictionProvider - Class in org.apache.jackrabbit.oak.spi.security.authorization.restriction
 
AbstractRestrictionProvider(Map<String, ? extends RestrictionDefinition>) - Constructor for class org.apache.jackrabbit.oak.spi.security.authorization.restriction.AbstractRestrictionProvider
 
AbstractTree - Class in org.apache.jackrabbit.oak.plugins.tree.impl
AbstractTree provides default implementations for most read methods of Tree.
AbstractTree() - Constructor for class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractTree
 
AC_NODETYPE_NAMES - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AccessControlConstants
 
accessControl(PermissionProviderFactory) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder
A condition that hold for accessible items as determined by the passed permission provider.
AccessControlAction - Class in org.apache.jackrabbit.oak.spi.security.user.action
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.
AccessControlAction() - Constructor for class org.apache.jackrabbit.oak.spi.security.user.action.AccessControlAction
 
AccessControlConstants - Interface in org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol
Constants for the default access control management implementation and and for built-in access control related node types.
AccessControlImporter - Class in org.apache.jackrabbit.oak.security.authorization.accesscontrol
ProtectedNodeImporter implementation that handles access control lists, entries and restrictions.
AccessControlImporter() - Constructor for class org.apache.jackrabbit.oak.security.authorization.accesscontrol.AccessControlImporter
 
AccessControlManagerImpl - Class in org.apache.jackrabbit.oak.security.authorization.accesscontrol
Default implementation of the JackrabbitAccessControlManager interface.
AccessControlManagerImpl(Root, NamePathMapper, SecurityProvider) - Constructor for class org.apache.jackrabbit.oak.security.authorization.accesscontrol.AccessControlManagerImpl
 
AccessControlValidatorProvider - Class in org.apache.jackrabbit.oak.security.authorization.accesscontrol
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.
AccessControlValidatorProvider(SecurityProvider) - Constructor for class org.apache.jackrabbit.oak.security.authorization.accesscontrol.AccessControlValidatorProvider
 
ACE - Class in org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol
Default implementation of the JackrabbitAccessControlEntry interface.
ACE(Principal, PrivilegeBits, boolean, Set<Restriction>, NamePathMapper) - Constructor for class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.ACE
 
ACE_PROPERTY_NAMES - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AccessControlConstants
 
ACFilter - Class in org.apache.jackrabbit.oak.plugins.observation.filter
EventTypeFilter filters based on the access rights of the observing session.
ACFilter(NodeState, NodeState, PermissionProvider) - Constructor for class org.apache.jackrabbit.oak.plugins.observation.filter.ACFilter
Create a new Filter instance that includes an event when the observing session has sufficient permissions to read the associated item.
acquire(String) - Method in interface org.apache.jackrabbit.oak.plugins.document.locks.NodeDocumentLocks
Acquires a lock for the given key.
acquire(String) - Method in class org.apache.jackrabbit.oak.plugins.document.locks.StripedNodeDocumentLocks
 
acquireRecoveryLock(int, int) - Method in class org.apache.jackrabbit.oak.plugins.document.MissingLastRevSeeker
Acquire a recovery lock for the given cluster node info document.
activate(BundleContext) - Method in class org.apache.jackrabbit.oak.plugins.atomic.AtomicCounterEditorProvider
 
activate(ComponentContext, Map<String, ?>) - Method in class org.apache.jackrabbit.oak.plugins.cow.COWNodeStoreService
 
activate(ComponentContext) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentDiscoveryLiteService
On activate the DocumentDiscoveryLiteService tries to start the background job
activate(ComponentContext, Map<String, ?>) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreService
 
activate(BundleContext, Map<String, Object>) - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexerService
 
activate(ComponentContext, Map<String, ?>) - Method in class org.apache.jackrabbit.oak.plugins.observation.ChangeCollectorProvider
 
activate(BundleContext, Map<String, Object>) - Method in class org.apache.jackrabbit.oak.security.internal.SecurityProviderRegistration
 
activate(BundleContext) - Method in class org.apache.jackrabbit.oak.security.SecurityProviderImpl
 
ACTIVITIES_PATH - Static variable in interface org.apache.jackrabbit.oak.plugins.version.VersionConstants
Quote from JSR 283 Section "15.12.3 Activity Storage"
add(String, long) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.replica.LocalChanges
 
add(ChangeSet) - Method in class org.apache.jackrabbit.oak.plugins.observation.ChangeSetBuilder
 
add(PrivilegeBits) - Method in class org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeBits
Adds the other privilege bits to this instance.
ADD_NODE - Static variable in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
 
ADD_PROPERTY - Static variable in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
 
addAccessControlEntry(Principal, Privilege[]) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AbstractAccessControlList
 
addChild(String) - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractMutableTree
 
addChild(String) - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.ImmutableTree
 
addChild(Tree, String, String, Tree, String) - Static method in class org.apache.jackrabbit.oak.plugins.tree.TreeUtil
 
addChild(Tree, String, String) - Static method in class org.apache.jackrabbit.oak.plugins.tree.TreeUtil
Adds a new child tree with the given name and primary type name.
addCollision(UpdateOp, Revision, Revision) - Static method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
Add a collision marker for the given revision.
addConfiguration(T) - Method in class org.apache.jackrabbit.oak.spi.security.CompositeConfiguration
 
addConfiguration(T, ConfigurationParameters) - Method in class org.apache.jackrabbit.oak.spi.security.CompositeConfiguration
 
addCustomMapping(NodeBuilder, String, String) - Static method in class org.apache.jackrabbit.oak.plugins.name.Namespaces
 
addDifference(PrivilegeBits, PrivilegeBits) - Method in class org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeBits
Subtracts the b from a and adds the result (diff) to this instance.
added(String, Set<String>, Set<String>, Set<String>, Map<String, String>, CommitInfo) - Method in class org.apache.jackrabbit.oak.plugins.observation.NodeObserver
A node at path has been added.
addEntry(Principal, Privilege[], boolean) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AbstractAccessControlList
 
addEntry(Principal, Privilege[], boolean, Map<String, Value>) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AbstractAccessControlList
 
addEntry(Principal, Privilege[], boolean, Map<String, Value>) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.ImmutableACL
 
addEntry(Principal, Privilege[], boolean, Map<String, Value>, Map<String, Value[]>) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.ImmutableACL
 
addExistingNode(NodeBuilder, String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.commit.AnnotatingConflictHandler
 
addExistingNode(NodeBuilder, String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.commit.ChildOrderConflictHandler
 
addExistingNode(NodeBuilder, String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.commit.DefaultConflictHandler
Deprecated.
 
addExistingNode(NodeBuilder, String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.commit.DefaultThreeWayConflictHandler
 
addExistingNode(NodeBuilder, String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.security.user.RepMembersConflictHandler
 
addExistingProperty(NodeBuilder, PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.commit.AnnotatingConflictHandler
 
addExistingProperty(NodeBuilder, PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.commit.ChildOrderConflictHandler
 
addExistingProperty(NodeBuilder, PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.commit.DefaultConflictHandler
Deprecated.
 
addExistingProperty(NodeBuilder, PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.commit.DefaultThreeWayConflictHandler
 
addExistingProperty(NodeBuilder, PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.commit.JcrLastModifiedConflictHandler
 
addExistingProperty(NodeBuilder, PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.security.user.RepMembersConflictHandler
 
addGeneration(int, boolean) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.BlobCache
 
addHandler(NodeState, NodeState, EventHandler) - Method in class org.apache.jackrabbit.oak.plugins.observation.EventGenerator
 
addImporterProvider(IndexImporterProvider) - Method in class org.apache.jackrabbit.oak.plugins.index.importer.IndexImporter
 
addInvalidate(Iterable<K>) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.async.CacheWriteQueue
 
addJoinCondition(JoinConditionImpl, boolean) - Method in class org.apache.jackrabbit.oak.query.ast.JoinImpl
 
addJoinCondition(JoinConditionImpl, boolean) - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
 
addJoinCondition(JoinConditionImpl, boolean) - Method in class org.apache.jackrabbit.oak.query.ast.SourceImpl
Add the join condition (the ON ...
addListener(ReplicaSetInfoListener) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.replica.ReplicaSetInfo
 
addListener(Broadcaster.Listener) - Method in interface org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast.Broadcaster
Add a listener for new messages.
addListener(Broadcaster.Listener) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast.InMemoryBroadcaster
 
addListener(Broadcaster.Listener) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast.TCPBroadcaster
 
addListener(Broadcaster.Listener) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast.UDPBroadcaster
 
addMember(Principal) - Method in class org.apache.jackrabbit.oak.spi.security.principal.EveryonePrincipal
 
addMixin(Tree, String, Tree, String) - Static method in class org.apache.jackrabbit.oak.plugins.tree.TreeUtil
 
addNodeType(String) - Method in class org.apache.jackrabbit.oak.plugins.observation.ChangeSetBuilder
 
addNodeTypes(Iterable<String>) - Method in class org.apache.jackrabbit.oak.plugins.observation.ChangeSetBuilder
 
addObserver(Observer) - Method in class org.apache.jackrabbit.oak.plugins.cow.BranchNodeStore
 
addObserver(Observer) - Method in class org.apache.jackrabbit.oak.plugins.cow.COWNodeStore
 
addObserver(Observer) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
addOrderBy(Order) - Method in class org.apache.jackrabbit.oak.query.xpath.Statement
 
addParentNodeName(String) - Method in class org.apache.jackrabbit.oak.plugins.observation.ChangeSetBuilder
 
addParentNodeType(String) - Method in class org.apache.jackrabbit.oak.plugins.observation.ChangeSetBuilder
 
addParentNodeTypes(Iterable<String>) - Method in class org.apache.jackrabbit.oak.plugins.observation.ChangeSetBuilder
 
addParentPath(String) - Method in class org.apache.jackrabbit.oak.plugins.observation.ChangeSetBuilder
 
addPathsForMBean(Set<String>) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder
Adds paths to the FilterConfigMBean's getPaths set
addProperty(T) - Method in interface org.apache.jackrabbit.oak.plugins.document.spi.JournalPropertyBuilder
Adds the JournalProperty instance fetched from CommitInfo to this builder
addPropertyName(String) - Method in class org.apache.jackrabbit.oak.plugins.observation.ChangeSetBuilder
 
addPut(K, V) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.async.CacheWriteQueue
 
addReadMap(int, CacheMap<K, V>) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.MultiGenerationMap
 
addSelectColumn(Expression.Property) - Method in class org.apache.jackrabbit.oak.query.xpath.Statement
 
addSerializedProperty(String) - Method in interface org.apache.jackrabbit.oak.plugins.document.spi.JournalPropertyBuilder
Adds the serialized form of journal property (as build from #buildAsString) call
addSubTree(String) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder
Adds a path to the set of paths whose subtrees include all events of this filter.
addSubtree() - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder
 
AddSubtreeFilter - Class in org.apache.jackrabbit.oak.plugins.observation.filter
This EventFilter implementation excludes events for child nodes of added nodes.
AddSubtreeTreeCondition() - Constructor for class org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder.AddSubtreeTreeCondition
 
addToUnionList(Set<ConstraintImpl>) - Method in class org.apache.jackrabbit.oak.query.ast.AndImpl
 
addWriteGeneration(int) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
adjustCountSync(NodeBuilder, long) - Static method in class org.apache.jackrabbit.oak.plugins.index.counter.ApproximateCounter
Adjust a counter in the given node.
adjustOffset(long, long, int) - Static method in class org.apache.jackrabbit.oak.plugins.index.counter.ApproximateCounter
This method ensures that the new approximate count (the old count plus the calculated offset) does not go below 0.
AdminPrincipal - Interface in org.apache.jackrabbit.oak.spi.security.principal
Principal used to mark an administrator.
afterNonBlocking() - Method in class org.apache.jackrabbit.oak.plugins.observation.CommitRateLimiter
The current thread finished running code that must not be throttled or blocked.
aggregate(NodeState, List<ChildNodeEntry>, PropertyState) - Method in interface org.apache.jackrabbit.oak.plugins.observation.filter.EventAggregator
Aggregates a property change
aggregate(NodeState, List<ChildNodeEntry>, ChildNodeEntry) - Method in interface org.apache.jackrabbit.oak.plugins.observation.filter.EventAggregator
Aggregates a node change
AGGREGATE_PRIVILEGES - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
The internal names and aggregation definition of all built-in privileges that are aggregates (except for jcr:all).
AggregatedPermissionProvider - Interface in org.apache.jackrabbit.oak.spi.security.authorization.permission
Extension of the PermissionProvider interface that allows it to be used in combination with other provider implementations.
AggregateIndex - Class in org.apache.jackrabbit.oak.plugins.index.aggregate
A virtual full-text that can aggregate nodes based on aggregate definitions.
AggregateIndex(QueryIndex.AdvanceFulltextQueryIndex) - Constructor for class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndex
 
AggregateIndexPlan - Class in org.apache.jackrabbit.oak.plugins.index.aggregate
An index plan for multiple query indexes.
AggregateIndexProvider - Class in org.apache.jackrabbit.oak.plugins.index.aggregate
A provider for aggregate indexes.
aggregates(long) - Static method in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
 
aggregator(EventAggregator) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder
 
alignWithExternalRevisions(NodeDocument, Clock, int) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
Makes sure the current time is after the most recent external revision timestamp in the _lastRev map of the given root document.
all(DocumentStore) - Static method in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfoDocument
Returns all cluster node info documents currently available in the given document store.
all(FilterBuilder.Condition...) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder
A compound condition that holds when all of its constituents hold.
all(List<FilterBuilder.Condition>) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder
A compound condition that holds when all of its constituents hold.
all(Iterable<FilterBuilder.Condition>) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder
A compound condition that holds when all of its constituents hold.
all(EventFilter...) - Static method in class org.apache.jackrabbit.oak.plugins.observation.filter.Filters
A filter that matches if and only if all of the filters passed to this method matches.
all(List<EventFilter>) - Static method in class org.apache.jackrabbit.oak.plugins.observation.filter.Filters
A filter that matches if and only if all of the filters passed to this method matches.
ALL - Static variable in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
 
ALL - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.RepositoryPermission
RepositoryPermission instance that always returns true.
ALL - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.TreePermission
TreePermission which always returns true and thus grants all permissions.
and(ConstraintImpl, ConstraintImpl) - Method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
 
AndImpl - Class in org.apache.jackrabbit.oak.query.ast
An AND condition.
AndImpl(List<ConstraintImpl>) - Constructor for class org.apache.jackrabbit.oak.query.ast.AndImpl
 
AndImpl(ConstraintImpl, ConstraintImpl) - Constructor for class org.apache.jackrabbit.oak.query.ast.AndImpl
 
AnnotatingConflictHandler - Class in org.apache.jackrabbit.oak.plugins.commit
This ThreeWayConflictHandler implementation resolves conflicts to ThreeWayConflictHandler.Resolution.THEIRS and in addition marks nodes where a conflict occurred with the mixin rep:MergeConflict:
AnnotatingConflictHandler() - Constructor for class org.apache.jackrabbit.oak.plugins.commit.AnnotatingConflictHandler
 
any(FilterBuilder.Condition...) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder
A compound condition that holds when any of its constituents hold.
any(Iterable<FilterBuilder.Condition>) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder
A compound condition that holds when any of its constituents hold.
any(EventFilter...) - Static method in class org.apache.jackrabbit.oak.plugins.observation.filter.Filters
A filter that matches if and only if any of the filters passed to this method matches.
any(List<EventFilter>) - Static method in class org.apache.jackrabbit.oak.plugins.observation.filter.Filters
A filter that matches if and only if any of the filters passed to this method matches.
anyOverflow() - Method in class org.apache.jackrabbit.oak.plugins.observation.ChangeSet
 
append(String, String) - Method in class org.apache.jackrabbit.oak.plugins.document.MemoryDiffCache.MemoryEntry
 
appendInCondition(StringBuilder, String, int, int) - Static method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBJDBCTools
Appends following SQL condition to the builder: ID in (?,?,?).
appendingUpdate(Connection, RDBDocumentStore.RDBTableMetaData, String, Long, boolean, Number, Boolean, Long, Long, Long, String) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStoreJDBC
 
appendJsonMap(StringBuilder, Map<Object, Object>) - Static method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBJSONSupport
 
appendJsonMember(StringBuilder, String, Object) - Static method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBJSONSupport
 
appendJsonString(StringBuilder, String) - Static method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBJSONSupport
 
appendJsonValue(StringBuilder, Object) - Static method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBJSONSupport
 
apply(NodeBuilder) - Method in class org.apache.jackrabbit.oak.plugins.index.importer.IndexDefinitionUpdater
 
apply(NodeBuilder, String) - Method in class org.apache.jackrabbit.oak.plugins.index.importer.IndexDefinitionUpdater
 
apply(Value) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.BooleanConstraint
 
apply(Value) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.NameConstraint
 
apply(Value) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.NumericConstraint
 
apply(Value) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.PathConstraint
 
apply(Value) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.ReferenceConstraint
 
apply(Value) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.StringConstraint
 
apply(String, Set<String>) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.TypePredicate
 
apply(Tree) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.TypePredicate
 
apply(NodeState) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.TypePredicate
 
apply(NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.PropertyPredicate
 
apply(NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.UuidPredicate
 
applyChanges(Document, UpdateOp) - Static method in class org.apache.jackrabbit.oak.plugins.document.UpdateUtils
Apply the changes to the in-memory document.
applyToCache(RevisionVector, boolean) - Method in class org.apache.jackrabbit.oak.plugins.document.Commit
Apply the changes to the DocumentNodeStore (to update the cache).
ApproximateCounter - Class in org.apache.jackrabbit.oak.plugins.index.counter
An approximate counter algorithm.
areAllDescendantsIncluded(String) - Method in class org.apache.jackrabbit.oak.plugins.index.PathFilter
Check whether this node and all descendants are included in this filter.
asBranchRevision() - Method in class org.apache.jackrabbit.oak.plugins.document.Revision
Returns a revision with the same timestamp, counter and clusterId as this revision and the branch flag set to true.
asBranchRevision(int) - Method in class org.apache.jackrabbit.oak.plugins.document.RevisionVector
A clone of this revision vector with the revision for the given clusterId set to a branch revision.
asBytes(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
ascending(DynamicOperandImpl) - Method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
 
asJson() - Method in interface org.apache.jackrabbit.oak.query.stats.QueryStatsMBean
 
asJson() - Method in class org.apache.jackrabbit.oak.query.stats.QueryStatsMBeanImpl
 
asLong(Number) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
Returns the given number instance as a Long.
asPropertyState() - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.DocumentBundlor
 
asPropertyState(String) - Method in class org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeBits
 
asPropertyState(PropertyDefinition) - Method in class org.apache.jackrabbit.oak.spi.xml.PropInfo
 
assertUnconditional(UpdateOp) - Static method in class org.apache.jackrabbit.oak.plugins.document.UpdateUtils
Ensures that the given UpdateOp is unconditional
asString() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState
 
asString() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState.Children
 
asString() - Method in class org.apache.jackrabbit.oak.plugins.document.LocalDiffCache.Diff
 
asString() - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
 
asString() - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument.Children
 
asString() - Method in class org.apache.jackrabbit.oak.plugins.document.PathRev
 
asString(Document) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentSerializer
Serializes all non-column properties of the Document into a JSON string.
asString(UpdateOp) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentSerializer
Serializes the changes in the UpdateOp into a JSON array; each entry is another JSON array holding operation, key, revision, and value.
asString() - Method in class org.apache.jackrabbit.oak.plugins.document.RevisionVector
Returns a string representation of this revision vector, which can be parsed again by RevisionVector.fromString(String).
asString() - Method in class org.apache.jackrabbit.oak.plugins.document.util.RevisionsKey
 
asString() - Method in class org.apache.jackrabbit.oak.plugins.document.util.StringValue
 
asString() - Method in class org.apache.jackrabbit.oak.plugins.observation.ChangeSet
 
asStringValueIterable(Iterable<String>) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
Transforms the given Iterable from String to StringValue elements.
AstElementFactory - Class in org.apache.jackrabbit.oak.query.ast
A factory for syntax tree elements.
AstElementFactory() - Constructor for class org.apache.jackrabbit.oak.query.ast.AstElementFactory
 
asTrunkRevision() - Method in class org.apache.jackrabbit.oak.plugins.document.Revision
Returns a revision with the same timestamp, counter and clusterId as this revision and the branch flag set to false.
asTrunkRevision() - Method in class org.apache.jackrabbit.oak.plugins.document.RevisionVector
Returns a revision vector where all revision elements are turned into trunk revisions.
AstVisitor - Interface in org.apache.jackrabbit.oak.query.ast
A visitor to access all elements.
AstVisitorBase - Class in org.apache.jackrabbit.oak.query.ast
The base class to visit all elements.
AstVisitorBase() - Constructor for class org.apache.jackrabbit.oak.query.ast.AstVisitorBase
 
ASYNC_PROPERTY_NAME - Static variable in interface org.apache.jackrabbit.oak.plugins.index.IndexConstants
 
ASYNC_REINDEX_VALUE - Static variable in interface org.apache.jackrabbit.oak.plugins.index.IndexConstants
 
AsyncIndexerLock<T extends AsyncIndexerLock.LockToken> - Interface in org.apache.jackrabbit.oak.plugins.index.importer
Lock used to prevent AsyncIndexUpdate from running when Index import is in progress
AsyncIndexerLock.LockToken - Interface in org.apache.jackrabbit.oak.plugins.index.importer
Marker interface.
AsyncIndexerService - Class in org.apache.jackrabbit.oak.plugins.index
 
AsyncIndexerService() - Constructor for class org.apache.jackrabbit.oak.plugins.index.AsyncIndexerService
 
AsyncIndexInfo - Class in org.apache.jackrabbit.oak.plugins.index
 
AsyncIndexInfo(String, long, long, boolean, IndexStatsMBean) - Constructor for class org.apache.jackrabbit.oak.plugins.index.AsyncIndexInfo
 
AsyncIndexInfoService - Interface in org.apache.jackrabbit.oak.plugins.index
 
AsyncIndexInfoServiceImpl - Class in org.apache.jackrabbit.oak.plugins.index
 
AsyncIndexInfoServiceImpl() - Constructor for class org.apache.jackrabbit.oak.plugins.index.AsyncIndexInfoServiceImpl
 
AsyncIndexInfoServiceImpl(NodeStore) - Constructor for class org.apache.jackrabbit.oak.plugins.index.AsyncIndexInfoServiceImpl
 
AsyncIndexUpdate - Class in org.apache.jackrabbit.oak.plugins.index
 
AsyncIndexUpdate(String, NodeStore, IndexEditorProvider, boolean) - Constructor for class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate
 
AsyncIndexUpdate(String, NodeStore, IndexEditorProvider, StatisticsProvider, boolean) - Constructor for class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate
 
AsyncIndexUpdate(String, NodeStore, IndexEditorProvider) - Constructor for class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate
 
AsyncIndexUpdate.AsyncUpdateCallback - Class in org.apache.jackrabbit.oak.plugins.index
Index update callback that tries to raise the async status flag when the first index change is detected.
AsyncLaneSwitcher - Class in org.apache.jackrabbit.oak.plugins.index.importer
Coordinates the switching of indexing lane for indexes which are to be imported.
AsyncLaneSwitcher() - Constructor for class org.apache.jackrabbit.oak.plugins.index.importer.AsyncLaneSwitcher
 
AsyncUpdateCallback(NodeStore, String, long, String, AsyncIndexUpdate.AsyncIndexStats, AtomicBoolean) - Constructor for class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate.AsyncUpdateCallback
 
AtomicCounterEditor - Class in org.apache.jackrabbit.oak.plugins.atomic
Manages a node as Atomic Counter: a node which will handle at low level a protected property (AtomicCounterEditor.PROP_COUNTER) in an atomic way.
AtomicCounterEditor(NodeBuilder, String, ScheduledExecutorService, NodeStore, Whiteboard) - Constructor for class org.apache.jackrabbit.oak.plugins.atomic.AtomicCounterEditor
Create an instance of the editor for atomic increments.
AtomicCounterEditor.ConsolidatorTask - Class in org.apache.jackrabbit.oak.plugins.atomic
 
AtomicCounterEditorProvider - Class in org.apache.jackrabbit.oak.plugins.atomic
Provide an instance of AtomicCounterEditor.
AtomicCounterEditorProvider() - Constructor for class org.apache.jackrabbit.oak.plugins.atomic.AtomicCounterEditorProvider
OSGi oriented constructor where all the required dependencies will be taken care of.
AtomicCounterEditorProvider(Supplier<Clusterable>, Supplier<ScheduledExecutorService>, Supplier<NodeStore>, Supplier<Whiteboard>) - Constructor for class org.apache.jackrabbit.oak.plugins.atomic.AtomicCounterEditorProvider
Plain Java oriented constructor.
authenticate(Credentials) - Method in interface org.apache.jackrabbit.oak.spi.security.authentication.Authentication
Validates the specified Credentials and returns true if the validation was successful.
Authentication - Interface in org.apache.jackrabbit.oak.spi.security.authentication
The Authentication interface defines methods to validate Credentials during the login step of the authentication process.
AuthenticationConfiguration - Interface in org.apache.jackrabbit.oak.spi.security.authentication
Interface for the authentication setup.
AuthenticationConfigurationImpl - Class in org.apache.jackrabbit.oak.security.authentication
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.
AuthenticationConfigurationImpl() - Constructor for class org.apache.jackrabbit.oak.security.authentication.AuthenticationConfigurationImpl
Constructor for OSGi
AuthenticationConfigurationImpl(SecurityProvider) - Constructor for class org.apache.jackrabbit.oak.security.authentication.AuthenticationConfigurationImpl
Constructor for non-OSGi
AuthInfoImpl - Class in org.apache.jackrabbit.oak.spi.security.authentication
Default implementation of the AuthInfo interface.
AuthInfoImpl(String, Map<String, ?>, Set<? extends Principal>) - Constructor for class org.apache.jackrabbit.oak.spi.security.authentication.AuthInfoImpl
 
AuthorizableAction - Interface in org.apache.jackrabbit.oak.spi.security.user.action
The AuthorizableAction interface provide an implementation specific way to execute additional validation or write tasks upon User creation, Group creation, Authorizable removal and User password modification.
AuthorizableActionProvider - Interface in org.apache.jackrabbit.oak.spi.security.user.action
AuthorizableActionProvider is used to provide AuthorizableActions for each instance of UserManager.
AuthorizableNodeName - Interface in org.apache.jackrabbit.oak.spi.security.user
The AuthorizableNodeName is in charge of generating a valid node name from a given authorizable ID.
AuthorizableNodeName.Default - Class in org.apache.jackrabbit.oak.spi.security.user
Default implementation of the AuthorizableNodeName interface that uses the specified authorizable identifier as node name escaping any illegal JCR chars.
AuthorizableType - Enum in org.apache.jackrabbit.oak.spi.security.user
The different authorizable types.
AuthorizationConfiguration - Interface in org.apache.jackrabbit.oak.spi.security.authorization
Configuration for access control management and permission evaluation.
AuthorizationConfigurationImpl - Class in org.apache.jackrabbit.oak.security.authorization
Default implementation of the AccessControlConfiguration.
AuthorizationConfigurationImpl() - Constructor for class org.apache.jackrabbit.oak.security.authorization.AuthorizationConfigurationImpl
 
AuthorizationConfigurationImpl(SecurityProvider) - Constructor for class org.apache.jackrabbit.oak.security.authorization.AuthorizationConfigurationImpl
 
autoCreateItems(Tree, Tree, Tree, String) - Static method in class org.apache.jackrabbit.oak.plugins.tree.TreeUtil
 
autoCreateProperty(String, Tree, String) - Static method in class org.apache.jackrabbit.oak.plugins.tree.TreeUtil
 
autoSave(boolean) - Method in class org.apache.jackrabbit.oak.security.user.autosave.AutoSaveEnabledManager
 
autoSave(boolean) - Method in class org.apache.jackrabbit.oak.security.user.UserManagerImpl
Changing the auto-save behavior is not supported by this implementation and this method always throws UnsupportedRepositoryOperationException
AutoSaveEnabledManager - Class in org.apache.jackrabbit.oak.security.user.autosave
Implementation of the user management that allows to set the autosave flag.
AutoSaveEnabledManager(UserManager, Root) - Constructor for class org.apache.jackrabbit.oak.security.user.autosave.AutoSaveEnabledManager
 

B

BaseDiffCollector - Class in org.apache.jackrabbit.oak.plugins.index.diffindex
 
BaseDiffCollector(NodeState, NodeState) - Constructor for class org.apache.jackrabbit.oak.plugins.index.diffindex.BaseDiffCollector
 
batchedAppendingUpdate(Connection, RDBDocumentStore.RDBTableMetaData, List<String>, Long, boolean, String) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStoreJDBC
 
beforeNonBlocking() - Method in class org.apache.jackrabbit.oak.plugins.observation.CommitRateLimiter
The current thread will now run code that must not be throttled or blocked, such as processing events (EventListener.onEvent is going to be called).
BESTEFFORT - Static variable in class org.apache.jackrabbit.oak.spi.xml.ImportBehavior
Same as ImportBehavior.IGNORE but in addition tries to circumvent the problem.
BinaryConstraint - Class in org.apache.jackrabbit.oak.plugins.nodetype.constraint
 
BinaryConstraint(String) - Constructor for class org.apache.jackrabbit.oak.plugins.nodetype.constraint.BinaryConstraint
 
bindAuthenticationConfiguration(AuthenticationConfiguration) - Method in class org.apache.jackrabbit.oak.security.internal.SecurityProviderRegistration
 
bindAuthenticationConfiguration(AuthenticationConfiguration) - Method in class org.apache.jackrabbit.oak.security.SecurityProviderImpl
 
bindAuthorizableActionProvider(AuthorizableActionProvider, Map<String, Object>) - Method in class org.apache.jackrabbit.oak.security.internal.SecurityProviderRegistration
 
bindAuthorizableNodeName(AuthorizableNodeName, Map<String, Object>) - Method in class org.apache.jackrabbit.oak.security.internal.SecurityProviderRegistration
 
bindAuthorizationConfiguration(AuthorizationConfiguration, Map<String, Object>) - Method in class org.apache.jackrabbit.oak.security.internal.SecurityProviderRegistration
 
bindAuthorizationConfiguration(AuthorizationConfiguration) - Method in class org.apache.jackrabbit.oak.security.SecurityProviderImpl
 
bindBlobDataSource(DataSource) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreService
 
bindBlobStore(BlobStore) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreService
 
bindCluster(Clusterable) - Method in class org.apache.jackrabbit.oak.plugins.atomic.AtomicCounterEditorProvider
 
bindCredentialsSupport(CredentialsSupport) - Method in class org.apache.jackrabbit.oak.security.authentication.token.TokenConfigurationImpl
 
bindDataSource(DataSource) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreService
 
bindDocumentNodeStore(DocumentNodeStore) - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.SecondaryStoreCacheService
 
bindInfoProviders(IndexInfoProvider) - Method in class org.apache.jackrabbit.oak.plugins.index.IndexInfoServiceImpl
 
bindNodeStateCache(DocumentNodeStateCache) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreService
 
bindNodeStoreProvider(NodeStoreProvider, Map<String, ?>) - Method in class org.apache.jackrabbit.oak.plugins.cow.COWNodeStoreService
 
bindPrincipalConfiguration(PrincipalConfiguration, Map<String, Object>) - Method in class org.apache.jackrabbit.oak.security.internal.SecurityProviderRegistration
 
bindPrincipalConfiguration(PrincipalConfiguration) - Method in class org.apache.jackrabbit.oak.security.SecurityProviderImpl
 
bindPrivilegeConfiguration(PrivilegeConfiguration) - Method in class org.apache.jackrabbit.oak.security.internal.SecurityProviderRegistration
 
bindPrivilegeConfiguration(PrivilegeConfiguration) - Method in class org.apache.jackrabbit.oak.security.SecurityProviderImpl
 
bindRestrictionProvider(RestrictionProvider, Map<String, Object>) - Method in class org.apache.jackrabbit.oak.security.internal.SecurityProviderRegistration
 
bindSelector(SourceImpl) - Method in class org.apache.jackrabbit.oak.query.ast.ChildNodeImpl
 
bindSelector(SourceImpl) - Method in class org.apache.jackrabbit.oak.query.ast.ChildNodeJoinConditionImpl
 
bindSelector(SourceImpl) - Method in class org.apache.jackrabbit.oak.query.ast.ColumnImpl
 
bindSelector(SourceImpl) - Method in class org.apache.jackrabbit.oak.query.ast.DescendantNodeImpl
 
bindSelector(SourceImpl) - Method in class org.apache.jackrabbit.oak.query.ast.DescendantNodeJoinConditionImpl
 
bindSelector(SourceImpl) - Method in class org.apache.jackrabbit.oak.query.ast.EquiJoinConditionImpl
 
bindSelector(SourceImpl) - Method in class org.apache.jackrabbit.oak.query.ast.FullTextSearchImpl
 
bindSelector(SourceImpl) - Method in class org.apache.jackrabbit.oak.query.ast.FullTextSearchScoreImpl
 
bindSelector(SourceImpl) - Method in class org.apache.jackrabbit.oak.query.ast.NativeFunctionImpl
 
bindSelector(SourceImpl) - Method in class org.apache.jackrabbit.oak.query.ast.NodeLocalNameImpl
 
bindSelector(SourceImpl) - Method in class org.apache.jackrabbit.oak.query.ast.NodeNameImpl
 
bindSelector(SourceImpl) - Method in class org.apache.jackrabbit.oak.query.ast.PropertyExistenceImpl
 
bindSelector(SourceImpl) - Method in class org.apache.jackrabbit.oak.query.ast.PropertyInexistenceImpl
 
bindSelector(SourceImpl) - Method in class org.apache.jackrabbit.oak.query.ast.PropertyValueImpl
 
bindSelector(SourceImpl) - Method in class org.apache.jackrabbit.oak.query.ast.SameNodeImpl
 
bindSelector(SourceImpl) - Method in class org.apache.jackrabbit.oak.query.ast.SameNodeJoinConditionImpl
 
bindSelector(SourceImpl) - Method in class org.apache.jackrabbit.oak.query.ast.SimilarImpl
 
bindSelector(SourceImpl) - Method in class org.apache.jackrabbit.oak.query.ast.SpellcheckImpl
 
bindSelector(SourceImpl) - Method in class org.apache.jackrabbit.oak.query.ast.SuggestImpl
 
bindStatsMBeans(IndexStatsMBean) - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexInfoServiceImpl
 
bindStore(NodeStore) - Method in class org.apache.jackrabbit.oak.plugins.atomic.AtomicCounterEditorProvider
 
bindTokenConfiguration(TokenConfiguration, Map<String, Object>) - Method in class org.apache.jackrabbit.oak.security.internal.SecurityProviderRegistration
 
bindTokenConfiguration(TokenConfiguration) - Method in class org.apache.jackrabbit.oak.security.SecurityProviderImpl
 
bindUserAuthenticationFactory(UserAuthenticationFactory, Map<String, Object>) - Method in class org.apache.jackrabbit.oak.security.internal.SecurityProviderRegistration
 
bindUserConfiguration(UserConfiguration) - Method in class org.apache.jackrabbit.oak.security.internal.SecurityProviderRegistration
 
bindUserConfiguration(UserConfiguration) - Method in class org.apache.jackrabbit.oak.security.SecurityProviderImpl
 
bindValue(String, PropertyValue) - Method in interface org.apache.jackrabbit.oak.query.Query
 
bindValue(String, PropertyValue) - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
bindValue(String, PropertyValue) - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
bindVariable(String) - Method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
 
BindVariableValueImpl - Class in org.apache.jackrabbit.oak.query.ast
A bind variable.
BindVariableValueImpl(String) - Constructor for class org.apache.jackrabbit.oak.query.ast.BindVariableValueImpl
 
BlobCache - Class in org.apache.jackrabbit.oak.plugins.document.persistentCache
A persistent blob cache.
BlobCache(PersistentCache, GarbageCollectableBlobStore) - Constructor for class org.apache.jackrabbit.oak.plugins.document.persistentCache.BlobCache
 
BlobCollector - Class in org.apache.jackrabbit.oak.plugins.document
 
BlobCollector(DocumentNodeStore) - Constructor for class org.apache.jackrabbit.oak.plugins.document.BlobCollector
 
BlobReferenceIterator - Class in org.apache.jackrabbit.oak.plugins.document
An iterator over all referenced binaries.
BlobReferenceIterator(DocumentNodeStore) - Constructor for class org.apache.jackrabbit.oak.plugins.document.BlobReferenceIterator
 
blockCommit() - Method in class org.apache.jackrabbit.oak.plugins.observation.CommitRateLimiter
 
blockCommits() - Method in class org.apache.jackrabbit.oak.plugins.observation.CommitRateLimiter
Block any further commits until CommitRateLimiter.unblockCommits() is called.
BooleanConstraint - Class in org.apache.jackrabbit.oak.plugins.nodetype.constraint
 
BooleanConstraint(String) - Constructor for class org.apache.jackrabbit.oak.plugins.nodetype.constraint.BooleanConstraint
 
branch(String) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK
 
BranchNodeStore - Class in org.apache.jackrabbit.oak.plugins.cow
 
BranchNodeStore(NodeStore) - Constructor for class org.apache.jackrabbit.oak.plugins.cow.BranchNodeStore
 
BROADCAST_ID - Static variable in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfo
The broadcast id.
BROADCAST_LISTENER - Static variable in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfo
The broadcast listener (host:port).
Broadcaster - Interface in org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast
A broadcast mechanism that is able to send and receive commands.
Broadcaster.Listener - Interface in org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast
A listener for new messages.
build() - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundledTypesRegistry.BundledTypesRegistryBuilder
 
build() - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundledTypesRegistry.BundledTypesRegistryBuilder.TypeBuilder
 
build() - Method in interface org.apache.jackrabbit.oak.plugins.document.spi.JournalPropertyBuilder
Constructs a JournalProperty instance based on current builder state
build() - Method in class org.apache.jackrabbit.oak.plugins.observation.ChangeSetBuilder
 
build() - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder
Create a FilterProvider reflecting the current state of this builder.
buildAlternativeQuery() - Method in interface org.apache.jackrabbit.oak.query.Query
Try to convert the query to an alternative form, specially a "union".
buildAlternativeQuery() - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
buildAlternativeQuery() - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
buildAsString() - Method in interface org.apache.jackrabbit.oak.plugins.document.spi.JournalPropertyBuilder
Returns a string representation state of the builder which would be stored in JournalEntry
buildCache() - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.SecondaryStoreBuilder
 
buildChildrenCache(DocumentNodeStore) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
buildDocumentCache(DocumentStore) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
builder() - Static method in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundledTypesRegistry
 
Builder() - Constructor for class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
builder() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState
 
builder() - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.DelegatingDocumentNodeState
 
buildIndexNode(NodeBuilder) - Static method in class org.apache.jackrabbit.oak.plugins.name.Namespaces
 
buildLocalDiffCache() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
buildMemoryDiffCache() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
buildNodeCache(DocumentNodeStore) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
buildNodeDocumentCache(DocumentStore, NodeDocumentLocks) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
buildObserver() - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.SecondaryStoreBuilder
 
buildObserver(SecondaryStoreRootObserver) - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.SecondaryStoreBuilder
 
buildPasswordHash(String) - Static method in class org.apache.jackrabbit.oak.spi.security.user.util.PasswordUtil
Generates a hash of the specified password with the default values for algorithm, salt-size and number of iterations.
buildPasswordHash(String, String, int, int) - Static method in class org.apache.jackrabbit.oak.spi.security.user.util.PasswordUtil
Generates a hash of the specified password using the specified algorithm, salt size and number of iterations into account.
buildPasswordHash(String, ConfigurationParameters) - Static method in class org.apache.jackrabbit.oak.spi.security.user.util.PasswordUtil
Same as PasswordUtil.buildPasswordHash(String, String, int, int) but retrieving the parameters for hash generation from the specified configuration.
buildPath(StringBuilder) - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractTree
 
buildPrevDocumentsCache(DocumentStore) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
buildRegistry() - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundledTypesRegistry.BundledTypesRegistryBuilder
 
buildRegistry() - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundledTypesRegistry.BundledTypesRegistryBuilder.TypeBuilder
 
BUILT_IN - Static variable in class org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeBits
 
BundledDocumentDiffer - Class in org.apache.jackrabbit.oak.plugins.document.bundlor
 
BundledDocumentDiffer(DocumentNodeStore) - Constructor for class org.apache.jackrabbit.oak.plugins.document.bundlor.BundledDocumentDiffer
 
BundledTypesRegistry - Class in org.apache.jackrabbit.oak.plugins.document.bundlor
 
BundledTypesRegistry(Map<String, DocumentBundlor>) - Constructor for class org.apache.jackrabbit.oak.plugins.document.bundlor.BundledTypesRegistry
 
BundledTypesRegistry.BundledTypesRegistryBuilder - Class in org.apache.jackrabbit.oak.plugins.document.bundlor
 
BundledTypesRegistry.BundledTypesRegistryBuilder.TypeBuilder - Class in org.apache.jackrabbit.oak.plugins.document.bundlor
 
BundledTypesRegistryBuilder(NodeBuilder) - Constructor for class org.apache.jackrabbit.oak.plugins.document.bundlor.BundledTypesRegistry.BundledTypesRegistryBuilder
 
BundlingConfigHandler - Class in org.apache.jackrabbit.oak.plugins.document.bundlor
 
BundlingConfigHandler() - Constructor for class org.apache.jackrabbit.oak.plugins.document.bundlor.BundlingConfigHandler
 
BundlingConfigInitializer - Enum in org.apache.jackrabbit.oak.plugins.document.bundlor
 
BundlingHandler - Class in org.apache.jackrabbit.oak.plugins.document.bundlor
 
BundlingHandler(BundledTypesRegistry) - Constructor for class org.apache.jackrabbit.oak.plugins.document.bundlor.BundlingHandler
 
BUNDLOR - Static variable in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundlingConfigHandler
 
BUNDLOR_META_PROP_PREFIX - Static variable in class org.apache.jackrabbit.oak.plugins.document.bundlor.DocumentBundlor
Prefix used for various meta properties used for bundling
BundlorUtils - Class in org.apache.jackrabbit.oak.plugins.document.bundlor
 
BundlorUtils() - Constructor for class org.apache.jackrabbit.oak.plugins.document.bundlor.BundlorUtils
 

C

CacheActionDispatcher - Class in org.apache.jackrabbit.oak.plugins.document.persistentCache.async
An asynchronous buffer of the CacheAction objects.
CacheActionDispatcher() - Constructor for class org.apache.jackrabbit.oak.plugins.document.persistentCache.async.CacheActionDispatcher
 
CacheChangesTracker - Class in org.apache.jackrabbit.oak.plugins.document.cache
 
CacheChangesTracker.LazyBloomFilter - Class in org.apache.jackrabbit.oak.plugins.document.cache
 
cacheInfoAsString() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
CacheInvalidationStats - Interface in org.apache.jackrabbit.oak.plugins.document.cache
 
CacheMap<K,V> - Class in org.apache.jackrabbit.oak.plugins.document.persistentCache
A cache map.
CacheMap(MapFactory, String, MVMap.Builder<K, V>) - Constructor for class org.apache.jackrabbit.oak.plugins.document.persistentCache.CacheMap
 
CacheMetadata<K> - Class in org.apache.jackrabbit.oak.plugins.document.persistentCache
In order to avoid leaking values from the metadataMap, following order should be maintained for combining the cache and CacheMetadata: 1.
CacheMetadata() - Constructor for class org.apache.jackrabbit.oak.plugins.document.persistentCache.CacheMetadata
 
CacheType - Enum in org.apache.jackrabbit.oak.plugins.document.persistentCache
 
CacheWriteQueue<K,V> - Class in org.apache.jackrabbit.oak.plugins.document.persistentCache.async
 
CacheWriteQueue(CacheActionDispatcher, PersistentCache, Map<K, V>) - Constructor for class org.apache.jackrabbit.oak.plugins.document.persistentCache.async.CacheWriteQueue
 
calculateOffset(long, int) - Static method in class org.apache.jackrabbit.oak.plugins.index.counter.ApproximateCounter
Calculate the approximate offset from a given offset.
calculatePermissions(PrivilegeBits, PrivilegeBits, boolean) - Static method in class org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeBits
Calculate the granted permissions by evaluating the given privileges.
calculateVersion(NodeBuilder, NodeBuilder) - Method in class org.apache.jackrabbit.oak.plugins.version.ReadWriteVersionManager
Copied from Apache Jackrabbit Core
call() - Method in class org.apache.jackrabbit.oak.plugins.atomic.AtomicCounterEditor.ConsolidatorTask
 
call() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.replica.GetRootRevisionsCallable
 
callbackHandler - Variable in class org.apache.jackrabbit.oak.spi.security.authentication.AbstractLoginModule
 
cancel() - Method in class org.apache.jackrabbit.oak.plugins.document.VersionGarbageCollector
 
cancelRevisionGC() - Method in class org.apache.jackrabbit.oak.management.RepositoryManager
 
cancelRevisionGCForRole(String) - Method in class org.apache.jackrabbit.oak.management.RepositoryManager
 
canConvert(int, int) - Static method in class org.apache.jackrabbit.oak.query.ValueConverter
 
canEvaluate(Set<SourceImpl>) - Method in class org.apache.jackrabbit.oak.query.ast.ChildNodeJoinConditionImpl
 
canEvaluate(Set<SourceImpl>) - Method in class org.apache.jackrabbit.oak.query.ast.DescendantNodeJoinConditionImpl
 
canEvaluate(Set<SourceImpl>) - Method in class org.apache.jackrabbit.oak.query.ast.EquiJoinConditionImpl
 
canEvaluate(Set<SourceImpl>) - Method in class org.apache.jackrabbit.oak.query.ast.JoinConditionImpl
Whether the join condition can be evaluated if the given selectors are able to retrieve data.
canEvaluate(Set<SourceImpl>) - Method in class org.apache.jackrabbit.oak.query.ast.SameNodeJoinConditionImpl
 
canRead(FormatVersion) - Method in class org.apache.jackrabbit.oak.plugins.document.FormatVersion
Returns true if this version can read data written by the other version.
canRead() - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.TreePermission
Return if read access is granted for the Tree associated with this TreePermission instance.
canRead(PropertyState) - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.TreePermission
Return if read access is granted for the property of the Tree for which this TreePermission instance has been created.
canReadAll() - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.TreePermission
Returns true if read access is granted to the Tree associated with this instance and the whole subtree defined by it including all properties.
canReadProperties() - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.TreePermission
Returns true if all properties of the Tree associated with this instance can be read.
canRestrictSelector(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.DynamicOperandImpl
Check whether the condition can be applied to a selector (to restrict the selector).
canRestrictSelector(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.FullTextSearchScoreImpl
 
canRestrictSelector(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.LengthImpl
 
canRestrictSelector(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.LowerCaseImpl
 
canRestrictSelector(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.NodeLocalNameImpl
 
canRestrictSelector(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.NodeNameImpl
 
canRestrictSelector(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.PropertyValueImpl
 
canRestrictSelector(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.UpperCaseImpl
 
castAuthorizable(Authorizable, Class<T>) - Static method in class org.apache.jackrabbit.oak.spi.security.user.util.UserUtil
 
ch - Variable in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBBlobStore
 
changeChangedProperty(NodeBuilder, PropertyState, PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.commit.AnnotatingConflictHandler
 
changeChangedProperty(NodeBuilder, PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.commit.ChildOrderConflictHandler
 
changeChangedProperty(NodeBuilder, PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.commit.DefaultConflictHandler
Deprecated.
 
changeChangedProperty(NodeBuilder, PropertyState, PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.commit.DefaultThreeWayConflictHandler
 
changeChangedProperty(NodeBuilder, PropertyState, PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.commit.JcrLastModifiedConflictHandler
 
changeChangedProperty(NodeBuilder, PropertyState, PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.security.user.RepMembersConflictHandler
 
ChangeCollectorProvider - Class in org.apache.jackrabbit.oak.plugins.observation
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.
ChangeCollectorProvider() - Constructor for class org.apache.jackrabbit.oak.plugins.observation.ChangeCollectorProvider
 
changed(String, Set<String>, Set<String>, Set<String>, Map<String, String>, CommitInfo) - Method in class org.apache.jackrabbit.oak.plugins.observation.NodeObserver
A node at path has been changed.
changeDeletedNode(NodeBuilder, String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.commit.AnnotatingConflictHandler
 
changeDeletedNode(NodeBuilder, String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.commit.ChildOrderConflictHandler
 
changeDeletedNode(NodeBuilder, String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.commit.DefaultConflictHandler
Deprecated.
 
changeDeletedNode(NodeBuilder, String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.commit.DefaultThreeWayConflictHandler
 
changeDeletedNode(NodeBuilder, String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.security.user.RepMembersConflictHandler
 
changeDeletedProperty(NodeBuilder, PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.commit.AnnotatingConflictHandler
 
changeDeletedProperty(NodeBuilder, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.commit.ChildOrderConflictHandler
 
changeDeletedProperty(NodeBuilder, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.commit.DefaultConflictHandler
Deprecated.
 
changeDeletedProperty(NodeBuilder, PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.commit.DefaultThreeWayConflictHandler
 
changeDeletedProperty(NodeBuilder, PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.security.user.RepMembersConflictHandler
 
ChangeSet - Class in org.apache.jackrabbit.oak.plugins.observation
A ChangeSet is a collection of items that have been changed as part of a commit.
ChangeSetBuilder - Class in org.apache.jackrabbit.oak.plugins.observation
Builder of a ChangeSet - only used by ChangeCollectorProvider (and tests..)
ChangeSetBuilder(int, int) - Constructor for class org.apache.jackrabbit.oak.plugins.observation.ChangeSetBuilder
 
ChangeSetFilter - Interface in org.apache.jackrabbit.oak.plugins.observation.filter
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 - Class in org.apache.jackrabbit.oak.plugins.observation.filter
 
ChangeSetFilterImpl(Set<String>, boolean, Set<String>, Set<String>, Set<String>, Set<String>, Set<String>) - Constructor for class org.apache.jackrabbit.oak.plugins.observation.filter.ChangeSetFilterImpl
 
ChangeSetFilterImpl(Set<String>, boolean, Set<String>, Set<String>, Set<String>, Set<String>, Set<String>, int) - Constructor for class org.apache.jackrabbit.oak.plugins.observation.filter.ChangeSetFilterImpl
 
CHAR2OCTETRATIO - Static variable in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
checkACLPath(NodeBuilder, String) - Static method in class org.apache.jackrabbit.oak.security.authorization.permission.PermissionUtil
 
checkACLPath(Tree, String) - Static method in class org.apache.jackrabbit.oak.security.authorization.permission.PermissionUtil
 
checkConditions(Document, Map<UpdateOp.Key, UpdateOp.Condition>) - Static method in class org.apache.jackrabbit.oak.plugins.document.UpdateUtils
 
checkin(NodeBuilder) - Method in class org.apache.jackrabbit.oak.plugins.version.ReadWriteVersionManager
 
checkMandatoryItems(Tree) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.EffectiveNodeType
 
checkMemoryLimit(long, QueryLimits) - Static method in class org.apache.jackrabbit.oak.query.FilterIterators
Verify the number of in-memory nodes is below the limit.
checkName(String, boolean) - Static method in class org.apache.jackrabbit.oak.namepath.JcrNameParser
 
checkOrderableChildNodes() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.EffectiveNodeType
 
checkout(NodeBuilder) - Method in class org.apache.jackrabbit.oak.plugins.version.ReadWriteVersionManager
 
checkpoint(long) - Method in class org.apache.jackrabbit.oak.management.RepositoryManager
 
checkpoint(long, Map<String, String>) - Method in class org.apache.jackrabbit.oak.plugins.cow.BranchNodeStore
 
checkpoint(long) - Method in class org.apache.jackrabbit.oak.plugins.cow.BranchNodeStore
 
checkpoint(long, Map<String, String>) - Method in class org.apache.jackrabbit.oak.plugins.cow.COWNodeStore
 
checkpoint(long) - Method in class org.apache.jackrabbit.oak.plugins.cow.COWNodeStore
 
checkpoint(long) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK
 
checkpoint(long, Map<String, String>) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
checkpoint(long) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
checkpoint - Variable in class org.apache.jackrabbit.oak.plugins.index.importer.IndexerInfo
 
CHECKPOINT_CREATION_TIME - Static variable in interface org.apache.jackrabbit.oak.plugins.index.IndexConstants
CommitInfo attribute name which refers to the time at which async index checkpoint is created i.e.
checkpointInfo(String) - Method in class org.apache.jackrabbit.oak.plugins.cow.BranchNodeStore
 
checkpointInfo(String) - Method in class org.apache.jackrabbit.oak.plugins.cow.COWNodeStore
 
checkpointInfo(String) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
checkpoints() - Method in class org.apache.jackrabbit.oak.plugins.cow.BranchNodeStore
 
checkpoints() - Method in class org.apache.jackrabbit.oak.plugins.cow.COWNodeStore
 
checkpoints() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
checkReadLimit(long, QueryLimits) - Static method in class org.apache.jackrabbit.oak.query.FilterIterators
Verify the number of node read operations is below the limit.
checkRemoveProperty(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.EffectiveNodeType
 
checkSetProperty(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.EffectiveNodeType
 
checkValidName(String) - Static method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate
 
checkVersion() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoStatus
 
checkVersion(DatabaseMetaData) - Method in enum org.apache.jackrabbit.oak.plugins.document.rdb.RDBBlobStoreDB
 
checkVersion(DatabaseMetaData) - Method in enum org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStoreDB
Check the database brand and version
checkVersionable(Tree) - Method in class org.apache.jackrabbit.oak.plugins.version.ReadOnlyVersionManager
Checks if the given tree is versionable and throws a UnsupportedRepositoryOperationException if it is not.
childAdded(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundlingHandler
 
childChanged(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundlingHandler
 
childDeleted(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundlingHandler
 
childNode(String, String) - Method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
 
childNodeAdded(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.atomic.AtomicCounterEditor
 
childNodeAdded(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.commit.ConflictValidator
 
childNodeAdded(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.commit.MergingNodeStateDiff
 
childNodeAdded(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.document.util.CountingDiff
 
childNodeAdded(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.index.counter.NodeCounterEditor
 
childNodeAdded(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.index.IndexUpdate
 
childNodeAdded(String, NodeState) - Method in class org.apache.jackrabbit.oak.security.authorization.permission.MoveAwarePermissionValidator
 
childNodeChanged(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.atomic.AtomicCounterEditor
 
childNodeChanged(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.commit.ConflictValidator
 
childNodeChanged(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.commit.MergingNodeStateDiff
 
childNodeChanged(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.document.util.CountingDiff
 
childNodeChanged(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.index.counter.NodeCounterEditor
 
childNodeChanged(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.index.IndexUpdate
 
childNodeDeleted(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.commit.ConflictValidator
 
childNodeDeleted(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.document.util.CountingDiff
 
childNodeDeleted(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.index.counter.NodeCounterEditor
 
childNodeDeleted(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.index.IndexUpdate
 
childNodeDeleted(String, NodeState) - Method in class org.apache.jackrabbit.oak.security.authorization.permission.MoveAwarePermissionValidator
 
ChildNodeImpl - Class in org.apache.jackrabbit.oak.query.ast
The "ischildnode(...)" condition.
ChildNodeImpl(String, String) - Constructor for class org.apache.jackrabbit.oak.query.ast.ChildNodeImpl
 
childNodeJoinCondition(String, String) - Method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
 
ChildNodeJoinConditionImpl - Class in org.apache.jackrabbit.oak.query.ast
The "ischildnode(...)" join condition.
ChildNodeJoinConditionImpl(String, String) - Constructor for class org.apache.jackrabbit.oak.query.ast.ChildNodeJoinConditionImpl
 
ChildOrderConflictHandler - Class in org.apache.jackrabbit.oak.plugins.commit
This conflict handler instance takes care of properly merging conflicts occurring by concurrent reorder operations.
ChildOrderConflictHandler() - Constructor for class org.apache.jackrabbit.oak.plugins.commit.ChildOrderConflictHandler
 
ChildOrderDiff - Class in org.apache.jackrabbit.oak.plugins.tree.impl
Helper class to handle modifications to the hidden TreeConstants.OAK_CHILD_ORDER property.
Children() - Constructor for class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState.Children
 
Children() - Constructor for class org.apache.jackrabbit.oak.plugins.document.NodeDocument.Children
 
clear() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.CacheMap
 
clear() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.MultiGenerationMap
 
clear() - Method in class org.apache.jackrabbit.oak.spi.security.ConfigurationParameters
clear() - Method in class org.apache.jackrabbit.oak.spi.xml.ReferenceChangeTracker
Resets all internal state.
clearCache() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.BlobCache
 
clearInUse() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.BlobCache
 
ClearMembershipAction - Class in org.apache.jackrabbit.oak.spi.security.user.action
Authorizable action attempting to clear all group membership before removing the specified authorizable.
ClearMembershipAction() - Constructor for class org.apache.jackrabbit.oak.spi.security.user.action.ClearMembershipAction
 
clearState() - Method in class org.apache.jackrabbit.oak.security.authentication.token.TokenLoginModule
 
clearState() - Method in class org.apache.jackrabbit.oak.security.authentication.user.LoginModuleImpl
 
clearState() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.AbstractLoginModule
Clear state information that has been created during LoginModule.login().
clock(Clock) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
clock - Variable in class org.apache.jackrabbit.oak.plugins.document.MissingLastRevSeeker
 
clone() - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument.Children
 
close() - Method in class org.apache.jackrabbit.oak.core.ContentRepositoryImpl
 
close() - Method in class org.apache.jackrabbit.oak.plugins.document.BlobReferenceIterator
 
close() - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundlingConfigHandler
 
close() - Method in class org.apache.jackrabbit.oak.plugins.document.cache.CacheChangesTracker
 
close() - Method in class org.apache.jackrabbit.oak.plugins.document.cache.NodeDocumentCache
 
close() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.replica.NodeCollectionProvider
 
close() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.BlobCache
 
close() - Method in interface org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast.Broadcaster
Close the broadcaster.
close() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast.InMemoryBroadcaster
 
close() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast.TCPBroadcaster
 
close() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast.UDPBroadcaster
 
close() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCache
 
close() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBBlobStore
 
close() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBConnectionHandler
 
close() - Method in class org.apache.jackrabbit.oak.plugins.document.SplitDocumentCleanUp
 
close() - Method in class org.apache.jackrabbit.oak.plugins.document.util.CloseableIterable
 
close() - Method in class org.apache.jackrabbit.oak.plugins.document.util.CloseableIterator
 
close() - Method in class org.apache.jackrabbit.oak.plugins.document.util.MongoConnection
Closes the underlying Mongo instance
close() - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate
 
close() - Method in class org.apache.jackrabbit.oak.plugins.index.datastore.DataStoreTextWriter
 
close() - Method in class org.apache.jackrabbit.oak.plugins.metric.MetricStatisticsProvider
 
close() - Method in class org.apache.jackrabbit.oak.plugins.observation.FilteringObserver
 
CloseableIterable<T> - Class in org.apache.jackrabbit.oak.plugins.document.util
 
CloseableIterable(Iterable<T>, Closeable) - Constructor for class org.apache.jackrabbit.oak.plugins.document.util.CloseableIterable
 
CloseableIterator<T> - Class in org.apache.jackrabbit.oak.plugins.document.util
 
CloseableIterator(Iterator<T>, Closeable) - Constructor for class org.apache.jackrabbit.oak.plugins.document.util.CloseableIterator
 
closeConnection(Connection) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBConnectionHandler
Close the Connection.
closeIfCloseable(Object) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
Closes the obj its of type Closeable.
closeResultSet(ResultSet) - Static method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBJDBCTools
Closes a ResultSet, logging potential problems.
closeStatement(T) - Static method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBJDBCTools
Closes a Statement, logging potential problems.
CLUSTER_NODES - Static variable in class org.apache.jackrabbit.oak.plugins.document.Collection
The 'clusterNodes' collection contains the list of currently running cluster nodes.
ClusterNodeInfo - Class in org.apache.jackrabbit.oak.plugins.document
Information about a cluster node.
ClusterNodeInfo.ClusterNodeState - Enum in org.apache.jackrabbit.oak.plugins.document
 
ClusterNodeInfo.RecoverLockState - Enum in org.apache.jackrabbit.oak.plugins.document
 
ClusterNodeInfoDocument - Class in org.apache.jackrabbit.oak.plugins.document
A document storing cluster node info.
ClusterNodeInfoDocument() - Constructor for class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfoDocument
 
ClusterNodeStoreLock - Class in org.apache.jackrabbit.oak.plugins.index.importer
Lock implementation for clustered scenario.
ClusterNodeStoreLock(NodeStore) - Constructor for class org.apache.jackrabbit.oak.plugins.index.importer.ClusterNodeStoreLock
 
ClusterNodeStoreLock(NodeStore, Clock) - Constructor for class org.apache.jackrabbit.oak.plugins.index.importer.ClusterNodeStoreLock
 
ClusterStateChangeListener - Interface in org.apache.jackrabbit.oak.plugins.document
DocumentNS-internal listener that gets invoked when a change in the clusterNodes collection (active/inactive/timed out/recovering) is detected.
collect(NodeDocument, Collection<ReferencedBlob>) - Method in class org.apache.jackrabbit.oak.plugins.document.BlobCollector
 
collect(Filter) - Method in class org.apache.jackrabbit.oak.plugins.index.diffindex.BaseDiffCollector
 
collect(Filter) - Method in class org.apache.jackrabbit.oak.plugins.index.diffindex.UUIDDiffCollector
 
collectCheckpoints(TabularDataSupport) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentCheckpointMBean
 
collectIdToBeDeleted(String) - Method in class org.apache.jackrabbit.oak.plugins.document.SplitDocumentCleanUp
Collects document IDs for subsequent deletion.
Collection<T extends Document> - Class in org.apache.jackrabbit.oak.plugins.document
The collection types.
Collection(String) - Constructor for class org.apache.jackrabbit.oak.plugins.document.Collection
 
COLLECTION_BLOBS - Static variable in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoBlobStore
 
collectLimit - Variable in class org.apache.jackrabbit.oak.plugins.document.VersionGarbageCollector.VersionGCInfo
 
collectLimit - Variable in class org.apache.jackrabbit.oak.plugins.document.VersionGCOptions
 
collectReferences(ReferenceCollector) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentBlobReferenceRetriever
 
COLLISIONS - Static variable in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
Revision collision markers set by commits with modifications, which overlap with un-merged branch commits.
COLLISIONSMODCOUNT - Static variable in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
Optional counter for changes to "_collisions" map (NodeDocument.COLLISIONS).
column(String, String, String) - Method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
 
ColumnImpl - Class in org.apache.jackrabbit.oak.query.ast
A result column expression.
ColumnImpl(String, String, String) - Constructor for class org.apache.jackrabbit.oak.query.ast.ColumnImpl
 
commit(Map<String, Object>) - Method in class org.apache.jackrabbit.oak.core.ImmutableRoot
 
commit() - Method in class org.apache.jackrabbit.oak.core.ImmutableRoot
 
Commit - Class in org.apache.jackrabbit.oak.plugins.document
A higher level object representing a commit.
commit(String, String, String, String) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK
 
commit() - Method in class org.apache.jackrabbit.oak.security.authentication.token.TokenLoginModule
 
commit() - Method in class org.apache.jackrabbit.oak.security.authentication.user.LoginModuleImpl
 
commit() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.GuestLoginModule
 
COMMIT_CONTEXT_OBSERVATION_CHANGESET - Static variable in class org.apache.jackrabbit.oak.plugins.observation.ChangeCollectorProvider
 
commitProgress(IndexCommitCallback.IndexProgress) - Method in interface org.apache.jackrabbit.oak.plugins.index.IndexCommitCallback
 
commitProgress(IndexCommitCallback.IndexProgress) - Method in class org.apache.jackrabbit.oak.plugins.index.IndexUpdate
 
commitQueue - Variable in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
The commit queue to coordinate the commits.
CommitRateLimiter - Class in org.apache.jackrabbit.oak.plugins.observation
This CommitHook can be used to block or delay commits for any length of time.
CommitRateLimiter() - Constructor for class org.apache.jackrabbit.oak.plugins.observation.CommitRateLimiter
 
compare(AbstractDocumentNodeState, AbstractDocumentNodeState, NodeStateDiff) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
Compares the given node against the base state and reports the differences to the NodeStateDiff.
compare(String, String) - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocumentIdComparator
 
compare(AbstractDocumentNodeState, AbstractDocumentNodeState, NodeStateDiff) - Method in interface org.apache.jackrabbit.oak.plugins.document.NodeStateDiffer
Compares the given node against the base state and reports the differences to the NodeStateDiff.
compare(String, String) - Method in class org.apache.jackrabbit.oak.plugins.document.PathComparator
 
compare(Object, Object) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.KeyDataType
 
compare(Object, Object) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.ValueDataType
 
compare(Revision, Revision) - Method in class org.apache.jackrabbit.oak.plugins.document.StableRevisionComparator
 
compareAgainstBaseState(NodeState, NodeStateDiff) - Method in class org.apache.jackrabbit.oak.plugins.document.AbstractDocumentNodeState
 
compareKeys(K, K) - Method in enum org.apache.jackrabbit.oak.plugins.document.persistentCache.CacheType
 
compareTo(FormatVersion) - Method in class org.apache.jackrabbit.oak.plugins.document.FormatVersion
 
compareTo(PathRev) - Method in class org.apache.jackrabbit.oak.plugins.document.PathRev
 
compareTo(RevisionVector) - Method in class org.apache.jackrabbit.oak.plugins.document.RevisionVector
 
compareTo(RevisionsKey) - Method in class org.apache.jackrabbit.oak.plugins.document.util.RevisionsKey
 
comparison(DynamicOperandImpl, Operator, StaticOperandImpl) - Method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
 
ComparisonImpl - Class in org.apache.jackrabbit.oak.query.ast
A comparison operation (including "like").
ComparisonImpl(DynamicOperandImpl, Operator, StaticOperandImpl) - Constructor for class org.apache.jackrabbit.oak.query.ast.ComparisonImpl
 
compose(Collection<IndexEditorProvider>) - Static method in class org.apache.jackrabbit.oak.plugins.index.CompositeIndexEditorProvider
 
CompositeActionProvider - Class in org.apache.jackrabbit.oak.spi.security.user.action
Aggregates a collection of AuthorizableActionProviders into a single provider.
CompositeActionProvider(Collection<? extends AuthorizableActionProvider>) - Constructor for class org.apache.jackrabbit.oak.spi.security.user.action.CompositeActionProvider
 
CompositeActionProvider(AuthorizableActionProvider...) - Constructor for class org.apache.jackrabbit.oak.spi.security.user.action.CompositeActionProvider
 
CompositeAuthorizationConfiguration - Class in org.apache.jackrabbit.oak.security.authorization.composite
CompositeAuthorizationConfiguration that combines different authorization models.
CompositeAuthorizationConfiguration() - Constructor for class org.apache.jackrabbit.oak.security.authorization.composite.CompositeAuthorizationConfiguration
 
CompositeAuthorizationConfiguration(SecurityProvider) - Constructor for class org.apache.jackrabbit.oak.security.authorization.composite.CompositeAuthorizationConfiguration
 
CompositeAuthorizationConfiguration.CompositionType - Enum in org.apache.jackrabbit.oak.security.authorization.composite
 
CompositeConfiguration<T extends SecurityConfiguration> - Class in org.apache.jackrabbit.oak.spi.security
Abstract base implementation for SecurityConfigurations that can combine different implementations.
CompositeConfiguration(String) - Constructor for class org.apache.jackrabbit.oak.spi.security.CompositeConfiguration
 
CompositeConfiguration(String, SecurityProvider) - Constructor for class org.apache.jackrabbit.oak.spi.security.CompositeConfiguration
 
CompositeIndexEditorProvider - Class in org.apache.jackrabbit.oak.plugins.index
Aggregation of a list of editor providers into a single provider.
CompositeIndexEditorProvider(IndexEditorProvider...) - Constructor for class org.apache.jackrabbit.oak.plugins.index.CompositeIndexEditorProvider
 
CompositePattern - Class in org.apache.jackrabbit.oak.spi.security.authorization.restriction
Aggregates of a list of RestrictionPatterns into a single pattern.
CompositePattern(List<RestrictionPattern>) - Constructor for class org.apache.jackrabbit.oak.spi.security.authorization.restriction.CompositePattern
 
CompositePrincipalConfiguration - Class in org.apache.jackrabbit.oak.spi.security.principal
PrincipalConfiguration that combines different principal provider implementations that share a common principal manager implementation.
CompositePrincipalConfiguration() - Constructor for class org.apache.jackrabbit.oak.spi.security.principal.CompositePrincipalConfiguration
 
CompositePrincipalConfiguration(SecurityProvider) - Constructor for class org.apache.jackrabbit.oak.spi.security.principal.CompositePrincipalConfiguration
 
CompositePrincipalProvider - Class in org.apache.jackrabbit.oak.spi.security.principal
PrincipalProvider implementation that aggregates a list of principal providers into a single.
CompositePrincipalProvider(List<PrincipalProvider>) - Constructor for class org.apache.jackrabbit.oak.spi.security.principal.CompositePrincipalProvider
 
CompositeRestrictionProvider - Class in org.apache.jackrabbit.oak.spi.security.authorization.restriction
Aggregates of a collection of RestrictionProvider implementations into a single provider.
CompositeTokenConfiguration - Class in org.apache.jackrabbit.oak.spi.security.authentication.token
TokenConfiguration that combines different token provider implementations.
CompositeTokenConfiguration() - Constructor for class org.apache.jackrabbit.oak.spi.security.authentication.token.CompositeTokenConfiguration
 
CompositeTokenConfiguration(SecurityProvider) - Constructor for class org.apache.jackrabbit.oak.spi.security.authentication.token.CompositeTokenConfiguration
 
CompositeTokenProvider - Class in org.apache.jackrabbit.oak.spi.security.authentication.token
Aggregates a collection of TokenProviders into a single provider.
computeNext() - Method in class org.apache.jackrabbit.oak.plugins.document.BlobReferenceIterator
 
condition(FilterBuilder.Condition) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder
Set the condition of this filter.
CONFIG_PATH - Static variable in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundlingConfigHandler
 
ConfigurationBase - Class in org.apache.jackrabbit.oak.spi.security
Abstract base implementation for the various security configurations.
ConfigurationBase() - Constructor for class org.apache.jackrabbit.oak.spi.security.ConfigurationBase
osgi constructor
ConfigurationBase(SecurityProvider, ConfigurationParameters) - Constructor for class org.apache.jackrabbit.oak.spi.security.ConfigurationBase
non-osgi constructor
ConfigurationParameters - Class in org.apache.jackrabbit.oak.spi.security
ConfigurationParameters is a convenience class that allows typed access to configuration properties.
ConfigurationParameters.Milliseconds - Class in org.apache.jackrabbit.oak.spi.security
Helper class for configuration parameters that denote a "duration", such as a timeout or expiration time.
CONFIGURATIONS_PATH - Static variable in interface org.apache.jackrabbit.oak.plugins.version.VersionConstants
Quote from JSR 283 Section "15.13.2 Configuration Proxy Nodes"
ConfigurationUtil - Class in org.apache.jackrabbit.oak.spi.security.authentication
Utility to create Configurations for built-in LoginModule implementations.
ConflictHook - Class in org.apache.jackrabbit.oak.plugins.commit
This commit hook implementation is responsible for resolving conflicts.
ConflictHook(ThreeWayConflictHandler) - Constructor for class org.apache.jackrabbit.oak.plugins.commit.ConflictHook
Create a new instance of the conflict hook using the passed conflict handler for resolving conflicts.
ConflictValidator - Class in org.apache.jackrabbit.oak.plugins.commit
Validator which checks the presence of conflict markers in the tree in fails the commit if any are found.
ConflictValidator(Tree) - Constructor for class org.apache.jackrabbit.oak.plugins.commit.ConflictValidator
Deprecated.
ConflictValidatorProvider - Class in org.apache.jackrabbit.oak.plugins.commit
TODO document
ConflictValidatorProvider() - Constructor for class org.apache.jackrabbit.oak.plugins.commit.ConflictValidatorProvider
 
connect(Map<String, String>) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentBroadcastConfig
 
connect(Map<String, String>) - Method in interface org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast.DynamicBroadcastConfig
Announce a new client to others.
consolidateCount(NodeBuilder) - Static method in class org.apache.jackrabbit.oak.plugins.atomic.AtomicCounterEditor
consolidate the AtomicCounterEditor.PREFIX_PROP_COUNTER properties and sum them into the AtomicCounterEditor.PROP_COUNTER
ConsolidatedCacheStats - Class in org.apache.jackrabbit.oak.cache.impl
 
ConsolidatedCacheStats() - Constructor for class org.apache.jackrabbit.oak.cache.impl.ConsolidatedCacheStats
 
ConsolidatorTask(String, PropertyState, NodeStore, ScheduledExecutorService, long, CommitHook) - Constructor for class org.apache.jackrabbit.oak.plugins.atomic.AtomicCounterEditor.ConsolidatorTask
 
ConstantFilter - Class in org.apache.jackrabbit.oak.plugins.observation.filter
TODO document
ConstantFilter(boolean) - Constructor for class org.apache.jackrabbit.oak.plugins.observation.filter.ConstantFilter
 
CONSTRAINT - Static variable in class org.apache.jackrabbit.oak.spi.security.user.action.PasswordValidationAction
 
ConstraintImpl - Class in org.apache.jackrabbit.oak.query.ast
The base class for constraints.
ConstraintImpl() - Constructor for class org.apache.jackrabbit.oak.query.ast.ConstraintImpl
 
Constraints - Class in org.apache.jackrabbit.oak.plugins.nodetype.constraint
 
contains(long) - Method in class org.apache.jackrabbit.oak.plugins.document.util.TimeInterval
Checks whether the interval contains the given time stamp.
contains(String) - Method in class org.apache.jackrabbit.oak.spi.security.ConfigurationParameters
Returns true if this instance contains a configuration entry with the specified key irrespective of the defined value; false otherwise.
containsField(String) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.RevisionEntry
 
containsKey(String) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.RevisionEntry
 
containsKey(Object) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.CacheMap
 
containsKey(Object) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.MultiGenerationMap
 
containsKey(Object) - Method in class org.apache.jackrabbit.oak.spi.security.ConfigurationParameters
containsNativeConstraint() - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
 
containsRevision(Revision) - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
Returns true if this document contains an entry for the given revision in the NodeDocument.REVISIONS map.
containsUnfilteredFullTextCondition() - Method in class org.apache.jackrabbit.oak.query.ast.AndImpl
 
containsUnfilteredFullTextCondition() - Method in class org.apache.jackrabbit.oak.query.ast.ConstraintImpl
Whether the condition contains a fulltext condition that can not be applied to the filter, for example because it is part of an "or" condition of the form "where a=1 or contains(., 'x')".
containsUnfilteredFullTextCondition() - Method in class org.apache.jackrabbit.oak.query.ast.NotImpl
 
containsUnfilteredFullTextCondition() - Method in class org.apache.jackrabbit.oak.query.ast.OrImpl
 
containsUnfilteredFullTextCondition() - Method in interface org.apache.jackrabbit.oak.query.Query
Whether the condition contains a fulltext condition that can not be applied to the filter, for example because it is part of an "or" condition of the form "where a=1 or contains(., 'x')".
containsUnfilteredFullTextCondition() - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
containsUnfilteredFullTextCondition() - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
containsValue(Object) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.MultiGenerationMap
 
containsValue(Object) - Method in class org.apache.jackrabbit.oak.spi.security.ConfigurationParameters
contentChanged(NodeState, CommitInfo) - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundlingConfigHandler
 
contentChanged(NodeState, CommitInfo) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentDiscoveryLiteService
Additionally the DocumentDiscoveryLiteService must be notified when the background-read has finished - as it could be waiting for a crashed node's recovery to finish - which it can only do by checking the lastKnownRevision of the crashed instance - and that check is best done after the background read is just finished (it could optinoally do that just purely time based as well, but going via a listener is more timely, that's why this approach has been chosen).
contentChanged(AbstractDocumentNodeState) - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.SecondaryStoreCache
 
contentChanged(NodeState, CommitInfo) - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.SecondaryStoreObserver
 
contentChanged(NodeState, NodeState, CommitInfo) - Method in interface org.apache.jackrabbit.oak.plugins.observation.FilteringAwareObserver
Equivalent to the state-full contentChanged() method of the Observer with one important difference being that this variation explicitly passes the before NodeState (thus the observer must in this case not remember the previous state)
contentChanged(NodeState, CommitInfo) - Method in class org.apache.jackrabbit.oak.plugins.observation.FilteringDispatcher
 
contentChanged(NodeState, CommitInfo) - Method in class org.apache.jackrabbit.oak.plugins.observation.FilteringObserver
 
contentChanged(NodeState, CommitInfo) - Method in class org.apache.jackrabbit.oak.plugins.observation.NodeObserver
 
ContentMirrorStoreStrategy - Class in org.apache.jackrabbit.oak.plugins.index.property.strategy
An IndexStoreStrategy implementation that saves the nodes under a hierarchy that mirrors the repository tree.
ContentMirrorStoreStrategy() - Constructor for class org.apache.jackrabbit.oak.plugins.index.property.strategy.ContentMirrorStoreStrategy
 
ContentMirrorStoreStrategy(String) - Constructor for class org.apache.jackrabbit.oak.plugins.index.property.strategy.ContentMirrorStoreStrategy
 
ContentRepositoryImpl - Class in org.apache.jackrabbit.oak.core
NodeStore-based implementation of the ContentRepository interface.
ContentRepositoryImpl(NodeStore, CommitHook, String, QueryEngineSettings, QueryIndexProvider, SecurityProvider, Descriptors) - Constructor for class org.apache.jackrabbit.oak.core.ContentRepositoryImpl
Creates an content repository instance based on the given, already initialized components.
Context - Interface in org.apache.jackrabbit.oak.spi.security
Context represents item related information in relation to a dedicated SecurityConfiguration.
Context.Default - Class in org.apache.jackrabbit.oak.spi.security
Default implementation of the Context interface that always returns false.
ContextAwareCallback - Interface in org.apache.jackrabbit.oak.plugins.index
Extension to IndexUpdateCallback which also provides access to IndexingContext
convert(Throwable) - Static method in exception org.apache.jackrabbit.oak.plugins.document.DocumentStoreException
 
convert(Throwable, String) - Static method in exception org.apache.jackrabbit.oak.plugins.document.DocumentStoreException
 
convert(PropertyValue, int, NamePathMapper) - Static method in class org.apache.jackrabbit.oak.query.ValueConverter
Converts the given value to a value of the specified target type.
convert(String) - Method in class org.apache.jackrabbit.oak.query.xpath.XPathToSQL2Converter
Convert the query to SQL2.
convertFromDBObject(Collection<T>, DBObject) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoDocumentStore
 
convertFromDBObject(Collection<T>, RDBRow) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
convertToUnion() - Method in class org.apache.jackrabbit.oak.query.ast.AndImpl
 
convertToUnion() - Method in class org.apache.jackrabbit.oak.query.ast.ConstraintImpl
Compute a set of sub-constraints that could be used for composing UNION statements.
convertToUnion() - Method in class org.apache.jackrabbit.oak.query.ast.OrImpl
 
copy() - Method in class org.apache.jackrabbit.oak.plugins.document.memory.MemoryDocumentStore
 
copy() - Method in class org.apache.jackrabbit.oak.plugins.document.UpdateOp
Creates a deep copy of this update operation.
copy() - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndexPlan
 
copyElementAndCheckReference(AstElement) - Static method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
as the AstElement.copyOf() can return this is the cloning is not implemented by the subclass, this method add some spice around it by checking for this case and tracking a DEBUG message in the logs.
copyOf() - Method in class org.apache.jackrabbit.oak.query.ast.AndImpl
 
copyOf() - Method in class org.apache.jackrabbit.oak.query.ast.ChildNodeImpl
 
copyOf() - Method in class org.apache.jackrabbit.oak.query.ast.ChildNodeJoinConditionImpl
 
copyOf() - Method in class org.apache.jackrabbit.oak.query.ast.ColumnImpl
 
copyOf() - Method in class org.apache.jackrabbit.oak.query.ast.ComparisonImpl
 
copyOf() - Method in class org.apache.jackrabbit.oak.query.ast.DescendantNodeImpl
 
copyOf() - Method in class org.apache.jackrabbit.oak.query.ast.DescendantNodeJoinConditionImpl
 
copyOf() - Method in class org.apache.jackrabbit.oak.query.ast.EquiJoinConditionImpl
 
copyOf() - Method in class org.apache.jackrabbit.oak.query.ast.FullTextSearchImpl
 
copyOf() - Method in class org.apache.jackrabbit.oak.query.ast.InImpl
 
copyOf() - Method in class org.apache.jackrabbit.oak.query.ast.JoinImpl
 
copyOf() - Method in class org.apache.jackrabbit.oak.query.ast.NativeFunctionImpl
 
copyOf() - Method in class org.apache.jackrabbit.oak.query.ast.NotImpl
 
copyOf() - Method in class org.apache.jackrabbit.oak.query.ast.OrImpl
 
copyOf() - Method in class org.apache.jackrabbit.oak.query.ast.PropertyExistenceImpl
 
copyOf() - Method in class org.apache.jackrabbit.oak.query.ast.PropertyInexistenceImpl
 
copyOf() - Method in class org.apache.jackrabbit.oak.query.ast.SameNodeImpl
 
copyOf() - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
 
copyOf() - Method in class org.apache.jackrabbit.oak.query.ast.SimilarImpl
 
copyOf() - Method in class org.apache.jackrabbit.oak.query.ast.SpellcheckImpl
 
copyOf() - Method in class org.apache.jackrabbit.oak.query.ast.SuggestImpl
 
copyOf() - Method in interface org.apache.jackrabbit.oak.query.Query
returns a clone of the current object.
copyOf() - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
copyOf() - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
CORRUPT_PROPERTY_NAME - Static variable in interface org.apache.jackrabbit.oak.plugins.index.IndexConstants
Property name for indicating that given index is corrupt and should be excluded from further indexing.
CorruptIndexHandler - Interface in org.apache.jackrabbit.oak.plugins.index
 
COST_OVERHEAD - Static variable in class org.apache.jackrabbit.oak.plugins.index.property.PropertyIndexLookup
The cost overhead to use the index in number of read operations.
COST_OVERHEAD - Static variable in class org.apache.jackrabbit.oak.plugins.index.property.PropertyIndexPlan
The cost overhead to use the index in number of read operations.
count(NodeState, NodeState, Set<String>, int) - Method in class org.apache.jackrabbit.oak.plugins.index.property.strategy.ContentMirrorStoreStrategy
 
count(Filter, NodeState, NodeState, Set<String>, int) - Method in class org.apache.jackrabbit.oak.plugins.index.property.strategy.ContentMirrorStoreStrategy
 
count(NodeState, NodeState, Set<String>, int) - Method in class org.apache.jackrabbit.oak.plugins.index.property.strategy.FilteringIndexStoreStrategy
 
count(Filter, NodeState, NodeState, Set<String>, int) - Method in class org.apache.jackrabbit.oak.plugins.index.property.strategy.FilteringIndexStoreStrategy
 
count(NodeState, NodeState, Set<String>, int) - Method in interface org.apache.jackrabbit.oak.plugins.index.property.strategy.IndexStoreStrategy
Count the occurrence of a given set of values.
count(Filter, NodeState, NodeState, Set<String>, int) - Method in interface org.apache.jackrabbit.oak.plugins.index.property.strategy.IndexStoreStrategy
Count the occurrence of a given set of values.
count(NodeState, NodeState, Set<String>, int) - Method in class org.apache.jackrabbit.oak.plugins.index.property.strategy.UniqueEntryStoreStrategy
 
count(Filter, NodeState, NodeState, Set<String>, int) - Method in class org.apache.jackrabbit.oak.plugins.index.property.strategy.UniqueEntryStoreStrategy
 
COUNT_HASH - Static variable in class org.apache.jackrabbit.oak.plugins.index.counter.jmx.NodeCounter
Approximate count using the hashed name (deterministically, so that after adding a removing all nodes the count goes back to zero).
COUNT_HASH_PROPERTY_NAME - Static variable in class org.apache.jackrabbit.oak.plugins.index.counter.NodeCounterEditor
 
COUNT_MAX - Static variable in class org.apache.jackrabbit.oak.plugins.index.counter.ApproximateCounter
 
COUNT_PROPERTY_NAME - Static variable in class org.apache.jackrabbit.oak.plugins.index.counter.NodeCounterEditor
 
COUNT_PROPERTY_PREFIX - Static variable in class org.apache.jackrabbit.oak.plugins.index.counter.ApproximateCounter
 
COUNT_RESOLUTION - Static variable in class org.apache.jackrabbit.oak.plugins.index.counter.ApproximateCounter
 
countChanges(NodeState, NodeState) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.CountingDiff
 
countDeleteChunks(List<String>, long) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoBlobStore
 
countDeleteChunks(List<String>, long) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.BlobCache
 
countDeleteChunks(List<String>, long) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBBlobStore
 
CountingDiff - Class in org.apache.jackrabbit.oak.plugins.document.util
A NodeStateDiff implementation that counts the differences between two node states, including their sub tree.
CountingDiff() - Constructor for class org.apache.jackrabbit.oak.plugins.document.util.CountingDiff
 
COWNodeStore - Class in org.apache.jackrabbit.oak.plugins.cow
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.
COWNodeStore(NodeStore) - Constructor for class org.apache.jackrabbit.oak.plugins.cow.COWNodeStore
 
COWNodeStoreService - Class in org.apache.jackrabbit.oak.plugins.cow
 
COWNodeStoreService() - Constructor for class org.apache.jackrabbit.oak.plugins.cow.COWNodeStoreService
 
create(NodeStore, CommitHook, String, SecurityProvider, QueryIndexProvider) - Static method in class org.apache.jackrabbit.oak.core.SystemRoot
 
create(NodeStore, CommitHook, String, SecurityProvider, QueryEngineSettings, QueryIndexProvider) - Static method in class org.apache.jackrabbit.oak.core.SystemRoot
 
create(Collection<T>, List<UpdateOp>) - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStore
Try to create a list of documents.
create(Collection<T>, List<UpdateOp>) - Method in class org.apache.jackrabbit.oak.plugins.document.memory.MemoryDocumentStore
 
create(Collection<T>, List<UpdateOp>) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoDocumentStore
 
create(Collection<T>, List<UpdateOp>) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
create(Collection<T>, List<UpdateOp>) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LeaseCheckDocumentStoreWrapper
 
create(Collection<T>, List<UpdateOp>) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LoggingDocumentStoreWrapper
 
create() - Method in class org.apache.jackrabbit.oak.plugins.document.util.MapFactory
 
create(Collection<T>, List<UpdateOp>) - Method in class org.apache.jackrabbit.oak.plugins.document.util.SynchronizingDocumentStoreWrapper
 
create(Collection<T>, List<UpdateOp>) - Method in class org.apache.jackrabbit.oak.plugins.document.util.TimingDocumentStoreWrapper
 
create(NodeTypeDefinition, NodeTypeDefinition) - Static method in class org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeDefDiff
 
create(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.ACFilter
 
create(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.AddSubtreeFilter
 
create(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.ConstantFilter
 
create(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.DeleteSubtreeFilter
 
create(String, NodeState, NodeState) - Method in interface org.apache.jackrabbit.oak.plugins.observation.filter.EventFilter
Factory for creating a filter instance for the given child node
create(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.EventTypeFilter
 
create(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.GlobbingPathFilter
 
create(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.MoveFilter
 
create(Root) - Method in interface org.apache.jackrabbit.oak.plugins.observation.filter.PermissionProviderFactory
Create a new PermissionProvider instance.
create(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.UniversalFilter
 
create(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.VisibleFilter
 
create(Tree) - Static method in class org.apache.jackrabbit.oak.plugins.tree.TreeLocation
Create a new TreeLocation instance for a tree
create(Root, String) - Static method in class org.apache.jackrabbit.oak.plugins.tree.TreeLocation
Create a new TreeLocation instance for the item at the given path in root.
create(Root) - Static method in class org.apache.jackrabbit.oak.plugins.tree.TreeLocation
Equivalent to create(root, "/")
create(long, long, Iterator<T>) - Static method in class org.apache.jackrabbit.oak.security.user.query.ResultIterator
Returns an iterator respecting the specified offset and max.
create(List<RestrictionPattern>) - Static method in class org.apache.jackrabbit.oak.spi.security.authorization.restriction.CompositePattern
 
createBinary(InputStream) - Method in class org.apache.jackrabbit.oak.plugins.value.jcr.ValueFactoryImpl
 
createBlob(InputStream) - Method in class org.apache.jackrabbit.oak.core.ImmutableRoot
 
createBlob(InputStream) - Method in class org.apache.jackrabbit.oak.plugins.cow.BranchNodeStore
 
createBlob(InputStream) - Method in class org.apache.jackrabbit.oak.plugins.cow.COWNodeStore
 
createBlob(InputStream) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
createBlobGarbageCollector(long, String) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
Creates and returns a MarkSweepGarbageCollector if the current BlobStore supports garbage collection
createCheckpoint(long) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentCheckpointMBean
 
createChild(String) - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractTree
Factory method for creating child trees
createChild(String) - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.ImmutableTree
 
createChild(String) - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.NodeBuilderTree
 
createCleanUp(Set<NodeDocument.SplitDocType>, RevisionVector, long, VersionGarbageCollector.VersionGCStats) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoVersionGCSupport
 
createCleanUp(Set<NodeDocument.SplitDocType>, RevisionVector, long, VersionGarbageCollector.VersionGCStats) - Method in class org.apache.jackrabbit.oak.plugins.document.VersionGCSupport
 
createContentRepository() - Method in class org.apache.jackrabbit.oak.Oak
Returns the content repository instance created with the given configuration.
createContentSession() - Method in class org.apache.jackrabbit.oak.Oak
Creates a content repository with the given configuration and logs in to the default workspace with no credentials, returning the resulting content session.
createCopy() - Method in class org.apache.jackrabbit.oak.query.ast.DynamicOperandImpl
 
createCopy() - Method in class org.apache.jackrabbit.oak.query.ast.FullTextSearchScoreImpl
 
createCopy() - Method in class org.apache.jackrabbit.oak.query.ast.LengthImpl
 
createCopy() - Method in class org.apache.jackrabbit.oak.query.ast.LowerCaseImpl
 
createCopy() - Method in class org.apache.jackrabbit.oak.query.ast.NodeLocalNameImpl
 
createCopy() - Method in class org.apache.jackrabbit.oak.query.ast.NodeNameImpl
 
createCopy() - Method in class org.apache.jackrabbit.oak.query.ast.OrderingImpl
 
createCopy() - Method in class org.apache.jackrabbit.oak.query.ast.PropertyValueImpl
 
createCopy() - Method in class org.apache.jackrabbit.oak.query.ast.UpperCaseImpl
 
createDescriptors() - Method in class org.apache.jackrabbit.oak.core.ContentRepositoryImpl
 
createFilter(NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder.AddSubtreeTreeCondition
 
createFilter(NodeState, NodeState) - Method in interface org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder.Condition
 
createFilter(NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder.DeleteSubtreeTreeCondition
 
createFilter(NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder.MoveCondition
 
createFilter(boolean) - Method in class org.apache.jackrabbit.oak.query.ast.JoinImpl
 
createFilter(boolean) - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
Create the filter condition for planning or execution.
createFilter(boolean) - Method in class org.apache.jackrabbit.oak.query.ast.SourceImpl
!Test purpose only! this creates a filter for the given query
createFromSubject(Subject) - Static method in class org.apache.jackrabbit.oak.spi.security.authentication.AuthInfoImpl
 
createGroup(String) - Method in class org.apache.jackrabbit.oak.security.user.autosave.AutoSaveEnabledManager
 
createGroup(Principal) - Method in class org.apache.jackrabbit.oak.security.user.autosave.AutoSaveEnabledManager
 
createGroup(Principal, String) - Method in class org.apache.jackrabbit.oak.security.user.autosave.AutoSaveEnabledManager
 
createGroup(String, Principal, String) - Method in class org.apache.jackrabbit.oak.security.user.autosave.AutoSaveEnabledManager
 
createGroup(String) - Method in class org.apache.jackrabbit.oak.security.user.UserManagerImpl
 
createGroup(Principal) - Method in class org.apache.jackrabbit.oak.security.user.UserManagerImpl
 
createGroup(Principal, String) - Method in class org.apache.jackrabbit.oak.security.user.UserManagerImpl
 
createGroup(String, Principal, String) - Method in class org.apache.jackrabbit.oak.security.user.UserManagerImpl
 
createIndexDefinition(NodeBuilder, String, boolean, boolean, Collection<String>, Collection<String>) - Static method in class org.apache.jackrabbit.oak.plugins.index.IndexUtils
Create a new property index definition below the given indexNode.
createIndexDefinition(Tree, String, boolean, String[], String...) - Static method in class org.apache.jackrabbit.oak.plugins.index.IndexUtils
Create a new property2 index definition below the given indexNode.
createIndexDefinition(Tree, String, boolean, Collection<String>, Collection<String>, String, Map<String, String>) - Static method in class org.apache.jackrabbit.oak.plugins.index.IndexUtils
Create a new property index definition below the given indexNode of the provided propertyIndexType.
createIndexDefinition(NodeBuilder, String, boolean, Iterable<String>, String[], String, Map<String, String>) - Static method in class org.apache.jackrabbit.oak.plugins.index.IndexUtils
Create a new property index definition below the given indexNode of the provided propertyIndexType.
createInStatement(String, Collection<String>, boolean) - Static method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBJDBCTools
 
createJcrConflictHandler() - Static method in class org.apache.jackrabbit.oak.plugins.commit.JcrConflictHandler
createMatcher() - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.DocumentBundlor
 
createMatcher() - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.Include
 
createMissingLastRevSeeker() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
createNodeDefinitionTemplate() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.ReadOnlyNodeTypeManager
 
createNodeDefinitionTemplate() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.write.ReadWriteNodeTypeManager
 
createNodeTypeTemplate() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.ReadOnlyNodeTypeManager
 
createNodeTypeTemplate(NodeTypeDefinition) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.ReadOnlyNodeTypeManager
 
createNodeTypeTemplate() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.write.ReadWriteNodeTypeManager
 
createNodeTypeTemplate(NodeTypeDefinition) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.write.ReadWriteNodeTypeManager
 
createOrUpdate(Collection<T>, UpdateOp) - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStore
Atomically checks if the document exists and updates it, otherwise the document is created (aka upsert).
createOrUpdate(Collection<T>, List<UpdateOp>) - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStore
Create or unconditionally update a number of documents.
createOrUpdate(Collection<T>, UpdateOp) - Method in class org.apache.jackrabbit.oak.plugins.document.memory.MemoryDocumentStore
 
createOrUpdate(Collection<T>, List<UpdateOp>) - Method in class org.apache.jackrabbit.oak.plugins.document.memory.MemoryDocumentStore
 
createOrUpdate(Collection<T>, UpdateOp) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoDocumentStore
 
createOrUpdate(Collection<T>, List<UpdateOp>) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoDocumentStore
Try to apply all the UpdateOps with at least MongoDB requests as possible.
createOrUpdate(Collection<T>, UpdateOp) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
createOrUpdate(Collection<T>, List<UpdateOp>) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
createOrUpdate(Collection<T>, UpdateOp) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LeaseCheckDocumentStoreWrapper
 
createOrUpdate(Collection<T>, List<UpdateOp>) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LeaseCheckDocumentStoreWrapper
 
createOrUpdate(Collection<T>, UpdateOp) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LoggingDocumentStoreWrapper
 
createOrUpdate(Collection<T>, List<UpdateOp>) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LoggingDocumentStoreWrapper
 
createOrUpdate(Collection<T>, UpdateOp) - Method in class org.apache.jackrabbit.oak.plugins.document.util.SynchronizingDocumentStoreWrapper
 
createOrUpdate(Collection<T>, List<UpdateOp>) - Method in class org.apache.jackrabbit.oak.plugins.document.util.SynchronizingDocumentStoreWrapper
 
createOrUpdate(Collection<T>, UpdateOp) - Method in class org.apache.jackrabbit.oak.plugins.document.util.TimingDocumentStoreWrapper
 
createOrUpdate(Collection<T>, List<UpdateOp>) - Method in class org.apache.jackrabbit.oak.plugins.document.util.TimingDocumentStoreWrapper
 
createPropertyDefinitionTemplate() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.ReadOnlyNodeTypeManager
 
createPropertyDefinitionTemplate() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.write.ReadWriteNodeTypeManager
 
createReadOnlyRoot(NodeState) - Static method in class org.apache.jackrabbit.oak.plugins.tree.RootFactory
 
createReadOnlyRoot(Root) - Static method in class org.apache.jackrabbit.oak.plugins.tree.RootFactory
 
createReadOnlyTree(NodeState) - Static method in class org.apache.jackrabbit.oak.plugins.tree.TreeFactory
 
createReadOnlyTree(Tree, String, NodeState) - Static method in class org.apache.jackrabbit.oak.plugins.tree.TreeFactory
 
createReferenceIndex(NodeBuilder) - Static method in class org.apache.jackrabbit.oak.plugins.index.IndexUtils
 
createRestriction(String, String, Value) - Method in class org.apache.jackrabbit.oak.security.authorization.restriction.PrincipalRestrictionProvider
 
createRestriction(String, String, Value...) - Method in class org.apache.jackrabbit.oak.security.authorization.restriction.PrincipalRestrictionProvider
 
createRestriction(String, String, Value) - Method in class org.apache.jackrabbit.oak.security.authorization.restriction.WhiteboardRestrictionProvider
 
createRestriction(String, String, Value...) - Method in class org.apache.jackrabbit.oak.security.authorization.restriction.WhiteboardRestrictionProvider
 
createRestriction(String, String, Value) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.restriction.AbstractRestrictionProvider
 
createRestriction(String, String, Value...) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.restriction.AbstractRestrictionProvider
 
createRestriction(String, String, Value) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.restriction.CompositeRestrictionProvider
 
createRestriction(String, String, Value...) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.restriction.CompositeRestrictionProvider
 
createRestriction(String, String, Value) - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.restriction.RestrictionProvider
Creates a new single valued restriction for the specified parameters.
createRestriction(String, String, Value...) - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.restriction.RestrictionProvider
Creates a new multi valued restriction for the specified parameters.
createRoot() - Method in class org.apache.jackrabbit.oak.Oak
Creates a content repository with the given configuration and returns a Root instance after logging in to the default workspace with no credentials.
createStandardMappings(NodeBuilder) - Static method in class org.apache.jackrabbit.oak.plugins.name.Namespaces
 
createSystemRoot(NodeStore, CommitHook, String, SecurityProvider, QueryEngineSettings, QueryIndexProvider) - Static method in class org.apache.jackrabbit.oak.plugins.tree.RootFactory
Deprecated.
with Oak 1.7.2 due to the usage of deprecated QueryEngineSettings
createSystemRoot(NodeStore, CommitHook, String, SecurityProvider, QueryIndexProvider) - Static method in class org.apache.jackrabbit.oak.plugins.tree.RootFactory
 
createSystemUser(String, String) - Method in class org.apache.jackrabbit.oak.security.user.autosave.AutoSaveEnabledManager
 
createSystemUser(String, String) - Method in class org.apache.jackrabbit.oak.security.user.UserManagerImpl
 
createTableName(String, String) - Static method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBJDBCTools
Creates a table name based on an optional prefix and a base name.
createToken(Credentials) - Method in class org.apache.jackrabbit.oak.spi.security.authentication.token.CompositeTokenProvider
 
createToken(String, Map<String, ?>) - Method in class org.apache.jackrabbit.oak.spi.security.authentication.token.CompositeTokenProvider
 
createToken(Credentials) - Method in interface org.apache.jackrabbit.oak.spi.security.authentication.token.TokenProvider
Issues a new login token for the user with the specified credentials and returns the associated TokenInfo.
createToken(String, Map<String, ?>) - Method in interface org.apache.jackrabbit.oak.spi.security.authentication.token.TokenProvider
Issues a new login token for the user with the given userId and the specified attributes.
createTree(NodeBuilder) - Static method in class org.apache.jackrabbit.oak.plugins.tree.TreeFactory
 
createUser(String, String) - Method in class org.apache.jackrabbit.oak.security.user.autosave.AutoSaveEnabledManager
 
createUser(String, String, Principal, String) - Method in class org.apache.jackrabbit.oak.security.user.autosave.AutoSaveEnabledManager
 
createUser(String, String) - Method in class org.apache.jackrabbit.oak.security.user.UserManagerImpl
 
createUser(String, String, Principal, String) - Method in class org.apache.jackrabbit.oak.security.user.UserManagerImpl
 
createValue(PropertyState, NamePathMapper) - Static method in class org.apache.jackrabbit.oak.plugins.value.jcr.ValueFactoryImpl
Utility method for creating a Value based on a PropertyState.
createValue(PropertyValue, NamePathMapper) - Static method in class org.apache.jackrabbit.oak.plugins.value.jcr.ValueFactoryImpl
Utility method for creating a Value based on a PropertyValue.
createValue(String) - Method in class org.apache.jackrabbit.oak.plugins.value.jcr.ValueFactoryImpl
 
createValue(InputStream) - Method in class org.apache.jackrabbit.oak.plugins.value.jcr.ValueFactoryImpl
 
createValue(Binary) - Method in class org.apache.jackrabbit.oak.plugins.value.jcr.ValueFactoryImpl
 
createValue(long) - Method in class org.apache.jackrabbit.oak.plugins.value.jcr.ValueFactoryImpl
 
createValue(double) - Method in class org.apache.jackrabbit.oak.plugins.value.jcr.ValueFactoryImpl
 
createValue(Calendar) - Method in class org.apache.jackrabbit.oak.plugins.value.jcr.ValueFactoryImpl
 
createValue(boolean) - Method in class org.apache.jackrabbit.oak.plugins.value.jcr.ValueFactoryImpl
 
createValue(Node) - Method in class org.apache.jackrabbit.oak.plugins.value.jcr.ValueFactoryImpl
 
createValue(Node, boolean) - Method in class org.apache.jackrabbit.oak.plugins.value.jcr.ValueFactoryImpl
 
createValue(BigDecimal) - Method in class org.apache.jackrabbit.oak.plugins.value.jcr.ValueFactoryImpl
 
createValue(String, int) - Method in class org.apache.jackrabbit.oak.plugins.value.jcr.ValueFactoryImpl
 
createValues(PropertyState, NamePathMapper) - Static method in class org.apache.jackrabbit.oak.plugins.value.jcr.ValueFactoryImpl
Utility method for creating Values based on a PropertyState.
createValues(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.value.jcr.ValueFactoryImpl
Utility method for creating Values based on a PropertyState.
CREDENTIALS_ATTRIBUTE_NEWPASSWORD - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
Name of the SimpleCredentials attribute containing the new password.
CredentialsCallback - Class in org.apache.jackrabbit.oak.spi.security.authentication.callback
Callback implementation to retrieve Credentials.
CredentialsCallback() - Constructor for class org.apache.jackrabbit.oak.spi.security.authentication.callback.CredentialsCallback
 
CredentialsSupport - Interface in org.apache.jackrabbit.oak.spi.security.authentication.credentials
Simple helper interface that allows to easily plug support for additional or custom Credentials implementations during authentication.
currentOakProperty(String) - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
Get the property value.
currentPath() - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
Get the current absolute Oak path (normalized).
currentProperty() - Method in class org.apache.jackrabbit.oak.query.ast.ColumnImpl
 
currentProperty() - Method in class org.apache.jackrabbit.oak.query.ast.DynamicOperandImpl
 
currentProperty() - Method in class org.apache.jackrabbit.oak.query.ast.FacetColumnImpl
 
currentProperty() - Method in class org.apache.jackrabbit.oak.query.ast.FullTextSearchScoreImpl
 
currentProperty() - Method in class org.apache.jackrabbit.oak.query.ast.LengthImpl
 
currentProperty() - Method in class org.apache.jackrabbit.oak.query.ast.LowerCaseImpl
 
currentProperty() - Method in class org.apache.jackrabbit.oak.query.ast.NodeLocalNameImpl
 
currentProperty() - Method in class org.apache.jackrabbit.oak.query.ast.NodeNameImpl
 
currentProperty() - Method in class org.apache.jackrabbit.oak.query.ast.PropertyValueImpl
 
currentProperty(String) - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
The value for the given selector for the current node.
currentProperty(String, int) - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
The value for the given selector for the current node, filtered by property type.
currentProperty() - Method in class org.apache.jackrabbit.oak.query.ast.UpperCaseImpl
 
currentTree() - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
Get the tree at the current path.
currentValue() - Method in class org.apache.jackrabbit.oak.query.ast.BindVariableValueImpl
 
currentValue() - Method in class org.apache.jackrabbit.oak.query.ast.LiteralImpl
 
currentValue() - Method in class org.apache.jackrabbit.oak.query.ast.StaticOperandImpl
 
Cursors - Class in org.apache.jackrabbit.oak.plugins.index
This utility class provides factory methods to create commonly used types of Cursors.
Cursors.AbstractCursor - Class in org.apache.jackrabbit.oak.plugins.index
A Cursor implementation where the remove method throws an UnsupportedOperationException.
Cursors.PathCursor - Class in org.apache.jackrabbit.oak.plugins.index
PathCursor implements a simple Cursor that iterates over a String based path Iterable.
CUSTOM_BLOB_STORE - Static variable in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreService
 

D

data - Variable in class org.apache.jackrabbit.oak.plugins.document.Document
The data of this document.
DATA_NODE_NAME - Static variable in class org.apache.jackrabbit.oak.plugins.index.counter.NodeCounterEditor
 
DataStoreTextProviderService - Class in org.apache.jackrabbit.oak.plugins.index.datastore
 
DataStoreTextProviderService() - Constructor for class org.apache.jackrabbit.oak.plugins.index.datastore.DataStoreTextProviderService
 
DataStoreTextWriter - Class in org.apache.jackrabbit.oak.plugins.index.datastore
TextWriter implementation which just stores the extracted text as files using the same layout as used by FileDataStore
DataStoreTextWriter(File, boolean) - Constructor for class org.apache.jackrabbit.oak.plugins.index.datastore.DataStoreTextWriter
 
DateConstraint - Class in org.apache.jackrabbit.oak.plugins.nodetype.constraint
 
DateConstraint(String) - Constructor for class org.apache.jackrabbit.oak.plugins.nodetype.constraint.DateConstraint
 
DateVersionSelector - Class in org.apache.jackrabbit.oak.plugins.version
Inspired by Jackrabbit 2.x
DateVersionSelector(String) - Constructor for class org.apache.jackrabbit.oak.plugins.version.DateVersionSelector
Creates a DateVersionSelector that will select the latest version of all those that are older than the given timestamp.
deactivate() - Method in class org.apache.jackrabbit.oak.plugins.atomic.AtomicCounterEditorProvider
 
deactivate() - Method in class org.apache.jackrabbit.oak.plugins.cow.COWNodeStoreService
 
deactivate() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentDiscoveryLiteService
On deactivate the background job is stopped - if it was running at all
deactivate() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreService
 
deactivate() - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexerService
 
deactivate() - Method in class org.apache.jackrabbit.oak.security.internal.SecurityProviderRegistration
 
deactivate() - Method in class org.apache.jackrabbit.oak.security.SecurityProviderImpl
 
DecimalConstraint - Class in org.apache.jackrabbit.oak.plugins.nodetype.constraint
 
DecimalConstraint(String) - Constructor for class org.apache.jackrabbit.oak.plugins.nodetype.constraint.DecimalConstraint
 
DECLARING_NODE_TYPES - Static variable in interface org.apache.jackrabbit.oak.plugins.index.IndexConstants
Defines the property name of the "declaringNodeTypes" property with allows to restrict a given index definition to specific node types.
deepCopy(Document) - Method in class org.apache.jackrabbit.oak.plugins.document.Document
Performs a deep copy of the data within this document to the given target.
deepCopyMap(Map<K, Object>, Map<K, Object>) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
Deep copy of a map that may contain map values.
DEFAULT - Static variable in interface org.apache.jackrabbit.oak.namepath.NamePathMapper
 
Default() - Constructor for class org.apache.jackrabbit.oak.namepath.NamePathMapper.Default
 
DEFAULT - Static variable in interface org.apache.jackrabbit.oak.spi.security.Context
 
Default() - Constructor for class org.apache.jackrabbit.oak.spi.security.Context.Default
 
Default() - Constructor for class org.apache.jackrabbit.oak.spi.security.SecurityConfiguration.Default
 
DEFAULT - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.AuthorizableNodeName
Default AuthorizableNodeName instance.
Default() - Constructor for class org.apache.jackrabbit.oak.spi.security.user.AuthorizableNodeName.Default
 
DEFAULT_ADMIN_ID - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
DEFAULT_ALGORITHM - Static variable in class org.apache.jackrabbit.oak.spi.security.user.util.PasswordUtil
 
DEFAULT_ANONYMOUS_ID - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
DEFAULT_APP_NAME - Static variable in interface org.apache.jackrabbit.oak.spi.security.authentication.AuthenticationConfiguration
 
DEFAULT_CACHE_SEGMENT_COUNT - Static variable in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
DEFAULT_CACHE_STACK_MOVE_DISTANCE - Static variable in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
DEFAULT_CHILDREN_CACHE_PERCENTAGE - Static variable in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
DEFAULT_DEPTH - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
DEFAULT_DIFF_CACHE_PERCENTAGE - Static variable in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
DEFAULT_DIFFER - Static variable in interface org.apache.jackrabbit.oak.plugins.document.NodeStateDiffer
 
DEFAULT_DIRECTION - Static variable in interface org.apache.jackrabbit.oak.plugins.index.property.OrderedIndex
the default direction for sorting the index
DEFAULT_ENABLE_RFC7613_USERCASE_MAPPED_PROFILE - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
DEFAULT_FAST_QUERY_SIZE - Static variable in class org.apache.jackrabbit.oak.query.QueryEngineSettings
 
DEFAULT_GROUP_PATH - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
DEFAULT_ITERATIONS - Static variable in class org.apache.jackrabbit.oak.spi.security.user.util.PasswordUtil
 
DEFAULT_LEASE_CHECK_DISABLED - Static variable in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfo
 
DEFAULT_LEASE_DURATION_MILLIS - Static variable in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfo
 
DEFAULT_LEASE_FAILURE_MARGIN_MILLIS - Static variable in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfo
OAK-3398 : default failure margin 20sec before actual lease timeout (note that OAK-3399 / MAX_RETRY_SLEEPS_BEFORE_LEASE_FAILURE eats off another few seconds from this margin, by default 5sec, so the actual default failure-margin is down to 15sec - and that is high-noon!)
DEFAULT_LEASE_UPDATE_INTERVAL_MILLIS - Static variable in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfo
OAK-3398 : default update interval 10sec
DEFAULT_LENGTH - Static variable in class org.apache.jackrabbit.oak.security.user.RandomAuthorizableNodeName
21 characters, each character with 6 bit of entropy (64 possible characters), results in 126 bits of entropy.
DEFAULT_MEMBERSHIP_THRESHOLD - Static variable in class org.apache.jackrabbit.oak.security.user.MembershipWriter
 
DEFAULT_MEMORY_CACHE_SIZE - Static variable in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
DEFAULT_NODE_CACHE_PERCENTAGE - Static variable in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
DEFAULT_PASSWORD_INITIAL_CHANGE - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
DEFAULT_PASSWORD_MAX_AGE - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
DEFAULT_PREV_DOC_CACHE_PERCENTAGE - Static variable in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
DEFAULT_QUERY_LIMIT_IN_MEMORY - Static variable in class org.apache.jackrabbit.oak.query.QueryEngineSettings
 
DEFAULT_QUERY_LIMIT_READS - Static variable in class org.apache.jackrabbit.oak.query.QueryEngineSettings
 
DEFAULT_READ_PATHS - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.PermissionConstants
Default value for the PermissionConstants.PARAM_READ_PATHS configuration parameter.
DEFAULT_RESOLUTION - Static variable in class org.apache.jackrabbit.oak.plugins.index.counter.NodeCounterEditor
 
DEFAULT_SALT_SIZE - Static variable in class org.apache.jackrabbit.oak.spi.security.user.util.PasswordUtil
 
DEFAULT_SYSTEM_RELATIVE_PATH - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
Default intermediate path for system users.
DEFAULT_USER_PATH - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
DEFAULT_WORKSPACE_NAME - Static variable in class org.apache.jackrabbit.oak.Oak
Constant for the default workspace name
DefaultAuthorizableActionProvider - Class in org.apache.jackrabbit.oak.spi.security.user.action
Default implementation of the AuthorizableActionProvider interface that allows to config all actions provided by the OAK.
DefaultAuthorizableActionProvider() - Constructor for class org.apache.jackrabbit.oak.spi.security.user.action.DefaultAuthorizableActionProvider
 
DefaultAuthorizableActionProvider(ConfigurationParameters) - Constructor for class org.apache.jackrabbit.oak.spi.security.user.action.DefaultAuthorizableActionProvider
 
DefaultConflictHandler - Class in org.apache.jackrabbit.oak.plugins.commit
Deprecated.
DefaultConflictHandler(PartialConflictHandler.Resolution) - Constructor for class org.apache.jackrabbit.oak.plugins.commit.DefaultConflictHandler
Deprecated.
Create a new ConflictHandler which always returns resolution.
DefaultEventHandler - Class in org.apache.jackrabbit.oak.plugins.observation
Default implementation of EventHandler that does nothing.
DefaultEventHandler() - Constructor for class org.apache.jackrabbit.oak.plugins.observation.DefaultEventHandler
 
defaultExecutorService() - Static method in class org.apache.jackrabbit.oak.Oak
Default ExecutorService used for scheduling concurrent tasks.
defaultScheduledExecutor() - Static method in class org.apache.jackrabbit.oak.Oak
Default ScheduledExecutorService used for scheduling background tasks.
DefaultThreeWayConflictHandler - Class in org.apache.jackrabbit.oak.plugins.commit
This implementation of a ThreeWayConflictHandler always returns the same resolution.
DefaultThreeWayConflictHandler(ThreeWayConflictHandler.Resolution) - Constructor for class org.apache.jackrabbit.oak.plugins.commit.DefaultThreeWayConflictHandler
Create a new ConflictHandler which always returns resolution.
defines(String, AccessControlPolicy) - Method in class org.apache.jackrabbit.oak.security.authorization.accesscontrol.AccessControlManagerImpl
 
defines(String, AccessControlPolicy) - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.PolicyOwner
Determines if the implementing AccessManager defines the specified accessControlPolicy at the given absPath.
definesContextRoot(Tree) - Method in interface org.apache.jackrabbit.oak.plugins.tree.TreeContext
Reveals if the specified Tree is the root of a subtree defined by the module that exposes this TreeContext instance.
definesContextRoot(Tree) - Method in class org.apache.jackrabbit.oak.spi.security.Context.Default
 
definesInternal(Tree) - Method in interface org.apache.jackrabbit.oak.plugins.tree.TreeContext
Reveals if the specified Tree defines repository internal information, which is not hidden by default.
definesInternal(Tree) - Method in class org.apache.jackrabbit.oak.spi.security.Context.Default
 
definesLocation(TreeLocation) - Method in interface org.apache.jackrabbit.oak.plugins.tree.TreeContext
Reveals if the specified TreeLocation is defined by the module that exposes this TreeContext instance.
definesLocation(TreeLocation) - Method in class org.apache.jackrabbit.oak.spi.security.Context.Default
 
definesProperty(Tree, PropertyState) - Method in interface org.apache.jackrabbit.oak.plugins.tree.TreeContext
Reveals if the specified PropertyState is defined by the module that exposes this TreeContext instance.
definesProperty(Tree, PropertyState) - Method in class org.apache.jackrabbit.oak.spi.security.Context.Default
 
definesTree(Tree) - Method in interface org.apache.jackrabbit.oak.plugins.tree.TreeContext
Reveals if the specified Tree is defined by the module that exposes this TreeContext instance.
definesTree(Tree) - Method in class org.apache.jackrabbit.oak.spi.security.Context.Default
 
DefinitionProvider - Interface in org.apache.jackrabbit.oak.plugins.nodetype
DefinitionProvider...
delay() - Method in class org.apache.jackrabbit.oak.plugins.observation.CommitRateLimiter
 
delayFactor - Variable in class org.apache.jackrabbit.oak.plugins.document.VersionGCOptions
 
DelegatingDocumentNodeState - Class in org.apache.jackrabbit.oak.plugins.document.secondary
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
delete(Connection, RDBDocumentStore.RDBTableMetaData, List<String>) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStoreJDBC
 
delete(Connection, RDBDocumentStore.RDBTableMetaData, Map<String, Map<UpdateOp.Key, UpdateOp.Condition>>) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStoreJDBC
 
deleteChangedNode(NodeBuilder, String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.commit.AnnotatingConflictHandler
 
deleteChangedNode(NodeBuilder, String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.commit.ChildOrderConflictHandler
 
deleteChangedNode(NodeBuilder, String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.commit.DefaultConflictHandler
Deprecated.
 
deleteChangedNode(NodeBuilder, String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.commit.DefaultThreeWayConflictHandler
 
deleteChangedNode(NodeBuilder, String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.security.user.RepMembersConflictHandler
 
deleteChangedProperty(NodeBuilder, PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.commit.AnnotatingConflictHandler
 
deleteChangedProperty(NodeBuilder, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.commit.ChildOrderConflictHandler
 
deleteChangedProperty(NodeBuilder, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.commit.DefaultConflictHandler
Deprecated.
 
deleteChangedProperty(NodeBuilder, PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.commit.DefaultThreeWayConflictHandler
 
deleteChangedProperty(NodeBuilder, PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.security.user.RepMembersConflictHandler
 
deleteChunks(List<String>, long) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.BlobCache
Deprecated.
deleteCount - Variable in class org.apache.jackrabbit.oak.plugins.document.SplitDocumentCleanUp
 
deleted(String, Set<String>, Set<String>, Set<String>, Map<String, String>, CommitInfo) - Method in class org.apache.jackrabbit.oak.plugins.observation.NodeObserver
A node at path has been deleted.
DELETED_ONCE - Static variable in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
Flag indicating that whether this node was ever deleted.
deleteDeletedNode(NodeBuilder, String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.commit.AnnotatingConflictHandler
 
deleteDeletedNode(NodeBuilder, String) - Method in class org.apache.jackrabbit.oak.plugins.commit.ChildOrderConflictHandler
 
deleteDeletedNode(NodeBuilder, String) - Method in class org.apache.jackrabbit.oak.plugins.commit.DefaultConflictHandler
Deprecated.
 
deleteDeletedNode(NodeBuilder, String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.commit.DefaultThreeWayConflictHandler
 
deleteDeletedNode(NodeBuilder, String, NodeState) - Method in class org.apache.jackrabbit.oak.security.user.RepMembersConflictHandler
 
deleteDeletedProperty(NodeBuilder, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.commit.AnnotatingConflictHandler
 
deleteDeletedProperty(NodeBuilder, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.commit.ChildOrderConflictHandler
 
deleteDeletedProperty(NodeBuilder, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.commit.DefaultConflictHandler
Deprecated.
 
deleteDeletedProperty(NodeBuilder, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.commit.DefaultThreeWayConflictHandler
 
deleteDeletedProperty(NodeBuilder, PropertyState) - Method in class org.apache.jackrabbit.oak.security.user.RepMembersConflictHandler
 
deletedOnce() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBRow
 
deletedOnceFlagReset() - Method in interface org.apache.jackrabbit.oak.plugins.document.RevisionGCStatsCollector
 
deleteSplitDocuments() - Method in class org.apache.jackrabbit.oak.plugins.document.SplitDocumentCleanUp
 
deleteSubtree() - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder
 
DeleteSubtreeFilter - Class in org.apache.jackrabbit.oak.plugins.observation.filter
This EventFilter implementation excludes events for child nodes of removed nodes.
DeleteSubtreeTreeCondition() - Constructor for class org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder.DeleteSubtreeTreeCondition
 
deleteWithCondition(Connection, RDBDocumentStore.RDBTableMetaData, List<RDBDocumentStore.QueryCondition>) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStoreJDBC
 
DEPRECATION_MESSAGE - Static variable in interface org.apache.jackrabbit.oak.plugins.index.property.OrderedIndex
Deprecation message tracked when using the ordered index.
depth() - Method in interface org.apache.jackrabbit.oak.plugins.document.bundlor.Matcher
Matcher depth.
descendantNode(String, String) - Method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
 
DescendantNodeImpl - Class in org.apache.jackrabbit.oak.query.ast
The "isdescendantnode(...)" condition.
DescendantNodeImpl(String, String) - Constructor for class org.apache.jackrabbit.oak.query.ast.DescendantNodeImpl
 
descendantNodeJoinCondition(String, String) - Method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
 
DescendantNodeJoinConditionImpl - Class in org.apache.jackrabbit.oak.query.ast
The "isdescendantnode(...)" join condition.
DescendantNodeJoinConditionImpl(String, String) - Constructor for class org.apache.jackrabbit.oak.query.ast.DescendantNodeJoinConditionImpl
 
descending(DynamicOperandImpl) - Method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
 
description - Variable in enum org.apache.jackrabbit.oak.plugins.document.rdb.RDBBlobStoreDB
 
description - Variable in enum org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStoreDB
 
description() - Method in class org.apache.jackrabbit.oak.plugins.document.util.MergeSortedIterators
Provides details about this iterator
determineServerTimeDifferenceMillis() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreMBean
 
determineServerTimeDifferenceMillis() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStore
 
determineServerTimeDifferenceMillis() - Method in class org.apache.jackrabbit.oak.plugins.document.memory.MemoryDocumentStore
 
determineServerTimeDifferenceMillis() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoDocumentStore
 
determineServerTimeDifferenceMillis() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
determineServerTimeDifferenceMillis(Connection) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStoreJDBC
 
determineServerTimeDifferenceMillis() - Method in class org.apache.jackrabbit.oak.plugins.document.util.LeaseCheckDocumentStoreWrapper
 
determineServerTimeDifferenceMillis() - Method in class org.apache.jackrabbit.oak.plugins.document.util.LoggingDocumentStoreWrapper
 
determineServerTimeDifferenceMillis() - Method in class org.apache.jackrabbit.oak.plugins.document.util.SynchronizingDocumentStoreWrapper
 
determineServerTimeDifferenceMillis() - Method in class org.apache.jackrabbit.oak.plugins.document.util.TimingDocumentStoreWrapper
 
diff(AbstractDocumentNodeState, AbstractDocumentNodeState, JsopWriter) - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundledDocumentDiffer
Performs diff for bundled nodes.
diff(String, String, String, int) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK
 
Diff(Map<String, String>, long) - Constructor for class org.apache.jackrabbit.oak.plugins.document.LocalDiffCache.Diff
 
diff(long, long) - Static method in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
Returns those bits from permissions that are not present in the otherPermissions, i.e.
diff(PrivilegeBits) - Method in class org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeBits
Subtracts the other PrivilegeBits from the this.
If the specified bits do not intersect with this, it isn't modified.
If this is included in other empty privilege bits is returned.
diffCache - Variable in class org.apache.jackrabbit.oak.plugins.document.MemoryDiffCache
Diff cache.
diffCacheStats - Variable in class org.apache.jackrabbit.oak.plugins.document.MemoryDiffCache
 
DiffCollector - Interface in org.apache.jackrabbit.oak.plugins.index.diffindex
In charge of collecting the paths of nodes that match a given filter from the diff of the 2 states.
differ(NodeStateDiffer) - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.SecondaryStoreBuilder
 
difference(RevisionVector) - Method in class org.apache.jackrabbit.oak.plugins.document.RevisionVector
Returns the difference of this and the other vector.
DiffIndex - Class in org.apache.jackrabbit.oak.plugins.index.diffindex
QueryIndex that relies n a diff-ing mechanism to get query results
DiffIndex(DiffCollector) - Constructor for class org.apache.jackrabbit.oak.plugins.index.diffindex.DiffIndex
 
DIRECTION - Static variable in interface org.apache.jackrabbit.oak.plugins.index.property.OrderedIndex
the 'key' used for specifying the direction of the index when providing the configuration { "propertyNames"="foobar", "direction"="ascending" }
disableBranches() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
disableCopyOnWrite() - Method in class org.apache.jackrabbit.oak.plugins.cow.COWNodeStore
 
disconnect(String) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentBroadcastConfig
 
disconnect(String) - Method in interface org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast.DynamicBroadcastConfig
Sign off.
disconnect() - Method in class org.apache.jackrabbit.oak.plugins.document.SplitDocumentCleanUp
 
dispose() - Method in class org.apache.jackrabbit.oak.plugins.cow.BranchNodeStore
 
dispose() - Method in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfo
 
dispose() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK
 
dispose() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
dispose() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStore
Dispose this instance.
dispose() - Method in class org.apache.jackrabbit.oak.plugins.document.memory.MemoryDocumentStore
 
dispose() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoDocumentStore
 
dispose() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
dispose() - Method in class org.apache.jackrabbit.oak.plugins.document.util.LeaseCheckDocumentStoreWrapper
 
dispose() - Method in class org.apache.jackrabbit.oak.plugins.document.util.LoggingDocumentStoreWrapper
 
dispose() - Method in class org.apache.jackrabbit.oak.plugins.document.util.SynchronizingDocumentStoreWrapper
 
dispose() - Method in class org.apache.jackrabbit.oak.plugins.document.util.TimingDocumentStoreWrapper
 
dispose() - Method in class org.apache.jackrabbit.oak.spi.xml.PropInfo
Disposes all values contained in this property.
dispose() - Method in interface org.apache.jackrabbit.oak.spi.xml.TextValue
Dispose this value, i.e.
doCreateToken(Credentials) - Method in class org.apache.jackrabbit.oak.spi.security.authentication.token.CompositeTokenProvider
 
doCreateToken(Credentials) - Method in interface org.apache.jackrabbit.oak.spi.security.authentication.token.TokenProvider
Returns true if the given credentials indicate that a new token needs to be issued.
Document - Class in org.apache.jackrabbit.oak.plugins.document
A document corresponds to a node stored in the DocumentNodeStore.
Document() - Constructor for class org.apache.jackrabbit.oak.plugins.document.Document
 
DOCUMENT_NODE_STORE - Static variable in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundlingConfigHandler
 
DocumentBlobReferenceRetriever - Class in org.apache.jackrabbit.oak.plugins.document
Implementation of BlobReferenceRetriever for the DocumentNodeStore.
DocumentBlobReferenceRetriever(DocumentNodeStore) - Constructor for class org.apache.jackrabbit.oak.plugins.document.DocumentBlobReferenceRetriever
 
DocumentBroadcastConfig - Class in org.apache.jackrabbit.oak.plugins.document
 
DocumentBroadcastConfig(DocumentNodeStore) - Constructor for class org.apache.jackrabbit.oak.plugins.document.DocumentBroadcastConfig
 
DocumentBundlor - Class in org.apache.jackrabbit.oak.plugins.document.bundlor
 
DocumentCheckpointMBean - Class in org.apache.jackrabbit.oak.plugins.document
CheckpointMBean implementation for the DocumentNodeStore.
DocumentCheckpointMBean(DocumentNodeStore) - Constructor for class org.apache.jackrabbit.oak.plugins.document.DocumentCheckpointMBean
 
DocumentDiscoveryLiteService - Class in org.apache.jackrabbit.oak.plugins.document
The DocumentDiscoveryLiteService is taking care of providing a repository descriptor that contains the current cluster-view details.
DocumentDiscoveryLiteService() - Constructor for class org.apache.jackrabbit.oak.plugins.document.DocumentDiscoveryLiteService
 
DocumentMK - Class in org.apache.jackrabbit.oak.plugins.document
A JSON-based wrapper around the NodeStore implementation that stores the data in a DocumentStore.
DocumentMK.Builder - Class in org.apache.jackrabbit.oak.plugins.document
A builder for a DocumentMK instance.
DocumentNodeState - Class in org.apache.jackrabbit.oak.plugins.document
A NodeState implementation for the DocumentNodeStore.
DocumentNodeState.Children - Class in org.apache.jackrabbit.oak.plugins.document
A list of children for a node.
DocumentNodeStateCache - Interface in org.apache.jackrabbit.oak.plugins.document
 
DocumentNodeStore - Class in org.apache.jackrabbit.oak.plugins.document
Implementation of a NodeStore on DocumentStore.
DocumentNodeStore(DocumentMK.Builder) - Constructor for class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
DocumentNodeStoreMBean - Interface in org.apache.jackrabbit.oak.plugins.document
 
DocumentNodeStoreService - Class in org.apache.jackrabbit.oak.plugins.document
The OSGi service to start/stop a DocumentNodeStore instance.
DocumentNodeStoreService() - Constructor for class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreService
 
DocumentNodeStoreStats - Class in org.apache.jackrabbit.oak.plugins.document
 
DocumentNodeStoreStats(StatisticsProvider) - Constructor for class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreStats
 
DocumentNodeStoreStatsCollector - Interface in org.apache.jackrabbit.oak.plugins.document
 
documentRead() - Method in interface org.apache.jackrabbit.oak.plugins.document.RevisionGCStatsCollector
 
documentsDeleted(long) - Method in interface org.apache.jackrabbit.oak.plugins.document.RevisionGCStatsCollector
 
DocumentStore - Interface in org.apache.jackrabbit.oak.plugins.document
The interface for the backend storage for documents.
DocumentStoreException - Exception in org.apache.jackrabbit.oak.plugins.document
DocumentStoreException is a runtime exception for DocumentStore implementations to signal unexpected problems like a communication exception.
DocumentStoreException(String) - Constructor for exception org.apache.jackrabbit.oak.plugins.document.DocumentStoreException
 
DocumentStoreException(Throwable) - Constructor for exception org.apache.jackrabbit.oak.plugins.document.DocumentStoreException
 
DocumentStoreException(String, Throwable) - Constructor for exception org.apache.jackrabbit.oak.plugins.document.DocumentStoreException
 
DocumentStoreStats - Class in org.apache.jackrabbit.oak.plugins.document
Document Store statistics helper class.
DocumentStoreStats(StatisticsProvider) - Constructor for class org.apache.jackrabbit.oak.plugins.document.DocumentStoreStats
 
DocumentStoreStatsCollector - Interface in org.apache.jackrabbit.oak.plugins.document
 
DocumentStoreStatsMBean - Interface in org.apache.jackrabbit.oak.plugins.document
 
doesHitMaxPathDepth() - Method in class org.apache.jackrabbit.oak.plugins.observation.ChangeSet
 
done() - Method in class org.apache.jackrabbit.oak.plugins.document.MemoryDiffCache.MemoryEntry
 
doneBackgroundRead(BackgroundReadStats) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreStats
 
doneBackgroundRead(BackgroundReadStats) - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreStatsCollector
 
doneBackgroundUpdate(BackgroundWriteStats) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreStats
 
doneBackgroundUpdate(BackgroundWriteStats) - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreStatsCollector
 
doneCreate(long, Collection<? extends Document>, List<String>, boolean) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentStoreStats
 
doneCreate(long, Collection<? extends Document>, List<String>, boolean) - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStoreStatsCollector
Called when a document is created in the given collection
doneCreateOrUpdate(long, Collection<? extends Document>, List<String>) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentStoreStats
 
doneCreateOrUpdate(long, Collection<? extends Document>, List<String>) - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStoreStatsCollector
Called when multiple document are either created or updated.
doneFindAndModify(long, Collection<? extends Document>, String, boolean, boolean, int) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentStoreStats
 
doneFindAndModify(long, Collection<? extends Document>, String, boolean, boolean, int) - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStoreStatsCollector
Called when a update operation was completed which affected single document.
doneFindCached(Collection<? extends Document>, String) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentStoreStats
 
doneFindCached(Collection<? extends Document>, String) - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStoreStatsCollector
Called when a document with given key is found from the cache
doneFindUncached(long, Collection<? extends Document>, String, boolean, boolean) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentStoreStats
 
doneFindUncached(long, Collection<? extends Document>, String, boolean, boolean) - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStoreStatsCollector
Called when a document with given key is read from remote store
doneMerge(int, long, boolean, boolean) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreStats
 
doneMerge(int, long, boolean, boolean) - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreStatsCollector
 
doneQuery(long, Collection<? extends Document>, String, String, boolean, int, long, boolean) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentStoreStats
 
doneQuery(long, Collection<? extends Document>, String, String, boolean, int, long, boolean) - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStoreStatsCollector
Called when query with given parameters is performed
doneRemove(long, Collection<? extends Document>, int) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentStoreStats
 
doneRemove(long, Collection<? extends Document>, int) - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStoreStatsCollector
Called when a remove operation for documents was completed.
doneUpdate(long, Collection<? extends Document>, int) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentStoreStats
 
doneUpdate(long, Collection<? extends Document>, int) - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStoreStatsCollector
Called when a given updated has modified multiple documents
DoubleConstraint - Class in org.apache.jackrabbit.oak.plugins.nodetype.constraint
 
DoubleConstraint(String) - Constructor for class org.apache.jackrabbit.oak.plugins.nodetype.constraint.DoubleConstraint
 
driverForDBType(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBJDBCTools
 
dropTablesOnClose(boolean) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBOptions
Whether to drop the tables on close (in case they have been auto-created)
dumpResultSetMeta(ResultSetMetaData) - Static method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBJDBCTools
Return approximated string representation of table DDL.
DynamicBroadcastConfig - Interface in org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast
Broadcast configuration.
DynamicOperandImpl - Class in org.apache.jackrabbit.oak.query.ast
The base class for dynamic operands (such as a function or property).
DynamicOperandImpl() - Constructor for class org.apache.jackrabbit.oak.query.ast.DynamicOperandImpl
 

E

EffectiveNodeType - Class in org.apache.jackrabbit.oak.plugins.nodetype
EffectiveNodeType...
EffectiveNodeTypeProvider - Interface in org.apache.jackrabbit.oak.plugins.nodetype
EffectiveNodeTypeProvider...
EMPTY - Static variable in class org.apache.jackrabbit.oak.plugins.index.fulltext.ExtractedText
 
EMPTY - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.RepositoryPermission
RepositoryPermission instance that always returns false.
EMPTY - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.TreePermission
TreePermission which always returns false not granting any permissions.
EMPTY - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.restriction.RestrictionPattern
Default implementation of the RestrictionPattern that always returns true and thus matches all items or paths.
EMPTY - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.restriction.RestrictionProvider
Empty restriction provider implementation that doesn't support any restrictions.
EMPTY - Static variable in class org.apache.jackrabbit.oak.spi.security.ConfigurationParameters
An empty configuration parameters
EMPTY - Static variable in class org.apache.jackrabbit.oak.spi.security.principal.PrincipalIteratorAdapter
Static instance of an empty PrincipalIterator.
EMPTY - Static variable in class org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeBits
 
EMPTY_KEY_PATTERN - Static variable in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
EmptyPermissionProvider - Class in org.apache.jackrabbit.oak.spi.security.authorization.permission
Permission provider implementation that does not grant any permissions.
EmptyPrincipalProvider - Class in org.apache.jackrabbit.oak.spi.security.principal
Implementation of the PrincipalProvider interface that never returns any principals.
enableCopyOnWrite() - Method in class org.apache.jackrabbit.oak.plugins.cow.COWNodeStore
 
encodeUri(String) - Static method in class org.apache.jackrabbit.oak.plugins.name.Namespaces
encodes the uri value to be used as a property
end(Tree) - Method in class org.apache.jackrabbit.oak.security.authorization.accesscontrol.AccessControlImporter
 
end() - Method in interface org.apache.jackrabbit.oak.spi.xml.Importer
Called once at the end of the content import.
end(Tree) - Method in interface org.apache.jackrabbit.oak.spi.xml.ProtectedNodeImporter
Informs this importer that the tree to be imported below protectedParent has bee completed.
endChildInfo() - Method in class org.apache.jackrabbit.oak.security.authorization.accesscontrol.AccessControlImporter
 
endChildInfo() - Method in interface org.apache.jackrabbit.oak.spi.xml.ProtectedNodeImporter
Informs this importer about the end of a child info.
endNode(NodeInfo) - Method in interface org.apache.jackrabbit.oak.spi.xml.Importer
Called to end the import of a node.
endsAfter(long) - Method in class org.apache.jackrabbit.oak.plugins.document.util.TimeInterval
Checks whether the interval end after the given time stamp.
enter(NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.commit.ConflictValidator
 
enter(NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.index.counter.NodeCounterEditor
 
enter(NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.index.IndexUpdate
 
enter(NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.DefaultEventHandler
 
enter(NodeState, NodeState) - Method in interface org.apache.jackrabbit.oak.plugins.observation.EventHandler
Called before the given before and after states are compared.
enter(NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.FilteredHandler
 
ENTRY_COUNT_PROPERTY_NAME - Static variable in interface org.apache.jackrabbit.oak.plugins.index.IndexConstants
 
entrySet() - Method in class org.apache.jackrabbit.oak.plugins.document.Document
 
entrySet() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.MultiGenerationMap
 
entrySet() - Method in class org.apache.jackrabbit.oak.spi.security.ConfigurationParameters
equals(Object) - Method in class org.apache.jackrabbit.oak.plugins.document.AbstractDocumentNodeState
 
equals(Object) - Method in class org.apache.jackrabbit.oak.plugins.document.FormatVersion
 
equals(Object) - Method in class org.apache.jackrabbit.oak.plugins.document.LocalDiffCache.Diff
 
equals(Object) - Method in class org.apache.jackrabbit.oak.plugins.document.PathRev
 
equals(Object) - Method in class org.apache.jackrabbit.oak.plugins.document.Revision
 
equals(Object) - Method in class org.apache.jackrabbit.oak.plugins.document.RevisionVector
 
equals(Object) - Method in class org.apache.jackrabbit.oak.plugins.document.UpdateOp.Key
 
equals(Object) - Method in class org.apache.jackrabbit.oak.plugins.document.util.RevisionsKey
 
equals(Object) - Method in class org.apache.jackrabbit.oak.plugins.document.util.StringValue
 
equals(Object) - Method in class org.apache.jackrabbit.oak.plugins.document.util.TimeInterval
 
equals(Calendar, Calendar) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.DateConstraint
 
equals(BigDecimal, BigDecimal) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.DecimalConstraint
 
equals(T, T) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.NumericConstraint
 
equals(Object) - Method in class org.apache.jackrabbit.oak.plugins.observation.ChangeSet
 
equals(Object) - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.ImmutableTree
 
equals(Object) - Method in class org.apache.jackrabbit.oak.query.ast.AndImpl
 
equals(Object) - Method in class org.apache.jackrabbit.oak.query.ast.BindVariableValueImpl
 
equals(Object) - Method in class org.apache.jackrabbit.oak.query.ast.ConstraintImpl
 
equals(Object) - Method in class org.apache.jackrabbit.oak.query.ast.DynamicOperandImpl
 
equals(Object) - Method in class org.apache.jackrabbit.oak.query.ast.InImpl
 
equals(Object) - Method in class org.apache.jackrabbit.oak.query.ast.LiteralImpl
 
equals(Object) - Method in class org.apache.jackrabbit.oak.query.ast.OrImpl
 
equals(Object) - Method in class org.apache.jackrabbit.oak.query.ast.PropertyExistenceImpl
 
equals(Object) - Method in class org.apache.jackrabbit.oak.query.ast.PropertyInexistenceImpl
 
equals(Object) - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
 
equals(Object) - Method in class org.apache.jackrabbit.oak.query.ResultRowImpl
 
equals(Object) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.ACE
 
equals(Object) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.ImmutableACL
 
equals(Object) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.restriction.RestrictionDefinitionImpl
 
equals(Object) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.restriction.RestrictionImpl
 
equals(Object) - Method in class org.apache.jackrabbit.oak.spi.security.ConfigurationParameters.Milliseconds
 
equals(Object) - Method in class org.apache.jackrabbit.oak.spi.security.principal.EveryonePrincipal
 
equals(Object) - Method in class org.apache.jackrabbit.oak.spi.security.principal.PrincipalImpl
Two principals are equal, if their names are.
equals(Object) - Method in class org.apache.jackrabbit.oak.spi.security.privilege.ImmutablePrivilegeDefinition
 
equals(Object) - Method in class org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeBits
 
equiJoinCondition(String, String, String, String) - Method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
 
EquiJoinConditionImpl - Class in org.apache.jackrabbit.oak.query.ast
The "a.x = b.y" join condition.
EquiJoinConditionImpl(String, String, String, String) - Constructor for class org.apache.jackrabbit.oak.query.ast.EquiJoinConditionImpl
 
ERROR - Static variable in class org.apache.jackrabbit.oak.plugins.index.fulltext.ExtractedText
 
escapeForQuery(String, NamePathMapper) - Static method in class org.apache.jackrabbit.oak.security.user.query.QueryUtil
 
escapeForQuery(String) - Static method in class org.apache.jackrabbit.oak.security.user.query.QueryUtil
 
escapeNodeName(String) - Static method in class org.apache.jackrabbit.oak.security.user.query.QueryUtil
Escape string for matching in jcr escaped node names
escapePropertyName(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
 
escapeStringLiteral(String) - Static method in class org.apache.jackrabbit.oak.query.SQL2Parser
 
estimateCurrentWeight() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
estimatedIterations - Variable in class org.apache.jackrabbit.oak.plugins.document.VersionGarbageCollector.VersionGCInfo
 
estimateMemoryUsage(Map<?, Object>) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
 
evaluate() - Method in class org.apache.jackrabbit.oak.query.ast.AndImpl
 
evaluate() - Method in class org.apache.jackrabbit.oak.query.ast.ChildNodeImpl
 
evaluate() - Method in class org.apache.jackrabbit.oak.query.ast.ChildNodeJoinConditionImpl
 
evaluate() - Method in class org.apache.jackrabbit.oak.query.ast.ComparisonImpl
 
evaluate() - Method in class org.apache.jackrabbit.oak.query.ast.ConstraintImpl
Evaluate the result using the currently set values.
evaluate() - Method in class org.apache.jackrabbit.oak.query.ast.DescendantNodeImpl
 
evaluate() - Method in class org.apache.jackrabbit.oak.query.ast.DescendantNodeJoinConditionImpl
 
evaluate() - Method in class org.apache.jackrabbit.oak.query.ast.EquiJoinConditionImpl
 
evaluate() - Method in class org.apache.jackrabbit.oak.query.ast.FullTextSearchImpl
 
evaluate() - Method in class org.apache.jackrabbit.oak.query.ast.InImpl
 
evaluate() - Method in class org.apache.jackrabbit.oak.query.ast.JoinConditionImpl
Evaluate the result using the currently set values.
evaluate() - Method in class org.apache.jackrabbit.oak.query.ast.NativeFunctionImpl
 
evaluate() - Method in class org.apache.jackrabbit.oak.query.ast.NotImpl
 
evaluate(PropertyValue, PropertyValue) - Method in enum org.apache.jackrabbit.oak.query.ast.Operator
"operand2 always evaluates to a scalar value" for multi-valued properties: if any of the value matches, then return true
evaluate() - Method in class org.apache.jackrabbit.oak.query.ast.OrImpl
 
evaluate() - Method in class org.apache.jackrabbit.oak.query.ast.PropertyExistenceImpl
 
evaluate() - Method in class org.apache.jackrabbit.oak.query.ast.PropertyInexistenceImpl
 
evaluate() - Method in class org.apache.jackrabbit.oak.query.ast.SameNodeImpl
 
evaluate() - Method in class org.apache.jackrabbit.oak.query.ast.SameNodeJoinConditionImpl
 
evaluate() - Method in class org.apache.jackrabbit.oak.query.ast.SimilarImpl
 
evaluate() - Method in class org.apache.jackrabbit.oak.query.ast.SpellcheckImpl
 
evaluate() - Method in class org.apache.jackrabbit.oak.query.ast.SuggestImpl
 
evaluateStop() - Method in class org.apache.jackrabbit.oak.query.ast.AndImpl
 
evaluateStop() - Method in class org.apache.jackrabbit.oak.query.ast.ConstraintImpl
Whether this condition will, from now on, always evaluate to false.
evaluateStop() - Method in class org.apache.jackrabbit.oak.query.ast.FullTextSearchImpl
 
evaluateStop() - Method in class org.apache.jackrabbit.oak.query.ast.OrImpl
 
EventAggregator - Interface in org.apache.jackrabbit.oak.plugins.observation.filter
An EventAggregator can be provided via a FilterProvider and is then used to 'aggregate' an event at creation time (ie after filtering).
EventFilter - Interface in org.apache.jackrabbit.oak.plugins.observation.filter
Filter for determining what changes to report the the event listener.
EventGenerator - Class in org.apache.jackrabbit.oak.plugins.observation
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.
EventGenerator() - Constructor for class org.apache.jackrabbit.oak.plugins.observation.EventGenerator
Creates a new generator instance.
EventGenerator(NodeState, NodeState, EventHandler) - Constructor for class org.apache.jackrabbit.oak.plugins.observation.EventGenerator
Creates a new generator instance for processing the given changes.
EventHandler - Interface in org.apache.jackrabbit.oak.plugins.observation
Handler of content change events.
eventType(int) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder
A condition that holds for matching event types.
EventTypeFilter - Class in org.apache.jackrabbit.oak.plugins.observation.filter
EventTypeFilter filters based on event types as defined by ObservationManager.addEventListener().
EventTypeFilter(int) - Constructor for class org.apache.jackrabbit.oak.plugins.observation.filter.EventTypeFilter
Create a new Filter instance that includes all events matching the eventTypes bit mask.
EveryonePrincipal - Class in org.apache.jackrabbit.oak.spi.security.principal
Built-in principal group that has every other principal as member.
evicted(K, V, RemovalCause) - Method in interface org.apache.jackrabbit.oak.plugins.document.persistentCache.EvictionListener
 
EvictionListener<K,V> - Interface in org.apache.jackrabbit.oak.plugins.document.persistentCache
A listener that gets notified of entries that were removed from the cache.
EXCLUDE_ALL - Static variable in class org.apache.jackrabbit.oak.plugins.observation.filter.ConstantFilter
 
excludeAll() - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder
A condition that never holds
excludeAll() - Static method in class org.apache.jackrabbit.oak.plugins.observation.filter.Filters
 
ExcludeExternal - Interface in org.apache.jackrabbit.oak.plugins.observation
The presence of this marker interface on a EventListener indicates that cluster external observation events must not be reported to that event listener.
excludes(ChangeSet) - Method in interface org.apache.jackrabbit.oak.plugins.observation.filter.ChangeSetFilter
Decides if the commit belonging to the provided ChangeSet is potentially relevant to the listener or if it can definitely be excluded.
excludes(ChangeSet) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.ChangeSetFilterImpl
 
excludes(NodeState, CommitInfo) - Method in interface org.apache.jackrabbit.oak.plugins.observation.Filter
Whether or not to exclude a particular content change from being forwarded to downstream observers.
execute(NodeState) - Method in class org.apache.jackrabbit.oak.query.ast.JoinImpl
 
execute(NodeState) - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
 
execute(NodeState) - Method in class org.apache.jackrabbit.oak.query.ast.SourceImpl
Execute the query.
execute(long) - Method in class org.apache.jackrabbit.oak.query.stats.QueryStatsData.QueryExecutionStats
 
executeQuery() - Method in interface org.apache.jackrabbit.oak.query.Query
 
executeQuery(String, String, Map<String, ? extends PropertyValue>, Map<String, String>) - Method in class org.apache.jackrabbit.oak.query.QueryEngineImpl
 
executeQuery(String, String, long, long, Map<String, ? extends PropertyValue>, Map<String, String>) - Method in class org.apache.jackrabbit.oak.query.QueryEngineImpl
 
executeQuery() - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
executeQuery() - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
ExecutionContext - Class in org.apache.jackrabbit.oak.query
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.
ExecutionContext(NodeState, Root, QueryEngineSettings, QueryIndexProvider, PermissionProvider) - Constructor for class org.apache.jackrabbit.oak.query.ExecutionContext
 
ExecutionPlan - Interface in org.apache.jackrabbit.oak.query.plan
An execution plan for a join or a selector.
exists() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState
 
exists() - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.DelegatingDocumentNodeState
 
EXISTS - Static variable in class org.apache.jackrabbit.oak.plugins.document.UpdateOp.Condition
Check if a sub-key exists in a map.
exists(Supplier<NodeBuilder>, String) - Method in class org.apache.jackrabbit.oak.plugins.index.property.strategy.ContentMirrorStoreStrategy
 
exists(Supplier<NodeBuilder>, String) - Method in class org.apache.jackrabbit.oak.plugins.index.property.strategy.FilteringIndexStoreStrategy
 
exists(Supplier<NodeBuilder>, String) - Method in interface org.apache.jackrabbit.oak.plugins.index.property.strategy.IndexStoreStrategy
Check whether an entry for the given key exists.
exists(Supplier<NodeBuilder>, String) - Method in class org.apache.jackrabbit.oak.plugins.index.property.strategy.UniqueEntryStoreStrategy
 
exists() - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractTree
 
exists() - Method in class org.apache.jackrabbit.oak.plugins.tree.TreeLocation
Determine whether the underlying Tree or PropertyState for this TreeLocation is available.
exists() - Method in interface org.apache.jackrabbit.oak.query.ast.NodeTypeInfo
Check whether the nodetype exists.
ExtractedText - Class in org.apache.jackrabbit.oak.plugins.index.fulltext
 
ExtractedText(ExtractedText.ExtractionResult) - Constructor for class org.apache.jackrabbit.oak.plugins.index.fulltext.ExtractedText
 
ExtractedText(ExtractedText.ExtractionResult, CharSequence) - Constructor for class org.apache.jackrabbit.oak.plugins.index.fulltext.ExtractedText
 
ExtractedText.ExtractionResult - Enum in org.apache.jackrabbit.oak.plugins.index.fulltext
 

F

FacetColumnImpl - Class in org.apache.jackrabbit.oak.query.ast
A facet result column expression.
FacetResult - Class in org.apache.jackrabbit.oak.query.facet
A facet result is a wrapper for QueryResult capable of returning information about facets stored in the query result Rows.
FacetResult(QueryResult) - Constructor for class org.apache.jackrabbit.oak.query.facet.FacetResult
 
FacetResult.Facet - Class in org.apache.jackrabbit.oak.query.facet
A query result facet, composed by its label and count.
failedMerge(int, long, boolean, boolean) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreStats
 
failedMerge(int, long, boolean, boolean) - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreStatsCollector
 
filter(String) - Method in class org.apache.jackrabbit.oak.plugins.index.PathFilter
Determines whether given path is to be included or not
Filter - Interface in org.apache.jackrabbit.oak.plugins.observation
A filter is used by the FilteringObserver to decide whether or not a content change should be forwarded.
FilterBuilder - Class in org.apache.jackrabbit.oak.plugins.observation.filter
Builder for FilterProvider instances.
FilterBuilder() - Constructor for class org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder
 
FilterBuilder.AddSubtreeTreeCondition - Class in org.apache.jackrabbit.oak.plugins.observation.filter
 
FilterBuilder.Condition - Interface in org.apache.jackrabbit.oak.plugins.observation.filter
 
FilterBuilder.DeleteSubtreeTreeCondition - Class in org.apache.jackrabbit.oak.plugins.observation.filter
 
FilterBuilder.MoveCondition - Class in org.apache.jackrabbit.oak.plugins.observation.filter
 
FilterConfigMBean - Interface in org.apache.jackrabbit.oak.plugins.observation.filter
 
FilteredHandler - Class in org.apache.jackrabbit.oak.plugins.observation
Filtered event handler.
FilteredHandler(EventFilter, EventHandler) - Constructor for class org.apache.jackrabbit.oak.plugins.observation.FilteredHandler
 
FilterImpl - Class in org.apache.jackrabbit.oak.query.index
A filter or lookup condition.
FilterImpl(SelectorImpl, String, QueryLimits) - Constructor for class org.apache.jackrabbit.oak.query.index.FilterImpl
Create a filter.
FilterImpl(Filter) - Constructor for class org.apache.jackrabbit.oak.query.index.FilterImpl
 
FilteringAwareObserver - Interface in org.apache.jackrabbit.oak.plugins.observation
A FilteringAwareObserver is the stateless-variant of an Observer which gets an explicit before as well as the after NodeState.
FilteringDispatcher - Class in org.apache.jackrabbit.oak.plugins.observation
Part of the FilteringObserver: the FilteringDispatcher is used to implement the skipping (filtering) of content changes which the FilteringDispatcher flags as NOOP_CHANGE.
FilteringDispatcher(FilteringAwareObserver) - Constructor for class org.apache.jackrabbit.oak.plugins.observation.FilteringDispatcher
 
FilteringIndexStoreStrategy - Class in org.apache.jackrabbit.oak.plugins.index.property.strategy
A delegating IndexStoreStrategy that filters out updates that are not accepted by the given predicate
FilteringIndexStoreStrategy(IndexStoreStrategy, Predicate<String>) - Constructor for class org.apache.jackrabbit.oak.plugins.index.property.strategy.FilteringIndexStoreStrategy
 
FilteringIndexStoreStrategy(IndexStoreStrategy, Predicate<String>, boolean) - Constructor for class org.apache.jackrabbit.oak.plugins.index.property.strategy.FilteringIndexStoreStrategy
 
FilteringObserver - Class in org.apache.jackrabbit.oak.plugins.observation
An observer that implements filtering of content changes while at the same time supporting (wrapping) a BackgroundObserver underneath.
FilteringObserver(Executor, int, Filter, FilteringAwareObserver) - Constructor for class org.apache.jackrabbit.oak.plugins.observation.FilteringObserver
Default constructor which creates a BackgroundObserver automatically, including creating a FilteringDispatcher.
FilteringObserver(BackgroundObserver, Filter) - Constructor for class org.apache.jackrabbit.oak.plugins.observation.FilteringObserver
Alternative constructor where the BackgroundObserver is created elsewhere
FilterIterators - Class in org.apache.jackrabbit.oak.query
Filtering iterators that are useful for queries with limit, offset, order by, or distinct.
FilterProvider - Interface in org.apache.jackrabbit.oak.plugins.observation.filter
Instance of this class provide a EventFilter for observation events and a filter for commits.
Filters - Class in org.apache.jackrabbit.oak.plugins.observation.filter
This utility class provides common EventFilter instances
finalize() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoDocumentStore
 
finalize() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBBlobStore
 
finalize() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
find(Collection<T>, String) - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStore
Get the document with the given key.
find(Collection<T>, String, int) - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStore
Get the document with the key.
find(Collection<T>, String, int) - Method in class org.apache.jackrabbit.oak.plugins.document.memory.MemoryDocumentStore
 
find(Collection<T>, String) - Method in class org.apache.jackrabbit.oak.plugins.document.memory.MemoryDocumentStore
 
find(Collection<T>, String) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoDocumentStore
 
find(Collection<T>, String, int) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoDocumentStore
 
find(Collection<T>, String) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
find(Collection<T>, String, int) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
find(Collection<T>, String) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LeaseCheckDocumentStoreWrapper
 
find(Collection<T>, String, int) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LeaseCheckDocumentStoreWrapper
 
find(Collection<T>, String) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LoggingDocumentStoreWrapper
 
find(Collection<T>, String, int) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LoggingDocumentStoreWrapper
 
find(Collection<T>, String) - Method in class org.apache.jackrabbit.oak.plugins.document.util.SynchronizingDocumentStoreWrapper
 
find(Collection<T>, String, int) - Method in class org.apache.jackrabbit.oak.plugins.document.util.SynchronizingDocumentStoreWrapper
 
find(Collection<T>, String) - Method in class org.apache.jackrabbit.oak.plugins.document.util.TimingDocumentStoreWrapper
 
find(Collection<T>, String, int) - Method in class org.apache.jackrabbit.oak.plugins.document.util.TimingDocumentStoreWrapper
 
findAndUpdate(Collection<T>, UpdateOp) - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStore
Performs a conditional update (e.g.
findAndUpdate(Collection<T>, UpdateOp) - Method in class org.apache.jackrabbit.oak.plugins.document.memory.MemoryDocumentStore
 
findAndUpdate(Collection<T>, UpdateOp) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoDocumentStore
 
findAndUpdate(Collection<T>, UpdateOp) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
findAndUpdate(Collection<T>, UpdateOp) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LeaseCheckDocumentStoreWrapper
 
findAndUpdate(Collection<T>, UpdateOp) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LoggingDocumentStoreWrapper
 
findAndUpdate(Collection<T>, UpdateOp) - Method in class org.apache.jackrabbit.oak.plugins.document.util.SynchronizingDocumentStoreWrapper
 
findAndUpdate(Collection<T>, UpdateOp) - Method in class org.apache.jackrabbit.oak.plugins.document.util.TimingDocumentStoreWrapper
 
findAuthorizables(String, String) - Method in class org.apache.jackrabbit.oak.security.user.autosave.AutoSaveEnabledManager
 
findAuthorizables(String, String, int) - Method in class org.apache.jackrabbit.oak.security.user.autosave.AutoSaveEnabledManager
 
findAuthorizables(Query) - Method in class org.apache.jackrabbit.oak.security.user.autosave.AutoSaveEnabledManager
 
findAuthorizables(Query) - Method in class org.apache.jackrabbit.oak.security.user.query.UserQueryManager
Find the authorizables matching the specified user Query.
findAuthorizables(String, String, AuthorizableType) - Method in class org.apache.jackrabbit.oak.security.user.query.UserQueryManager
Find the authorizables matching the following search parameters within the sub-tree defined by an authorizable tree:
findAuthorizables(String, String, AuthorizableType, boolean) - Method in class org.apache.jackrabbit.oak.security.user.query.UserQueryManager
Find the authorizables matching the following search parameters within the sub-tree defined by an authorizable tree:
findAuthorizables(String, String) - Method in class org.apache.jackrabbit.oak.security.user.UserManagerImpl
 
findAuthorizables(String, String, int) - Method in class org.apache.jackrabbit.oak.security.user.UserManagerImpl
 
findAuthorizables(Query) - Method in class org.apache.jackrabbit.oak.security.user.UserManagerImpl
 
findDefaultPrimaryType(Tree, boolean) - Static method in class org.apache.jackrabbit.oak.plugins.tree.TreeUtil
 
findPrincipals(String, int) - Method in class org.apache.jackrabbit.oak.spi.security.principal.CompositePrincipalProvider
 
findPrincipals(int) - Method in class org.apache.jackrabbit.oak.spi.security.principal.CompositePrincipalProvider
 
findPrincipals(String, int) - Method in class org.apache.jackrabbit.oak.spi.security.principal.EmptyPrincipalProvider
 
findPrincipals(int) - Method in class org.apache.jackrabbit.oak.spi.security.principal.EmptyPrincipalProvider
 
findPrincipals(String) - Method in class org.apache.jackrabbit.oak.spi.security.principal.PrincipalManagerImpl
 
findPrincipals(String, int) - Method in class org.apache.jackrabbit.oak.spi.security.principal.PrincipalManagerImpl
 
findPrincipals(String, int) - Method in interface org.apache.jackrabbit.oak.spi.security.principal.PrincipalProvider
Find the principals that match the specified nameHint and search type.
findPrincipals(int) - Method in interface org.apache.jackrabbit.oak.spi.security.principal.PrincipalProvider
Find all principals that match the search type.
findUncached(Collection<T>, String, MongoDocumentStore.DocumentReadPreference) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoDocumentStore
 
finished(VersionGarbageCollector.VersionGCStats) - Method in interface org.apache.jackrabbit.oak.plugins.document.RevisionGCStatsCollector
 
firstReordered(PropertyState, PropertyState) - Static method in class org.apache.jackrabbit.oak.plugins.tree.impl.ChildOrderDiff
Tests if there was any user-supplied reordering involved with the modification of the TreeConstants.OAK_CHILD_ORDER property.
FOREVER - Static variable in class org.apache.jackrabbit.oak.spi.security.ConfigurationParameters.Milliseconds
 
forJdbcUrl(String, String, String, String) - Static method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDataSourceFactory
 
forJdbcUrl(String, String, String) - Static method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDataSourceFactory
 
format() - Method in class org.apache.jackrabbit.oak.plugins.document.Document
Formats this document for use in a log message.
format(Value) - Static method in class org.apache.jackrabbit.oak.security.user.query.QueryUtil
 
formatRevision(String, boolean) - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreMBean
 
FormatVersion - Class in org.apache.jackrabbit.oak.plugins.document
The format version currently in use by the DocumentNodeStore and written to the underlying DocumentStore.
forType(String) - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundledTypesRegistry.BundledTypesRegistryBuilder
 
forType(String, String...) - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundledTypesRegistry.BundledTypesRegistryBuilder
 
ForwardingListener<K,V> - Class in org.apache.jackrabbit.oak.plugins.document.cache
Listener which forwards the notifications to a delegate.
ForwardingListener() - Constructor for class org.apache.jackrabbit.oak.plugins.document.cache.ForwardingListener
 
ForwardingListener(RemovalListener<K, V>) - Constructor for class org.apache.jackrabbit.oak.plugins.document.cache.ForwardingListener
 
from(NodeState) - Static method in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundledTypesRegistry
 
from(NodeState) - Static method in class org.apache.jackrabbit.oak.plugins.document.bundlor.DocumentBundlor
 
from(Iterable<String>) - Static method in class org.apache.jackrabbit.oak.plugins.document.bundlor.DocumentBundlor
 
from(PropertyState) - Static method in class org.apache.jackrabbit.oak.plugins.document.bundlor.DocumentBundlor
 
from(NodeBuilder) - Static method in class org.apache.jackrabbit.oak.plugins.index.PathFilter
Constructs the predicate based on given definition state.
fromDirectory(File) - Static method in class org.apache.jackrabbit.oak.plugins.index.importer.IndexerInfo
 
fromExternalChange() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState
 
fromIndexMeta(NodeState) - Static method in enum org.apache.jackrabbit.oak.plugins.index.property.OrderedIndex.OrderDirection
tells whether the provided index definition is ascending or descending
fromMs - Variable in class org.apache.jackrabbit.oak.plugins.document.util.TimeInterval
 
fromParent(String) - Static method in class org.apache.jackrabbit.oak.plugins.observation.filter.Selectors
A selector returning the node at relPath relative to Selectors.PARENT
fromRow(Collection<T>, RDBRow) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentSerializer
Reconstructs a Document based on the persisted RDBRow.
fromString(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState.Children
 
fromString(DocumentNodeStore, String) - Static method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState
 
fromString(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.LocalDiffCache.Diff
 
fromString(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument.Children
 
fromString(DocumentStore, String) - Static method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
 
fromString(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.PathRev
 
fromString(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.Revision
 
fromString(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.RevisionVector
Creates a revision vector from a string representation as returned by RevisionVector.asString().
fromString(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.RevisionsKey
 
fromString(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.StringValue
 
fromString(String) - Static method in enum org.apache.jackrabbit.oak.plugins.index.property.OrderedIndex.OrderDirection
retrieve an OrderDirection from a provided String.
fromString(String) - Static method in class org.apache.jackrabbit.oak.plugins.observation.ChangeSet
 
fromString(String) - Static method in enum org.apache.jackrabbit.oak.security.authorization.composite.CompositeAuthorizationConfiguration.CompositionType
Returns the corresponding composition type.
fromThis(String) - Static method in class org.apache.jackrabbit.oak.plugins.observation.filter.Selectors
A selector returning the node at relPath relative to Selectors.THIS
fullTextSearch(String, String, StaticOperandImpl) - Method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
 
FullTextSearchImpl - Class in org.apache.jackrabbit.oak.query.ast
A fulltext "contains(...)" condition.
FullTextSearchImpl(String, String, StaticOperandImpl) - Constructor for class org.apache.jackrabbit.oak.query.ast.FullTextSearchImpl
 
fullTextSearchScore(String) - Method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
 
FullTextSearchScoreImpl - Class in org.apache.jackrabbit.oak.query.ast
A fulltext search score expression.
FullTextSearchScoreImpl(String) - Constructor for class org.apache.jackrabbit.oak.query.ast.FullTextSearchScoreImpl
 

G

gc() - Method in class org.apache.jackrabbit.oak.plugins.document.JournalGarbageCollector
Deletes entries in the journal that are older than JournalGarbageCollector.getMaxRevisionAgeMillis().
gc(long, TimeUnit) - Method in class org.apache.jackrabbit.oak.plugins.document.VersionGarbageCollector
 
generate() - Method in class org.apache.jackrabbit.oak.plugins.observation.EventGenerator
Generates a finite number of EventHandler callbacks based on the content changes that have yet to be processed.
generateNodeName(String) - Method in class org.apache.jackrabbit.oak.security.user.RandomAuthorizableNodeName
 
generateNodeName(String) - Method in class org.apache.jackrabbit.oak.security.user.whiteboard.WhiteboardAuthorizableNodeName
 
generateNodeName(String) - Method in class org.apache.jackrabbit.oak.spi.security.user.AuthorizableNodeName.Default
 
generateNodeName(String) - Method in interface org.apache.jackrabbit.oak.spi.security.user.AuthorizableNodeName
Generates a node name from the specified authorizableId.
generateUUID() - Static method in class org.apache.jackrabbit.oak.plugins.identifier.IdentifierManager
 
generateUUID(String) - Static method in class org.apache.jackrabbit.oak.plugins.identifier.IdentifierManager
 
get(String) - Method in class org.apache.jackrabbit.oak.core.SimpleCommitContext
 
get(String, Callable<NodeDocument>) - Method in class org.apache.jackrabbit.oak.plugins.document.cache.NodeDocumentCache
Return the document matching given key, optionally loading it from an external source.
get(String) - Method in class org.apache.jackrabbit.oak.plugins.document.Document
Gets the data for the given key.
get(String) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.replica.NodeCollectionProvider
 
get(String) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.RevisionEntry
 
get(Object) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.CacheMap
 
get(Object) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.MultiGenerationMap
 
get(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.StringCache
 
get(Object) - Method in class org.apache.jackrabbit.oak.spi.security.ConfigurationParameters
get(String) - Method in class org.apache.jackrabbit.oak.spi.xml.ReferenceChangeTracker
Returns the new node id to which oldUUID has been mapped or null if no such mapping exists.
getAccessControlEntries() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AbstractAccessControlList
 
getAccessControlManager(Root, NamePathMapper) - Method in class org.apache.jackrabbit.oak.security.authorization.AuthorizationConfigurationImpl
 
getAccessControlManager(Root, NamePathMapper) - Method in class org.apache.jackrabbit.oak.security.authorization.composite.CompositeAuthorizationConfiguration
 
getAccessControlManager(Root, NamePathMapper) - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.AuthorizationConfiguration
 
getAccessControlManager(Root, NamePathMapper) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.OpenAuthorizationConfiguration
 
getActiveClusterNodes() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreMBean
 
getAdditionalDiagnostics(RDBConnectionHandler, String) - Method in enum org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStoreDB
 
getAdditionalMessages(SQLException) - Static method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBJDBCTools
Return a string containing additional messages from chained exceptions.
getAdminId(ConfigurationParameters) - Static method in class org.apache.jackrabbit.oak.spi.security.user.util.UserUtil
 
getAfterState() - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.UniversalFilter
 
getAggregatedPrivilegeNames(String...) - Method in class org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeBitsProvider
Return the names of the non-aggregate privileges corresponding to the specified privilegeNames.
getAllChunkIds(long) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoBlobStore
 
getAllChunkIds(long) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.BlobCache
 
getAllChunkIds(long) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBBlobStore
 
getAllClusters() - Method in class org.apache.jackrabbit.oak.plugins.document.MissingLastRevSeeker
Gets the clusters which potentially need _lastRev recovery.
getAllDocuments(DocumentStore) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
Returns an Iterable over all NodeDocuments in the given store.
getAllIndexInfo() - Method in interface org.apache.jackrabbit.oak.plugins.index.IndexInfoService
Returns IndexInfo for all the indexes present in the repository
getAllIndexInfo() - Method in class org.apache.jackrabbit.oak.plugins.index.IndexInfoServiceImpl
 
getAllNodeTypes() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.ReadOnlyNodeTypeManager
 
getAllNodeTypes() - Method in class org.apache.jackrabbit.oak.plugins.observation.ChangeSet
 
getAnonymousId(ConfigurationParameters) - Static method in class org.apache.jackrabbit.oak.spi.security.user.util.UserUtil
 
getApplicablePolicies(String) - Method in class org.apache.jackrabbit.oak.security.authorization.accesscontrol.AccessControlManagerImpl
 
getApplicablePolicies(Principal) - Method in class org.apache.jackrabbit.oak.security.authorization.accesscontrol.AccessControlManagerImpl
 
getAsyncDelay() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
getAsyncDelay() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
getAsyncLaneName() - Method in interface org.apache.jackrabbit.oak.plugins.index.IndexInfo
Returns name of the async index lane to which this index is bound to or null if its not an async index
getAsyncLaneName(NodeState, String) - Static method in class org.apache.jackrabbit.oak.plugins.index.IndexUtils
 
getAsyncLaneName(NodeState, String, PropertyState) - Static method in class org.apache.jackrabbit.oak.plugins.index.IndexUtils
 
getAsyncLanes() - Method in interface org.apache.jackrabbit.oak.plugins.index.AsyncIndexInfoService
Returns all the async indexing lanes which are active in the setup.
getAsyncLanes(NodeState) - Method in interface org.apache.jackrabbit.oak.plugins.index.AsyncIndexInfoService
Returns all the async indexing lanes which are active in the setup based on given root NodeState
getAsyncLanes() - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexInfoServiceImpl
 
getAsyncLanes(NodeState) - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexInfoServiceImpl
 
getAttribute(String) - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndexPlan
 
getAttribute(String) - Method in class org.apache.jackrabbit.oak.spi.security.authentication.AuthInfoImpl
 
getAttributeNames() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.AuthInfoImpl
 
getAttributes(Credentials) - Method in interface org.apache.jackrabbit.oak.spi.security.authentication.credentials.CredentialsSupport
Obtains the attributes as present with the specified Credentials.
getAttributes(Credentials) - Method in class org.apache.jackrabbit.oak.spi.security.authentication.credentials.SimpleCredentialsSupport
 
getAuthentication(UserConfiguration, Root, String) - Method in class org.apache.jackrabbit.oak.security.user.UserAuthenticationFactoryImpl
 
getAuthentication(UserConfiguration, Root, String) - Method in class org.apache.jackrabbit.oak.security.user.whiteboard.WhiteboardUserAuthenticationFactory
 
getAuthentication(UserConfiguration, Root, String) - Method in interface org.apache.jackrabbit.oak.spi.security.user.UserAuthenticationFactory
Returns an implementation Authentication for the specified userId.
getAuthorizable(String) - Method in class org.apache.jackrabbit.oak.security.user.autosave.AutoSaveEnabledManager
 
getAuthorizable(String, Class<T>) - Method in class org.apache.jackrabbit.oak.security.user.autosave.AutoSaveEnabledManager
 
getAuthorizable(Principal) - Method in class org.apache.jackrabbit.oak.security.user.autosave.AutoSaveEnabledManager
 
getAuthorizable(String) - Method in class org.apache.jackrabbit.oak.security.user.UserManagerImpl
 
getAuthorizable(String, Class<T>) - Method in class org.apache.jackrabbit.oak.security.user.UserManagerImpl
 
getAuthorizable(Principal) - Method in class org.apache.jackrabbit.oak.security.user.UserManagerImpl
 
getAuthorizable(Tree) - Method in class org.apache.jackrabbit.oak.security.user.UserManagerImpl
 
getAuthorizableActions(SecurityProvider) - Method in class org.apache.jackrabbit.oak.security.user.whiteboard.WhiteboardAuthorizableActionProvider
 
getAuthorizableActions(SecurityProvider) - Method in interface org.apache.jackrabbit.oak.spi.security.user.action.AuthorizableActionProvider
 
getAuthorizableActions(SecurityProvider) - Method in class org.apache.jackrabbit.oak.spi.security.user.action.CompositeActionProvider
 
getAuthorizableActions(SecurityProvider) - Method in class org.apache.jackrabbit.oak.spi.security.user.action.DefaultAuthorizableActionProvider
 
getAuthorizableByPath(String) - Method in class org.apache.jackrabbit.oak.security.user.autosave.AutoSaveEnabledManager
 
getAuthorizableByPath(String) - Method in class org.apache.jackrabbit.oak.security.user.UserManagerImpl
 
getAuthorizableClass() - Method in enum org.apache.jackrabbit.oak.spi.security.user.AuthorizableType
 
getAuthorizableId(Tree) - Static method in class org.apache.jackrabbit.oak.spi.security.user.util.UserUtil
 
getAuthorizableId(Tree, AuthorizableType) - Static method in class org.apache.jackrabbit.oak.spi.security.user.util.UserUtil
Retrieve the id from the given authorizableTree, which must have been verified for being a valid authorizable of the specified type upfront.
getAuthorizableRootPath(ConfigurationParameters, AuthorizableType) - Static method in class org.apache.jackrabbit.oak.spi.security.user.util.UserUtil
 
getAutoCreateNodeDefinitions() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.EffectiveNodeType
 
getAutoCreatePropertyDefinitions() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.EffectiveNodeType
 
getAverageLoadPenalty() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
getBackgroundObserver() - Method in class org.apache.jackrabbit.oak.plugins.observation.FilteringObserver
 
getBackgroundUpdateCountHistory() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreMBean
 
getBackupStatus() - Method in class org.apache.jackrabbit.oak.management.RepositoryManager
 
getBaseCredentials() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.ImpersonationCredentials
Returns the Credentials originally passed to Session.impersonate(javax.jcr.Credentials).
getBaseState() - Method in class org.apache.jackrabbit.oak.query.ExecutionContext
Used to evaluate the query (ie.
getBaseVersion(Tree) - Method in class org.apache.jackrabbit.oak.plugins.version.ReadOnlyVersionManager
Returns the tree representing the base version of the given versionable tree or null if none exists yet.
getBdata() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBRow
 
getBeforeState() - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.UniversalFilter
 
getBestSelectorExecutionPlan(FilterImpl) - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
getBindVariableName() - Method in class org.apache.jackrabbit.oak.query.ast.BindVariableValueImpl
 
getBindVariableNames() - Method in interface org.apache.jackrabbit.oak.query.Query
 
getBindVariableNames(String, String, Map<String, String>) - Method in class org.apache.jackrabbit.oak.query.QueryEngineImpl
Parse the query (check if it's valid) and get the list of bind variable names.
getBindVariableNames() - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
getBindVariableNames() - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
getBindVariableValue(String) - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
getBits(String...) - Method in class org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeBitsProvider
Returns the bits for the given privilege names
getBits(Iterable<String>) - Method in class org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeBitsProvider
Returns the bits for the given privilege names
getBits(Privilege[], NameMapper) - Method in class org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeBitsProvider
Returns the bits for the given privileges
getBlob(String) - Method in class org.apache.jackrabbit.oak.core.ImmutableRoot
 
getBlob(String) - Method in class org.apache.jackrabbit.oak.plugins.cow.BranchNodeStore
 
getBlob(String) - Method in class org.apache.jackrabbit.oak.plugins.cow.COWNodeStore
 
getBlob(String) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
Returns the Blob with the given reference.
getBlobFromBlobId(String) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
Returns the Blob with the given blobId.
getBlobId(String) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.BlobCache
 
getBlobLength(String) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.BlobCache
 
getBlobStore() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
getBlobStore() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
getBlobStoreCacheStats() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
getBlobStoreStats() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
getBlockCommits() - Method in class org.apache.jackrabbit.oak.plugins.observation.CommitRateLimiter
 
getBlockSizeMin() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.BlobCache
 
getBoolean(String) - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.DelegatingDocumentNodeState
 
getBoolean(Tree, String) - Static method in class org.apache.jackrabbit.oak.plugins.tree.TreeUtil
Returns the boolean representation of the property with the specified propertyName.
getBound(String) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.DateConstraint
 
getBound(String) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.DecimalConstraint
 
getBound(String) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.DoubleConstraint
 
getBound(String) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.LongConstraint
 
getBound(String) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.NumericConstraint
 
getBranches() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
getBranches() - Method in interface org.apache.jackrabbit.oak.plugins.document.RevisionContext
 
getBranchRevision() - Method in class org.apache.jackrabbit.oak.plugins.document.RevisionVector
 
getBroadcastConfig() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCache
 
getBroadcastRecvRateHistory() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
getBundledChildNodeNames() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState
 
getBundlingConfigHandler() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
getBundlor(NodeState) - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundledTypesRegistry
 
getCacheStats() - Method in class org.apache.jackrabbit.oak.cache.impl.ConsolidatedCacheStats
 
getCacheStats() - Method in class org.apache.jackrabbit.oak.plugins.document.cache.NodeDocumentCache
 
getCacheStats() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStore
 
getCacheStats() - Method in class org.apache.jackrabbit.oak.plugins.document.memory.MemoryDocumentStore
 
getCacheStats() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoDocumentStore
 
getCacheStats() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
getCacheStats() - Method in class org.apache.jackrabbit.oak.plugins.document.util.LeaseCheckDocumentStoreWrapper
 
getCacheStats() - Method in class org.apache.jackrabbit.oak.plugins.document.util.LoggingDocumentStoreWrapper
 
getCacheStats() - Method in class org.apache.jackrabbit.oak.plugins.document.util.SynchronizingDocumentStoreWrapper
 
getCacheStats() - Method in class org.apache.jackrabbit.oak.plugins.document.util.TimingDocumentStoreWrapper
 
getCandidates(long) - Method in class org.apache.jackrabbit.oak.plugins.document.MissingLastRevSeeker
Get the candidates with modified time greater than or equal the specified startTime in milliseconds since the start of the epoch.
getCandidates(long) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoMissingLastRevSeeker
 
getCaptureStackTraces() - Method in interface org.apache.jackrabbit.oak.query.stats.QueryStatsMBean
 
getCaptureStackTraces() - Method in class org.apache.jackrabbit.oak.query.stats.QueryStatsMBeanImpl
 
getChanges() - Method in class org.apache.jackrabbit.oak.plugins.document.LocalDiffCache.Diff
 
getChanges(RevisionVector, RevisionVector, String, DiffCache.Loader) - Method in class org.apache.jackrabbit.oak.plugins.document.LocalDiffCache
 
getChanges(RevisionVector, RevisionVector, String, DiffCache.Loader) - Method in class org.apache.jackrabbit.oak.plugins.document.MemoryDiffCache
 
getChanges() - Method in class org.apache.jackrabbit.oak.plugins.document.UpdateOp
 
getChangeSetMaxDepth() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
getChangeSetMaxItems() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
getCheckpoints() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
getChild(String) - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractTree
 
getChild(String) - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.ImmutableTree
 
getChild(String) - Method in class org.apache.jackrabbit.oak.plugins.tree.TreeLocation
Navigate to a child of the given name.
getChildHandler(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.DefaultEventHandler
 
getChildHandler(String, NodeState, NodeState) - Method in interface org.apache.jackrabbit.oak.plugins.observation.EventHandler
Returns a handler of events within the given child node, or null if changes within that child are not to be processed.
getChildHandler(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.FilteredHandler
 
getChildNames() - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractTree
Returns the list of child names considering its ordering when the TreeConstants.OAK_CHILD_ORDER property is set.
getChildNode(String) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState
 
getChildNode(String) - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.DelegatingDocumentNodeState
 
getChildNodeCount(long) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState
 
getChildNodeCount(long) - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.DelegatingDocumentNodeState
 
getChildNodeEntries() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState
 
getChildNodeEntries() - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.DelegatingDocumentNodeState
 
getChildNodeNames(Collection<String>, Matcher) - Static method in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundlorUtils
 
getChildNodeNames() - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.DelegatingDocumentNodeState
 
getChildPermission(String, NodeState) - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.TreePermission
Retrieve the TreePermission for the tree identified by the specified childName and childState, which is a child of the tree associated with this instanceof TreePermission.
getChildren() - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractTree
 
getChildrenCacheSize() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
getChildrenCount(long) - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractTree
 
getChildTracker(String) - Method in class org.apache.jackrabbit.oak.namepath.PathTracker
 
getChildTracker(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.identifier.IdentifierTracker
 
getClientInfo() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentBroadcastConfig
 
getClientInfo() - Method in interface org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast.DynamicBroadcastConfig
Get the client info of all connected clients.
getClock() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
getClock() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
getClock() - Method in interface org.apache.jackrabbit.oak.plugins.document.RevisionContext
 
getClusterId() - Method in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfoDocument
 
getClusterId() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
getClusterId() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
getClusterId() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreMBean
 
getClusterId() - Method in class org.apache.jackrabbit.oak.plugins.document.Revision
 
getClusterId() - Method in interface org.apache.jackrabbit.oak.plugins.document.RevisionContext
 
getClusterInfo() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
getClusterNodeInfo(int) - Method in class org.apache.jackrabbit.oak.plugins.document.MissingLastRevSeeker
Gets the cluster node info for the given cluster node id.
getCollation(QueryBuilder.Direction) - Static method in class org.apache.jackrabbit.oak.security.user.query.QueryUtil
 
getCollisionsModcount() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBRow
 
getColumnIndex(String) - Method in interface org.apache.jackrabbit.oak.query.Query
 
getColumnIndex(String) - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
getColumnIndex(String) - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
getColumnName() - Method in class org.apache.jackrabbit.oak.query.ast.ColumnImpl
 
getColumnNames() - Method in class org.apache.jackrabbit.oak.query.ResultImpl
 
getColumns() - Method in interface org.apache.jackrabbit.oak.query.Query
 
getColumns() - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
getColumns() - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
getColumnSelectorNames() - Method in class org.apache.jackrabbit.oak.query.ResultImpl
 
getCommitHooks(String) - Method in class org.apache.jackrabbit.oak.security.authorization.AuthorizationConfigurationImpl
 
getCommitHooks(String) - Method in class org.apache.jackrabbit.oak.security.privilege.PrivilegeConfigurationImpl
 
getCommitHooks(String) - Method in class org.apache.jackrabbit.oak.spi.security.CompositeConfiguration
 
getCommitHooks(String) - Method in class org.apache.jackrabbit.oak.spi.security.SecurityConfiguration.Default
 
getCommitHooks(String) - Method in interface org.apache.jackrabbit.oak.spi.security.SecurityConfiguration
Returns the list of commit hooks that need to be executed for the specified workspace name.
getCommitInfo() - Method in interface org.apache.jackrabbit.oak.plugins.index.IndexingContext
Commit info associated with commit as part of which IndexEditor is being invoked
getCommitRootPath(Revision) - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
Returns the commit root path for the given revision or null if this document does not have a commit root entry for the given revision.
getCommitValue(Revision, NodeDocument) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
getCommitValue(Revision, NodeDocument) - Method in interface org.apache.jackrabbit.oak.plugins.document.RevisionContext
Retrieves the commit value for a given change.
getCommitValueCacheSize() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
getComparator(OrderingImpl[]) - Static method in class org.apache.jackrabbit.oak.query.ResultRowImpl
 
getConcatQuery(String, int) - Method in enum org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStoreDB
Returns the CONCAT function or its equivalent function or sub-query.
getConditions() - Method in class org.apache.jackrabbit.oak.plugins.document.UpdateOp
 
getConfig() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentBroadcastConfig
 
getConfig() - Method in interface org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast.DynamicBroadcastConfig
Get the global configuration data that is not associated to a specific client.
getConfig() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AbstractAccessControlManager
 
getConfigMBean() - Method in interface org.apache.jackrabbit.oak.plugins.observation.filter.FilterProvider
 
getConfiguration(Class<T>) - Method in class org.apache.jackrabbit.oak.security.SecurityProviderImpl
 
getConfiguration(Class<T>) - Method in class org.apache.jackrabbit.oak.spi.security.OpenSecurityProvider
 
getConfiguration(Class<T>) - Method in interface org.apache.jackrabbit.oak.spi.security.SecurityProvider
Returns the security configuration of the specified configClass.
getConfigurations() - Method in class org.apache.jackrabbit.oak.security.SecurityProviderImpl
 
getConfigurations() - Method in class org.apache.jackrabbit.oak.spi.security.CompositeConfiguration
 
getConfigurations() - Method in class org.apache.jackrabbit.oak.spi.security.OpenSecurityProvider
 
getConfigurations() - Method in interface org.apache.jackrabbit.oak.spi.security.SecurityProvider
Returns all available SecurityConfigurations.
getConfigValue(String, T, Class<T>) - Method in class org.apache.jackrabbit.oak.spi.security.ConfigurationParameters
Returns the value of the configuration entry with the given key applying the following rules: If this instance doesn't contain a configuration entry with that key the specified defaultValue will be returned. If defaultValue is null the original value will be returned. If the configured value is null this method will always return null. If neither defaultValue nor the configured value is null an attempt is made to convert the configured value to match the type of the default value.
getConfigValue(String, T) - Method in class org.apache.jackrabbit.oak.spi.security.ConfigurationParameters
Returns the value of the configuration entry with the given key applying the following rules: If this instance doesn't contain a configuration entry with that key, or if the entry is null, the specified defaultValue will be returned. If the configured value is not null an attempt is made to convert the configured value to match the type of the default value.
getConflictHandlers() - Method in class org.apache.jackrabbit.oak.security.user.UserConfigurationImpl
 
getConflictHandlers() - Method in class org.apache.jackrabbit.oak.spi.security.CompositeConfiguration
 
getConflictHandlers() - Method in class org.apache.jackrabbit.oak.spi.security.SecurityConfiguration.Default
 
getConflictHandlers() - Method in interface org.apache.jackrabbit.oak.spi.security.SecurityConfiguration
Returns the list of conflict handlers available for this security configuration.
getConstraint() - Method in class org.apache.jackrabbit.oak.query.ast.NotImpl
 
getConstraint() - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
getConstraints() - Method in class org.apache.jackrabbit.oak.query.ast.AndImpl
 
getConstraints() - Method in class org.apache.jackrabbit.oak.query.ast.OrImpl
 
getContentRepository() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.callback.RepositoryCallback
 
getContentSession() - Method in class org.apache.jackrabbit.oak.core.ImmutableRoot
 
getContext() - Method in class org.apache.jackrabbit.oak.security.authorization.AuthorizationConfigurationImpl
 
getContext() - Method in class org.apache.jackrabbit.oak.security.privilege.PrivilegeConfigurationImpl
 
getContext() - Method in class org.apache.jackrabbit.oak.security.user.UserConfigurationImpl
 
getContext() - Method in class org.apache.jackrabbit.oak.spi.security.CompositeConfiguration
 
getContext() - Method in class org.apache.jackrabbit.oak.spi.security.SecurityConfiguration.Default
 
getContext() - Method in interface org.apache.jackrabbit.oak.spi.security.SecurityConfiguration
 
getCorruptIndexData(String) - Method in class org.apache.jackrabbit.oak.plugins.index.TrackingCorruptIndexHandler
 
getCorruptSinceAsCal() - Method in class org.apache.jackrabbit.oak.plugins.index.TrackingCorruptIndexHandler.CorruptIndexInfo
 
getCost(Filter, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndex
 
getCost(Filter) - Method in class org.apache.jackrabbit.oak.plugins.index.diffindex.BaseDiffCollector
 
getCost(Filter) - Method in interface org.apache.jackrabbit.oak.plugins.index.diffindex.DiffCollector
Get the cost for the given filter, and prepare the result if the index can be used.
getCost(Filter, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.index.diffindex.DiffIndex
 
getCost(Filter, String, PropertyValue) - Method in class org.apache.jackrabbit.oak.plugins.index.property.PropertyIndexLookup
 
getCost(Filter, NodeState) - Method in class org.apache.jackrabbit.oak.query.index.TraversingIndex
 
getCostPerEntry() - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndexPlan
 
getCostPerExecution() - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndexPlan
 
getCount() - Method in class org.apache.jackrabbit.oak.query.facet.FacetResult.Facet
get the facet count
getCounter() - Method in class org.apache.jackrabbit.oak.plugins.document.Revision
 
getCounterStats(String, StatsOptions) - Method in class org.apache.jackrabbit.oak.plugins.metric.MetricStatisticsProvider
 
getCountSync(NodeState) - Static method in class org.apache.jackrabbit.oak.plugins.index.counter.ApproximateCounter
Get the count estimation.
getCreated() - Method in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfoDocument
 
getCreated() - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
 
getCreatedMillis() - Method in class org.apache.jackrabbit.oak.query.stats.QueryStatsData
 
getCreateJournalHistory() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentStoreStats
 
getCreateJournalHistory() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStoreStatsMBean
 
getCreateNodesHistory() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentStoreStats
 
getCreateNodesHistory() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStoreStatsMBean
 
getCredentialClasses() - Method in interface org.apache.jackrabbit.oak.spi.security.authentication.credentials.CredentialsSupport
Returns all credentials classes supported by this implemenation.
getCredentialClasses() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.credentials.SimpleCredentialsSupport
 
getCredentials() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.AbstractLoginModule
Tries to retrieve valid (supported) Credentials: using a CredentialsCallback, looking for a AbstractLoginModule.SHARED_KEY_CREDENTIALS entry in the shared state (see also AbstractLoginModule.getSharedCredentials() and finally by searching for valid credentials in the subject.
getCredentials() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.callback.CredentialsCallback
Returns the Credentials that have been set before using CredentialsCallback.setCredentials(javax.jcr.Credentials).
getCurrentTimestamp() - Static method in class org.apache.jackrabbit.oak.plugins.document.Revision
Get the timestamp value of the current date and time.
getCurrentTimeStampInSecondsSyntax() - Method in enum org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStoreDB
Query syntax for current time in ms since the epoch
getData() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoBlob
 
getData() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBRow
 
getDataStoreGCStatus() - Method in class org.apache.jackrabbit.oak.management.RepositoryManager
 
getDataTableCreationStatement(String) - Method in enum org.apache.jackrabbit.oak.plugins.document.rdb.RDBBlobStoreDB
 
getDB() - Method in class org.apache.jackrabbit.oak.plugins.document.util.MongoConnection
Returns the DB as passed in the URI of the constructor.
getDB(String) - Method in class org.apache.jackrabbit.oak.plugins.document.util.MongoConnection
Returns the DB with the given name.
getDeclaredAggregateNames() - Method in class org.apache.jackrabbit.oak.spi.security.privilege.ImmutablePrivilegeDefinition
 
getDeclaredAggregateNames() - Method in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeDefinition
Returns the internal names of the declared aggregated privileges or an empty array if the privilege defined by this definition isn't an aggregate.
getDefaultAuthenticationFactory() - Static method in class org.apache.jackrabbit.oak.security.user.UserConfigurationImpl
 
getDefaultBuilder() - Static method in class org.apache.jackrabbit.oak.plugins.document.util.MongoConnection
Constructs a builder with default options set.
getDefaultChildType(Tree, Tree, String) - Static method in class org.apache.jackrabbit.oak.plugins.tree.TreeUtil
Finds the default primary type for a new child node with the given name.
getDefaultConfig() - Method in class org.apache.jackrabbit.oak.spi.security.CompositeConfiguration
 
getDefaultConfiguration(ConfigurationParameters) - Static method in class org.apache.jackrabbit.oak.spi.security.authentication.ConfigurationUtil
Creates a new Configuration for the default OAK authentication setup which only handles login for standard JCR credentials.
getDefaultReadConcern(DB) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.MongoConnection
Returns the default read concern depending on MongoDB deployment.
getDefaultWriteConcern(DB) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.MongoConnection
Returns the default write concern depending on MongoDB deployment.
getDefinition() - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndexPlan
 
getDefinition(Tree, String) - Method in interface org.apache.jackrabbit.oak.plugins.nodetype.DefinitionProvider
Returns the node definition for a child node of parent named nodeName with a default primary type.
getDefinition(Tree, Tree) - Method in interface org.apache.jackrabbit.oak.plugins.nodetype.DefinitionProvider
Calculates the applicable definition for the child node under the given parent node.
getDefinition(Tree, PropertyState, boolean) - Method in interface org.apache.jackrabbit.oak.plugins.nodetype.DefinitionProvider
Calculates the applicable definition for the property state under the given parent tree.
getDefinition(Tree, String) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.ReadOnlyNodeTypeManager
 
getDefinition(Tree, Tree) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.ReadOnlyNodeTypeManager
 
getDefinition(Tree, PropertyState, boolean) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.ReadOnlyNodeTypeManager
 
getDefinition() - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.restriction.Restriction
Returns the underlying restriction definition.
getDefinition() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.restriction.RestrictionImpl
 
getDeletedDocCount() - Method in interface org.apache.jackrabbit.oak.plugins.document.RevisionGCStatsMBean
 
getDeletedDocHistory() - Method in interface org.apache.jackrabbit.oak.plugins.document.RevisionGCStatsMBean
 
getDeletedIntSplitDocCount() - Method in interface org.apache.jackrabbit.oak.plugins.document.RevisionGCStatsMBean
 
getDeletedIntSplitDocHistory() - Method in interface org.apache.jackrabbit.oak.plugins.document.RevisionGCStatsMBean
 
getDeletedLeafDocCount() - Method in interface org.apache.jackrabbit.oak.plugins.document.RevisionGCStatsMBean
 
getDeletedLeafDocHistory() - Method in interface org.apache.jackrabbit.oak.plugins.document.RevisionGCStatsMBean
 
getDeletedOnceCount() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoVersionGCSupport
 
getDeletedOnceCount() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBVersionGCSupport
 
getDeletedOnceCount() - Method in class org.apache.jackrabbit.oak.plugins.document.VersionGCSupport
 
getDeletedSplitDocCount() - Method in interface org.apache.jackrabbit.oak.plugins.document.RevisionGCStatsMBean
 
getDeletedSplitDocHistory() - Method in interface org.apache.jackrabbit.oak.plugins.document.RevisionGCStatsMBean
 
getDepthFromId(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
 
getDescription() - Method in enum org.apache.jackrabbit.oak.plugins.version.VersionExceptionCode
 
getDescriptors() - Method in class org.apache.jackrabbit.oak.core.ContentRepositoryImpl
 
getDiffCache() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
getDiffCache() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
getDiffCacheSize() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
getDiffCacheStats() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
getDimensions() - Method in class org.apache.jackrabbit.oak.plugins.document.RevisionVector
Returns the dimensions of this revision vector.
getDimensions() - Method in class org.apache.jackrabbit.oak.query.facet.FacetResult
 
getDirection() - Method in enum org.apache.jackrabbit.oak.plugins.index.property.OrderedIndex.OrderDirection
 
getDocumentCacheSize() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
getDocumentNodeState(String, RevisionVector, RevisionVector) - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentNodeStateCache
Get the node for the given path and revision.
getDocumentNodeState(String, RevisionVector, RevisionVector) - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.SecondaryStoreCache
 
getDocumentStore() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
getDocumentStore() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK
 
getDocumentStore() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
getDocumentStore() - Method in class org.apache.jackrabbit.oak.plugins.document.VersionGCSupport
Returns the underlying document store.
getDocumentStoreStatsCollector() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
getDroppedTables() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
getDurationMs() - Method in class org.apache.jackrabbit.oak.plugins.document.util.TimeInterval
Returns the duration in ms.
getEffectiveNodeType(Node) - Method in interface org.apache.jackrabbit.oak.plugins.nodetype.EffectiveNodeTypeProvider
Calculates and returns the effective node types of the given node.
getEffectiveNodeType(Tree) - Method in interface org.apache.jackrabbit.oak.plugins.nodetype.EffectiveNodeTypeProvider
Calculates and returns the effective node types of the given tree.
getEffectiveNodeType(Node) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.ReadOnlyNodeTypeManager
Returns all the node types of the given node, in a breadth-first traversal order of the type hierarchy.
getEffectiveNodeType(Tree) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.ReadOnlyNodeTypeManager
 
getEffectivePolicies(String) - Method in class org.apache.jackrabbit.oak.security.authorization.accesscontrol.AccessControlManagerImpl
 
getEffectivePolicies(Set<Principal>) - Method in class org.apache.jackrabbit.oak.security.authorization.accesscontrol.AccessControlManagerImpl
 
getEffectiveType(Tree, Tree) - Static method in class org.apache.jackrabbit.oak.plugins.tree.TreeUtil
Returns the effective node types of the given node.
getElementCount() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
getEntries() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AbstractAccessControlList
 
getEntries() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.ImmutableACL
 
getEntryName(String) - Static method in class org.apache.jackrabbit.oak.security.authorization.permission.PermissionUtil
 
getEstimatedChildNodeCounts(String, int) - Method in class org.apache.jackrabbit.oak.plugins.index.counter.jmx.NodeCounter
 
getEstimatedChildNodeCounts(String, int) - Method in interface org.apache.jackrabbit.oak.plugins.index.counter.jmx.NodeCounterMBean
Get the estimated number of nodes for the child nodes of a given path.
getEstimatedCost() - Method in interface org.apache.jackrabbit.oak.query.plan.ExecutionPlan
 
getEstimatedCost() - Method in class org.apache.jackrabbit.oak.query.plan.JoinExecutionPlan
 
getEstimatedCost() - Method in class org.apache.jackrabbit.oak.query.plan.SelectorExecutionPlan
 
getEstimatedCost() - Method in interface org.apache.jackrabbit.oak.query.Query
Get the estimated cost.
getEstimatedCost() - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
getEstimatedCost() - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
getEstimatedEntryCount() - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndexPlan
 
getEstimatedEntryCount() - Method in interface org.apache.jackrabbit.oak.plugins.index.IndexInfo
An estimate of entry count in the index
getEstimatedNodeCount(String) - Method in class org.apache.jackrabbit.oak.plugins.index.counter.jmx.NodeCounter
 
getEstimatedNodeCount(NodeState, String, boolean) - Static method in class org.apache.jackrabbit.oak.plugins.index.counter.jmx.NodeCounter
Get the estimated number of nodes for a given path.
getEstimatedNodeCount(String) - Method in interface org.apache.jackrabbit.oak.plugins.index.counter.jmx.NodeCounterMBean
Get the estimated number of nodes below a given path.
getEstimatedNodeCount(String, Set<String>) - Method in class org.apache.jackrabbit.oak.plugins.index.progress.NodeCounterMBeanEstimator
 
getEstimatedNodeCount(String, Set<String>) - Method in interface org.apache.jackrabbit.oak.plugins.index.progress.NodeCountEstimator
Provides an estimate of the sub tree node count at given path
getEventAggregator() - Method in interface org.apache.jackrabbit.oak.plugins.observation.filter.FilterProvider
Allows providers to supply an optional EventAggregator that is used to adjust (aggregate) the event identifier before event creation (ie after event filtering).
getEveryone() - Method in class org.apache.jackrabbit.oak.spi.security.principal.PrincipalManagerImpl
 
getEvictionCount() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
getEvictionCount() - Method in class org.apache.jackrabbit.oak.query.stats.QueryStatsMBeanImpl
 
getExceptionCount() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCache
 
getExecuteCount() - Method in class org.apache.jackrabbit.oak.query.stats.QueryStatsData
 
getExecutionContext() - Method in class org.apache.jackrabbit.oak.query.QueryEngineImpl
Get the execution context for a single query execution.
getExecutionContext() - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
getExecutionPlan() - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
 
getExecutor() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
getExistingSelector(String) - Method in class org.apache.jackrabbit.oak.query.ast.SourceImpl
Get the selector with the given name, or fail if not found.
getExpression() - Method in class org.apache.jackrabbit.oak.query.ast.SpellcheckImpl
 
getExpression() - Method in class org.apache.jackrabbit.oak.query.ast.SuggestImpl
 
getExternalChangeCountHistory() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreMBean
 
getExtractedText() - Method in class org.apache.jackrabbit.oak.plugins.index.fulltext.ExtractedText
 
getExtractFunction() - Static method in class org.apache.jackrabbit.oak.plugins.document.mongo.replica.Timestamped
 
getExtractionResult() - Method in class org.apache.jackrabbit.oak.plugins.index.fulltext.ExtractedText
 
getFacets(String) - Method in class org.apache.jackrabbit.oak.query.facet.FacetResult
 
getFailingIndexData(String) - Method in class org.apache.jackrabbit.oak.plugins.index.TrackingCorruptIndexHandler
 
getFailingIndexStats(String) - Method in class org.apache.jackrabbit.oak.plugins.index.TrackingCorruptIndexHandler
 
getFailTraversal() - Method in class org.apache.jackrabbit.oak.query.QueryEngineSettings
 
getFetchFirstSyntax() - Method in enum org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStoreDB
Query syntax for "FETCH FIRST"
getFilter() - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndexPlan
 
getFilter(NodeState, NodeState) - Method in interface org.apache.jackrabbit.oak.plugins.observation.filter.FilterProvider
Factory method for creating a Filter for the passed before and after states.
getFindCachedNodesHistory() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentStoreStats
 
getFindCachedNodesHistory() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStoreStatsMBean
 
getFindNodesFromPrimaryHistory() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentStoreStats
 
getFindNodesFromPrimaryHistory() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStoreStatsMBean
 
getFindNodesFromSlaveHistory() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentStoreStats
 
getFindNodesFromSlaveHistory() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStoreStatsMBean
 
getFindSplitNodesHistory() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentStoreStats
 
getFindSplitNodesHistory() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStoreStatsMBean
 
getFullTextComparisonWithoutIndex() - Method in class org.apache.jackrabbit.oak.query.QueryEngineSettings
 
getFulltextConditions() - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
 
getFullTextConstraint(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.AndImpl
 
getFullTextConstraint(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.ConstraintImpl
Get the (combined) full-text constraint.
getFullTextConstraint(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.FullTextSearchImpl
 
getFullTextConstraint(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.OrImpl
 
getFullTextConstraint() - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
 
getFullTextSearchExpression() - Method in class org.apache.jackrabbit.oak.query.ast.FullTextSearchImpl
 
getFunction(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.DynamicOperandImpl
Get the function of a function-based index, in Polish notation.
getFunction(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.FullTextSearchScoreImpl
 
getFunction(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.LengthImpl
 
getFunction(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.LowerCaseImpl
 
getFunction(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.NodeLocalNameImpl
 
getFunction(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.NodeNameImpl
 
getFunction(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.PropertyValueImpl
 
getFunction(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.UpperCaseImpl
 
getGCMonitor() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
getGroupMembership(Principal) - Method in class org.apache.jackrabbit.oak.spi.security.principal.CompositePrincipalProvider
 
getGroupMembership(Principal) - Method in class org.apache.jackrabbit.oak.spi.security.principal.EmptyPrincipalProvider
 
getGroupMembership(Principal) - Method in class org.apache.jackrabbit.oak.spi.security.principal.PrincipalManagerImpl
 
getGroupMembership(Principal) - Method in interface org.apache.jackrabbit.oak.spi.security.principal.PrincipalProvider
Returns an iterator over all group principals for which the given principal is either direct or indirect member of.
getHead() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreMBean
 
getHeadRevision() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK
 
getHeadRevision() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
getHeadRevision() - Method in interface org.apache.jackrabbit.oak.plugins.document.RevisionContext
 
getHistogram(String, StatsOptions) - Method in class org.apache.jackrabbit.oak.plugins.metric.MetricStatisticsProvider
 
getHitCount() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
getHitPercentageHistory() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
getHitRate() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
getHitRateHistory() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
getId() - Method in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfo
 
getId() - Method in class org.apache.jackrabbit.oak.plugins.document.Document
Get the id (the primary key) of this document.
getId() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoBlob
 
getId() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBRow
 
getId() - Method in class org.apache.jackrabbit.oak.plugins.document.UpdateOp
 
getIdentifier(Tree) - Static method in class org.apache.jackrabbit.oak.plugins.identifier.IdentifierManager
Return the identifier of a tree.
getIdentifier() - Method in class org.apache.jackrabbit.oak.plugins.identifier.IdentifierTracker
 
getIdentifierManager() - Method in class org.apache.jackrabbit.oak.plugins.version.ReadOnlyVersionManager
 
getIdFromPath(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
 
getIfCached(Collection<T>, String) - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStore
Fetches the cached document.
getIfCached(Collection<T>, String) - Method in class org.apache.jackrabbit.oak.plugins.document.memory.MemoryDocumentStore
 
getIfCached(Collection<T>, String) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoDocumentStore
 
getIfCached(Collection<T>, String) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
getIfCached(Collection<T>, String) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LeaseCheckDocumentStoreWrapper
 
getIfCached(Collection<T>, String) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LoggingDocumentStoreWrapper
 
getIfCached(Collection<T>, String) - Method in class org.apache.jackrabbit.oak.plugins.document.util.SynchronizingDocumentStoreWrapper
 
getIfCached(Collection<T>, String) - Method in class org.apache.jackrabbit.oak.plugins.document.util.TimingDocumentStoreWrapper
 
getIfPresent(String) - Method in class org.apache.jackrabbit.oak.plugins.document.cache.NodeDocumentCache
Return the cached value or null.
getImmutableTree(Tree, Root) - Static method in class org.apache.jackrabbit.oak.security.authorization.permission.PermissionUtil
 
getImpersonatorInfo() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.ImpersonationCredentials
Returns the AuthInfo present with the editing session that want to impersonate.
getImportBehavior(ConfigurationParameters) - Static method in class org.apache.jackrabbit.oak.spi.security.user.util.UserUtil
Return the configured ImportBehavior for the given config.
getInactiveClusterNodes() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreMBean
 
getIndex() - Method in class org.apache.jackrabbit.oak.query.plan.SelectorExecutionPlan
 
getIndexCostInfo(NodeState) - Method in class org.apache.jackrabbit.oak.query.ast.JoinImpl
 
getIndexCostInfo(NodeState) - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
 
getIndexCostInfo(NodeState) - Method in class org.apache.jackrabbit.oak.query.ast.SourceImpl
Get the index cost as a JSON string.
getIndexCostInfo() - Method in interface org.apache.jackrabbit.oak.query.Query
Get the index cost as a JSON string.
getIndexCostInfo() - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
getIndexCostInfo() - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
getIndexCreationStatements(String) - Method in enum org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStoreDB
 
getIndexDefinitionDiff() - Method in interface org.apache.jackrabbit.oak.plugins.index.IndexInfo
If the index definition has changed without doing any reindexing then this method can be used to determine the diff in the index definition
getIndexEditor(String, NodeBuilder, NodeState, IndexUpdateCallback) - Method in class org.apache.jackrabbit.oak.plugins.index.CompositeIndexEditorProvider
 
getIndexEditor(String, NodeBuilder, NodeState, IndexUpdateCallback) - Method in class org.apache.jackrabbit.oak.plugins.index.counter.NodeCounterEditorProvider
 
getIndexEditor(String, NodeBuilder, NodeState, IndexUpdateCallback) - Method in interface org.apache.jackrabbit.oak.plugins.index.IndexEditorProvider
Each provider knows how to produce a certain type of index.
getIndexEditor(String, NodeBuilder, NodeState, IndexUpdateCallback) - Method in class org.apache.jackrabbit.oak.plugins.index.property.OrderedPropertyIndexEditorProvider
 
getIndexEditor(String, NodeBuilder, NodeState, IndexUpdateCallback) - Method in class org.apache.jackrabbit.oak.plugins.index.property.PropertyIndexEditorProvider
 
getIndexEditor(String, NodeBuilder, NodeState, IndexUpdateCallback) - Method in class org.apache.jackrabbit.oak.plugins.index.reference.ReferenceEditorProvider
 
getIndexEditor(String, NodeBuilder, NodeState, IndexUpdateCallback) - Method in class org.apache.jackrabbit.oak.plugins.index.WhiteboardIndexEditorProvider
 
getIndexedUpToTime() - Method in interface org.apache.jackrabbit.oak.plugins.index.IndexInfo
Returns time in millis of the repository state up to which index is up-to-date.
getIndexes() - Method in class org.apache.jackrabbit.oak.plugins.index.importer.IndexerInfo
 
getIndexingContext() - Method in interface org.apache.jackrabbit.oak.plugins.index.ContextAwareCallback
 
getIndexingStats() - Method in class org.apache.jackrabbit.oak.plugins.index.IndexUpdate
 
getIndexName() - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndex
 
getIndexName() - Method in class org.apache.jackrabbit.oak.plugins.index.diffindex.UUIDDiffIndex
 
getIndexName() - Method in class org.apache.jackrabbit.oak.query.index.TraversingIndex
 
getIndexNodeName(MountInfoProvider, String, String) - Static method in class org.apache.jackrabbit.oak.plugins.index.property.Multiplexers
 
getIndexNodeName() - Method in class org.apache.jackrabbit.oak.plugins.index.property.strategy.ContentMirrorStoreStrategy
 
getIndexNodeName() - Method in class org.apache.jackrabbit.oak.plugins.index.property.strategy.FilteringIndexStoreStrategy
 
getIndexNodeName() - Method in interface org.apache.jackrabbit.oak.plugins.index.property.strategy.IndexStoreStrategy
 
getIndexNodeName() - Method in class org.apache.jackrabbit.oak.plugins.index.property.strategy.UniqueEntryStoreStrategy
 
getIndexPath() - Method in interface org.apache.jackrabbit.oak.plugins.index.IndexInfo
Returns paths of index definition in the repository
getIndexPath() - Method in interface org.apache.jackrabbit.oak.plugins.index.IndexingContext
Path of the index definition in the repository
getIndexPaths() - Method in class org.apache.jackrabbit.oak.plugins.index.importer.IndexDefinitionUpdater
 
getIndexPaths() - Method in interface org.apache.jackrabbit.oak.plugins.index.IndexPathService
Returns all index definitions paths present in the repository
getIndexPaths() - Method in class org.apache.jackrabbit.oak.plugins.index.IndexPathServiceImpl
 
getIndexPlan() - Method in class org.apache.jackrabbit.oak.query.plan.SelectorExecutionPlan
 
getIndexProvider() - Method in class org.apache.jackrabbit.oak.query.ExecutionContext
 
getIndexState(String) - Method in class org.apache.jackrabbit.oak.plugins.index.importer.IndexDefinitionUpdater
 
getIndexStats() - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate
 
getInfo(long, TimeUnit) - Method in class org.apache.jackrabbit.oak.plugins.document.VersionGarbageCollector
 
getInfo(String) - Method in interface org.apache.jackrabbit.oak.plugins.index.AsyncIndexInfoService
Returns the info for async indexer with given name
getInfo(String, NodeState) - Method in interface org.apache.jackrabbit.oak.plugins.index.AsyncIndexInfoService
Returns the info for async indexer with given name and based on given root NodeState
getInfo(String) - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexInfoServiceImpl
 
getInfo(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexInfoServiceImpl
 
getInfo(String) - Method in interface org.apache.jackrabbit.oak.plugins.index.IndexInfoProvider
 
getInfo(String) - Method in interface org.apache.jackrabbit.oak.plugins.index.IndexInfoService
Returns IndexInfo for index at given path
getInfo(String) - Method in class org.apache.jackrabbit.oak.plugins.index.IndexInfoServiceImpl
 
getInfo(String) - Method in class org.apache.jackrabbit.oak.plugins.index.property.PropertyIndexInfoProvider
 
getInitializationStatement() - Method in enum org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStoreDB
Query for any required initialization of the DB.
getInitialSchema() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBOptions
 
getInnerJoinConditions() - Method in class org.apache.jackrabbit.oak.query.ast.JoinImpl
 
getInnerJoinConditions() - Method in class org.apache.jackrabbit.oak.query.ast.SourceImpl
Get the list of inner join conditions.
getInnerJoinSelectors() - Method in class org.apache.jackrabbit.oak.query.ast.JoinImpl
 
getInnerJoinSelectors() - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
 
getInnerJoinSelectors() - Method in class org.apache.jackrabbit.oak.query.ast.SourceImpl
Get all sources that are joined via inner join.
getInputStream(String) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.BlobCache
 
getInstance(Root) - Static method in class org.apache.jackrabbit.oak.core.ImmutableRoot
 
getInstance(DocumentStore, int) - Static method in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfo
Create a cluster node info instance for the store, with the
getInstance(DocumentStore, String, String) - Static method in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfo
Create a cluster node info instance for the store.
getInstance(DocumentStore, String, String, int, boolean) - Static method in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfo
Create a cluster node info instance for the store.
getInstance() - Static method in class org.apache.jackrabbit.oak.plugins.document.util.MapFactory
 
getInstance(DocumentStore) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.ReadOnlyDocumentStoreWrapperFactory
 
getInstance(Root, NamePathMapper) - Static method in class org.apache.jackrabbit.oak.plugins.nodetype.ReadOnlyNodeTypeManager
Return a new instance of ReadOnlyNodeTypeManager that reads node type information from the tree at NodeTypeConstants.NODE_TYPES_PATH.
getInstance() - Static method in class org.apache.jackrabbit.oak.plugins.observation.filter.AddSubtreeFilter
 
getInstance() - Static method in class org.apache.jackrabbit.oak.plugins.observation.filter.DeleteSubtreeFilter
 
getInstance(Root, NamePathMapper) - Static method in class org.apache.jackrabbit.oak.plugins.version.ReadOnlyVersionManager
Return a new instance of ReadOnlyVersionManager that reads version information from the tree at VersionConstants.VERSION_STORE_PATH.
getInstance() - Static method in class org.apache.jackrabbit.oak.spi.security.authentication.credentials.SimpleCredentialsSupport
 
getInstance() - Static method in class org.apache.jackrabbit.oak.spi.security.authorization.permission.EmptyPermissionProvider
 
getInstance() - Static method in class org.apache.jackrabbit.oak.spi.security.authorization.permission.OpenPermissionProvider
 
getInstance() - Static method in class org.apache.jackrabbit.oak.spi.security.principal.EveryonePrincipal
 
getInstance() - Static method in class org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeBits
Creates a mutable instance of privilege bits.
getInstance(PrivilegeBits...) - Static method in class org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeBits
Creates a mutable instance of privilege bits.
getInstance(PropertyState) - Static method in class org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeBits
Get or create an instance of privilege bits for a specific property that stores privileges.
getInstance(Tree) - Static method in class org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeBits
Get or create an instance of privilege bits for a privilege definition.
getInstanceId() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
getInternalNodeNames() - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractTree
 
getInternalNodeNames() - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.ImmutableTree
 
getInvalidateAllRateHistory() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
getInvalidateOneRateHistory() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
getIteratorOverDocsWithBinaries() - Method in class org.apache.jackrabbit.oak.plugins.document.BlobReferenceIterator
Override this document to use a document store specific iterator.
getIteratorOverDocsWithBinaries() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoBlobReferenceIterator
 
getIteratorOverDocsWithBinaries() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBBlobReferenceIterator
 
getJackrabbit2Configuration(ConfigurationParameters) - Static method in class org.apache.jackrabbit.oak.spi.security.authentication.ConfigurationUtil
Creates a new Configuration backwards compatible with the default Jackrabbit 2.x authentication setup.
getJcrName(String) - Method in class org.apache.jackrabbit.oak.namepath.GlobalNameMapper
 
getJcrName(String) - Method in class org.apache.jackrabbit.oak.namepath.LocalNameMapper
 
getJcrName(String) - Method in interface org.apache.jackrabbit.oak.namepath.NameMapper
Returns the JCR name for the given Oak name.
getJcrName(String) - Method in class org.apache.jackrabbit.oak.namepath.NamePathMapper.Default
 
getJcrName(String) - Method in class org.apache.jackrabbit.oak.namepath.NamePathMapperImpl
 
getJcrPath(String) - Method in class org.apache.jackrabbit.oak.namepath.NamePathMapper.Default
 
getJcrPath(String) - Method in class org.apache.jackrabbit.oak.namepath.NamePathMapperImpl
 
getJcrPath(String) - Method in interface org.apache.jackrabbit.oak.namepath.PathMapper
Returns the JCR path for the given Oak path.
getJoin() - Method in class org.apache.jackrabbit.oak.query.plan.JoinExecutionPlan
 
getJoinCondition() - Method in class org.apache.jackrabbit.oak.query.ast.JoinImpl
 
getJournalCreateCount() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentStoreStats
 
getJournalCreateCount() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStoreStatsMBean
 
getJournalGarbageCollector() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
getJournalGCMaxAge() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
The maximum age for journal entries in milliseconds.
getJournalPropertyHandlerFactory() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
getJournalPropertyHandlerFactory() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
getJournalReadCount() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentStoreStats
 
getJournalReadCount() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStoreStatsMBean
 
getKey() - Method in class org.apache.jackrabbit.oak.query.stats.QueryStatsData
 
getKeyLowerLimit(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
Returns the lower key limit to retrieve the children of the given path.
getKeyUpperLimit(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
Returns the upper key limit to retrieve the children of the given path.
getLabel() - Method in class org.apache.jackrabbit.oak.query.facet.FacetResult.Facet
get the facet label
getLag() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.replica.ReplicaSetInfo
 
getLanguage() - Method in class org.apache.jackrabbit.oak.query.stats.QueryStatsData
 
getLastCheckTime() - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
Returns the last time when this object was checked for consistency.
getLastException() - Method in class org.apache.jackrabbit.oak.plugins.index.TrackingCorruptIndexHandler.CorruptIndexInfo
 
getLastExecutedMillis() - Method in class org.apache.jackrabbit.oak.query.stats.QueryStatsData
 
getLastIndexedTo() - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexInfo
Time in millis upto which the repository state is indexed via this indexer
getLastKnownRevisions() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreMBean
 
getLastMod() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoBlob
 
getLastRev() - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
 
getLastRevision() - Method in class org.apache.jackrabbit.oak.plugins.document.AbstractDocumentNodeState
 
getLastRevision() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState
 
getLastRevision() - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.DelegatingDocumentNodeState
 
getLastRevRecoveryAgent() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
getLastThreadName() - Method in class org.apache.jackrabbit.oak.query.stats.QueryStatsData
 
getLastUpdatedTime() - Method in interface org.apache.jackrabbit.oak.plugins.index.IndexInfo
Time in millis at which index was last updated
getLastWrittenRootRev() - Method in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfoDocument
the root-revision of the last background write (of unsaved modifications)
getLatestRoot() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AbstractAccessControlManager
 
getLeaseCheck() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
getLeaseEndTime() - Method in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfo
 
getLeaseEndTime() - Method in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfoDocument
 
getLeaseExpiryTime() - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexInfo
Time in millis at which the current help lease would expire if indexing is in progress.
getLeaseFailureHandler() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
getLeaseTime() - Method in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfo
 
getLeaseTimeOut() - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate
 
getLeft() - Method in class org.apache.jackrabbit.oak.query.ast.JoinImpl
 
getLeftPlan() - Method in class org.apache.jackrabbit.oak.query.plan.JoinExecutionPlan
 
getLength(String) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK
 
getLevel() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoBlob
 
getLimitInMemory() - Method in class org.apache.jackrabbit.oak.query.QueryEngineSettings
 
getLimitReads() - Method in class org.apache.jackrabbit.oak.query.QueryEngineSettings
 
getLiteralValue() - Method in class org.apache.jackrabbit.oak.query.ast.LiteralImpl
 
getLiveRevision(RevisionContext, RevisionVector, Map<Revision, String>, LastRevs) - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
Get the earliest (oldest) revision where the node was alive at or before the provided revision, if the node was alive at the given revision.
getLoadCount() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
getLoadExceptionCount() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
getLoadExceptionRate() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
getLoadExceptionRateHistory() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
getLoadRateHistory() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
getLoadSuccessCount() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
getLocalBranchCommits() - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
Returns the branch commit entries on this document (NodeDocument.BRANCH_COMMITS).
getLocalDiffCacheSize() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
getLogging() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
getLoginContext(Credentials, String) - Method in interface org.apache.jackrabbit.oak.spi.security.authentication.LoginContextProvider
Returns a new login context instance for handling authentication.
getLoginContextProvider(ContentRepository) - Method in class org.apache.jackrabbit.oak.security.authentication.AuthenticationConfigurationImpl
Create a LoginContextProvider using standard JAAS functionality.
getLoginContextProvider(ContentRepository) - Method in interface org.apache.jackrabbit.oak.spi.security.authentication.AuthenticationConfiguration
 
getLoginContextProvider(ContentRepository) - Method in class org.apache.jackrabbit.oak.spi.security.authentication.OpenAuthenticationConfiguration
 
getLong(Connection, RDBDocumentStore.RDBTableMetaData, String, String, String, String, List<String>, List<RDBDocumentStore.QueryCondition>) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStoreJDBC
 
getLong(String) - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.DelegatingDocumentNodeState
 
getLong(Tree, String, long) - Static method in class org.apache.jackrabbit.oak.plugins.tree.TreeUtil
 
getLongestPrefix(Filter, String) - Static method in class org.apache.jackrabbit.oak.plugins.index.property.PropertyIndexPlan
Get the longest prefix of restrictions on a property.
getMainPath() - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
Returns the path of the main document if this document is part of a _prev history tree.
getMandatoryNodeDefinitions() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.EffectiveNodeType
 
getMandatoryPropertyDefinitions() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.EffectiveNodeType
 
getMap(Collection<T>) - Method in class org.apache.jackrabbit.oak.plugins.document.memory.MemoryDocumentStore
Get the in-memory map for this collection.
getMatchedPath() - Method in interface org.apache.jackrabbit.oak.plugins.document.bundlor.Matcher
Relative node path from the bundling root if there was a match
getMatchingProperties(Map<String, PropertyState>, Matcher) - Static method in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundlorUtils
 
getMaxBackOffMillis() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
getMaxBinaryEntrySize() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCache
 
getMaxExternalTimestamp(Iterable<Revision>, int) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
Returns the highest timestamp of all the passed external revisions.
getMaxItems() - Method in class org.apache.jackrabbit.oak.plugins.observation.ChangeCollectorProvider
FOR TESTING-ONLY
getMaxPathDepth() - Method in class org.apache.jackrabbit.oak.plugins.observation.ChangeCollectorProvider
FOR TESTING-ONLY
getMaxPrefilterPathDepth() - Method in class org.apache.jackrabbit.oak.plugins.observation.ChangeSet
 
getMaxPrefilterPathDepth() - Method in class org.apache.jackrabbit.oak.plugins.observation.ChangeSetBuilder
 
getMaxReplicationLagMillis() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
getMaxRowsScanned() - Method in class org.apache.jackrabbit.oak.query.stats.QueryStatsData
 
getMaxSize() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCache
 
getMaxTimeNanos() - Method in class org.apache.jackrabbit.oak.query.stats.QueryStatsData
The maximum CPU time needed to run one query.
getMaxTotalWeight() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
getMBean() - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundlingConfigHandler
 
getMBean() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
getMemory() - Method in class org.apache.jackrabbit.oak.plugins.document.Document
 
getMemory() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState.Children
 
getMemory() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState
 
getMemory() - Method in class org.apache.jackrabbit.oak.plugins.document.LocalDiffCache.Diff
 
getMemory() - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument.Children
 
getMemory() - Method in class org.apache.jackrabbit.oak.plugins.document.PathRev
 
getMemory(Object) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.KeyDataType
 
getMemory(Object) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.ValueDataType
 
getMemory() - Method in class org.apache.jackrabbit.oak.plugins.document.Revision
 
getMemory() - Method in class org.apache.jackrabbit.oak.plugins.document.RevisionVector
 
getMemory() - Method in class org.apache.jackrabbit.oak.plugins.document.util.RevisionsKey
 
getMemory() - Method in class org.apache.jackrabbit.oak.plugins.document.util.StringValue
 
getMemory(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.StringValue
 
getMemoryDiffCacheSize() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
getMergeFailureHistory() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreMBean
 
getMergeSuccessHistory() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreMBean
 
getMetadata() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStore
 
getMetadata() - Method in class org.apache.jackrabbit.oak.plugins.document.memory.MemoryDocumentStore
 
getMetadata() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoDocumentStore
 
getMetadata() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
getMetadata() - Method in class org.apache.jackrabbit.oak.plugins.document.util.LeaseCheckDocumentStoreWrapper
 
getMetadata() - Method in class org.apache.jackrabbit.oak.plugins.document.util.LoggingDocumentStoreWrapper
 
getMetadata() - Method in class org.apache.jackrabbit.oak.plugins.document.util.SynchronizingDocumentStoreWrapper
 
getMetadata() - Method in class org.apache.jackrabbit.oak.plugins.document.util.TimingDocumentStoreWrapper
 
getMetaProps() - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundlingHandler
 
getMetaTableCreationStatement(String) - Method in enum org.apache.jackrabbit.oak.plugins.document.rdb.RDBBlobStoreDB
 
getMeter(String, StatsOptions) - Method in class org.apache.jackrabbit.oak.plugins.metric.MetricStatisticsProvider
 
getMinimumCost() - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndex
 
getMinimumCost() - Method in class org.apache.jackrabbit.oak.plugins.index.diffindex.UUIDDiffIndex
 
getMinimumCost() - Method in class org.apache.jackrabbit.oak.query.index.TraversingIndex
 
getMinimumRootRevisions() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.replica.ReplicaSetInfo
 
getMinTimestampForDiff(RevisionVector, RevisionVector, RevisionVector) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
Returns the minimum timestamp to use for a query for child documents that have been modified between fromRev and toRev.
getMinValue(Collection<T>, String, String, String, List<String>, List<RDBDocumentStore.QueryCondition>) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
getMissCount() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
getMissRate() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
getMixinNodeTypes() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.ReadOnlyNodeTypeManager
 
getMixinSubTypes() - Method in interface org.apache.jackrabbit.oak.query.ast.NodeTypeInfo
Get the set of mixin subtypes.
getMixinTypeNames() - Method in class org.apache.jackrabbit.oak.spi.xml.NodeInfo
Returns the names of the mixin types of the node being imported.
getMixinTypes() - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
 
getMixinTypes() - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
 
getModCount() - Method in class org.apache.jackrabbit.oak.plugins.document.Document
Get the modification count of this document.
getModcount() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBRow
 
getModified() - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
getModified() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBRow
 
getModifiedInSecs(long) - Static method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
Return time in seconds with 5 second resolution
getMongoStatus() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
Returns the status of the Mongo server configured in the DocumentMK.Builder.setMongoDB(String, String, int) method.
getMongoUri() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
Returns the Mongo URI used in the DocumentMK.Builder.setMongoDB(String, String, int) method.
getName() - Method in class org.apache.jackrabbit.oak.management.RepositoryManager
 
getName() - Method in class org.apache.jackrabbit.oak.plugins.atomic.AtomicCounterEditor.ConsolidatorTask
 
getName() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
getName(String) - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.DelegatingDocumentNodeState
 
getName() - Method in interface org.apache.jackrabbit.oak.plugins.document.spi.JournalPropertyService
Name of the journal property
getName() - Method in class org.apache.jackrabbit.oak.plugins.document.UpdateOp.Key
 
getName() - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexInfo
 
getName() - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate
 
getName() - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.ImmutableTree
 
getName() - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.NodeBuilderTree
 
getName() - Method in class org.apache.jackrabbit.oak.plugins.tree.TreeLocation
The name of this location
getName(Tree, String) - Static method in class org.apache.jackrabbit.oak.plugins.tree.TreeUtil
 
getName() - Method in enum org.apache.jackrabbit.oak.query.ast.Order
 
getName() - Method in class org.apache.jackrabbit.oak.security.authentication.AuthenticationConfigurationImpl
 
getName() - Method in class org.apache.jackrabbit.oak.security.authentication.token.TokenConfigurationImpl
 
getName() - Method in class org.apache.jackrabbit.oak.security.authorization.AuthorizationConfigurationImpl
 
getName() - Method in class org.apache.jackrabbit.oak.security.principal.PrincipalConfigurationImpl
 
getName() - Method in class org.apache.jackrabbit.oak.security.privilege.PrivilegeConfigurationImpl
 
getName() - Method in class org.apache.jackrabbit.oak.security.user.UserConfigurationImpl
 
getName() - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.restriction.RestrictionDefinition
The internal oak name of this restriction definition.
getName() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.restriction.RestrictionDefinitionImpl
 
getName() - Method in class org.apache.jackrabbit.oak.spi.security.CompositeConfiguration
 
getName() - Method in class org.apache.jackrabbit.oak.spi.security.principal.EveryonePrincipal
 
getName() - Method in class org.apache.jackrabbit.oak.spi.security.principal.PrincipalImpl
 
getName() - Method in class org.apache.jackrabbit.oak.spi.security.principal.SystemPrincipal
 
getName() - Method in class org.apache.jackrabbit.oak.spi.security.privilege.ImmutablePrivilegeDefinition
 
getName() - Method in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeDefinition
The internal name of this privilege.
getName() - Method in class org.apache.jackrabbit.oak.spi.security.SecurityConfiguration.Default
 
getName() - Method in interface org.apache.jackrabbit.oak.spi.security.SecurityConfiguration
Returns the name of this security configuration.
getName() - Method in class org.apache.jackrabbit.oak.spi.xml.NodeInfo
Returns the name of the node being imported.
getName() - Method in class org.apache.jackrabbit.oak.spi.xml.PropInfo
 
getNamedNodeDefinitions(String) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.EffectiveNodeType
Return all node definitions that match the specified oak name.
getNamedPropertyDefinitions(String) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.EffectiveNodeType
Return all property definitions that match the specified oak name.
getNamePathMapper() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.ReadOnlyNodeTypeManager
Returns a NameMapper to be used by this node type manager.
getNamePathMapper() - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
getNamePathMapper() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AbstractAccessControlList
 
getNamePathMapper() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AbstractAccessControlManager
 
getNames(String) - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.DelegatingDocumentNodeState
 
getNames(Tree, String) - Static method in class org.apache.jackrabbit.oak.plugins.tree.TreeUtil
 
getNames(long) - Static method in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
Returns names of the specified permissions.
getNamespaceMap(Tree) - Static method in class org.apache.jackrabbit.oak.plugins.name.Namespaces
 
getNamespacePrefix(Tree, String) - Static method in class org.apache.jackrabbit.oak.plugins.name.Namespaces
 
getNamespacesProperty(String) - Method in class org.apache.jackrabbit.oak.namepath.GlobalNameMapper
 
getNamespaceURI(Tree, String) - Static method in class org.apache.jackrabbit.oak.plugins.name.Namespaces
 
getNamesSingleValuesProperties() - Method in interface org.apache.jackrabbit.oak.query.ast.NodeTypeInfo
Get the names of all single-valued properties.
getNativeSearchExpression() - Method in class org.apache.jackrabbit.oak.query.ast.NativeFunctionImpl
 
getNewDef() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeDefDiff.ChildNodeDefDiff
 
getNewDef() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeDefDiff.PropDefDiff
 
getNode(String, RevisionVector) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
Get the node for the given path and revision.
getNodeAggregator() - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndex
 
getNodeAtRevision(DocumentNodeStore, RevisionVector, Revision) - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
Returns a DocumentNodeState as seen at the given readRevision.
getNodeBuilder() - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractTree
 
getNodeBuilder() - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.ImmutableTree
 
getNodeBuilder() - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.NodeBuilderTree
 
getNodeCache() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
getNodeCacheSize() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
getNodeCacheStats() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
getNodeChildrenCache() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
getNodeChildrenCacheStats() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
getNodeDefinition(String, EffectiveNodeType) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.EffectiveNodeType
 
getNodeDefinitions() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.EffectiveNodeType
 
getNodeDocumentCache() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
getNodeForMount(Mount, String) - Static method in class org.apache.jackrabbit.oak.plugins.index.property.Multiplexers
 
getNodeFullPath() - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundlingHandler
Returns absolute path of the current node
getNodes(String, String, int, long, int, String) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK
 
getNodesCreateCount() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentStoreStats
 
getNodesCreateCount() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStoreStatsMBean
 
getNodesFindCount() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentStoreStats
 
getNodesFindCount() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStoreStatsMBean
 
getNodesFindQueryCount() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentStoreStats
 
getNodesFindQueryCount() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStoreStatsMBean
 
getNodesReadByQueryCount() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentStoreStats
 
getNodesReadByQueryCount() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStoreStatsMBean
 
getNodesRemoveCount() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentStoreStats
 
getNodesRemoveCount() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStoreStatsMBean
 
getNodeState() - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundlingHandler
 
getNodeState() - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractTree
 
getNodeStateCache() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
getNodeStateDiffer() - Method in class org.apache.jackrabbit.oak.plugins.document.AbstractDocumentNodeState
 
getNodeStateDiffer() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState
 
getNodeStateDiffer() - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.DelegatingDocumentNodeState
 
getNodeStore() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
getNodeStore() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK
 
getNodeStoreStatsCollector() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
getNodesTraversedPerSecond() - Method in class org.apache.jackrabbit.oak.plugins.index.progress.MetricRateEstimator
 
getNodesTraversedPerSecond() - Method in class org.apache.jackrabbit.oak.plugins.index.progress.SimpleRateEstimator
 
getNodesTraversedPerSecond() - Method in interface org.apache.jackrabbit.oak.plugins.index.progress.TraversalRateEstimator
 
getNodesUpdateCount() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentStoreStats
 
getNodesUpdateCount() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStoreStatsMBean
 
getNodeType(String) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.ReadOnlyNodeTypeManager
 
getNodeType() - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
 
getNodeType() - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
 
getNodeTypeInfo(String) - Method in interface org.apache.jackrabbit.oak.query.ast.NodeTypeInfoProvider
Verify that the given nodetype exists.
getNodeTypeInfo(String) - Method in class org.apache.jackrabbit.oak.query.NodeStateNodeTypeInfoProvider
 
getNodeTypeInfoProvider() - Method in class org.apache.jackrabbit.oak.query.ExecutionContext
Get the nodetype info provider.
getNodeTypeManager() - Method in class org.apache.jackrabbit.oak.plugins.version.ReadOnlyVersionManager
 
getNodeTypeManager() - Method in class org.apache.jackrabbit.oak.plugins.version.ReadWriteVersionManager
 
getNodeTypeName() - Method in interface org.apache.jackrabbit.oak.query.ast.NodeTypeInfo
Get the name of the nodetype.
getNodeTypeName(AuthorizableType) - Static method in class org.apache.jackrabbit.oak.security.user.query.QueryUtil
Retrieve the node type name for the specified authorizable type.
getNumChanges() - Method in class org.apache.jackrabbit.oak.plugins.document.util.CountingDiff
 
getOakName(String) - Method in class org.apache.jackrabbit.oak.namepath.GlobalNameMapper
 
getOakName(String) - Method in interface org.apache.jackrabbit.oak.namepath.NameMapper
Returns the Oak name for the specified JCR name.
getOakName(String) - Method in class org.apache.jackrabbit.oak.namepath.NamePathMapper.Default
 
getOakName(String) - Method in class org.apache.jackrabbit.oak.namepath.NamePathMapperImpl
 
getOakName(String) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.ReadOnlyNodeTypeManager
Returns the internal name for the specified JCR name.
getOakNameFromExpanded(String) - Method in class org.apache.jackrabbit.oak.namepath.GlobalNameMapper
 
getOakNameOrNull(String) - Method in class org.apache.jackrabbit.oak.namepath.GlobalNameMapper
 
getOakNameOrNull(String) - Method in class org.apache.jackrabbit.oak.namepath.LocalNameMapper
 
getOakNameOrNull(String) - Method in interface org.apache.jackrabbit.oak.namepath.NameMapper
Returns the Oak name for the given JCR name, or null if no such mapping exists because the given JCR name contains an unknown namespace URI or prefix, or is otherwise invalid.
getOakNameOrNull(String) - Method in class org.apache.jackrabbit.oak.namepath.NamePathMapper.Default
 
getOakNameOrNull(String) - Method in class org.apache.jackrabbit.oak.namepath.NamePathMapperImpl
 
getOakPath(String) - Method in class org.apache.jackrabbit.oak.namepath.NamePathMapper.Default
 
getOakPath(String) - Method in class org.apache.jackrabbit.oak.namepath.NamePathMapperImpl
 
getOakPath(String) - Method in interface org.apache.jackrabbit.oak.namepath.PathMapper
Returns the Oak path for the given JCR path, or null if no such mapping exists because the given JCR path contains a name element with an unknown namespace URI or prefix, or is otherwise invalid.
getOakPath(String) - Method in class org.apache.jackrabbit.oak.query.QueryImpl
Validate the path is syntactically correct, and convert it to an Oak internal path (including namespace remapping if needed).
getOakPath() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AbstractAccessControlList
 
getOakPath(String) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AbstractAccessControlManager
 
getOakPrefixOrNull(String) - Method in class org.apache.jackrabbit.oak.namepath.GlobalNameMapper
 
getOakURIOrNull(String) - Method in class org.apache.jackrabbit.oak.namepath.GlobalNameMapper
 
getOldDef() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeDefDiff.ChildNodeDefDiff
 
getOldDef() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeDefDiff.PropDefDiff
 
getOldestCheckpointCreationTimestamp() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentCheckpointMBean
 
getOldestDeletedOnceTimestamp(Clock, long) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoVersionGCSupport
 
getOldestDeletedOnceTimestamp(Clock, long) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBVersionGCSupport
 
getOldestDeletedOnceTimestamp(Clock, long) - Method in class org.apache.jackrabbit.oak.plugins.document.VersionGCSupport
Retrieve the time of the oldest document marked as 'deletedOnce'.
getOpenCount() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.MapFactory
 
getOpenCount() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCache
 
getOperand() - Method in class org.apache.jackrabbit.oak.query.ast.LengthImpl
 
getOperand() - Method in class org.apache.jackrabbit.oak.query.ast.LowerCaseImpl
 
getOperand() - Method in class org.apache.jackrabbit.oak.query.ast.OrderingImpl
 
getOperand() - Method in class org.apache.jackrabbit.oak.query.ast.UpperCaseImpl
 
getOperand1() - Method in class org.apache.jackrabbit.oak.query.ast.ComparisonImpl
 
getOperand1() - Method in class org.apache.jackrabbit.oak.query.ast.InImpl
 
getOperand2() - Method in class org.apache.jackrabbit.oak.query.ast.ComparisonImpl
 
getOperand2() - Method in class org.apache.jackrabbit.oak.query.ast.InImpl
 
getOperationTimestamp() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.replica.Timestamped
 
getOperator() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore.QueryCondition
 
getOperator() - Method in class org.apache.jackrabbit.oak.query.ast.ComparisonImpl
 
getOptions() - Method in class org.apache.jackrabbit.oak.plugins.document.VersionGarbageCollector
 
getOrAddChild(Tree, String, String) - Static method in class org.apache.jackrabbit.oak.plugins.tree.TreeUtil
Combination of Tree.getChild(String) and adding a child including its jcr:primaryType property (i.e.
getOrCreateOakIndex(NodeBuilder) - Static method in class org.apache.jackrabbit.oak.plugins.index.IndexUtils
 
getOrCreateVersionHistory(NodeBuilder, Map<String, Object>) - Method in class org.apache.jackrabbit.oak.plugins.version.ReadWriteVersionManager
Gets or creates the version history for the given versionable node.
getOrderEntry(SelectorImpl, OrderingImpl) - Method in class org.apache.jackrabbit.oak.query.ast.DynamicOperandImpl
Create an entry for the "order by" list for a given filter.
getOrderEntry(SelectorImpl, OrderingImpl) - Method in class org.apache.jackrabbit.oak.query.ast.FullTextSearchScoreImpl
 
getOrderEntry(SelectorImpl, OrderingImpl) - Method in class org.apache.jackrabbit.oak.query.ast.LengthImpl
 
getOrderEntry(SelectorImpl, OrderingImpl) - Method in class org.apache.jackrabbit.oak.query.ast.LowerCaseImpl
 
getOrderEntry(SelectorImpl, OrderingImpl) - Method in class org.apache.jackrabbit.oak.query.ast.NodeLocalNameImpl
 
getOrderEntry(SelectorImpl, OrderingImpl) - Method in class org.apache.jackrabbit.oak.query.ast.NodeNameImpl
 
getOrderEntry(SelectorImpl, OrderingImpl) - Method in class org.apache.jackrabbit.oak.query.ast.PropertyValueImpl
 
getOrderEntry(SelectorImpl, OrderingImpl) - Method in class org.apache.jackrabbit.oak.query.ast.UpperCaseImpl
 
getOrderings() - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
getParameters(String) - Method in class org.apache.jackrabbit.oak.security.SecurityProviderImpl
 
getParameters() - Method in class org.apache.jackrabbit.oak.security.user.UserConfigurationImpl
 
getParameters() - Method in class org.apache.jackrabbit.oak.spi.security.CompositeConfiguration
 
getParameters() - Method in class org.apache.jackrabbit.oak.spi.security.ConfigurationBase
 
getParameters(String) - Method in class org.apache.jackrabbit.oak.spi.security.OpenSecurityProvider
 
getParameters() - Method in class org.apache.jackrabbit.oak.spi.security.SecurityConfiguration.Default
 
getParameters() - Method in interface org.apache.jackrabbit.oak.spi.security.SecurityConfiguration
Returns the configuration parameters associated with this security configuration instance.
getParameters(String) - Method in interface org.apache.jackrabbit.oak.spi.security.SecurityProvider
Allows to retrieve the configuration parameters associated with a given SecurityConfiguration accessible by this provider.
getParent() - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractTree
 
getParent() - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.ImmutableTree.DefaultParentProvider
 
getParent() - Method in interface org.apache.jackrabbit.oak.plugins.tree.impl.ImmutableTree.ParentProvider
 
getParent() - Method in class org.apache.jackrabbit.oak.plugins.tree.TreeLocation
Navigate to the parent or an invalid location for the root of the hierarchy.
getParentId(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
Returns the parent id for given id if possible
getParentIdFromLowerLimit(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
Returns parentId extracted from the fromKey.
getParentNodeNames() - Method in class org.apache.jackrabbit.oak.plugins.observation.ChangeSet
 
getParentNodeTypes() - Method in class org.apache.jackrabbit.oak.plugins.observation.ChangeSet
 
getParentOrNull() - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractTree
 
getParentOrNull() - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.ImmutableTree
 
getParentOrNull() - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.NodeBuilderTree
 
getParentPathOrNull(String) - Static method in class org.apache.jackrabbit.oak.security.authorization.permission.PermissionUtil
 
getParentPaths() - Method in class org.apache.jackrabbit.oak.plugins.observation.ChangeSet
 
getParents(NodeState, String) - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.SimpleNodeAggregator
 
getPath() - Method in class org.apache.jackrabbit.oak.namepath.PathTracker
 
getPath() - Method in class org.apache.jackrabbit.oak.plugins.document.AbstractDocumentNodeState
 
getPath() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState
 
getPath() - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
 
getPath() - Method in class org.apache.jackrabbit.oak.plugins.document.PathRev
 
getPath() - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.DelegatingDocumentNodeState
 
getPath(String) - Method in class org.apache.jackrabbit.oak.plugins.identifier.IdentifierManager
The path of the tree identified by the specified identifier or null.
getPath(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.identifier.IdentifierManager
Returns the path of the tree references by the specified (weak) reference PropertyState.
getPath(PropertyValue) - Method in class org.apache.jackrabbit.oak.plugins.identifier.IdentifierManager
Returns the path of the tree references by the specified (weak) reference PropertyState.
getPath() - Method in class org.apache.jackrabbit.oak.plugins.index.IndexUpdate
Returns the path of this node, building it lazily when first requested.
getPath() - Method in interface org.apache.jackrabbit.oak.plugins.index.NodeTraversalCallback.PathSource
 
getPath() - Method in class org.apache.jackrabbit.oak.plugins.index.TrackingCorruptIndexHandler.CorruptIndexInfo
 
getPath() - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractTree
 
getPath() - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.ImmutableTree
 
getPath() - Method in class org.apache.jackrabbit.oak.plugins.tree.TreeLocation
The path of this location
getPath() - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
Get the path.
getPath() - Method in class org.apache.jackrabbit.oak.query.index.IndexRowImpl
 
getPath() - Method in class org.apache.jackrabbit.oak.query.ResultRowImpl
 
getPath(String) - Method in class org.apache.jackrabbit.oak.query.ResultRowImpl
 
getPath(Tree, Tree) - Static method in class org.apache.jackrabbit.oak.security.authorization.permission.PermissionUtil
 
getPath() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AbstractAccessControlList
 
getPathExpression() - Method in class org.apache.jackrabbit.oak.query.ast.SimilarImpl
 
getPathFromId(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
 
getPathPlan() - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
 
getPathPrefix() - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndexPlan
 
getPathRestriction() - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
 
getPaths() - Method in interface org.apache.jackrabbit.oak.plugins.observation.filter.FilterConfigMBean
A set of paths, potentially containing globs, that include all events of this filter.
getPattern() - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.Include
 
getPattern(String, Tree) - Method in class org.apache.jackrabbit.oak.security.authorization.restriction.PrincipalRestrictionProvider
 
getPattern(String, Set<Restriction>) - Method in class org.apache.jackrabbit.oak.security.authorization.restriction.PrincipalRestrictionProvider
 
getPattern(String, Tree) - Method in class org.apache.jackrabbit.oak.security.authorization.restriction.RestrictionProviderImpl
 
getPattern(String, Set<Restriction>) - Method in class org.apache.jackrabbit.oak.security.authorization.restriction.RestrictionProviderImpl
 
getPattern(String, Tree) - Method in class org.apache.jackrabbit.oak.security.authorization.restriction.WhiteboardRestrictionProvider
 
getPattern(String, Set<Restriction>) - Method in class org.apache.jackrabbit.oak.security.authorization.restriction.WhiteboardRestrictionProvider
 
getPattern(String, Tree) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.restriction.CompositeRestrictionProvider
 
getPattern(String, Set<Restriction>) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.restriction.CompositeRestrictionProvider
 
getPattern(String, Tree) - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.restriction.RestrictionProvider
Creates the RestrictionPattern for the restriction information stored with specified tree.
getPattern(String, Set<Restriction>) - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.restriction.RestrictionProvider
Creates the RestrictionPattern for the specified restrictions.
getPendingModifications() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
getPendingModifications() - Method in interface org.apache.jackrabbit.oak.plugins.document.RevisionContext
 
getPendingWriteCount() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
getPermission(String, long) - Static method in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
 
getPermissionProvider() - Method in class org.apache.jackrabbit.oak.query.ExecutionContext
 
getPermissionProvider(Root, String, Set<Principal>) - Method in class org.apache.jackrabbit.oak.security.authorization.AuthorizationConfigurationImpl
 
getPermissionProvider(Root, String, Set<Principal>) - Method in class org.apache.jackrabbit.oak.security.authorization.composite.CompositeAuthorizationConfiguration
 
getPermissionProvider() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AbstractAccessControlManager
 
getPermissionProvider(Root, String, Set<Principal>) - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.AuthorizationConfiguration
 
getPermissionProvider(Root, String, Set<Principal>) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.OpenAuthorizationConfiguration
 
getPermissionRootName(Mount, String) - Static method in class org.apache.jackrabbit.oak.security.authorization.permission.MountPermissionProvider
 
getPermissions(String, TreeLocation, boolean) - Static method in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
Returns the permissions that correspond the given jcr actions such as specified in Session.hasPermission(String, String).
getPermissions(String) - Static method in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
Returns the permissions that correspond the given permission names.
getPermissionsRoot(Root, String) - Static method in class org.apache.jackrabbit.oak.security.authorization.permission.PermissionUtil
 
getPermissionStore(Root, String, RestrictionProvider) - Method in class org.apache.jackrabbit.oak.security.authorization.permission.MountPermissionProvider
 
getPermissionStore(Root, String, RestrictionProvider) - Method in class org.apache.jackrabbit.oak.security.authorization.permission.PermissionProviderImpl
 
getPersistenceCacheStats() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
getPersistentCache() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
getPersistentCacheStats(Cache<?, ?>) - Static method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCache
 
getPlan(Filter, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndex
 
getPlan(Filter, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.index.diffindex.DiffIndex
 
getPlan(NodeState) - Method in class org.apache.jackrabbit.oak.query.ast.JoinImpl
 
getPlan(NodeState) - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
 
getPlan(NodeState) - Method in class org.apache.jackrabbit.oak.query.ast.SourceImpl
Get the query plan.
getPlan(Filter, NodeState) - Method in class org.apache.jackrabbit.oak.query.index.TraversingIndex
 
getPlan() - Method in interface org.apache.jackrabbit.oak.query.Query
Get the query plan.
getPlan() - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
getPlan() - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
getPlanDescription(QueryIndex.IndexPlan, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndex
 
getPlanName() - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndexPlan
 
getPlans(Filter, List<QueryIndex.OrderEntry>, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndex
 
getPolicies(String) - Method in class org.apache.jackrabbit.oak.security.authorization.accesscontrol.AccessControlManagerImpl
 
getPolicies(Principal) - Method in class org.apache.jackrabbit.oak.security.authorization.accesscontrol.AccessControlManagerImpl
 
getPopularQueries() - Method in interface org.apache.jackrabbit.oak.query.stats.QueryStatsMBean
 
getPopularQueries() - Method in class org.apache.jackrabbit.oak.query.stats.QueryStatsMBeanImpl
 
getPossiblyDeletedDocs(long, long) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoVersionGCSupport
 
getPossiblyDeletedDocs(long, long) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBVersionGCSupport
 
getPossiblyDeletedDocs(long, long) - Method in class org.apache.jackrabbit.oak.plugins.document.VersionGCSupport
Returns documents that have a NodeDocument.MODIFIED_IN_SECS value within the given range and the NodeDocument.DELETED set to true.
getPrefix(String) - Method in class org.apache.jackrabbit.oak.plugins.name.ReadOnlyNamespaceRegistry
 
getPrefixes() - Method in class org.apache.jackrabbit.oak.namepath.GlobalNameMapper
 
getPrefixes() - Method in class org.apache.jackrabbit.oak.plugins.name.ReadOnlyNamespaceRegistry
 
getPrevDocumentCacheSize() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
getPreviousIdFor(String, Revision, int) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
 
getPreviousPathFor(String, Revision, int) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
 
getPrimaryNodeTypes() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.ReadOnlyNodeTypeManager
 
getPrimarySubTypes() - Method in interface org.apache.jackrabbit.oak.query.ast.NodeTypeInfo
Get the set of primary subtypes.
getPrimaryTypeName(Tree) - Static method in class org.apache.jackrabbit.oak.plugins.tree.TreeUtil
 
getPrimaryTypeName() - Method in class org.apache.jackrabbit.oak.spi.xml.NodeInfo
Returns the name of the primary type of the node being imported.
getPrimaryTypes() - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
 
getPrimaryTypes() - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
 
getPrincipal() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.ACE
 
getPrincipal(String) - Method in class org.apache.jackrabbit.oak.spi.security.principal.CompositePrincipalProvider
 
getPrincipal(String) - Method in class org.apache.jackrabbit.oak.spi.security.principal.EmptyPrincipalProvider
 
getPrincipal(String) - Method in class org.apache.jackrabbit.oak.spi.security.principal.PrincipalManagerImpl
 
getPrincipal(String) - Method in interface org.apache.jackrabbit.oak.spi.security.principal.PrincipalProvider
Returns the principal with the specified name or null if the principal does not exist.
getPrincipalManager(Root, NamePathMapper) - Method in class org.apache.jackrabbit.oak.security.principal.PrincipalConfigurationImpl
 
getPrincipalManager(Root, NamePathMapper) - Method in class org.apache.jackrabbit.oak.spi.security.principal.CompositePrincipalConfiguration
 
getPrincipalManager(Root, NamePathMapper) - Method in interface org.apache.jackrabbit.oak.spi.security.principal.PrincipalConfiguration
Returns an instance of PrincipalManager that can be used to query and retrieve principals such as needed for JCR access control management.
getPrincipalProvider(Root, NamePathMapper) - Method in class org.apache.jackrabbit.oak.security.principal.PrincipalConfigurationImpl
 
getPrincipalProvider() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.AbstractLoginModule
Retrieves the PrincipalProvider that should be used to handle this authentication.
getPrincipalProvider() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.callback.PrincipalProviderCallback
getPrincipalProvider(Root, NamePathMapper) - Method in class org.apache.jackrabbit.oak.spi.security.principal.CompositePrincipalConfiguration
 
getPrincipalProvider(Root, NamePathMapper) - Method in interface org.apache.jackrabbit.oak.spi.security.principal.PrincipalConfiguration
Returns an instance of the OAK PrincipalProvider.
getPrincipalRoot(Tree, String) - Static method in class org.apache.jackrabbit.oak.security.authorization.permission.PermissionUtil
 
getPrincipals(String) - Method in class org.apache.jackrabbit.oak.spi.security.authentication.AbstractLoginModule
Retrieves all principals associated with the specified userId for the configured principal provider.
getPrincipals(Principal) - Method in class org.apache.jackrabbit.oak.spi.security.authentication.AbstractLoginModule
 
getPrincipals() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.AuthInfoImpl
 
getPrincipals(String) - Method in class org.apache.jackrabbit.oak.spi.security.principal.CompositePrincipalProvider
 
getPrincipals(String) - Method in class org.apache.jackrabbit.oak.spi.security.principal.EmptyPrincipalProvider
 
getPrincipals(int) - Method in class org.apache.jackrabbit.oak.spi.security.principal.PrincipalManagerImpl
 
getPrincipals(String) - Method in interface org.apache.jackrabbit.oak.spi.security.principal.PrincipalProvider
Tries to resolve the specified userID to a valid principal and it's group membership.
getPrivateAttributes() - Method in interface org.apache.jackrabbit.oak.spi.security.authentication.token.TokenInfo
Returns the private attributes stored with this info object.
getPrivilegeBits() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.ACE
 
getPrivilegeManager(Root, NamePathMapper) - Method in class org.apache.jackrabbit.oak.security.privilege.PrivilegeConfigurationImpl
 
getPrivilegeManager() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AbstractAccessControlManager
 
getPrivilegeManager(Root, NamePathMapper) - Method in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConfiguration
Creates a new instance of PrivilegeManager.
getPrivilegeNames(PrivilegeBits) - Method in class org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeBitsProvider
Resolve the given privilege bits to a set of privilege names.
getPrivileges(Tree) - Method in class org.apache.jackrabbit.oak.security.authorization.permission.PermissionProviderImpl
 
getPrivileges(String) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AbstractAccessControlManager
 
getPrivileges(String, Set<Principal>) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AbstractAccessControlManager
 
getPrivileges(Tree) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.permission.EmptyPermissionProvider
 
getPrivileges(Tree) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.permission.OpenPermissionProvider
 
getPrivileges(Tree) - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.PermissionProvider
Returns the set of privilege names which are granted to the set of Principals associated with this provider instance for the specified Tree.
getPrivilegesTree() - Method in class org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeBitsProvider
Returns the root tree for all privilege definitions stored in the content repository.
getPrivilegesTree(Root) - Static method in class org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeUtil
Returns the root tree for all privilege definitions stored in the content repository.
getProcessedReferences() - Method in class org.apache.jackrabbit.oak.spi.xml.ReferenceChangeTracker
Returns an iterator over all processed reference properties.
getProperties() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState
 
getProperties() - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.DelegatingDocumentNodeState
 
getProperties() - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractTree
 
getProperty(String) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState
 
getProperty(String) - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.DelegatingDocumentNodeState
 
getProperty(String) - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractTree
 
getProperty() - Method in class org.apache.jackrabbit.oak.plugins.tree.TreeLocation
Get the underlying PropertyState for this TreeLocation.
getProperty() - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.restriction.Restriction
The OAK property state associated with this restriction.
getProperty() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.restriction.RestrictionImpl
 
getPropertyCount() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState
 
getPropertyCount() - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.DelegatingDocumentNodeState
 
getPropertyCount() - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractTree
 
getPropertyDef(EffectiveNodeType) - Method in class org.apache.jackrabbit.oak.spi.xml.PropInfo
 
getPropertyDefinition(String, boolean, int, boolean) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.EffectiveNodeType
Calculates the applicable definition for the property with the specified characteristics under a parent with this effective type.
getPropertyDefinitions() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.EffectiveNodeType
 
getPropertyExistence() - Method in class org.apache.jackrabbit.oak.query.ast.DynamicOperandImpl
Get the property existence condition for this operand, if this operand is used as part of a condition.
getPropertyExistence() - Method in class org.apache.jackrabbit.oak.query.ast.FullTextSearchScoreImpl
 
getPropertyExistence() - Method in class org.apache.jackrabbit.oak.query.ast.LengthImpl
 
getPropertyExistence() - Method in class org.apache.jackrabbit.oak.query.ast.LowerCaseImpl
 
getPropertyExistence() - Method in class org.apache.jackrabbit.oak.query.ast.NodeLocalNameImpl
 
getPropertyExistence() - Method in class org.apache.jackrabbit.oak.query.ast.NodeNameImpl
 
getPropertyExistence() - Method in class org.apache.jackrabbit.oak.query.ast.PropertyValueImpl
 
getPropertyExistence() - Method in class org.apache.jackrabbit.oak.query.ast.UpperCaseImpl
 
getPropertyExistenceConditions() - Method in class org.apache.jackrabbit.oak.query.ast.AndImpl
 
getPropertyExistenceConditions() - Method in class org.apache.jackrabbit.oak.query.ast.ChildNodeImpl
 
getPropertyExistenceConditions() - Method in class org.apache.jackrabbit.oak.query.ast.ComparisonImpl
 
getPropertyExistenceConditions() - Method in class org.apache.jackrabbit.oak.query.ast.ConstraintImpl
Get the set of property existence conditions that can be derived for this condition.
getPropertyExistenceConditions() - Method in class org.apache.jackrabbit.oak.query.ast.DescendantNodeImpl
 
getPropertyExistenceConditions() - Method in class org.apache.jackrabbit.oak.query.ast.FullTextSearchImpl
 
getPropertyExistenceConditions() - Method in class org.apache.jackrabbit.oak.query.ast.InImpl
 
getPropertyExistenceConditions() - Method in class org.apache.jackrabbit.oak.query.ast.NativeFunctionImpl
 
getPropertyExistenceConditions() - Method in class org.apache.jackrabbit.oak.query.ast.NotImpl
 
getPropertyExistenceConditions() - Method in class org.apache.jackrabbit.oak.query.ast.OrImpl
 
getPropertyExistenceConditions() - Method in class org.apache.jackrabbit.oak.query.ast.PropertyExistenceImpl
 
getPropertyExistenceConditions() - Method in class org.apache.jackrabbit.oak.query.ast.PropertyInexistenceImpl
 
getPropertyExistenceConditions() - Method in class org.apache.jackrabbit.oak.query.ast.SameNodeImpl
 
getPropertyExistenceConditions() - Method in class org.apache.jackrabbit.oak.query.ast.SimilarImpl
 
getPropertyExistenceConditions() - Method in class org.apache.jackrabbit.oak.query.ast.SpellcheckImpl
 
getPropertyExistenceConditions() - Method in class org.apache.jackrabbit.oak.query.ast.SuggestImpl
 
getPropertyIndexAsyncReindexStatus() - Method in class org.apache.jackrabbit.oak.management.RepositoryManager
 
getPropertyIndexAsyncReindexStatus() - Method in class org.apache.jackrabbit.oak.plugins.index.property.jmx.PropertyIndexAsyncReindex
 
getPropertyIndexAsyncReindexStatus() - Method in interface org.apache.jackrabbit.oak.plugins.index.property.jmx.PropertyIndexAsyncReindexMBean
Asynchronous Property Index reindexing status
getPropertyName() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore.QueryCondition
 
getPropertyName() - Method in class org.apache.jackrabbit.oak.query.ast.ColumnImpl
 
getPropertyName() - Method in class org.apache.jackrabbit.oak.query.ast.PropertyValueImpl
 
getPropertyNames() - Method in class org.apache.jackrabbit.oak.plugins.observation.ChangeSet
 
getPropertyPath(String) - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundlingHandler
Returns property path.
getPropertyRestriction() - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndexPlan
 
getPropertyRestriction(String) - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
 
getPropertyRestrictions() - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
 
getPropertyRestrictions(String) - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
 
getPropertyStatus(String) - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractTree
 
getPropertyTypeFromName(String) - Static method in class org.apache.jackrabbit.oak.query.SQL2Parser
Get the property type from the given case insensitive name.
getProtectedItemImporters() - Method in class org.apache.jackrabbit.oak.security.authorization.AuthorizationConfigurationImpl
 
getProtectedItemImporters() - Method in class org.apache.jackrabbit.oak.security.user.UserConfigurationImpl
 
getProtectedItemImporters() - Method in class org.apache.jackrabbit.oak.spi.security.CompositeConfiguration
 
getProtectedItemImporters() - Method in class org.apache.jackrabbit.oak.spi.security.SecurityConfiguration.Default
 
getProtectedItemImporters() - Method in interface org.apache.jackrabbit.oak.spi.security.SecurityConfiguration
 
getPublicAttributes() - Method in interface org.apache.jackrabbit.oak.spi.security.authentication.token.TokenInfo
Returns the public attributes stored with this info object.
getPutRateHistory() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
getPutRejectedAlreadyPersistedRateHistory() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
getPutRejectedAsCachedInSecRateHistory() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
getPutRejectedEntryNotUsedRateHistory() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
getPutRejectedQueueFullRateHistory() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
getQuery() - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
 
getQuery() - Method in class org.apache.jackrabbit.oak.query.stats.QueryStatsData
 
getQueryEngine() - Method in class org.apache.jackrabbit.oak.core.ImmutableRoot
 
getQueryExecution(String, String) - Method in class org.apache.jackrabbit.oak.query.stats.QueryStatsMBeanImpl
 
getQueryExecution(String, String) - Method in interface org.apache.jackrabbit.oak.query.stats.QueryStatsReporter
 
getQueryExecutionStats() - Method in interface org.apache.jackrabbit.oak.query.Query
 
getQueryExecutionStats() - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
getQueryExecutionStats() - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
getQueryIndexes(NodeState) - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndexProvider
 
getQueryIndexes(NodeState) - Method in class org.apache.jackrabbit.oak.plugins.index.diffindex.UUIDDiffIndexProviderWrapper
 
getQueryIndexes(NodeState) - Method in class org.apache.jackrabbit.oak.plugins.index.nodetype.NodeTypeIndexProvider
 
getQueryIndexes(NodeState) - Method in class org.apache.jackrabbit.oak.plugins.index.property.OrderedPropertyIndexProvider
 
getQueryIndexes(NodeState) - Method in class org.apache.jackrabbit.oak.plugins.index.property.PropertyIndexProvider
 
getQueryIndexes(NodeState) - Method in class org.apache.jackrabbit.oak.plugins.index.reference.ReferenceIndexProvider
 
getQueryJournalHistory() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentStoreStats
 
getQueryJournalHistory() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStoreStatsMBean
 
getQueryLimits() - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
 
getQueryNodesFromPrimaryHistory() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentStoreStats
 
getQueryNodesFromPrimaryHistory() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStoreStatsMBean
 
getQueryNodesFromSlaveHistory() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentStoreStats
 
getQueryNodesFromSlaveHistory() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStoreStatsMBean
 
getQueryNodesLockHistory() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentStoreStats
 
getQueryNodesLockHistory() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStoreStatsMBean
 
getQueryOptions() - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
getQueryStatement() - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
 
getQueryStats() - Method in class org.apache.jackrabbit.oak.query.QueryEngineSettings
 
getQueryStatsReporter() - Method in class org.apache.jackrabbit.oak.query.QueryEngineSettings
 
getReadDocCount() - Method in interface org.apache.jackrabbit.oak.plugins.document.RevisionGCStatsMBean
 
getReadDocHistory() - Method in interface org.apache.jackrabbit.oak.plugins.document.RevisionGCStatsMBean
 
getReadOnlyInstance(DocumentStore) - Static method in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfo
Create a dummy cluster node info instance to be utilized for read only access to underlying store.
getReadOnlyMode() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
getReadPreference() - Method in class org.apache.jackrabbit.oak.plugins.document.memory.MemoryDocumentStore
 
getRecoveryBy() - Method in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfoDocument
 
getRecoveryCandidateNodes() - Method in class org.apache.jackrabbit.oak.plugins.document.LastRevRecoveryAgent
Gets the _lastRev recovery candidate cluster nodes.
getReference(String) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.BlobCache
 
getReferencedBlobsIterator() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
Returns an iterator for all the blob present in the store.
getReferences(boolean, Tree, String) - Method in class org.apache.jackrabbit.oak.plugins.identifier.IdentifierManager
Searches all reference properties to the specified tree that match the given name and node type constraints.
getReferences(Tree, String, String, boolean) - Method in class org.apache.jackrabbit.oak.plugins.identifier.IdentifierManager
Searches all reference properties to the specified tree that match the given propertyName and the specified, mandatory node type constraint (ntName).
getRegistry() - Method in class org.apache.jackrabbit.oak.plugins.metric.MetricStatisticsProvider
 
getReindexedDefinitions() - Method in class org.apache.jackrabbit.oak.plugins.index.IndexUpdate
 
getReindexedIndexPaths() - Method in class org.apache.jackrabbit.oak.plugins.index.progress.IndexingProgressReporter
Set of indexPaths which have been reindexed
getReindexStats() - Method in class org.apache.jackrabbit.oak.plugins.index.IndexUpdate
 
getReindexStats() - Method in class org.apache.jackrabbit.oak.plugins.index.progress.IndexingProgressReporter
 
getRemovedProps() - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundlingHandler
Returns name of properties which needs to be removed or marked as deleted
getRemoveNodesHistory() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentStoreStats
 
getRemoveNodesHistory() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStoreStatsMBean
 
getReplicaConfig() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.replica.ReplicaSetInfo
 
getReplicaStatus() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.replica.ReplicaSetInfo
 
getRepositoryInitializer() - Method in class org.apache.jackrabbit.oak.security.privilege.PrivilegeConfigurationImpl
 
getRepositoryInitializer() - Method in class org.apache.jackrabbit.oak.spi.security.CompositeConfiguration
 
getRepositoryInitializer() - Method in class org.apache.jackrabbit.oak.spi.security.SecurityConfiguration.Default
 
getRepositoryInitializer() - Method in interface org.apache.jackrabbit.oak.spi.security.SecurityConfiguration
Returns a repository initializer for this security configuration.
getRepositoryPermission() - Method in class org.apache.jackrabbit.oak.security.authorization.permission.PermissionProviderImpl
 
getRepositoryPermission() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.permission.EmptyPermissionProvider
 
getRepositoryPermission() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.permission.OpenPermissionProvider
 
getRepositoryPermission() - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.PermissionProvider
Return the RepositoryPermission for the set of Principals associated with this provider instance.
getRequestCount() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
getRequestRateHistory() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
getRequiredType() - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.restriction.RestrictionDefinition
The required type as defined by this definition.
getRequiredType() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.restriction.RestrictionDefinitionImpl
 
getResetDeletedFlagCount() - Method in interface org.apache.jackrabbit.oak.plugins.document.RevisionGCStatsMBean
 
getResetDeletedFlagHistory() - Method in interface org.apache.jackrabbit.oak.plugins.document.RevisionGCStatsMBean
 
getResidualNodeDefinitions() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.EffectiveNodeType
Return all residual node definitions.
getResidualPropertyDefinitions() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.EffectiveNodeType
Return all residual property definitions.
getRestoreStatus() - Method in class org.apache.jackrabbit.oak.management.RepositoryManager
 
getRestriction(String) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.ACE
 
getRestrictionNames() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AbstractAccessControlList
 
getRestrictionNames() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.ACE
 
getRestrictionProvider() - Method in class org.apache.jackrabbit.oak.security.authorization.AuthorizationConfigurationImpl
 
getRestrictionProvider() - Method in class org.apache.jackrabbit.oak.security.authorization.composite.CompositeAuthorizationConfiguration
 
getRestrictionProvider() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AbstractAccessControlList
 
getRestrictionProvider() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.ImmutableACL
 
getRestrictionProvider() - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.AuthorizationConfiguration
 
getRestrictionProvider() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.OpenAuthorizationConfiguration
 
getRestrictions() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.ACE
 
getRestrictions(String) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.ACE
 
getRestrictionsTree(Tree) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.restriction.AbstractRestrictionProvider
Returns the tree that contains the restriction of the specified ACE tree.
getRestrictionType(String) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AbstractAccessControlList
 
getResults(Filter) - Method in class org.apache.jackrabbit.oak.plugins.index.diffindex.BaseDiffCollector
 
getResults(Filter) - Method in interface org.apache.jackrabbit.oak.plugins.index.diffindex.DiffCollector
Get the result for this filter.
getResults(Filter) - Method in class org.apache.jackrabbit.oak.plugins.index.diffindex.UUIDDiffCollector
 
getReverse() - Method in class org.apache.jackrabbit.oak.plugins.document.UpdateOp.Operation
 
getReverseOperation() - Method in class org.apache.jackrabbit.oak.plugins.document.UpdateOp
 
getRevision(int) - Method in class org.apache.jackrabbit.oak.plugins.document.RevisionVector
Returns the revision element with the given clusterId or null if there is no such revision in this vector.
getRevision() - Method in class org.apache.jackrabbit.oak.plugins.document.UpdateOp.Key
 
getRevisionComparatorState() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreMBean
Deprecated.
getRevisionGCStatus() - Method in class org.apache.jackrabbit.oak.management.RepositoryManager
 
getRevisionGCStatusForRole(String) - Method in class org.apache.jackrabbit.oak.management.RepositoryManager
 
getRight() - Method in class org.apache.jackrabbit.oak.query.ast.JoinImpl
 
getRightPlan() - Method in class org.apache.jackrabbit.oak.query.plan.JoinExecutionPlan
 
getROConnection() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBConnectionHandler
Obtain a Connection suitable for read-only operations.
getRoot() - Method in class org.apache.jackrabbit.oak.plugins.cow.BranchNodeStore
 
getRoot() - Method in class org.apache.jackrabbit.oak.plugins.cow.COWNodeStore
 
getRoot() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
getRoot() - Method in class org.apache.jackrabbit.oak.plugins.document.MissingLastRevSeeker
 
getRoot() - Method in class org.apache.jackrabbit.oak.query.ExecutionContext
Used to create the actual query results from the indexed paths, needs to be a secured version of a tree to take into account ACLs
getRoot() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.AbstractLoginModule
Tries to obtain a Root object from the callback handler using a new RepositoryCallback and keeps the value as private field.
getRoot() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AbstractAccessControlManager
 
getRootBundlePath() - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundlingHandler
 
getRootDefinition() - Method in interface org.apache.jackrabbit.oak.plugins.nodetype.DefinitionProvider
 
getRootDefinition() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.ReadOnlyNodeTypeManager
 
getRootDocument(DocumentStore) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
Returns the root node document of the given document store.
getRootEditor(NodeState, NodeState, NodeBuilder, CommitInfo) - Method in class org.apache.jackrabbit.oak.plugins.atomic.AtomicCounterEditorProvider
 
getRootEditor(NodeState, NodeState, NodeBuilder, CommitInfo) - Method in class org.apache.jackrabbit.oak.plugins.index.IndexUpdateProvider
 
getRootEditor(NodeState, NodeState, NodeBuilder, CommitInfo) - Method in class org.apache.jackrabbit.oak.plugins.name.NamespaceEditorProvider
 
getRootEditor(NodeState, NodeState, NodeBuilder, CommitInfo) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.TypeEditorProvider
 
getRootIncludePaths() - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.ChangeSetFilterImpl
for testing only
getRootRevision() - Method in class org.apache.jackrabbit.oak.plugins.document.AbstractDocumentNodeState
 
getRootRevision() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState
Returns the root revision for this node state.
getRootRevision() - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.DelegatingDocumentNodeState
 
getRootRevisions(Iterable<String>) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.replica.ReplicaSetInfo
 
GetRootRevisionsCallable - Class in org.apache.jackrabbit.oak.plugins.document.mongo.replica
 
GetRootRevisionsCallable(Clock, String, NodeCollectionProvider) - Constructor for class org.apache.jackrabbit.oak.plugins.document.mongo.replica.GetRootRevisionsCallable
 
getRootValidator(NodeState, NodeState, CommitInfo) - Method in class org.apache.jackrabbit.oak.plugins.commit.ConflictValidatorProvider
 
getRootValidator(NodeState, NodeState, CommitInfo) - Method in class org.apache.jackrabbit.oak.plugins.itemsave.ItemSaveValidatorProvider
 
getRootValidator(NodeState, NodeState, CommitInfo) - Method in class org.apache.jackrabbit.oak.plugins.name.NameValidatorProvider
 
getRootValidator(NodeState, NodeState, CommitInfo) - Method in class org.apache.jackrabbit.oak.plugins.observation.ChangeCollectorProvider
 
getRootValidator(NodeState, NodeState, CommitInfo) - Method in class org.apache.jackrabbit.oak.security.authorization.accesscontrol.AccessControlValidatorProvider
 
getRootValidator(NodeState, NodeState, CommitInfo) - Method in class org.apache.jackrabbit.oak.security.authorization.permission.PermissionStoreValidatorProvider
 
getRootValidator(NodeState, NodeState, CommitInfo) - Method in class org.apache.jackrabbit.oak.security.authorization.permission.PermissionValidatorProvider
 
getRows() - Method in interface org.apache.jackrabbit.oak.query.Query
 
getRows() - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
getRows() - Method in class org.apache.jackrabbit.oak.query.ResultImpl
 
getRows() - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
getRWConnection() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBConnectionHandler
Obtain a Connection suitable for read-write operations.
getScanCount() - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
 
getSchema(Connection) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBConnectionHandler
Return current schema name or null when unavailable
getSearchRoot(AuthorizableType, ConfigurationParameters) - Static method in class org.apache.jackrabbit.oak.security.user.query.QueryUtil
Determine the search root for the given authorizable type based on the configured root path.
getSecurityProvider() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.AbstractLoginModule
Tries to obtain the SecurityProvider object from the callback handler using a new SecurityProviderCallback and keeps the value as private field.
getSecurityProvider() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.callback.RepositoryCallback
 
getSecurityProvider() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.callback.SecurityProviderCallback
 
getSecurityProvider() - Method in class org.apache.jackrabbit.oak.spi.security.CompositeConfiguration
 
getSecurityProvider() - Method in class org.apache.jackrabbit.oak.spi.security.ConfigurationBase
 
getSelectedDocuments(DocumentStore, String, long, int) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
Returns an Iterable over all NodeDocuments in the given store matching a condition on an indexed property.
getSelectedDocuments(DocumentStore, String, long) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
getSelector() - Method in class org.apache.jackrabbit.oak.query.ast.ColumnImpl
 
getSelector(String) - Method in class org.apache.jackrabbit.oak.query.ast.JoinImpl
 
getSelector(String) - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
 
getSelector(String) - Method in class org.apache.jackrabbit.oak.query.ast.SourceImpl
Get the selector with the given name, or null if not found.
getSelector() - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
 
getSelector() - Method in class org.apache.jackrabbit.oak.query.plan.SelectorExecutionPlan
 
getSelectorConstraints() - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
 
getSelectorIndex(String) - Method in interface org.apache.jackrabbit.oak.query.Query
 
getSelectorIndex(String) - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
getSelectorIndex(String) - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
getSelectorName() - Method in class org.apache.jackrabbit.oak.query.ast.PropertyValueImpl
 
getSelectorName() - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
 
getSelectorNames() - Method in interface org.apache.jackrabbit.oak.query.Query
 
getSelectorNames() - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
getSelectorNames() - Method in class org.apache.jackrabbit.oak.query.ResultImpl
 
getSelectorNames() - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
getSelectors() - Method in class org.apache.jackrabbit.oak.query.ast.AndImpl
 
getSelectors() - Method in class org.apache.jackrabbit.oak.query.ast.ChildNodeImpl
 
getSelectors() - Method in class org.apache.jackrabbit.oak.query.ast.ComparisonImpl
 
getSelectors() - Method in class org.apache.jackrabbit.oak.query.ast.ConstraintImpl
Get the set of selectors for the given condition.
getSelectors() - Method in class org.apache.jackrabbit.oak.query.ast.DescendantNodeImpl
 
getSelectors() - Method in class org.apache.jackrabbit.oak.query.ast.DynamicOperandImpl
Get the set of selectors for this operand.
getSelectors() - Method in class org.apache.jackrabbit.oak.query.ast.FullTextSearchImpl
 
getSelectors() - Method in class org.apache.jackrabbit.oak.query.ast.FullTextSearchScoreImpl
 
getSelectors() - Method in class org.apache.jackrabbit.oak.query.ast.InImpl
 
getSelectors() - Method in class org.apache.jackrabbit.oak.query.ast.LengthImpl
 
getSelectors() - Method in class org.apache.jackrabbit.oak.query.ast.LowerCaseImpl
 
getSelectors() - Method in class org.apache.jackrabbit.oak.query.ast.NativeFunctionImpl
 
getSelectors() - Method in class org.apache.jackrabbit.oak.query.ast.NodeLocalNameImpl
 
getSelectors() - Method in class org.apache.jackrabbit.oak.query.ast.NodeNameImpl
 
getSelectors() - Method in class org.apache.jackrabbit.oak.query.ast.NotImpl
 
getSelectors() - Method in class org.apache.jackrabbit.oak.query.ast.OrImpl
 
getSelectors() - Method in class org.apache.jackrabbit.oak.query.ast.PropertyExistenceImpl
 
getSelectors() - Method in class org.apache.jackrabbit.oak.query.ast.PropertyInexistenceImpl
 
getSelectors() - Method in class org.apache.jackrabbit.oak.query.ast.PropertyValueImpl
 
getSelectors() - Method in class org.apache.jackrabbit.oak.query.ast.SameNodeImpl
 
getSelectors() - Method in class org.apache.jackrabbit.oak.query.ast.SimilarImpl
 
getSelectors() - Method in class org.apache.jackrabbit.oak.query.ast.SpellcheckImpl
 
getSelectors() - Method in class org.apache.jackrabbit.oak.query.ast.SuggestImpl
 
getSelectors() - Method in class org.apache.jackrabbit.oak.query.ast.UpperCaseImpl
 
getServerDetails() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoStatus
 
getSessionLocalMappings() - Method in class org.apache.jackrabbit.oak.namepath.GlobalNameMapper
 
getSessionLocalMappings() - Method in class org.apache.jackrabbit.oak.namepath.LocalNameMapper
 
getSessionLocalMappings() - Method in interface org.apache.jackrabbit.oak.namepath.NameMapper
Returns the local namespace prefix mappings, or an empty map if there aren't any local mappings.
getSessionLocalMappings() - Method in class org.apache.jackrabbit.oak.namepath.NamePathMapper.Default
 
getSessionLocalMappings() - Method in class org.apache.jackrabbit.oak.namepath.NamePathMapperImpl
 
getSettings() - Method in class org.apache.jackrabbit.oak.query.ExecutionContext
 
getSettings() - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
getSharedCredentials() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.AbstractLoginModule
 
getSharedLoginName() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.AbstractLoginModule
 
getSharedPreAuthLogin() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.AbstractLoginModule
 
getSize(Result.SizePrecision, long) - Method in class org.apache.jackrabbit.oak.plugins.index.Cursors.AbstractCursor
 
getSize(Result.SizePrecision, long) - Method in class org.apache.jackrabbit.oak.query.ast.JoinImpl
 
getSize(Result.SizePrecision, long) - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
 
getSize(Result.SizePrecision, long) - Method in class org.apache.jackrabbit.oak.query.ast.SourceImpl
Get the size if known.
getSize() - Method in interface org.apache.jackrabbit.oak.query.Query
Get the size if known.
getSize(Result.SizePrecision, long) - Method in interface org.apache.jackrabbit.oak.query.Query
Get the size if known.
getSize() - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
getSize(Result.SizePrecision, long) - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
getSize() - Method in class org.apache.jackrabbit.oak.query.ResultImpl
 
getSize(Result.SizePrecision, long) - Method in class org.apache.jackrabbit.oak.query.ResultImpl
 
getSize() - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
getSize(Result.SizePrecision, long) - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
getSizeInBytes() - Method in interface org.apache.jackrabbit.oak.plugins.index.IndexInfo
Index data storage size
getSkippedCount() - Method in class org.apache.jackrabbit.oak.plugins.index.TrackingCorruptIndexHandler.CorruptIndexInfo
 
getSlowQueries() - Method in interface org.apache.jackrabbit.oak.query.stats.QueryStatsMBean
Get the slow queries.
getSlowQueries() - Method in class org.apache.jackrabbit.oak.query.stats.QueryStatsMBeanImpl
 
getSortOrder() - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndexPlan
An aggregated query can not sort, as it gets results from a number of indexes.
getSource() - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
getSplitDocType() - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
Determines the type of split document
getStartTime() - Method in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfoDocument
 
getStatement() - Method in interface org.apache.jackrabbit.oak.query.Query
 
getStatement() - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
getStatement() - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
getStatementComponent() - Method in interface org.apache.jackrabbit.oak.plugins.document.rdb.RDBJDBCTools.PreparedStatementComponent
 
getStatisticsProvider() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
getStats() - Method in class org.apache.jackrabbit.oak.plugins.document.LocalDiffCache
 
getStats() - Method in class org.apache.jackrabbit.oak.plugins.document.MemoryDiffCache
 
getStats() - Method in class org.apache.jackrabbit.oak.plugins.index.TrackingCorruptIndexHandler.CorruptIndexInfo
 
getStats() - Method in class org.apache.jackrabbit.oak.plugins.metric.MetricStatisticsProvider
 
getStatsCollector() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
getStatsForAllIndexes(String, int, int, int) - Method in class org.apache.jackrabbit.oak.plugins.index.property.jmx.PropertyIndexStats
 
getStatsForAllIndexes(String, int, int, int) - Method in interface org.apache.jackrabbit.oak.plugins.index.property.jmx.PropertyIndexStatsMBean
 
getStatsForSpecificIndex(String, int, int, int) - Method in class org.apache.jackrabbit.oak.plugins.index.property.jmx.PropertyIndexStats
 
getStatsForSpecificIndex(String, int, int, int) - Method in interface org.apache.jackrabbit.oak.plugins.index.property.jmx.PropertyIndexStatsMBean
 
getStatsMBean() - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexInfo
IndexStatsMBean for current indexer.
getStatus() - Method in class org.apache.jackrabbit.oak.plugins.document.VersionGarbageCollector
 
getStatus() - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractTree
 
getStrategies(boolean, MountInfoProvider, NodeBuilder, String) - Static method in class org.apache.jackrabbit.oak.plugins.index.property.Multiplexers
 
getStrategies(boolean, MountInfoProvider, NodeState, String) - Static method in class org.apache.jackrabbit.oak.plugins.index.property.Multiplexers
 
getString(String) - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.DelegatingDocumentNodeState
 
getString(Tree, String) - Static method in class org.apache.jackrabbit.oak.plugins.tree.TreeUtil
 
getString(Tree, String, String) - Method in class org.apache.jackrabbit.oak.plugins.tree.TreeUtil
 
getString(long) - Static method in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
Returns the names of the specified permissions separated by ','.
getString() - Method in interface org.apache.jackrabbit.oak.spi.xml.TextValue
 
getStrings(String) - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.DelegatingDocumentNodeState
 
getStrings(NodeBuilder, String) - Static method in class org.apache.jackrabbit.oak.plugins.index.property.ValuePattern
 
getStrings(NodeState, String) - Static method in class org.apache.jackrabbit.oak.plugins.index.property.ValuePattern
 
getStrings(Tree, String) - Static method in class org.apache.jackrabbit.oak.plugins.tree.TreeUtil
 
getSubject() - Method in interface org.apache.jackrabbit.oak.spi.security.authentication.LoginContext
 
getSubject() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.PreAuthContext
 
getSubTrees() - Method in interface org.apache.jackrabbit.oak.plugins.observation.filter.FilterProvider
A set of paths whose subtrees include all events of this filter.
getSuperTypes() - Method in interface org.apache.jackrabbit.oak.query.ast.NodeTypeInfo
Get the set of supertypes.
getSupertypes() - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
 
getSupertypes() - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
 
getSupportedCredentials() - Method in class org.apache.jackrabbit.oak.security.authentication.token.TokenLoginModule
 
getSupportedCredentials() - Method in class org.apache.jackrabbit.oak.security.authentication.user.LoginModuleImpl
 
getSupportedCredentials() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.AbstractLoginModule
 
getSupportedLanguages() - Method in interface org.apache.jackrabbit.oak.query.QueryParser
Returns the set of query languages supported by this parser.
getSupportedPrivileges(String) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AbstractAccessControlManager
 
getSupportedQueryLanguages() - Method in class org.apache.jackrabbit.oak.query.QueryEngineImpl
 
getSupportedRestrictions(String) - Method in class org.apache.jackrabbit.oak.security.authorization.restriction.PrincipalRestrictionProvider
 
getSupportedRestrictions(String) - Method in class org.apache.jackrabbit.oak.security.authorization.restriction.WhiteboardRestrictionProvider
 
getSupportedRestrictions(String) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.restriction.AbstractRestrictionProvider
 
getSupportedRestrictions(String) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.restriction.CompositeRestrictionProvider
 
getSupportedRestrictions(String) - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.restriction.RestrictionProvider
Returns the restriction definitions supported by this provider implementation at the specified path.
getTable(Collection<T>) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
getTableCreationStatement(String, int) - Method in enum org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStoreDB
Table creation statement string
getTableNames() - Static method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
getTablePrefix() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBOptions
 
getTableUpgradeStatement(String, int) - Method in enum org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStoreDB
Statements needed to upgrade the DB
getTailRevision() - Method in class org.apache.jackrabbit.oak.plugins.document.JournalGarbageCollector
 
getTargetType(PropertyDefinition) - Method in class org.apache.jackrabbit.oak.spi.xml.PropInfo
 
getTempLaneName(String) - Static method in class org.apache.jackrabbit.oak.plugins.index.importer.AsyncLaneSwitcher
 
getText(String, Blob) - Method in class org.apache.jackrabbit.oak.plugins.index.datastore.DataStoreTextWriter
 
getText(String, Blob) - Method in interface org.apache.jackrabbit.oak.plugins.index.fulltext.PreExtractedTextProvider
Get pre extracted text for given blob at given path
getTextValue() - Method in class org.apache.jackrabbit.oak.spi.xml.PropInfo
 
getTextValues() - Method in class org.apache.jackrabbit.oak.spi.xml.PropInfo
 
getTime() - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate.AsyncUpdateCallback
 
getTimer(String, StatsOptions) - Method in class org.apache.jackrabbit.oak.plugins.metric.MetricStatisticsProvider
 
getTimestamp() - Method in class org.apache.jackrabbit.oak.plugins.document.Revision
Get the timestamp in milliseconds since 1970.
getTimestampDifference(Revision, Revision) - Static method in class org.apache.jackrabbit.oak.plugins.document.Revision
Get the timestamp difference between two revisions (r1 - r2) in milliseconds.
getTimeString(long) - Static method in class org.apache.jackrabbit.oak.query.stats.QueryStatsData
 
getTiming() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
getToken() - Method in interface org.apache.jackrabbit.oak.spi.security.authentication.token.TokenInfo
Returns the login token.
getTokenInfo(String) - Method in class org.apache.jackrabbit.oak.spi.security.authentication.token.CompositeTokenProvider
 
getTokenInfo(String) - Method in interface org.apache.jackrabbit.oak.spi.security.authentication.token.TokenProvider
Retrieves the TokenInfo associated with the specified login token or null.
getTokenProvider(Root) - Method in class org.apache.jackrabbit.oak.security.authentication.token.TokenConfigurationImpl
Returns a new instance of TokenProvider.
getTokenProvider() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.callback.TokenProviderCallback
Returns the token provider as set using TokenProviderCallback.setTokenProvider(TokenProvider) or null.
getTokenProvider(Root) - Method in class org.apache.jackrabbit.oak.spi.security.authentication.token.CompositeTokenConfiguration
 
getTokenProvider(Root) - Method in interface org.apache.jackrabbit.oak.spi.security.authentication.token.TokenConfiguration
Returns a new instance of TokenProvider.
getTotalLoadTime() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
getTotalRowsRead() - Method in class org.apache.jackrabbit.oak.query.stats.QueryStatsData
 
getTotalRowsScanned() - Method in class org.apache.jackrabbit.oak.query.stats.QueryStatsData
 
getTotalTimeNanos() - Method in class org.apache.jackrabbit.oak.query.stats.QueryStatsData
 
getTree(String) - Method in class org.apache.jackrabbit.oak.core.ImmutableRoot
 
getTree(String) - Method in class org.apache.jackrabbit.oak.plugins.identifier.IdentifierManager
The possibly non existing tree identified by the specified identifier or null.
getTree() - Method in class org.apache.jackrabbit.oak.plugins.tree.TreeLocation
Get the underlying Tree for this TreeLocation.
getTree(Tree, String) - Static method in class org.apache.jackrabbit.oak.plugins.tree.TreeUtil
Return the possibly non existing tree located at the passed path from the location of the start tree or null if path results in a parent of the root.
getTree(String) - Method in interface org.apache.jackrabbit.oak.query.Query
 
getTree(String) - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
getTree(String) - Method in class org.apache.jackrabbit.oak.query.ResultRowImpl
 
getTree(String) - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
getTree(String, long, boolean) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AbstractAccessControlManager
 
getTreePermission(Tree, TreePermission) - Method in class org.apache.jackrabbit.oak.security.authorization.permission.PermissionProviderImpl
 
getTreePermission(Tree, TreeType, TreePermission) - Method in class org.apache.jackrabbit.oak.security.authorization.permission.PermissionProviderImpl
 
getTreePermission(Tree, TreeType, TreePermission) - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.AggregatedPermissionProvider
Return the TreePermission for the set of Principals associated with this provider at the specified tree with the given type.
getTreePermission(Tree, TreePermission) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.permission.EmptyPermissionProvider
 
getTreePermission(Tree, TreePermission) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.permission.OpenPermissionProvider
 
getTreePermission(Tree, TreePermission) - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.PermissionProvider
Return the TreePermission for the set of Principals associated with this provider at the specified tree.
getType() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.BlobCache
 
getType() - Method in interface org.apache.jackrabbit.oak.plugins.index.importer.IndexImporterProvider
Index type for this implementation
getType() - Method in interface org.apache.jackrabbit.oak.plugins.index.IndexInfo
Returns type of index definition like 'property' or 'lucene'
getType() - Method in interface org.apache.jackrabbit.oak.plugins.index.IndexInfoProvider
Index type for this implementation can provide information
getType() - Method in class org.apache.jackrabbit.oak.plugins.index.property.PropertyIndexInfoProvider
 
getType() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeDefDiff
Returns the type of modification as expressed by the following constants: NONE: no modification at all TRIVIAL: does not affect consistency of existing content MAJOR: does affect consistency of existing content
getType() - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.ImmutableTree
 
getType(Tree) - Method in class org.apache.jackrabbit.oak.plugins.tree.TreeTypeProvider
 
getType(Tree, TreeType) - Method in class org.apache.jackrabbit.oak.plugins.tree.TreeTypeProvider
 
getType(int) - Static method in enum org.apache.jackrabbit.oak.spi.security.user.AuthorizableType
 
getType(Tree) - Static method in class org.apache.jackrabbit.oak.spi.security.user.util.UserUtil
 
getType(String) - Static method in class org.apache.jackrabbit.oak.spi.security.user.util.UserUtil
 
getType() - Method in class org.apache.jackrabbit.oak.spi.xml.PropInfo
 
getTypes() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.ReadOnlyNodeTypeManager
 
getUnmergedBranchCount() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreMBean
 
getUpdatedIndexPaths() - Method in class org.apache.jackrabbit.oak.plugins.index.IndexUpdate
 
getUpdatedIndexPaths() - Method in class org.apache.jackrabbit.oak.plugins.index.progress.IndexingProgressReporter
Set of indexPaths which have been updated or accessed in this indexing cycle.
getUpdateLimit() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
getUpdateNodesFailureHistory() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentStoreStats
 
getUpdateNodesFailureHistory() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStoreStatsMBean
 
getUpdateNodesHistory() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentStoreStats
 
getUpdateNodesHistory() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStoreStatsMBean
 
getUpdateNodesRetryHistory() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentStoreStats
 
getUpdateNodesRetryHistory() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStoreStatsMBean
 
getUpgradeToSchema() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBOptions
 
getURI(String) - Method in class org.apache.jackrabbit.oak.plugins.name.ReadOnlyNamespaceRegistry
 
getURIs() - Method in class org.apache.jackrabbit.oak.plugins.name.ReadOnlyNamespaceRegistry
 
getUsedSpaceHistory() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
getUserId() - Method in interface org.apache.jackrabbit.oak.spi.security.authentication.Authentication
Optional method that return the userID extracted upon Authentication.authenticate(Credentials).
getUserID() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.AuthInfoImpl
 
getUserId(Credentials) - Method in interface org.apache.jackrabbit.oak.spi.security.authentication.credentials.CredentialsSupport
Retrieves the user identifier from the specified Credentials.
getUserId(Credentials) - Method in class org.apache.jackrabbit.oak.spi.security.authentication.credentials.SimpleCredentialsSupport
 
getUserId() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.PreAuthenticatedLogin
 
getUserId() - Method in interface org.apache.jackrabbit.oak.spi.security.authentication.token.TokenInfo
Returns the ID of the user associated with this token info object.
getUserId() - Method in class org.apache.jackrabbit.oak.spi.security.user.UserIdCredentials
 
getUserManager(Root, NamePathMapper) - Method in class org.apache.jackrabbit.oak.security.user.UserConfigurationImpl
 
getUserManager() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.AbstractLoginModule
Retrieves the UserManager that should be used to handle this authentication.
getUserManager() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.callback.UserManagerCallback
getUserManager(Root, NamePathMapper) - Method in interface org.apache.jackrabbit.oak.spi.security.user.UserConfiguration
Create a new UserManager instance
getUserPrincipal() - Method in interface org.apache.jackrabbit.oak.spi.security.authentication.Authentication
Optional method that return the Principal of the authenticating user extracted upon Authentication.authenticate(Credentials).
getUserPrincipalProvider(Root, NamePathMapper) - Method in class org.apache.jackrabbit.oak.security.user.UserConfigurationImpl
 
getUserPrincipalProvider(Root, NamePathMapper) - Method in interface org.apache.jackrabbit.oak.spi.security.user.UserConfiguration
Optional method that allows a given user management implementation to provide a specific and optimized implementation of the PrincipalProvider interface for the principals represented by the user/groups known to this implementation.
getUUID() - Method in class org.apache.jackrabbit.oak.spi.xml.NodeInfo
Returns the uuid of the node being imported.
getValidators(String, Set<Principal>, MoveTracker) - Method in class org.apache.jackrabbit.oak.security.authentication.token.TokenConfigurationImpl
 
getValidators(String, Set<Principal>, MoveTracker) - Method in class org.apache.jackrabbit.oak.security.authorization.AuthorizationConfigurationImpl
 
getValidators(String, Set<Principal>, MoveTracker) - Method in class org.apache.jackrabbit.oak.security.privilege.PrivilegeConfigurationImpl
 
getValidators(String, Set<Principal>, MoveTracker) - Method in class org.apache.jackrabbit.oak.security.user.UserConfigurationImpl
 
getValidators(String, Set<Principal>, MoveTracker) - Method in class org.apache.jackrabbit.oak.spi.security.CompositeConfiguration
 
getValidators(String, Set<Principal>, MoveTracker) - Method in class org.apache.jackrabbit.oak.spi.security.SecurityConfiguration.Default
 
getValidators(String, Set<Principal>, MoveTracker) - Method in interface org.apache.jackrabbit.oak.spi.security.SecurityConfiguration
Returns the list of validators that need to be executed for the specified workspace name.
getValue() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.replica.Timestamped
 
getValue(String) - Static method in enum org.apache.jackrabbit.oak.plugins.document.rdb.RDBBlobStoreDB
 
getValue() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore.QueryCondition
 
getValue(String) - Static method in enum org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStoreDB
 
getValue(Value) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.BinaryConstraint
 
getValue(Value) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.DateConstraint
 
getValue(Value) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.DecimalConstraint
 
getValue(Value) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.DoubleConstraint
 
getValue(Value) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.LongConstraint
 
getValue(Value) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.NumericConstraint
 
getValue(String) - Method in class org.apache.jackrabbit.oak.query.index.IndexRowImpl
 
getValue(String) - Method in class org.apache.jackrabbit.oak.query.ResultRowImpl
 
getValue(int) - Method in class org.apache.jackrabbit.oak.spi.xml.PropInfo
 
getValue(int) - Method in interface org.apache.jackrabbit.oak.spi.xml.TextValue
 
getValueFactory() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.ReadOnlyNodeTypeManager
The value factory to be used by PropertyDefinitionImpl.getDefaultValues().
getValueMap(String) - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
Gets the value map for the given key.
getValues() - Method in class org.apache.jackrabbit.oak.query.ResultRowImpl
 
getValues(int) - Method in class org.apache.jackrabbit.oak.spi.xml.PropInfo
 
getVersion() - Static method in class org.apache.jackrabbit.oak.OakVersion
Returns the version of oak-core.
getVersion() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoStatus
 
getVersion(String) - Method in class org.apache.jackrabbit.oak.plugins.version.ReadOnlyVersionManager
Returns the version tree with the given uuid.
getVersionable(Tree, String) - Method in class org.apache.jackrabbit.oak.plugins.version.ReadOnlyVersionManager
Tries to retrieve the tree corresponding to specified versionTree outside of the version storage based on versionable path information stored with the version history.
getVersionGarbageCollector() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
getVersionHistory(Tree) - Method in class org.apache.jackrabbit.oak.plugins.version.ReadOnlyVersionManager
Returns the tree representing the version history of the given versionable tree or null if none exists yet.
getVersionHistoryPath(String) - Method in class org.apache.jackrabbit.oak.plugins.version.ReadOnlyVersionManager
Returns the path of the version history for the given uuid.
getVersionStorage() - Method in class org.apache.jackrabbit.oak.plugins.version.ReadOnlyVersionManager
 
getVersionStorage() - Method in class org.apache.jackrabbit.oak.plugins.version.ReadWriteVersionManager
 
getVisibilityToken() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
getWeigher() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
getWhiteboard() - Method in class org.apache.jackrabbit.oak.Oak
 
getWhiteboard() - Method in class org.apache.jackrabbit.oak.security.SecurityProviderImpl
 
getWhiteboard() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.AbstractLoginModule
Tries to obtain the Whiteboard object from the callback handler using a new WhiteboardCallback and keeps the value as private field.
getWhiteboard() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.callback.WhiteboardCallback
Returns the whiteboard as set using WhiteboardCallback.setWhiteboard(Whiteboard) or null.
getWildcardColumns() - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
 
getWorkspaceInitializer() - Method in class org.apache.jackrabbit.oak.security.authorization.AuthorizationConfigurationImpl
 
getWorkspaceInitializer() - Method in class org.apache.jackrabbit.oak.security.user.UserConfigurationImpl
 
getWorkspaceInitializer() - Method in class org.apache.jackrabbit.oak.spi.security.CompositeConfiguration
 
getWorkspaceInitializer() - Method in class org.apache.jackrabbit.oak.spi.security.SecurityConfiguration.Default
 
getWorkspaceInitializer() - Method in interface org.apache.jackrabbit.oak.spi.security.SecurityConfiguration
Returns a workspace initializer for this security configuration.
getWorkspaceName() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.callback.RepositoryCallback
 
getWorkspaceRoot() - Method in class org.apache.jackrabbit.oak.plugins.version.ReadOnlyVersionManager
/**
getWorkspaceRoot() - Method in class org.apache.jackrabbit.oak.plugins.version.ReadWriteVersionManager
 
getWriteConcern() - Method in class org.apache.jackrabbit.oak.plugins.document.memory.MemoryDocumentStore
 
getWriteRoot() - Method in class org.apache.jackrabbit.oak.plugins.name.ReadWriteNamespaceRegistry
Called by the write methods to acquire a fresh Root instance that can be used to persist the requested namespace changes (and nothing else).
getWriteRoot() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.write.ReadWriteNodeTypeManager
GlobalNameMapper - Class in org.apache.jackrabbit.oak.namepath
Name mapper with no local prefix remappings.
GlobalNameMapper(Root) - Constructor for class org.apache.jackrabbit.oak.namepath.GlobalNameMapper
 
GlobalNameMapper(NodeState) - Constructor for class org.apache.jackrabbit.oak.namepath.GlobalNameMapper
 
GlobalNameMapper(Map<String, String>) - Constructor for class org.apache.jackrabbit.oak.namepath.GlobalNameMapper
 
GlobbingPathFilter - Class in org.apache.jackrabbit.oak.plugins.observation.filter
This Filter implementation supports filtering on paths using simple glob patterns.
GlobbingPathFilter(String, Map<String, Pattern>) - Constructor for class org.apache.jackrabbit.oak.plugins.observation.filter.GlobbingPathFilter
 
GlobbingPathFilter(String) - Constructor for class org.apache.jackrabbit.oak.plugins.observation.filter.GlobbingPathFilter
for testing only - use variant which passes the patternMap for productive code
GlobbingPathHelper - Class in org.apache.jackrabbit.oak.plugins.observation.filter
 
GlobbingPathHelper() - Constructor for class org.apache.jackrabbit.oak.plugins.observation.filter.GlobbingPathHelper
 
globPathAsRegex(String) - Static method in class org.apache.jackrabbit.oak.plugins.observation.filter.GlobbingPathHelper
Converts the provided path containing glob characters * and ** into a regular expression.
gotRootRevisions(RevisionVector) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.replica.LocalChanges
 
gotRootRevisions(RevisionVector) - Method in interface org.apache.jackrabbit.oak.plugins.document.mongo.replica.ReplicaSetInfoListener
 
greater(T, T) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.NumericConstraint
 
greaterOrEqual(T, T) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.NumericConstraint
 
GROUP_PRIVILEGE_NAMES - Static variable in class org.apache.jackrabbit.oak.spi.security.user.action.AccessControlAction
 
GROUP_PROPERTY_NAMES - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
 
GroupAction - Interface in org.apache.jackrabbit.oak.spi.security.user.action
GuestLoginModule - Class in org.apache.jackrabbit.oak.spi.security.authentication
The GuestLoginModule is intended to provide backwards compatibility with the login handling present in the JCR reference implementation located in jackrabbit-core.
GuestLoginModule() - Constructor for class org.apache.jackrabbit.oak.spi.security.authentication.GuestLoginModule
 

H

handleClusterStateChange() - Method in interface org.apache.jackrabbit.oak.plugins.document.ClusterStateChangeListener
Informs the listener that DocumentNodeStore has discovered a change in the clusterNodes collection.
handleClusterStateChange() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentDiscoveryLiteService
 
handleLeaseFailure() - Method in interface org.apache.jackrabbit.oak.plugins.document.LeaseFailureHandler
Invoked by ClusterNodeInfo when it detects a lease failure and has started preventing any further access to the DocumentStore by throwing exceptions - what's now left is any further actions that should be taken such as eg stopping the oak-core bundle.
handlePropInfo(Tree, PropInfo, PropertyDefinition) - Method in interface org.apache.jackrabbit.oak.spi.xml.ProtectedPropertyImporter
Handles a single protected property.
HAS_BINARY_FLAG - Static variable in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
 
HAS_BINARY_VAL - Static variable in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
 
HAS_CHILD_PROP_PREFIX - Static variable in class org.apache.jackrabbit.oak.plugins.document.bundlor.DocumentBundlor
 
hasAllRevisionLessThan(long) - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
Checks if revision time of all entries in this document is less than the passed time
hasBeenModifiedSince(long) - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
Checks if this document has been modified after the given lastModifiedTime
hasBinary() - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
 
hasBinaryProperties() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBRow
 
hasChanges() - Method in class org.apache.jackrabbit.oak.plugins.document.UpdateOp
Checks if the UpdateOp has any change operation is registered with current update operation
hasChild(String) - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractTree
 
hasChildNode(String) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState
 
hasChildNode(String) - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.DelegatingDocumentNodeState
 
hasChildren() - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
Returns true if this node possibly has children.
hashCode() - Method in class org.apache.jackrabbit.oak.plugins.document.PathRev
 
hashCode() - Method in class org.apache.jackrabbit.oak.plugins.document.Revision
 
hashCode() - Method in class org.apache.jackrabbit.oak.plugins.document.RevisionVector
 
hashCode() - Method in class org.apache.jackrabbit.oak.plugins.document.UpdateOp.Key
 
hashCode() - Method in class org.apache.jackrabbit.oak.plugins.document.util.RevisionsKey
 
hashCode() - Method in class org.apache.jackrabbit.oak.plugins.document.util.StringValue
 
hashCode() - Method in class org.apache.jackrabbit.oak.plugins.document.util.TimeInterval
 
hashCode() - Method in class org.apache.jackrabbit.oak.plugins.observation.ChangeSet
 
hashCode() - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.ImmutableTree
 
hashCode() - Method in class org.apache.jackrabbit.oak.query.ast.AndImpl
 
hashCode() - Method in class org.apache.jackrabbit.oak.query.ast.BindVariableValueImpl
 
hashCode() - Method in class org.apache.jackrabbit.oak.query.ast.ConstraintImpl
 
hashCode() - Method in class org.apache.jackrabbit.oak.query.ast.DynamicOperandImpl
 
hashCode() - Method in class org.apache.jackrabbit.oak.query.ast.InImpl
 
hashCode() - Method in class org.apache.jackrabbit.oak.query.ast.LiteralImpl
 
hashCode() - Method in class org.apache.jackrabbit.oak.query.ast.OrImpl
 
hashCode() - Method in class org.apache.jackrabbit.oak.query.ast.PropertyExistenceImpl
 
hashCode() - Method in class org.apache.jackrabbit.oak.query.ast.PropertyInexistenceImpl
 
hashCode() - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
 
hashCode() - Method in class org.apache.jackrabbit.oak.query.ResultRowImpl
 
hashCode() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.ACE
 
hashCode() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.ImmutableACL
 
hashCode() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.restriction.RestrictionDefinitionImpl
 
hashCode() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.restriction.RestrictionImpl
 
hashCode() - Method in class org.apache.jackrabbit.oak.spi.security.ConfigurationParameters.Milliseconds
 
hashCode() - Method in class org.apache.jackrabbit.oak.spi.security.principal.EveryonePrincipal
 
hashCode() - Method in class org.apache.jackrabbit.oak.spi.security.principal.PrincipalImpl
 
hashCode() - Method in class org.apache.jackrabbit.oak.spi.security.privilege.ImmutablePrivilegeDefinition
 
hashCode() - Method in class org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeBits
 
hasIndexDefinitionChangedWithoutReindexing() - Method in interface org.apache.jackrabbit.oak.plugins.index.IndexInfo
Determines if index definition has changed but no reindexing was done for that change.
hasMetaProps(NodeState) - Static method in class org.apache.jackrabbit.oak.plugins.document.secondary.DelegatingDocumentNodeState
 
hasNext() - Method in class org.apache.jackrabbit.oak.plugins.document.util.CloseableIterator
 
hasNext() - Method in class org.apache.jackrabbit.oak.plugins.document.util.MergeSortedIterators
 
hasNext() - Method in class org.apache.jackrabbit.oak.plugins.index.Cursors.PathCursor
 
hasNext() - Method in class org.apache.jackrabbit.oak.security.user.query.ResultIterator
 
hasNoChildren() - Method in class org.apache.jackrabbit.oak.plugins.document.AbstractDocumentNodeState
 
hasNoChildren() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState
 
hasNoChildren() - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.DelegatingDocumentNodeState
 
hasNodeType(String) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.ReadOnlyNodeTypeManager
 
hasOnlyBundledChildren() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState
 
hasOrderableChildren() - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractTree
 
hasPendingChanges() - Method in class org.apache.jackrabbit.oak.core.ImmutableRoot
 
hasPrincipal(String) - Method in class org.apache.jackrabbit.oak.spi.security.principal.PrincipalManagerImpl
 
hasPrivileges(Tree, String...) - Method in class org.apache.jackrabbit.oak.security.authorization.permission.PermissionProviderImpl
 
hasPrivileges(String, Privilege[]) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AbstractAccessControlManager
 
hasPrivileges(String, Set<Principal>, Privilege[]) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AbstractAccessControlManager
 
hasPrivileges(Tree, String...) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.permission.EmptyPermissionProvider
 
hasPrivileges(Tree, String...) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.permission.OpenPermissionProvider
 
hasPrivileges(Tree, String...) - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.PermissionProvider
Returns whether the principal set associated with this PrivilegeManager is granted the privileges identified by the specified privilege names for the given tree.
hasProperty(String) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState
 
hasProperty(String) - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.DelegatingDocumentNodeState
 
hasProperty(String) - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractTree
 
hasReadConcern(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.MongoConnection
Returns true if the given uri has a read concern set.
hasSufficientReadConcern(DB) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.MongoConnection
Returns true if the default read concern on the db is sufficient for Oak.
hasSufficientWriteConcern(DB) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.MongoConnection
Returns true if the default write concern on the db is sufficient for Oak.
hasWriteConcern(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.MongoConnection
Returns true if the given uri has a write concern set.

I

ID - Static variable in class org.apache.jackrabbit.oak.plugins.document.Document
The name of the field that contains the document id (the primary key / the key).
ID - Static variable in interface org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast.DynamicBroadcastConfig
The unique id of this client.
IdentifierManager - Class in org.apache.jackrabbit.oak.plugins.identifier
TODO document
IdentifierManager(Root) - Constructor for class org.apache.jackrabbit.oak.plugins.identifier.IdentifierManager
 
IdentifierTracker - Class in org.apache.jackrabbit.oak.plugins.identifier
Simple utility class for lazily tracking the current identifier during a tree traversal that recurses down a subtree.
IdentifierTracker(NodeState) - Constructor for class org.apache.jackrabbit.oak.plugins.identifier.IdentifierTracker
 
identifyGarbage(Set<NodeDocument.SplitDocType>, RevisionVector, long) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoVersionGCSupport
 
identifyGarbage(Set<NodeDocument.SplitDocType>, RevisionVector, long) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBVersionGCSupport
 
identifyGarbage(Set<NodeDocument.SplitDocType>, RevisionVector, long) - Method in class org.apache.jackrabbit.oak.plugins.document.VersionGCSupport
 
IDSIZE - Static variable in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBBlobStore
 
idsToBeDeleted - Variable in class org.apache.jackrabbit.oak.plugins.document.SplitDocumentCleanUp
 
IGNORE - Static variable in class org.apache.jackrabbit.oak.spi.xml.ImportBehavior
If a value cannot be set due to constraints enforced by the API implementation, the failure is logged as warning and the value is ignored.
ImmutableACL - Class in org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol
An implementation of the JackrabbitAccessControlList interface that only allows for reading.
ImmutableACL(String, List<? extends JackrabbitAccessControlEntry>, RestrictionProvider, NamePathMapper) - Constructor for class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.ImmutableACL
Construct a new UnmodifiableAccessControlList
ImmutablePrivilegeDefinition - Class in org.apache.jackrabbit.oak.spi.security.privilege
Default implementation of the PrivilegeDefinition interface.
ImmutablePrivilegeDefinition(String, boolean, Iterable<String>) - Constructor for class org.apache.jackrabbit.oak.spi.security.privilege.ImmutablePrivilegeDefinition
 
ImmutableRoot - Class in org.apache.jackrabbit.oak.core
Simple implementation of the Root interface that only supports simple read operations based on the NodeState (or ImmutableTree) passed to the constructor.
ImmutableRoot(NodeState) - Constructor for class org.apache.jackrabbit.oak.core.ImmutableRoot
 
ImmutableRoot(Root) - Constructor for class org.apache.jackrabbit.oak.core.ImmutableRoot
 
ImmutableRoot(ImmutableTree) - Constructor for class org.apache.jackrabbit.oak.core.ImmutableRoot
 
ImmutableTree - Class in org.apache.jackrabbit.oak.plugins.tree.impl
Immutable implementation of the Tree interface in order to provide the much feature rich API functionality for a given NodeState.
ImmutableTree(NodeState) - Constructor for class org.apache.jackrabbit.oak.plugins.tree.impl.ImmutableTree
 
ImmutableTree(ImmutableTree, String, NodeState) - Constructor for class org.apache.jackrabbit.oak.plugins.tree.impl.ImmutableTree
 
ImmutableTree(ImmutableTree.ParentProvider, String, NodeState) - Constructor for class org.apache.jackrabbit.oak.plugins.tree.impl.ImmutableTree
 
ImmutableTree.DefaultParentProvider - Class in org.apache.jackrabbit.oak.plugins.tree.impl
 
ImmutableTree.ParentProvider - Interface in org.apache.jackrabbit.oak.plugins.tree.impl
 
ImpersonationCredentials - Class in org.apache.jackrabbit.oak.spi.security.authentication
Implementation of the JCR Credentials interface used to distinguish a regular login request from Session.impersonate(javax.jcr.Credentials).
ImpersonationCredentials(Credentials, AuthInfo) - Constructor for class org.apache.jackrabbit.oak.spi.security.authentication.ImpersonationCredentials
 
ImportBehavior - Class in org.apache.jackrabbit.oak.spi.xml
Utility class defining specific, configurable import behavior.
Importer - Interface in org.apache.jackrabbit.oak.spi.xml
Content importer.
importIndex() - Method in class org.apache.jackrabbit.oak.plugins.index.importer.IndexImporter
 
importIndex(NodeState, NodeBuilder, File) - Method in interface org.apache.jackrabbit.oak.plugins.index.importer.IndexImporterProvider
Import the index data from given directory into the NodeBuilder created for the index at given path
importIndex(String) - Method in class org.apache.jackrabbit.oak.plugins.index.IndexerMBeanImpl
 
in(DynamicOperandImpl, ArrayList<StaticOperandImpl>) - Method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
 
IN_CLAUSE_BATCH_SIZE - Static variable in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoDocumentStore
 
include(String) - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundledTypesRegistry.BundledTypesRegistryBuilder.TypeBuilder
 
Include - Class in org.apache.jackrabbit.oak.plugins.document.bundlor
Include represents a single path pattern which captures the path which needs to be included in bundling.
Include(String) - Constructor for class org.apache.jackrabbit.oak.plugins.document.bundlor.Include
 
INCLUDE_ALL - Static variable in class org.apache.jackrabbit.oak.plugins.index.aggregate.SimpleNodeAggregator
 
INCLUDE_ALL - Static variable in class org.apache.jackrabbit.oak.plugins.observation.filter.ConstantFilter
 
includeAdd(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.ACFilter
 
includeAdd(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.ACFilter
 
includeAdd(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.AddSubtreeFilter
 
includeAdd(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.AddSubtreeFilter
 
includeAdd(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.ConstantFilter
 
includeAdd(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.ConstantFilter
 
includeAdd(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.DeleteSubtreeFilter
 
includeAdd(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.DeleteSubtreeFilter
 
includeAdd(PropertyState) - Method in interface org.apache.jackrabbit.oak.plugins.observation.filter.EventFilter
Include an added property
includeAdd(String, NodeState) - Method in interface org.apache.jackrabbit.oak.plugins.observation.filter.EventFilter
Include an added node
includeAdd(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.EventTypeFilter
 
includeAdd(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.EventTypeFilter
 
includeAdd(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.GlobbingPathFilter
 
includeAdd(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.GlobbingPathFilter
 
includeAdd(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.MoveFilter
 
includeAdd(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.MoveFilter
 
includeAdd(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.UniversalFilter
 
includeAdd(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.UniversalFilter
 
includeAdd(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.VisibleFilter
 
includeAdd(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.VisibleFilter
 
includeAll() - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder
A condition the always holds
includeAll() - Static method in class org.apache.jackrabbit.oak.plugins.observation.filter.Filters
 
includeChange(PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.ACFilter
 
includeChange(PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.AddSubtreeFilter
 
includeChange(PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.ConstantFilter
 
includeChange(PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.DeleteSubtreeFilter
 
includeChange(PropertyState, PropertyState) - Method in interface org.apache.jackrabbit.oak.plugins.observation.filter.EventFilter
Include a changed property
includeChange(PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.EventTypeFilter
 
includeChange(PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.GlobbingPathFilter
 
includeChange(PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.MoveFilter
 
includeChange(PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.UniversalFilter
 
includeChange(PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.VisibleFilter
 
includeClusterExternal(boolean) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder
Whether to include cluster external changes.
includeClusterLocal(boolean) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder
Whether to include cluster local changes.
includeCommit(String, CommitInfo) - Method in interface org.apache.jackrabbit.oak.plugins.observation.filter.FilterProvider
Filter whole commits.
includeDelete(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.ACFilter
 
includeDelete(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.ACFilter
 
includeDelete(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.AddSubtreeFilter
 
includeDelete(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.AddSubtreeFilter
 
includeDelete(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.ConstantFilter
 
includeDelete(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.ConstantFilter
 
includeDelete(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.DeleteSubtreeFilter
 
includeDelete(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.DeleteSubtreeFilter
 
includeDelete(PropertyState) - Method in interface org.apache.jackrabbit.oak.plugins.observation.filter.EventFilter
Include a deleted property
includeDelete(String, NodeState) - Method in interface org.apache.jackrabbit.oak.plugins.observation.filter.EventFilter
Include a deleted node
includeDelete(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.EventTypeFilter
 
includeDelete(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.EventTypeFilter
 
includeDelete(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.GlobbingPathFilter
 
includeDelete(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.GlobbingPathFilter
 
includeDelete(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.MoveFilter
 
includeDelete(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.MoveFilter
 
includeDelete(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.UniversalFilter
 
includeDelete(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.UniversalFilter
 
includeDelete(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.VisibleFilter
 
includeDelete(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.VisibleFilter
 
includeMove(String, String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.ACFilter
 
includeMove(String, String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.AddSubtreeFilter
 
includeMove(String, String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.ConstantFilter
 
includeMove(String, String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.DeleteSubtreeFilter
 
includeMove(String, String, NodeState) - Method in interface org.apache.jackrabbit.oak.plugins.observation.filter.EventFilter
Include a moved node
includeMove(String, String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.EventTypeFilter
 
includeMove(String, String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.GlobbingPathFilter
 
includeMove(String, String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.MoveFilter
 
includeMove(String, String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.UniversalFilter
 
includeMove(String, String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.VisibleFilter
 
includeReorder(String, String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.ACFilter
 
includeReorder(String, String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.AddSubtreeFilter
 
includeReorder(String, String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.ConstantFilter
 
includeReorder(String, String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.DeleteSubtreeFilter
 
includeReorder(String, String, NodeState) - Method in interface org.apache.jackrabbit.oak.plugins.observation.filter.EventFilter
Include a reordered node
includeReorder(String, String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.EventTypeFilter
 
includeReorder(String, String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.GlobbingPathFilter
 
includeReorder(String, String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.MoveFilter
 
includeReorder(String, String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.UniversalFilter
 
includeReorder(String, String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.VisibleFilter
 
includes(long, long) - Static method in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
 
includes(PrivilegeBits) - Method in class org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeBits
Returns true if all privileges defined by the specified otherBits are present in this instance.
includeSessionLocal(boolean) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder
Whether to include session local changes.
includesNodeData() - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndexPlan
Whether all base plan include node data.
includesNodeType(String) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.EffectiveNodeType
Determines whether this effective node type representation includes (either through inheritance or aggregation) the given node type.
includesNodeTypes(String[]) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.EffectiveNodeType
Determines whether this effective node type representation includes (either through inheritance or aggregation) all of the given node types.
increment(String, long) - Method in class org.apache.jackrabbit.oak.plugins.document.UpdateOp
Increment the value.
INDEX_CONTENT_NODE_NAME - Static variable in interface org.apache.jackrabbit.oak.plugins.index.IndexConstants
 
INDEX_DEFINITION_MANAGEMENT - Static variable in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
 
INDEX_DEFINITIONS_JSON - Static variable in class org.apache.jackrabbit.oak.plugins.index.importer.IndexDefinitionUpdater
Name of file which would be check for presence of index-definitions
INDEX_DEFINITIONS_NAME - Static variable in interface org.apache.jackrabbit.oak.plugins.index.IndexConstants
 
INDEX_DEFINITIONS_NODE_TYPE - Static variable in interface org.apache.jackrabbit.oak.plugins.index.IndexConstants
 
INDEX_METADATA_FILE_NAME - Static variable in class org.apache.jackrabbit.oak.plugins.index.importer.IndexerInfo
Name of meta file which stores the index related meta information in properties file format
INDEX_NAME_OPTION - Static variable in interface org.apache.jackrabbit.oak.plugins.index.IndexConstants
The index name hint (when using "option(index abc)", this is "abc")
INDEX_TAG_OPTION - Static variable in interface org.apache.jackrabbit.oak.plugins.index.IndexConstants
The index tag hint (when using "option(index tagged x, y)", this is IN("x", "y"))
INDEX_TAGS - Static variable in interface org.apache.jackrabbit.oak.plugins.index.IndexConstants
The tags property in the index definition.
IndexCommitCallback - Interface in org.apache.jackrabbit.oak.plugins.index
Implementations of this interface can be notified of progress of commit that would update the index.
IndexCommitCallback.IndexProgress - Enum in org.apache.jackrabbit.oak.plugins.index
 
IndexConstants - Interface in org.apache.jackrabbit.oak.plugins.index
TODO document
IndexDefinitionPrinter - Class in org.apache.jackrabbit.oak.plugins.index.inventory
 
IndexDefinitionPrinter() - Constructor for class org.apache.jackrabbit.oak.plugins.index.inventory.IndexDefinitionPrinter
 
IndexDefinitionPrinter(NodeStore, IndexPathService) - Constructor for class org.apache.jackrabbit.oak.plugins.index.inventory.IndexDefinitionPrinter
 
IndexDefinitionUpdater - Class in org.apache.jackrabbit.oak.plugins.index.importer
 
IndexDefinitionUpdater(File) - Constructor for class org.apache.jackrabbit.oak.plugins.index.importer.IndexDefinitionUpdater
 
IndexDefinitionUpdater(String) - Constructor for class org.apache.jackrabbit.oak.plugins.index.importer.IndexDefinitionUpdater
 
IndexEditor - Interface in org.apache.jackrabbit.oak.plugins.index
Represents the content of a QueryIndex as well as a mechanism for keeping this content up to date.
IndexEditorProvider - Interface in org.apache.jackrabbit.oak.plugins.index
Extension point for plugging in different kinds of IndexEditor providers.
INDEXER_META - Static variable in class org.apache.jackrabbit.oak.plugins.index.importer.IndexerInfo
File name stored in final index directory which contains meta information like checkpoint details.
IndexerInfo - Class in org.apache.jackrabbit.oak.plugins.index.importer
Represents the index data created by oak-run tooling on the file system.
IndexerInfo(File, String) - Constructor for class org.apache.jackrabbit.oak.plugins.index.importer.IndexerInfo
 
IndexerMBeanImpl - Class in org.apache.jackrabbit.oak.plugins.index
 
IndexerMBeanImpl() - Constructor for class org.apache.jackrabbit.oak.plugins.index.IndexerMBeanImpl
 
IndexImporter - Class in org.apache.jackrabbit.oak.plugins.index.importer
 
IndexImporter(NodeStore, File, IndexEditorProvider, AsyncIndexerLock) - Constructor for class org.apache.jackrabbit.oak.plugins.index.importer.IndexImporter
 
IndexImporterProvider - Interface in org.apache.jackrabbit.oak.plugins.index.importer
This class is responsible for importing the index data from the file system into the repository.
IndexInfo - Interface in org.apache.jackrabbit.oak.plugins.index
Captures information related to index
IndexInfoProvider - Interface in org.apache.jackrabbit.oak.plugins.index
Service to be provided by various index implementations.
IndexInfoService - Interface in org.apache.jackrabbit.oak.plugins.index
 
IndexInfoServiceImpl - Class in org.apache.jackrabbit.oak.plugins.index
 
IndexInfoServiceImpl() - Constructor for class org.apache.jackrabbit.oak.plugins.index.IndexInfoServiceImpl
 
IndexInfoServiceImpl(NodeStore, IndexPathService) - Constructor for class org.apache.jackrabbit.oak.plugins.index.IndexInfoServiceImpl
 
INDEXING_MODE_NRT - Static variable in interface org.apache.jackrabbit.oak.plugins.index.IndexConstants
 
INDEXING_MODE_SYNC - Static variable in interface org.apache.jackrabbit.oak.plugins.index.IndexConstants
 
IndexingContext - Interface in org.apache.jackrabbit.oak.plugins.index
 
IndexingProgressReporter - Class in org.apache.jackrabbit.oak.plugins.index.progress
 
IndexingProgressReporter(IndexUpdateCallback, NodeTraversalCallback) - Constructor for class org.apache.jackrabbit.oak.plugins.index.progress.IndexingProgressReporter
 
IndexMBeanRegistration - Class in org.apache.jackrabbit.oak.plugins.index
 
IndexMBeanRegistration(Whiteboard) - Constructor for class org.apache.jackrabbit.oak.plugins.index.IndexMBeanRegistration
 
indexName - Variable in class org.apache.jackrabbit.oak.query.QueryOptions
 
IndexPathService - Interface in org.apache.jackrabbit.oak.plugins.index
 
IndexPathServiceImpl - Class in org.apache.jackrabbit.oak.plugins.index
 
IndexPathServiceImpl() - Constructor for class org.apache.jackrabbit.oak.plugins.index.IndexPathServiceImpl
 
IndexPathServiceImpl(NodeStore) - Constructor for class org.apache.jackrabbit.oak.plugins.index.IndexPathServiceImpl
 
IndexPathServiceImpl(NodeStore, MountInfoProvider) - Constructor for class org.apache.jackrabbit.oak.plugins.index.IndexPathServiceImpl
 
IndexPrinter - Class in org.apache.jackrabbit.oak.plugins.index.inventory
 
IndexPrinter() - Constructor for class org.apache.jackrabbit.oak.plugins.index.inventory.IndexPrinter
 
IndexPrinter(IndexInfoService, AsyncIndexInfoService) - Constructor for class org.apache.jackrabbit.oak.plugins.index.inventory.IndexPrinter
 
IndexRowImpl - Class in org.apache.jackrabbit.oak.query.index
A simple index row implementation.
IndexRowImpl(String) - Constructor for class org.apache.jackrabbit.oak.query.index.IndexRowImpl
 
IndexStoreStrategy - Interface in org.apache.jackrabbit.oak.plugins.index.property.strategy
Strategy that defines how the index content will be actually stored under the index node
indexTag - Variable in class org.apache.jackrabbit.oak.query.QueryOptions
 
indexUpdate() - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate.AsyncUpdateCallback
 
IndexUpdate - Class in org.apache.jackrabbit.oak.plugins.index
 
IndexUpdate(IndexEditorProvider, String, NodeState, NodeBuilder, IndexUpdateCallback) - Constructor for class org.apache.jackrabbit.oak.plugins.index.IndexUpdate
 
IndexUpdate(IndexEditorProvider, String, NodeState, NodeBuilder, IndexUpdateCallback, CommitInfo) - Constructor for class org.apache.jackrabbit.oak.plugins.index.IndexUpdate
 
IndexUpdate(IndexEditorProvider, String, NodeState, NodeBuilder, IndexUpdateCallback, NodeTraversalCallback, CommitInfo, CorruptIndexHandler) - Constructor for class org.apache.jackrabbit.oak.plugins.index.IndexUpdate
 
indexUpdate() - Method in interface org.apache.jackrabbit.oak.plugins.index.IndexUpdateCallback
Invoked by the IndexEditor for every NodeState indexed it.
indexUpdate(String) - Method in class org.apache.jackrabbit.oak.plugins.index.progress.IndexingProgressReporter
Callback to indicate that index at give path has got an update
IndexUpdate.MissingIndexProviderStrategy - Class in org.apache.jackrabbit.oak.plugins.index
 
IndexUpdateCallback - Interface in org.apache.jackrabbit.oak.plugins.index
 
indexUpdateFailed(String, String, Exception) - Method in interface org.apache.jackrabbit.oak.plugins.index.CorruptIndexHandler
 
indexUpdateFailed(Exception) - Method in interface org.apache.jackrabbit.oak.plugins.index.IndexingContext
Invoked by IndexEditor to indicate that update of index has failed
indexUpdateFailed(String, String, Exception) - Method in class org.apache.jackrabbit.oak.plugins.index.TrackingCorruptIndexHandler
 
IndexUpdateProvider - Class in org.apache.jackrabbit.oak.plugins.index
 
IndexUpdateProvider(IndexEditorProvider, boolean) - Constructor for class org.apache.jackrabbit.oak.plugins.index.IndexUpdateProvider
 
IndexUpdateProvider(IndexEditorProvider) - Constructor for class org.apache.jackrabbit.oak.plugins.index.IndexUpdateProvider
 
IndexUpdateProvider(IndexEditorProvider, String, boolean) - Constructor for class org.apache.jackrabbit.oak.plugins.index.IndexUpdateProvider
 
IndexUtils - Class in org.apache.jackrabbit.oak.plugins.index
TODO document
InImpl - Class in org.apache.jackrabbit.oak.query.ast
A "in" comparison operation.
InImpl(DynamicOperandImpl, List<StaticOperandImpl>) - Constructor for class org.apache.jackrabbit.oak.query.ast.InImpl
 
init(String) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast.TCPBroadcaster
 
init - Variable in class org.apache.jackrabbit.oak.plugins.index.diffindex.BaseDiffCollector
 
init() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeDefDiff.ChildNodeDefDiff
 
init() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeDefDiff.PropDefDiff
 
init() - Method in interface org.apache.jackrabbit.oak.query.Query
Initialize the query.
init() - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
init() - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
init(Session, Root, NamePathMapper, boolean, int, ReferenceChangeTracker, SecurityProvider) - Method in class org.apache.jackrabbit.oak.security.authorization.accesscontrol.AccessControlImporter
 
init(SecurityProvider, ConfigurationParameters) - Method in class org.apache.jackrabbit.oak.spi.security.user.action.AbstractAuthorizableAction
Doesn't perform any action.
init(SecurityProvider, ConfigurationParameters) - Method in class org.apache.jackrabbit.oak.spi.security.user.action.AccessControlAction
 
init(SecurityProvider, ConfigurationParameters) - Method in interface org.apache.jackrabbit.oak.spi.security.user.action.AuthorizableAction
Initialize this action with the specified security provider and configuration.
init(SecurityProvider, ConfigurationParameters) - Method in class org.apache.jackrabbit.oak.spi.security.user.action.PasswordValidationAction
 
init(Session, Root, NamePathMapper, boolean, int, ReferenceChangeTracker, SecurityProvider) - Method in interface org.apache.jackrabbit.oak.spi.xml.ProtectedItemImporter
Initializes the importer.
INITIAL_CONTENT - Static variable in class org.apache.jackrabbit.oak.InitialContent
 
InitialContent - Class in org.apache.jackrabbit.oak
InitialContent implements a RepositoryInitializer the creates the initial JCR/Oak repository structure.
InitialContent() - Constructor for class org.apache.jackrabbit.oak.InitialContent
 
initialize(NodeBuilder) - Method in class org.apache.jackrabbit.oak.InitialContent
 
initialize(NodeStore, RepositoryInitializer, IndexEditorProvider) - Static method in class org.apache.jackrabbit.oak.OakInitializer
 
initialize(Iterable<WorkspaceInitializer>, NodeStore, String, IndexEditorProvider) - Static method in class org.apache.jackrabbit.oak.OakInitializer
 
initialize(Observable, Executor) - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundlingConfigHandler
 
initialize(NodeBuilder) - Method in enum org.apache.jackrabbit.oak.plugins.document.bundlor.BundlingConfigInitializer
 
initialize(Subject, CallbackHandler, Map<String, ?>, Map<String, ?>) - Method in class org.apache.jackrabbit.oak.spi.security.authentication.AbstractLoginModule
 
initialize(Subject, CallbackHandler, Map<String, ?>, Map<String, ?>) - Method in class org.apache.jackrabbit.oak.spi.security.authentication.GuestLoginModule
 
initialSchema(int) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBOptions
Control over initial DB schema
initLease() - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate.AsyncUpdateCallback
 
InMemoryBroadcaster - Class in org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast
A mechanism that broadcasts to all registered consumers.
InMemoryBroadcaster() - Constructor for class org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast.InMemoryBroadcaster
 
insert(Connection, RDBDocumentStore.RDBTableMetaData, List<T>) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStoreJDBC
 
INSTANCE - Static variable in class org.apache.jackrabbit.oak.plugins.document.NodeDocumentIdComparator
 
INSTANCE - Static variable in class org.apache.jackrabbit.oak.plugins.document.PathComparator
 
INSTANCE - Static variable in class org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast.InMemoryBroadcaster
 
INSTANCE - Static variable in class org.apache.jackrabbit.oak.plugins.document.StableRevisionComparator
 
INSTANCE - Static variable in class org.apache.jackrabbit.oak.plugins.observation.DefaultEventHandler
 
INSTANCE - Static variable in class org.apache.jackrabbit.oak.spi.security.authentication.SystemSubject
 
INSTANCE - Static variable in class org.apache.jackrabbit.oak.spi.security.principal.EmptyPrincipalProvider
 
INSTANCE - Static variable in class org.apache.jackrabbit.oak.spi.security.principal.SystemPrincipal
 
intermediateSplitDocumentsDeleted(long) - Method in interface org.apache.jackrabbit.oak.plugins.document.RevisionGCStatsCollector
 
invalidate(String) - Method in class org.apache.jackrabbit.oak.plugins.document.cache.NodeDocumentCache
Invalidate document with given key.
invalidateCache() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStore
Invalidate the document cache.
invalidateCache(Iterable<String>) - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStore
Invalidate the document cache but only with entries that match one of the keys provided.
invalidateCache(Collection<T>, String) - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStore
Invalidate the document cache for the given key.
invalidateCache() - Method in class org.apache.jackrabbit.oak.plugins.document.memory.MemoryDocumentStore
 
invalidateCache(Iterable<String>) - Method in class org.apache.jackrabbit.oak.plugins.document.memory.MemoryDocumentStore
 
invalidateCache(Collection<T>, String) - Method in class org.apache.jackrabbit.oak.plugins.document.memory.MemoryDocumentStore
 
invalidateCache() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoDocumentStore
 
invalidateCache(Iterable<String>) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoDocumentStore
 
invalidateCache(Collection<T>, String) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoDocumentStore
 
invalidateCache() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
invalidateCache(Iterable<String>) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
invalidateCache(Collection<T>, String) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
invalidateCache() - Method in class org.apache.jackrabbit.oak.plugins.document.util.LeaseCheckDocumentStoreWrapper
 
invalidateCache(Iterable<String>) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LeaseCheckDocumentStoreWrapper
 
invalidateCache(Collection<T>, String) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LeaseCheckDocumentStoreWrapper
 
invalidateCache() - Method in class org.apache.jackrabbit.oak.plugins.document.util.LoggingDocumentStoreWrapper
 
invalidateCache(Iterable<String>) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LoggingDocumentStoreWrapper
 
invalidateCache(Collection<T>, String) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LoggingDocumentStoreWrapper
 
invalidateCache() - Method in class org.apache.jackrabbit.oak.plugins.document.util.SynchronizingDocumentStoreWrapper
 
invalidateCache(Iterable<String>) - Method in class org.apache.jackrabbit.oak.plugins.document.util.SynchronizingDocumentStoreWrapper
 
invalidateCache(Collection<T>, String) - Method in class org.apache.jackrabbit.oak.plugins.document.util.SynchronizingDocumentStoreWrapper
 
invalidateCache() - Method in class org.apache.jackrabbit.oak.plugins.document.util.TimingDocumentStoreWrapper
 
invalidateCache(Iterable<String>) - Method in class org.apache.jackrabbit.oak.plugins.document.util.TimingDocumentStoreWrapper
 
invalidateCache(Collection<T>, String) - Method in class org.apache.jackrabbit.oak.plugins.document.util.TimingDocumentStoreWrapper
 
invalidateDocument(String) - Method in class org.apache.jackrabbit.oak.plugins.document.cache.CacheChangesTracker
 
invalidateOutdated(Map<String, ModificationStamp>) - Method in class org.apache.jackrabbit.oak.plugins.document.cache.NodeDocumentCache
Invalidate document with given keys iff their modification stamps are different as passed in the map.
isAbstract() - Method in class org.apache.jackrabbit.oak.spi.security.privilege.ImmutablePrivilegeDefinition
 
isAbstract() - Method in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeDefinition
Returns true if the privilege described by this definition is abstract.
isAccessible(String) - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
 
isActive() - Method in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfoDocument
 
isAdmin(ConfigurationParameters, String) - Static method in class org.apache.jackrabbit.oak.spi.security.user.util.UserUtil
 
isAdminOrSystem(Set<Principal>, ConfigurationParameters) - Static method in class org.apache.jackrabbit.oak.security.authorization.permission.PermissionUtil
 
isAggregate(long) - Static method in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
 
isAllNodeTypeOverflown() - Method in class org.apache.jackrabbit.oak.plugins.observation.ChangeSetBuilder
 
isAllow() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.ACE
 
isAlwaysFalse() - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
 
isAscending() - Method in enum org.apache.jackrabbit.oak.plugins.index.property.OrderedIndex.OrderDirection
 
isAscending(NodeState) - Static method in enum org.apache.jackrabbit.oak.plugins.index.property.OrderedIndex.OrderDirection
convenience method that tells if the provided index definition is ascending
isAsync() - Method in interface org.apache.jackrabbit.oak.plugins.index.IndexingContext
Flag indicating that indexed is being done asynchronously
isAsyncLaneName(String) - Static method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate
 
isAutoSave() - Method in class org.apache.jackrabbit.oak.security.user.autosave.AutoSaveEnabledManager
 
isAutoSave() - Method in class org.apache.jackrabbit.oak.security.user.UserManagerImpl
Always returns false.
isBeingRecovered() - Method in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfoDocument
 
isBeingRecoveredBy(int) - Method in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfoDocument
Returns true if the cluster node represented by this document is currently being recovered by the given clusterId.
isBranch() - Method in class org.apache.jackrabbit.oak.plugins.document.Revision
 
isBranch() - Method in class org.apache.jackrabbit.oak.plugins.document.RevisionVector
 
isBundled(String) - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.DocumentBundlor
 
isBundledNode() - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundlingHandler
Returns true if and only if current node is bundled in another node
isBundlingDisabled() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
isBundlingRoot() - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundlingHandler
 
isCached(String) - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentNodeStateCache
Determines if given path is cached by this implementation
isCached(String) - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.SecondaryStoreCache
 
isCheckedOut(Tree) - Method in class org.apache.jackrabbit.oak.plugins.version.ReadOnlyVersionManager
Returns true if the tree is checked out; otherwise false.
isClosed() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBConnectionHandler
 
isClosed() - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate
 
isCommitRootEntry(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
 
isCommitted(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
Returns true if a revision tagged with the given revision should be considered committed, false otherwise.
isDefaultNoBranchSplitNewerThan(NodeDocument, RevisionVector) - Static method in class org.apache.jackrabbit.oak.plugins.document.VersionGCSupport
Returns true if the given document is of type NodeDocument.SplitDocType.DEFAULT_NO_BRANCH and the most recent change on the document is newer than the sweepRevs.
isDelayed() - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndexPlan
Whether any base plan is delayed.
isDeletedEntry(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
 
isDescending(NodeState) - Static method in enum org.apache.jackrabbit.oak.plugins.index.property.OrderedIndex.OrderDirection
convenience method that tells if the provided index definition is descending
isDescending() - Method in enum org.apache.jackrabbit.oak.plugins.index.property.OrderedIndex.OrderDirection
 
isDescending() - Method in class org.apache.jackrabbit.oak.query.ast.OrderingImpl
 
isDisableBranches() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
isDisableBranches() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
isDistinct() - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
 
isDone() - Method in class org.apache.jackrabbit.oak.plugins.observation.EventGenerator
Checks whether there are no more content changes to be processed.
isDropTablesOnClose() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBOptions
 
isEmpty() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.MultiGenerationMap
 
isEmpty() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AbstractAccessControlList
 
isEmpty() - Method in class org.apache.jackrabbit.oak.spi.security.ConfigurationParameters
isEmpty() - Method in class org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeBits
Returns true if this privilege bits includes no privileges at all.
isEnabled() - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundlingConfigHandler
 
isExpandedName(String) - Static method in class org.apache.jackrabbit.oak.namepath.GlobalNameMapper
 
isExpired(long) - Method in interface org.apache.jackrabbit.oak.spi.security.authentication.token.TokenInfo
Returns true if the token has already expired; false otherwise.
isFailing() - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate
 
isFailing(String) - Method in class org.apache.jackrabbit.oak.plugins.index.TrackingCorruptIndexHandler
 
isFailingSinceLongTime() - Method in class org.apache.jackrabbit.oak.plugins.index.TrackingCorruptIndexHandler.CorruptIndexInfo
 
isFastQuerySize() - Method in class org.apache.jackrabbit.oak.query.QueryEngineSettings
 
isFinished() - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate
 
isFromExternalChange() - Method in class org.apache.jackrabbit.oak.plugins.document.AbstractDocumentNodeState
 
isFromExternalChange() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState
 
isFromExternalChange() - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.DelegatingDocumentNodeState
 
isFulltextIndex() - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndexPlan
Whether any base plan is a full text index.
isGranted(Tree, PropertyState, long) - Method in class org.apache.jackrabbit.oak.security.authorization.permission.PermissionProviderImpl
 
isGranted(String, String) - Method in class org.apache.jackrabbit.oak.security.authorization.permission.PermissionProviderImpl
 
isGranted(TreeLocation, long) - Method in class org.apache.jackrabbit.oak.security.authorization.permission.PermissionProviderImpl
 
isGranted(TreeLocation, long) - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.AggregatedPermissionProvider
Test if the specified permissions are granted for the set of Principals associated with this provider instance for the item identified by the given location and optionally property.
isGranted(Tree, PropertyState, long) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.permission.EmptyPermissionProvider
 
isGranted(String, String) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.permission.EmptyPermissionProvider
 
isGranted(Tree, PropertyState, long) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.permission.OpenPermissionProvider
 
isGranted(String, String) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.permission.OpenPermissionProvider
 
isGranted(Tree, PropertyState, long) - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.PermissionProvider
Test if the specified permissions are granted for the set of Principals associated with this provider instance for the item identified by the given tree and optionally property.
isGranted(String, String) - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.PermissionProvider
Tests if the the specified actions are granted at the given path for the set of Principals associated with this provider instance.
isGranted(long) - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.RepositoryPermission
Returns true if the specified repository level permissions are granted; false otherwise.
isGranted(long) - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.TreePermission
Returns true if all specified permissions are granted on the Tree associated with this TreePermission instance; false otherwise.
isGranted(long, PropertyState) - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.TreePermission
Returns true if all specified permissions are granted on the PropertyState associated with this TreePermission instance; false otherwise.
isGreaterOrEquals(RevisionVector, RevisionVector) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
Returns true if all the revisions in the a greater or equals to their counterparts in b.
isHidden(String) - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractTree
Determine whether an item should be hidden.
isHidden(String) - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.ImmutableTree
 
isHiddenName(String) - Static method in class org.apache.jackrabbit.oak.namepath.GlobalNameMapper
 
isHiddenPath(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
 
isIdFromLongPath(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
 
isIncludeClusterExternal() - Method in interface org.apache.jackrabbit.oak.plugins.observation.filter.FilterConfigMBean
Whether to include cluster external changes.
isIncludeClusterLocal() - Method in interface org.apache.jackrabbit.oak.plugins.observation.filter.FilterConfigMBean
Whether to include cluster local changes.
isIndexed(String, String, Filter) - Method in class org.apache.jackrabbit.oak.plugins.index.property.PropertyIndexLookup
Checks whether the named property is indexed somewhere along the given path.
isIndexNodeType(NodeState) - Static method in class org.apache.jackrabbit.oak.plugins.index.IndexUtils
 
isIndexNodeType(NodeState, String) - Static method in class org.apache.jackrabbit.oak.plugins.index.IndexUtils
 
isInit() - Method in interface org.apache.jackrabbit.oak.query.Query
 
isInit() - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
isInit() - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
isInternal() - Method in interface org.apache.jackrabbit.oak.query.Query
 
isInternal() - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
isInternal(String) - Static method in class org.apache.jackrabbit.oak.query.SQL2Parser
Whether the given statement is an internal query.
isInternal() - Method in class org.apache.jackrabbit.oak.query.stats.QueryStatsData
 
isInternal() - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
isLastRevEntry(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
 
isLeafPreviousDocId(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
Determines if the passed id belongs to a leaf level previous doc
isLocked(String) - Method in class org.apache.jackrabbit.oak.plugins.index.importer.ClusterNodeStoreLock
 
isLongPath(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
 
isMajor() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeDefDiff
 
isMajorityReadConcernEnabled() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoStatus
Check if the majority read concern is enabled and can be used for queries.
isMajorityReadConcernSupported() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoStatus
Check if the majority read concern is supported by this storage engine.
isMajorityWriteConcern(DB) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.MongoConnection
Returns true if the majority write concern is used for the given DB.
isMandatory() - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.restriction.RestrictionDefinition
Indicates if this restriction is mandatory.
isMandatory() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.restriction.RestrictionDefinitionImpl
 
isMarkedAsCorrupt() - Method in class org.apache.jackrabbit.oak.plugins.index.TrackingCorruptIndexHandler.CorruptIndexInfo
 
isMarkEnabled() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoBlobStore
 
isMarkEnabled() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBBlobStore
 
isMatch() - Method in interface org.apache.jackrabbit.oak.plugins.document.bundlor.Matcher
Returns true if there was a match wrt current child node path
isMeasureOrExplainEnabled() - Method in interface org.apache.jackrabbit.oak.query.Query
 
isMeasureOrExplainEnabled() - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
isMeasureOrExplainEnabled() - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
isMember(Principal) - Method in class org.apache.jackrabbit.oak.spi.security.principal.EveryonePrincipal
 
isMixin() - Method in interface org.apache.jackrabbit.oak.query.ast.NodeTypeInfo
Check whether this is a mixin.
isModified() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeDefDiff
 
isMoreRecentThan(RevisionVector) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.replica.ReplicaSetInfo
 
isMultiValueRestriction(String) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AbstractAccessControlList
 
isNew() - Method in class org.apache.jackrabbit.oak.plugins.document.UpdateOp
 
isNodeType(Tree, String) - Method in interface org.apache.jackrabbit.oak.plugins.nodetype.EffectiveNodeTypeProvider
Returns true if this tree is of the specified primary node type or mixin type, or a subtype thereof respecting the effective node type of the tree.
isNodeType(String, Iterator<String>, String) - Method in interface org.apache.jackrabbit.oak.plugins.nodetype.EffectiveNodeTypeProvider
Returns true if typeName is of the specified primary node type or mixin type, or a subtype thereof.
isNodeType(String, String) - Method in interface org.apache.jackrabbit.oak.plugins.nodetype.EffectiveNodeTypeProvider
Returns true if typeName is of the specified primary node type or mixin type, or a subtype thereof.
isNodeType(Tree, String) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.ReadOnlyNodeTypeManager
 
isNodeType(String, Iterator<String>, String) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.ReadOnlyNodeTypeManager
 
isNodeType(String, String) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.ReadOnlyNodeTypeManager
 
isNodeType(Tree, String, Tree) - Static method in class org.apache.jackrabbit.oak.plugins.tree.TreeUtil
 
isNone(PropertyState) - Static method in class org.apache.jackrabbit.oak.plugins.index.importer.AsyncLaneSwitcher
 
isolationLevelToString(int) - Static method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBJDBCTools
Return string representation of transaction isolation level.
isOrderable(NodeState) - Static method in class org.apache.jackrabbit.oak.plugins.nodetype.TypePredicate
 
isOuterJoinRightHandSide() - Method in class org.apache.jackrabbit.oak.query.ast.JoinImpl
 
isOuterJoinRightHandSide() - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
 
isOuterJoinRightHandSide() - Method in class org.apache.jackrabbit.oak.query.ast.SourceImpl
Whether any selector is the outer-join right hand side.
isParent(SourceImpl) - Method in class org.apache.jackrabbit.oak.query.ast.ChildNodeJoinConditionImpl
 
isParent(SourceImpl) - Method in class org.apache.jackrabbit.oak.query.ast.DescendantNodeJoinConditionImpl
 
isParent(SourceImpl) - Method in class org.apache.jackrabbit.oak.query.ast.EquiJoinConditionImpl
 
isParent(SourceImpl) - Method in class org.apache.jackrabbit.oak.query.ast.JoinConditionImpl
Check whether the given source is the parent of the join condition, as selector "[b]" is the parent of the join condition "isdescendantnode([a], [b])".
isParent(SourceImpl) - Method in class org.apache.jackrabbit.oak.query.ast.SameNodeJoinConditionImpl
 
isParentNodeNameOverflown() - Method in class org.apache.jackrabbit.oak.plugins.observation.ChangeSetBuilder
 
isParentNodeTypeOverflown() - Method in class org.apache.jackrabbit.oak.plugins.observation.ChangeSetBuilder
 
isParentPathOverflown() - Method in class org.apache.jackrabbit.oak.plugins.observation.ChangeSetBuilder
 
isPartialObject() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.RevisionEntry
 
isPlainTextPassword(String) - Static method in class org.apache.jackrabbit.oak.spi.security.user.util.PasswordUtil
Returns true if the specified string doesn't start with a valid algorithm name in curly brackets.
isPotentiallySlow(Filter, NodeState) - Method in class org.apache.jackrabbit.oak.query.index.TraversingIndex
 
isPotentiallySlow() - Method in interface org.apache.jackrabbit.oak.query.Query
Whether the query is potentially slow.
isPotentiallySlow() - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
isPotentiallySlow() - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
isPrefetchExternalChanges() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
isPrepared() - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
 
isPrepared(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
Whether the given selector is already prepared during the prepare phase of a join.
isPreparing() - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
 
isPreviousDocId(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
Determines if the passed id belongs to a previous doc
isProcessed(String) - Method in class org.apache.jackrabbit.oak.plugins.index.datastore.DataStoreTextWriter
 
isPropertyName(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
 
isPropertyNameOverflown() - Method in class org.apache.jackrabbit.oak.plugins.observation.ChangeSetBuilder
 
isReadOnlyTree(Tree) - Static method in class org.apache.jackrabbit.oak.plugins.tree.TreeUtil
Returns true if the specified tree is a read-only tree such as obtained through TreeFactory or a read-only Root.
isRecoveryNeeded() - Method in class org.apache.jackrabbit.oak.plugins.document.LastRevRecoveryAgent
Determines if any of the cluster node failed to renew its lease and did not properly shutdown.
isRecoveryNeeded() - Method in class org.apache.jackrabbit.oak.plugins.document.MissingLastRevSeeker
 
isRecoveryNeeded(ClusterNodeInfoDocument) - Method in class org.apache.jackrabbit.oak.plugins.document.MissingLastRevSeeker
Check if _lastRev recovery needed for this cluster node state is Active and currentTime past the leaseEnd time
isRecoveryNeeded() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoMissingLastRevSeeker
 
isReindexing() - Method in interface org.apache.jackrabbit.oak.plugins.index.IndexingContext
Flag indicating that index is being reindex
isReindexingPerformed() - Method in class org.apache.jackrabbit.oak.plugins.index.IndexUpdate
 
isReindexingPerformed() - Method in class org.apache.jackrabbit.oak.plugins.index.progress.IndexingProgressReporter
Returns true if any reindexing is performed in current indexing cycle
isRepositoryPermission(long) - Static method in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
 
isRevisionNewer(Revision) - Method in class org.apache.jackrabbit.oak.plugins.document.RevisionVector
Returns true if the given revision is newer than the revision element with the same clusterId in the vector.
isRevisionsEntry(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
 
isRoot() - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractTree
 
isRoot() - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.ImmutableTree
 
isRunning() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast.TCPBroadcaster
 
isRunning() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast.UDPBroadcaster
 
isRunning() - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexInfo
Returns true if the async indexer is currently active
isSame(String, char[]) - Static method in class org.apache.jackrabbit.oak.spi.security.user.util.PasswordUtil
Returns true if hash of the specified password equals the given hashed password.
isSame(String, String) - Static method in class org.apache.jackrabbit.oak.spi.security.user.util.PasswordUtil
Returns true if hash of the specified password equals the given hashed password.
isSealed() - Method in class org.apache.jackrabbit.oak.plugins.document.Document
Determines if this document is sealed or not
isSortedByIndex() - Method in interface org.apache.jackrabbit.oak.query.Query
Returns whether the results will be sorted by index.
isSortedByIndex() - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
isSortedByIndex() - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
isSplitDocument() - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
Determines if this document is a split document
isSql2Optimisation() - Method in class org.apache.jackrabbit.oak.query.QueryEngineSettings
 
isSystemUser(Tree) - Static method in class org.apache.jackrabbit.oak.spi.security.user.util.UserUtil
 
isThreadBlocking() - Method in class org.apache.jackrabbit.oak.plugins.observation.CommitRateLimiter
Check whether the current thread is non-blocking.
isTimedOut(long) - Static method in class org.apache.jackrabbit.oak.plugins.atomic.AtomicCounterEditor.ConsolidatorTask
 
isTrivial() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeDefDiff
 
isType(Authorizable) - Method in enum org.apache.jackrabbit.oak.spi.security.user.AuthorizableType
 
isType(Tree, AuthorizableType) - Static method in class org.apache.jackrabbit.oak.spi.security.user.util.UserUtil
 
isUnique() - Method in class org.apache.jackrabbit.oak.plugins.index.diffindex.BaseDiffCollector
 
isUnique() - Method in class org.apache.jackrabbit.oak.plugins.index.diffindex.UUIDDiffCollector
 
isUnsupportedPath(String) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.restriction.AbstractRestrictionProvider
Returns true if the specified path is null.
isUseSimpleRevision() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
isValid(String) - Method in interface org.apache.jackrabbit.oak.plugins.index.IndexInfoProvider
Determined if the index is valid and usable.
isValid(String) - Method in interface org.apache.jackrabbit.oak.plugins.index.IndexInfoService
Determined if the index is valid and usable.
isValid(String) - Method in class org.apache.jackrabbit.oak.plugins.index.IndexInfoServiceImpl
 
isValid(String) - Method in class org.apache.jackrabbit.oak.plugins.index.property.PropertyIndexInfoProvider
 
isValidLocalName(String) - Static method in class org.apache.jackrabbit.oak.plugins.name.Namespaces
 
isValidPrefix(String) - Static method in class org.apache.jackrabbit.oak.plugins.name.Namespaces
 
isValidUUID(String) - Static method in class org.apache.jackrabbit.oak.plugins.identifier.IdentifierManager
 
isVersionable(Tree) - Method in class org.apache.jackrabbit.oak.plugins.version.ReadOnlyVersionManager
Returns true if the given tree is of type mix:versionable; false otherwise.
isVersionStoreTree(Tree) - Static method in class org.apache.jackrabbit.oak.plugins.version.ReadOnlyVersionManager
Returns true if the specified tree has VersionConstants.REP_VERSIONSTORAGE defines as primary node type i.e.
isVirtualRow() - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
 
isVirtualRow() - Method in class org.apache.jackrabbit.oak.query.index.IndexRowImpl
 
isVisible(String, long) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
ItemSaveValidatorProvider - Class in org.apache.jackrabbit.oak.plugins.itemsave
This validator checks that all changes are contained within the subtree rooted at a given path.
ItemSaveValidatorProvider() - Constructor for class org.apache.jackrabbit.oak.plugins.itemsave.ItemSaveValidatorProvider
 
iterator() - Method in class org.apache.jackrabbit.oak.plugins.document.RevisionVector
 
iterator() - Method in class org.apache.jackrabbit.oak.plugins.document.util.CloseableIterable
 

J

JaasLoginContext - Class in org.apache.jackrabbit.oak.spi.security.authentication
Bridge class that connects the JAAS LoginContext class with the LoginContext interface used by Oak.
JaasLoginContext(String) - Constructor for class org.apache.jackrabbit.oak.spi.security.authentication.JaasLoginContext
 
JaasLoginContext(String, Subject) - Constructor for class org.apache.jackrabbit.oak.spi.security.authentication.JaasLoginContext
 
JaasLoginContext(String, CallbackHandler) - Constructor for class org.apache.jackrabbit.oak.spi.security.authentication.JaasLoginContext
 
JaasLoginContext(String, Subject, CallbackHandler) - Constructor for class org.apache.jackrabbit.oak.spi.security.authentication.JaasLoginContext
 
JaasLoginContext(String, Subject, CallbackHandler, Configuration) - Constructor for class org.apache.jackrabbit.oak.spi.security.authentication.JaasLoginContext
 
JCR_ACTIVITIES - Static variable in interface org.apache.jackrabbit.oak.plugins.version.VersionConstants
 
JCR_ACTIVITY - Static variable in interface org.apache.jackrabbit.oak.plugins.version.VersionConstants
 
JCR_ACTIVITY_TITLE - Static variable in interface org.apache.jackrabbit.oak.plugins.version.VersionConstants
 
JCR_ADD_CHILD_NODES - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
Internal (oak) name of the Privilege.JCR_ADD_CHILD_NODES privilege
JCR_ALL - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
Internal (oak) name of the Privilege.JCR_ALL privilege
JCR_AVAILABLE_QUERY_OPERATORS - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
JCR_CHILD_VERSION_HISTORY - Static variable in interface org.apache.jackrabbit.oak.plugins.version.VersionConstants
 
JCR_CONFIGURATION - Static variable in interface org.apache.jackrabbit.oak.plugins.version.VersionConstants
 
JCR_CONFIGURATIONS - Static variable in interface org.apache.jackrabbit.oak.plugins.version.VersionConstants
 
JCR_COPIED_FROM - Static variable in interface org.apache.jackrabbit.oak.plugins.version.VersionConstants
 
JCR_CREATEDBY - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
Additional name constants not present in JcrConstants
JCR_IS_ABSTRACT - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
JCR_IS_FULLTEXT_SEARCHABLE - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
JCR_IS_QUERY_ORDERABLE - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
JCR_IS_QUERYABLE - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
JCR_LASTMODIFIEDBY - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
JCR_LIFECYCLE_MANAGEMENT - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
Internal (oak) name of the Privilege.JCR_LIFECYCLE_MANAGEMENT privilege
JCR_LOCK_MANAGEMENT - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
Internal (oak) name of the Privilege.JCR_LOCK_MANAGEMENT privilege
JCR_MODIFY_ACCESS_CONTROL - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
Internal (oak) name of the Privilege.JCR_MODIFY_ACCESS_CONTROL privilege
JCR_MODIFY_PROPERTIES - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
Internal (oak) name of the Privilege.JCR_MODIFY_PROPERTIES privilege
JCR_NAMESPACE_MANAGEMENT - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
Internal (oak) name of the jcr:namespaceManagement privilege
JCR_NODE_TYPE_DEFINITION_MANAGEMENT - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
Internal (oak) name of the jcr:nodeTypeDefinitionManagement privilege
JCR_NODE_TYPE_MANAGEMENT - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
Internal (oak) name of the Privilege.JCR_NODE_TYPE_MANAGEMENT privilege
JCR_NODE_TYPES - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
JCR_READ - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
Internal (oak) name of the Privilege.JCR_READ privilege
JCR_READ_ACCESS_CONTROL - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
Internal (oak) name of the Privilege.JCR_READ_ACCESS_CONTROL privilege
JCR_REMOVE_CHILD_NODES - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
Internal (oak) name of the Privilege.JCR_REMOVE_CHILD_NODES privilege
JCR_REMOVE_NODE - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
Internal (oak) name of the Privilege.JCR_REMOVE_NODE privilege
JCR_RETENTION_MANAGEMENT - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
Internal (oak) name of the Privilege.JCR_RETENTION_MANAGEMENT privilege
JCR_ROOT - Static variable in interface org.apache.jackrabbit.oak.plugins.version.VersionConstants
 
JCR_VERSION_MANAGEMENT - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
Internal (oak) name of the Privilege.JCR_VERSION_MANAGEMENT privilege
JCR_WORKSPACE_MANAGEMENT - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
Internal (oak) name of the jcr:workspaceManagement privilege
JCR_WRITE - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
Internal (oak) name of the Privilege.JCR_WRITE privilege
JcrConflictHandler - Class in org.apache.jackrabbit.oak.plugins.commit
Utility class providing conflict handlers used for JCR.
JcrLastModifiedConflictHandler - Class in org.apache.jackrabbit.oak.plugins.commit
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.
JcrLastModifiedConflictHandler() - Constructor for class org.apache.jackrabbit.oak.plugins.commit.JcrLastModifiedConflictHandler
 
JcrNameParser - Class in org.apache.jackrabbit.oak.namepath
Parses and validates JCR names.
JcrPathParser - Class in org.apache.jackrabbit.oak.namepath
TODO document
jdbctype(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBJDBCTools
 
join(SourceImpl, SourceImpl, JoinType, JoinConditionImpl) - Method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
 
JoinConditionImpl - Class in org.apache.jackrabbit.oak.query.ast
The base class for join conditions.
JoinConditionImpl() - Constructor for class org.apache.jackrabbit.oak.query.ast.JoinConditionImpl
 
JoinExecutionPlan - Class in org.apache.jackrabbit.oak.query.plan
An execution plan for a join.
JoinExecutionPlan(JoinImpl, ExecutionPlan, ExecutionPlan, double) - Constructor for class org.apache.jackrabbit.oak.query.plan.JoinExecutionPlan
 
JoinImpl - Class in org.apache.jackrabbit.oak.query.ast
A join.
JoinImpl(SourceImpl, SourceImpl, JoinType, JoinConditionImpl) - Constructor for class org.apache.jackrabbit.oak.query.ast.JoinImpl
 
joinQuietly(Thread...) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
Calls Thread.join() on each of the passed threads and catches any potentially thrown InterruptedException.
JoinType - Enum in org.apache.jackrabbit.oak.query.ast
The enumeration of all join types.
JOURNAL - Static variable in class org.apache.jackrabbit.oak.plugins.document.Collection
The 'journal' collection contains documents with consolidated diffs for changes performed by a cluster node between two background updates.
JournalEntry - Class in org.apache.jackrabbit.oak.plugins.document
Keeps track of changes performed between two consecutive background updates.
JournalGarbageCollector - Class in org.apache.jackrabbit.oak.plugins.document
The JournalGarbageCollector can clean up JournalEntries that are older than a particular age.
JournalGarbageCollector(DocumentNodeStore, long) - Constructor for class org.apache.jackrabbit.oak.plugins.document.JournalGarbageCollector
 
JournalProperty - Interface in org.apache.jackrabbit.oak.plugins.document.spi
Marker interface to indicate the implementing class can be made part of JournalEntry
JournalPropertyBuilder<T extends JournalProperty> - Interface in org.apache.jackrabbit.oak.plugins.document.spi
 
JournalPropertyHandlerFactory - Class in org.apache.jackrabbit.oak.plugins.document
 
JournalPropertyHandlerFactory() - Constructor for class org.apache.jackrabbit.oak.plugins.document.JournalPropertyHandlerFactory
 
JournalPropertyService - Interface in org.apache.jackrabbit.oak.plugins.document.spi
Each component which needs to add a property to JournalEntry should register this service

K

Key(String, Revision) - Constructor for class org.apache.jackrabbit.oak.plugins.document.UpdateOp.Key
 
KEY_COUNT_PROPERTY_NAME - Static variable in interface org.apache.jackrabbit.oak.plugins.index.IndexConstants
 
KEY_DATA - Static variable in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoBlob
 
KEY_ID - Static variable in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoBlob
 
KEY_LAST_MOD - Static variable in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoBlob
 
KEY_LEVEL - Static variable in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoBlob
 
KeyDataType - Class in org.apache.jackrabbit.oak.plugins.document.persistentCache
 
KeyDataType(CacheType) - Constructor for class org.apache.jackrabbit.oak.plugins.document.persistentCache.KeyDataType
 
keyFromString(String) - Method in enum org.apache.jackrabbit.oak.plugins.document.persistentCache.CacheType
 
keys() - Method in class org.apache.jackrabbit.oak.plugins.document.cache.NodeDocumentCache
 
keySet() - Method in class org.apache.jackrabbit.oak.plugins.document.Document
 
keySet() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.RevisionEntry
 
keySet() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.MultiGenerationMap
 
keySet() - Method in class org.apache.jackrabbit.oak.spi.security.ConfigurationParameters
keyToString(K) - Method in enum org.apache.jackrabbit.oak.plugins.document.persistentCache.CacheType
 
KNOWN_PARENT_PATH - Static variable in class org.apache.jackrabbit.oak.query.ast.JoinConditionImpl
The parent path of the joined selector
KNOWN_PATH - Static variable in class org.apache.jackrabbit.oak.query.ast.JoinConditionImpl
A path for a join.
KNOWN_VALUE - Static variable in class org.apache.jackrabbit.oak.query.ast.JoinConditionImpl
 

L

LAST_WRITTEN_ROOT_REV_KEY - Static variable in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfo
The key for the root-revision of the last background write (of unsaved modifications) - that is: the last root-revision written by the instance in case of a clear shutdown or via recovery of another instance in case of a crash
LastRevRecoveryAgent - Class in org.apache.jackrabbit.oak.plugins.document
Utility class for recovering potential missing _lastRev updates of nodes due to crash of a node.
LastRevRecoveryAgent(DocumentNodeStore, MissingLastRevSeeker) - Constructor for class org.apache.jackrabbit.oak.plugins.document.LastRevRecoveryAgent
 
LastRevRecoveryAgent(DocumentNodeStore) - Constructor for class org.apache.jackrabbit.oak.plugins.document.LastRevRecoveryAgent
 
LastRevTracker - Interface in org.apache.jackrabbit.oak.plugins.document
An implementation of this interface receives callbacks about paths that need an update of the _lastRev field on documents.
lastSuccess - Variable in class org.apache.jackrabbit.oak.plugins.document.VersionGarbageCollector.VersionGCInfo
 
LazyBloomFilter(int) - Constructor for class org.apache.jackrabbit.oak.plugins.document.cache.CacheChangesTracker.LazyBloomFilter
 
leafDocumentsDeleted(long) - Method in interface org.apache.jackrabbit.oak.plugins.document.RevisionGCStatsCollector
 
LEASE_CHECK_INTERVAL - Static variable in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate.AsyncUpdateCallback
Interval in terms of number of nodes traversed after which time would be checked for lease expiry
LEASE_END_KEY - Static variable in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfo
The end of the lease.
LeaseCheckDocumentStoreWrapper - Class in org.apache.jackrabbit.oak.plugins.document.util
Wrapper of another DocumentStore that does a lease check on any method invocation (read or update) and fails if the lease is not valid.
LeaseCheckDocumentStoreWrapper(DocumentStore, ClusterNodeInfo) - Constructor for class org.apache.jackrabbit.oak.plugins.document.util.LeaseCheckDocumentStoreWrapper
 
LeaseFailureHandler - Interface in org.apache.jackrabbit.oak.plugins.document
A LeaseFailureHandler can be provided to the DocumentMK.Builder and will be passed on to the ClusterNodeInfo for use upon lease failure.
leasify(String) - Static method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate
 
leave(NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.atomic.AtomicCounterEditor
 
leave(NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.commit.ConflictValidator
 
leave(NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.index.counter.NodeCounterEditor
 
leave(NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.index.IndexUpdate
 
leave(NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.DefaultEventHandler
 
leave(NodeState, NodeState) - Method in interface org.apache.jackrabbit.oak.plugins.observation.EventHandler
Called after the given before and after states are compared.
leave(NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.FilteredHandler
 
leaveNew(NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.index.counter.NodeCounterEditor
 
length(DynamicOperandImpl) - Method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
 
LengthImpl - Class in org.apache.jackrabbit.oak.query.ast
The function "length(..)".
LengthImpl(DynamicOperandImpl) - Constructor for class org.apache.jackrabbit.oak.query.ast.LengthImpl
 
less(Calendar, Calendar) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.DateConstraint
 
less(BigDecimal, BigDecimal) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.DecimalConstraint
 
less(Double, Double) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.DoubleConstraint
 
less(Long, Long) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.LongConstraint
 
less(T, T) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.NumericConstraint
 
lessOrEqual(T, T) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.NumericConstraint
 
LIFECYCLE_MANAGEMENT - Static variable in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
 
LISTENER - Static variable in interface org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast.DynamicBroadcastConfig
The listener address, for example the IP address and port.
listeners - Variable in class org.apache.jackrabbit.oak.plugins.document.mongo.replica.ReplicaSetInfo
 
literal(PropertyValue) - Method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
 
LiteralImpl - Class in org.apache.jackrabbit.oak.query.ast
A literal of a certain data type, possibly "cast(..)" of a literal.
LiteralImpl(PropertyValue) - Constructor for class org.apache.jackrabbit.oak.query.ast.LiteralImpl
 
local - Variable in class org.apache.jackrabbit.oak.namepath.LocalNameMapper
 
LocalChanges - Class in org.apache.jackrabbit.oak.plugins.document.mongo.replica
This class maintains a list of local changes (path+local revision timestamp), which shouldn't be read from the secondary Mongo, as we are not sure if they have been already replicated from primary.
LocalChanges(int) - Constructor for class org.apache.jackrabbit.oak.plugins.document.mongo.replica.LocalChanges
 
LocalDiffCache - Class in org.apache.jackrabbit.oak.plugins.document
A diff cache, which is pro-actively filled after a commit.
LocalDiffCache.Diff - Class in org.apache.jackrabbit.oak.plugins.document
 
LocalNameMapper - Class in org.apache.jackrabbit.oak.namepath
Name mapper with local namespace mappings.
LocalNameMapper(Root, Map<String, String>) - Constructor for class org.apache.jackrabbit.oak.namepath.LocalNameMapper
 
LocalNameMapper(Map<String, String>, Map<String, String>) - Constructor for class org.apache.jackrabbit.oak.namepath.LocalNameMapper
 
lock(String) - Method in class org.apache.jackrabbit.oak.plugins.index.importer.AbortingIndexerLock
 
lock(String) - Method in interface org.apache.jackrabbit.oak.plugins.index.importer.AsyncIndexerLock
 
lock(String) - Method in class org.apache.jackrabbit.oak.plugins.index.importer.ClusterNodeStoreLock
 
LOCK_MANAGEMENT - Static variable in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
 
LOCK_PROPERTY_NAMES - Static variable in interface org.apache.jackrabbit.oak.plugins.lock.LockConstants
 
LockConstants - Interface in org.apache.jackrabbit.oak.plugins.lock
 
LoggingDocumentStoreWrapper - Class in org.apache.jackrabbit.oak.plugins.document.util
Implements a DocumentStore wrapper and logs all calls.
LoggingDocumentStoreWrapper(DocumentStore) - Constructor for class org.apache.jackrabbit.oak.plugins.document.util.LoggingDocumentStoreWrapper
 
login(Credentials, String) - Method in class org.apache.jackrabbit.oak.core.ContentRepositoryImpl
 
login() - Method in class org.apache.jackrabbit.oak.security.authentication.token.TokenLoginModule
 
login() - Method in class org.apache.jackrabbit.oak.security.authentication.user.LoginModuleImpl
 
login() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.GuestLoginModule
 
login() - Method in interface org.apache.jackrabbit.oak.spi.security.authentication.LoginContext
 
login() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.PreAuthContext
 
LoginContext - Interface in org.apache.jackrabbit.oak.spi.security.authentication
Interface version of the JAAS LoginContext class.
LoginContextProvider - Interface in org.apache.jackrabbit.oak.spi.security.authentication
Configurable provider taking care of building login contexts for the desired authentication mechanism.
LoginModuleImpl - Class in org.apache.jackrabbit.oak.security.authentication.user
Default login module implementation that authenticates JCR Credentials against the repository.
LoginModuleImpl() - Constructor for class org.apache.jackrabbit.oak.security.authentication.user.LoginModuleImpl
 
logout() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.AbstractLoginModule
 
logout() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.GuestLoginModule
 
logout() - Method in interface org.apache.jackrabbit.oak.spi.security.authentication.LoginContext
 
logout() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.PreAuthContext
 
logReport() - Method in class org.apache.jackrabbit.oak.plugins.index.progress.IndexingProgressReporter
 
LONG_UNSET - Static variable in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBRow
 
LongConstraint - Class in org.apache.jackrabbit.oak.plugins.nodetype.constraint
 
LongConstraint(String) - Constructor for class org.apache.jackrabbit.oak.plugins.nodetype.constraint.LongConstraint
 
lowerCase(DynamicOperandImpl) - Method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
 
LowerCaseImpl - Class in org.apache.jackrabbit.oak.query.ast
The function "lower(..)".
LowerCaseImpl(DynamicOperandImpl) - Constructor for class org.apache.jackrabbit.oak.query.ast.LowerCaseImpl
 

M

main(String[]) - Static method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBCreator
 
main(String[]) - Static method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBExport
 
main(String[]) - Static method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBHelper
 
MAJOR - Static variable in class org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeDefDiff
major modification: does affect consistency of existing content
MapFactory - Class in org.apache.jackrabbit.oak.plugins.document.persistentCache
 
MapFactory() - Constructor for class org.apache.jackrabbit.oak.plugins.document.persistentCache.MapFactory
 
MapFactory - Class in org.apache.jackrabbit.oak.plugins.document.util
Experimental extension point for OAK-1772 to try out alternative approaches for persisting in memory state Not part of API
MapFactory() - Constructor for class org.apache.jackrabbit.oak.plugins.document.util.MapFactory
 
mark(AbstractBlobStore.BlockId) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoBlobStore
 
mark(AbstractBlobStore.BlockId) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBBlobStore
 
markAsPartialObject() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.RevisionEntry
 
markBytesWritten(long) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
markChanged(String) - Method in class org.apache.jackrabbit.oak.plugins.document.cache.NodeDocumentCache
Mark that the document with the given key is being changed.
markEmpty(String) - Method in class org.apache.jackrabbit.oak.plugins.index.datastore.DataStoreTextWriter
 
markError(String) - Method in class org.apache.jackrabbit.oak.plugins.index.datastore.DataStoreTextWriter
 
markException() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
markHit() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
markInvalidateAll() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
markInvalidateOne() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
markPut() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
markPutRejectedAlreadyPersisted() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
markPutRejectedAsCachedInSecondary() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
markPutRejectedEntryNotUsed() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
markPutRejectedQueueFull() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
markRecvBroadcast() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
markRequest() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
markUpToDate(long) - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
Mark this instance as up-to-date (matches the state in persistence store).
markWorkingIndexes(Set<String>) - Method in class org.apache.jackrabbit.oak.plugins.index.TrackingCorruptIndexHandler
 
match(String) - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.Include
 
match(String, int) - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.Include
Matches node name against pattern at given depth.
match(NodeState, Filter) - Method in class org.apache.jackrabbit.oak.plugins.index.diffindex.UUIDDiffCollector
 
matchAny(int) - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.Include
 
Matcher - Interface in org.apache.jackrabbit.oak.plugins.document.bundlor
 
matches(String) - Method in class org.apache.jackrabbit.oak.plugins.index.property.ValuePattern
 
matches(TokenCredentials) - Method in interface org.apache.jackrabbit.oak.spi.security.authentication.token.TokenInfo
Returns true if the specified credentials can be successfully validated against the information stored in this instance.
matches(Tree, PropertyState) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.restriction.CompositePattern
 
matches(String) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.restriction.CompositePattern
 
matches() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.restriction.CompositePattern
 
matches(Tree, PropertyState) - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.restriction.RestrictionPattern
Returns true if the underlying restriction matches the specified tree or property state.
matches(String) - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.restriction.RestrictionPattern
Returns true if the underlying restriction matches the specified path.
matches() - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.restriction.RestrictionPattern
Returns true if the underlying restriction matches for repository level permissions.
matchesAll() - Method in class org.apache.jackrabbit.oak.plugins.index.property.ValuePattern
 
matchesAll(Set<String>) - Method in class org.apache.jackrabbit.oak.plugins.index.property.ValuePattern
 
matchesAllChildren() - Method in interface org.apache.jackrabbit.oak.plugins.document.bundlor.Matcher
Returns true if matcher for all immediate child node would also be a matching matcher.
matchesAllTypes() - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
 
matchesAllTypes() - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
 
matchesPrefix(String) - Method in class org.apache.jackrabbit.oak.plugins.index.property.ValuePattern
 
matchesSQLState(SQLException, String...) - Static method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBJDBCTools
Check whether the exception matches one of the given states.
max(Revision, Revision) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
Returns the revision with the newer timestamp or null if both revisions are null.
max(Revision, Revision, Comparator<Revision>) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
Returns the revision which is considered more recent or null if both revisions are null.
MAX_ALL - Static variable in class org.apache.jackrabbit.oak.security.user.query.ResultIterator
 
MAX_ID_VALUE - Static variable in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
All NodeDocument ID value would be less than this value It can be used as endKey in DocumentStore#query methods
MAX_IN_CLAUSE - Static variable in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBJDBCTools
 
MAX_TIMEOUT - Static variable in class org.apache.jackrabbit.oak.plugins.atomic.AtomicCounterEditor.ConsolidatorTask
millis over which the task will timeout
MAX_UNION - Static variable in class org.apache.jackrabbit.oak.query.QueryImpl
 
maxDurationMs - Variable in class org.apache.jackrabbit.oak.plugins.document.VersionGCOptions
 
maxIterations - Variable in class org.apache.jackrabbit.oak.plugins.document.VersionGCOptions
 
mayContain(String) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.replica.LocalChanges
Check if it's possible that the given document hasn't been replicated to the secondary yet.
mayContainChildrenOf(String) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.replica.LocalChanges
Check if it's possible that the children of the given document hasn't been replicated to the secondary yet.
members() - Method in class org.apache.jackrabbit.oak.spi.security.principal.EveryonePrincipal
 
MembershipWriter - Class in org.apache.jackrabbit.oak.security.user
 
MembershipWriter() - Constructor for class org.apache.jackrabbit.oak.security.user.MembershipWriter
 
memoryCacheDistribution(int, int, int, int) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
memoryCacheSize(long) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
MemoryDiffCache - Class in org.apache.jackrabbit.oak.plugins.document
An in-memory diff cache implementation.
MemoryDiffCache(DocumentMK.Builder) - Constructor for class org.apache.jackrabbit.oak.plugins.document.MemoryDiffCache
 
MemoryDiffCache.MemoryEntry - Class in org.apache.jackrabbit.oak.plugins.document
 
MemoryDocumentStore - Class in org.apache.jackrabbit.oak.plugins.document.memory
Emulates a MongoDB store (possibly consisting of multiple shards and replicas).
MemoryDocumentStore() - Constructor for class org.apache.jackrabbit.oak.plugins.document.memory.MemoryDocumentStore
 
MemoryEntry(RevisionVector, RevisionVector) - Constructor for class org.apache.jackrabbit.oak.plugins.document.MemoryDiffCache.MemoryEntry
 
merge(NodeBuilder, CommitHook, CommitInfo) - Method in class org.apache.jackrabbit.oak.plugins.cow.BranchNodeStore
 
merge(NodeBuilder, CommitHook, CommitInfo) - Method in class org.apache.jackrabbit.oak.plugins.cow.COWNodeStore
 
merge(String, String) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK
 
merge(NodeBuilder, CommitHook, CommitInfo) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
MergeSortedIterators<T> - Class in org.apache.jackrabbit.oak.plugins.document.util
MergeSortedIterators is a specialized implementation of a merge sort of already sorted iterators of some type of comparable elements.
MergeSortedIterators(Comparator<T>) - Constructor for class org.apache.jackrabbit.oak.plugins.document.util.MergeSortedIterators
 
MergingNodeStateDiff - Class in org.apache.jackrabbit.oak.plugins.commit
MergingNodeStateDiff...
META_PROP_BUNDLED_CHILD - Static variable in class org.apache.jackrabbit.oak.plugins.document.bundlor.DocumentBundlor
Hidden property name having boolean value indicating that current node has children which are bundled
META_PROP_BUNDLING_PATH - Static variable in class org.apache.jackrabbit.oak.plugins.document.bundlor.DocumentBundlor
Hidden property name used as suffix for relative node path to indicate presence of that node.
META_PROP_NAMES - Static variable in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
List of meta properties which are created by DocumentNodeStore and which needs to be retained in any cloned copy of DocumentNodeState.
META_PROP_NON_BUNDLED_CHILD - Static variable in class org.apache.jackrabbit.oak.plugins.document.bundlor.DocumentBundlor
Hidden property name having boolean value indicating that current node has children which are not bundled
META_PROP_PATTERN - Static variable in class org.apache.jackrabbit.oak.plugins.document.bundlor.DocumentBundlor
Hidden property to store the pattern as part of NodeState TODO - Also store the NodeType
metaPropNames(List<String>) - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.SecondaryStoreBuilder
 
MetricRateEstimator - Class in org.apache.jackrabbit.oak.plugins.index.progress
 
MetricRateEstimator(String, MetricRegistry) - Constructor for class org.apache.jackrabbit.oak.plugins.index.progress.MetricRateEstimator
 
MetricStatisticsProvider - Class in org.apache.jackrabbit.oak.plugins.metric
 
MetricStatisticsProvider(MBeanServer, ScheduledExecutorService) - Constructor for class org.apache.jackrabbit.oak.plugins.metric.MetricStatisticsProvider
 
mightBeenAffected(String) - Method in class org.apache.jackrabbit.oak.plugins.document.cache.CacheChangesTracker
 
mightContain(String) - Method in class org.apache.jackrabbit.oak.plugins.document.cache.CacheChangesTracker.LazyBloomFilter
 
min(Revision, Revision) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
Returns the revision with the older timestamp or null if both revisions are null.
min(Revision, Revision, Comparator<Revision>) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
Returns the revision which is considered older or null if both revisions are null.
MIN_ID_VALUE - Static variable in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
All NodeDocument ID value would be greater than this value It can be used as startKey in DocumentStore#query methods
MIN_TIMEOUT - Static variable in class org.apache.jackrabbit.oak.plugins.atomic.AtomicCounterEditor.ConsolidatorTask
millis below which the next delay will schedule at this amount.
MISSING - Static variable in class org.apache.jackrabbit.oak.plugins.document.UpdateOp.Condition
Check if a sub-key is missing in a map.
MissingIndexProviderStrategy() - Constructor for class org.apache.jackrabbit.oak.plugins.index.IndexUpdate.MissingIndexProviderStrategy
 
MissingLastRevSeeker - Class in org.apache.jackrabbit.oak.plugins.document
Utilities to retrieve _lastRev missing update candidates.
MissingLastRevSeeker(DocumentStore, Clock) - Constructor for class org.apache.jackrabbit.oak.plugins.document.MissingLastRevSeeker
 
MIX_ATOMIC_COUNTER - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
mixin to enable the AtomicCounterEditor.
MIX_CREATED - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
MIX_INDEXABLE - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
adding such mixin will allow the JcrConstants.NT_UNSTRUCTURED type under restricting nodes such JcrConstants.NT_FOLDER
MIX_LASTMODIFIED - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
MIX_REP_ACCESS_CONTROLLABLE - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AccessControlConstants
 
MIX_REP_IMPERSONATABLE - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
 
MIX_REP_MERGE_CONFLICT - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
Merge conflict handling
MIX_REP_REPO_ACCESS_CONTROLLABLE - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AccessControlConstants
 
MIX_REP_VERSIONABLE_PATHS - Static variable in interface org.apache.jackrabbit.oak.plugins.version.VersionConstants
 
mixinFlagDiff() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeDefDiff
 
MOD_COUNT - Static variable in class org.apache.jackrabbit.oak.plugins.document.Document
The modification count on the document.
modCount - Variable in class org.apache.jackrabbit.oak.plugins.document.cache.ModificationStamp
 
modifiable() - Method in class org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeBits
 
ModificationStamp - Class in org.apache.jackrabbit.oak.plugins.document.cache
 
ModificationStamp(long, long) - Constructor for class org.apache.jackrabbit.oak.plugins.document.cache.ModificationStamp
 
modified - Variable in class org.apache.jackrabbit.oak.plugins.document.cache.ModificationStamp
 
MODIFIED - Static variable in class org.apache.jackrabbit.oak.plugins.document.JournalEntry
 
modified(Map<String, Object>) - Method in class org.apache.jackrabbit.oak.plugins.observation.ChangeCollectorProvider
 
modified(Map<String, Object>) - Method in class org.apache.jackrabbit.oak.security.internal.SecurityProviderRegistration
 
MODIFIED_IN_SECS - Static variable in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
The modified time in seconds (5 second resolution).
MODIFY_ACCESS_CONTROL - Static variable in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
 
MODIFY_CHILD_NODE_COLLECTION - Static variable in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
 
MODIFY_PROPERTY - Static variable in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
 
MongoBlob - Class in org.apache.jackrabbit.oak.plugins.document.mongo
The MongoDB representation of a blob.
MongoBlob() - Constructor for class org.apache.jackrabbit.oak.plugins.document.mongo.MongoBlob
Default constructor.
MongoBlobReferenceIterator - Class in org.apache.jackrabbit.oak.plugins.document.mongo
 
MongoBlobReferenceIterator(DocumentNodeStore, MongoDocumentStore) - Constructor for class org.apache.jackrabbit.oak.plugins.document.mongo.MongoBlobReferenceIterator
 
MongoBlobStore - Class in org.apache.jackrabbit.oak.plugins.document.mongo
Implementation of blob store for the MongoDB extending from AbstractBlobStore.
MongoBlobStore(DB) - Constructor for class org.apache.jackrabbit.oak.plugins.document.mongo.MongoBlobStore
Constructs a new MongoBlobStore
MongoBlobStore(DB, long) - Constructor for class org.apache.jackrabbit.oak.plugins.document.mongo.MongoBlobStore
 
MongoConnection - Class in org.apache.jackrabbit.oak.plugins.document.util
The MongoConnection abstracts connection to the MongoDB.
MongoConnection(String) - Constructor for class org.apache.jackrabbit.oak.plugins.document.util.MongoConnection
Constructs a new connection using the specified MongoDB connection string.
MongoConnection(String, MongoClientOptions.Builder) - Constructor for class org.apache.jackrabbit.oak.plugins.document.util.MongoConnection
Constructs a new connection using the specified MongoDB connection String.
MongoConnection(String, int, String) - Constructor for class org.apache.jackrabbit.oak.plugins.document.util.MongoConnection
Constructs a new MongoConnection.
MongoDocumentStore - Class in org.apache.jackrabbit.oak.plugins.document.mongo
A document store that uses MongoDB as the backend.
MongoDocumentStore(DB, DocumentMK.Builder) - Constructor for class org.apache.jackrabbit.oak.plugins.document.mongo.MongoDocumentStore
 
MongoMissingLastRevSeeker - Class in org.apache.jackrabbit.oak.plugins.document.mongo
Mongo specific version of MissingLastRevSeeker which uses mongo queries to fetch candidates which may have missed '_lastRev' updates.
MongoMissingLastRevSeeker(MongoDocumentStore, Clock) - Constructor for class org.apache.jackrabbit.oak.plugins.document.mongo.MongoMissingLastRevSeeker
 
MongoStatus - Class in org.apache.jackrabbit.oak.plugins.document.mongo
 
MongoStatus(DB) - Constructor for class org.apache.jackrabbit.oak.plugins.document.mongo.MongoStatus
 
MongoVersionGCSupport - Class in org.apache.jackrabbit.oak.plugins.document.mongo
Mongo specific version of VersionGCSupport which uses mongo queries to fetch required NodeDocuments
MongoVersionGCSupport(MongoDocumentStore) - Constructor for class org.apache.jackrabbit.oak.plugins.document.mongo.MongoVersionGCSupport
 
MORE_LIKE_THIS_PREFIX - Static variable in class org.apache.jackrabbit.oak.query.ast.SimilarImpl
 
MountPermissionProvider - Class in org.apache.jackrabbit.oak.security.authorization.permission
 
MountPermissionProvider(Root, String, Set<Principal>, RestrictionProvider, ConfigurationParameters, Context, MountInfoProvider) - Constructor for class org.apache.jackrabbit.oak.security.authorization.permission.MountPermissionProvider
 
move(String, String) - Method in class org.apache.jackrabbit.oak.core.ImmutableRoot
 
MoveAwarePermissionValidator - Class in org.apache.jackrabbit.oak.security.authorization.permission
 
MoveCondition() - Constructor for class org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder.MoveCondition
 
MoveFilter - Class in org.apache.jackrabbit.oak.plugins.observation.filter
This filter implementation excludes generating add node events for child nodes of the destination of a move operation.
MoveFilter() - Constructor for class org.apache.jackrabbit.oak.plugins.observation.filter.MoveFilter
 
moveSubtree() - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder
 
MultiGenerationMap<K,V> - Class in org.apache.jackrabbit.oak.plugins.document.persistentCache
 
Multiplexers - Class in org.apache.jackrabbit.oak.plugins.index.property
 

N

NAME - Static variable in class org.apache.jackrabbit.oak.plugins.index.reference.NodeReferenceConstants
 
NAME - Static variable in interface org.apache.jackrabbit.oak.spi.security.authentication.AuthenticationConfiguration
 
NAME - Static variable in interface org.apache.jackrabbit.oak.spi.security.authentication.token.TokenConfiguration
 
NAME - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.AuthorizationConfiguration
 
NAME - Static variable in class org.apache.jackrabbit.oak.spi.security.principal.EveryonePrincipal
 
NAME - Static variable in interface org.apache.jackrabbit.oak.spi.security.principal.PrincipalConfiguration
 
NAME - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConfiguration
 
NAME - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConfiguration
 
NAME_ABORT - Static variable in class org.apache.jackrabbit.oak.spi.xml.ImportBehavior
 
NAME_BESTEFFORT - Static variable in class org.apache.jackrabbit.oak.spi.xml.ImportBehavior
 
NAME_IGNORE - Static variable in class org.apache.jackrabbit.oak.spi.xml.ImportBehavior
 
NameConstraint - Class in org.apache.jackrabbit.oak.plugins.nodetype.constraint
 
NameConstraint(String) - Constructor for class org.apache.jackrabbit.oak.plugins.nodetype.constraint.NameConstraint
 
nameFromValue(int) - Static method in class org.apache.jackrabbit.oak.spi.xml.ImportBehavior
 
NameMapper - Interface in org.apache.jackrabbit.oak.namepath
TODO document
NamePathMapper - Interface in org.apache.jackrabbit.oak.namepath
The NamePathMapper interface combines NameMapper and PathMapper.
NamePathMapper.Default - Class in org.apache.jackrabbit.oak.namepath
Default implementation that doesn't perform any conversions for cases where a mapper object only deals with oak internal names and paths.
NamePathMapperImpl - Class in org.apache.jackrabbit.oak.namepath
TODO document
NamePathMapperImpl(NameMapper) - Constructor for class org.apache.jackrabbit.oak.namepath.NamePathMapperImpl
 
NamePathMapperImpl(NameMapper, IdentifierManager) - Constructor for class org.apache.jackrabbit.oak.namepath.NamePathMapperImpl
 
NAMESPACE_MANAGEMENT - Static variable in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
 
NAMESPACE_REP - Static variable in interface org.apache.jackrabbit.oak.plugins.name.NamespaceConstants
 
NAMESPACE_SV - Static variable in interface org.apache.jackrabbit.oak.plugins.name.NamespaceConstants
 
NAMESPACE_XMLNS - Static variable in interface org.apache.jackrabbit.oak.plugins.name.NamespaceConstants
 
NamespaceConstants - Interface in org.apache.jackrabbit.oak.plugins.name
TODO document
NamespaceEditorProvider - Class in org.apache.jackrabbit.oak.plugins.name
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.
NamespaceEditorProvider() - Constructor for class org.apache.jackrabbit.oak.plugins.name.NamespaceEditorProvider
 
Namespaces - Class in org.apache.jackrabbit.oak.plugins.name
Internal static utility class for managing the persisted namespace registry.
namespaces - Variable in class org.apache.jackrabbit.oak.plugins.name.ReadOnlyNamespaceRegistry
 
NAMESPACES_PATH - Static variable in interface org.apache.jackrabbit.oak.plugins.name.NamespaceConstants
 
NameValidatorProvider - Class in org.apache.jackrabbit.oak.plugins.name
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.
NameValidatorProvider() - Constructor for class org.apache.jackrabbit.oak.plugins.name.NameValidatorProvider
 
NATIVE_LUCENE_LANGUAGE - Static variable in class org.apache.jackrabbit.oak.query.ast.SimilarImpl
 
NATIVE_LUCENE_LANGUAGE - Static variable in class org.apache.jackrabbit.oak.query.ast.SpellcheckImpl
 
NATIVE_LUCENE_LANGUAGE - Static variable in class org.apache.jackrabbit.oak.query.ast.SuggestImpl
 
NATIVE_PREFIX - Static variable in class org.apache.jackrabbit.oak.query.ast.NativeFunctionImpl
The prefix for native function restrictions (native, similar, spellcheck, suggest).
nativeFunction(String, String, StaticOperandImpl) - Method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
 
NativeFunctionImpl - Class in org.apache.jackrabbit.oak.query.ast
A native function condition.
NEVER - Static variable in class org.apache.jackrabbit.oak.spi.security.ConfigurationParameters.Milliseconds
 
newAncestorCursor(Cursor, int, QueryLimits) - Static method in class org.apache.jackrabbit.oak.plugins.index.Cursors
Returns a cursor wrapper, which returns the ancestor rows at the given level of the wrapped cursor c.
newAsyncUpdateCallback(NodeStore, String, long, String, AsyncIndexUpdate.AsyncIndexStats, AtomicBoolean) - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate
 
newBuilder() - Method in interface org.apache.jackrabbit.oak.plugins.document.spi.JournalPropertyService
 
newBundlingHandler() - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundlingConfigHandler
 
newCombinedFilter(Iterator<K>, boolean, long, long, Comparator<K>, QueryLimits) - Static method in class org.apache.jackrabbit.oak.query.FilterIterators
 
newConcatCursor(List<Cursor>, QueryLimits) - Static method in class org.apache.jackrabbit.oak.plugins.index.Cursors
 
newDistinct(Iterator<K>, QueryLimits) - Static method in class org.apache.jackrabbit.oak.query.FilterIterators
 
newDocument(DocumentStore) - Method in class org.apache.jackrabbit.oak.plugins.document.Collection
 
newEntry(RevisionVector, RevisionVector, boolean) - Method in class org.apache.jackrabbit.oak.plugins.document.LocalDiffCache
 
newEntry(RevisionVector, RevisionVector, boolean) - Method in class org.apache.jackrabbit.oak.plugins.document.MemoryDiffCache
 
newEqualsCondition(Object) - Static method in class org.apache.jackrabbit.oak.plugins.document.UpdateOp.Condition
Creates a new equals condition with the given value.
newHandler() - Method in class org.apache.jackrabbit.oak.plugins.document.JournalPropertyHandlerFactory
 
newInstance() - Static method in class org.apache.jackrabbit.oak.plugins.document.cache.ForwardingListener
 
newInstance(RemovalListener<K, V>) - Static method in class org.apache.jackrabbit.oak.plugins.document.cache.ForwardingListener
 
newInstance(TokenProvider...) - Static method in class org.apache.jackrabbit.oak.spi.security.authentication.token.CompositeTokenProvider
 
newInstance(List<? extends TokenProvider>) - Static method in class org.apache.jackrabbit.oak.spi.security.authentication.token.CompositeTokenProvider
 
newInstance(RestrictionProvider...) - Static method in class org.apache.jackrabbit.oak.spi.security.authorization.restriction.CompositeRestrictionProvider
 
newInstance(Collection<? extends RestrictionProvider>) - Static method in class org.apache.jackrabbit.oak.spi.security.authorization.restriction.CompositeRestrictionProvider
 
newIntersectionCursor(Cursor, Cursor, QueryLimits) - Static method in class org.apache.jackrabbit.oak.plugins.index.Cursors
 
newLimit(Iterator<K>, long) - Static method in class org.apache.jackrabbit.oak.query.FilterIterators
 
newNotEqualsCondition(Object) - Static method in class org.apache.jackrabbit.oak.plugins.document.UpdateOp.Condition
Creates a new notEquals condition with the given value.
newOffset(Iterator<K>, long) - Static method in class org.apache.jackrabbit.oak.query.FilterIterators
 
newPathCursor(Iterable<String>, QueryLimits) - Static method in class org.apache.jackrabbit.oak.plugins.index.Cursors
Creates a Cursor over paths.
newPathCursorDistinct(Iterable<String>, QueryLimits) - Static method in class org.apache.jackrabbit.oak.plugins.index.Cursors
Creates a Cursor over paths, and make the result distinct.
newRevision() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
newRevision() - Method in interface org.apache.jackrabbit.oak.plugins.document.RevisionContext
 
newRuleWithName(String, List<String>) - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.SimpleNodeAggregator
Include children with the provided name.
newSort(Iterator<K>, Comparator<K>, int, QueryLimits) - Static method in class org.apache.jackrabbit.oak.query.FilterIterators
 
newTestInstance() - Static method in class org.apache.jackrabbit.oak.query.index.FilterImpl
Create a new filter instance that is used for unit testing.
newTraversingCursor(Filter, NodeState) - Static method in class org.apache.jackrabbit.oak.plugins.index.Cursors
Returns a traversing cursor based on the path restriction in the given Filter.
next(String) - Method in interface org.apache.jackrabbit.oak.plugins.document.bundlor.Matcher
Returns a matcher for given child node name based on current state
next() - Method in class org.apache.jackrabbit.oak.plugins.document.util.CloseableIterator
 
next() - Method in class org.apache.jackrabbit.oak.plugins.document.util.MergeSortedIterators
 
next() - Method in class org.apache.jackrabbit.oak.plugins.index.Cursors.PathCursor
 
next() - Method in class org.apache.jackrabbit.oak.query.ast.JoinImpl
 
next() - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
 
next() - Method in class org.apache.jackrabbit.oak.query.ast.SourceImpl
Go to the next node for the given source.
next() - Method in class org.apache.jackrabbit.oak.security.user.query.ResultIterator
 
NEXT_AFTER_BUILT_INS - Static variable in class org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeBits
 
nextBits() - Method in class org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeBits
Method to calculate the next privilege bits associated with this instance.
nextDelay(long) - Static method in class org.apache.jackrabbit.oak.plugins.atomic.AtomicCounterEditor.ConsolidatorTask
 
nextIterator() - Method in class org.apache.jackrabbit.oak.plugins.document.util.MergeSortedIterators
 
nextPrincipal() - Method in class org.apache.jackrabbit.oak.spi.security.principal.PrincipalIteratorAdapter
Returns the next policy.
NO_CHILDREN - Static variable in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState
 
NO_PERMISSION - Static variable in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
 
NO_RECOURSE - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.TreePermission
 
NODE_NAME_LIMIT - Static variable in class org.apache.jackrabbit.oak.plugins.document.util.Utils
The maximum size a node name, in bytes.
NODE_TYPE_DEFINITION_MANAGEMENT - Static variable in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
 
NODE_TYPE_MANAGEMENT - Static variable in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
 
NODE_TYPES_PATH - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
nodeAdded(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.DefaultEventHandler
 
nodeAdded(String, NodeState) - Method in interface org.apache.jackrabbit.oak.plugins.observation.EventHandler
Notification for an added node
nodeAdded(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.FilteredHandler
 
NodeBuilderTree - Class in org.apache.jackrabbit.oak.plugins.tree.impl
A mutable Tree implementation based on an underlying NodeBuilder, which tracks all changes recorded through this tree's mutator methods.
NodeBuilderTree(String, NodeBuilder) - Constructor for class org.apache.jackrabbit.oak.plugins.tree.impl.NodeBuilderTree
Create a new AbstractTree instance
NodeBuilderTree(NodeBuilderTree, NodeBuilder, String) - Constructor for class org.apache.jackrabbit.oak.plugins.tree.impl.NodeBuilderTree
 
NodeCollectionProvider - Class in org.apache.jackrabbit.oak.plugins.document.mongo.replica
This class connects to Mongo instances and returns the NODES collection.
NodeCollectionProvider(String, String) - Constructor for class org.apache.jackrabbit.oak.plugins.document.mongo.replica.NodeCollectionProvider
 
NodeCounter - Class in org.apache.jackrabbit.oak.plugins.index.counter.jmx
A mechanism to retrieve node counter data.
NodeCounter(NodeStore) - Constructor for class org.apache.jackrabbit.oak.plugins.index.counter.jmx.NodeCounter
 
NodeCounterEditor - Class in org.apache.jackrabbit.oak.plugins.index.counter
An approximate descendant node counter mechanism.
NodeCounterEditor(NodeCounterEditor.NodeCounterRoot, NodeCounterEditor, String, SipHash) - Constructor for class org.apache.jackrabbit.oak.plugins.index.counter.NodeCounterEditor
 
NodeCounterEditor.NodeCounterRoot - Class in org.apache.jackrabbit.oak.plugins.index.counter
 
NodeCounterEditorProvider - Class in org.apache.jackrabbit.oak.plugins.index.counter
 
NodeCounterEditorProvider() - Constructor for class org.apache.jackrabbit.oak.plugins.index.counter.NodeCounterEditorProvider
 
NodeCounterMBean - Interface in org.apache.jackrabbit.oak.plugins.index.counter.jmx
An MBean that provides an approximate node count for a given path.
NodeCounterMBeanEstimator - Class in org.apache.jackrabbit.oak.plugins.index.progress
 
NodeCounterMBeanEstimator(NodeStore) - Constructor for class org.apache.jackrabbit.oak.plugins.index.progress.NodeCounterMBeanEstimator
 
NodeCountEstimator - Interface in org.apache.jackrabbit.oak.plugins.index.progress
 
nodeDeleted(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.DefaultEventHandler
 
nodeDeleted(String, NodeState) - Method in interface org.apache.jackrabbit.oak.plugins.observation.EventHandler
Notification for a deleted node
nodeDeleted(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.FilteredHandler
 
NodeDocument - Class in org.apache.jackrabbit.oak.plugins.document
A document storing data about a node.
NodeDocument(DocumentStore, long) - Constructor for class org.apache.jackrabbit.oak.plugins.document.NodeDocument
Required for serialization
NodeDocument.Children - Class in org.apache.jackrabbit.oak.plugins.document
The list of children for a node.
NodeDocument.SplitDocType - Enum in org.apache.jackrabbit.oak.plugins.document
A document which is created from splitting a main document can be classified into multiple types depending on the content i.e.
NodeDocumentCache - Class in org.apache.jackrabbit.oak.plugins.document.cache
Cache for the NodeDocuments.
NodeDocumentCache(Cache<CacheValue, NodeDocument>, CacheStats, Cache<StringValue, NodeDocument>, CacheStats, NodeDocumentLocks) - Constructor for class org.apache.jackrabbit.oak.plugins.document.cache.NodeDocumentCache
 
NodeDocumentIdComparator - Class in org.apache.jackrabbit.oak.plugins.document
Implements a comparator, which sorts NodeDocumentId string according to 1) their depth (highest first) and 2) the id string itself.
NodeDocumentLocks - Interface in org.apache.jackrabbit.oak.plugins.document.locks
 
nodeExists(String, String) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK
 
NodeInfo - Class in org.apache.jackrabbit.oak.spi.xml
Information about a node being imported.
NodeInfo(String, String, Iterable<String>, String) - Constructor for class org.apache.jackrabbit.oak.spi.xml.NodeInfo
Creates a node information instance.
nodeLocalName(String) - Method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
 
NodeLocalNameImpl - Class in org.apache.jackrabbit.oak.query.ast
The function "localname(..)".
NodeLocalNameImpl(String) - Constructor for class org.apache.jackrabbit.oak.query.ast.NodeLocalNameImpl
 
nodeMoved(String, String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.DefaultEventHandler
 
nodeMoved(String, String, NodeState) - Method in interface org.apache.jackrabbit.oak.plugins.observation.EventHandler
Notification for a moved node
nodeMoved(String, String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.FilteredHandler
 
nodeName(String) - Method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
 
NodeNameImpl - Class in org.apache.jackrabbit.oak.query.ast
The function "name(..)".
NodeNameImpl(String) - Constructor for class org.apache.jackrabbit.oak.query.ast.NodeNameImpl
 
NodeObserver - Class in org.apache.jackrabbit.oak.plugins.observation
Base class for Observer instances that group changes by node instead of tracking them down to individual properties.
NodeObserver(String, String...) - Constructor for class org.apache.jackrabbit.oak.plugins.observation.NodeObserver
Create a new instance for observing the given path.
NodeReferenceConstants - Class in org.apache.jackrabbit.oak.plugins.index.reference
 
nodeReordered(String, String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.DefaultEventHandler
 
nodeReordered(String, String, NodeState) - Method in interface org.apache.jackrabbit.oak.plugins.observation.EventHandler
Notification for a reordered node
nodeReordered(String, String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.FilteredHandler
 
NODES - Static variable in class org.apache.jackrabbit.oak.plugins.document.Collection
The 'nodes' collection.
NodeStateDiffer - Interface in org.apache.jackrabbit.oak.plugins.document
 
NodeStateNodeTypeInfoProvider - Class in org.apache.jackrabbit.oak.query
A nodetype info provider that is based on node states.
NodeStateNodeTypeInfoProvider(NodeState) - Constructor for class org.apache.jackrabbit.oak.query.NodeStateNodeTypeInfoProvider
 
nodeStore - Variable in class org.apache.jackrabbit.oak.plugins.document.Commit
 
nodeStore - Variable in class org.apache.jackrabbit.oak.plugins.document.DocumentMK
The node store.
NodeTraversalCallback - Interface in org.apache.jackrabbit.oak.plugins.index
Callback which invoked for any changed node read by IndexUpdate as part of diff traversal
NodeTraversalCallback.PathSource - Interface in org.apache.jackrabbit.oak.plugins.index
Provides a way to lazily construct the path and provides access to the current path
nodeType(UniversalFilter.Selector, String[]) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder
A condition that holds for matching node types.
NODETYPE_OPTIMIZATION - Static variable in class org.apache.jackrabbit.oak.query.xpath.XPathToSQL2Converter
Optimize queries of the form "from [nt:base] where [jcr:primaryType] = 'x'" to "from [x] where [jcr:primaryType] = 'x'".
NODETYPE_UNION - Static variable in class org.apache.jackrabbit.oak.query.xpath.XPathToSQL2Converter
Convert queries of the form "where [jcr:primaryType] = 'x' or [jcr:primaryType] = 'y'" to "select ...
NodeTypeConstants - Interface in org.apache.jackrabbit.oak.plugins.nodetype
NodeTypeConstants...
NodeTypeDefDiff - Class in org.apache.jackrabbit.oak.plugins.nodetype
A NodeTypeDefDiff represents the result of the comparison of two node type definitions.
NodeTypeDefDiff.ChildNodeDefDiff - Class in org.apache.jackrabbit.oak.plugins.nodetype
 
NodeTypeDefDiff.PropDefDiff - Class in org.apache.jackrabbit.oak.plugins.nodetype
 
NodeTypeIndexProvider - Class in org.apache.jackrabbit.oak.plugins.index.nodetype
NodeTypeIndexProvider is a QueryIndexProvider for NodeTypeIndex instances.
NodeTypeIndexProvider() - Constructor for class org.apache.jackrabbit.oak.plugins.index.nodetype.NodeTypeIndexProvider
 
NodeTypeInfo - Interface in org.apache.jackrabbit.oak.query.ast
A nodetype info mechanism.
NodeTypeInfoProvider - Interface in org.apache.jackrabbit.oak.query.ast
A nodetype info mechanism.
NodeTypeRegistry - Class in org.apache.jackrabbit.oak.plugins.nodetype.write
BuiltInNodeTypes is a utility class that registers the built-in node types required for a JCR repository running on Oak.
NON_AGGREGATE_PRIVILEGES - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
The internal names of all built-in privileges that are not aggregates.
NON_MATCHING - Static variable in interface org.apache.jackrabbit.oak.plugins.document.bundlor.Matcher
 
NONE - Static variable in class org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeDefDiff
no modification
NOOP - Static variable in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundledTypesRegistry
 
NOOP - Static variable in interface org.apache.jackrabbit.oak.plugins.document.DocumentNodeStateCache
 
NOOP - Static variable in interface org.apache.jackrabbit.oak.plugins.index.CorruptIndexHandler
 
NOOP - Static variable in interface org.apache.jackrabbit.oak.plugins.index.IndexUpdateCallback
 
NOOP - Static variable in interface org.apache.jackrabbit.oak.plugins.index.NodeTraversalCallback
 
NOOP - Static variable in interface org.apache.jackrabbit.oak.plugins.index.progress.NodeCountEstimator
 
NOOP_LOCK - Static variable in interface org.apache.jackrabbit.oak.plugins.index.importer.AsyncIndexerLock
 
not(FilterBuilder.Condition) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder
A compound condition that holds when its constituent does not hold.
not(EventFilter) - Static method in class org.apache.jackrabbit.oak.plugins.observation.filter.Filters
A filter that matches if and only if any the filter passed to this method does not match.
not(ConstraintImpl) - Method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
 
NOT_BUNDLOR_PROPS - Static variable in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundlorUtils
 
notEarlierThan(long) - Method in class org.apache.jackrabbit.oak.plugins.document.util.TimeInterval
Shortens the interval to the specified start value, if is contained in the interval.
NotFullTextSearchImpl - Class in org.apache.jackrabbit.oak.query.ast
 
NotFullTextSearchImpl(String, String, StaticOperandImpl) - Constructor for class org.apache.jackrabbit.oak.query.ast.NotFullTextSearchImpl
 
NotFullTextSearchImpl(FullTextSearchImpl) - Constructor for class org.apache.jackrabbit.oak.query.ast.NotFullTextSearchImpl
 
NotImpl - Class in org.apache.jackrabbit.oak.query.ast
A "not" condition.
NotImpl(ConstraintImpl) - Constructor for class org.apache.jackrabbit.oak.query.ast.NotImpl
 
notLaterThan(long) - Method in class org.apache.jackrabbit.oak.plugins.document.util.TimeInterval
Shortens the interval to the specified end value, if is contained in the interval.
nsdata - Variable in class org.apache.jackrabbit.oak.plugins.name.ReadOnlyNamespaceRegistry
 
NT_ACTIVITY - Static variable in interface org.apache.jackrabbit.oak.plugins.version.VersionConstants
 
NT_CONFIGURATION - Static variable in interface org.apache.jackrabbit.oak.plugins.version.VersionConstants
 
NT_NAMES - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
 
NT_OAK_RESOURCE - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
NT_OAK_UNSTRUCTURED - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
NT_REP_ACE - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AccessControlConstants
 
NT_REP_ACL - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AccessControlConstants
 
NT_REP_AUTHORIZABLE - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
 
NT_REP_AUTHORIZABLE_FOLDER - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
 
NT_REP_CHILD_NODE_DEFINITION - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
NT_REP_CHILD_NODE_DEFINITIONS - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
NT_REP_DENY_ACE - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AccessControlConstants
 
NT_REP_GRANT_ACE - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AccessControlConstants
 
NT_REP_GROUP - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
 
NT_REP_MEMBER_REFERENCES - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
 
NT_REP_MEMBER_REFERENCES_LIST - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
 
NT_REP_MEMBERS - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
Deprecated.
NT_REP_NAMED_CHILD_NODE_DEFINITIONS - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
NT_REP_NAMED_PROPERTY_DEFINITIONS - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
NT_REP_NODE_TYPE - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
NT_REP_NODE_TYPES - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
NT_REP_PASSWORD - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
 
NT_REP_PERMISSION_STORE - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.PermissionConstants
 
NT_REP_PERMISSIONS - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.PermissionConstants
 
NT_REP_POLICY - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AccessControlConstants
 
NT_REP_PRIVILEGE - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
Node type name of the privilege definition nodes
NT_REP_PRIVILEGES - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
Node type name of the root node of the privilege store
NT_REP_PROPERTY_DEFINITION - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
NT_REP_PROPERTY_DEFINITIONS - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
NT_REP_RESTRICTIONS - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AccessControlConstants
 
NT_REP_ROOT - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
Constants for built-in repository defined node type names
NT_REP_SYSTEM - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
NT_REP_SYSTEM_USER - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
 
NT_REP_UNSTRUCTURED - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
NT_REP_USER - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
 
NULL - Static variable in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
Marker document, which indicates the document does not exist.
NULL - Static variable in class org.apache.jackrabbit.oak.spi.security.ConfigurationParameters.Milliseconds
 
NumericConstraint<T> - Class in org.apache.jackrabbit.oak.plugins.nodetype.constraint
 
NumericConstraint(String) - Constructor for class org.apache.jackrabbit.oak.plugins.nodetype.constraint.NumericConstraint
 

O

Oak - Class in org.apache.jackrabbit.oak
Builder class for constructing ContentRepository instances with a set of specified plugin components.
Oak(NodeStore) - Constructor for class org.apache.jackrabbit.oak.Oak
 
Oak() - Constructor for class org.apache.jackrabbit.oak.Oak
 
OAK_CHILD_ORDER - Static variable in interface org.apache.jackrabbit.oak.plugins.tree.impl.TreeConstants
Name of the internal property that contains the child order
OAK_DISCOVERYLITE_CLUSTERVIEW - Static variable in class org.apache.jackrabbit.oak.plugins.document.DocumentDiscoveryLiteService
Name of the repository descriptor via which the clusterView is published - which is the raison d'etre of the DocumentDiscoveryLiteService
OAK_QUERY_FAIL_TRAVERSAL - Static variable in class org.apache.jackrabbit.oak.query.QueryEngineSettings
 
OAK_QUERY_LIMIT_IN_MEMORY - Static variable in class org.apache.jackrabbit.oak.query.QueryEngineSettings
 
OAK_QUERY_LIMIT_READS - Static variable in class org.apache.jackrabbit.oak.query.QueryEngineSettings
 
OAK_SECURITY_NAME - Static variable in class org.apache.jackrabbit.oak.spi.security.RegistrationConstants
Name to be used when registering components that are required by the SecurityProviderRegistration
OakInitializer - Class in org.apache.jackrabbit.oak
 
OakVersion - Class in org.apache.jackrabbit.oak
Provides version information about Oak.
of(ConflictHandler) - Static method in class org.apache.jackrabbit.oak.plugins.commit.ConflictHook
of(ThreeWayConflictHandler) - Static method in class org.apache.jackrabbit.oak.plugins.commit.ConflictHook
 
of(long) - Static method in class org.apache.jackrabbit.oak.spi.security.ConfigurationParameters.Milliseconds
Returns a new milliseconds object from the given long value.
of(String) - Static method in class org.apache.jackrabbit.oak.spi.security.ConfigurationParameters.Milliseconds
Parses a value string into a duration.
of(String, ConfigurationParameters.Milliseconds) - Static method in class org.apache.jackrabbit.oak.spi.security.ConfigurationParameters.Milliseconds
 
of(ConfigurationParameters...) - Static method in class org.apache.jackrabbit.oak.spi.security.ConfigurationParameters
Creates a new configuration parameters instance by merging all params sequentially.
of(Properties) - Static method in class org.apache.jackrabbit.oak.spi.security.ConfigurationParameters
Creates new a configuration parameters instance by copying the given properties.
of(Dictionary<String, Object>) - Static method in class org.apache.jackrabbit.oak.spi.security.ConfigurationParameters
Creates new a configuration parameters instance by copying the given properties.
of(Map<?, ?>) - Static method in class org.apache.jackrabbit.oak.spi.security.ConfigurationParameters
Creates new a configuration parameters instance by copying the given map.
of(String, Object) - Static method in class org.apache.jackrabbit.oak.spi.security.ConfigurationParameters
Creates new a single valued configuration parameters instance from the given key and value.
of(String, Object, String, Object) - Static method in class org.apache.jackrabbit.oak.spi.security.ConfigurationParameters
Creates new a configuration parameters instance from the given key and value pairs.
of(List<PrincipalProvider>) - Static method in class org.apache.jackrabbit.oak.spi.security.principal.CompositePrincipalProvider
 
OFFSET_NONE - Static variable in class org.apache.jackrabbit.oak.security.user.query.ResultIterator
 
oldestRevisionEstimate - Variable in class org.apache.jackrabbit.oak.plugins.document.VersionGarbageCollector.VersionGCInfo
 
onCreate(Group, Root, NamePathMapper) - Method in class org.apache.jackrabbit.oak.spi.security.user.action.AbstractAuthorizableAction
Doesn't perform any action.
onCreate(User, String, Root, NamePathMapper) - Method in class org.apache.jackrabbit.oak.spi.security.user.action.AbstractAuthorizableAction
Doesn't perform any action.
onCreate(Group, Root, NamePathMapper) - Method in class org.apache.jackrabbit.oak.spi.security.user.action.AccessControlAction
 
onCreate(User, String, Root, NamePathMapper) - Method in class org.apache.jackrabbit.oak.spi.security.user.action.AccessControlAction
 
onCreate(Group, Root, NamePathMapper) - Method in interface org.apache.jackrabbit.oak.spi.security.user.action.AuthorizableAction
Allows to add application specific modifications or validation associated with the creation of a new group.
onCreate(User, String, Root, NamePathMapper) - Method in interface org.apache.jackrabbit.oak.spi.security.user.action.AuthorizableAction
Allows to add application specific modifications or validation associated with the creation of a new user.
onCreate(User, String, Root, NamePathMapper) - Method in class org.apache.jackrabbit.oak.spi.security.user.action.PasswordValidationAction
 
onMemberAdded(Group, Authorizable, Root, NamePathMapper) - Method in class org.apache.jackrabbit.oak.spi.security.user.action.AbstractGroupAction
Doesn't perform any action.
onMemberAdded(Group, Authorizable, Root, NamePathMapper) - Method in interface org.apache.jackrabbit.oak.spi.security.user.action.GroupAction
A specific Authorizable was added as a member of the Group.
onMemberRemoved(Group, Authorizable, Root, NamePathMapper) - Method in class org.apache.jackrabbit.oak.spi.security.user.action.AbstractGroupAction
Doesn't perform any action.
onMemberRemoved(Group, Authorizable, Root, NamePathMapper) - Method in interface org.apache.jackrabbit.oak.spi.security.user.action.GroupAction
A specific Authorizable was removed from the Group.
onMembersAdded(Group, Iterable<String>, Iterable<String>, Root, NamePathMapper) - Method in class org.apache.jackrabbit.oak.spi.security.user.action.AbstractGroupAction
Doesn't perform any action.
onMembersAdded(Group, Iterable<String>, Iterable<String>, Root, NamePathMapper) - Method in interface org.apache.jackrabbit.oak.spi.security.user.action.GroupAction
Multiple members were added to the Group.
onMembersAddedContentId(Group, Iterable<String>, Iterable<String>, Root, NamePathMapper) - Method in class org.apache.jackrabbit.oak.spi.security.user.action.AbstractGroupAction
Doesn't perform any action.
onMembersAddedContentId(Group, Iterable<String>, Iterable<String>, Root, NamePathMapper) - Method in interface org.apache.jackrabbit.oak.spi.security.user.action.GroupAction
Multiple members were added to the Group during XML group import.
onMembersRemoved(Group, Iterable<String>, Iterable<String>, Root, NamePathMapper) - Method in class org.apache.jackrabbit.oak.spi.security.user.action.AbstractGroupAction
Doesn't perform any action.
onMembersRemoved(Group, Iterable<String>, Iterable<String>, Root, NamePathMapper) - Method in interface org.apache.jackrabbit.oak.spi.security.user.action.GroupAction
Multiple members were removed from the Group.
onMissingIndex(String, NodeBuilder, String) - Method in class org.apache.jackrabbit.oak.plugins.index.IndexUpdate.MissingIndexProviderStrategy
 
onPasswordChange(User, String, Root, NamePathMapper) - Method in class org.apache.jackrabbit.oak.spi.security.user.action.AbstractAuthorizableAction
Doesn't perform any action.
onPasswordChange(User, String, Root, NamePathMapper) - Method in interface org.apache.jackrabbit.oak.spi.security.user.action.AuthorizableAction
Allows to add application specific action or validation associated with changing a user password.
onPasswordChange(User, String, Root, NamePathMapper) - Method in class org.apache.jackrabbit.oak.spi.security.user.action.PasswordChangeAction
 
onPasswordChange(User, String, Root, NamePathMapper) - Method in class org.apache.jackrabbit.oak.spi.security.user.action.PasswordValidationAction
 
onRemoval(RemovalNotification<K, V>) - Method in class org.apache.jackrabbit.oak.plugins.document.cache.ForwardingListener
 
onRemove(Authorizable, Root, NamePathMapper) - Method in class org.apache.jackrabbit.oak.spi.security.user.action.AbstractAuthorizableAction
Doesn't perform any action.
onRemove(Authorizable, Root, NamePathMapper) - Method in interface org.apache.jackrabbit.oak.spi.security.user.action.AuthorizableAction
Allows to add application specific behavior associated with the removal of an authorizable.
onRemove(Authorizable, Root, NamePathMapper) - Method in class org.apache.jackrabbit.oak.spi.security.user.action.ClearMembershipAction
 
onSessionRefresh() - Method in class org.apache.jackrabbit.oak.namepath.GlobalNameMapper
 
OP_NAME - Static variable in class org.apache.jackrabbit.oak.plugins.index.property.jmx.PropertyIndexAsyncReindex
 
open() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
Open the DocumentMK instance using the configured options.
OpenAuthenticationConfiguration - Class in org.apache.jackrabbit.oak.spi.security.authentication
This implementation of the authentication configuration provides login contexts that accept any credentials and doesn't validate specified workspace name.
OpenAuthenticationConfiguration() - Constructor for class org.apache.jackrabbit.oak.spi.security.authentication.OpenAuthenticationConfiguration
 
OpenAuthorizationConfiguration - Class in org.apache.jackrabbit.oak.spi.security.authorization
This class implements an AuthorizationConfiguration which grants full access to any Subject.
OpenAuthorizationConfiguration() - Constructor for class org.apache.jackrabbit.oak.spi.security.authorization.OpenAuthorizationConfiguration
 
openMap(int, String, MVMap.Builder<K, V>) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCache
 
OpenPermissionProvider - Class in org.apache.jackrabbit.oak.spi.security.authorization.permission
Permission provider implementation that grants full access everywhere.
OpenSecurityProvider - Class in org.apache.jackrabbit.oak.spi.security
Rudimentary SecurityProvider implementation that allow every subject to authenticate and grants it full access everywhere.
OpenSecurityProvider() - Constructor for class org.apache.jackrabbit.oak.spi.security.OpenSecurityProvider
 
Operator - Enum in org.apache.jackrabbit.oak.query.ast
The enumeration of all operators.
optimize() - Method in class org.apache.jackrabbit.oak.query.xpath.Statement
 
options - Variable in class org.apache.jackrabbit.oak.spi.security.authentication.AbstractLoginModule
 
or(ConstraintImpl, ConstraintImpl) - Method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
 
Order - Enum in org.apache.jackrabbit.oak.query.ast
The enumeration of query column orders (ascending and descending).
orderBefore(String) - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractMutableTree
 
orderBefore(String) - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.ImmutableTree
 
orderBefore(AccessControlEntry, AccessControlEntry) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.ImmutableACL
 
OrderedIndex - Interface in org.apache.jackrabbit.oak.plugins.index.property
interface for shared constants around different actors: QueryIndex, IndexEditors, IndexEditorProviders, ...
OrderedIndex.OrderDirection - Enum in org.apache.jackrabbit.oak.plugins.index.property
enum for easing the order direction of the index
OrderedPropertyIndexEditorProvider - Class in org.apache.jackrabbit.oak.plugins.index.property
 
OrderedPropertyIndexEditorProvider() - Constructor for class org.apache.jackrabbit.oak.plugins.index.property.OrderedPropertyIndexEditorProvider
 
OrderedPropertyIndexProvider - Class in org.apache.jackrabbit.oak.plugins.index.property
 
OrderedPropertyIndexProvider() - Constructor for class org.apache.jackrabbit.oak.plugins.index.property.OrderedPropertyIndexProvider
 
OrderingImpl - Class in org.apache.jackrabbit.oak.query.ast
An element of an "order by" list.
OrderingImpl(DynamicOperandImpl, Order) - Constructor for class org.apache.jackrabbit.oak.query.ast.OrderingImpl
 
org.apache.jackrabbit.oak - package org.apache.jackrabbit.oak
 
org.apache.jackrabbit.oak.cache.impl - package org.apache.jackrabbit.oak.cache.impl
 
org.apache.jackrabbit.oak.core - package org.apache.jackrabbit.oak.core
 
org.apache.jackrabbit.oak.management - package org.apache.jackrabbit.oak.management
 
org.apache.jackrabbit.oak.namepath - package org.apache.jackrabbit.oak.namepath
 
org.apache.jackrabbit.oak.plugins - package org.apache.jackrabbit.oak.plugins
Oak plugins.
org.apache.jackrabbit.oak.plugins.atomic - package org.apache.jackrabbit.oak.plugins.atomic
 
org.apache.jackrabbit.oak.plugins.commit - package org.apache.jackrabbit.oak.plugins.commit
 
org.apache.jackrabbit.oak.plugins.cow - package org.apache.jackrabbit.oak.plugins.cow
 
org.apache.jackrabbit.oak.plugins.document - package org.apache.jackrabbit.oak.plugins.document
 
org.apache.jackrabbit.oak.plugins.document.bundlor - package org.apache.jackrabbit.oak.plugins.document.bundlor
 
org.apache.jackrabbit.oak.plugins.document.cache - package org.apache.jackrabbit.oak.plugins.document.cache
 
org.apache.jackrabbit.oak.plugins.document.locks - package org.apache.jackrabbit.oak.plugins.document.locks
 
org.apache.jackrabbit.oak.plugins.document.memory - package org.apache.jackrabbit.oak.plugins.document.memory
 
org.apache.jackrabbit.oak.plugins.document.mongo - package org.apache.jackrabbit.oak.plugins.document.mongo
 
org.apache.jackrabbit.oak.plugins.document.mongo.replica - package org.apache.jackrabbit.oak.plugins.document.mongo.replica
 
org.apache.jackrabbit.oak.plugins.document.persistentCache - package org.apache.jackrabbit.oak.plugins.document.persistentCache
 
org.apache.jackrabbit.oak.plugins.document.persistentCache.async - package org.apache.jackrabbit.oak.plugins.document.persistentCache.async
 
org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast - package org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast
 
org.apache.jackrabbit.oak.plugins.document.rdb - package org.apache.jackrabbit.oak.plugins.document.rdb
Implementations of DocumentStore and BlobStore for relational databases.
org.apache.jackrabbit.oak.plugins.document.secondary - package org.apache.jackrabbit.oak.plugins.document.secondary
 
org.apache.jackrabbit.oak.plugins.document.spi - package org.apache.jackrabbit.oak.plugins.document.spi
 
org.apache.jackrabbit.oak.plugins.document.util - package org.apache.jackrabbit.oak.plugins.document.util
 
org.apache.jackrabbit.oak.plugins.identifier - package org.apache.jackrabbit.oak.plugins.identifier
 
org.apache.jackrabbit.oak.plugins.index - package org.apache.jackrabbit.oak.plugins.index
 
org.apache.jackrabbit.oak.plugins.index.aggregate - package org.apache.jackrabbit.oak.plugins.index.aggregate
 
org.apache.jackrabbit.oak.plugins.index.counter - package org.apache.jackrabbit.oak.plugins.index.counter
 
org.apache.jackrabbit.oak.plugins.index.counter.jmx - package org.apache.jackrabbit.oak.plugins.index.counter.jmx
 
org.apache.jackrabbit.oak.plugins.index.datastore - package org.apache.jackrabbit.oak.plugins.index.datastore
 
org.apache.jackrabbit.oak.plugins.index.diffindex - package org.apache.jackrabbit.oak.plugins.index.diffindex
 
org.apache.jackrabbit.oak.plugins.index.fulltext - package org.apache.jackrabbit.oak.plugins.index.fulltext
 
org.apache.jackrabbit.oak.plugins.index.importer - package org.apache.jackrabbit.oak.plugins.index.importer
 
org.apache.jackrabbit.oak.plugins.index.inventory - package org.apache.jackrabbit.oak.plugins.index.inventory
 
org.apache.jackrabbit.oak.plugins.index.nodetype - package org.apache.jackrabbit.oak.plugins.index.nodetype
 
org.apache.jackrabbit.oak.plugins.index.progress - package org.apache.jackrabbit.oak.plugins.index.progress
 
org.apache.jackrabbit.oak.plugins.index.property - package org.apache.jackrabbit.oak.plugins.index.property
 
org.apache.jackrabbit.oak.plugins.index.property.jmx - package org.apache.jackrabbit.oak.plugins.index.property.jmx
 
org.apache.jackrabbit.oak.plugins.index.property.strategy - package org.apache.jackrabbit.oak.plugins.index.property.strategy
 
org.apache.jackrabbit.oak.plugins.index.reference - package org.apache.jackrabbit.oak.plugins.index.reference
 
org.apache.jackrabbit.oak.plugins.itemsave - package org.apache.jackrabbit.oak.plugins.itemsave
 
org.apache.jackrabbit.oak.plugins.lock - package org.apache.jackrabbit.oak.plugins.lock
 
org.apache.jackrabbit.oak.plugins.metric - package org.apache.jackrabbit.oak.plugins.metric
 
org.apache.jackrabbit.oak.plugins.name - package org.apache.jackrabbit.oak.plugins.name
 
org.apache.jackrabbit.oak.plugins.nodetype - package org.apache.jackrabbit.oak.plugins.nodetype
 
org.apache.jackrabbit.oak.plugins.nodetype.constraint - package org.apache.jackrabbit.oak.plugins.nodetype.constraint
 
org.apache.jackrabbit.oak.plugins.nodetype.write - package org.apache.jackrabbit.oak.plugins.nodetype.write
 
org.apache.jackrabbit.oak.plugins.observation - package org.apache.jackrabbit.oak.plugins.observation
 
org.apache.jackrabbit.oak.plugins.observation.filter - package org.apache.jackrabbit.oak.plugins.observation.filter
 
org.apache.jackrabbit.oak.plugins.tree - package org.apache.jackrabbit.oak.plugins.tree
 
org.apache.jackrabbit.oak.plugins.tree.impl - package org.apache.jackrabbit.oak.plugins.tree.impl
 
org.apache.jackrabbit.oak.plugins.value.jcr - package org.apache.jackrabbit.oak.plugins.value.jcr
 
org.apache.jackrabbit.oak.plugins.version - package org.apache.jackrabbit.oak.plugins.version
 
org.apache.jackrabbit.oak.query - package org.apache.jackrabbit.oak.query
 
org.apache.jackrabbit.oak.query.ast - package org.apache.jackrabbit.oak.query.ast
 
org.apache.jackrabbit.oak.query.facet - package org.apache.jackrabbit.oak.query.facet
 
org.apache.jackrabbit.oak.query.index - package org.apache.jackrabbit.oak.query.index
 
org.apache.jackrabbit.oak.query.plan - package org.apache.jackrabbit.oak.query.plan
 
org.apache.jackrabbit.oak.query.stats - package org.apache.jackrabbit.oak.query.stats
 
org.apache.jackrabbit.oak.query.xpath - package org.apache.jackrabbit.oak.query.xpath
 
org.apache.jackrabbit.oak.security - package org.apache.jackrabbit.oak.security
 
org.apache.jackrabbit.oak.security.authentication - package org.apache.jackrabbit.oak.security.authentication
 
org.apache.jackrabbit.oak.security.authentication.token - package org.apache.jackrabbit.oak.security.authentication.token
 
org.apache.jackrabbit.oak.security.authentication.user - package org.apache.jackrabbit.oak.security.authentication.user
 
org.apache.jackrabbit.oak.security.authorization - package org.apache.jackrabbit.oak.security.authorization
 
org.apache.jackrabbit.oak.security.authorization.accesscontrol - package org.apache.jackrabbit.oak.security.authorization.accesscontrol
 
org.apache.jackrabbit.oak.security.authorization.composite - package org.apache.jackrabbit.oak.security.authorization.composite
 
org.apache.jackrabbit.oak.security.authorization.permission - package org.apache.jackrabbit.oak.security.authorization.permission
 
org.apache.jackrabbit.oak.security.authorization.restriction - package org.apache.jackrabbit.oak.security.authorization.restriction
 
org.apache.jackrabbit.oak.security.internal - package org.apache.jackrabbit.oak.security.internal
 
org.apache.jackrabbit.oak.security.principal - package org.apache.jackrabbit.oak.security.principal
 
org.apache.jackrabbit.oak.security.privilege - package org.apache.jackrabbit.oak.security.privilege
 
org.apache.jackrabbit.oak.security.user - package org.apache.jackrabbit.oak.security.user
 
org.apache.jackrabbit.oak.security.user.autosave - package org.apache.jackrabbit.oak.security.user.autosave
 
org.apache.jackrabbit.oak.security.user.query - package org.apache.jackrabbit.oak.security.user.query
 
org.apache.jackrabbit.oak.security.user.whiteboard - package org.apache.jackrabbit.oak.security.user.whiteboard
 
org.apache.jackrabbit.oak.spi.security - package org.apache.jackrabbit.oak.spi.security
 
org.apache.jackrabbit.oak.spi.security.authentication - package org.apache.jackrabbit.oak.spi.security.authentication
 
org.apache.jackrabbit.oak.spi.security.authentication.callback - package org.apache.jackrabbit.oak.spi.security.authentication.callback
 
org.apache.jackrabbit.oak.spi.security.authentication.credentials - package org.apache.jackrabbit.oak.spi.security.authentication.credentials
 
org.apache.jackrabbit.oak.spi.security.authentication.token - package org.apache.jackrabbit.oak.spi.security.authentication.token
 
org.apache.jackrabbit.oak.spi.security.authorization - package org.apache.jackrabbit.oak.spi.security.authorization
 
org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol - package org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol
 
org.apache.jackrabbit.oak.spi.security.authorization.permission - package org.apache.jackrabbit.oak.spi.security.authorization.permission
 
org.apache.jackrabbit.oak.spi.security.authorization.restriction - package org.apache.jackrabbit.oak.spi.security.authorization.restriction
 
org.apache.jackrabbit.oak.spi.security.principal - package org.apache.jackrabbit.oak.spi.security.principal
 
org.apache.jackrabbit.oak.spi.security.privilege - package org.apache.jackrabbit.oak.spi.security.privilege
 
org.apache.jackrabbit.oak.spi.security.user - package org.apache.jackrabbit.oak.spi.security.user
 
org.apache.jackrabbit.oak.spi.security.user.action - package org.apache.jackrabbit.oak.spi.security.user.action
 
org.apache.jackrabbit.oak.spi.security.user.util - package org.apache.jackrabbit.oak.spi.security.user.util
 
org.apache.jackrabbit.oak.spi.xml - package org.apache.jackrabbit.oak.spi.xml
 
OrImpl - Class in org.apache.jackrabbit.oak.query.ast
An "or" condition.
OrImpl(List<ConstraintImpl>) - Constructor for class org.apache.jackrabbit.oak.query.ast.OrImpl
 
OrImpl(ConstraintImpl, ConstraintImpl) - Constructor for class org.apache.jackrabbit.oak.query.ast.OrImpl
 
OURS - Static variable in class org.apache.jackrabbit.oak.plugins.commit.DefaultConflictHandler
Deprecated.
A ConflictHandler which always return oak.spi.commit.ConflictHandler.Resolution.
OURS - Static variable in class org.apache.jackrabbit.oak.plugins.commit.DefaultThreeWayConflictHandler
A ConflictHandler which always return ThreeWayConflictHandler.Resolution.OURS.
overflowToDiskThreshold - Variable in class org.apache.jackrabbit.oak.plugins.document.VersionGCOptions
 

P

PARAM_ADMIN_ID - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
Configuration option defining the ID of the administrator user.
PARAM_ADMINISTRATIVE_PRINCIPALS - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.PermissionConstants
Configuration parameter specifying additional principals that should be treated as 'administrator' thus get granted full permissions on the complete repository content.
PARAM_ANONYMOUS_ID - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
Configuration option defining the ID of the anonymous user.
PARAM_APP_NAME - Static variable in interface org.apache.jackrabbit.oak.spi.security.authentication.AuthenticationConfiguration
 
PARAM_AUTHORIZABLE_ACTION_PROVIDER - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
Optional configuration parameter to set the AuthorizableActionProvider to be used with the given user management implementation.
PARAM_AUTHORIZABLE_NODE_NAME - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
Optional configuration parameter defining how to generate the name of the authorizable node from the ID of the new authorizable that is being created.
PARAM_CONFIG_SPI_NAME - Static variable in interface org.apache.jackrabbit.oak.spi.security.authentication.AuthenticationConfiguration
 
PARAM_DEFAULT_DEPTH - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
Parameter used to change the number of levels that are used by default to store authorizable nodes.
The default number of levels is 2.
PARAM_ENABLE_RFC7613_USERCASE_MAPPED_PROFILE - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
Optionally enables the UsernameCaseMapped profile defined in https://tools.ietf.org/html/rfc7613#section-3.2 for user name comparison.
PARAM_GROUP_PATH - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
Configuration option to define the path underneath which group nodes are being created.
PARAM_IMPORT_BEHAVIOR - Static variable in interface org.apache.jackrabbit.oak.spi.xml.ProtectedItemImporter
Parameter name for the import behavior configuration option.
PARAM_MOUNT_PROVIDER - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AccessControlConstants
 
PARAM_OMIT_ADMIN_PW - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
Configuration option defining if the admin password should be omitted upon user creation.
PARAM_PASSWORD_HASH_ALGORITHM - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
Configuration parameter to change the default algorithm used to generate password hashes.
PARAM_PASSWORD_HASH_ITERATIONS - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
Configuration parameter to change the number of iterations used for password hash generation.
PARAM_PASSWORD_HISTORY_SIZE - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
Optional configuration parameter indicating the maximum number of passwords recorded for a user after password changes.
PARAM_PASSWORD_INITIAL_CHANGE - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
Optional configuration parameter indicating whether users must change their passwords on first login.
PARAM_PASSWORD_MAX_AGE - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
Optional configuration parameter indicating the maximum age in days a password may have before it expires.
PARAM_PASSWORD_SALT_SIZE - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
Configuration parameter to change the number of iterations used for password hash generation.
PARAM_PERMISSIONS_JR2 - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.PermissionConstants
Configuration parameter to enforce backwards compatible permission validation with respect to user management and node removal: User Management: As of OAK 1.0 creation/removal of user and groups as well as modification of user/group specific protected properties requires USER_MANAGEMENT permissions while in Jackrabbit 2.0 they were covered by regular item write permissions. Removing Nodes: As of OAK 1.0 removing a node will succeed if the removal is granted on that specific node irrespective of the permission granted or denied within the subtree.
PARAM_RANKING - Static variable in class org.apache.jackrabbit.oak.spi.security.CompositeConfiguration
Parameter used to define the ranking of a given configuration compared to other registered configuration in this aggregate.
PARAM_READ_PATHS - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.PermissionConstants
Configuration parameter to enable full read access to regular nodes and properties at the specified paths.
PARAM_RESTRICTION_PROVIDER - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AccessControlConstants
 
PARAM_SUPPORT_AUTOSAVE - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
Optional configuration parameter that might be used to get back support for the auto-save behavior which has been dropped in the default user management implementation present with OAK.
PARAM_SYSTEM_RELATIVE_PATH - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
Configuration option to define the path relative to the user root node underneath which system user nodes are being created.
PARAM_TOKEN_EXPIRATION - Static variable in interface org.apache.jackrabbit.oak.spi.security.authentication.token.TokenProvider
Optional configuration parameter to set the token expiration time in ms.
PARAM_TOKEN_LENGTH - Static variable in interface org.apache.jackrabbit.oak.spi.security.authentication.token.TokenProvider
Optional configuration parameter to define the length of the key.
PARAM_TOKEN_REFRESH - Static variable in interface org.apache.jackrabbit.oak.spi.security.authentication.token.TokenProvider
Optional configuration parameter to define if a given token should be refreshed or not.
PARAM_USER_AUTHENTICATION_FACTORY - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
Mandatory configuration option denoting the user Authentication implementation to use in the login module.
PARAM_USER_PATH - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
Configuration option to define the path underneath which user nodes are being created.
PARENT - Static variable in class org.apache.jackrabbit.oak.plugins.observation.filter.Selectors
A selector returning the parent node of the item for which a call back on EventFilter was called.
parse(String, JcrNameParser.Listener, int) - Static method in class org.apache.jackrabbit.oak.namepath.JcrNameParser
Parse the specified jcr name and inform the specified listener about the result or any error that may occur during parsing.
parse(String, JcrPathParser.Listener) - Static method in class org.apache.jackrabbit.oak.namepath.JcrPathParser
 
parse(String) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBJSONSupport
Parses the supplied JSON.
parse(JsopTokenizer) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBJSONSupport
Parses the supplied JSON.
parse(String, String) - Method in interface org.apache.jackrabbit.oak.query.QueryParser
Parses the given query string, expressed in the specified language.
parse(String, boolean) - Method in class org.apache.jackrabbit.oak.query.SQL2Parser
Parse the statement and return the query.
parse(String) - Method in class org.apache.jackrabbit.oak.query.SQL2Parser
as SQL2Parser.parse(String, boolean) by providing true to the initialisation flag.
parseDel(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBExport
 
PASSWORD_HISTORY_DISABLED_SIZE - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
Constant to indicate disabled password history, which is the default.
PasswordChangeAction - Class in org.apache.jackrabbit.oak.spi.security.user.action
PasswordChangeAction() - Constructor for class org.apache.jackrabbit.oak.spi.security.user.action.PasswordChangeAction
 
PasswordUtil - Class in org.apache.jackrabbit.oak.spi.security.user.util
Utility to generate and compare password hashes.
PasswordValidationAction - Class in org.apache.jackrabbit.oak.spi.security.user.action
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.
PasswordValidationAction() - Constructor for class org.apache.jackrabbit.oak.spi.security.user.action.PasswordValidationAction
 
PATH - Static variable in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
The node path, in case the id can not be converted to a path.
path(String) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder
A condition that holds on the paths matching a certain pattern.
PathComparator - Class in org.apache.jackrabbit.oak.plugins.document
Implements a comparator, which sorts path string according to 1) their depth (highest first) and 2) the path string itself.
PathConstraint - Class in org.apache.jackrabbit.oak.plugins.nodetype.constraint
 
PathConstraint(String) - Constructor for class org.apache.jackrabbit.oak.plugins.nodetype.constraint.PathConstraint
 
PathCursor(Iterator<String>, boolean, QueryLimits) - Constructor for class org.apache.jackrabbit.oak.plugins.index.Cursors.PathCursor
 
pathDepth(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
 
pathFilter(PathFilter) - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.SecondaryStoreBuilder
 
PathFilter - Class in org.apache.jackrabbit.oak.plugins.index
Filter which determines whether given path should be included for processing or not
PathFilter(Iterable<String>, Iterable<String>) - Constructor for class org.apache.jackrabbit.oak.plugins.index.PathFilter
Constructs the predicate with given included and excluded paths If both are empty then all paths would be considered to be included
PathFilter.Result - Enum in org.apache.jackrabbit.oak.plugins.index
 
PathMapper - Interface in org.apache.jackrabbit.oak.namepath
PathMapper instances provide methods for mapping paths from their JCR string representation to their Oak representation and vice versa.
PathRev - Class in org.apache.jackrabbit.oak.plugins.document
A cache key implementation, which is a combination of a path string and a revision.
PathRev(String, RevisionVector) - Constructor for class org.apache.jackrabbit.oak.plugins.document.PathRev
 
pathToId(Iterable<String>) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
Transforms the given paths into ids using Utils.getIdFromPath(String).
PathTracker - Class in org.apache.jackrabbit.oak.namepath
Simple utility class for lazily tracking the current path during a tree traversal that recurses down a subtree.
PathTracker() - Constructor for class org.apache.jackrabbit.oak.namepath.PathTracker
 
PERF_LOG_THRESHOLD - Static variable in class org.apache.jackrabbit.oak.plugins.document.DocumentStoreStats
 
performLeaseCheck() - Method in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfo
Checks if the lease for this cluster node is still valid, otherwise throws a DocumentStoreException.
performRecoveryIfNeeded() - Method in class org.apache.jackrabbit.oak.plugins.document.LastRevRecoveryAgent
 
PERMISSION_NAMES - Static variable in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
 
PERMISSION_NODE_NAMES - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.PermissionConstants
 
PERMISSION_NODETYPE_NAMES - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.PermissionConstants
 
PERMISSION_PROPERTY_NAMES - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.PermissionConstants
 
PermissionConstants - Interface in org.apache.jackrabbit.oak.spi.security.authorization.permission
Implementation specific constants related to permission evaluation.
PermissionHook - Class in org.apache.jackrabbit.oak.security.authorization.permission
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.
PermissionHook(String, RestrictionProvider, MountInfoProvider) - Constructor for class org.apache.jackrabbit.oak.security.authorization.permission.PermissionHook
 
PermissionProvider - Interface in org.apache.jackrabbit.oak.spi.security.authorization.permission
Main entry point for permission evaluation in Oak.
PermissionProviderFactory - Interface in org.apache.jackrabbit.oak.plugins.observation.filter
Factory for PermissionProvider instances.
PermissionProviderImpl - Class in org.apache.jackrabbit.oak.security.authorization.permission
 
PermissionProviderImpl(Root, String, Set<Principal>, RestrictionProvider, ConfigurationParameters, Context) - Constructor for class org.apache.jackrabbit.oak.security.authorization.permission.PermissionProviderImpl
 
Permissions - Class in org.apache.jackrabbit.oak.spi.security.authorization.permission
Provides constants for permissions used in the OAK access evaluation as well as permission related utility methods.
PERMISSIONS_STORE_PATH - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.PermissionConstants
 
PermissionStoreValidatorProvider - Class in org.apache.jackrabbit.oak.security.authorization.permission
Validator implementation that asserts that the permission store is read-only.
PermissionStoreValidatorProvider() - Constructor for class org.apache.jackrabbit.oak.security.authorization.permission.PermissionStoreValidatorProvider
 
PermissionUtil - Class in org.apache.jackrabbit.oak.security.authorization.permission
Utility methods to evaluate permissions.
PermissionValidatorProvider - Class in org.apache.jackrabbit.oak.security.authorization.permission
ValidatorProvider implementation for permission evaluation associated with write operations.
PermissionValidatorProvider(SecurityProvider, String, Set<Principal>, MoveTracker) - Constructor for class org.apache.jackrabbit.oak.security.authorization.permission.PermissionValidatorProvider
 
PersistentCache - Class in org.apache.jackrabbit.oak.plugins.document.persistentCache
A persistent cache for the document store.
PersistentCache(String) - Constructor for class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCache
 
PersistentCacheStats - Class in org.apache.jackrabbit.oak.plugins.document.persistentCache
Persistence Cache Statistics.
PersistentCacheStats(CacheType, StatisticsProvider) - Constructor for class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
pmax(RevisionVector) - Method in class org.apache.jackrabbit.oak.plugins.document.RevisionVector
Calculates the parallel maximum of this and the given vector.
pmin(RevisionVector) - Method in class org.apache.jackrabbit.oak.plugins.document.RevisionVector
Calculates the parallel minimum of this and the given vector.
POLICY_NODE_NAMES - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AccessControlConstants
 
PolicyOwner - Interface in org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol
Interface to improve pluggability of the AccessControlManager, namely the interaction of multiple managers within a single repository.
PRE_AUTHENTICATED - Static variable in class org.apache.jackrabbit.oak.spi.security.authentication.PreAuthenticatedLogin
 
PreAuthContext - Class in org.apache.jackrabbit.oak.spi.security.authentication
LoginContext for pre-authenticated subjects that don't require further validation nor additional login/logout steps.
PreAuthContext(Subject) - Constructor for class org.apache.jackrabbit.oak.spi.security.authentication.PreAuthContext
 
PreAuthenticatedLogin - Class in org.apache.jackrabbit.oak.spi.security.authentication
PreAuthenticatedLogin is used as marker in the shared map of the login context.
PreAuthenticatedLogin(String) - Constructor for class org.apache.jackrabbit.oak.spi.security.authentication.PreAuthenticatedLogin
 
precisionMs - Variable in class org.apache.jackrabbit.oak.plugins.document.VersionGCOptions
 
PreExtractedTextProvider - Interface in org.apache.jackrabbit.oak.plugins.index.fulltext
 
PREFIX_PROP_COUNTER - Static variable in class org.apache.jackrabbit.oak.plugins.atomic.AtomicCounterEditor
prefix used internally for tracking the counting requests
PREFIX_PROP_REVISION - Static variable in class org.apache.jackrabbit.oak.plugins.atomic.AtomicCounterEditor
prefix used internally for tracking the cluster node related revision numbers
PREFIX_REP - Static variable in interface org.apache.jackrabbit.oak.plugins.name.NamespaceConstants
 
PREFIX_SV - Static variable in interface org.apache.jackrabbit.oak.plugins.name.NamespaceConstants
 
PREFIX_XMLNS - Static variable in interface org.apache.jackrabbit.oak.plugins.name.NamespaceConstants
 
prepare(String) - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate.AsyncUpdateCallback
 
prepare(ExecutionPlan) - Method in class org.apache.jackrabbit.oak.query.ast.JoinImpl
 
prepare() - Method in class org.apache.jackrabbit.oak.query.ast.JoinImpl
 
prepare(ExecutionPlan) - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
 
prepare() - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
 
prepare() - Method in class org.apache.jackrabbit.oak.query.ast.SourceImpl
Prepare executing the query (recursively).
prepare(ExecutionPlan) - Method in class org.apache.jackrabbit.oak.query.ast.SourceImpl
Re-apply a previously prepared plan.
prepare() - Method in interface org.apache.jackrabbit.oak.query.Query
Prepare the query.
prepare() - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
prepare() - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
PrincipalConfiguration - Interface in org.apache.jackrabbit.oak.spi.security.principal
Configuration interface for principal management.
PrincipalConfigurationImpl - Class in org.apache.jackrabbit.oak.security.principal
Default implementation of the PrincipalConfiguration
PrincipalConfigurationImpl() - Constructor for class org.apache.jackrabbit.oak.security.principal.PrincipalConfigurationImpl
 
PrincipalConfigurationImpl(SecurityProvider) - Constructor for class org.apache.jackrabbit.oak.security.principal.PrincipalConfigurationImpl
 
PrincipalImpl - Class in org.apache.jackrabbit.oak.spi.security.principal
Default implementation of the JackrabbitPrincipal interface.
PrincipalImpl(String) - Constructor for class org.apache.jackrabbit.oak.spi.security.principal.PrincipalImpl
 
PrincipalIteratorAdapter - Class in org.apache.jackrabbit.oak.spi.security.principal
Principal specific RangeIteratorAdapter implementing the PrincipalIterator interface.
PrincipalIteratorAdapter(Iterator<? extends Principal>) - Constructor for class org.apache.jackrabbit.oak.spi.security.principal.PrincipalIteratorAdapter
Creates an adapter for the given Iterator of principals.
PrincipalIteratorAdapter(Collection<? extends Principal>) - Constructor for class org.apache.jackrabbit.oak.spi.security.principal.PrincipalIteratorAdapter
Creates an iterator for the given collection of Principals.
PrincipalManagerImpl - Class in org.apache.jackrabbit.oak.spi.security.principal
Default implementation of the PrincipalManager interface.
PrincipalManagerImpl(PrincipalProvider) - Constructor for class org.apache.jackrabbit.oak.spi.security.principal.PrincipalManagerImpl
 
PrincipalProvider - Interface in org.apache.jackrabbit.oak.spi.security.principal
The PrincipalProvider defines methods to provide access to sources of Principals.
PrincipalProviderCallback - Class in org.apache.jackrabbit.oak.spi.security.authentication.callback
Callback implementation used to pass a PrincipalProvider to the login module.
PrincipalProviderCallback() - Constructor for class org.apache.jackrabbit.oak.spi.security.authentication.callback.PrincipalProviderCallback
 
PrincipalRestrictionProvider - Class in org.apache.jackrabbit.oak.security.authorization.restriction
Restriction provider implementation used for editing access control by principal.
PrincipalRestrictionProvider(RestrictionProvider) - Constructor for class org.apache.jackrabbit.oak.security.authorization.restriction.PrincipalRestrictionProvider
 
print(PrintWriter, Format, boolean) - Method in class org.apache.jackrabbit.oak.plugins.index.inventory.IndexDefinitionPrinter
 
print(PrintWriter, Format, boolean) - Method in class org.apache.jackrabbit.oak.plugins.index.inventory.IndexPrinter
 
PRIVILEGE_MANAGEMENT - Static variable in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
 
PRIVILEGE_NODETYPE_NAMES - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
Node type names associated with privilege content
PRIVILEGE_PROPERTY_NAMES - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
The internal names of all property definitions that are associated with the rep:Privilege node type
PrivilegeBits - Class in org.apache.jackrabbit.oak.spi.security.privilege
Internal representation of JCR privileges.
PrivilegeBitsProvider - Class in org.apache.jackrabbit.oak.spi.security.privilege
Reads and writes privilege definitions from and to the repository content without applying any validation.
PrivilegeBitsProvider(Root) - Constructor for class org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeBitsProvider
 
PrivilegeConfiguration - Interface in org.apache.jackrabbit.oak.spi.security.privilege
Interface for the privilege management configuration.
PrivilegeConfigurationImpl - Class in org.apache.jackrabbit.oak.security.privilege
Configuration for the privilege management component.
PrivilegeConfigurationImpl() - Constructor for class org.apache.jackrabbit.oak.security.privilege.PrivilegeConfigurationImpl
 
PrivilegeConstants - Interface in org.apache.jackrabbit.oak.spi.security.privilege
Internal name constants used for the privilege management.
PrivilegeDefinition - Interface in org.apache.jackrabbit.oak.spi.security.privilege
The PrivilegeDefinition interface defines the characteristics of a JCR Privilege.
privilegeFromName(String) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AbstractAccessControlManager
 
PRIVILEGES_PATH - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
Internal (oak) path for the privilege store.
PrivilegeUtil - Class in org.apache.jackrabbit.oak.spi.security.privilege
Privilege management related utility methods.
processCommit(NodeState, NodeState, CommitInfo) - Method in enum org.apache.jackrabbit.oak.core.ResetCommitAttributeHook
 
processCommit(NodeState, NodeState, CommitInfo) - Method in class org.apache.jackrabbit.oak.plugins.commit.ConflictHook
 
processCommit(NodeState, NodeState, CommitInfo) - Method in class org.apache.jackrabbit.oak.plugins.observation.CommitRateLimiter
 
processCommit(NodeState, NodeState, CommitInfo) - Method in class org.apache.jackrabbit.oak.plugins.version.VersionablePathHook
 
processCommit(NodeState, NodeState, CommitInfo) - Method in class org.apache.jackrabbit.oak.plugins.version.VersionHook
 
processCommit(NodeState, NodeState, CommitInfo) - Method in class org.apache.jackrabbit.oak.security.authorization.permission.PermissionHook
 
processedReference(Object) - Method in class org.apache.jackrabbit.oak.spi.xml.ReferenceChangeTracker
Store the given reference property for later retrieval using ReferenceChangeTracker.getProcessedReferences().
processReferences() - Method in class org.apache.jackrabbit.oak.security.authorization.accesscontrol.AccessControlImporter
 
processReferences() - Method in interface org.apache.jackrabbit.oak.spi.xml.ProtectedItemImporter
Post processing protected reference properties underneath a protected or non-protected parent node.
PROP_ASYNC_NAME - Static variable in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate
Name of service property which determines the name of Async task
PROP_BLOB_GC_MAX_AGE - Static variable in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreService
 
PROP_BLOB_SNAPSHOT_INTERVAL - Static variable in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreService
 
PROP_COUNTER - Static variable in class org.apache.jackrabbit.oak.plugins.atomic.AtomicCounterEditor
property with the consolidated counter
PROP_DISABLED - Static variable in class org.apache.jackrabbit.oak.plugins.document.bundlor.DocumentBundlor
Boolean property.
PROP_DS_TYPE - Static variable in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreService
 
PROP_EXCLUDED_PATHS - Static variable in class org.apache.jackrabbit.oak.plugins.index.PathFilter
Multi value property name used to determine list of paths to be excluded
PROP_INCLUDED_PATHS - Static variable in class org.apache.jackrabbit.oak.plugins.index.PathFilter
Multi value property name used to determine list of paths to be included
PROP_INCREMENT - Static variable in class org.apache.jackrabbit.oak.plugins.atomic.AtomicCounterEditor
property to be set for incrementing/decrementing the counter
PROP_INDEX_PATH - Static variable in class org.apache.jackrabbit.oak.plugins.index.importer.IndexerInfo
Property name in index-details.txt which refers to the index path in repository
PROP_LAST_REV - Static variable in class org.apache.jackrabbit.oak.plugins.document.secondary.DelegatingDocumentNodeState
 
PROP_PATTERN - Static variable in class org.apache.jackrabbit.oak.plugins.document.bundlor.DocumentBundlor
 
PROP_PREFETCH_EXTERNAL_CHANGES - Static variable in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreService
 
PROP_REPLICATION_LAG - Static variable in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreService
 
PROP_REV_RECOVERY_INTERVAL - Static variable in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreService
 
PROP_REVISION - Static variable in class org.apache.jackrabbit.oak.plugins.document.secondary.DelegatingDocumentNodeState
 
PROP_ROLE - Static variable in class org.apache.jackrabbit.oak.plugins.cow.COWNodeStoreService
 
PROP_ROLE - Static variable in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreService
 
PROP_UPDATE_LIMIT - Static variable in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreService
 
PROP_VER_GC_CONTINUOUS - Static variable in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreService
 
PROP_VER_GC_MAX_AGE - Static variable in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreService
 
propertiesCompleted(Tree) - Method in interface org.apache.jackrabbit.oak.spi.xml.ProtectedPropertyImporter
Informs this importer that all properties to be imported below protectedParent have been processed by the importer.
property(UniversalFilter.Selector, String, Predicate<PropertyState>) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder
A condition that holds when the property predicate matches.
PROPERTY_NAMES - Static variable in interface org.apache.jackrabbit.oak.plugins.index.IndexConstants
Defines the names of the properties that are covered by a specific property index definition.
PROPERTY_OR_DELETED - Static variable in class org.apache.jackrabbit.oak.plugins.document.util.Utils
A predicate for property and _deleted names.
propertyAdded(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.atomic.AtomicCounterEditor
 
propertyAdded(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.commit.ConflictValidator
 
propertyAdded(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.document.util.CountingDiff
 
propertyAdded(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.index.counter.NodeCounterEditor
 
propertyAdded(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.index.IndexUpdate
 
propertyAdded(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.observation.DefaultEventHandler
 
propertyAdded(PropertyState) - Method in interface org.apache.jackrabbit.oak.plugins.observation.EventHandler
Notification for an added property
propertyAdded(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.observation.FilteredHandler
 
propertyChanged(PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.commit.ConflictValidator
 
propertyChanged(PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.document.util.CountingDiff
 
propertyChanged(PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.index.counter.NodeCounterEditor
 
propertyChanged(PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.index.IndexUpdate
 
propertyChanged(PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.observation.DefaultEventHandler
 
propertyChanged(PropertyState, PropertyState) - Method in interface org.apache.jackrabbit.oak.plugins.observation.EventHandler
Notification for a changed property
propertyChanged(PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.observation.FilteredHandler
 
propertyDeleted(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.document.util.CountingDiff
 
propertyDeleted(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.index.counter.NodeCounterEditor
 
propertyDeleted(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.index.IndexUpdate
 
propertyDeleted(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.observation.DefaultEventHandler
 
propertyDeleted(PropertyState) - Method in interface org.apache.jackrabbit.oak.plugins.observation.EventHandler
Notification for a deleted property
propertyDeleted(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.observation.FilteredHandler
 
propertyExistence(String, String) - Method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
 
PropertyExistenceImpl - Class in org.apache.jackrabbit.oak.query.ast
A condition to check if the property exists ("is not null").
PropertyExistenceImpl(SelectorImpl, String, String) - Constructor for class org.apache.jackrabbit.oak.query.ast.PropertyExistenceImpl
 
PropertyExistenceImpl(String, String) - Constructor for class org.apache.jackrabbit.oak.query.ast.PropertyExistenceImpl
 
PropertyIndexAsyncReindex - Class in org.apache.jackrabbit.oak.plugins.index.property.jmx
Default implementation of PropertyIndexAsyncReindexMBean based on a Runnable.
PropertyIndexAsyncReindex(AsyncIndexUpdate, Executor) - Constructor for class org.apache.jackrabbit.oak.plugins.index.property.jmx.PropertyIndexAsyncReindex
 
PropertyIndexAsyncReindexMBean - Interface in org.apache.jackrabbit.oak.plugins.index.property.jmx
MBean for starting and monitoring the progress of asynchronous reindexing of the property index
PropertyIndexEditorProvider - Class in org.apache.jackrabbit.oak.plugins.index.property
Service that provides PropertyIndex based editors.
PropertyIndexEditorProvider() - Constructor for class org.apache.jackrabbit.oak.plugins.index.property.PropertyIndexEditorProvider
 
PropertyIndexInfoProvider - Class in org.apache.jackrabbit.oak.plugins.index.property
 
PropertyIndexInfoProvider() - Constructor for class org.apache.jackrabbit.oak.plugins.index.property.PropertyIndexInfoProvider
 
PropertyIndexInfoProvider(NodeStore) - Constructor for class org.apache.jackrabbit.oak.plugins.index.property.PropertyIndexInfoProvider
 
PropertyIndexLookup - Class in org.apache.jackrabbit.oak.plugins.index.property
Is responsible for querying the property index content.
PropertyIndexLookup(NodeState) - Constructor for class org.apache.jackrabbit.oak.plugins.index.property.PropertyIndexLookup
 
PropertyIndexLookup(NodeState, MountInfoProvider) - Constructor for class org.apache.jackrabbit.oak.plugins.index.property.PropertyIndexLookup
 
PropertyIndexPlan - Class in org.apache.jackrabbit.oak.plugins.index.property
Plan for querying a given property index using a given filter.
PropertyIndexProvider - Class in org.apache.jackrabbit.oak.plugins.index.property
A provider for property indexes.
PropertyIndexProvider() - Constructor for class org.apache.jackrabbit.oak.plugins.index.property.PropertyIndexProvider
 
PropertyIndexStats - Class in org.apache.jackrabbit.oak.plugins.index.property.jmx
 
PropertyIndexStats() - Constructor for class org.apache.jackrabbit.oak.plugins.index.property.jmx.PropertyIndexStats
 
PropertyIndexStatsMBean - Interface in org.apache.jackrabbit.oak.plugins.index.property.jmx
 
propertyInexistence(String, String) - Method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
 
PropertyInexistenceImpl - Class in org.apache.jackrabbit.oak.query.ast
A condition to check if the property does not exist ("is null").
PropertyInexistenceImpl(SelectorImpl, String, String) - Constructor for class org.apache.jackrabbit.oak.query.ast.PropertyInexistenceImpl
 
PropertyInexistenceImpl(String, String) - Constructor for class org.apache.jackrabbit.oak.query.ast.PropertyInexistenceImpl
 
PropertyPredicate - Class in org.apache.jackrabbit.oak.plugins.observation.filter
Predicate on property values.
PropertyPredicate(String, Predicate<PropertyState>) - Constructor for class org.apache.jackrabbit.oak.plugins.observation.filter.PropertyPredicate
 
propertyValue(String, String) - Method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
 
propertyValue(String, String, String) - Method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
 
PropertyValueImpl - Class in org.apache.jackrabbit.oak.query.ast
A property expression.
PropertyValueImpl(String, String) - Constructor for class org.apache.jackrabbit.oak.query.ast.PropertyValueImpl
 
PropertyValueImpl(String, String, String) - Constructor for class org.apache.jackrabbit.oak.query.ast.PropertyValueImpl
 
PropInfo - Class in org.apache.jackrabbit.oak.spi.xml
Information about a property being imported.
PropInfo(String, int, TextValue) - Constructor for class org.apache.jackrabbit.oak.spi.xml.PropInfo
Creates a property information instance.
PropInfo(String, int, List<? extends TextValue>) - Constructor for class org.apache.jackrabbit.oak.spi.xml.PropInfo
Creates a property information instance.
PropInfo(String, int, List<? extends TextValue>, PropInfo.MultipleStatus) - Constructor for class org.apache.jackrabbit.oak.spi.xml.PropInfo
Creates a property information instance.
PropInfo.MultipleStatus - Enum in org.apache.jackrabbit.oak.spi.xml
Hint indicating whether the property is multi- or single-value
ProtectedItemImporter - Interface in org.apache.jackrabbit.oak.spi.xml
ProtectedNodeImporter - Interface in org.apache.jackrabbit.oak.spi.xml
ProtectedNodeImporter provides means to import protected Nodes and the subtree defined below such nodes.
ProtectedPropertyImporter - Interface in org.apache.jackrabbit.oak.spi.xml
ProtectedPropertyImporter is in charge of importing single properties with a protected PropertyDefinition.
pullOrRight() - Method in class org.apache.jackrabbit.oak.query.ast.AndImpl
 
put(String) - Method in class org.apache.jackrabbit.oak.plugins.document.cache.CacheChangesTracker.LazyBloomFilter
 
put(NodeDocument) - Method in class org.apache.jackrabbit.oak.plugins.document.cache.NodeDocumentCache
Puts document into cache.
put(String, Object) - Method in class org.apache.jackrabbit.oak.plugins.document.Document
Sets the data for the given key.
put(String, Object) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.RevisionEntry
 
put(K, V) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.CacheMap
 
put(K, V) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.MultiGenerationMap
 
put(String, Object) - Method in class org.apache.jackrabbit.oak.spi.security.ConfigurationParameters
put(String, String) - Method in class org.apache.jackrabbit.oak.spi.xml.ReferenceChangeTracker
Store the given id mapping for later lookup using ReferenceChangeTracker.get(String).
putAll(BSONObject) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.RevisionEntry
 
putAll(Map) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.RevisionEntry
 
putAll(Map<? extends K, ? extends V>) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.MultiGenerationMap
 
putAll(Map<? extends String, ?>) - Method in class org.apache.jackrabbit.oak.spi.security.ConfigurationParameters
putDocument(String) - Method in class org.apache.jackrabbit.oak.plugins.document.cache.CacheChangesTracker
 
putIfAbsent(NodeDocument) - Method in class org.apache.jackrabbit.oak.plugins.document.cache.NodeDocumentCache
Puts document into cache iff no entry with the given key is cached already.
putIfNewer(NodeDocument) - Method in class org.apache.jackrabbit.oak.plugins.document.cache.NodeDocumentCache
Puts document into cache iff no entry with the given key is cached already or the cached document is older (has smaller Document.MOD_COUNT).
putInternal(NodeDocument) - Method in class org.apache.jackrabbit.oak.plugins.document.cache.NodeDocumentCache
Puts a document into the cache without acquiring a lock.
putNonConflictingDocs(CacheChangesTracker, Iterable<NodeDocument>) - Method in class org.apache.jackrabbit.oak.plugins.document.cache.NodeDocumentCache
Updates the cache with all the documents that: (1) currently have their older versions in the cache or (2) have been neither put nor invalidated during the tracker lifetime.
PWD_PROPERTY_NAMES - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
 

Q

query(Collection<T>, String, String, int) - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStore
Get a list of documents where the key is greater than a start value and less than an end value.
query(Collection<T>, String, String, String, long, int) - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStore
Get a list of documents where the key is greater than a start value and less than an end value and the given "indexed property" is greater or equals the specified value.
query(Collection<T>, String, String, int) - Method in class org.apache.jackrabbit.oak.plugins.document.memory.MemoryDocumentStore
 
query(Collection<T>, String, String, String, long, int) - Method in class org.apache.jackrabbit.oak.plugins.document.memory.MemoryDocumentStore
 
query(Collection<T>, String, String, int) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoDocumentStore
 
query(Collection<T>, String, String, String, long, int) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoDocumentStore
 
query(Collection<T>, String, String, int) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
query(Collection<T>, String, String, String, long, int) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
query(Collection<T>, String, String, List<String>, List<RDBDocumentStore.QueryCondition>, int) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
query(Connection, RDBDocumentStore.RDBTableMetaData, String, String, List<String>, List<RDBDocumentStore.QueryCondition>, int) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStoreJDBC
 
query(Collection<T>, String, String, int) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LeaseCheckDocumentStoreWrapper
 
query(Collection<T>, String, String, String, long, int) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LeaseCheckDocumentStoreWrapper
 
query(Collection<T>, String, String, int) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LoggingDocumentStoreWrapper
 
query(Collection<T>, String, String, String, long, int) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LoggingDocumentStoreWrapper
 
query(Collection<T>, String, String, int) - Method in class org.apache.jackrabbit.oak.plugins.document.util.SynchronizingDocumentStoreWrapper
 
query(Collection<T>, String, String, String, long, int) - Method in class org.apache.jackrabbit.oak.plugins.document.util.SynchronizingDocumentStoreWrapper
 
query(Collection<T>, String, String, int) - Method in class org.apache.jackrabbit.oak.plugins.document.util.TimingDocumentStoreWrapper
 
query(Collection<T>, String, String, String, long, int) - Method in class org.apache.jackrabbit.oak.plugins.document.util.TimingDocumentStoreWrapper
 
query(Filter, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndex
 
query(QueryIndex.IndexPlan, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndex
 
query(Filter, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.index.diffindex.DiffIndex
 
query(Filter, String, PropertyValue) - Method in class org.apache.jackrabbit.oak.plugins.index.property.PropertyIndexLookup
 
query(Filter, String, NodeState, String, Iterable<String>) - Method in class org.apache.jackrabbit.oak.plugins.index.property.strategy.ContentMirrorStoreStrategy
 
query(Filter, String, NodeState, Iterable<String>) - Method in class org.apache.jackrabbit.oak.plugins.index.property.strategy.ContentMirrorStoreStrategy
 
query(Filter, String, NodeState, Iterable<String>) - Method in class org.apache.jackrabbit.oak.plugins.index.property.strategy.FilteringIndexStoreStrategy
 
query(Filter, String, NodeState, Iterable<String>) - Method in interface org.apache.jackrabbit.oak.plugins.index.property.strategy.IndexStoreStrategy
Search for a given set of values.
query(Filter, String, NodeState, Iterable<String>) - Method in class org.apache.jackrabbit.oak.plugins.index.property.strategy.UniqueEntryStoreStrategy
 
query(Filter, NodeState) - Method in class org.apache.jackrabbit.oak.query.index.TraversingIndex
 
Query - Interface in org.apache.jackrabbit.oak.query
A "select" or "union" query.
query - Variable in class org.apache.jackrabbit.oak.query.ResultImpl
 
QUERY_PATHS - Static variable in interface org.apache.jackrabbit.oak.plugins.index.IndexConstants
MVP to define the paths for which the index can be used to perform queries.
queryAsIterable(Collection<T>, String, String, List<String>, List<RDBDocumentStore.QueryCondition>, int, String) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
queryAsIterator(RDBConnectionHandler, RDBDocumentStore.RDBTableMetaData, String, String, List<String>, List<RDBDocumentStore.QueryCondition>, int, String) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStoreJDBC
 
QueryCondition(String, String, long) - Constructor for class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore.QueryCondition
 
queryCount(Collection<T>, String, String, List<String>, List<RDBDocumentStore.QueryCondition>) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
QueryEngineImpl - Class in org.apache.jackrabbit.oak.query
The query engine implementation.
QueryEngineImpl() - Constructor for class org.apache.jackrabbit.oak.query.QueryEngineImpl
 
QueryEngineImpl.QuerySelectionMode - Enum in org.apache.jackrabbit.oak.query
Used to instruct the QueryEngineImpl on how to act with respect of the SQL2 optimisation.
QueryEngineSettings - Class in org.apache.jackrabbit.oak.query
Settings of the query engine.
QueryEngineSettings() - Constructor for class org.apache.jackrabbit.oak.query.QueryEngineSettings
 
QueryEngineSettingsService - Class in org.apache.jackrabbit.oak.query
 
QueryEngineSettingsService() - Constructor for class org.apache.jackrabbit.oak.query.QueryEngineSettingsService
 
QueryExecutionStats() - Constructor for class org.apache.jackrabbit.oak.query.stats.QueryStatsData.QueryExecutionStats
 
QueryImpl - Class in org.apache.jackrabbit.oak.query
Represents a parsed query.
QueryOptions - Class in org.apache.jackrabbit.oak.query
A query options (or "hints") that are used to customize the way the query is processed.
QueryOptions() - Constructor for class org.apache.jackrabbit.oak.query.QueryOptions
 
QueryOptions.Traversal - Enum in org.apache.jackrabbit.oak.query
 
QueryParser - Interface in org.apache.jackrabbit.oak.query
Query parser interface.
QueryStatsData - Class in org.apache.jackrabbit.oak.query.stats
 
QueryStatsData(String, String) - Constructor for class org.apache.jackrabbit.oak.query.stats.QueryStatsData
 
QueryStatsData.QueryExecutionStats - Class in org.apache.jackrabbit.oak.query.stats
 
QueryStatsMBean - Interface in org.apache.jackrabbit.oak.query.stats
 
QueryStatsMBeanImpl - Class in org.apache.jackrabbit.oak.query.stats
 
QueryStatsMBeanImpl(QueryEngineSettings) - Constructor for class org.apache.jackrabbit.oak.query.stats.QueryStatsMBeanImpl
 
QueryStatsReporter - Interface in org.apache.jackrabbit.oak.query.stats
 
QueryUtil - Class in org.apache.jackrabbit.oak.security.user.query
Common utilities used for user/group queries.
quote(Object) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.LoggingDocumentStoreWrapper
 

R

RandomAuthorizableNodeName - Class in org.apache.jackrabbit.oak.security.user
Implementation of the AuthorizableNodeName that generates a random node name that doesn't reveal the ID of the authorizable.
RandomAuthorizableNodeName() - Constructor for class org.apache.jackrabbit.oak.security.user.RandomAuthorizableNodeName
 
RDBBlobReferenceIterator - Class in org.apache.jackrabbit.oak.plugins.document.rdb
 
RDBBlobReferenceIterator(DocumentNodeStore, RDBDocumentStore) - Constructor for class org.apache.jackrabbit.oak.plugins.document.rdb.RDBBlobReferenceIterator
 
RDBBlobStore - Class in org.apache.jackrabbit.oak.plugins.document.rdb
 
RDBBlobStore(DataSource, RDBOptions) - Constructor for class org.apache.jackrabbit.oak.plugins.document.rdb.RDBBlobStore
Creates a RDBBlobStore instance using the provided DataSource using the given RDBOptions.
RDBBlobStore(DataSource) - Constructor for class org.apache.jackrabbit.oak.plugins.document.rdb.RDBBlobStore
Creates a RDBBlobStore instance using the provided DataSource using default RDBOptions.
RDBBlobStoreDB - Enum in org.apache.jackrabbit.oak.plugins.document.rdb
Defines variation in the capabilities of different RDBs.
RDBConnectionHandler - Class in org.apache.jackrabbit.oak.plugins.document.rdb
Utility functions for connection handling.
RDBConnectionHandler(DataSource) - Constructor for class org.apache.jackrabbit.oak.plugins.document.rdb.RDBConnectionHandler
 
RDBCreator - Class in org.apache.jackrabbit.oak.plugins.document.rdb
 
RDBCreator() - Constructor for class org.apache.jackrabbit.oak.plugins.document.rdb.RDBCreator
 
RDBDataSourceFactory - Class in org.apache.jackrabbit.oak.plugins.document.rdb
Factory for creating DataSources based on a JDBC connection URL.
RDBDataSourceFactory() - Constructor for class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDataSourceFactory
 
RDBDocumentSerializer - Class in org.apache.jackrabbit.oak.plugins.document.rdb
Serialization/Parsing of documents.
RDBDocumentSerializer(DocumentStore, Set<String>) - Constructor for class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentSerializer
 
RDBDocumentStore - Class in org.apache.jackrabbit.oak.plugins.document.rdb
Implementation of DocumentStore for relational databases.
RDBDocumentStore(DataSource, DocumentMK.Builder, RDBOptions) - Constructor for class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
Creates a RDBDocumentStore instance using the provided DataSource, DocumentMK.Builder, and RDBOptions.
RDBDocumentStore(DataSource, DocumentMK.Builder) - Constructor for class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
Creates a RDBDocumentStore instance using the provided DataSource, DocumentMK.Builder, and default RDBOptions.
RDBDocumentStore.QueryCondition - Class in org.apache.jackrabbit.oak.plugins.document.rdb
 
RDBDocumentStoreDB - Enum in org.apache.jackrabbit.oak.plugins.document.rdb
Defines variation in the capabilities of different RDBs.
RDBDocumentStoreDB.FETCHFIRSTSYNTAX - Enum in org.apache.jackrabbit.oak.plugins.document.rdb
 
RDBDocumentStoreJDBC - Class in org.apache.jackrabbit.oak.plugins.document.rdb
Implements (most) DB interactions used in RDBDocumentStore.
RDBDocumentStoreJDBC(RDBDocumentStoreDB, RDBDocumentSerializer, int, int) - Constructor for class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStoreJDBC
 
RDBExport - Class in org.apache.jackrabbit.oak.plugins.document.rdb
Utility for dumping contents from RDBDocumentStore's tables.
RDBExport() - Constructor for class org.apache.jackrabbit.oak.plugins.document.rdb.RDBExport
 
RDBHelper - Class in org.apache.jackrabbit.oak.plugins.document.rdb
Convenience class that dumps the table creation statements for various database types.
RDBHelper() - Constructor for class org.apache.jackrabbit.oak.plugins.document.rdb.RDBHelper
 
RDBJDBCTools - Class in org.apache.jackrabbit.oak.plugins.document.rdb
Convenience methods dealing with JDBC specifics.
RDBJDBCTools() - Constructor for class org.apache.jackrabbit.oak.plugins.document.rdb.RDBJDBCTools
 
RDBJDBCTools.PreparedStatementComponent - Interface in org.apache.jackrabbit.oak.plugins.document.rdb
Provides a component for a PreparedStatement and a method for setting the parameters within this component
RDBJSONSupport - Class in org.apache.jackrabbit.oak.plugins.document.rdb
Utilities that provide JSON support on top of the existing JsopTokenizer support in oak-commons.
RDBJSONSupport(boolean) - Constructor for class org.apache.jackrabbit.oak.plugins.document.rdb.RDBJSONSupport
 
RDBOptions - Class in org.apache.jackrabbit.oak.plugins.document.rdb
Options applicable to RDB persistence
RDBOptions() - Constructor for class org.apache.jackrabbit.oak.plugins.document.rdb.RDBOptions
 
RDBRow - Class in org.apache.jackrabbit.oak.plugins.document.rdb
Container for the information in a RDB database column.
RDBRow(String, Long, Boolean, Long, Long, Long, String, byte[]) - Constructor for class org.apache.jackrabbit.oak.plugins.document.rdb.RDBRow
 
RDBVersionGCSupport - Class in org.apache.jackrabbit.oak.plugins.document.rdb
RDB specific version of VersionGCSupport which uses an extended query interface to fetch required NodeDocuments.
RDBVersionGCSupport(RDBDocumentStore) - Constructor for class org.apache.jackrabbit.oak.plugins.document.rdb.RDBVersionGCSupport
 
read(String, long, byte[], int, int) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK
 
read(ByteBuffer) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.KeyDataType
 
read(ByteBuffer, Object[], int, boolean) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.KeyDataType
 
read(ByteBuffer) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.ValueDataType
 
read(ByteBuffer, Object[], int, boolean) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.ValueDataType
 
read(Connection, RDBDocumentStore.RDBTableMetaData, Collection<String>) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStoreJDBC
 
read(Connection, RDBDocumentStore.RDBTableMetaData, String, long, long) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStoreJDBC
 
read(long, long, long) - Method in class org.apache.jackrabbit.oak.query.stats.QueryStatsData.QueryExecutionStats
 
READ - Static variable in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
 
READ_ACCESS_CONTROL - Static variable in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
 
READ_NODE - Static variable in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
 
READ_PROPERTY - Static variable in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
 
readBlob(String, long, byte[], int, int) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.BlobCache
 
readBlockFromBackend(AbstractBlobStore.BlockId) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoBlobStore
 
readBlockFromBackend(byte[]) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBBlobStore
 
readBlockFromBackend(AbstractBlobStore.BlockId) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBBlobStore
 
readConcernLevel(ReadConcern) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.MongoConnection
 
readDefinition(Tree) - Static method in class org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeUtil
Reads the privilege definition stored in the specified definition tree.
readFrom(CommitInfo) - Method in class org.apache.jackrabbit.oak.plugins.document.JournalEntry
 
ReadOnlyDocumentStoreWrapperFactory - Class in org.apache.jackrabbit.oak.plugins.document.util
 
ReadOnlyDocumentStoreWrapperFactory() - Constructor for class org.apache.jackrabbit.oak.plugins.document.util.ReadOnlyDocumentStoreWrapperFactory
 
ReadOnlyNamespaceRegistry - Class in org.apache.jackrabbit.oak.plugins.name
Read-only namespace registry.
ReadOnlyNamespaceRegistry(Root) - Constructor for class org.apache.jackrabbit.oak.plugins.name.ReadOnlyNamespaceRegistry
 
ReadOnlyNodeTypeManager - Class in org.apache.jackrabbit.oak.plugins.nodetype
Base implementation of a NodeTypeManager with support for reading node types from the Tree returned by ReadOnlyNodeTypeManager.getTypes().
ReadOnlyNodeTypeManager() - Constructor for class org.apache.jackrabbit.oak.plugins.nodetype.ReadOnlyNodeTypeManager
 
ReadOnlyVersionManager - Class in org.apache.jackrabbit.oak.plugins.version
ReadOnlyVersionManager provides implementations for read-only version operations modeled after the ones available in VersionManager.
ReadOnlyVersionManager() - Constructor for class org.apache.jackrabbit.oak.plugins.version.ReadOnlyVersionManager
 
readRestrictions(String, Tree) - Method in class org.apache.jackrabbit.oak.security.authorization.restriction.PrincipalRestrictionProvider
 
readRestrictions(String, Tree) - Method in class org.apache.jackrabbit.oak.security.authorization.restriction.WhiteboardRestrictionProvider
 
readRestrictions(String, Tree) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.restriction.AbstractRestrictionProvider
 
readRestrictions(String, Tree) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.restriction.CompositeRestrictionProvider
 
readRestrictions(String, Tree) - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.restriction.RestrictionProvider
Read the valid restrictions stored in the specified ACE tree.
ReadWriteNamespaceRegistry - Class in org.apache.jackrabbit.oak.plugins.name
Writable namespace registry.
ReadWriteNamespaceRegistry(Root) - Constructor for class org.apache.jackrabbit.oak.plugins.name.ReadWriteNamespaceRegistry
 
ReadWriteNodeTypeManager - Class in org.apache.jackrabbit.oak.plugins.nodetype.write
ReadWriteNodeTypeManager extends the ReadOnlyNodeTypeManager with support for operations that modify node types.
ReadWriteNodeTypeManager() - Constructor for class org.apache.jackrabbit.oak.plugins.nodetype.write.ReadWriteNodeTypeManager
 
ReadWriteVersionManager - Class in org.apache.jackrabbit.oak.plugins.version
Extends the ReadOnlyVersionManager with methods to modify the version store.
ReadWriteVersionManager(NodeBuilder, NodeBuilder) - Constructor for class org.apache.jackrabbit.oak.plugins.version.ReadWriteVersionManager
 
rebase() - Method in class org.apache.jackrabbit.oak.core.ImmutableRoot
 
rebase(NodeBuilder) - Method in class org.apache.jackrabbit.oak.plugins.cow.BranchNodeStore
 
rebase(NodeBuilder) - Method in class org.apache.jackrabbit.oak.plugins.cow.COWNodeStore
 
rebase(String, String) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK
 
rebase(NodeBuilder) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
receive(ByteBuffer) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.BlobCache
 
receive(ByteBuffer) - Method in interface org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast.Broadcaster.Listener
Receive a message.
receive(ByteBuffer) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCache
 
recommendedCleanupInterval - Variable in class org.apache.jackrabbit.oak.plugins.document.VersionGarbageCollector.VersionGCInfo
 
recommendedCleanupTimestamp - Variable in class org.apache.jackrabbit.oak.plugins.document.VersionGarbageCollector.VersionGCInfo
 
recover(int, long) - Method in class org.apache.jackrabbit.oak.plugins.document.LastRevRecoveryAgent
Recover the correct _lastRev updates for potentially missing candidate nodes.
recover(int) - Method in class org.apache.jackrabbit.oak.plugins.document.LastRevRecoveryAgent
Same as LastRevRecoveryAgent.recover(int, long), but does not wait for ongoing recovery.
recover(Iterable<NodeDocument>, int) - Method in class org.apache.jackrabbit.oak.plugins.document.LastRevRecoveryAgent
Recover the correct _lastRev updates for the given candidate nodes.
recover(Iterable<NodeDocument>, int, boolean) - Method in class org.apache.jackrabbit.oak.plugins.document.LastRevRecoveryAgent
Recover the correct _lastRev updates for the given candidate nodes.
REF_NAME - Static variable in class org.apache.jackrabbit.oak.plugins.index.reference.NodeReferenceConstants
 
ReferenceChangeTracker - Class in org.apache.jackrabbit.oak.spi.xml
Helper class used to keep track of uuid mappings (e.g.
ReferenceChangeTracker() - Constructor for class org.apache.jackrabbit.oak.spi.xml.ReferenceChangeTracker
 
ReferenceConstraint - Class in org.apache.jackrabbit.oak.plugins.nodetype.constraint
 
ReferenceConstraint(String) - Constructor for class org.apache.jackrabbit.oak.plugins.nodetype.constraint.ReferenceConstraint
 
ReferenceEditorProvider - Class in org.apache.jackrabbit.oak.plugins.index.reference
 
ReferenceEditorProvider() - Constructor for class org.apache.jackrabbit.oak.plugins.index.reference.ReferenceEditorProvider
 
ReferenceIndexProvider - Class in org.apache.jackrabbit.oak.plugins.index.reference
A provider for node references indices.
ReferenceIndexProvider() - Constructor for class org.apache.jackrabbit.oak.plugins.index.reference.ReferenceIndexProvider
 
refresh() - Method in class org.apache.jackrabbit.oak.core.ImmutableRoot
 
refresh() - Method in class org.apache.jackrabbit.oak.plugins.name.ReadWriteNamespaceRegistry
Called by the write methods to refresh the state of the possible session associated with this instance.
refresh() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.write.ReadWriteNodeTypeManager
Called by the ReadWriteNodeTypeManager implementation methods to refresh the state of the session associated with this instance.
refresh() - Method in class org.apache.jackrabbit.oak.security.authorization.permission.PermissionProviderImpl
 
refresh() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.permission.EmptyPermissionProvider
 
refresh() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.permission.OpenPermissionProvider
 
refresh() - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.PermissionProvider
Refresh this PermissionProvider.
refreshAllSessions() - Method in class org.apache.jackrabbit.oak.management.RepositoryManager
 
register(Root, InputStream, String) - Static method in class org.apache.jackrabbit.oak.plugins.nodetype.write.NodeTypeRegistry
Register the node type definitions contained in the specified input using the given Root.
registerAsyncIndexer(AsyncIndexUpdate, long) - Method in class org.apache.jackrabbit.oak.plugins.index.IndexMBeanRegistration
 
registerIndex(String, boolean, long) - Method in class org.apache.jackrabbit.oak.plugins.index.progress.IndexingProgressReporter
Registers the index for progress tracking
registerIndexCommitCallback(IndexCommitCallback) - Method in interface org.apache.jackrabbit.oak.plugins.index.IndexingContext
registers IndexCommitCallback instance which can then be notified of how indexing commit progresses.
registerNamespace(String, String) - Method in class org.apache.jackrabbit.oak.plugins.name.ReadOnlyNamespaceRegistry
 
registerNamespace(String, String) - Method in class org.apache.jackrabbit.oak.plugins.name.ReadWriteNamespaceRegistry
 
registerNodeType(NodeTypeDefinition, boolean) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.ReadOnlyNodeTypeManager
This implementation always throws a UnsupportedRepositoryOperationException.
registerNodeType(NodeTypeDefinition, boolean) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.write.ReadWriteNodeTypeManager
 
registerNodeTypes(NodeTypeDefinition[], boolean) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.ReadOnlyNodeTypeManager
This implementation always throws a UnsupportedRepositoryOperationException.
registerNodeTypes(NodeTypeDefinition[], boolean) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.write.ReadWriteNodeTypeManager
 
registerTracker(String, String) - Method in class org.apache.jackrabbit.oak.plugins.document.cache.NodeDocumentCache
Registers a new CacheChangesTracker that records all puts and invalidations related to children of the given parent.
registerTracker(Set<String>) - Method in class org.apache.jackrabbit.oak.plugins.document.cache.NodeDocumentCache
Registers a new CacheChangesTracker that records all puts and invalidations related to the given documents
RegistrationConstants - Class in org.apache.jackrabbit.oak.spi.security
Holds the names of well-known registration properties for security-related components
registry() - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundledTypesRegistry.BundledTypesRegistryBuilder.TypeBuilder
 
REINDEX_ASYNC_PROPERTY_NAME - Static variable in interface org.apache.jackrabbit.oak.plugins.index.IndexConstants
 
REINDEX_COUNT - Static variable in interface org.apache.jackrabbit.oak.plugins.index.IndexConstants
 
REINDEX_PROPERTY_NAME - Static variable in interface org.apache.jackrabbit.oak.plugins.index.IndexConstants
 
reindexingTraversalEnd() - Method in class org.apache.jackrabbit.oak.plugins.index.progress.IndexingProgressReporter
Invoked to indicate that reindexing phase has ended in current indexing cycle
reindexingTraversalStart(String) - Method in class org.apache.jackrabbit.oak.plugins.index.progress.IndexingProgressReporter
Invoked to indicate that reindexing phase has started in current indexing cycle
RelativePathSelector - Class in org.apache.jackrabbit.oak.plugins.observation.filter
A selector for selecting a node at a relative path from the node selected by an initial selector.
RelativePathSelector(String, UniversalFilter.Selector) - Constructor for class org.apache.jackrabbit.oak.plugins.observation.filter.RelativePathSelector
 
release(String) - Method in class org.apache.jackrabbit.oak.plugins.cow.BranchNodeStore
 
release(String) - Method in class org.apache.jackrabbit.oak.plugins.cow.COWNodeStore
 
release(String) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
releaseCheckpoint(String) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentCheckpointMBean
 
releaseRecoveryLock(int, boolean) - Method in class org.apache.jackrabbit.oak.plugins.document.MissingLastRevSeeker
Releases the recovery lock on the given clusterId.
remove(String) - Method in class org.apache.jackrabbit.oak.core.SimpleCommitContext
 
remove(String) - Method in class org.apache.jackrabbit.oak.plugins.document.Document
Removes the given key.
remove(Collection<T>, String) - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStore
Remove a document.
remove(Collection<T>, List<String>) - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStore
Batch remove documents with given keys.
remove(Collection<T>, Map<String, Map<UpdateOp.Key, UpdateOp.Condition>>) - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStore
Batch remove documents with given keys and corresponding conditions.
remove(Collection<T>, String, long, long) - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStore
Batch remove documents where the given "indexed property" is within the given range (exclusive) - (startValue, endValue).
remove(Collection<T>, String) - Method in class org.apache.jackrabbit.oak.plugins.document.memory.MemoryDocumentStore
 
remove(Collection<T>, List<String>) - Method in class org.apache.jackrabbit.oak.plugins.document.memory.MemoryDocumentStore
 
remove(Collection<T>, Map<String, Map<UpdateOp.Key, UpdateOp.Condition>>) - Method in class org.apache.jackrabbit.oak.plugins.document.memory.MemoryDocumentStore
 
remove(Collection<T>, String, long, long) - Method in class org.apache.jackrabbit.oak.plugins.document.memory.MemoryDocumentStore
 
remove(Collection<T>, String) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoDocumentStore
 
remove(Collection<T>, List<String>) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoDocumentStore
 
remove(Collection<T>, Map<String, Map<UpdateOp.Key, UpdateOp.Condition>>) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoDocumentStore
 
remove(Collection<T>, String, long, long) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoDocumentStore
 
remove(Object) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.CacheMap
 
remove(Object) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.MultiGenerationMap
 
remove(Collection<T>, String) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
remove(Collection<T>, List<String>) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
remove(Collection<T>, Map<String, Map<UpdateOp.Key, UpdateOp.Condition>>) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
remove(Collection<T>, String, long, long) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
remove(int) - Method in class org.apache.jackrabbit.oak.plugins.document.RevisionVector
Returns a RevisionVector without the revision element with the given clusterId.
remove(String) - Method in class org.apache.jackrabbit.oak.plugins.document.UpdateOp
Remove a property.
remove() - Method in class org.apache.jackrabbit.oak.plugins.document.util.CloseableIterator
 
remove(Collection<T>, String) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LeaseCheckDocumentStoreWrapper
 
remove(Collection<T>, List<String>) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LeaseCheckDocumentStoreWrapper
 
remove(Collection<T>, Map<String, Map<UpdateOp.Key, UpdateOp.Condition>>) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LeaseCheckDocumentStoreWrapper
 
remove(Collection<T>, String, long, long) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LeaseCheckDocumentStoreWrapper
 
remove(Collection<T>, String) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LoggingDocumentStoreWrapper
 
remove(Collection<T>, List<String>) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LoggingDocumentStoreWrapper
 
remove(Collection<T>, Map<String, Map<UpdateOp.Key, UpdateOp.Condition>>) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LoggingDocumentStoreWrapper
 
remove(Collection<T>, String, long, long) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LoggingDocumentStoreWrapper
 
remove() - Method in class org.apache.jackrabbit.oak.plugins.document.util.MergeSortedIterators
 
remove(Collection<T>, String) - Method in class org.apache.jackrabbit.oak.plugins.document.util.SynchronizingDocumentStoreWrapper
 
remove(Collection<T>, List<String>) - Method in class org.apache.jackrabbit.oak.plugins.document.util.SynchronizingDocumentStoreWrapper
 
remove(Collection<T>, Map<String, Map<UpdateOp.Key, UpdateOp.Condition>>) - Method in class org.apache.jackrabbit.oak.plugins.document.util.SynchronizingDocumentStoreWrapper
 
remove(Collection<T>, String, long, long) - Method in class org.apache.jackrabbit.oak.plugins.document.util.SynchronizingDocumentStoreWrapper
 
remove(Collection<T>, String) - Method in class org.apache.jackrabbit.oak.plugins.document.util.TimingDocumentStoreWrapper
 
remove(Collection<T>, List<String>) - Method in class org.apache.jackrabbit.oak.plugins.document.util.TimingDocumentStoreWrapper
 
remove(Collection<T>, Map<String, Map<UpdateOp.Key, UpdateOp.Condition>>) - Method in class org.apache.jackrabbit.oak.plugins.document.util.TimingDocumentStoreWrapper
 
remove(Collection<T>, String, long, long) - Method in class org.apache.jackrabbit.oak.plugins.document.util.TimingDocumentStoreWrapper
 
remove() - Method in class org.apache.jackrabbit.oak.plugins.index.Cursors.AbstractCursor
 
remove() - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractMutableTree
 
remove() - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.ImmutableTree
 
remove() - Method in class org.apache.jackrabbit.oak.plugins.tree.TreeLocation
Remove the underlying item.
remove() - Method in class org.apache.jackrabbit.oak.security.user.query.ResultIterator
 
remove() - Method in interface org.apache.jackrabbit.oak.spi.security.authentication.token.TokenInfo
Tries to remove the login token and all related information.
REMOVE - Static variable in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
 
remove(Object) - Method in class org.apache.jackrabbit.oak.spi.security.ConfigurationParameters
REMOVE_NODE - Static variable in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
 
REMOVE_PROPERTY - Static variable in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
 
removeAccessControlEntry(AccessControlEntry) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.ImmutableACL
 
removeBranchCommit(UpdateOp, Revision) - Static method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
 
removeCollision(UpdateOp, Revision) - Static method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
 
removeCommitRoot(UpdateOp, Revision) - Static method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
 
removeConfiguration(T) - Method in class org.apache.jackrabbit.oak.spi.security.CompositeConfiguration
 
removeDeleted(UpdateOp, Revision) - Static method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
 
removeField(String) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.RevisionEntry
 
removeGeneration(int) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.BlobCache
 
removeListener(Broadcaster.Listener) - Method in interface org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast.Broadcaster
Remove a listener.
removeListener(Broadcaster.Listener) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast.InMemoryBroadcaster
 
removeListener(Broadcaster.Listener) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast.TCPBroadcaster
 
removeListener(Broadcaster.Listener) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast.UDPBroadcaster
 
removeMapEntry(String, Revision) - Method in class org.apache.jackrabbit.oak.plugins.document.UpdateOp
Remove a map entry.
removeMember(Principal) - Method in class org.apache.jackrabbit.oak.spi.security.principal.EveryonePrincipal
 
removeNode(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.document.Commit
 
removePolicy(String, AccessControlPolicy) - Method in class org.apache.jackrabbit.oak.security.authorization.accesscontrol.AccessControlManagerImpl
 
removePrevious(UpdateOp, Range) - Static method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
 
removePrevious(UpdateOp, Revision) - Static method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
 
removeProperty(String) - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractMutableTree
 
removeProperty(String) - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.ImmutableTree
 
removeReadGeneration(int) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
removeReadMap(int) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.MultiGenerationMap
 
removeReferences(List<Object>) - Method in class org.apache.jackrabbit.oak.spi.xml.ReferenceChangeTracker
Remove the given references that have already been processed from the references list.
removeRevision(UpdateOp, Revision) - Static method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
 
removeStalePrevious(UpdateOp, Revision) - Static method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
 
removeVersionLabel(String, String) - Method in class org.apache.jackrabbit.oak.plugins.version.ReadWriteVersionManager
Removes a version label from the jcr:versionLabels node of the referenced version history.
renewLease() - Method in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfo
Renew the cluster id lease.
REP_ACCESS_CONTROLLED_PATH - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.PermissionConstants
 
REP_ACTIVITIES - Static variable in interface org.apache.jackrabbit.oak.plugins.version.VersionConstants
 
REP_ADD_PROPERTIES - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
Internal (oak) name of the rep:addProperties privilege
REP_AGGREGATES - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
Name of the privilege definition property that stores the aggregate privilege names.
REP_ALTER_PROPERTIES - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
Internal (oak) name of the rep:alterProperties privilege
REP_AUTHORIZABLE_ID - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
 
REP_BITS - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
Name of the privilege definition property that stores the internal representation of this privilege.
REP_CONFIGURATIONS - Static variable in interface org.apache.jackrabbit.oak.plugins.version.VersionConstants
 
REP_DECLARING_NODE_TYPE - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
REP_DISABLED - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
 
REP_GLOB - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AccessControlConstants
 
REP_HAS_PROTECTED_RESIDUAL_CHILD_NODES - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
REP_HAS_PROTECTED_RESIDUAL_PROPERTIES - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
REP_IMPERSONATORS - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
 
REP_INDEX_DEFINITION_MANAGEMENT - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
Internal (oak) name of the rep:indexDefinitionManagement privilege
REP_IS_ABSTRACT - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
Name of the property that defines if the privilege is abstract.
REP_IS_ALLOW - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.PermissionConstants
 
REP_ITEM_NAMES - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AccessControlConstants
Name of the optional multivalued access control restriction by item name.
REP_MANDATORY_CHILD_NODES - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
REP_MANDATORY_PROPERTIES - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
REP_MEMBERS - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
 
REP_MEMBERS_LIST - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
 
REP_MIXIN_SUBTYPES - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
REP_MIXIN_TYPES - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
REP_NAMED_CHILD_NODE_DEFINITIONS - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
REP_NAMED_PROPERTY_DEFINITIONS - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
REP_NAMED_SINGLE_VALUED_PROPERTIES - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
REP_NAMESPACES - Static variable in interface org.apache.jackrabbit.oak.plugins.name.NamespaceConstants
 
REP_NEXT - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
Name of the property storing the value of the next available privilege bits.
REP_NODE_PATH - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AccessControlConstants
 
REP_NSDATA - Static variable in interface org.apache.jackrabbit.oak.plugins.name.NamespaceConstants
 
REP_NT_NAMES - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AccessControlConstants
Name of the optional multivalued access control restriction by node type name.
REP_OURS - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
REP_PASSWORD - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
 
REP_PASSWORD_LAST_MODIFIED - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
 
REP_PERMISSION_STORE - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.PermissionConstants
 
REP_POLICY - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AccessControlConstants
 
REP_PREFIXES - Static variable in interface org.apache.jackrabbit.oak.plugins.name.NamespaceConstants
 
REP_PREFIXES - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AccessControlConstants
Name of the optional multivalued access control restriction which matches by name space prefix.
REP_PRIMARY_SUBTYPES - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
REP_PRIMARY_TYPE - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
REP_PRINCIPAL_NAME - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AccessControlConstants
 
REP_PRINCIPAL_NAME - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
 
REP_PRIVILEGE_BITS - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.PermissionConstants
 
REP_PRIVILEGE_MANAGEMENT - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
Internal (oak) name of the rep:privilegeManagement privilege
REP_PRIVILEGES - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AccessControlConstants
 
REP_PRIVILEGES - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
Internal (oak) name for the root node of the privilege store.
REP_PROTECTED_CHILD_NODES - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
REP_PROTECTED_PROPERTIES - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
REP_PWD - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
 
REP_PWD_HISTORY - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
 
REP_READ_NODES - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
Internal (oak) name of the rep:readNodes privilege
REP_READ_PROPERTIES - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
Internal (oak) name of the rep:readProperties privilege
REP_REMOVE_PROPERTIES - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
Internal (oak) name of the rep:removeProperties privilege
REP_REPO_POLICY - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AccessControlConstants
 
REP_RESIDUAL_CHILD_NODE_DEFINITIONS - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
REP_RESIDUAL_PROPERTY_DEFINITIONS - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
REP_RESTRICTIONS - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AccessControlConstants
 
REP_SUPERTYPES - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
REP_URIS - Static variable in interface org.apache.jackrabbit.oak.plugins.name.NamespaceConstants
 
REP_USER_MANAGEMENT - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
Internal (oak) name of the rep:userManagement privilege
REP_UUID - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
REP_VERSIONSTORAGE - Static variable in interface org.apache.jackrabbit.oak.plugins.version.VersionConstants
 
REP_WRITE - Static variable in interface org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeConstants
Internal (oak) name of the rep:write privilege
replaceCachedDocument(NodeDocument, NodeDocument) - Method in class org.apache.jackrabbit.oak.plugins.document.cache.NodeDocumentCache
Replaces the cached value if the old document is currently present in the cache.
ReplicaSetInfo - Class in org.apache.jackrabbit.oak.plugins.document.mongo.replica
This class analyses the replica set info provided by MongoDB to find out two what's the current synchronization state of secondary instances in terms of revision values and timestamp.
ReplicaSetInfo(Clock, DB, String, long, long, Executor) - Constructor for class org.apache.jackrabbit.oak.plugins.document.mongo.replica.ReplicaSetInfo
 
ReplicaSetInfo.MemberState - Enum in org.apache.jackrabbit.oak.plugins.document.mongo.replica
 
ReplicaSetInfoListener - Interface in org.apache.jackrabbit.oak.plugins.document.mongo.replica
Classes implementing this interface will be informed about the current root revision states on secondary instances by ReplicaSetInfo.
RepMembersConflictHandler - Class in org.apache.jackrabbit.oak.security.user
The RepMembersConflictHandler takes care of merging the rep:members property during parallel updates.
RepMembersConflictHandler() - Constructor for class org.apache.jackrabbit.oak.security.user.RepMembersConflictHandler
 
RepositoryCallback - Class in org.apache.jackrabbit.oak.spi.security.authentication.callback
Callback implementation used to access the repository.
RepositoryCallback() - Constructor for class org.apache.jackrabbit.oak.spi.security.authentication.callback.RepositoryCallback
 
RepositoryManager - Class in org.apache.jackrabbit.oak.management
Default implementation of the RepositoryManagementMBean based on a Whiteboard instance, which is used to look up individual service providers for backup (FileStoreBackupRestoreMBean), data store garbage collections (BlobGCMBean) and revision store garbage collections (RevisionGCMBean).
RepositoryManager(Whiteboard) - Constructor for class org.apache.jackrabbit.oak.management.RepositoryManager
 
RepositoryPermission - Interface in org.apache.jackrabbit.oak.spi.security.authorization.permission
The RepositoryPermission allows to evaluate permissions that have been defined on the repository level and which consequently are not bound to a particular item.
requiresFullTextIndex() - Method in class org.apache.jackrabbit.oak.query.ast.AndImpl
 
requiresFullTextIndex() - Method in class org.apache.jackrabbit.oak.query.ast.ConstraintImpl
Whether the constraint contains a fulltext condition that requires using a fulltext index, because the condition can only be evaluated there.
requiresFullTextIndex() - Method in class org.apache.jackrabbit.oak.query.ast.FullTextSearchImpl
 
requiresFullTextIndex() - Method in class org.apache.jackrabbit.oak.query.ast.NativeFunctionImpl
 
requiresFullTextIndex() - Method in class org.apache.jackrabbit.oak.query.ast.NotFullTextSearchImpl
 
requiresFullTextIndex() - Method in class org.apache.jackrabbit.oak.query.ast.NotImpl
 
requiresFullTextIndex() - Method in class org.apache.jackrabbit.oak.query.ast.OrImpl
 
requiresFullTextIndex() - Method in class org.apache.jackrabbit.oak.query.ast.SimilarImpl
 
requiresFullTextIndex() - Method in class org.apache.jackrabbit.oak.query.ast.SpellcheckImpl
 
requiresFullTextIndex() - Method in class org.apache.jackrabbit.oak.query.ast.SuggestImpl
 
RESERVED_PREFIXES - Static variable in interface org.apache.jackrabbit.oak.plugins.name.NamespaceConstants
Reserved namespace prefixes as defined in jackrabbit 2
RESERVED_URIS - Static variable in interface org.apache.jackrabbit.oak.plugins.name.NamespaceConstants
Reserved namespace URIs as defined in jackrabbit 2
reset(NodeBuilder) - Method in class org.apache.jackrabbit.oak.plugins.cow.BranchNodeStore
 
reset(NodeBuilder) - Method in class org.apache.jackrabbit.oak.plugins.cow.COWNodeStore
 
reset(String, String) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK
 
reset(NodeBuilder) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
reset() - Method in class org.apache.jackrabbit.oak.plugins.document.VersionGarbageCollector
 
ResetCommitAttributeHook - Enum in org.apache.jackrabbit.oak.core
 
resetExpiration(long) - Method in interface org.apache.jackrabbit.oak.spi.security.authentication.token.TokenInfo
Resets the expiration time of the login token associated with the given TokenInfo.
resetStats() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
resetStats() - Method in interface org.apache.jackrabbit.oak.query.stats.QueryStatsMBean
 
resetStats() - Method in class org.apache.jackrabbit.oak.query.stats.QueryStatsMBeanImpl
 
RESIDUAL_NAME - Static variable in interface org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeConstants
 
RESOLUTION - Static variable in class org.apache.jackrabbit.oak.plugins.index.counter.NodeCounterEditorProvider
 
resolveChunks(String) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.BlobCache
 
resolveCommitRevision(Revision, String) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
Resolve the commit revision for the given revision rev and the associated commit tag.
resolveUUID(String) - Method in class org.apache.jackrabbit.oak.plugins.identifier.IdentifierManager
 
respectParentPermissions(long) - Static method in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
 
restore(NodeBuilder, String, VersionSelector) - Method in class org.apache.jackrabbit.oak.plugins.version.ReadWriteVersionManager
 
RESTORE_PREFIX - Static variable in interface org.apache.jackrabbit.oak.plugins.version.VersionConstants
Prefix of the jcr:baseVersion value for a restore.
restrict(FilterImpl) - Method in class org.apache.jackrabbit.oak.query.ast.AndImpl
 
restrict(FilterImpl) - Method in class org.apache.jackrabbit.oak.query.ast.ChildNodeImpl
 
restrict(FilterImpl) - Method in class org.apache.jackrabbit.oak.query.ast.ChildNodeJoinConditionImpl
 
restrict(FilterImpl) - Method in class org.apache.jackrabbit.oak.query.ast.ComparisonImpl
 
restrict(FilterImpl) - Method in class org.apache.jackrabbit.oak.query.ast.ConstraintImpl
Apply the condition to the filter, further restricting the filter if possible.
restrict(FilterImpl) - Method in class org.apache.jackrabbit.oak.query.ast.DescendantNodeImpl
 
restrict(FilterImpl) - Method in class org.apache.jackrabbit.oak.query.ast.DescendantNodeJoinConditionImpl
 
restrict(FilterImpl, Operator, PropertyValue) - Method in class org.apache.jackrabbit.oak.query.ast.DynamicOperandImpl
Apply a restriction of type "this = value" to the given filter.
restrict(FilterImpl) - Method in class org.apache.jackrabbit.oak.query.ast.EquiJoinConditionImpl
 
restrict(FilterImpl) - Method in class org.apache.jackrabbit.oak.query.ast.FullTextSearchImpl
 
restrict(FilterImpl, Operator, PropertyValue) - Method in class org.apache.jackrabbit.oak.query.ast.FullTextSearchScoreImpl
 
restrict(FilterImpl) - Method in class org.apache.jackrabbit.oak.query.ast.InImpl
 
restrict(FilterImpl) - Method in class org.apache.jackrabbit.oak.query.ast.JoinConditionImpl
Apply the condition to the filter, further restricting the filter if possible.
restrict(FilterImpl, Operator, PropertyValue) - Method in class org.apache.jackrabbit.oak.query.ast.LengthImpl
 
restrict(FilterImpl, Operator, PropertyValue) - Method in class org.apache.jackrabbit.oak.query.ast.LowerCaseImpl
 
restrict(FilterImpl) - Method in class org.apache.jackrabbit.oak.query.ast.NativeFunctionImpl
 
restrict(FilterImpl, Operator, PropertyValue) - Method in class org.apache.jackrabbit.oak.query.ast.NodeLocalNameImpl
 
restrict(FilterImpl, Operator, PropertyValue) - Method in class org.apache.jackrabbit.oak.query.ast.NodeNameImpl
 
restrict(FilterImpl) - Method in class org.apache.jackrabbit.oak.query.ast.NotImpl
 
restrict(FilterImpl) - Method in class org.apache.jackrabbit.oak.query.ast.OrImpl
 
restrict(FilterImpl) - Method in class org.apache.jackrabbit.oak.query.ast.PropertyExistenceImpl
 
restrict(FilterImpl) - Method in class org.apache.jackrabbit.oak.query.ast.PropertyInexistenceImpl
 
restrict(FilterImpl, Operator, PropertyValue) - Method in class org.apache.jackrabbit.oak.query.ast.PropertyValueImpl
 
restrict(FilterImpl) - Method in class org.apache.jackrabbit.oak.query.ast.SameNodeImpl
 
restrict(FilterImpl) - Method in class org.apache.jackrabbit.oak.query.ast.SameNodeJoinConditionImpl
 
restrict(FilterImpl) - Method in class org.apache.jackrabbit.oak.query.ast.SimilarImpl
 
restrict(FilterImpl) - Method in class org.apache.jackrabbit.oak.query.ast.SpellcheckImpl
 
restrict(FilterImpl) - Method in class org.apache.jackrabbit.oak.query.ast.SuggestImpl
 
restrict(FilterImpl, Operator, PropertyValue) - Method in class org.apache.jackrabbit.oak.query.ast.UpperCaseImpl
 
restrictFulltextCondition(String) - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
 
Restriction - Interface in org.apache.jackrabbit.oak.spi.security.authorization.restriction
A Restriction object represents a "live" restriction object that has been created using the Jackrabbit specific extensions of the AccessControlEntry interface.
RestrictionDefinition - Interface in org.apache.jackrabbit.oak.spi.security.authorization.restriction
The RestrictionDefinition interface provides methods for discovering the static definition of any additional policy-internal refinements of the access control definitions.
RestrictionDefinitionImpl - Class in org.apache.jackrabbit.oak.spi.security.authorization.restriction
Default implementation of the RestrictionDefinition interface.
RestrictionDefinitionImpl(String, Type<?>, boolean) - Constructor for class org.apache.jackrabbit.oak.spi.security.authorization.restriction.RestrictionDefinitionImpl
Create a new instance.
RestrictionImpl - Class in org.apache.jackrabbit.oak.spi.security.authorization.restriction
RestrictionImpl
RestrictionImpl(PropertyState, RestrictionDefinition) - Constructor for class org.apache.jackrabbit.oak.spi.security.authorization.restriction.RestrictionImpl
 
RestrictionImpl(PropertyState, boolean) - Constructor for class org.apache.jackrabbit.oak.spi.security.authorization.restriction.RestrictionImpl
 
RestrictionPattern - Interface in org.apache.jackrabbit.oak.spi.security.authorization.restriction
Interface used to verify if a given restriction applies to a given item or path.
RestrictionProvider - Interface in org.apache.jackrabbit.oak.spi.security.authorization.restriction
Interface to manage the supported restrictions present with a given access control and permission management implementation.
RestrictionProviderImpl - Class in org.apache.jackrabbit.oak.security.authorization.restriction
Default restriction provider implementation that supports the following restrictions: AccessControlConstants.REP_GLOB: A simple paths matching pattern.
RestrictionProviderImpl() - Constructor for class org.apache.jackrabbit.oak.security.authorization.restriction.RestrictionProviderImpl
 
restrictList(FilterImpl, List<PropertyValue>) - Method in class org.apache.jackrabbit.oak.query.ast.DynamicOperandImpl
Apply a restriction of type "this in (list)" to the given filter.
restrictList(FilterImpl, List<PropertyValue>) - Method in class org.apache.jackrabbit.oak.query.ast.FullTextSearchScoreImpl
 
restrictList(FilterImpl, List<PropertyValue>) - Method in class org.apache.jackrabbit.oak.query.ast.LengthImpl
 
restrictList(FilterImpl, List<PropertyValue>) - Method in class org.apache.jackrabbit.oak.query.ast.LowerCaseImpl
 
restrictList(FilterImpl, List<PropertyValue>) - Method in class org.apache.jackrabbit.oak.query.ast.NodeLocalNameImpl
 
restrictList(FilterImpl, List<PropertyValue>) - Method in class org.apache.jackrabbit.oak.query.ast.NodeNameImpl
 
restrictList(FilterImpl, List<PropertyValue>) - Method in class org.apache.jackrabbit.oak.query.ast.PropertyValueImpl
 
restrictList(FilterImpl, List<PropertyValue>) - Method in class org.apache.jackrabbit.oak.query.ast.UpperCaseImpl
 
restrictPath(String, Filter.PathRestriction) - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
 
restrictProperty(String, Operator, PropertyValue) - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
 
restrictProperty(String, Operator, PropertyValue, int) - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
 
restrictPropertyAsList(String, List<PropertyValue>) - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
 
restrictPushDown(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.AndImpl
 
restrictPushDown(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.ChildNodeImpl
 
restrictPushDown(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.ChildNodeJoinConditionImpl
 
restrictPushDown(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.ComparisonImpl
 
restrictPushDown(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.ConstraintImpl
Push as much of the condition down to this selector, further restricting the selector condition if possible.
restrictPushDown(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.DescendantNodeImpl
 
restrictPushDown(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.DescendantNodeJoinConditionImpl
 
restrictPushDown(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.EquiJoinConditionImpl
 
restrictPushDown(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.FullTextSearchImpl
 
restrictPushDown(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.InImpl
 
restrictPushDown(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.JoinConditionImpl
Push as much of the condition down to this selector, further restricting the selector condition if possible.
restrictPushDown(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.NativeFunctionImpl
 
restrictPushDown(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.NotImpl
 
restrictPushDown(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.OrImpl
 
restrictPushDown(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.PropertyExistenceImpl
 
restrictPushDown(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.PropertyInexistenceImpl
 
restrictPushDown(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.SameNodeImpl
 
restrictPushDown(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.SameNodeJoinConditionImpl
 
restrictPushDown(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.SimilarImpl
 
restrictPushDown(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.SpellcheckImpl
 
restrictPushDown(SelectorImpl) - Method in class org.apache.jackrabbit.oak.query.ast.SuggestImpl
 
restrictSelector(ConstraintImpl) - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
 
ResultImpl - Class in org.apache.jackrabbit.oak.query
A query result.
ResultIterator<T> - Class in org.apache.jackrabbit.oak.security.user.query
Implements a query result iterator which only returns a maximum number of element from an underlying iterator starting at a given offset.
ResultRowImpl - Class in org.apache.jackrabbit.oak.query
A query result row that keeps all data (for this row only) in memory.
retain(Set<String>) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.replica.NodeCollectionProvider
 
retain(PrivilegeBits) - Method in class org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeBits
Retains the elements in this PrivilegeBits that are contained in the specified other PrivilegeBits.
RETENTION_MANAGEMENT - Static variable in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
 
retrieve(String) - Method in class org.apache.jackrabbit.oak.plugins.cow.BranchNodeStore
 
retrieve(String) - Method in class org.apache.jackrabbit.oak.plugins.cow.COWNodeStore
 
retrieve(String) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
REV_RECOVERY_BY - Static variable in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfo
Flag indicating which cluster node is running the recovery.
REV_RECOVERY_LOCK - Static variable in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfo
Flag to indicate whether the _lastRev recovery is in progress.
REVERSE - Static variable in class org.apache.jackrabbit.oak.plugins.document.StableRevisionComparator
 
revertSwitch(NodeBuilder, String) - Static method in class org.apache.jackrabbit.oak.plugins.index.importer.AsyncLaneSwitcher
 
Revision - Class in org.apache.jackrabbit.oak.plugins.document
A revision.
Revision(long, int, int) - Constructor for class org.apache.jackrabbit.oak.plugins.document.Revision
 
Revision(long, int, int, boolean) - Constructor for class org.apache.jackrabbit.oak.plugins.document.Revision
 
RevisionContext - Interface in org.apache.jackrabbit.oak.plugins.document
Provides revision related context.
RevisionEntry - Class in org.apache.jackrabbit.oak.plugins.document.mongo
A light-weight implementation of a MongoDB DBObject for a single revision based map entry.
RevisionEntry(Revision, Object) - Constructor for class org.apache.jackrabbit.oak.plugins.document.mongo.RevisionEntry
 
RevisionGCStatsCollector - Interface in org.apache.jackrabbit.oak.plugins.document
Collector interface for DocumentNodeStore revision garbage collection statistics.
RevisionGCStatsMBean - Interface in org.apache.jackrabbit.oak.plugins.document
MBean exposing DocumentNodeStore revision garbage collection statistics.
RevisionListener - Interface in org.apache.jackrabbit.oak.plugins.document
Document stores implementing this interface will be informed about all revisions in which the nodes are accessed.
revisionsCandidateCount - Variable in class org.apache.jackrabbit.oak.plugins.document.VersionGarbageCollector.VersionGCInfo
 
RevisionsKey - Class in org.apache.jackrabbit.oak.plugins.document.util
A cache key implementation which consists of two Revisions.
RevisionsKey(RevisionVector, RevisionVector) - Constructor for class org.apache.jackrabbit.oak.plugins.document.util.RevisionsKey
 
RevisionVector - Class in org.apache.jackrabbit.oak.plugins.document
A vector of revisions.
RevisionVector(Revision...) - Constructor for class org.apache.jackrabbit.oak.plugins.document.RevisionVector
 
RevisionVector(Iterable<Revision>) - Constructor for class org.apache.jackrabbit.oak.plugins.document.RevisionVector
 
RevisionVector(Set<Revision>) - Constructor for class org.apache.jackrabbit.oak.plugins.document.RevisionVector
 
rollbackConnection(Connection) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBConnectionHandler
Roll back the Connection.
ROOT_PATH - Variable in class org.apache.jackrabbit.oak.plugins.document.MissingLastRevSeeker
 
ROOT_PROVIDER - Static variable in interface org.apache.jackrabbit.oak.plugins.tree.impl.ImmutableTree.ParentProvider
 
RootFactory - Class in org.apache.jackrabbit.oak.plugins.tree
Factory to obtain immutable Root objects.
rootRevisions - Variable in class org.apache.jackrabbit.oak.plugins.document.mongo.replica.ReplicaSetInfo
 
run() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.replica.ReplicaSetInfo
 
run() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.async.CacheActionDispatcher
 
run() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast.UDPBroadcaster
 
run() - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate
 
runBackgroundOperations() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
Used for testing only

S

sameNode(String, String) - Method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
 
SameNodeImpl - Class in org.apache.jackrabbit.oak.query.ast
The function "issamenode(..)".
SameNodeImpl(String, String) - Constructor for class org.apache.jackrabbit.oak.query.ast.SameNodeImpl
 
sameNodeJoinCondition(String, String, String) - Method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
 
SameNodeJoinConditionImpl - Class in org.apache.jackrabbit.oak.query.ast
The "issamenode(...)" join condition.
SameNodeJoinConditionImpl(String, String, String) - Constructor for class org.apache.jackrabbit.oak.query.ast.SameNodeJoinConditionImpl
 
saturatedAdd(long, long) - Static method in class org.apache.jackrabbit.oak.query.QueryImpl
Add two values, but don't let it overflow or underflow.
save() - Method in class org.apache.jackrabbit.oak.plugins.index.importer.IndexerInfo
 
scan(long, long) - Method in class org.apache.jackrabbit.oak.query.stats.QueryStatsData.QueryExecutionStats
 
SD_MAX_REV_TIME_IN_SECS - Static variable in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
Property name which refers to timestamp (long) of the latest revision kept in the document
SD_TYPE - Static variable in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
Defines the type of split document.
seal() - Method in class org.apache.jackrabbit.oak.plugins.document.Document
Seals this document and turns it into an immutable object.
SecondaryStoreBuilder - Class in org.apache.jackrabbit.oak.plugins.document.secondary
 
SecondaryStoreBuilder(NodeStore) - Constructor for class org.apache.jackrabbit.oak.plugins.document.secondary.SecondaryStoreBuilder
 
SecondaryStoreCache - Class in org.apache.jackrabbit.oak.plugins.document.secondary
 
SecondaryStoreCache(NodeStore, NodeStateDiffer, PathFilter, StatisticsProvider) - Constructor for class org.apache.jackrabbit.oak.plugins.document.secondary.SecondaryStoreCache
 
SecondaryStoreCacheService - Class in org.apache.jackrabbit.oak.plugins.document.secondary
 
SecondaryStoreCacheService() - Constructor for class org.apache.jackrabbit.oak.plugins.document.secondary.SecondaryStoreCacheService
 
SecondaryStoreObserver - Class in org.apache.jackrabbit.oak.plugins.document.secondary
 
SecondaryStoreObserver(NodeStore, List<String>, NodeStateDiffer, PathFilter, StatisticsProvider, SecondaryStoreRootObserver) - Constructor for class org.apache.jackrabbit.oak.plugins.document.secondary.SecondaryStoreObserver
 
SecurityConfiguration - Interface in org.apache.jackrabbit.oak.spi.security
Base interface for all security related configurations.
SecurityConfiguration.Default - Class in org.apache.jackrabbit.oak.spi.security
Default implementation that provides empty initializers, validators, commit hooks and parameters.
SecurityProvider - Interface in org.apache.jackrabbit.oak.spi.security
Main entry point for security related plugins to an Oak repository.
SecurityProviderCallback - Class in org.apache.jackrabbit.oak.spi.security.authentication.callback
Callback implementation to set and get the SecurityProvider.
SecurityProviderCallback() - Constructor for class org.apache.jackrabbit.oak.spi.security.authentication.callback.SecurityProviderCallback
 
SecurityProviderImpl - Class in org.apache.jackrabbit.oak.security
 
SecurityProviderImpl() - Constructor for class org.apache.jackrabbit.oak.security.SecurityProviderImpl
Default constructor used in OSGi environments.
SecurityProviderImpl(ConfigurationParameters) - Constructor for class org.apache.jackrabbit.oak.security.SecurityProviderImpl
Create a new SecurityProvider instance with the given configuration parameters.
SecurityProviderRegistration - Class in org.apache.jackrabbit.oak.security.internal
 
SecurityProviderRegistration() - Constructor for class org.apache.jackrabbit.oak.security.internal.SecurityProviderRegistration
 
SEED - Static variable in class org.apache.jackrabbit.oak.plugins.index.counter.NodeCounterEditorProvider
 
select(UniversalFilter, PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.RelativePathSelector
 
select(UniversalFilter, String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.RelativePathSelector
 
select(UniversalFilter, PropertyState, PropertyState) - Method in interface org.apache.jackrabbit.oak.plugins.observation.filter.UniversalFilter.Selector
Map a property event.
select(UniversalFilter, String, NodeState, NodeState) - Method in interface org.apache.jackrabbit.oak.plugins.observation.filter.UniversalFilter.Selector
Map a node event.
select(NodeBuilder) - Method in class org.apache.jackrabbit.oak.plugins.version.DateVersionSelector
 
select(NodeBuilder) - Method in interface org.apache.jackrabbit.oak.plugins.version.VersionSelector
Selects a version of the given version history.
selector(NodeTypeInfo, String) - Method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
 
SelectorExecutionPlan - Class in org.apache.jackrabbit.oak.query.plan
An execution plan for one selector in a query.
SelectorExecutionPlan(SelectorImpl, QueryIndex, QueryIndex.IndexPlan, double) - Constructor for class org.apache.jackrabbit.oak.query.plan.SelectorExecutionPlan
 
SelectorImpl - Class in org.apache.jackrabbit.oak.query.ast
A selector within a query.
SelectorImpl(NodeTypeInfo, String) - Constructor for class org.apache.jackrabbit.oak.query.ast.SelectorImpl
 
Selectors - Class in org.apache.jackrabbit.oak.plugins.observation.filter
Common Selector implementations
send(ByteBuffer) - Method in interface org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast.Broadcaster
Send a message.
send(ByteBuffer) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast.InMemoryBroadcaster
 
send(ByteBuffer) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast.TCPBroadcaster
 
send(ByteBuffer) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast.UDPBroadcaster
 
SESSION_ID - Static variable in class org.apache.jackrabbit.oak.OakInitializer
 
set(String, Object) - Method in class org.apache.jackrabbit.oak.core.SimpleCommitContext
 
set(String, long) - Method in class org.apache.jackrabbit.oak.plugins.document.UpdateOp
Set the property to the given long value.
set(String, boolean) - Method in class org.apache.jackrabbit.oak.plugins.document.UpdateOp
Set the property to the given boolean value.
set(String, String) - Method in class org.apache.jackrabbit.oak.plugins.document.UpdateOp
Set the property to the given String value.
SET_PROPERTY - Static variable in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
 
setAllowNumberLiterals(boolean) - Method in class org.apache.jackrabbit.oak.query.SQL2Parser
 
setAllowTextLiterals(boolean) - Method in class org.apache.jackrabbit.oak.query.SQL2Parser
Enable or disable support for text literals in queries.
setAlwaysFalse() - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
 
setAsyncDelay(int) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
Set the maximum delay to write the last revision to the root node.
setAsyncDelay(int) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
setAttributes(Credentials, Map<String, ?>) - Method in interface org.apache.jackrabbit.oak.spi.security.authentication.credentials.CredentialsSupport
Writes the attributes to the specified Credentials.
setAttributes(Credentials, Map<String, ?>) - Method in class org.apache.jackrabbit.oak.spi.security.authentication.credentials.SimpleCredentialsSupport
 
setAuthInfo(AuthInfo, Subject) - Static method in class org.apache.jackrabbit.oak.spi.security.authentication.AbstractLoginModule
 
setBlobStore(BlobStore) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
Set the blob store to use.
setBlockSize(int) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.BlobCache
 
setBranchCommit(UpdateOp, Revision) - Static method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
 
setBroadcastConfig(DynamicBroadcastConfig) - Method in interface org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast.Broadcaster
Change the dynamic broadcasting configuration.
setBroadcastConfig(DynamicBroadcastConfig) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast.InMemoryBroadcaster
 
setBroadcastConfig(DynamicBroadcastConfig) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast.TCPBroadcaster
 
setBroadcastConfig(DynamicBroadcastConfig) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast.UDPBroadcaster
 
setBroadcastConfig(DynamicBroadcastConfig) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCache
 
setBundlingDisabled(boolean) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
setCacheSegmentCount(int) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
setCacheStackMoveDistance(int) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
setCaptureStackTraces(boolean) - Method in class org.apache.jackrabbit.oak.query.stats.QueryStatsData
 
setCaptureStackTraces(boolean) - Method in interface org.apache.jackrabbit.oak.query.stats.QueryStatsMBean
Whether to capture a thread dump in addition to the thread name.
setCaptureStackTraces(boolean) - Method in class org.apache.jackrabbit.oak.query.stats.QueryStatsMBeanImpl
 
setChangeSetFilter(ChangeSetFilter) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder
 
setChangeSetMaxDepth(int) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
setChangeSetMaxItems(int) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
setCheckpoint(String) - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate.AsyncUpdateCallback
 
setChildrenFlag(UpdateOp, boolean) - Static method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
 
setCloseTimeOut(int) - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate
 
setClusterId(int) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
Set the cluster id to use.
setColumnSelector(Selector) - Method in class org.apache.jackrabbit.oak.query.xpath.Statement
 
setCommitRoot(UpdateOp, Revision, int) - Static method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
 
setCommitValueCacheSize(int) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
setContentRepository(ContentRepository) - Method in class org.apache.jackrabbit.oak.spi.security.authentication.callback.RepositoryCallback
 
setCorruptIndexHandler(TrackingCorruptIndexHandler) - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate
 
setCorruptIndexHandler(CorruptIndexHandler) - Method in class org.apache.jackrabbit.oak.plugins.index.IndexUpdateProvider
 
setCorruptInterval(long, TimeUnit) - Method in class org.apache.jackrabbit.oak.plugins.index.TrackingCorruptIndexHandler
 
setCredentials(Credentials) - Method in class org.apache.jackrabbit.oak.spi.security.authentication.callback.CredentialsCallback
Set the credentials.
setData(byte[]) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoBlob
 
setDefaultConfig(T) - Method in class org.apache.jackrabbit.oak.spi.security.CompositeConfiguration
 
setDelay(long) - Method in class org.apache.jackrabbit.oak.plugins.observation.CommitRateLimiter
Number of milliseconds to delay commits going through this hook.
setDelegate(RemovalListener<K, V>) - Method in class org.apache.jackrabbit.oak.plugins.document.cache.ForwardingListener
 
setDeleted(UpdateOp, Revision, boolean) - Static method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
 
setDeletedOnce(UpdateOp) - Static method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
 
setDiffCache(DiffCache) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
setDistinct(boolean) - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
 
setDistinct(boolean) - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
setDocumentStore(DocumentStore) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
Set the document store to use.
setDocumentStoreStatsCollector(DocumentStoreStatsCollector) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
setErrorWarnInterval(long, TimeUnit) - Method in class org.apache.jackrabbit.oak.plugins.index.TrackingCorruptIndexHandler
 
setExecutionContext(ExecutionContext) - Method in interface org.apache.jackrabbit.oak.query.Query
 
setExecutionContext(ExecutionContext) - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
setExecutionContext(ExecutionContext) - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
setExecutor(Executor) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
setExplain(boolean) - Method in interface org.apache.jackrabbit.oak.query.Query
 
setExplain(boolean) - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
setExplain(boolean) - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
setExplain(boolean) - Method in class org.apache.jackrabbit.oak.query.xpath.Statement
 
setFailTraversal(boolean) - Method in class org.apache.jackrabbit.oak.query.QueryEngineSettings
 
setFastQuerySize(boolean) - Method in class org.apache.jackrabbit.oak.query.QueryEngineSettings
 
setFilter(Filter) - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndexPlan
 
setFilter(String) - Method in class org.apache.jackrabbit.oak.plugins.index.inventory.IndexDefinitionPrinter
 
setFullTextComparisonWithoutIndex(boolean) - Method in class org.apache.jackrabbit.oak.query.QueryEngineSettings
 
setFullTextConstraint(FullTextExpression) - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
 
setGCMonitor(GCMonitor) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
setGCMonitor(GCMonitor) - Method in class org.apache.jackrabbit.oak.plugins.document.VersionGarbageCollector
 
setHasBinary(UpdateOp) - Static method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
 
setId(String) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoBlob
 
setIgnoreReindexFlags(boolean) - Method in class org.apache.jackrabbit.oak.plugins.index.IndexUpdate
 
setIgnoreReindexFlags(boolean) - Method in class org.apache.jackrabbit.oak.plugins.index.IndexUpdateProvider
 
setIncludeSelectorNameInWildcardColumns(boolean) - Method in class org.apache.jackrabbit.oak.query.SQL2Parser
 
setIndexMBeanRegistration(IndexMBeanRegistration) - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate
 
setInfo(Map<String, String>) - Method in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfo
Update the cluster node info.
setInstance(MapFactory) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.MapFactory
 
setInternal(boolean) - Method in interface org.apache.jackrabbit.oak.query.Query
 
setInternal(boolean) - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
setInternal(boolean) - Method in class org.apache.jackrabbit.oak.query.stats.QueryStatsData.QueryExecutionStats
 
setInternal(boolean) - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
setJournalCache(String) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
Sets the journal cache option.
setJournalGCMaxAge(long) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
setJournalPropertyHandlerFactory(JournalPropertyHandlerFactory) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
setLastMod(long) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoBlob
 
setLastRev(UpdateOp, Revision) - Static method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
 
setLeaseCheck(boolean) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
setLeaseCheckDisabled(boolean) - Method in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfo
 
setLeaseFailureHandler(LeaseFailureHandler) - Method in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfo
 
setLeaseFailureHandler(LeaseFailureHandler) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
setLeaseTimeOut(long) - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate
Milliseconds for the timeout
setLevel(int) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoBlob
 
setLimit(long) - Method in interface org.apache.jackrabbit.oak.query.Query
 
setLimit(long) - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
setLimit(long) - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
setLimitInMemory(long) - Method in class org.apache.jackrabbit.oak.query.QueryEngineSettings
 
setLimitReads(long) - Method in class org.apache.jackrabbit.oak.query.QueryEngineSettings
 
setLogging(boolean) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
setMatchesAllTypes(boolean) - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
 
setMaxBackOffMillis(int) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
setMaxItems(int) - Method in class org.apache.jackrabbit.oak.plugins.observation.ChangeCollectorProvider
FOR TESTING-ONLY
setMaxPathDepth(int) - Method in class org.apache.jackrabbit.oak.plugins.observation.ChangeCollectorProvider
FOR TESTING-ONLY
setMaxReplicationLag(long, TimeUnit) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
setMeasure(boolean) - Method in interface org.apache.jackrabbit.oak.query.Query
 
setMeasure(boolean) - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
setMeasure(boolean) - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
setMeasure(boolean) - Method in class org.apache.jackrabbit.oak.query.xpath.Statement
 
setMembershipSizeThreshold(int) - Method in class org.apache.jackrabbit.oak.security.user.MembershipWriter
 
setModified(UpdateOp, Revision) - Static method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
 
setMongoDB(String, String, int) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
Uses the given information to connect to to MongoDB as backend storage for the DocumentNodeStore.
setMongoDB(DB, int) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
Use the given MongoDB as backend storage for the DocumentNodeStore.
setMongoDB(DB) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
Use the given MongoDB as backend storage for the DocumentNodeStore.
setNew(boolean) - Method in class org.apache.jackrabbit.oak.plugins.document.UpdateOp
 
setNodeCountEstimator(NodeCountEstimator) - Method in class org.apache.jackrabbit.oak.plugins.index.IndexUpdate
 
setNodeCountEstimator(NodeCountEstimator) - Method in class org.apache.jackrabbit.oak.plugins.index.progress.IndexingProgressReporter
 
setNodeStateCache(DocumentNodeStateCache) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
setNodeStoreStatsCollector(DocumentNodeStoreStatsCollector) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
setOffset(long) - Method in interface org.apache.jackrabbit.oak.query.Query
 
setOffset(long) - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
setOffset(long) - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
setOptions(VersionGCOptions) - Method in class org.apache.jackrabbit.oak.plugins.document.VersionGarbageCollector
 
setOrderableChildren(boolean) - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractMutableTree
 
setOrderableChildren(boolean) - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.ImmutableTree
 
setOrderings(OrderingImpl[]) - Method in interface org.apache.jackrabbit.oak.query.Query
 
setOrderings(OrderingImpl[]) - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
setOrderings(OrderingImpl[]) - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
setOriginalQuery(String) - Method in class org.apache.jackrabbit.oak.query.xpath.Statement
 
setOuterJoin(boolean, boolean) - Method in class org.apache.jackrabbit.oak.query.ast.JoinImpl
 
setOuterJoin(boolean, boolean) - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
 
setOuterJoin(boolean, boolean) - Method in class org.apache.jackrabbit.oak.query.ast.SourceImpl
Set whether this source is the left hand side or right hand side of a left outer join.
setParameters(PreparedStatement, int) - Method in interface org.apache.jackrabbit.oak.plugins.document.rdb.RDBJDBCTools.PreparedStatementComponent
Set the parameters need by the statement component returned by RDBJDBCTools.PreparedStatementComponent.getStatementComponent()
setParameters(ConfigurationParameters) - Method in class org.apache.jackrabbit.oak.spi.security.ConfigurationBase
 
setPath(String) - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
 
setPersistentCache(String) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
Sets the persistent cache option.
setPolicy(String, AccessControlPolicy) - Method in class org.apache.jackrabbit.oak.security.authorization.accesscontrol.AccessControlManagerImpl
 
setPrefetchExternalChanges(boolean) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
setPreparing(boolean) - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
 
setPrevious(UpdateOp, Range) - Static method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
 
setPrincipalProvider(PrincipalProvider) - Method in class org.apache.jackrabbit.oak.spi.security.authentication.callback.PrincipalProviderCallback
Sets the PrincipalProvider that is being used during the authentication process.
setProperty(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractMutableTree
 
setProperty(String, T) - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractMutableTree
 
setProperty(String, T, Type<T>) - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractMutableTree
 
setProperty(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.ImmutableTree
 
setProperty(String, T) - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.ImmutableTree
 
setProperty(String, T, Type<T>) - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.ImmutableTree
 
setQueryConstraint(ConstraintImpl) - Method in class org.apache.jackrabbit.oak.query.ast.JoinImpl
 
setQueryConstraint(ConstraintImpl) - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
 
setQueryConstraint(ConstraintImpl) - Method in class org.apache.jackrabbit.oak.query.ast.SourceImpl
Set the complete constraint of the query (the WHERE ...
setQueryOptions(QueryOptions) - Method in interface org.apache.jackrabbit.oak.query.Query
Set the query option to be used for this query.
setQueryOptions(QueryOptions) - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
setQueryOptions(QueryOptions) - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
setQueryOptions(QueryOptions) - Method in class org.apache.jackrabbit.oak.query.xpath.Statement
 
setQuerySelectionMode(QueryEngineImpl.QuerySelectionMode) - Method in class org.apache.jackrabbit.oak.query.QueryEngineImpl
Instruct the query engine on how to behave with regards to the SQL2 optimised query if available.
setRDBConnection(DataSource) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
Sets a DataSource to use for the RDB document and blob stores.
setRDBConnection(DataSource, RDBOptions) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
Sets a DataSource to use for the RDB document and blob stores, including RDBOptions.
setRDBConnection(DataSource, DataSource) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
Sets a DataSources to use for the RDB document and blob stores.
setReadOnlyMode() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
setReadWriteMode(String) - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStore
Set the level of guarantee for read and write operations, if supported by this backend.
setReadWriteMode(String) - Method in class org.apache.jackrabbit.oak.plugins.document.memory.MemoryDocumentStore
 
setReadWriteMode(String) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoDocumentStore
 
setReadWriteMode(String) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
setReadWriteMode(String) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LeaseCheckDocumentStoreWrapper
 
setReadWriteMode(String) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LoggingDocumentStoreWrapper
 
setReadWriteMode(String) - Method in class org.apache.jackrabbit.oak.plugins.document.util.SynchronizingDocumentStoreWrapper
 
setReadWriteMode(String) - Method in class org.apache.jackrabbit.oak.plugins.document.util.TimingDocumentStoreWrapper
 
setRevision(UpdateOp, Revision, String) - Static method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
 
setSecurityProvider(SecurityProvider) - Method in class org.apache.jackrabbit.oak.spi.security.authentication.callback.RepositoryCallback
 
setSecurityProvider(SecurityProvider) - Method in class org.apache.jackrabbit.oak.spi.security.authentication.callback.SecurityProviderCallback
 
setSecurityProvider(SecurityProvider) - Method in class org.apache.jackrabbit.oak.spi.security.CompositeConfiguration
 
setSecurityProvider(SecurityProvider) - Method in class org.apache.jackrabbit.oak.spi.security.ConfigurationBase
 
setSelectors(ArrayList<Selector>) - Method in class org.apache.jackrabbit.oak.query.xpath.Statement
 
setSocketKeepAlive(boolean) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
Enables the socket keep-alive option for MongoDB.
setStalePrevious(UpdateOp, Revision, int) - Static method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
 
setStatisticsProvider(StatisticsProvider) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
setStatsCollector(DocumentStoreStatsCollector) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoDocumentStore
 
setStatsCollector(DocumentStoreStatsCollector) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
setSupportSQL1(boolean) - Method in class org.apache.jackrabbit.oak.query.SQL2Parser
Enable or disable support for SQL-1 queries.
setSweepRevision(UpdateOp, Revision) - Static method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
 
setThreadName(String) - Method in class org.apache.jackrabbit.oak.query.stats.QueryStatsData.QueryExecutionStats
 
setTiming(boolean) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
Use the timing document store wrapper.
SETTINGS - Static variable in class org.apache.jackrabbit.oak.plugins.document.Collection
The 'settings' collection contains setting/state data required for DocumentNodeStore
setTokenProvider(TokenProvider) - Method in class org.apache.jackrabbit.oak.spi.security.authentication.callback.TokenProviderCallback
Sets the TokenProvider that is being used during the authentication process.
setTraversalEnabled(boolean) - Method in interface org.apache.jackrabbit.oak.query.Query
 
setTraversalEnabled(boolean) - Method in class org.apache.jackrabbit.oak.query.QueryEngineImpl
 
setTraversalEnabled(boolean) - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
setTraversalEnabled(boolean) - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
setTraversalRateEstimator(TraversalRateEstimator) - Method in class org.apache.jackrabbit.oak.plugins.index.IndexUpdate
 
setTraversalRateEstimator(TraversalRateEstimator) - Method in class org.apache.jackrabbit.oak.plugins.index.progress.IndexingProgressReporter
 
setType(TreeType) - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.ImmutableTree
 
setUpdateLimit(int) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
setupNamespaces(NodeBuilder) - Static method in class org.apache.jackrabbit.oak.plugins.name.Namespaces
 
setUserManager(UserManager) - Method in class org.apache.jackrabbit.oak.spi.security.authentication.callback.UserManagerCallback
Sets the UserManager that is being used during the authentication process.
setUseSimpleRevision(boolean) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
setValidatorProviders(List<ValidatorProvider>) - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate.AsyncUpdateCallback
 
setValidatorProviders(List<ValidatorProvider>) - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate
 
setWhere(Expression) - Method in class org.apache.jackrabbit.oak.query.xpath.Statement
 
setWhiteboard(Whiteboard) - Method in class org.apache.jackrabbit.oak.security.SecurityProviderImpl
 
setWhiteboard(Whiteboard) - Method in class org.apache.jackrabbit.oak.spi.security.authentication.callback.WhiteboardCallback
Sets the Whiteboard that is being used during the authentication process.
setWorkspaceName(String) - Method in class org.apache.jackrabbit.oak.spi.security.authentication.callback.RepositoryCallback
 
setWriteMap(CacheMap<K, V>) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.MultiGenerationMap
 
shallowCopy(String) - Method in class org.apache.jackrabbit.oak.plugins.document.UpdateOp
Creates an update operation for the document with the given id.
SHARED_KEY_ATTRIBUTES - Static variable in class org.apache.jackrabbit.oak.spi.security.authentication.AbstractLoginModule
Key of the sharedState entry referring to public attributes that are shared between multiple login modules.
SHARED_KEY_CREDENTIALS - Static variable in class org.apache.jackrabbit.oak.spi.security.authentication.AbstractLoginModule
Key of the sharedState entry referring to validated Credentials that is shared between multiple login modules.
SHARED_KEY_LOGIN_NAME - Static variable in class org.apache.jackrabbit.oak.spi.security.authentication.AbstractLoginModule
Key of the sharedState entry referring to a valid login ID that is shared between multiple login modules.
SHARED_KEY_PRE_AUTH_LOGIN - Static variable in class org.apache.jackrabbit.oak.spi.security.authentication.AbstractLoginModule
Key of the sharedState entry referring to pre authenticated login information that is shared between multiple login modules.
sharedState - Variable in class org.apache.jackrabbit.oak.spi.security.authentication.AbstractLoginModule
 
shouldCache(DocumentNodeStore, K) - Method in enum org.apache.jackrabbit.oak.plugins.document.persistentCache.CacheType
 
similar(String, String, StaticOperandImpl) - Method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
 
SimilarImpl - Class in org.apache.jackrabbit.oak.query.ast
Support for "similar(...)
SimpleCommitContext - Class in org.apache.jackrabbit.oak.core
 
SimpleCommitContext() - Constructor for class org.apache.jackrabbit.oak.core.SimpleCommitContext
 
SimpleCredentialsSupport - Class in org.apache.jackrabbit.oak.spi.security.authentication.credentials
Implementation of the SupportedCredentials interface that handles SimpleCredentials.
SimpleNodeAggregator - Class in org.apache.jackrabbit.oak.plugins.index.aggregate
List based NodeAggregator
SimpleNodeAggregator() - Constructor for class org.apache.jackrabbit.oak.plugins.index.aggregate.SimpleNodeAggregator
 
SimpleRateEstimator - Class in org.apache.jackrabbit.oak.plugins.index.progress
 
SimpleRateEstimator() - Constructor for class org.apache.jackrabbit.oak.plugins.index.progress.SimpleRateEstimator
 
simplify() - Method in class org.apache.jackrabbit.oak.query.ast.AndImpl
 
simplify() - Method in class org.apache.jackrabbit.oak.query.ast.ConstraintImpl
Simplify the expression if possible, for example by removing duplicate expressions.
simplify() - Method in class org.apache.jackrabbit.oak.query.ast.InImpl
 
simplify() - Method in class org.apache.jackrabbit.oak.query.ast.NotImpl
Apply DeMorgan's Laws to push AND/OR constraints higher.
simplify() - Method in class org.apache.jackrabbit.oak.query.ast.OrImpl
 
size() - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.Include
 
size() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.MultiGenerationMap
 
size() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AbstractAccessControlList
 
size() - Method in class org.apache.jackrabbit.oak.spi.security.ConfigurationParameters
skippingCorruptIndex(String, String, Calendar) - Method in interface org.apache.jackrabbit.oak.plugins.index.CorruptIndexHandler
Callback method to inform handler that a corrupt index has been skipped
skippingCorruptIndex(String, String, Calendar) - Method in class org.apache.jackrabbit.oak.plugins.index.TrackingCorruptIndexHandler
 
somethingIndexed() - Method in class org.apache.jackrabbit.oak.plugins.index.progress.IndexingProgressReporter
 
SourceImpl - Class in org.apache.jackrabbit.oak.query.ast
The base class of a selector and a join.
SourceImpl() - Constructor for class org.apache.jackrabbit.oak.query.ast.SourceImpl
 
SPECIAL_PATH_PREFIX - Static variable in class org.apache.jackrabbit.oak.query.ast.JoinConditionImpl
The prefix for known paths.
spellcheck(String, StaticOperandImpl) - Method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
 
SPELLCHECK_PREFIX - Static variable in class org.apache.jackrabbit.oak.query.ast.SpellcheckImpl
 
SpellcheckImpl - Class in org.apache.jackrabbit.oak.query.ast
Support for "spellcheck(...)
split(RevisionContext, RevisionVector, Function<String, Long>) - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
Returns update operations to split this document.
splitDocGarbage - Variable in class org.apache.jackrabbit.oak.plugins.document.SplitDocumentCleanUp
 
SplitDocumentCleanUp - Class in org.apache.jackrabbit.oak.plugins.document
Implements a split document cleanup.
SplitDocumentCleanUp(DocumentStore, VersionGarbageCollector.VersionGCStats, Iterable<NodeDocument>) - Constructor for class org.apache.jackrabbit.oak.plugins.document.SplitDocumentCleanUp
 
splitDocumentsDeleted(long) - Method in interface org.apache.jackrabbit.oak.plugins.document.RevisionGCStatsCollector
 
SQL2_OPTIMISATION_FLAG - Static variable in class org.apache.jackrabbit.oak.query.QueryEngineSettings
the flag used to turn on/off the optimisations on top of the org.apache.jackrabbit.oak.query.Query object.
SQL2_OPTIMISATION_FLAG_2 - Static variable in class org.apache.jackrabbit.oak.query.QueryEngineSettings
 
SQL2_OPTIMIZATION_2 - Static variable in class org.apache.jackrabbit.oak.query.QueryEngineSettings
 
SQL2Parser - Class in org.apache.jackrabbit.oak.query
The SQL2 parser can convert a JCR-SQL2 query to a query.
SQL2Parser(NamePathMapper, NodeTypeInfoProvider, QueryEngineSettings, QueryStatsData.QueryExecutionStats) - Constructor for class org.apache.jackrabbit.oak.query.SQL2Parser
Create a new parser.
StableRevisionComparator - Class in org.apache.jackrabbit.oak.plugins.document
StableRevisionComparator implements a revision comparator, which is only based on stable information available in the two revisions presented to this comparator.
STAR - Static variable in class org.apache.jackrabbit.oak.plugins.observation.filter.GlobbingPathFilter
 
STAR_STAR - Static variable in class org.apache.jackrabbit.oak.plugins.observation.filter.GlobbingPathFilter
 
start(Tree) - Method in class org.apache.jackrabbit.oak.security.authorization.accesscontrol.AccessControlImporter
 
start() - Method in interface org.apache.jackrabbit.oak.spi.xml.Importer
Called once at the beginning of the content import.
start(Tree) - Method in interface org.apache.jackrabbit.oak.spi.xml.ProtectedNodeImporter
Notifies this importer about the existence of a protected node that has either been created (NEW) or has been found to be existing.
START_TIME_KEY - Static variable in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfo
The start time.
startAndDuration(long) - Method in class org.apache.jackrabbit.oak.plugins.document.util.TimeInterval
Returns a new interval starting at the previous time, but ending after the specified duration.
startBackup() - Method in class org.apache.jackrabbit.oak.management.RepositoryManager
 
startChildInfo(NodeInfo, List<PropInfo>) - Method in class org.apache.jackrabbit.oak.security.authorization.accesscontrol.AccessControlImporter
 
startChildInfo(NodeInfo, List<PropInfo>) - Method in interface org.apache.jackrabbit.oak.spi.xml.ProtectedNodeImporter
Informs this importer about a new childInfo and it's properties.
startDataStoreGC(boolean) - Method in class org.apache.jackrabbit.oak.management.RepositoryManager
 
startLoaderTimer() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
startMark() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoBlobStore
 
startMark() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.BlobCache
 
startMark() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBBlobStore
 
startNode(NodeInfo, List<PropInfo>) - Method in interface org.apache.jackrabbit.oak.spi.xml.Importer
Called to start the import of a node.
startPropertyIndexAsyncReindex() - Method in class org.apache.jackrabbit.oak.management.RepositoryManager
 
startPropertyIndexAsyncReindex() - Method in class org.apache.jackrabbit.oak.plugins.index.property.jmx.PropertyIndexAsyncReindex
 
startPropertyIndexAsyncReindex() - Method in interface org.apache.jackrabbit.oak.plugins.index.property.jmx.PropertyIndexAsyncReindexMBean
Initiate a reindex operation for the property indexes marked for reindexing
startReadTimer() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCacheStats
 
startRestore() - Method in class org.apache.jackrabbit.oak.management.RepositoryManager
 
startRevisionGC() - Method in class org.apache.jackrabbit.oak.management.RepositoryManager
 
startRevisionGCForRole(String) - Method in class org.apache.jackrabbit.oak.management.RepositoryManager
 
STATE - Static variable in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfo
The state of the cluster.
Statement - Class in org.apache.jackrabbit.oak.query.xpath
An xpath statement.
Statement() - Constructor for class org.apache.jackrabbit.oak.query.xpath.Statement
 
StaticOperandImpl - Class in org.apache.jackrabbit.oak.query.ast
The base class for static operands (literal, bind variables).
StaticOperandImpl() - Constructor for class org.apache.jackrabbit.oak.query.ast.StaticOperandImpl
 
statisticsProvider(StatisticsProvider) - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.SecondaryStoreBuilder
 
StatisticsProviderFactory - Class in org.apache.jackrabbit.oak.plugins.metric
Factory to create StatisticsProvider depending on setup.
StatisticsProviderFactory() - Constructor for class org.apache.jackrabbit.oak.plugins.metric.StatisticsProviderFactory
 
stats - Variable in class org.apache.jackrabbit.oak.plugins.document.SplitDocumentCleanUp
 
stop() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.replica.ReplicaSetInfo
 
stop() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.async.CacheActionDispatcher
Stop the processing.
store - Variable in class org.apache.jackrabbit.oak.plugins.document.DocumentMK
The document store (might be used by multiple DocumentMKs).
store - Variable in class org.apache.jackrabbit.oak.plugins.document.SplitDocumentCleanUp
 
storeBlock(byte[], int, byte[]) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoBlobStore
 
storeBlock(byte[], int, byte[]) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBBlobStore
 
StringCache - Class in org.apache.jackrabbit.oak.plugins.document
TODO document
StringConstraint - Class in org.apache.jackrabbit.oak.plugins.nodetype.constraint
 
StringConstraint(String) - Constructor for class org.apache.jackrabbit.oak.plugins.nodetype.constraint.StringConstraint
 
StringValue - Class in org.apache.jackrabbit.oak.plugins.document.util
A cache value wrapping a simple string.
StringValue(String) - Constructor for class org.apache.jackrabbit.oak.plugins.document.util.StringValue
 
StripedNodeDocumentLocks - Class in org.apache.jackrabbit.oak.plugins.document.locks
 
StripedNodeDocumentLocks() - Constructor for class org.apache.jackrabbit.oak.plugins.document.locks.StripedNodeDocumentLocks
 
subject - Variable in class org.apache.jackrabbit.oak.spi.security.authentication.AbstractLoginModule
 
suggest(String, StaticOperandImpl) - Method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
 
SUGGEST_PREFIX - Static variable in class org.apache.jackrabbit.oak.query.ast.SuggestImpl
 
SuggestImpl - Class in org.apache.jackrabbit.oak.query.ast
Support for "suggest(...)
summaryReport() - Method in interface org.apache.jackrabbit.oak.plugins.document.cache.CacheInvalidationStats
 
supertypesDiff() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeDefDiff
 
SUPPORTED_CREDENTIALS - Static variable in class org.apache.jackrabbit.oak.security.authentication.user.LoginModuleImpl
 
supportedPermissions(Tree, PropertyState, long) - Method in class org.apache.jackrabbit.oak.security.authorization.permission.PermissionProviderImpl
 
supportedPermissions(TreeLocation, long) - Method in class org.apache.jackrabbit.oak.security.authorization.permission.PermissionProviderImpl
 
supportedPermissions(TreePermission, PropertyState, long) - Method in class org.apache.jackrabbit.oak.security.authorization.permission.PermissionProviderImpl
 
supportedPermissions(Tree, PropertyState, long) - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.AggregatedPermissionProvider
Allows to determined the set or subset of permissions evaluated by the implementing permission provider for the specified item (identified by tree and optionally property) or at the repository level in case the specified tree is null.
supportedPermissions(TreeLocation, long) - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.AggregatedPermissionProvider
Allows to determined the set or subset of permissions evaluated by the implementing permission provider for the specified location.
supportedPermissions(TreePermission, PropertyState, long) - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.AggregatedPermissionProvider
Allows to determined the set or subset of permissions evaluated by the implementing permission provider for the specified tree permission (plus optionally property).
supportedPrivileges(Tree, PrivilegeBits) - Method in class org.apache.jackrabbit.oak.security.authorization.permission.PermissionProviderImpl
 
supportedPrivileges(Tree, PrivilegeBits) - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.AggregatedPermissionProvider
Allows to determined the set or subset of privileges evaluated by the implementing permission provider for the specified tree or at the repository level in case the specified tree is null.
supportsMixin(String) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.EffectiveNodeType
Determines whether this effective node type supports adding the specified mixin.
supportsRangeConditions() - Method in class org.apache.jackrabbit.oak.query.ast.DynamicOperandImpl
 
supportsRangeConditions() - Method in class org.apache.jackrabbit.oak.query.ast.NodeLocalNameImpl
 
supportsRangeConditions() - Method in class org.apache.jackrabbit.oak.query.ast.NodeNameImpl
 
supportsRangeConditions() - Method in class org.apache.jackrabbit.oak.query.ast.PropertyValueImpl
 
sweep() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoBlobStore
 
sweep() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.BlobCache
 
sweep() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBBlobStore
 
switchGenerationIfNeeded() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCache
 
switchLane(NodeBuilder, String) - Static method in class org.apache.jackrabbit.oak.plugins.index.importer.AsyncLaneSwitcher
Make a copy of current async value and replace it with one required for offline reindexing The switch lane operation can be safely repeated and if the index lane is found to be switched already it would not be modified
SynchronizingDocumentStoreWrapper - Class in org.apache.jackrabbit.oak.plugins.document.util
Implements a DocumentStore wrapper which synchronizes on all methods.
SynchronizingDocumentStoreWrapper(DocumentStore) - Constructor for class org.apache.jackrabbit.oak.plugins.document.util.SynchronizingDocumentStoreWrapper
 
SYS_PROP_DISABLE_JOURNAL - Static variable in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
SYSTEM_PATHS - Static variable in interface org.apache.jackrabbit.oak.plugins.version.VersionConstants
 
SystemPrincipal - Class in org.apache.jackrabbit.oak.spi.security.principal
Principal to mark an system internal subject.
SystemRoot - Class in org.apache.jackrabbit.oak.core
Internal extension of the MutableRoot to be used when an usage of the system internal subject is needed.
SystemSubject - Class in org.apache.jackrabbit.oak.spi.security.authentication
Internal utility providing access to a system internal subject instance.
SystemUserPrincipal - Interface in org.apache.jackrabbit.oak.spi.security.principal
Principal used to mark a system user.

T

tablePrefix(String) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBOptions
Prefix for table names.
TCPBroadcaster - Class in org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast
A broadcast mechanism that uses TCP.
TCPBroadcaster(String) - Constructor for class org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast.TCPBroadcaster
 
testPath(String) - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
 
TextValue - Interface in org.apache.jackrabbit.oak.spi.xml
TextValue represents a serialized property value read from a System or Document View XML document.
THEIRS - Static variable in class org.apache.jackrabbit.oak.plugins.commit.DefaultConflictHandler
Deprecated.
A ConflictHandler which always return oak.spi.commit.ConflictHandler.Resolution.
THEIRS - Static variable in class org.apache.jackrabbit.oak.plugins.commit.DefaultThreeWayConflictHandler
A ConflictHandler which always return ThreeWayConflictHandler.Resolution.THEIRS.
THIS - Static variable in class org.apache.jackrabbit.oak.plugins.observation.filter.Selectors
A selector returning the node for which a call back on EventFilter was called or a non existing node in the case of a property call back.
TimeInterval - Class in org.apache.jackrabbit.oak.plugins.document.util
A class representing a time interval, with utility methods to derive related intervals, check time stamps for containment, etc.
TimeInterval(long, long) - Constructor for class org.apache.jackrabbit.oak.plugins.document.util.TimeInterval
 
TIMEOUT_SECONDS - Static variable in class org.apache.jackrabbit.oak.plugins.index.importer.AbortingIndexerLock
 
Timestamped<T> - Class in org.apache.jackrabbit.oak.plugins.document.mongo.replica
A value with a timestamp.
Timestamped(T, long) - Constructor for class org.apache.jackrabbit.oak.plugins.document.mongo.replica.Timestamped
 
timestampToString(long) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
Provides a readable string for given timestamp
TimingDocumentStoreWrapper - Class in org.apache.jackrabbit.oak.plugins.document.util
A DocumentStore wrapper that can be used to log and also time DocumentStore calls.
TimingDocumentStoreWrapper(DocumentStore) - Constructor for class org.apache.jackrabbit.oak.plugins.document.util.TimingDocumentStoreWrapper
 
tnData - Variable in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBBlobStore
 
tnMeta - Variable in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBBlobStore
 
TokenConfiguration - Interface in org.apache.jackrabbit.oak.spi.security.authentication.token
Configuration for token management.
TokenConfigurationImpl - Class in org.apache.jackrabbit.oak.security.authentication.token
Default implementation for the TokenConfiguration interface.
TokenConfigurationImpl() - Constructor for class org.apache.jackrabbit.oak.security.authentication.token.TokenConfigurationImpl
 
TokenConfigurationImpl(SecurityProvider) - Constructor for class org.apache.jackrabbit.oak.security.authentication.token.TokenConfigurationImpl
 
TokenInfo - Interface in org.apache.jackrabbit.oak.spi.security.authentication.token
The TokenInfo provides data associated with a login token and basic methods to verify the validity of token credentials at given point in time.
TokenLoginModule - Class in org.apache.jackrabbit.oak.security.authentication.token
LoginModule implementation that is able to handle login request based on TokenCredentials.
TokenLoginModule() - Constructor for class org.apache.jackrabbit.oak.security.authentication.token.TokenLoginModule
 
TokenProvider - Interface in org.apache.jackrabbit.oak.spi.security.authentication.token
Interface to manage create and manage login tokens.
TokenProviderCallback - Class in org.apache.jackrabbit.oak.spi.security.authentication.callback
Callback implementation to set and retrieve a login token provider.
TokenProviderCallback() - Constructor for class org.apache.jackrabbit.oak.spi.security.authentication.callback.TokenProviderCallback
 
toMap() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.RevisionEntry
 
toMs - Variable in class org.apache.jackrabbit.oak.plugins.document.util.TimeInterval
 
TOO_MANY_UNION - Static variable in class org.apache.jackrabbit.oak.query.QueryImpl
 
toReadableString() - Method in class org.apache.jackrabbit.oak.plugins.document.Revision
 
toString() - Method in class org.apache.jackrabbit.oak.core.SimpleCommitContext
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundlingHandler
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.DocumentBundlor
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.Include
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfo
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfoDocument
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.document.Collection
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.document.Document
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState.Children
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.document.FormatVersion
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.document.LocalDiffCache.Diff
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.document.memory.MemoryDocumentStore
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.replica.Timestamped
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.RevisionEntry
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.document.PathRev
 
toString() - Method in enum org.apache.jackrabbit.oak.plugins.document.rdb.RDBBlobStoreDB
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore.QueryCondition
 
toString() - Method in enum org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStoreDB
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.document.Revision
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.document.RevisionVector
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.document.UpdateOp.Condition
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.document.UpdateOp.Key
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.document.UpdateOp.Operation
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.document.UpdateOp
 
toString(MongoClientOptions) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.MongoConnection
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.document.util.RevisionsKey
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.document.util.StringValue
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.document.util.TimeInterval
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.document.VersionGarbageCollector.VersionGCStats
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexInfo
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.index.datastore.DataStoreTextWriter
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.index.PathFilter
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.index.property.PropertyIndexPlan
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.BooleanConstraint
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.NameConstraint
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.NumericConstraint
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.PathConstraint
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.ReferenceConstraint
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.StringConstraint
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeDefDiff
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.TypePredicate
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.observation.ChangeSet
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.observation.ChangeSetBuilder
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.ChangeSetFilterImpl
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.GlobbingPathFilter
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractTree
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.tree.TreeLocation
 
toString() - Method in class org.apache.jackrabbit.oak.plugins.version.VersionablePathHook
 
toString() - Method in class org.apache.jackrabbit.oak.query.ast.AndImpl
 
toString() - Method in class org.apache.jackrabbit.oak.query.ast.BindVariableValueImpl
 
toString() - Method in class org.apache.jackrabbit.oak.query.ast.ChildNodeImpl
 
toString() - Method in class org.apache.jackrabbit.oak.query.ast.ChildNodeJoinConditionImpl
 
toString() - Method in class org.apache.jackrabbit.oak.query.ast.ColumnImpl
 
toString() - Method in class org.apache.jackrabbit.oak.query.ast.ComparisonImpl
 
toString() - Method in class org.apache.jackrabbit.oak.query.ast.DescendantNodeImpl
 
toString() - Method in class org.apache.jackrabbit.oak.query.ast.DescendantNodeJoinConditionImpl
 
toString() - Method in class org.apache.jackrabbit.oak.query.ast.EquiJoinConditionImpl
 
toString() - Method in class org.apache.jackrabbit.oak.query.ast.FullTextSearchImpl
 
toString() - Method in class org.apache.jackrabbit.oak.query.ast.FullTextSearchScoreImpl
 
toString() - Method in class org.apache.jackrabbit.oak.query.ast.InImpl
 
toString() - Method in class org.apache.jackrabbit.oak.query.ast.JoinImpl
 
toString() - Method in enum org.apache.jackrabbit.oak.query.ast.JoinType
Returns the join type.
toString() - Method in class org.apache.jackrabbit.oak.query.ast.LengthImpl
 
toString() - Method in class org.apache.jackrabbit.oak.query.ast.LiteralImpl
 
toString() - Method in class org.apache.jackrabbit.oak.query.ast.LowerCaseImpl
 
toString() - Method in class org.apache.jackrabbit.oak.query.ast.NativeFunctionImpl
 
toString() - Method in class org.apache.jackrabbit.oak.query.ast.NodeLocalNameImpl
 
toString() - Method in class org.apache.jackrabbit.oak.query.ast.NodeNameImpl
 
toString() - Method in class org.apache.jackrabbit.oak.query.ast.NotFullTextSearchImpl
 
toString() - Method in class org.apache.jackrabbit.oak.query.ast.NotImpl
 
toString() - Method in enum org.apache.jackrabbit.oak.query.ast.Operator
Returns the name of this query operator.
toString() - Method in class org.apache.jackrabbit.oak.query.ast.OrderingImpl
 
toString() - Method in class org.apache.jackrabbit.oak.query.ast.OrImpl
 
toString() - Method in class org.apache.jackrabbit.oak.query.ast.PropertyExistenceImpl
 
toString() - Method in class org.apache.jackrabbit.oak.query.ast.PropertyInexistenceImpl
 
toString() - Method in class org.apache.jackrabbit.oak.query.ast.PropertyValueImpl
 
toString() - Method in class org.apache.jackrabbit.oak.query.ast.SameNodeImpl
 
toString() - Method in class org.apache.jackrabbit.oak.query.ast.SameNodeJoinConditionImpl
 
toString() - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
 
toString() - Method in class org.apache.jackrabbit.oak.query.ast.SimilarImpl
 
toString() - Method in class org.apache.jackrabbit.oak.query.ast.SpellcheckImpl
 
toString() - Method in class org.apache.jackrabbit.oak.query.ast.SuggestImpl
 
toString() - Method in class org.apache.jackrabbit.oak.query.ast.UpperCaseImpl
 
toString() - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
 
toString() - Method in class org.apache.jackrabbit.oak.query.QueryEngineSettings
 
toString() - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
toString() - Method in class org.apache.jackrabbit.oak.query.ResultRowImpl
 
toString() - Method in class org.apache.jackrabbit.oak.query.stats.QueryStatsData
 
toString() - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
toString() - Method in class org.apache.jackrabbit.oak.query.xpath.Statement
 
toString() - Method in class org.apache.jackrabbit.oak.security.authorization.permission.PermissionHook
 
toString() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.AuthInfoImpl
 
toString() - Method in class org.apache.jackrabbit.oak.spi.security.principal.EveryonePrincipal
 
toString() - Method in class org.apache.jackrabbit.oak.spi.security.principal.PrincipalImpl
 
toString() - Method in class org.apache.jackrabbit.oak.spi.security.privilege.ImmutablePrivilegeDefinition
 
toString() - Method in class org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeBits
 
toStringBuilder(StringBuilder) - Method in class org.apache.jackrabbit.oak.plugins.document.Revision
Appends the string representation of this revision to the given StringBuilder.
toStringBuilder(StringBuilder) - Method in class org.apache.jackrabbit.oak.plugins.document.RevisionVector
Appends the string representation of this revision vector to the passed StringBuilder.
track(String) - Method in interface org.apache.jackrabbit.oak.plugins.document.LastRevTracker
Called when a document needs an update of the _lastRev field.
TRACK_DEPRECATION_EVERY - Static variable in interface org.apache.jackrabbit.oak.plugins.index.property.OrderedIndex
the deprecation message will be tracked every N times
TrackingCorruptIndexHandler - Class in org.apache.jackrabbit.oak.plugins.index
 
TrackingCorruptIndexHandler() - Constructor for class org.apache.jackrabbit.oak.plugins.index.TrackingCorruptIndexHandler
 
TrackingCorruptIndexHandler.CorruptIndexInfo - Class in org.apache.jackrabbit.oak.plugins.index
 
transformAndSeal(Map<Object, Object>, String, int) - Method in class org.apache.jackrabbit.oak.plugins.document.Document
Transform and seal the data of this document.
traversal - Variable in class org.apache.jackrabbit.oak.query.QueryOptions
 
TraversalRateEstimator - Interface in org.apache.jackrabbit.oak.plugins.index.progress
 
traversedNode(NodeTraversalCallback.PathSource) - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate.AsyncUpdateCallback
 
traversedNode(NodeTraversalCallback.PathSource) - Method in interface org.apache.jackrabbit.oak.plugins.index.NodeTraversalCallback
 
traversedNode(NodeTraversalCallback.PathSource) - Method in class org.apache.jackrabbit.oak.plugins.index.progress.IndexingProgressReporter
 
traversedNode() - Method in class org.apache.jackrabbit.oak.plugins.index.progress.MetricRateEstimator
 
traversedNode() - Method in class org.apache.jackrabbit.oak.plugins.index.progress.SimpleRateEstimator
 
traversedNode() - Method in interface org.apache.jackrabbit.oak.plugins.index.progress.TraversalRateEstimator
 
TRAVERSING_WARN - Static variable in class org.apache.jackrabbit.oak.plugins.index.property.strategy.ContentMirrorStoreStrategy
logging a warning every oak.traversing.warn traversed nodes.
TraversingIndex - Class in org.apache.jackrabbit.oak.query.index
An index that traverses over a given subtree.
TraversingIndex() - Constructor for class org.apache.jackrabbit.oak.query.index.TraversingIndex
 
TreeConstants - Interface in org.apache.jackrabbit.oak.plugins.tree.impl
 
TreeContext - Interface in org.apache.jackrabbit.oak.plugins.tree
TreeContext represents item related information in relation to a dedicated module.
TreeFactory - Class in org.apache.jackrabbit.oak.plugins.tree
Factory to obtain Tree objects from NodeStates and NodeBuilders.
TreeLocation - Class in org.apache.jackrabbit.oak.plugins.tree
A TreeLocation denotes a location inside a tree.
TreeLocation() - Constructor for class org.apache.jackrabbit.oak.plugins.tree.TreeLocation
 
TreePermission - Interface in org.apache.jackrabbit.oak.spi.security.authorization.permission
The TreePermission allow to evaluate permissions defined for a given Tree and it's properties.
TreeType - Enum in org.apache.jackrabbit.oak.plugins.tree
Allows to distinguish different types of trees based on their name, ancestry or primary type.
TreeTypeProvider - Class in org.apache.jackrabbit.oak.plugins.tree
 
TreeTypeProvider(TreeContext) - Constructor for class org.apache.jackrabbit.oak.plugins.tree.TreeTypeProvider
 
TreeUtil - Class in org.apache.jackrabbit.oak.plugins.tree
Utility providing common operations for the Tree that are not provided by the API.
TRIVIAL - Static variable in class org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeDefDiff
trivial modification: does not affect consistency of existing content
TYPE - Static variable in interface org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreMBean
 
TYPE - Static variable in interface org.apache.jackrabbit.oak.plugins.document.DocumentStoreStatsMBean
 
TYPE - Static variable in interface org.apache.jackrabbit.oak.plugins.document.RevisionGCStatsMBean
 
type - Variable in class org.apache.jackrabbit.oak.plugins.document.UpdateOp.Condition
The condition type.
type - Variable in class org.apache.jackrabbit.oak.plugins.document.UpdateOp.Operation
The operation type.
TYPE - Static variable in interface org.apache.jackrabbit.oak.plugins.index.counter.jmx.NodeCounterMBean
 
TYPE - Static variable in class org.apache.jackrabbit.oak.plugins.index.counter.NodeCounterEditorProvider
 
TYPE - Static variable in interface org.apache.jackrabbit.oak.plugins.index.property.jmx.PropertyIndexAsyncReindexMBean
 
TYPE - Static variable in interface org.apache.jackrabbit.oak.plugins.index.property.jmx.PropertyIndexStatsMBean
 
TYPE - Static variable in interface org.apache.jackrabbit.oak.plugins.index.property.OrderedIndex
 
TYPE - Static variable in class org.apache.jackrabbit.oak.plugins.index.property.PropertyIndexEditorProvider
 
TYPE - Static variable in class org.apache.jackrabbit.oak.plugins.index.reference.NodeReferenceConstants
 
TYPE - Static variable in class org.apache.jackrabbit.oak.plugins.observation.ChangeCollectorProvider
 
TYPE - Static variable in interface org.apache.jackrabbit.oak.plugins.observation.filter.FilterConfigMBean
 
TYPE - Static variable in interface org.apache.jackrabbit.oak.query.stats.QueryStatsMBean
 
TYPE_PROPERTY_NAME - Static variable in interface org.apache.jackrabbit.oak.plugins.index.IndexConstants
 
TYPE_UNKNOWN - Static variable in interface org.apache.jackrabbit.oak.plugins.index.IndexConstants
 
typeCode() - Method in enum org.apache.jackrabbit.oak.plugins.document.NodeDocument.SplitDocType
 
TypeEditorProvider - Class in org.apache.jackrabbit.oak.plugins.nodetype
 
TypeEditorProvider(boolean) - Constructor for class org.apache.jackrabbit.oak.plugins.nodetype.TypeEditorProvider
 
TypeEditorProvider() - Constructor for class org.apache.jackrabbit.oak.plugins.nodetype.TypeEditorProvider
 
TypePredicate - Class in org.apache.jackrabbit.oak.plugins.nodetype
Inheritance-aware node type predicate for node states.
TypePredicate(NodeState, String) - Constructor for class org.apache.jackrabbit.oak.plugins.nodetype.TypePredicate
Creates a predicate for checking whether a node state is an instance of the named node type.
TypePredicate(NodeState, Iterable<String>) - Constructor for class org.apache.jackrabbit.oak.plugins.nodetype.TypePredicate
Creates a predicate for checking whether a node state is an instance of any of the named node types.
TypePredicate(NodeState, String[]) - Constructor for class org.apache.jackrabbit.oak.plugins.nodetype.TypePredicate
Creates a predicate for checking whether a node state is an instance of any of the named node types.

U

UDPBroadcaster - Class in org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast
A broadcast mechanism that uses UDP.
UDPBroadcaster(String) - Constructor for class org.apache.jackrabbit.oak.plugins.document.persistentCache.broadcast.UDPBroadcaster
 
unbindAuthenticationConfiguration(AuthenticationConfiguration) - Method in class org.apache.jackrabbit.oak.security.internal.SecurityProviderRegistration
 
unbindAuthenticationConfiguration(AuthenticationConfiguration) - Method in class org.apache.jackrabbit.oak.security.SecurityProviderImpl
 
unbindAuthorizableActionProvider(AuthorizableActionProvider, Map<String, Object>) - Method in class org.apache.jackrabbit.oak.security.internal.SecurityProviderRegistration
 
unbindAuthorizableNodeName(AuthorizableNodeName, Map<String, Object>) - Method in class org.apache.jackrabbit.oak.security.internal.SecurityProviderRegistration
 
unbindAuthorizationConfiguration(AuthorizationConfiguration, Map<String, Object>) - Method in class org.apache.jackrabbit.oak.security.internal.SecurityProviderRegistration
 
unbindAuthorizationConfiguration(AuthorizationConfiguration) - Method in class org.apache.jackrabbit.oak.security.SecurityProviderImpl
 
unbindBlobDataSource(DataSource) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreService
 
unbindBlobStore(BlobStore) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreService
 
unbindCluster(Clusterable) - Method in class org.apache.jackrabbit.oak.plugins.atomic.AtomicCounterEditorProvider
 
unbindCredentialsSupport(CredentialsSupport) - Method in class org.apache.jackrabbit.oak.security.authentication.token.TokenConfigurationImpl
 
unbindDataSource(DataSource) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreService
 
unbindDocumentNodeStore(DocumentNodeStore) - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.SecondaryStoreCacheService
 
unbindInfoProviders(IndexInfoProvider) - Method in class org.apache.jackrabbit.oak.plugins.index.IndexInfoServiceImpl
 
unbindNodeStateCache(DocumentNodeStateCache) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreService
 
unbindNodeStoreProvider(NodeStoreProvider) - Method in class org.apache.jackrabbit.oak.plugins.cow.COWNodeStoreService
 
unbindPrincipalConfiguration(PrincipalConfiguration, Map<String, Object>) - Method in class org.apache.jackrabbit.oak.security.internal.SecurityProviderRegistration
 
unbindPrincipalConfiguration(PrincipalConfiguration) - Method in class org.apache.jackrabbit.oak.security.SecurityProviderImpl
 
unbindPrivilegeConfiguration(PrivilegeConfiguration) - Method in class org.apache.jackrabbit.oak.security.internal.SecurityProviderRegistration
 
unbindPrivilegeConfiguration(PrivilegeConfiguration) - Method in class org.apache.jackrabbit.oak.security.SecurityProviderImpl
 
unbindRestrictionProvider(RestrictionProvider, Map<String, Object>) - Method in class org.apache.jackrabbit.oak.security.internal.SecurityProviderRegistration
 
unbindStatsMBeans(IndexStatsMBean) - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexInfoServiceImpl
 
unbindStore(NodeStore) - Method in class org.apache.jackrabbit.oak.plugins.atomic.AtomicCounterEditorProvider
 
unbindTokenConfiguration(TokenConfiguration, Map<String, Object>) - Method in class org.apache.jackrabbit.oak.security.internal.SecurityProviderRegistration
 
unbindTokenConfiguration(TokenConfiguration) - Method in class org.apache.jackrabbit.oak.security.SecurityProviderImpl
 
unbindUserAuthenticationFactory(UserAuthenticationFactory, Map<String, Object>) - Method in class org.apache.jackrabbit.oak.security.internal.SecurityProviderRegistration
 
unbindUserConfiguration(UserConfiguration) - Method in class org.apache.jackrabbit.oak.security.internal.SecurityProviderRegistration
 
unbindUserConfiguration(UserConfiguration) - Method in class org.apache.jackrabbit.oak.security.SecurityProviderImpl
 
unblockCommits() - Method in class org.apache.jackrabbit.oak.plugins.observation.CommitRateLimiter
Unblock blocked commits.
unescapePropertyName(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
 
UnionQueryImpl - Class in org.apache.jackrabbit.oak.query
Represents a union query.
UNIQUE_PROPERTY_NAME - Static variable in interface org.apache.jackrabbit.oak.plugins.index.IndexConstants
Marks a unique property index.
UniqueEntryStoreStrategy - Class in org.apache.jackrabbit.oak.plugins.index.property.strategy
An IndexStoreStrategy implementation that saves the unique node in a single property.
This should reduce the number of nodes in the repository, and speed up access.

For example for a node that is under /test/node, the index structure will be /oak:index/index/@key:
UniqueEntryStoreStrategy() - Constructor for class org.apache.jackrabbit.oak.plugins.index.property.strategy.UniqueEntryStoreStrategy
 
UniqueEntryStoreStrategy(String) - Constructor for class org.apache.jackrabbit.oak.plugins.index.property.strategy.UniqueEntryStoreStrategy
 
universal(UniversalFilter.Selector, Predicate<NodeState>) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder
A condition that holds when the predicate matches.
UniversalFilter - Class in org.apache.jackrabbit.oak.plugins.observation.filter
An universal Filter implementation, which can be parametrised by a UniversalFilter.Selector and a Predicate.
UniversalFilter(NodeState, NodeState, UniversalFilter.Selector, Predicate<NodeState>) - Constructor for class org.apache.jackrabbit.oak.plugins.observation.filter.UniversalFilter
Create a new instance of an universal filter rooted at the passed trees.
UniversalFilter.Selector - Interface in org.apache.jackrabbit.oak.plugins.observation.filter
A selector instance maps call backs on Filters to NodeState instances, which should be used for determining inclusion or exclusion of the associated event.
unlock(SimpleToken) - Method in class org.apache.jackrabbit.oak.plugins.index.importer.AbortingIndexerLock
 
unlock(T) - Method in interface org.apache.jackrabbit.oak.plugins.index.importer.AsyncIndexerLock
 
unlock(ClusteredLockToken) - Method in class org.apache.jackrabbit.oak.plugins.index.importer.ClusterNodeStoreLock
 
unmodifiable() - Method in class org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeBits
Returns an unmodifiable instance.
unprepare() - Method in class org.apache.jackrabbit.oak.query.ast.JoinImpl
 
unprepare() - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
 
unprepare() - Method in class org.apache.jackrabbit.oak.query.ast.SourceImpl
Undo a prepare.
unregister() - Method in class org.apache.jackrabbit.oak.plugins.index.IndexMBeanRegistration
 
unregisterNamespace(String) - Method in class org.apache.jackrabbit.oak.plugins.name.ReadOnlyNamespaceRegistry
 
unregisterNamespace(String) - Method in class org.apache.jackrabbit.oak.plugins.name.ReadWriteNamespaceRegistry
 
unregisterNodeType(String) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.ReadOnlyNodeTypeManager
This implementation always throws a UnsupportedRepositoryOperationException.
unregisterNodeType(String) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.write.ReadWriteNodeTypeManager
 
unregisterNodeTypes(String[]) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.ReadOnlyNodeTypeManager
This implementation always throws a UnsupportedRepositoryOperationException.
unregisterNodeTypes(String[]) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.write.ReadWriteNodeTypeManager
 
unregisterObserver() - Method in class org.apache.jackrabbit.oak.plugins.document.bundlor.BundlingConfigHandler
 
unsetRevision(UpdateOp, Revision) - Static method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
 
unshareString(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
Make sure the name string does not contain unnecessary baggage (shared strings).
UNSUPPORTED - Static variable in interface org.apache.jackrabbit.oak.plugins.tree.impl.ImmutableTree.ParentProvider
 
update(Collection<T>, List<String>, UpdateOp) - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStore
Update documents with the given keys.
update(Collection<T>, List<String>, UpdateOp) - Method in class org.apache.jackrabbit.oak.plugins.document.memory.MemoryDocumentStore
 
update(Collection<T>, List<String>, UpdateOp) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoDocumentStore
 
update(Collection<T>, List<String>, UpdateOp) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
update(Connection, RDBDocumentStore.RDBTableMetaData, List<T>, boolean) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStoreJDBC
Update a list of documents using JDBC batches.
update(Connection, RDBDocumentStore.RDBTableMetaData, String, Long, Number, Boolean, Long, Long, Long, String) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStoreJDBC
 
update(Revision) - Method in class org.apache.jackrabbit.oak.plugins.document.RevisionVector
Creates a new revision vector with based on this vector and the given revision.
update(Collection<T>, List<String>, UpdateOp) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LeaseCheckDocumentStoreWrapper
 
update(Collection<T>, List<String>, UpdateOp) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LoggingDocumentStoreWrapper
 
update(Collection<T>, List<String>, UpdateOp) - Method in class org.apache.jackrabbit.oak.plugins.document.util.SynchronizingDocumentStoreWrapper
 
update(Collection<T>, List<String>, UpdateOp) - Method in class org.apache.jackrabbit.oak.plugins.document.util.TimingDocumentStoreWrapper
 
update(Supplier<NodeBuilder>, String, String, NodeBuilder, Set<String>, Set<String>) - Method in class org.apache.jackrabbit.oak.plugins.index.property.strategy.ContentMirrorStoreStrategy
 
update(Supplier<NodeBuilder>, String, String, NodeBuilder, Set<String>, Set<String>) - Method in class org.apache.jackrabbit.oak.plugins.index.property.strategy.FilteringIndexStoreStrategy
 
update(Supplier<NodeBuilder>, String, String, NodeBuilder, Set<String>, Set<String>) - Method in interface org.apache.jackrabbit.oak.plugins.index.property.strategy.IndexStoreStrategy
Updates the index for the given path.
update(Supplier<NodeBuilder>, String, String, NodeBuilder, Set<String>, Set<String>) - Method in class org.apache.jackrabbit.oak.plugins.index.property.strategy.UniqueEntryStoreStrategy
 
updateAccessedRevision(RevisionVector, int) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoDocumentStore
 
updateAccessedRevision(RevisionVector, int) - Method in interface org.apache.jackrabbit.oak.plugins.document.RevisionListener
 
updateAccessedRevision(RevisionVector, int) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LeaseCheckDocumentStoreWrapper
 
updateAccessedRevision(RevisionVector, int) - Method in class org.apache.jackrabbit.oak.plugins.document.util.LoggingDocumentStoreWrapper
 
updateAccessedRevision(RevisionVector, int) - Method in class org.apache.jackrabbit.oak.plugins.document.util.SynchronizingDocumentStoreWrapper
 
updateAccessedRevision(RevisionVector, int) - Method in class org.apache.jackrabbit.oak.plugins.document.util.TimingDocumentStoreWrapper
 
updateChildOrder(boolean) - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractMutableTree
Updates the child order to match any added or removed child nodes that are not yet reflected in the TreeConstants.OAK_CHILD_ORDER property.
updateIndex(NodeState, String, NodeState, String, String, AsyncIndexUpdate.AsyncUpdateCallback) - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate
 
UpdateOp - Class in org.apache.jackrabbit.oak.plugins.document
A DocumentStore "update" operation for one document.
UpdateOp(String, boolean) - Constructor for class org.apache.jackrabbit.oak.plugins.document.UpdateOp
Create an update operation for the document with the given id.
UpdateOp.Condition - Class in org.apache.jackrabbit.oak.plugins.document
A condition to check before an update is applied.
UpdateOp.Condition.Type - Enum in org.apache.jackrabbit.oak.plugins.document
 
UpdateOp.Key - Class in org.apache.jackrabbit.oak.plugins.document
A key for an operation consists of a property name and an optional revision.
UpdateOp.Operation - Class in org.apache.jackrabbit.oak.plugins.document
A DocumentStore operation for a given key within a document.
UpdateOp.Operation.Type - Enum in org.apache.jackrabbit.oak.plugins.document
The DocumentStore operation type.
UpdateUtils - Class in org.apache.jackrabbit.oak.plugins.document
Provides convenience methods for applying UpdateOps to Documents.
UpdateUtils() - Constructor for class org.apache.jackrabbit.oak.plugins.document.UpdateUtils
 
upgradeToSchema(int) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBOptions
Control over DB schema to upgrade to
upperCase(DynamicOperandImpl) - Method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
 
UpperCaseImpl - Class in org.apache.jackrabbit.oak.query.ast
The function "upper(..)".
UpperCaseImpl(DynamicOperandImpl) - Constructor for class org.apache.jackrabbit.oak.query.ast.UpperCaseImpl
 
USECMODCOUNT - Static variable in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
 
USER_MANAGEMENT - Static variable in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
 
USER_PRIVILEGE_NAMES - Static variable in class org.apache.jackrabbit.oak.spi.security.user.action.AccessControlAction
 
USER_PROPERTY_NAMES - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
 
UserAuthenticationFactory - Interface in org.apache.jackrabbit.oak.spi.security.user
Provides a user management specific implementation of the Authentication interface to those LoginModules that verify a given authentication request by evaluation information exposed by the Jackrabbit user management API.
UserAuthenticationFactoryImpl - Class in org.apache.jackrabbit.oak.security.user
 
UserAuthenticationFactoryImpl() - Constructor for class org.apache.jackrabbit.oak.security.user.UserAuthenticationFactoryImpl
 
UserConfiguration - Interface in org.apache.jackrabbit.oak.spi.security.user
Configuration interface for user management.
UserConfigurationImpl - Class in org.apache.jackrabbit.oak.security.user
Default implementation of the UserConfiguration.
UserConfigurationImpl() - Constructor for class org.apache.jackrabbit.oak.security.user.UserConfigurationImpl
 
UserConfigurationImpl(SecurityProvider) - Constructor for class org.apache.jackrabbit.oak.security.user.UserConfigurationImpl
 
UserConstants - Interface in org.apache.jackrabbit.oak.spi.security.user
User management related constants.
UserIdCredentials - Class in org.apache.jackrabbit.oak.spi.security.user
Credentials implementation that only contains a userId but no password.
UserIdCredentials(String) - Constructor for class org.apache.jackrabbit.oak.spi.security.user.UserIdCredentials
 
UserManagerCallback - Class in org.apache.jackrabbit.oak.spi.security.authentication.callback
Callback implementation used to pass a UserManager to the login module.
UserManagerCallback() - Constructor for class org.apache.jackrabbit.oak.spi.security.authentication.callback.UserManagerCallback
 
UserManagerImpl - Class in org.apache.jackrabbit.oak.security.user
UserManagerImpl...
UserManagerImpl(Root, NamePathMapper, SecurityProvider) - Constructor for class org.apache.jackrabbit.oak.security.user.UserManagerImpl
 
UserQueryManager - Class in org.apache.jackrabbit.oak.security.user.query
Query manager for user specific searches.
UserQueryManager(UserManagerImpl, NamePathMapper, ConfigurationParameters, Root) - Constructor for class org.apache.jackrabbit.oak.security.user.query.UserQueryManager
 
UserUtil - Class in org.apache.jackrabbit.oak.spi.security.user.util
Utility methods for user management.
Utils - Class in org.apache.jackrabbit.oak.plugins.document.util
Utility methods.
Utils() - Constructor for class org.apache.jackrabbit.oak.plugins.document.util.Utils
 
Utils - Class in org.apache.jackrabbit.oak.plugins.version
Utils provide some utility methods.
uuid(UniversalFilter.Selector, String[]) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder
A condition that holds for matching uuids.
UUIDDiffCollector - Class in org.apache.jackrabbit.oak.plugins.index.diffindex
DiffCollector that looks for UUID properties
UUIDDiffCollector(NodeState, NodeState) - Constructor for class org.apache.jackrabbit.oak.plugins.index.diffindex.UUIDDiffCollector
 
UUIDDiffIndex - Class in org.apache.jackrabbit.oak.plugins.index.diffindex
 
UUIDDiffIndex(NodeState, NodeState) - Constructor for class org.apache.jackrabbit.oak.plugins.index.diffindex.UUIDDiffIndex
 
UUIDDiffIndexProviderWrapper - Class in org.apache.jackrabbit.oak.plugins.index.diffindex
 
UUIDDiffIndexProviderWrapper(QueryIndexProvider, NodeState, NodeState) - Constructor for class org.apache.jackrabbit.oak.plugins.index.diffindex.UUIDDiffIndexProviderWrapper
 
UuidPredicate - Class in org.apache.jackrabbit.oak.plugins.observation.filter
A predicate for matching against a list of UUIDs.
UuidPredicate(String[]) - Constructor for class org.apache.jackrabbit.oak.plugins.observation.filter.UuidPredicate
 

V

validate(String) - Static method in class org.apache.jackrabbit.oak.namepath.JcrNameParser
 
validate(String) - Static method in class org.apache.jackrabbit.oak.namepath.JcrPathParser
 
validateRestrictions(String, Tree) - Method in class org.apache.jackrabbit.oak.security.authorization.restriction.PrincipalRestrictionProvider
 
validateRestrictions(String, Tree) - Method in class org.apache.jackrabbit.oak.security.authorization.restriction.RestrictionProviderImpl
 
validateRestrictions(String, Tree) - Method in class org.apache.jackrabbit.oak.security.authorization.restriction.WhiteboardRestrictionProvider
 
validateRestrictions(String, Tree) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.restriction.AbstractRestrictionProvider
 
validateRestrictions(String, Tree) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.restriction.CompositeRestrictionProvider
 
validateRestrictions(String, Tree) - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.restriction.RestrictionProvider
Validate the restrictions present with the specified ACE tree.
value - Variable in class org.apache.jackrabbit.oak.plugins.document.UpdateOp.Condition
The value.
value - Variable in class org.apache.jackrabbit.oak.plugins.document.UpdateOp.Operation
The value, if any.
value - Variable in class org.apache.jackrabbit.oak.spi.security.ConfigurationParameters.Milliseconds
 
VALUE_EXCLUDED_PREFIXES - Static variable in interface org.apache.jackrabbit.oak.plugins.index.IndexConstants
A list of prefixes to be excluded from the index.
VALUE_INCLUDED_PREFIXES - Static variable in interface org.apache.jackrabbit.oak.plugins.index.IndexConstants
A list of prefixes to be included from the index.
VALUE_PATTERN - Static variable in interface org.apache.jackrabbit.oak.plugins.index.IndexConstants
The regular expression pattern of the values to be indexes.
VALUE_PERMISSIONS_JR2 - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.PermissionConstants
Value of the PermissionConstants.PARAM_PERMISSIONS_JR2 configuration parameter that contains all value entries.
valueConstraint(int, String) - Static method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.Constraints
 
ValueConverter - Class in org.apache.jackrabbit.oak.query
 
ValueDataType - Class in org.apache.jackrabbit.oak.plugins.document.persistentCache
 
ValueDataType(DocumentNodeStore, DocumentStore, CacheType) - Constructor for class org.apache.jackrabbit.oak.plugins.document.persistentCache.ValueDataType
 
ValueFactoryImpl - Class in org.apache.jackrabbit.oak.plugins.value.jcr
Implementation of ValueFactory interface.
ValueFactoryImpl(Root, NamePathMapper) - Constructor for class org.apache.jackrabbit.oak.plugins.value.jcr.ValueFactoryImpl
Creates a new instance of ValueFactory.
valueFromString(DocumentNodeStore, DocumentStore, String) - Method in enum org.apache.jackrabbit.oak.plugins.document.persistentCache.CacheType
 
valueFromString(String) - Static method in class org.apache.jackrabbit.oak.spi.xml.ImportBehavior
 
valueOf(String) - Static method in enum org.apache.jackrabbit.oak.core.ResetCommitAttributeHook
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.jackrabbit.oak.plugins.document.bundlor.BundlingConfigInitializer
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfo.ClusterNodeState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfo.RecoverLockState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.FormatVersion
Returns a format version for the given String representation.
valueOf(String) - Static method in enum org.apache.jackrabbit.oak.plugins.document.mongo.replica.ReplicaSetInfo.MemberState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.jackrabbit.oak.plugins.document.NodeDocument.SplitDocType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.jackrabbit.oak.plugins.document.persistentCache.CacheType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.jackrabbit.oak.plugins.document.rdb.RDBBlobStoreDB
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStoreDB.FETCHFIRSTSYNTAX
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStoreDB
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.jackrabbit.oak.plugins.document.UpdateOp.Condition.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.jackrabbit.oak.plugins.document.UpdateOp.Operation.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.jackrabbit.oak.plugins.index.fulltext.ExtractedText.ExtractionResult
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.jackrabbit.oak.plugins.index.IndexCommitCallback.IndexProgress
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.jackrabbit.oak.plugins.index.PathFilter.Result
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.jackrabbit.oak.plugins.index.property.OrderedIndex.OrderDirection
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.jackrabbit.oak.plugins.tree.TreeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.jackrabbit.oak.plugins.version.VersionExceptionCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.jackrabbit.oak.query.ast.JoinType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.jackrabbit.oak.query.ast.Operator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.jackrabbit.oak.query.ast.Order
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.jackrabbit.oak.query.QueryEngineImpl.QuerySelectionMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.jackrabbit.oak.query.QueryOptions.Traversal
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.jackrabbit.oak.security.authorization.composite.CompositeAuthorizationConfiguration.CompositionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.jackrabbit.oak.spi.security.user.AuthorizableType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.jackrabbit.oak.spi.xml.PropInfo.MultipleStatus
Returns the enum constant of this type with the specified name.
ValuePattern - Class in org.apache.jackrabbit.oak.plugins.index.property
A value pattern.
ValuePattern(NodeBuilder) - Constructor for class org.apache.jackrabbit.oak.plugins.index.property.ValuePattern
 
ValuePattern(NodeState) - Constructor for class org.apache.jackrabbit.oak.plugins.index.property.ValuePattern
 
ValuePattern() - Constructor for class org.apache.jackrabbit.oak.plugins.index.property.ValuePattern
 
ValuePattern(String, Iterable<String>, Iterable<String>) - Constructor for class org.apache.jackrabbit.oak.plugins.index.property.ValuePattern
 
values() - Static method in enum org.apache.jackrabbit.oak.core.ResetCommitAttributeHook
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.jackrabbit.oak.plugins.document.bundlor.BundlingConfigInitializer
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.jackrabbit.oak.plugins.document.cache.NodeDocumentCache
 
values() - Static method in enum org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfo.ClusterNodeState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfo.RecoverLockState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in class org.apache.jackrabbit.oak.plugins.document.FormatVersion
 
values() - Static method in enum org.apache.jackrabbit.oak.plugins.document.mongo.replica.ReplicaSetInfo.MemberState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.jackrabbit.oak.plugins.document.NodeDocument.SplitDocType
Returns an array containing the constants of this enum type, in the order they are declared.
VALUES - Static variable in enum org.apache.jackrabbit.oak.plugins.document.persistentCache.CacheType
 
values() - Static method in enum org.apache.jackrabbit.oak.plugins.document.persistentCache.CacheType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.MultiGenerationMap
 
values() - Static method in enum org.apache.jackrabbit.oak.plugins.document.rdb.RDBBlobStoreDB
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStoreDB.FETCHFIRSTSYNTAX
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStoreDB
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.jackrabbit.oak.plugins.document.UpdateOp.Condition.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.jackrabbit.oak.plugins.document.UpdateOp.Operation.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.jackrabbit.oak.plugins.index.fulltext.ExtractedText.ExtractionResult
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.jackrabbit.oak.plugins.index.IndexCommitCallback.IndexProgress
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.jackrabbit.oak.plugins.index.PathFilter.Result
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.jackrabbit.oak.plugins.index.property.OrderedIndex.OrderDirection
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.jackrabbit.oak.plugins.tree.TreeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.jackrabbit.oak.plugins.version.VersionExceptionCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.jackrabbit.oak.query.ast.JoinType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.jackrabbit.oak.query.ast.Operator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.jackrabbit.oak.query.ast.Order
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.jackrabbit.oak.query.QueryEngineImpl.QuerySelectionMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.jackrabbit.oak.query.QueryOptions.Traversal
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.jackrabbit.oak.security.authorization.composite.CompositeAuthorizationConfiguration.CompositionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.jackrabbit.oak.spi.security.ConfigurationParameters
values() - Static method in enum org.apache.jackrabbit.oak.spi.security.user.AuthorizableType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.jackrabbit.oak.spi.xml.PropInfo.MultipleStatus
Returns an array containing the constants of this enum type, in the order they are declared.
valueToString(V) - Method in enum org.apache.jackrabbit.oak.plugins.document.persistentCache.CacheType
 
verifyNotPotentiallySlow() - Method in interface org.apache.jackrabbit.oak.query.Query
Verify the query is not potentially slow.
verifyNotPotentiallySlow() - Method in class org.apache.jackrabbit.oak.query.QueryImpl
 
verifyNotPotentiallySlow() - Method in class org.apache.jackrabbit.oak.query.UnionQueryImpl
 
VERSION - Static variable in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
 
VERSION_MANAGEMENT - Static variable in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
 
VERSION_NODE_NAMES - Static variable in interface org.apache.jackrabbit.oak.plugins.version.VersionConstants
 
VERSION_NODE_TYPE_NAMES - Static variable in interface org.apache.jackrabbit.oak.plugins.version.VersionConstants
 
VERSION_PROPERTY_NAMES - Static variable in interface org.apache.jackrabbit.oak.plugins.version.VersionConstants
 
VERSION_STORE_NT_NAMES - Static variable in interface org.apache.jackrabbit.oak.plugins.version.VersionConstants
 
VERSION_STORE_PATH - Static variable in interface org.apache.jackrabbit.oak.plugins.version.VersionConstants
Quote from JSR 283 Section "3.13.8 Version Storage"
VERSION_STORE_ROOT_NAMES - Static variable in interface org.apache.jackrabbit.oak.plugins.version.VersionConstants
 
VersionablePathHook - Class in org.apache.jackrabbit.oak.plugins.version
Commit hook which is responsible for storing the path of the versionable node with every version history.
VersionablePathHook(String) - Constructor for class org.apache.jackrabbit.oak.plugins.version.VersionablePathHook
 
versionCheck(DatabaseMetaData, int, int, int, int, String) - Static method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBJDBCTools
Generate database + driver version diagnostics.
versionCheck(DatabaseMetaData, int, int, String) - Static method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBJDBCTools
Generate database version diagnostics.
VersionConstants - Interface in org.apache.jackrabbit.oak.plugins.version
VersionConstants...
VersionExceptionCode - Enum in org.apache.jackrabbit.oak.plugins.version
VersionExceptionCode contains the codes for version related commit failures.
VersionGarbageCollector - Class in org.apache.jackrabbit.oak.plugins.document
 
VersionGarbageCollector.VersionGCInfo - Class in org.apache.jackrabbit.oak.plugins.document
 
VersionGarbageCollector.VersionGCStats - Class in org.apache.jackrabbit.oak.plugins.document
 
VersionGCOptions - Class in org.apache.jackrabbit.oak.plugins.document
 
VersionGCOptions() - Constructor for class org.apache.jackrabbit.oak.plugins.document.VersionGCOptions
 
VersionGCStats() - Constructor for class org.apache.jackrabbit.oak.plugins.document.VersionGarbageCollector.VersionGCStats
 
VersionGCSupport - Class in org.apache.jackrabbit.oak.plugins.document
 
VersionGCSupport(DocumentStore) - Constructor for class org.apache.jackrabbit.oak.plugins.document.VersionGCSupport
 
VersionHook - Class in org.apache.jackrabbit.oak.plugins.version
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.
VersionHook() - Constructor for class org.apache.jackrabbit.oak.plugins.version.VersionHook
 
versionOf(DocumentStore) - Static method in class org.apache.jackrabbit.oak.plugins.document.FormatVersion
Reads the FormatVersion from the given store.
VersionSelector - Interface in org.apache.jackrabbit.oak.plugins.version
Inspired by Jackrabbit 2.x
VISIBLE_FILTER - Static variable in class org.apache.jackrabbit.oak.plugins.observation.filter.VisibleFilter
 
VisibleFilter - Class in org.apache.jackrabbit.oak.plugins.observation.filter
Event filter that hides all non-visible content.
visit(AndImpl) - Method in interface org.apache.jackrabbit.oak.query.ast.AstVisitor
 
visit(BindVariableValueImpl) - Method in interface org.apache.jackrabbit.oak.query.ast.AstVisitor
 
visit(ChildNodeImpl) - Method in interface org.apache.jackrabbit.oak.query.ast.AstVisitor
 
visit(ChildNodeJoinConditionImpl) - Method in interface org.apache.jackrabbit.oak.query.ast.AstVisitor
 
visit(ColumnImpl) - Method in interface org.apache.jackrabbit.oak.query.ast.AstVisitor
 
visit(ComparisonImpl) - Method in interface org.apache.jackrabbit.oak.query.ast.AstVisitor
 
visit(InImpl) - Method in interface org.apache.jackrabbit.oak.query.ast.AstVisitor
 
visit(DescendantNodeImpl) - Method in interface org.apache.jackrabbit.oak.query.ast.AstVisitor
 
visit(DescendantNodeJoinConditionImpl) - Method in interface org.apache.jackrabbit.oak.query.ast.AstVisitor
 
visit(EquiJoinConditionImpl) - Method in interface org.apache.jackrabbit.oak.query.ast.AstVisitor
 
visit(FullTextSearchImpl) - Method in interface org.apache.jackrabbit.oak.query.ast.AstVisitor
 
visit(FullTextSearchScoreImpl) - Method in interface org.apache.jackrabbit.oak.query.ast.AstVisitor
 
visit(JoinImpl) - Method in interface org.apache.jackrabbit.oak.query.ast.AstVisitor
 
visit(LengthImpl) - Method in interface org.apache.jackrabbit.oak.query.ast.AstVisitor
 
visit(LiteralImpl) - Method in interface org.apache.jackrabbit.oak.query.ast.AstVisitor
 
visit(LowerCaseImpl) - Method in interface org.apache.jackrabbit.oak.query.ast.AstVisitor
 
visit(NodeLocalNameImpl) - Method in interface org.apache.jackrabbit.oak.query.ast.AstVisitor
 
visit(NodeNameImpl) - Method in interface org.apache.jackrabbit.oak.query.ast.AstVisitor
 
visit(NotImpl) - Method in interface org.apache.jackrabbit.oak.query.ast.AstVisitor
 
visit(OrderingImpl) - Method in interface org.apache.jackrabbit.oak.query.ast.AstVisitor
 
visit(OrImpl) - Method in interface org.apache.jackrabbit.oak.query.ast.AstVisitor
 
visit(PropertyExistenceImpl) - Method in interface org.apache.jackrabbit.oak.query.ast.AstVisitor
 
visit(PropertyInexistenceImpl) - Method in interface org.apache.jackrabbit.oak.query.ast.AstVisitor
 
visit(PropertyValueImpl) - Method in interface org.apache.jackrabbit.oak.query.ast.AstVisitor
 
visit(SameNodeImpl) - Method in interface org.apache.jackrabbit.oak.query.ast.AstVisitor
 
visit(SameNodeJoinConditionImpl) - Method in interface org.apache.jackrabbit.oak.query.ast.AstVisitor
 
visit(SelectorImpl) - Method in interface org.apache.jackrabbit.oak.query.ast.AstVisitor
 
visit(UpperCaseImpl) - Method in interface org.apache.jackrabbit.oak.query.ast.AstVisitor
 
visit(NativeFunctionImpl) - Method in interface org.apache.jackrabbit.oak.query.ast.AstVisitor
 
visit(SimilarImpl) - Method in interface org.apache.jackrabbit.oak.query.ast.AstVisitor
 
visit(SpellcheckImpl) - Method in interface org.apache.jackrabbit.oak.query.ast.AstVisitor
 
visit(SuggestImpl) - Method in interface org.apache.jackrabbit.oak.query.ast.AstVisitor
 
visit(AndImpl) - Method in class org.apache.jackrabbit.oak.query.ast.AstVisitorBase
Calls accept on each of the attached constraints of the AND node.
visit(ComparisonImpl) - Method in class org.apache.jackrabbit.oak.query.ast.AstVisitorBase
Calls accept on the two operands in the comparison node.
visit(InImpl) - Method in class org.apache.jackrabbit.oak.query.ast.AstVisitorBase
Calls accept on the all operands in the "in" node.
visit(FullTextSearchImpl) - Method in class org.apache.jackrabbit.oak.query.ast.AstVisitorBase
Calls accept on the static operand in the fulltext search constraint.
visit(NativeFunctionImpl) - Method in class org.apache.jackrabbit.oak.query.ast.AstVisitorBase
Calls accept on the static operand in the native search constraint.
visit(SimilarImpl) - Method in class org.apache.jackrabbit.oak.query.ast.AstVisitorBase
Calls accept on the static operand in the similar search constraint.
visit(SpellcheckImpl) - Method in class org.apache.jackrabbit.oak.query.ast.AstVisitorBase
Calls accept on the static operand in the spellcheck search constraint.
visit(SuggestImpl) - Method in class org.apache.jackrabbit.oak.query.ast.AstVisitorBase
Calls accept on the static operand in the suggest search constraint.
visit(JoinImpl) - Method in class org.apache.jackrabbit.oak.query.ast.AstVisitorBase
Calls accept on the two sources and the join condition in the join node.
visit(LengthImpl) - Method in class org.apache.jackrabbit.oak.query.ast.AstVisitorBase
Calls accept on the property value in the length node.
visit(LowerCaseImpl) - Method in class org.apache.jackrabbit.oak.query.ast.AstVisitorBase
Calls accept on the dynamic operand in the lower-case node.
visit(NotImpl) - Method in class org.apache.jackrabbit.oak.query.ast.AstVisitorBase
Calls accept on the constraint in the NOT node.
visit(OrderingImpl) - Method in class org.apache.jackrabbit.oak.query.ast.AstVisitorBase
Calls accept on the dynamic operand in the ordering node.
visit(OrImpl) - Method in class org.apache.jackrabbit.oak.query.ast.AstVisitorBase
Calls accept on each of the attached constraints of the OR node.
visit(QueryImpl) - Method in class org.apache.jackrabbit.oak.query.ast.AstVisitorBase
Calls accept on the following contained QOM nodes: Source Constraints Orderings Columns
visit(UpperCaseImpl) - Method in class org.apache.jackrabbit.oak.query.ast.AstVisitorBase
Calls accept on the dynamic operand in the lower-case node.

W

wasDeletedOnce() - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
Returns true if this document was ever deleted in past.
WEAK_REF_NAME - Static variable in class org.apache.jackrabbit.oak.plugins.index.reference.NodeReferenceConstants
 
WhiteboardAuthorizableActionProvider - Class in org.apache.jackrabbit.oak.security.user.whiteboard
Dynamic AuthorizableActionProvider based on the available whiteboard services.
WhiteboardAuthorizableActionProvider() - Constructor for class org.apache.jackrabbit.oak.security.user.whiteboard.WhiteboardAuthorizableActionProvider
 
WhiteboardAuthorizableNodeName - Class in org.apache.jackrabbit.oak.security.user.whiteboard
Dynamic AuthorizableNodeName based on the available whiteboard services.
WhiteboardAuthorizableNodeName() - Constructor for class org.apache.jackrabbit.oak.security.user.whiteboard.WhiteboardAuthorizableNodeName
 
WhiteboardCallback - Class in org.apache.jackrabbit.oak.spi.security.authentication.callback
Callback implementation to set and retrieve the Whiteboard.
WhiteboardCallback() - Constructor for class org.apache.jackrabbit.oak.spi.security.authentication.callback.WhiteboardCallback
 
WhiteboardIndexEditorProvider - Class in org.apache.jackrabbit.oak.plugins.index
Dynamic IndexEditorProvider based on the available whiteboard services.
WhiteboardIndexEditorProvider() - Constructor for class org.apache.jackrabbit.oak.plugins.index.WhiteboardIndexEditorProvider
 
WhiteboardRestrictionProvider - Class in org.apache.jackrabbit.oak.security.authorization.restriction
Dynamic RestrictionProvider based on the available whiteboard services.
WhiteboardRestrictionProvider() - Constructor for class org.apache.jackrabbit.oak.security.authorization.restriction.WhiteboardRestrictionProvider
 
WhiteboardUserAuthenticationFactory - Class in org.apache.jackrabbit.oak.security.user.whiteboard
Dynamic UserAuthenticationFactory based on the available whiteboard services.
WhiteboardUserAuthenticationFactory(UserAuthenticationFactory) - Constructor for class org.apache.jackrabbit.oak.security.user.whiteboard.WhiteboardUserAuthenticationFactory
 
with(Clusterable) - Method in class org.apache.jackrabbit.oak.Oak
Define the current repository as being a Clusterable one.
with(String) - Method in class org.apache.jackrabbit.oak.Oak
Sets the default workspace name that should be used in case of login with null workspace name.
with(RepositoryInitializer) - Method in class org.apache.jackrabbit.oak.Oak
 
with(QueryLimits) - Method in class org.apache.jackrabbit.oak.Oak
 
with(QueryIndexProvider) - Method in class org.apache.jackrabbit.oak.Oak
Associates the given query index provider with the repository to be created.
with(IndexEditorProvider) - Method in class org.apache.jackrabbit.oak.Oak
Associates the given index hook provider with the repository to be created.
with(CommitHook) - Method in class org.apache.jackrabbit.oak.Oak
Associates the given commit hook with the repository to be created.
with(EditorProvider) - Method in class org.apache.jackrabbit.oak.Oak
Associates the given editor provider with the repository to be created.
with(Editor) - Method in class org.apache.jackrabbit.oak.Oak
Associates the given editor with the repository to be created.
with(SecurityProvider) - Method in class org.apache.jackrabbit.oak.Oak
 
with(ConflictHandler) - Method in class org.apache.jackrabbit.oak.Oak
Deprecated.
with(ThreeWayConflictHandler) - Method in class org.apache.jackrabbit.oak.Oak
 
with(ScheduledExecutorService) - Method in class org.apache.jackrabbit.oak.Oak
 
with(Executor) - Method in class org.apache.jackrabbit.oak.Oak
 
with(MBeanServer) - Method in class org.apache.jackrabbit.oak.Oak
 
with(Whiteboard) - Method in class org.apache.jackrabbit.oak.Oak
 
with(Observer) - Method in class org.apache.jackrabbit.oak.Oak
 
with(MountInfoProvider) - Method in class org.apache.jackrabbit.oak.plugins.index.nodetype.NodeTypeIndexProvider
 
with(MountInfoProvider) - Method in class org.apache.jackrabbit.oak.plugins.index.property.PropertyIndexEditorProvider
 
with(MountInfoProvider) - Method in class org.apache.jackrabbit.oak.plugins.index.property.PropertyIndexProvider
 
with(MountInfoProvider) - Method in class org.apache.jackrabbit.oak.plugins.index.reference.ReferenceEditorProvider
 
with(MountInfoProvider) - Method in class org.apache.jackrabbit.oak.plugins.index.reference.ReferenceIndexProvider
 
withAsyncIndexing() - Method in class org.apache.jackrabbit.oak.Oak
Deprecated.
withAsyncIndexing(String, long) - Method in class org.apache.jackrabbit.oak.Oak
Enable the asynchronous (background) indexing behavior for the provided task name.
withAtomicCounter() - Method in class org.apache.jackrabbit.oak.Oak
 
withCollectLimit(long) - Method in class org.apache.jackrabbit.oak.plugins.document.VersionGCOptions
Sets the absolute limit on number of resource ids collected in one run.
withCompositionType(String) - Method in class org.apache.jackrabbit.oak.security.authorization.composite.CompositeAuthorizationConfiguration
 
withDelayFactor(double) - Method in class org.apache.jackrabbit.oak.plugins.document.VersionGCOptions
Set a delay factor between batched database modifications.
withFailOnMissingIndexProvider() - Method in class org.apache.jackrabbit.oak.Oak
 
withMaxDuration(TimeUnit, long) - Method in class org.apache.jackrabbit.oak.plugins.document.VersionGCOptions
Set the maximum duration in elapsed time that the garbage collection shall take.
withMaxIterations(int) - Method in class org.apache.jackrabbit.oak.plugins.document.VersionGCOptions
Set the maximum number of iterations that shall be attempted in a single run.
withMissingProviderStrategy(IndexUpdate.MissingIndexProviderStrategy) - Method in class org.apache.jackrabbit.oak.plugins.index.IndexUpdate
 
withOverflowToDiskThreshold(int) - Method in class org.apache.jackrabbit.oak.plugins.document.VersionGCOptions
Set the limit of number of resource id+_modified strings (not length) held in memory during a collection run.
withPrecisionMs(TimeUnit, long) - Method in class org.apache.jackrabbit.oak.plugins.document.VersionGCOptions
Set the minimum duration that is used for time based searches.
withPrePopulatedVersionStore() - Method in class org.apache.jackrabbit.oak.InitialContent
Instructs the initializer to pre-populate the version store with intermediate nodes.
withRootRevision(RevisionVector, boolean) - Method in class org.apache.jackrabbit.oak.plugins.document.AbstractDocumentNodeState
Creates a copy of this DocumentNodeState with the AbstractDocumentNodeState.getRootRevision() set to the given root revision.
withRootRevision(RevisionVector, boolean) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState
Creates a copy of this DocumentNodeState with the DocumentNodeState.rootRevision set to the given root revision.
withRootRevision(RevisionVector, boolean) - Method in class org.apache.jackrabbit.oak.plugins.document.secondary.DelegatingDocumentNodeState
 
withThreadNameLogging() - Method in class org.apache.jackrabbit.oak.plugins.document.util.LoggingDocumentStoreWrapper
 
withWeigher(Weigher<CacheValue, CacheValue>) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
 
WORKING_DIR - Static variable in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfo
The current working directory.
WORKSPACE_MANAGEMENT - Static variable in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
 
wrap(DocumentNodeStore, DocumentStore, Cache<K, V>, CacheType) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCache
 
wrap(DocumentNodeStore, DocumentStore, Cache<K, V>, CacheType, StatisticsProvider) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCache
 
wrap(NodeState, NodeStateDiffer) - Static method in class org.apache.jackrabbit.oak.plugins.document.secondary.DelegatingDocumentNodeState
 
wrap(Iterable<T>, Closeable) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.CloseableIterable
 
wrap(Iterable<T>) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.CloseableIterable
 
wrap(Iterator<T>, Closeable) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.CloseableIterator
 
wrap(Iterator<T>) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.CloseableIterator
 
wrap(QueryIndexProvider) - Static method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndexProvider
 
wrapBlobStore(GarbageCollectableBlobStore) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCache
 
wrapIfPossible(NodeState, NodeStateDiffer) - Static method in class org.apache.jackrabbit.oak.plugins.document.secondary.DelegatingDocumentNodeState
Wraps a given root NodeState as a DelegatingDocumentNodeState if it has required meta properties otherwise just returns the passed NodeState
wrapProgress(Editor) - Method in class org.apache.jackrabbit.oak.plugins.index.progress.IndexingProgressReporter
 
write(InputStream) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK
 
write(WriteBuffer, Object) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.KeyDataType
 
write(WriteBuffer, Object[], int, boolean) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.KeyDataType
 
write(WriteBuffer, Object) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.ValueDataType
 
write(WriteBuffer, Object[], int, boolean) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.ValueDataType
 
write(String, String) - Method in class org.apache.jackrabbit.oak.plugins.index.datastore.DataStoreTextWriter
 
WRITE - Static variable in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
 
writeBlob(InputStream) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.BlobCache
 
writeBlob(InputStream, BlobOptions) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.BlobCache
Ignores the options provided and delegates to BlobCache.writeBlob(InputStream).
writeBlob(String) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.BlobCache
 
writeRestrictions(String, Tree, Set<Restriction>) - Method in class org.apache.jackrabbit.oak.security.authorization.restriction.PrincipalRestrictionProvider
 
writeRestrictions(String, Tree, Set<Restriction>) - Method in class org.apache.jackrabbit.oak.security.authorization.restriction.WhiteboardRestrictionProvider
 
writeRestrictions(String, Tree, Set<Restriction>) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.restriction.AbstractRestrictionProvider
 
writeRestrictions(String, Tree, Set<Restriction>) - Method in class org.apache.jackrabbit.oak.spi.security.authorization.restriction.CompositeRestrictionProvider
 
writeRestrictions(String, Tree, Set<Restriction>) - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.restriction.RestrictionProvider
Writes the given restrictions to the specified ACE tree.
writeTo(DocumentStore) - Method in class org.apache.jackrabbit.oak.plugins.document.FormatVersion
Writes this version to the given document store.
writeTo(Tree) - Method in class org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeBits
Write this instance as property to the specified tree.

X

XPathToSQL2Converter - Class in org.apache.jackrabbit.oak.query.xpath
This class can can convert a XPATH query to a SQL2 query.
XPathToSQL2Converter() - Constructor for class org.apache.jackrabbit.oak.query.xpath.XPathToSQL2Converter
 
A B C D E F G H I J K L M N O P Q R S T U V W X 
Skip navigation links

Copyright © 2012–2017 The Apache Software Foundation. All rights reserved.