- 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
.
- 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
-
- AbstractBlob - Class in org.apache.jackrabbit.oak.plugins.memory
-
Abstract base class for
Blob
implementations.
- AbstractBlob(HashCode) - Constructor for class org.apache.jackrabbit.oak.plugins.memory.AbstractBlob
-
- AbstractBlob() - Constructor for class org.apache.jackrabbit.oak.plugins.memory.AbstractBlob
-
- AbstractCheckpointMBean - Class in org.apache.jackrabbit.oak.util
-
Abstract base class for CheckpointMBean
implementations.
- AbstractCheckpointMBean() - Constructor for class org.apache.jackrabbit.oak.util.AbstractCheckpointMBean
-
- AbstractChildNodeEntry - Class in org.apache.jackrabbit.oak.spi.state
-
- AbstractChildNodeEntry() - Constructor for class org.apache.jackrabbit.oak.spi.state.AbstractChildNodeEntry
-
- AbstractDataStoreService - Class in org.apache.jackrabbit.oak.plugins.blob.datastore
-
- AbstractDataStoreService() - Constructor for class org.apache.jackrabbit.oak.plugins.blob.datastore.AbstractDataStoreService
-
- abstractFlagDiff() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeDefDiff
-
- 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
-
- AbstractNodeState - Class in org.apache.jackrabbit.oak.spi.state
-
Abstract base class for
NodeState
implementations.
- AbstractNodeState() - Constructor for class org.apache.jackrabbit.oak.spi.state.AbstractNodeState
-
- AbstractPropertyState - Class in org.apache.jackrabbit.oak.plugins.memory
-
- AbstractPropertyState() - Constructor for class org.apache.jackrabbit.oak.plugins.memory.AbstractPropertyState
-
- AbstractRebaseDiff - Class in org.apache.jackrabbit.oak.spi.state
-
AbstractRebaseDiff
serves as base for rebase implementations.
- AbstractRebaseDiff(NodeBuilder) - Constructor for class org.apache.jackrabbit.oak.spi.state.AbstractRebaseDiff
-
- 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
-
- AbstractServiceTracker<T> - Class in org.apache.jackrabbit.oak.spi.whiteboard
-
AbstractServiceTracker
is a base class for composite components
that dynamically look up the available component services from the
whiteboard.
- AbstractServiceTracker(Class<T>) - Constructor for class org.apache.jackrabbit.oak.spi.whiteboard.AbstractServiceTracker
-
- 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
-
- accept(FullTextVisitor) - Method in class org.apache.jackrabbit.oak.query.fulltext.FullTextAnd
-
- accept(FullTextVisitor) - Method in class org.apache.jackrabbit.oak.query.fulltext.FullTextContains
-
- accept(FullTextVisitor) - Method in class org.apache.jackrabbit.oak.query.fulltext.FullTextExpression
-
Let the expression call the applicable visit method of the visitor.
- accept(FullTextVisitor) - Method in class org.apache.jackrabbit.oak.query.fulltext.FullTextOr
-
- accept(FullTextVisitor) - Method in class org.apache.jackrabbit.oak.query.fulltext.FullTextTerm
-
- ACCESS - Static variable in exception org.apache.jackrabbit.oak.api.CommitFailedException
-
Type name for access violation (i.e.
- ACCESS_CONTROL - Static variable in exception org.apache.jackrabbit.oak.api.CommitFailedException
-
Type name for access control violation errors.
- 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
-
- 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
-
- ACCURATE - Static variable in class org.apache.jackrabbit.oak.stats.Clock
-
Accurate clock implementation that uses interval timings from the
System.nanoTime()
method to calculate an as accurate as possible
time based on occasional calls to
System.currentTimeMillis()
to prevent clock drift.
- 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(Collection<String>) - Method in interface org.apache.jackrabbit.oak.plugins.document.locks.NodeDocumentLocks
-
Acquires locks for the given keys.
- acquire(String) - Method in class org.apache.jackrabbit.oak.plugins.document.locks.StripedNodeDocumentLocks
-
- acquire(Collection<String>) - Method in class org.apache.jackrabbit.oak.plugins.document.locks.StripedNodeDocumentLocks
-
- acquire(String) - Method in class org.apache.jackrabbit.oak.plugins.document.locks.TreeNodeDocumentLocks
-
Acquires a lock for the given key.
- acquire(Collection<String>) - Method in class org.apache.jackrabbit.oak.plugins.document.locks.TreeNodeDocumentLocks
-
- acquireExclusive(String) - Method in class org.apache.jackrabbit.oak.plugins.document.locks.TreeNodeDocumentLocks
-
Acquires an exclusive lock on the given parent key.
- 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, Object>) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.AbstractDataStoreService
-
- 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.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(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 interface org.apache.jackrabbit.oak.api.Tree
-
Add a child with the given name
.
- 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(String, String) - Method in class org.apache.jackrabbit.oak.util.NodeUtil
-
Adds a new child tree with the given name and primary type name.
- addChild(Tree, String, String, Tree, String) - Static method in class org.apache.jackrabbit.oak.util.TreeUtil
-
- 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.
- added(int) - Method in class org.apache.jackrabbit.oak.spi.commit.BackgroundObserver
-
Called when ever an item has been added to the queue
- 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
-
- addExistingNode(NodeBuilder, String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.commit.JcrLastModifiedConflictHandler
-
- addExistingNode(NodeBuilder, String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.CompositeConflictHandler
-
- addExistingNode(NodeBuilder, String, NodeState, NodeState) - Method in interface org.apache.jackrabbit.oak.spi.commit.ConflictHandler
-
The node ours
has been added to parent
which conflicts
with node theirs
which has been added in the persistence store.
- addExistingNode(NodeBuilder, String, NodeState, NodeState) - Method in interface org.apache.jackrabbit.oak.spi.commit.PartialConflictHandler
-
The node ours
has been added to parent
which conflicts
with node theirs
which has been added in the persistence store.
- addExistingNode(NodeBuilder, String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.spi.state.AbstractRebaseDiff
-
Called when the node after
was added on the branch but the node
exists already in the trunk.
- addExistingNode(NodeBuilder, String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.spi.state.ConflictAnnotatingRebaseDiff
-
- 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
-
- 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.spi.commit.CompositeConflictHandler
-
- addExistingProperty(NodeBuilder, PropertyState, PropertyState) - Method in interface org.apache.jackrabbit.oak.spi.commit.ConflictHandler
-
The property ours
has been added to parent
which conflicts
with property theirs
which has been added in the persistence store.
- addExistingProperty(NodeBuilder, PropertyState, PropertyState) - Method in interface org.apache.jackrabbit.oak.spi.commit.PartialConflictHandler
-
The property ours
has been added to parent
which conflicts
with property theirs
which has been added in the persistence store.
- addExistingProperty(NodeBuilder, PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.spi.state.AbstractRebaseDiff
-
Called when the property after
was added on the branch but the property
exists already in the trunk.
- addExistingProperty(NodeBuilder, PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.spi.state.ConflictAnnotatingRebaseDiff
-
- 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
-
- addHandler(PartialConflictHandler) - Method in class org.apache.jackrabbit.oak.spi.commit.CompositeConflictHandler
-
Add a new backing conflict handler.
- addingService(ServiceReference) - Method in class org.apache.jackrabbit.oak.osgi.ObserverTracker
-
- 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(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
-
- addMetadataRecord(InputStream, String) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore
-
- addMetadataRecord(InputStream, String) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.OakFileDataStore
-
- addMetadataRecord(InputStream, String) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.SharedS3DataStore
-
- addMetadataRecord(InputStream, String) - Method in interface org.apache.jackrabbit.oak.plugins.blob.SharedDataStore
-
Adds the root record.
- addMixin(Tree, String, Tree, String) - Static method in class org.apache.jackrabbit.oak.util.TreeUtil
-
- addMove(String, String) - Method in class org.apache.jackrabbit.oak.spi.commit.MoveTracker
-
- addObserver(Observer) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
-
- addObserver(Observer) - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeStore
-
- addObserver(Observer) - Method in class org.apache.jackrabbit.oak.spi.commit.ChangeDispatcher
-
Register a new
Observer
for receiving notifications about changes reported to
this change dispatcher.
- addObserver(Observer) - Method in class org.apache.jackrabbit.oak.spi.commit.CompositeObserver
-
- addObserver(Observer) - Method in interface org.apache.jackrabbit.oak.spi.commit.Observable
-
Register a new Observer
.
- addOrderBy(Order) - Method in class org.apache.jackrabbit.oak.query.xpath.Statement
-
- addReadMap(int, CacheMap<K, V>) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.MultiGenerationMap
-
- addRecord(InputStream) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore
-
- addReference(String, String) - Method in interface org.apache.jackrabbit.oak.plugins.blob.ReferenceCollector
-
Adds the reference detected with the node Id.
- addSelectColumn(Expression.Property) - Method in class org.apache.jackrabbit.oak.query.xpath.Statement
-
- 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.
- addValue(T) - Method in class org.apache.jackrabbit.oak.plugins.memory.PropertyBuilder
-
- addValues(Iterable<T>) - Method in class org.apache.jackrabbit.oak.plugins.memory.PropertyBuilder
-
- adjustCountSync(NodeBuilder, long) - Static method in class org.apache.jackrabbit.oak.util.ApproximateCounter
-
Adjust a counter in the given node.
- adjustOffset(long, long, int) - Static method in class org.apache.jackrabbit.oak.util.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.
- 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
-
- AggregatingDescriptors - Class in org.apache.jackrabbit.oak.util
-
An AggregatingDescriptors is an implementation of Descriptors
that allows to aggregate multiple Descriptors (which are
provided dynamically via a whiteboard tracker).
- AggregatingDescriptors(Tracker<Descriptors>) - Constructor for class org.apache.jackrabbit.oak.util.AggregatingDescriptors
-
Create an AggregatingDescriptors which uses descriptors.getServices()
at method invocation time
- 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.
- allowsCaseInSelect() - Method in enum org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStoreDB
-
Allows case in select.
- 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
-
- annotateSourcePath() - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeBuilder
-
Annotate this builder with its source path if this builder has not
been transiently added.
- AnnotatingConflictHandler - Class in org.apache.jackrabbit.oak.plugins.commit
-
This
ConflictHandler
implementation resolves conflicts to
org.apache.jackrabbit.oak.spi.commit.ConflictHandler.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.
- 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, Boolean, 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(K) - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS
-
- 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
-
- apply(NodeState) - Method in class org.apache.jackrabbit.oak.spi.state.ApplyDiff
-
- applyChanges(Document, UpdateOp) - Static method in class org.apache.jackrabbit.oak.plugins.document.UpdateUtils
-
Apply the changes to the in-memory document.
- ApplyDiff - Class in org.apache.jackrabbit.oak.spi.state
-
A node state diff handler that applies all reported changes
as-is to the given node builder.
- ApplyDiff(NodeBuilder) - Constructor for class org.apache.jackrabbit.oak.spi.state.ApplyDiff
-
- 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.util
-
An approximate counter algorithm.
- ApproximateCounter() - Constructor for class org.apache.jackrabbit.oak.util.ApproximateCounter
-
- areAllDescendantsIncluded(String) - Method in class org.apache.jackrabbit.oak.plugins.index.PathFilter
-
Check whether this node and all descendants are included in this filter.
- array(Type<T>) - Static method in class org.apache.jackrabbit.oak.plugins.memory.PropertyBuilder
-
Create a new instance for building array PropertyState
instances
of the given type
.
- array(Type<T>, String) - Static method in class org.apache.jackrabbit.oak.plugins.memory.PropertyBuilder
-
Create a new instance for building array PropertyState
instances
of the given type
.
- ArrayBasedBlob - Class in org.apache.jackrabbit.oak.plugins.memory
-
This Blob
implementations is based on an array of bytes.
- ArrayBasedBlob(byte[]) - Constructor for class org.apache.jackrabbit.oak.plugins.memory.ArrayBasedBlob
-
- 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
-
- asLong(Number) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
-
Returns the given number instance as a Long
.
- asMap() - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS
-
- asPropertyState(String) - Method in class org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeBits
-
- asRepositoryException() - Method in exception org.apache.jackrabbit.oak.api.CommitFailedException
-
- asRepositoryException(String) - Method in exception org.apache.jackrabbit.oak.api.CommitFailedException
-
- assertUnconditional(UpdateOp) - Static method in class org.apache.jackrabbit.oak.plugins.document.UpdateUtils
-
Ensures that the given
UpdateOp
is unconditional
- assignFrom(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.memory.PropertyBuilder
-
- 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
-
- asString() - Method in class org.apache.jackrabbit.oak.plugins.document.util.RevisionsKey
-
- asString() - Method in class org.apache.jackrabbit.oak.plugins.document.util.StringValue
-
- asStringValueIterable(Iterable<String>) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
-
- 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
-
- asyncDelay - Variable in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
-
The delay for asynchronous operations (delayed commit propagation and
cache update).
- 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) - 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.
- AsyncIndexUpdate.AsyncUpdateCallback(NodeStore, String, long, String, String, AsyncIndexUpdate.AsyncIndexStats, AtomicBoolean) - Constructor for class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate.AsyncUpdateCallback
-
- AtomicCounterEditor - Class in org.apache.jackrabbit.oak.plugins.atomic
-
- 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
-
- AtomicCounterEditor.ConsolidatorTask(String, PropertyState, NodeStore, ScheduledExecutorService, long, CommitHook) - Constructor for class org.apache.jackrabbit.oak.plugins.atomic.AtomicCounterEditor.ConsolidatorTask
-
- AtomicCounterEditorProvider - Class in org.apache.jackrabbit.oak.plugins.atomic
-
- 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.
- attributes - Variable in class org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan.Builder
-
- 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
- AuthInfo - Interface in org.apache.jackrabbit.oak.api
-
AuthInfo
instances provide access to information related
to authentication and authorization of a given content session.
- 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
-
- AuthorizableActionProvider - Interface in org.apache.jackrabbit.oak.spi.security.user.action
-
AuthorizableActionProvider
is used to provide AuthorizableAction
s
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.
- AuthorizableNodeName.Default() - Constructor for class org.apache.jackrabbit.oak.spi.security.user.AuthorizableNodeName.Default
-
- 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.util.TreeUtil
-
- autoCreateProperty(String, Tree, String) - Static method in class org.apache.jackrabbit.oak.util.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
-
- averageWeight(int) - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS.Builder
-
- cache - Variable in class org.apache.jackrabbit.oak.plugins.blob.CachingBlobStore
-
- cache - Variable in class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore
-
- CACHE_PATH - Static variable in class org.apache.jackrabbit.oak.plugins.blob.datastore.FileDataStoreService
-
- CACHE_SIZE - Static variable in class org.apache.jackrabbit.oak.plugins.blob.datastore.FileDataStoreService
-
- CachedNodeDocument - Interface in org.apache.jackrabbit.oak.plugins.document
-
Interface defining the minimum required properties of NodeDocument
which should be accessible without requiring the complete NodeDocument
to be deserialized
- cacheInfoAsString() - Method in interface org.apache.jackrabbit.oak.api.jmx.CacheStatsMBean
-
Gathers the stats of the cache for logging.
- cacheInfoAsString() - Method in class org.apache.jackrabbit.oak.cache.CacheStats
-
- CacheInvalidationStats - Interface in org.apache.jackrabbit.oak.plugins.document.cache
-
- CacheLIRS<K,V> - Class in org.apache.jackrabbit.oak.cache
-
A scan resistant cache.
- CacheLIRS(int) - Constructor for class org.apache.jackrabbit.oak.cache.CacheLIRS
-
Create a new cache with the given number of entries, and the default
settings (an average size of 1 per entry, 16 segments, and stack move
distance equals to the maximum number of entries divided by 100).
- CacheLIRS.Builder<K,V> - Class in org.apache.jackrabbit.oak.cache
-
A builder for the cache.
- CacheLIRS.Builder() - Constructor for class org.apache.jackrabbit.oak.cache.CacheLIRS.Builder
-
- CacheLIRS.EvictionCallback<K,V> - Interface in org.apache.jackrabbit.oak.cache
-
Listener for items that are evicted from the 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
-
- CacheStats - Class in org.apache.jackrabbit.oak.cache
-
Cache statistics.
- CacheStats(Cache<?, ?>, String, Weigher<?, ?>, long) - Constructor for class org.apache.jackrabbit.oak.cache.CacheStats
-
- CacheStatsMBean - Interface in org.apache.jackrabbit.oak.api.jmx
-
- CacheType - Enum in org.apache.jackrabbit.oak.plugins.document.persistentCache
-
- CacheValue - Interface in org.apache.jackrabbit.oak.cache
-
A cache value.
- CachingBlobStore - Class in org.apache.jackrabbit.oak.plugins.blob
-
A blob store with a cache.
- CachingBlobStore(long) - Constructor for class org.apache.jackrabbit.oak.plugins.blob.CachingBlobStore
-
- CachingBlobStore() - Constructor for class org.apache.jackrabbit.oak.plugins.blob.CachingBlobStore
-
- calculateOffset(long, int) - Static method in class org.apache.jackrabbit.oak.util.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.
- calculateSha256(Blob) - Static method in class org.apache.jackrabbit.oak.plugins.memory.AbstractBlob
-
- call() - Method in class org.apache.jackrabbit.oak.plugins.atomic.AtomicCounterEditor.ConsolidatorTask
-
- callbackHandler - Variable in class org.apache.jackrabbit.oak.spi.security.authentication.AbstractLoginModule
-
- canConvert(int, int) - Static method in class org.apache.jackrabbit.oak.spi.query.PropertyValues
-
- 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() - 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) - 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
-
- changeChangedProperty(NodeBuilder, PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.commit.JcrLastModifiedConflictHandler
-
- changeChangedProperty(NodeBuilder, PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.spi.commit.CompositeConflictHandler
-
- changeChangedProperty(NodeBuilder, PropertyState, PropertyState) - Method in interface org.apache.jackrabbit.oak.spi.commit.ConflictHandler
-
The property ours
has been changed in parent
while it was
also changed to a different value (theirs
) in the persistence store.
- changeChangedProperty(NodeBuilder, PropertyState, PropertyState) - Method in interface org.apache.jackrabbit.oak.spi.commit.PartialConflictHandler
-
The property ours
has been changed in parent
while it was
also changed to a different value (theirs
) in the persistence store.
- changeChangedProperty(NodeBuilder, PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.spi.state.AbstractRebaseDiff
-
Called when the property after
was changed on the branch but was
already changed to before
in the trunk.
- changeChangedProperty(NodeBuilder, PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.spi.state.ConflictAnnotatingRebaseDiff
-
- 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) - 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
-
- changeDeletedNode(NodeBuilder, String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.commit.JcrLastModifiedConflictHandler
-
- changeDeletedNode(NodeBuilder, String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.CompositeConflictHandler
-
- changeDeletedNode(NodeBuilder, String, NodeState) - Method in interface org.apache.jackrabbit.oak.spi.commit.ConflictHandler
-
The node ours
has been changed in parent
while it was
removed in the persistence store.
- changeDeletedNode(NodeBuilder, String, NodeState) - Method in interface org.apache.jackrabbit.oak.spi.commit.PartialConflictHandler
-
The node ours
has been changed in parent
while it was
removed in the persistence store.
- changeDeletedNode(NodeBuilder, String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.state.AbstractRebaseDiff
-
Called when the node after
was changed on the branch but was
deleted already in the trunk.
- changeDeletedNode(NodeBuilder, String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.state.ConflictAnnotatingRebaseDiff
-
- changeDeletedProperty(NodeBuilder, 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
-
- changeDeletedProperty(NodeBuilder, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.commit.JcrLastModifiedConflictHandler
-
- changeDeletedProperty(NodeBuilder, PropertyState) - Method in class org.apache.jackrabbit.oak.spi.commit.CompositeConflictHandler
-
- changeDeletedProperty(NodeBuilder, PropertyState) - Method in interface org.apache.jackrabbit.oak.spi.commit.ConflictHandler
-
The property ours
has been changed in parent
while it was
removed in the persistence store.
- changeDeletedProperty(NodeBuilder, PropertyState) - Method in interface org.apache.jackrabbit.oak.spi.commit.PartialConflictHandler
-
The property ours
has been changed in parent
while it was
removed in the persistence store.
- changeDeletedProperty(NodeBuilder, PropertyState) - Method in class org.apache.jackrabbit.oak.spi.state.AbstractRebaseDiff
-
Called when the property after
was changed on the branch but was
deleted already in the trunk.
- changeDeletedProperty(NodeBuilder, PropertyState) - Method in class org.apache.jackrabbit.oak.spi.state.ConflictAnnotatingRebaseDiff
-
- ChangeDispatcher - Class in org.apache.jackrabbit.oak.spi.commit
-
A
ChangeDispatcher
instance dispatches content changes
to registered
Observer
s.
- ChangeDispatcher(NodeState) - Constructor for class org.apache.jackrabbit.oak.spi.commit.ChangeDispatcher
-
Create a new instance for dispatching content changes
- 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
-
- checkConsistency() - Method in interface org.apache.jackrabbit.oak.plugins.blob.BlobGarbageCollector
-
Checks for consistency in the blob store and reporting the number of missing blobs.
- checkConsistency() - Method in class org.apache.jackrabbit.oak.plugins.blob.BlobGC
-
- checkConsistency() - Method in interface org.apache.jackrabbit.oak.plugins.blob.BlobGCMBean
-
Data Store consistency check
- checkConsistency() - Method in class org.apache.jackrabbit.oak.plugins.blob.MarkSweepGarbageCollector
-
Checks for the DataStore consistency and reports the number of missing blobs still referenced.
- checkMandatoryItems(Tree) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.EffectiveNodeType
-
- checkMemoryLimit(long, QueryEngineSettings) - 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
-
- checkpoint(long) - Method in interface org.apache.jackrabbit.oak.api.jmx.FileStoreBackupRestoreMBean
-
- checkpoint(long) - Method in interface org.apache.jackrabbit.oak.api.jmx.RepositoryManagementMBean
-
- checkpoint(long) - Method in class org.apache.jackrabbit.oak.management.RepositoryManager
-
- 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(long, Map<String, String>) - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeStore
-
- checkpoint(long) - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeStore
-
- checkpoint(long, Map<String, String>) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeStore
-
Creates a new checkpoint of the latest root of the tree.
- checkpoint(long) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeStore
-
Creates a new checkpoint of the latest root of the tree.
- checkpoint(long, Map<String, String>) - Method in class org.apache.jackrabbit.oak.spi.state.ProxyNodeStore
-
- checkpoint(long) - Method in class org.apache.jackrabbit.oak.spi.state.ProxyNodeStore
-
- checkpointInfo(String) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
-
- checkpointInfo(String) - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeStore
-
- checkpointInfo(String) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeStore
-
Retrieve the properties associated with a checkpoint.
- checkpointInfo(String) - Method in class org.apache.jackrabbit.oak.spi.state.ProxyNodeStore
-
- CheckpointMBean - Interface in org.apache.jackrabbit.oak.api.jmx
-
- checkReadLimit(long, QueryEngineSettings) - 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.spi.state.AbstractNodeState
-
- 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
-
- child(String) - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeBuilder
-
- child(String) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeBuilder
-
Returns a builder for constructing changes to the named child node.
- child(String) - Method in class org.apache.jackrabbit.oak.spi.state.ReadOnlyBuilder
-
- childNode(String, String) - Method in class org.apache.jackrabbit.oak.query.ast.AstElementFactory
-
- childNodeAdded(String, NodeState) - Method in class org.apache.jackrabbit.oak.json.JsopDiff
-
- 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.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
-
- childNodeAdded(String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.CompositeEditor
-
- childNodeAdded(String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.DefaultEditor
-
- childNodeAdded(String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.DefaultMoveValidator
-
- childNodeAdded(String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.DefaultValidator
-
- childNodeAdded(String, NodeState) - Method in interface org.apache.jackrabbit.oak.spi.commit.Editor
-
Processes an added child node.
- childNodeAdded(String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.EditorDiff
-
- childNodeAdded(String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.FailingValidator
-
- childNodeAdded(String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.ProgressNotificationEditor
-
- childNodeAdded(String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.SubtreeEditor
-
- childNodeAdded(String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.SubtreeExcludingValidator
-
- childNodeAdded(String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.SubtreeValidator
-
- childNodeAdded(String, NodeState) - Method in interface org.apache.jackrabbit.oak.spi.commit.Validator
-
Validate an added node
- childNodeAdded(String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.VisibleEditor
-
- childNodeAdded(String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.VisibleValidator
-
- childNodeAdded(String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.state.AbstractRebaseDiff
-
- childNodeAdded(String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.state.ApplyDiff
-
- childNodeAdded(String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.state.DefaultNodeStateDiff
-
- childNodeAdded(String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.state.EqualsDiff
-
- childNodeAdded(String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.state.MoveDetector
-
- childNodeAdded(String, NodeState) - Method in interface org.apache.jackrabbit.oak.spi.state.MoveValidator
-
- childNodeAdded(String, NodeState) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeStateDiff
-
Called for all added child nodes.
- childNodeChanged(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.json.JsopDiff
-
- 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.index.counter.NodeCounterEditor
-
- childNodeChanged(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.index.IndexUpdate
-
- childNodeChanged(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.CompositeEditor
-
- childNodeChanged(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.DefaultEditor
-
- childNodeChanged(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.DefaultMoveValidator
-
- childNodeChanged(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.DefaultValidator
-
- childNodeChanged(String, NodeState, NodeState) - Method in interface org.apache.jackrabbit.oak.spi.commit.Editor
-
Processes a changed child node.
- childNodeChanged(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.EditorDiff
-
- childNodeChanged(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.FailingValidator
-
- childNodeChanged(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.ProgressNotificationEditor
-
- childNodeChanged(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.SubtreeEditor
-
- childNodeChanged(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.SubtreeExcludingValidator
-
- childNodeChanged(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.SubtreeValidator
-
- childNodeChanged(String, NodeState, NodeState) - Method in interface org.apache.jackrabbit.oak.spi.commit.Validator
-
Validate a changed node
- childNodeChanged(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.VisibleEditor
-
- childNodeChanged(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.VisibleValidator
-
- childNodeChanged(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.spi.state.AbstractRebaseDiff
-
- childNodeChanged(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.spi.state.ApplyDiff
-
- childNodeChanged(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.spi.state.DefaultNodeStateDiff
-
- childNodeChanged(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.spi.state.EqualsDiff
-
- childNodeChanged(String, NodeState, NodeState) - Method in class org.apache.jackrabbit.oak.spi.state.MoveDetector
-
- childNodeChanged(String, NodeState, NodeState) - Method in interface org.apache.jackrabbit.oak.spi.state.MoveValidator
-
- childNodeChanged(String, NodeState, NodeState) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeStateDiff
-
Called for all child nodes that may contain changes between the before
and after states.
- childNodeDeleted(String, NodeState) - Method in class org.apache.jackrabbit.oak.json.JsopDiff
-
- childNodeDeleted(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.commit.ConflictValidator
-
- 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
-
- childNodeDeleted(String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.CompositeEditor
-
- childNodeDeleted(String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.DefaultEditor
-
- childNodeDeleted(String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.DefaultMoveValidator
-
- childNodeDeleted(String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.DefaultValidator
-
- childNodeDeleted(String, NodeState) - Method in interface org.apache.jackrabbit.oak.spi.commit.Editor
-
Processes a deleted child node.
- childNodeDeleted(String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.EditorDiff
-
- childNodeDeleted(String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.FailingValidator
-
- childNodeDeleted(String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.ProgressNotificationEditor
-
- childNodeDeleted(String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.SubtreeEditor
-
- childNodeDeleted(String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.SubtreeExcludingValidator
-
- childNodeDeleted(String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.SubtreeValidator
-
- childNodeDeleted(String, NodeState) - Method in interface org.apache.jackrabbit.oak.spi.commit.Validator
-
Validate a deleted node
- childNodeDeleted(String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.VisibleEditor
-
- childNodeDeleted(String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.VisibleValidator
-
- childNodeDeleted(String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.state.AbstractRebaseDiff
-
- childNodeDeleted(String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.state.ApplyDiff
-
- childNodeDeleted(String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.state.DefaultNodeStateDiff
-
- childNodeDeleted(String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.state.EqualsDiff
-
- childNodeDeleted(String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.state.MoveDetector
-
- childNodeDeleted(String, NodeState) - Method in interface org.apache.jackrabbit.oak.spi.state.MoveValidator
-
- childNodeDeleted(String, NodeState) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeStateDiff
-
Called for all deleted child nodes.
- ChildNodeEntry - Interface in org.apache.jackrabbit.oak.spi.state
-
A
ChildNodeEntry
instance represents the child node states of a
NodeState
.
- 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
-
- cleaned(long, long) - Method in class org.apache.jackrabbit.oak.spi.gc.DelegatingGCMonitor
-
- cleaned(long, long) - Method in interface org.apache.jackrabbit.oak.spi.gc.GCMonitor
-
The cleanup phase of the garbage collection process terminated successfully.
- cleaned(long, long) - Method in class org.apache.jackrabbit.oak.spi.gc.GCMonitor.Empty
-
- cleaned(long, long) - Method in class org.apache.jackrabbit.oak.spi.gc.GCMonitorTracker
-
- cleanUp() - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS
-
- 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.commit.MoveTracker
-
- 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.blob.CachingBlobStore
-
- clearCache() - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore
-
- clearCache() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.BlobCache
-
- clearInUse() - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore
-
- 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
-
- clock(Clock) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
-
- Clock - Class in org.apache.jackrabbit.oak.stats
-
Mechanism for keeping track of time at millisecond accuracy.
- Clock() - Constructor for class org.apache.jackrabbit.oak.stats.Clock
-
- Clock.Fast - Class in org.apache.jackrabbit.oak.stats
-
Fast clock implementation whose
Clock.Fast.getTime()
method returns
instantaneously thanks to a background task that takes care of the
actual time-keeping work.
- Clock.Fast(ScheduledExecutorService) - Constructor for class org.apache.jackrabbit.oak.stats.Clock.Fast
-
- Clock.Virtual - Class in org.apache.jackrabbit.oak.stats
-
A virtual clock that has no connection to the actual system time.
- Clock.Virtual() - Constructor for class org.apache.jackrabbit.oak.stats.Clock.Virtual
-
- 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.blob.datastore.DataStoreBlobStore
-
- close() - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreTextWriter
-
- close() - Method in class org.apache.jackrabbit.oak.plugins.blob.GarbageCollectorFileState
-
Completes the process by deleting the files.
- close() - Method in class org.apache.jackrabbit.oak.plugins.document.cache.NodeDocumentCache
-
- close() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoBlobReferenceIterator
-
- 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.util.CloseableIterable
-
- 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.metric.MetricStatisticsProvider
-
- close() - Method in class org.apache.jackrabbit.oak.spi.commit.BackgroundObserver
-
- close() - Method in class org.apache.jackrabbit.oak.stats.Clock.Fast
-
- close() - Method in class org.apache.jackrabbit.oak.stats.StopwatchLogger
-
- 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
-
- closeConnection(Connection) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBConnectionHandler
-
- closeIfCloseable(Object) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
-
- 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.
- CloudBlobStore - Class in org.apache.jackrabbit.oak.plugins.blob.cloud
-
Implementation of the BlobStore
to store blobs in a cloud blob store.
- CloudBlobStore() - Constructor for class org.apache.jackrabbit.oak.plugins.blob.cloud.CloudBlobStore
-
- CLUSTER_CONFIG_NODE - Static variable in class org.apache.jackrabbit.oak.plugins.identifier.ClusterRepositoryInfo
-
- CLUSTER_ID_PROP - Static variable in class org.apache.jackrabbit.oak.plugins.identifier.ClusterRepositoryInfo
-
- CLUSTER_NODES - Static variable in class org.apache.jackrabbit.oak.plugins.document.Collection
-
The 'clusterNodes' collection contains the list of currently running
cluster nodes.
- Clusterable - Interface in org.apache.jackrabbit.oak.spi.state
-
Interface for bearing cluster node specific information.
- 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
-
- ClusterRepositoryInfo - Class in org.apache.jackrabbit.oak.plugins.identifier
-
Utility class to manage a unique cluster/repository id for the cluster.
- ClusterRepositoryInfo() - Constructor for class org.apache.jackrabbit.oak.plugins.identifier.ClusterRepositoryInfo
-
- 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
-
- collectCheckpoints(TabularDataSupport) - Method in class org.apache.jackrabbit.oak.util.AbstractCheckpointMBean
-
Called to collect the tabular data for the checkpoints.
- collectGarbage(boolean) - Method in interface org.apache.jackrabbit.oak.plugins.blob.BlobGarbageCollector
-
Marks garbage blobs from the passed node store instance.
- collectGarbage(boolean) - Method in class org.apache.jackrabbit.oak.plugins.blob.MarkSweepGarbageCollector
-
- 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
-
- collectReferences(ReferenceCollector) - Method in interface org.apache.jackrabbit.oak.plugins.blob.BlobReferenceRetriever
-
Collect references.
- 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
-
- 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 interface org.apache.jackrabbit.oak.api.Root
-
Atomically persists all changes made to the tree attached to this root.
- commit() - Method in interface org.apache.jackrabbit.oak.api.Root
-
Atomically persists all changes made to the tree attached to this root.
- 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_PATH - Static variable in interface org.apache.jackrabbit.oak.api.Root
-
- CommitFailedException - Exception in org.apache.jackrabbit.oak.api
-
Main exception thrown by methods defined on the ContentSession
interface indicating that committing a given set of changes failed.
- CommitFailedException(String, String, int, String, Throwable) - Constructor for exception org.apache.jackrabbit.oak.api.CommitFailedException
-
- CommitFailedException(String, int, String, Throwable) - Constructor for exception org.apache.jackrabbit.oak.api.CommitFailedException
-
- CommitFailedException(String, int, String) - Constructor for exception org.apache.jackrabbit.oak.api.CommitFailedException
-
- CommitHook - Interface in org.apache.jackrabbit.oak.spi.commit
-
Extension point for validating and modifying content changes.
- CommitInfo - Class in org.apache.jackrabbit.oak.spi.commit
-
Commit info instances associate some meta data with a commit.
- CommitInfo(String, String) - Constructor for class org.apache.jackrabbit.oak.spi.commit.CommitInfo
-
Creates a commit info for the given session and user.
- CommitInfo(String, String, Map<String, Object>) - Constructor for class org.apache.jackrabbit.oak.spi.commit.CommitInfo
-
Creates a commit info for the given session and user and info map.
- 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
-
- compacted(long[], long[], long[]) - Method in class org.apache.jackrabbit.oak.spi.gc.DelegatingGCMonitor
-
- compacted(long[], long[], long[]) - Method in interface org.apache.jackrabbit.oak.spi.gc.GCMonitor
-
The compaction phase of the garbage collection process terminated successfully.
- compacted(long[], long[], long[]) - Method in class org.apache.jackrabbit.oak.spi.gc.GCMonitor.Empty
-
- compacted(long[], long[], long[]) - Method in class org.apache.jackrabbit.oak.spi.gc.GCMonitorTracker
-
- compare(String, String) - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocumentIdComparator
-
- 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.DocumentNodeState
-
- compareAgainstBaseState(NodeState, NodeStateDiff) - Method in class org.apache.jackrabbit.oak.plugins.memory.EmptyNodeState
-
- compareAgainstBaseState(NodeState, NodeStateDiff) - Method in class org.apache.jackrabbit.oak.plugins.memory.ModifiedNodeState
-
Since we keep track of an explicit base node state for a
ModifiedNodeState
instance, we can do this in two steps:
first compare all the modified properties and child nodes to those
of the given base state, and then compare the base states to each
other, ignoring all changed properties and child nodes that were
already covered earlier.
- compareAgainstBaseState(NodeState, NodeState, NodeStateDiff) - Static method in class org.apache.jackrabbit.oak.spi.state.AbstractNodeState
-
Generic default comparison algorithm that simply walks through the
property and child node lists of the given base state and compares
the entries one by one with corresponding ones (if any) in this state.
- compareAgainstBaseState(NodeState, NodeStateDiff) - Method in class org.apache.jackrabbit.oak.spi.state.AbstractNodeState
-
Generic default comparison algorithm that simply walks through the
property and child node lists of the given base state and compares
the entries one by one with corresponding ones (if any) in this state.
- compareAgainstBaseState(NodeState, NodeStateDiff) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeState
-
Compares this node state against the given base state.
- compareAgainstEmptyState(NodeState, NodeStateDiff) - Static method in class org.apache.jackrabbit.oak.plugins.memory.EmptyNodeState
-
- compareKeys(K, K) - Method in enum org.apache.jackrabbit.oak.plugins.document.persistentCache.CacheType
-
- comparePropertiesAgainstBaseState(NodeState, NodeState, NodeStateDiff) - Static method in class org.apache.jackrabbit.oak.spi.state.AbstractNodeState
-
Compares the properties of base
state with this
state.
- compareTo(Type<?>) - Method in class org.apache.jackrabbit.oak.api.Type
-
- 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
-
- compareTo(PropertyValue) - Method in class org.apache.jackrabbit.oak.spi.query.PropertyStateValue
-
- 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
-
- compose(Collection<? extends Editor>) - Static method in class org.apache.jackrabbit.oak.spi.commit.CompositeEditor
-
- compose(Collection<? extends EditorProvider>) - Static method in class org.apache.jackrabbit.oak.spi.commit.CompositeEditorProvider
-
- compose(Collection<CommitHook>) - Static method in class org.apache.jackrabbit.oak.spi.commit.CompositeHook
-
- compose(Collection<QueryIndexProvider>) - Static method in class org.apache.jackrabbit.oak.spi.query.CompositeQueryIndexProvider
-
- CompositeActionProvider - Class in org.apache.jackrabbit.oak.spi.security.user.action
-
- 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() - Constructor for class org.apache.jackrabbit.oak.security.authorization.composite.CompositeAuthorizationConfiguration
-
- CompositeAuthorizationConfiguration(SecurityProvider) - Constructor for class org.apache.jackrabbit.oak.security.authorization.composite.CompositeAuthorizationConfiguration
-
- CompositeConfiguration<T extends SecurityConfiguration> - Class in org.apache.jackrabbit.oak.spi.security
-
- 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
-
- CompositeConflictHandler - Class in org.apache.jackrabbit.oak.spi.commit
-
A CompositeConflictHandler
delegates conflict handling
to multiple backing handlers.
- CompositeConflictHandler(Iterable<PartialConflictHandler>) - Constructor for class org.apache.jackrabbit.oak.spi.commit.CompositeConflictHandler
-
Create a new CompositeConflictHandler
with an initial set of
backing handler.
- CompositeConflictHandler() - Constructor for class org.apache.jackrabbit.oak.spi.commit.CompositeConflictHandler
-
Create a new CompositeConflictHandler
with no backing handlers.
- CompositeEditor - Class in org.apache.jackrabbit.oak.spi.commit
-
Aggregation of a list of editors into a single editor.
- CompositeEditor(Collection<? extends Editor>) - Constructor for class org.apache.jackrabbit.oak.spi.commit.CompositeEditor
-
- CompositeEditor(Editor...) - Constructor for class org.apache.jackrabbit.oak.spi.commit.CompositeEditor
-
- CompositeEditorProvider - Class in org.apache.jackrabbit.oak.spi.commit
-
Aggregation of a list of editor providers into a single provider.
- CompositeEditorProvider(EditorProvider...) - Constructor for class org.apache.jackrabbit.oak.spi.commit.CompositeEditorProvider
-
- CompositeHook - Class in org.apache.jackrabbit.oak.spi.commit
-
Composite commit hook.
- CompositeHook(CommitHook...) - Constructor for class org.apache.jackrabbit.oak.spi.commit.CompositeHook
-
- 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
-
- CompositeInitializer - Class in org.apache.jackrabbit.oak.spi.lifecycle
-
- CompositeInitializer(Collection<RepositoryInitializer>) - Constructor for class org.apache.jackrabbit.oak.spi.lifecycle.CompositeInitializer
-
- CompositeInitializer(RepositoryInitializer...) - Constructor for class org.apache.jackrabbit.oak.spi.lifecycle.CompositeInitializer
-
- CompositeObserver - Class in org.apache.jackrabbit.oak.spi.commit
-
Composite observer that delegates all content changes to the set of
currently registered component observers.
- CompositeObserver() - Constructor for class org.apache.jackrabbit.oak.spi.commit.CompositeObserver
-
- CompositePattern - Class in org.apache.jackrabbit.oak.spi.security.authorization.restriction
-
- 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
-
- CompositeQueryIndexProvider - Class in org.apache.jackrabbit.oak.spi.query
-
This QueryIndexProvider
aggregates a list of query index providers
into a single query index provider.
- CompositeQueryIndexProvider(QueryIndexProvider...) - Constructor for class org.apache.jackrabbit.oak.spi.query.CompositeQueryIndexProvider
-
- CompositeRegistration - Class in org.apache.jackrabbit.oak.spi.whiteboard
-
- CompositeRegistration(Registration...) - Constructor for class org.apache.jackrabbit.oak.spi.whiteboard.CompositeRegistration
-
- CompositeRegistration(List<Registration>) - Constructor for class org.apache.jackrabbit.oak.spi.whiteboard.CompositeRegistration
-
- CompositeRestrictionProvider - Class in org.apache.jackrabbit.oak.spi.security.authorization.restriction
-
- CompositeTokenConfiguration - Class in org.apache.jackrabbit.oak.spi.security.authentication.token
-
- 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
TokenProvider
s into a single
provider.
- CompositeWorkspaceInitializer - Class in org.apache.jackrabbit.oak.spi.lifecycle
-
- CompositeWorkspaceInitializer(Collection<WorkspaceInitializer>) - Constructor for class org.apache.jackrabbit.oak.spi.lifecycle.CompositeWorkspaceInitializer
-
- CompositeWorkspaceInitializer(WorkspaceInitializer...) - Constructor for class org.apache.jackrabbit.oak.spi.lifecycle.CompositeWorkspaceInitializer
-
- computeNext() - Method in class org.apache.jackrabbit.oak.plugins.blob.migration.DepthFirstNodeIterator
-
- computeNext() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoBlobReferenceIterator
-
- condition(FilterBuilder.Condition) - Method in class org.apache.jackrabbit.oak.plugins.observation.filter.FilterBuilder
-
Set the condition of this filter.
- 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
Configuration
s for built-in LoginModule implementations.
- CONFLICT - Static variable in class org.apache.jackrabbit.oak.spi.state.ConflictAnnotatingRebaseDiff
-
- ConflictAnnotatingRebaseDiff - Class in org.apache.jackrabbit.oak.spi.state
-
This implementation of
AbstractRebaseDiff
implements a
NodeStateDiff
,
which performs the conflict handling as defined in
NodeStore.rebase(NodeBuilder)
on the Oak SPI state level by annotating conflicting items with conflict
markers.
- ConflictAnnotatingRebaseDiff(NodeBuilder) - Constructor for class org.apache.jackrabbit.oak.spi.state.ConflictAnnotatingRebaseDiff
-
- ConflictHandler - Interface in org.apache.jackrabbit.oak.spi.commit
-
A
ConflictHandler
is responsible for handling conflicts which happen
on
Root.rebase()
and on the implicit rebase operation which
takes part on
Root.commit()
.
- ConflictHook - Class in org.apache.jackrabbit.oak.plugins.commit
-
This commit hook implementation is responsible for resolving
conflicts.
- ConflictHook(ConflictHandler) - 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.
- ConflictType - Enum in org.apache.jackrabbit.oak.spi.state
-
Enum to define various types of 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.
- CONSISTENCY_OP_NAME - Static variable in class org.apache.jackrabbit.oak.plugins.blob.BlobGC
-
- consolidateCount(NodeBuilder) - Static method in class org.apache.jackrabbit.oak.plugins.atomic.AtomicCounterEditor
-
- ConsolidatedCacheStats - Class in org.apache.jackrabbit.oak.cache
-
- ConsolidatedCacheStats() - Constructor for class org.apache.jackrabbit.oak.cache.ConsolidatedCacheStats
-
- ConsolidatedCacheStatsMBean - Interface in org.apache.jackrabbit.oak.api.jmx
-
- 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 exception org.apache.jackrabbit.oak.api.CommitFailedException
-
Type name for constraint violation errors.
- 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(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(Object) - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS
-
Check whether there is a resident entry for the given key.
- 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
- containsMove(String) - Method in class org.apache.jackrabbit.oak.spi.commit.MoveTracker
-
- containsNativeConstraint() - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
-
- containsNativeConstraint() - Method in interface org.apache.jackrabbit.oak.spi.query.Filter
-
Whether the filter contains a native condition.
- containsRevision(Revision) - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
-
- 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.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(NodeState, CommitInfo) - Method in class org.apache.jackrabbit.oak.plugins.observation.NodeObserver
-
- contentChanged(NodeState, CommitInfo) - Method in class org.apache.jackrabbit.oak.spi.commit.BackgroundObserver
-
- contentChanged(NodeState, CommitInfo) - Method in class org.apache.jackrabbit.oak.spi.commit.ChangeDispatcher
-
- contentChanged(NodeState, CommitInfo) - Method in class org.apache.jackrabbit.oak.spi.commit.CompositeObserver
-
- contentChanged(NodeState, CommitInfo) - Method in class org.apache.jackrabbit.oak.spi.commit.DiffObserver
-
- contentChanged(NodeState, CommitInfo) - Method in class org.apache.jackrabbit.oak.spi.commit.EmptyObserver
-
- contentChanged(NodeState, CommitInfo) - Method in interface org.apache.jackrabbit.oak.spi.commit.Observer
-
Observes a content change.
- 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
-
- ContentRepository - Interface in org.apache.jackrabbit.oak.api
-
Oak content repository.
- ContentRepositoryImpl - Class in org.apache.jackrabbit.oak.core
-
- 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.
- ContentSession - Interface in org.apache.jackrabbit.oak.api
-
Authentication session for accessing a content repository.
- Context - Interface in org.apache.jackrabbit.oak.spi.security
-
- Context.Default - Class in org.apache.jackrabbit.oak.spi.security
-
Default implementation of the Context
interface that always returns
false
.
- Context.Default() - Constructor for class org.apache.jackrabbit.oak.spi.security.Context.Default
-
- Conversions - Class in org.apache.jackrabbit.oak.plugins.value
-
Utility class defining the conversion that take place between
PropertyState
s
of different types.
- Conversions.Converter - Class in org.apache.jackrabbit.oak.plugins.value
-
A converter converts a value to its representation as a specific target type.
- Conversions.Converter() - Constructor for class org.apache.jackrabbit.oak.plugins.value.Conversions.Converter
-
- 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(PropertyState, Type<?>) - Static method in class org.apache.jackrabbit.oak.plugins.memory.PropertyStates
-
- convert(String) - Static method in class org.apache.jackrabbit.oak.plugins.value.Conversions
-
Create a converter for a string.
- convert(Blob) - Static method in class org.apache.jackrabbit.oak.plugins.value.Conversions
-
Create a converter for a binary.
- convert(long) - Static method in class org.apache.jackrabbit.oak.plugins.value.Conversions
-
Create a converter for a long.
- convert(double) - Static method in class org.apache.jackrabbit.oak.plugins.value.Conversions
-
Create a converter for a double.
- convert(String, Type<?>) - Static method in class org.apache.jackrabbit.oak.plugins.value.Conversions
-
Create a converter for a date.
- convert(boolean) - Static method in class org.apache.jackrabbit.oak.plugins.value.Conversions
-
Create a converter for a boolean.
- convert(BigDecimal) - Static method in class org.apache.jackrabbit.oak.plugins.value.Conversions
-
Create a converter for a decimal.
- convert(String) - Method in class org.apache.jackrabbit.oak.query.xpath.XPathToSQL2Converter
-
Convert the query to SQL2.
- convert(PropertyValue, int, NamePathMapper) - Static method in class org.apache.jackrabbit.oak.spi.query.PropertyValues
-
Converts the given value to a value of the specified target type.
- 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(InputStream) - Static method in class org.apache.jackrabbit.oak.plugins.blob.GarbageCollectorFileState
-
- 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
-
- copy(Type<T>, PropertyState) - Static method in class org.apache.jackrabbit.oak.plugins.memory.PropertyBuilder
-
Create a new instance for building PropertyState
instances
of the given type
.
- copy() - Method in interface org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan
-
Creates a cloned copy of current plan.
- 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.
- copyNode(String, String) - Method in class org.apache.jackrabbit.oak.plugins.document.Commit
-
- 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
-
- 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.
- costPerEntry - Variable in class org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan.Builder
-
- costPerExecution - Variable in class org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan.Builder
-
- count() - Method in interface org.apache.jackrabbit.oak.api.PropertyState
-
The number of values of this property.
- count() - Method in interface org.apache.jackrabbit.oak.api.PropertyValue
-
The number of values of this object.
- 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, String, Set<String>, int) - Method in class org.apache.jackrabbit.oak.plugins.index.property.strategy.ContentMirrorStoreStrategy
-
- count(Filter, NodeState, NodeState, String, Set<String>, int) - Method in class org.apache.jackrabbit.oak.plugins.index.property.strategy.ContentMirrorStoreStrategy
-
- 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() - Method in class org.apache.jackrabbit.oak.plugins.memory.EmptyPropertyState
-
- count() - Method in class org.apache.jackrabbit.oak.plugins.memory.PropertyBuilder
-
- count() - Method in class org.apache.jackrabbit.oak.spi.query.PropertyStateValue
-
- count(Iterable<?>) - Static method in class org.apache.jackrabbit.oak.spi.state.AbstractNodeState
-
- COUNT_MAX - Static variable in class org.apache.jackrabbit.oak.util.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.util.ApproximateCounter
-
- COUNT_RESOLUTION - Static variable in class org.apache.jackrabbit.oak.util.ApproximateCounter
-
- countDeleteChunks(List<String>, long) - Method in class org.apache.jackrabbit.oak.plugins.blob.cloud.CloudBlobStore
-
- countDeleteChunks(List<String>, long) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore
-
- 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
-
- CounterStats - Interface in org.apache.jackrabbit.oak.stats
-
- Counting - Interface in org.apache.jackrabbit.oak.stats
-
- 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(T[], T[]) - Static method in class org.apache.jackrabbit.oak.query.plan.Permutations
-
Create a new permutations object.
- create(T[], T[], int) - Static method in class org.apache.jackrabbit.oak.query.plan.Permutations
-
Create a new permutations object.
- 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(PropertyState) - Static method in class org.apache.jackrabbit.oak.spi.query.PropertyValues
-
- create(PropertyValue) - Static method in class org.apache.jackrabbit.oak.spi.query.PropertyValues
-
- create(List<RestrictionPattern>) - Static method in class org.apache.jackrabbit.oak.spi.security.authorization.restriction.CompositePattern
-
- createBackend() - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.SharedS3DataStore
-
- createBinary(InputStream) - Method in class org.apache.jackrabbit.oak.plugins.value.ValueFactoryImpl
-
- createBlob(InputStream) - Method in interface org.apache.jackrabbit.oak.api.Root
-
Reads (and closes) the given stream and returns a
Blob
that
contains that binary.
- createBlob(InputStream) - Method in class org.apache.jackrabbit.oak.core.ImmutableRoot
-
- createBlob(InputStream) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
-
- createBlob(InputStream) - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeBuilder
-
- createBlob(InputStream) - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeStore
-
- createBlob(InputStream) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeBuilder
-
- createBlob(InputStream) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeStore
-
Create a
Blob
from the given input stream.
- createBlob(InputStream) - Method in class org.apache.jackrabbit.oak.spi.state.ProxyNodeStore
-
- createBlob(InputStream) - Method in class org.apache.jackrabbit.oak.spi.state.ReadOnlyBuilder
-
- 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 interface org.apache.jackrabbit.oak.api.jmx.CheckpointMBean
-
Create a new checkpoint with the given lifetime
.
- 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
-
- createChildBuilder(String) - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeBuilder
-
Factory method for creating new child state builders.
- createCleanUp(Set<NodeDocument.SplitDocType>, long, VersionGarbageCollector.VersionGCStats) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoVersionGCSupport
-
- createCleanUp(Set<NodeDocument.SplitDocType>, 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
-
- createDataStore(ComponentContext, Map<String, Object>) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.AbstractDataStoreService
-
- createDataStore(ComponentContext, Map<String, Object>) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.DbDataStoreService
-
- createDataStore(ComponentContext, Map<String, Object>) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.FileDataStoreService
-
- createDataStore(ComponentContext, Map<String, Object>) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.S3DataStoreService
-
- createDataStore(ComponentContext, Map<String, Object>) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.SharedS3DataStoreService
-
- createDescriptors() - Method in class org.apache.jackrabbit.oak.core.ContentRepositoryImpl
-
- createDiff(NodeBuilder, String) - Method in class org.apache.jackrabbit.oak.spi.state.AbstractRebaseDiff
-
Factory method for creating a rebase handler for the named child of the passed
parent builder.
- createDiff(NodeBuilder, String) - Method in class org.apache.jackrabbit.oak.spi.state.ConflictAnnotatingRebaseDiff
-
- 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
-
- createId(NodeStore) - Static method in class org.apache.jackrabbit.oak.plugins.identifier.ClusterRepositoryInfo
-
Adds a new uuid for the repository in the property /:clusterConfig/:clusterId if not available
- createId(NodeStore, String) - Static method in class org.apache.jackrabbit.oak.plugins.identifier.ClusterRepositoryInfo
-
Adds a new uuid for the repository in the property /:clusterConfig/:clusterId Or
update the id with the customId passed.
- 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(NodeUtil, 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(NodeUtil, String, boolean, String[], 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(NodeUtil, String, boolean, 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
.
- 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
-
- createLongProperty(String, long) - Static method in class org.apache.jackrabbit.oak.plugins.memory.LongPropertyState
-
Create a PropertyState
from a long.
- createLongProperty(String, Iterable<Long>) - Static method in class org.apache.jackrabbit.oak.plugins.memory.MultiLongPropertyState
-
Create a multi valued PropertyState
from a list of longs.
- 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
-
Create or update a document.
- 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
UpdateOp
s 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
-
- createProperty(String, Value) - Static method in class org.apache.jackrabbit.oak.plugins.memory.PropertyStates
-
Create a
PropertyState
based on a
Value
.
- createProperty(String, Iterable<Value>) - Static method in class org.apache.jackrabbit.oak.plugins.memory.PropertyStates
-
Create a multi valued
PropertyState
based on a list of
Value
instances.
- createProperty(String, Iterable<Value>, int) - Static method in class org.apache.jackrabbit.oak.plugins.memory.PropertyStates
-
- createProperty(String, String, int) - Static method in class org.apache.jackrabbit.oak.plugins.memory.PropertyStates
-
Create a PropertyState
from a string.
- createProperty(String, Object, Type<?>) - Static method in class org.apache.jackrabbit.oak.plugins.memory.PropertyStates
-
Create a PropertyState
.
- createProperty(String, T) - Static method in class org.apache.jackrabbit.oak.plugins.memory.PropertyStates
-
Create a
PropertyState
where the
Type
of the property state
is inferred from the runtime type of
T
according to the mapping
established through
Type
.
- 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.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.
- createRestriction(String, String, Value) - Method in class org.apache.jackrabbit.oak.spi.whiteboard.WhiteboardRestrictionProvider
-
- createRestriction(String, String, Value...) - Method in class org.apache.jackrabbit.oak.spi.whiteboard.WhiteboardRestrictionProvider
-
- 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
-
- 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
-
- createValidator(Validator, List<String>) - Method in class org.apache.jackrabbit.oak.spi.commit.SubtreeExcludingValidator
-
- createValue(PropertyState, NamePathMapper) - Static method in class org.apache.jackrabbit.oak.plugins.value.ValueFactoryImpl
-
Utility method for creating a Value
based on a PropertyState
.
- createValue(PropertyValue, NamePathMapper) - Static method in class org.apache.jackrabbit.oak.plugins.value.ValueFactoryImpl
-
Utility method for creating a Value
based on a PropertyValue
.
- createValue(String) - Method in class org.apache.jackrabbit.oak.plugins.value.ValueFactoryImpl
-
- createValue(InputStream) - Method in class org.apache.jackrabbit.oak.plugins.value.ValueFactoryImpl
-
- createValue(Binary) - Method in class org.apache.jackrabbit.oak.plugins.value.ValueFactoryImpl
-
- createValue(long) - Method in class org.apache.jackrabbit.oak.plugins.value.ValueFactoryImpl
-
- createValue(double) - Method in class org.apache.jackrabbit.oak.plugins.value.ValueFactoryImpl
-
- createValue(Calendar) - Method in class org.apache.jackrabbit.oak.plugins.value.ValueFactoryImpl
-
- createValue(boolean) - Method in class org.apache.jackrabbit.oak.plugins.value.ValueFactoryImpl
-
- createValue(Node) - Method in class org.apache.jackrabbit.oak.plugins.value.ValueFactoryImpl
-
- createValue(Node, boolean) - Method in class org.apache.jackrabbit.oak.plugins.value.ValueFactoryImpl
-
- createValue(BigDecimal) - Method in class org.apache.jackrabbit.oak.plugins.value.ValueFactoryImpl
-
- createValue(String, int) - Method in class org.apache.jackrabbit.oak.plugins.value.ValueFactoryImpl
-
- createValues(PropertyState, NamePathMapper) - Static method in class org.apache.jackrabbit.oak.plugins.value.ValueFactoryImpl
-
Utility method for creating Value
s based on a PropertyState
.
- createValues(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.value.ValueFactoryImpl
-
Utility method for creating Value
s based on a PropertyState
.
- CREDENTIALS_ATTRIBUTE_NEWPASSWORD - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
-
- 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
-
- 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
-
- Cursor - Interface in org.apache.jackrabbit.oak.spi.query
-
A cursor to read a number of nodes sequentially.
- Cursors - Class in org.apache.jackrabbit.oak.spi.query
-
This utility class provides factory methods to create commonly used types of
Cursor
s.
- Cursors.AbstractCursor - Class in org.apache.jackrabbit.oak.spi.query
-
A Cursor implementation where the remove method throws an
UnsupportedOperationException.
- Cursors.AbstractCursor() - Constructor for class org.apache.jackrabbit.oak.spi.query.Cursors.AbstractCursor
-
- Cursors.PathCursor - Class in org.apache.jackrabbit.oak.spi.query
-
- Cursors.PathCursor(Iterator<String>, boolean, QueryEngineSettings) - Constructor for class org.apache.jackrabbit.oak.spi.query.Cursors.PathCursor
-
- CUSTOM_BLOB_STORE - Static variable in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreService
-
- 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
-
- DataStoreBlobStore - Class in org.apache.jackrabbit.oak.plugins.blob.datastore
-
BlobStore wrapper for DataStore.
- DataStoreBlobStore(DataStore) - Constructor for class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore
-
- DataStoreBlobStore(DataStore, boolean) - Constructor for class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore
-
- DataStoreBlobStore(DataStore, boolean, int) - Constructor for class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore
-
- DataStoreTextProviderService - Class in org.apache.jackrabbit.oak.plugins.blob.datastore
-
- DataStoreTextProviderService() - Constructor for class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreTextProviderService
-
- DataStoreTextWriter - Class in org.apache.jackrabbit.oak.plugins.blob.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.blob.datastore.DataStoreTextWriter
-
- DATE - Static variable in class org.apache.jackrabbit.oak.api.Type
-
- DateConstraint - Class in org.apache.jackrabbit.oak.plugins.nodetype.constraint
-
- DateConstraint(String) - Constructor for class org.apache.jackrabbit.oak.plugins.nodetype.constraint.DateConstraint
-
- dateProperty(String, String) - Static method in class org.apache.jackrabbit.oak.plugins.memory.GenericPropertyState
-
Create a PropertyState
from a date.
- dateProperty(String, Iterable<String>) - Static method in class org.apache.jackrabbit.oak.plugins.memory.MultiGenericPropertyState
-
Create a multi valued PropertyState
from a list of dates.
- DATES - Static variable in class org.apache.jackrabbit.oak.api.Type
-
- 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.
- DbDataStoreService - Class in org.apache.jackrabbit.oak.plugins.blob.datastore
-
- DbDataStoreService() - Constructor for class org.apache.jackrabbit.oak.plugins.blob.datastore.DbDataStoreService
-
- deactivate() - Method in class org.apache.jackrabbit.oak.plugins.atomic.AtomicCounterEditorProvider
-
- deactivate() - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.AbstractDataStoreService
-
- 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.security.internal.SecurityProviderRegistration
-
- deactivate() - Method in class org.apache.jackrabbit.oak.security.SecurityProviderImpl
-
- dec() - Method in interface org.apache.jackrabbit.oak.stats.CounterStats
-
Decrement the counter by one.
- dec(long) - Method in interface org.apache.jackrabbit.oak.stats.CounterStats
-
Decrement the counter by n
.
- dec() - Method in class org.apache.jackrabbit.oak.stats.NoopStats
-
- dec(long) - Method in class org.apache.jackrabbit.oak.stats.NoopStats
-
- dec() - Method in class org.apache.jackrabbit.oak.stats.SimpleStats
-
- dec(long) - Method in class org.apache.jackrabbit.oak.stats.SimpleStats
-
- DECIMAL - Static variable in class org.apache.jackrabbit.oak.api.Type
-
- DecimalConstraint - Class in org.apache.jackrabbit.oak.plugins.nodetype.constraint
-
- DecimalConstraint(String) - Constructor for class org.apache.jackrabbit.oak.plugins.nodetype.constraint.DecimalConstraint
-
- decimalProperty(String, BigDecimal) - Static method in class org.apache.jackrabbit.oak.plugins.memory.DecimalPropertyState
-
Create a PropertyState
from a decimal.
- decimalProperty(String, Iterable<BigDecimal>) - Static method in class org.apache.jackrabbit.oak.plugins.memory.MultiDecimalPropertyState
-
Create a multi valued PropertyState
from a list of decimals.
- DecimalPropertyState - Class in org.apache.jackrabbit.oak.plugins.memory
-
- DecimalPropertyState(String, BigDecimal) - Constructor for class org.apache.jackrabbit.oak.plugins.memory.DecimalPropertyState
-
- DECIMALS - Static variable in class org.apache.jackrabbit.oak.api.Type
-
- 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.
- decodeName(int, String) - Static method in class org.apache.jackrabbit.oak.json.TypeCodes
-
Decode the property name encoded into a jsonString
given its split.
- decodeType(int, String) - Static method in class org.apache.jackrabbit.oak.json.TypeCodes
-
Decode the type encoded into jsonString
given its split.
- 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 - Static variable in interface org.apache.jackrabbit.oak.spi.lifecycle.RepositoryInitializer
-
Default implementation makes no changes to the repository.
- DEFAULT - Static variable in interface org.apache.jackrabbit.oak.spi.lifecycle.WorkspaceInitializer
-
- DEFAULT - Static variable in interface org.apache.jackrabbit.oak.spi.security.Context
-
- DEFAULT - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.AuthorizableNodeName
-
Default AuthorizableNodeName
instance.
- DEFAULT - Static variable in class org.apache.jackrabbit.oak.stats.StatsOptions
-
Default mode where both TimeSeries data and other statistical data
would be collected
- 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_BATCH_COUNT - Static variable in class org.apache.jackrabbit.oak.plugins.blob.MarkSweepGarbageCollector
-
- DEFAULT_CACHE_SEGMENT_COUNT - Static variable in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
-
- DEFAULT_CACHE_SIZE - Static variable in class org.apache.jackrabbit.oak.plugins.blob.CachingBlobStore
-
- DEFAULT_CACHE_SIZE - Static variable in class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore
-
- 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_DIRECTION - Static variable in interface org.apache.jackrabbit.oak.plugins.index.property.OrderedIndex
-
the default direction for sorting the index
- DEFAULT_DOC_CHILDREN_CACHE_PERCENTAGE - Static variable in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
-
- DEFAULT_FILTER_EXPRESSION - Static variable in class org.apache.jackrabbit.oak.json.JsonSerializer
-
- 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_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_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_READ_PATHS - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.PermissionConstants
-
- 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
-
- 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
-
This implementation of a
ConflictHandler
always returns the same resolution.
- DefaultConflictHandler(PartialConflictHandler.Resolution) - Constructor for class org.apache.jackrabbit.oak.plugins.commit.DefaultConflictHandler
-
Create a new ConflictHandler
which always returns resolution
.
- DefaultEditor - Class in org.apache.jackrabbit.oak.spi.commit
-
Editor that does nothing by default and doesn't recurse into subtrees.
- DefaultEditor() - Constructor for class org.apache.jackrabbit.oak.spi.commit.DefaultEditor
-
- 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.
- DefaultMoveValidator - Class in org.apache.jackrabbit.oak.spi.commit
-
MoveValidator
that does nothing by default and doesn't recurse into subtrees.
- DefaultMoveValidator() - Constructor for class org.apache.jackrabbit.oak.spi.commit.DefaultMoveValidator
-
- DefaultNodeStateDiff - Class in org.apache.jackrabbit.oak.spi.state
-
Node state diff handler that by default does nothing.
- DefaultNodeStateDiff() - Constructor for class org.apache.jackrabbit.oak.spi.state.DefaultNodeStateDiff
-
- defaultScheduledExecutor() - Static method in class org.apache.jackrabbit.oak.Oak
-
Default ScheduledExecutorService
used for scheduling background tasks.
- DefaultStatisticsProvider - Class in org.apache.jackrabbit.oak.stats
-
- DefaultStatisticsProvider(ScheduledExecutorService) - Constructor for class org.apache.jackrabbit.oak.stats.DefaultStatisticsProvider
-
- DefaultValidator - Class in org.apache.jackrabbit.oak.spi.commit
-
Validator that does nothing by default and doesn't recurse into subtrees.
- DefaultValidator() - Constructor for class org.apache.jackrabbit.oak.spi.commit.DefaultValidator
-
- DefaultWhiteboard - Class in org.apache.jackrabbit.oak.spi.whiteboard
-
- DefaultWhiteboard() - Constructor for class org.apache.jackrabbit.oak.spi.whiteboard.DefaultWhiteboard
-
- 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
-
- definition - Variable in class org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan.Builder
-
- DefinitionProvider - Interface in org.apache.jackrabbit.oak.plugins.nodetype
-
DefinitionProvider...
- DelegatingGCMonitor - Class in org.apache.jackrabbit.oak.spi.gc
-
This
GCMonitor
implementation simply delegates all its call
to registered monitors.
- DelegatingGCMonitor() - Constructor for class org.apache.jackrabbit.oak.spi.gc.DelegatingGCMonitor
-
- 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
-
- deleteAllMetadataRecords(String) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore
-
- deleteAllMetadataRecords(String) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.OakFileDataStore
-
- deleteAllMetadataRecords(String) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.SharedS3DataStore
-
- deleteAllMetadataRecords(String) - Method in interface org.apache.jackrabbit.oak.plugins.blob.SharedDataStore
-
Deletes all records matching the given prefix.
- deleteAllOlderThan(long) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore
-
- deleteBucket() - Method in class org.apache.jackrabbit.oak.plugins.blob.cloud.CloudBlobStore
-
Delete the cloud container and all its contents.
- deleteChangedNode(NodeBuilder, String, 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
-
- deleteChangedNode(NodeBuilder, String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.commit.JcrLastModifiedConflictHandler
-
- deleteChangedNode(NodeBuilder, String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.commit.CompositeConflictHandler
-
- deleteChangedNode(NodeBuilder, String, NodeState) - Method in interface org.apache.jackrabbit.oak.spi.commit.ConflictHandler
-
The node theirs
changed in the persistence store while it has been
deleted locally.
- deleteChangedNode(NodeBuilder, String, NodeState) - Method in interface org.apache.jackrabbit.oak.spi.commit.PartialConflictHandler
-
The node theirs
changed in the persistence store while it has been
deleted locally.
- deleteChangedNode(NodeBuilder, String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.state.AbstractRebaseDiff
-
Called when the node before
was deleted in the branch but was
already changed in the trunk.
- deleteChangedNode(NodeBuilder, String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.state.ConflictAnnotatingRebaseDiff
-
- deleteChangedProperty(NodeBuilder, 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
-
- deleteChangedProperty(NodeBuilder, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.commit.JcrLastModifiedConflictHandler
-
- deleteChangedProperty(NodeBuilder, PropertyState) - Method in class org.apache.jackrabbit.oak.spi.commit.CompositeConflictHandler
-
- deleteChangedProperty(NodeBuilder, PropertyState) - Method in interface org.apache.jackrabbit.oak.spi.commit.ConflictHandler
-
The property theirs
changed in the persistence store while it has been
deleted locally.
- deleteChangedProperty(NodeBuilder, PropertyState) - Method in interface org.apache.jackrabbit.oak.spi.commit.PartialConflictHandler
-
The property theirs
changed in the persistence store while it has been
deleted locally.
- deleteChangedProperty(NodeBuilder, PropertyState) - Method in class org.apache.jackrabbit.oak.spi.state.AbstractRebaseDiff
-
Called when the property before
was deleted in the branch but was
already changed in the trunk.
- deleteChangedProperty(NodeBuilder, PropertyState) - Method in class org.apache.jackrabbit.oak.spi.state.ConflictAnnotatingRebaseDiff
-
- deleteChunks(List<String>, long) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore
-
- deleteChunks(List<String>, long) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.BlobCache
-
Deprecated.
- 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) - 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
-
- deleteDeletedNode(NodeBuilder, String) - Method in class org.apache.jackrabbit.oak.plugins.commit.JcrLastModifiedConflictHandler
-
- deleteDeletedNode(NodeBuilder, String) - Method in class org.apache.jackrabbit.oak.spi.commit.CompositeConflictHandler
-
- deleteDeletedNode(NodeBuilder, String) - Method in interface org.apache.jackrabbit.oak.spi.commit.ConflictHandler
-
The node name
has been removed in parent
while it was
also removed in the persistence store.
- deleteDeletedNode(NodeBuilder, String) - Method in interface org.apache.jackrabbit.oak.spi.commit.PartialConflictHandler
-
The node name
has been removed in parent
while it was
also removed in the persistence store.
- deleteDeletedNode(NodeBuilder, String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.state.AbstractRebaseDiff
-
Called when the node before
was deleted in the branch but was
already deleted in the trunk.
- deleteDeletedNode(NodeBuilder, String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.state.ConflictAnnotatingRebaseDiff
-
- 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
-
- deleteDeletedProperty(NodeBuilder, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.commit.JcrLastModifiedConflictHandler
-
- deleteDeletedProperty(NodeBuilder, PropertyState) - Method in class org.apache.jackrabbit.oak.spi.commit.CompositeConflictHandler
-
- deleteDeletedProperty(NodeBuilder, PropertyState) - Method in interface org.apache.jackrabbit.oak.spi.commit.ConflictHandler
-
The property ours
has been removed in parent
while it was
also removed in the persistence store.
- deleteDeletedProperty(NodeBuilder, PropertyState) - Method in interface org.apache.jackrabbit.oak.spi.commit.PartialConflictHandler
-
The property ours
has been removed in parent
while it was
also removed in the persistence store.
- deleteDeletedProperty(NodeBuilder, PropertyState) - Method in class org.apache.jackrabbit.oak.spi.state.AbstractRebaseDiff
-
Called when the property before
was deleted in the branch but was
already deleted in the trunk.
- deleteDeletedProperty(NodeBuilder, PropertyState) - Method in class org.apache.jackrabbit.oak.spi.state.ConflictAnnotatingRebaseDiff
-
- deletedOnce() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBRow
-
- deleteMetadataRecord(String) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore
-
- deleteMetadataRecord(String) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.OakFileDataStore
-
- deleteMetadataRecord(String) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.SharedS3DataStore
-
- deleteMetadataRecord(String) - Method in interface org.apache.jackrabbit.oak.plugins.blob.SharedDataStore
-
Deletes the root record represented by the given parameters.
- deleteSplitDocuments() - Method in class org.apache.jackrabbit.oak.plugins.document.SplitDocumentCleanUp
-
- deleteSplitDocuments(Set<NodeDocument.SplitDocType>, long, VersionGarbageCollector.VersionGCStats) - Method in class org.apache.jackrabbit.oak.plugins.document.VersionGCSupport
-
- 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.
- DELIM - Static variable in class org.apache.jackrabbit.oak.plugins.blob.MarkSweepGarbageCollector
-
- DEPRECATION_MESSAGE - Static variable in interface org.apache.jackrabbit.oak.plugins.index.property.OrderedIndex
-
Deprecation message tracked when using the ordered index.
- DepthFirstNodeIterator - Class in org.apache.jackrabbit.oak.plugins.blob.migration
-
- DepthFirstNodeIterator(NodeState) - Constructor for class org.apache.jackrabbit.oak.plugins.blob.migration.DepthFirstNodeIterator
-
- 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
- Descriptors - Interface in org.apache.jackrabbit.oak.api
-
Repository descriptors interface that is used to support providing the repository descriptors of
Repository
- 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(String, String, String, int) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK
-
- 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.
- 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
-
- DiffObserver - Class in org.apache.jackrabbit.oak.spi.commit
-
Abstract base class for observers that use a content diff to determine
what changed between two consecutive observed states of the repository.
- DiffObserver() - Constructor for class org.apache.jackrabbit.oak.spi.commit.DiffObserver
-
- diffToJsop(NodeState, NodeState) - Static method in class org.apache.jackrabbit.oak.json.JsopDiff
-
Create the JSOP diff between before
and after
for
debugging purposes.
- 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
-
- 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
-
- dispatcher - Variable in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
-
The change dispatcher for this node store.
- 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.
- dispose() - Method in class org.apache.jackrabbit.oak.stats.StatisticManager
-
Unregister all statistics previously registered with the whiteboard passed
to the constructor.
- 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
-
- DocumentBlobReferenceRetriever - Class in org.apache.jackrabbit.oak.plugins.document
-
- 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
-
- 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.
- DocumentMK.Builder() - Constructor for class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
-
- DocumentNodeState - Class in org.apache.jackrabbit.oak.plugins.document
-
- DocumentNodeState.Children - Class in org.apache.jackrabbit.oak.plugins.document
-
A list of children for a node.
- DocumentNodeState.Children() - Constructor for class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState.Children
-
- DocumentNodeStore - Class in org.apache.jackrabbit.oak.plugins.document
-
- 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
-
- 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
-
- done(String, R) - Static method in class org.apache.jackrabbit.oak.management.ManagementOperation
-
An operation that is already done with the given value
.
- done() - Method in class org.apache.jackrabbit.oak.plugins.document.MemoryDiffCache.MemoryEntry
-
- 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
- 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
- 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
- DOUBLE - Static variable in class org.apache.jackrabbit.oak.api.Type
-
- DoubleConstraint - Class in org.apache.jackrabbit.oak.plugins.nodetype.constraint
-
- DoubleConstraint(String) - Constructor for class org.apache.jackrabbit.oak.plugins.nodetype.constraint.DoubleConstraint
-
- doubleProperty(String, double) - Static method in class org.apache.jackrabbit.oak.plugins.memory.DoublePropertyState
-
Create a PropertyState
from a double.
- doubleProperty(String, Iterable<Double>) - Static method in class org.apache.jackrabbit.oak.plugins.memory.MultiDoublePropertyState
-
Create a multi valued PropertyState
from a list of doubles.
- DoublePropertyState - Class in org.apache.jackrabbit.oak.plugins.memory
-
- DoublePropertyState(String, double) - Constructor for class org.apache.jackrabbit.oak.plugins.memory.DoublePropertyState
-
- DOUBLES - Static variable in class org.apache.jackrabbit.oak.api.Type
-
- downloadCompleted(String) - Method in class org.apache.jackrabbit.oak.plugins.blob.BlobStoreStats
-
- downloaded(String, long, TimeUnit, long) - Method in class org.apache.jackrabbit.oak.plugins.blob.BlobStoreStats
-
- 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
-
- GarbageCollectionRepoStats - Class in org.apache.jackrabbit.oak.plugins.blob
-
Garbage collection stats for the repository.
- GarbageCollectionRepoStats() - Constructor for class org.apache.jackrabbit.oak.plugins.blob.GarbageCollectionRepoStats
-
- GarbageCollectorFileState - Class in org.apache.jackrabbit.oak.plugins.blob
-
Class for keeping the file system state of the garbage collection.
- GarbageCollectorFileState(String) - Constructor for class org.apache.jackrabbit.oak.plugins.blob.GarbageCollectorFileState
-
Instantiates a new garbage collector file state.
- gc(long, TimeUnit) - Method in class org.apache.jackrabbit.oak.plugins.document.JournalGarbageCollector
-
Deletes entries in the journal that are older than the given
maxRevisionAge.
- gc(long, TimeUnit) - Method in class org.apache.jackrabbit.oak.plugins.document.VersionGarbageCollector
-
- GCMonitor - Interface in org.apache.jackrabbit.oak.spi.gc
-
GCMonitor
instance are used to monitor garbage collection.
- GCMonitor.Empty - Class in org.apache.jackrabbit.oak.spi.gc
-
- GCMonitor.Empty() - Constructor for class org.apache.jackrabbit.oak.spi.gc.GCMonitor.Empty
-
- GCMonitorTracker - Class in org.apache.jackrabbit.oak.spi.gc
-
This
GCMonitor
implementation tracks
GCMonitor
instances registered
to the
Whiteboard
delegating all calls to to those.
- GCMonitorTracker() - Constructor for class org.apache.jackrabbit.oak.spi.gc.GCMonitorTracker
-
- 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.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
.
- generateNodeName(String) - Method in class org.apache.jackrabbit.oak.spi.whiteboard.WhiteboardAuthorizableNodeName
-
- 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
-
- GenericDescriptors - Class in org.apache.jackrabbit.oak.util
-
- GenericDescriptors() - Constructor for class org.apache.jackrabbit.oak.util.GenericDescriptors
-
Constructs an empty descriptors set.
- GenericDescriptors(Descriptors) - Constructor for class org.apache.jackrabbit.oak.util.GenericDescriptors
-
Constructs a descriptors set that uses the given base
descriptors as base.
- GenericPropertyState - Class in org.apache.jackrabbit.oak.plugins.memory
-
- GenericPropertyState(String, String, Type<?>) - Constructor for class org.apache.jackrabbit.oak.plugins.memory.GenericPropertyState
-
- get(K, Callable<? extends V>) - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS
-
- get(K) - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS
-
Get the value, loading it if needed.
- get(String) - Static method in class org.apache.jackrabbit.oak.cache.StringCache
-
- 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.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(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.
- GET_NAME - Static variable in interface org.apache.jackrabbit.oak.spi.state.ChildNodeEntry
-
Mapping from a ChildNodeEntry instance to its name.
- 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
-
- getAccessKey() - Method in class org.apache.jackrabbit.oak.plugins.blob.cloud.CloudBlobStore
-
- 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
.
- getAll(Iterable<? extends K>) - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS
-
- getAllChunkIds(long) - Method in class org.apache.jackrabbit.oak.plugins.blob.cloud.CloudBlobStore
-
- getAllChunkIds(long) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore
-
- 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
-
- getAllIdentifiers() - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore
-
- getAllIdentifiers() - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.OakFileDataStore
-
- getAllMetadataRecords(String) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore
-
- getAllMetadataRecords(String) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.OakFileDataStore
-
- getAllMetadataRecords(String) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.SharedS3DataStore
-
- getAllMetadataRecords(String) - Method in interface org.apache.jackrabbit.oak.plugins.blob.SharedDataStore
-
Gets the all root records.
- getAllNodeTypes() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.ReadOnlyNodeTypeManager
-
- getAllPresent(Iterable<?>) - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS
-
- 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
-
- getArrayType() - Method in class org.apache.jackrabbit.oak.api.Type
-
Determine the array type which has this type as base type
- getAsyncDelay() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
-
- getAsyncDelay() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
-
- getAttribute(String) - Method in interface org.apache.jackrabbit.oak.api.AuthInfo
-
Returns the attribute with the given name or null
if no attribute
with that attributeName
exists.
- getAttribute(String) - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndexPlan
-
- getAttribute(String) - Method in interface org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan
-
Returns the value of the named attribute as an Object
,
or null
if no attribute of the given name exists.
- getAttribute(String) - Method in class org.apache.jackrabbit.oak.spi.security.authentication.AuthInfoImpl
-
- getAttributeNames() - Method in interface org.apache.jackrabbit.oak.api.AuthInfo
-
Returns the attribute names associated with this instance.
- getAttributeNames() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.AuthInfoImpl
-
- getAuthentication(UserConfiguration, Root, String) - Method in class org.apache.jackrabbit.oak.security.user.UserAuthenticationFactoryImpl
-
- getAuthentication(UserConfiguration, Root, String) - Method in interface org.apache.jackrabbit.oak.spi.security.user.UserAuthenticationFactory
-
- getAuthentication(UserConfiguration, Root, String) - Method in class org.apache.jackrabbit.oak.spi.whiteboard.WhiteboardUserAuthenticationFactory
-
- getAuthInfo() - Method in interface org.apache.jackrabbit.oak.api.ContentSession
-
This methods provides access to information related to authentication
and authorization of this content session.
- getAuthInfo() - Method in interface org.apache.jackrabbit.oak.api.jmx.SessionMBean
-
- 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
-
- 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
-
- getAuthorizableActions(SecurityProvider) - Method in class org.apache.jackrabbit.oak.spi.whiteboard.WhiteboardAuthorizableActionProvider
-
- 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
-
- getAvailableRefs() - Method in class org.apache.jackrabbit.oak.plugins.blob.GarbageCollectorFileState
-
Gets the file storing the available references.
- getAverageLoadPenalty() - Method in interface org.apache.jackrabbit.oak.api.jmx.CacheStatsMBean
-
Returns the average time spent loading new values.
- getAverageLoadPenalty() - Method in class org.apache.jackrabbit.oak.cache.CacheStats
-
- getAverageMemory() - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS
-
Get the average memory used per entry.
- getBackupStatus() - Method in interface org.apache.jackrabbit.oak.api.jmx.FileStoreBackupRestoreMBean
-
Backup status
- getBackupStatus() - Method in interface org.apache.jackrabbit.oak.api.jmx.RepositoryManagementMBean
-
Backup status
- getBackupStatus() - Method in class org.apache.jackrabbit.oak.management.RepositoryManager
-
- getBase() - Method in class org.apache.jackrabbit.oak.query.fulltext.FullTextContains
-
- getBase() - Method in interface org.apache.jackrabbit.oak.spi.state.NodeStoreBranch
-
Returns the base state of this branch.
- getBaseCredentials() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.ImpersonationCredentials
-
- getBaseState() - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeBuilder
-
- getBaseState() - Method in class org.apache.jackrabbit.oak.plugins.memory.ModifiedNodeState
-
- getBaseState() - Method in class org.apache.jackrabbit.oak.query.ExecutionContext
-
Used to evaluate the query (ie.
- getBaseState() - Method in interface org.apache.jackrabbit.oak.spi.state.NodeBuilder
-
Returns the original base state that this builder is modifying.
- getBaseState() - Method in class org.apache.jackrabbit.oak.spi.state.ReadOnlyBuilder
-
- getBaseType() - Method in class org.apache.jackrabbit.oak.api.Type
-
Determine the base type of array types
- 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
-
- getBinary() - Method in class org.apache.jackrabbit.oak.plugins.value.ValueImpl
-
- getBindVariableName() - Method in class org.apache.jackrabbit.oak.query.ast.BindVariableValueImpl
-
- getBindVariableNames(String, String, Map<String, String>) - Method in interface org.apache.jackrabbit.oak.api.QueryEngine
-
Parse the query (check if it's valid) and get the list of bind variable names.
- 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 interface org.apache.jackrabbit.oak.api.Root
-
Get a blob by its reference.
- getBlob(String) - Method in class org.apache.jackrabbit.oak.core.ImmutableRoot
-
- getBlob() - Method in class org.apache.jackrabbit.oak.plugins.blob.ReferencedBlob
-
- getBlob(String) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
-
Returns the
Blob
with the given reference.
- getBlob(String) - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeStore
-
- getBlob(Value) - Static method in class org.apache.jackrabbit.oak.plugins.value.ValueImpl
-
- getBlob(String) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeStore
-
Get a blob by its reference.
- getBlob(String) - Method in class org.apache.jackrabbit.oak.spi.state.ProxyNodeStore
-
- getBlobCacheSize() - Method in class org.apache.jackrabbit.oak.plugins.blob.CachingBlobStore
-
- getBlobFromBlobId(String) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
-
Returns the
Blob
with the given blobId.
- getBlobGCStatus() - Method in class org.apache.jackrabbit.oak.plugins.blob.BlobGC
-
- getBlobGCStatus() - Method in interface org.apache.jackrabbit.oak.plugins.blob.BlobGCMBean
-
Data store garbage collection status
- getBlobId() - Method in class org.apache.jackrabbit.oak.plugins.blob.BlobStoreBlob
-
- getBlobId(String) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore
-
- getBlobId(String) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.BlobCache
-
- getBlobLength(String) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore
-
- getBlobLength(String) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.BlobCache
-
- getBlobMigrationStatus() - Method in class org.apache.jackrabbit.oak.plugins.blob.migration.BlobMigration
-
- getBlobMigrationStatus() - Method in interface org.apache.jackrabbit.oak.plugins.blob.migration.BlobMigrationMBean
-
- getBlobStore() - Method in class org.apache.jackrabbit.oak.plugins.blob.BlobStoreBlob
-
- 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
-
- getBlockSizeMin() - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore
-
- getBlockSizeMin() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.BlobCache
-
- getBoolean(String) - Method in class org.apache.jackrabbit.oak.plugins.memory.EmptyNodeState
-
- getBoolean(String) - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeBuilder
-
- getBoolean() - Method in class org.apache.jackrabbit.oak.plugins.value.ValueImpl
-
- getBoolean(NodeState, String) - Static method in class org.apache.jackrabbit.oak.spi.state.AbstractNodeState
-
- getBoolean(String) - Method in class org.apache.jackrabbit.oak.spi.state.AbstractNodeState
-
- getBoolean(String) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeBuilder
-
Returns the boolean value of the named property.
- getBoolean(String) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeState
-
Returns the boolean value of the named property.
- getBoolean(String) - Method in class org.apache.jackrabbit.oak.spi.state.ReadOnlyBuilder
-
- getBoolean(Tree, String) - Static method in class org.apache.jackrabbit.oak.util.TreeUtil
-
Returns the boolean representation of the property with the specified
propertyName
.
- getBoost() - Method in class org.apache.jackrabbit.oak.query.fulltext.FullTextTerm
-
- 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
-
- getBuilder(NodeBuilder) - Method in class org.apache.jackrabbit.oak.plugins.blob.migration.DepthFirstNodeIterator
-
- getCacheStats() - Method in interface org.apache.jackrabbit.oak.api.jmx.ConsolidatedCacheStatsMBean
-
- getCacheStats() - Method in class org.apache.jackrabbit.oak.cache.ConsolidatedCacheStats
-
- getCacheStats() - Method in class org.apache.jackrabbit.oak.plugins.blob.CachingBlobStore
-
- getCacheStats() - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore
-
- 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 after the specified
startTime
.
- getCandidates(long) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoMissingLastRevSeeker
-
- 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
-
- getCheckpoints() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
-
- getChild(String) - Method in interface org.apache.jackrabbit.oak.api.Tree
-
Get a possibly non existing child of this Tree
.
- 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
.
- getChild(String) - Method in class org.apache.jackrabbit.oak.util.NodeUtil
-
- 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
-
- getChildNode(String) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState
-
- getChildNode(String) - Method in class org.apache.jackrabbit.oak.plugins.memory.EmptyNodeState
-
- getChildNode(String) - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeBuilder
-
- getChildNode(String) - Method in class org.apache.jackrabbit.oak.plugins.memory.ModifiedNodeState
-
- getChildNode(String) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeBuilder
-
Returns a builder for constructing changes to the named child node.
- getChildNode(String) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeState
-
Returns the named, possibly non-existent, child node.
- getChildNode(String) - Method in class org.apache.jackrabbit.oak.spi.state.ReadOnlyBuilder
-
- getChildNodeCount(long) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState
-
- getChildNodeCount(long) - Method in class org.apache.jackrabbit.oak.plugins.memory.EmptyNodeState
-
- getChildNodeCount(long) - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeBuilder
-
- getChildNodeCount(long) - Method in class org.apache.jackrabbit.oak.plugins.memory.ModifiedNodeState
-
- getChildNodeCount(long) - Method in class org.apache.jackrabbit.oak.spi.state.AbstractNodeState
-
- getChildNodeCount(long) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeBuilder
-
Returns the current number of child nodes.
- getChildNodeCount(long) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeState
-
Returns the number of iterable child nodes of this node.
- getChildNodeCount(long) - Method in class org.apache.jackrabbit.oak.spi.state.ReadOnlyBuilder
-
- getChildNodeEntries() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState
-
- getChildNodeEntries() - Method in class org.apache.jackrabbit.oak.plugins.memory.EmptyNodeState
-
- getChildNodeEntries() - Method in class org.apache.jackrabbit.oak.plugins.memory.ModifiedNodeState
-
- getChildNodeEntries() - Method in interface org.apache.jackrabbit.oak.spi.state.NodeState
-
Returns the iterable child node entries of this instance.
- getChildNodeNames() - Method in class org.apache.jackrabbit.oak.plugins.memory.EmptyNodeState
-
- getChildNodeNames() - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeBuilder
-
- getChildNodeNames() - Method in class org.apache.jackrabbit.oak.plugins.memory.ModifiedNodeState
-
- getChildNodeNames() - Method in class org.apache.jackrabbit.oak.spi.state.AbstractNodeState
-
- getChildNodeNames() - Method in interface org.apache.jackrabbit.oak.spi.state.NodeBuilder
-
Returns the names of current child nodes.
- getChildNodeNames() - Method in interface org.apache.jackrabbit.oak.spi.state.NodeState
-
Returns the names of all iterable child nodes.
- getChildNodeNames() - Method in class org.apache.jackrabbit.oak.spi.state.ReadOnlyBuilder
-
- 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 interface org.apache.jackrabbit.oak.api.Tree
-
All accessible children of this Tree
instance.
- 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 interface org.apache.jackrabbit.oak.api.Tree
-
Determine the number of children of this Tree
instance taking
access restrictions into account.
- getChildrenCount(long) - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractTree
-
- getChildSerializer() - Method in class org.apache.jackrabbit.oak.json.JsonSerializer
-
- getChildTracker(String) - Method in class org.apache.jackrabbit.oak.namepath.PathTracker
-
- getChildTracker(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.identifier.IdentifierTracker
-
- getClassName() - Method in interface org.apache.jackrabbit.oak.spi.commit.BackgroundObserverMBean
-
- 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
-
- getCloudContainer() - Method in class org.apache.jackrabbit.oak.plugins.blob.cloud.CloudBlobStore
-
- getCloudProvider() - Method in class org.apache.jackrabbit.oak.plugins.blob.cloud.CloudBlobStore
-
- 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.
- getCode() - Method in exception org.apache.jackrabbit.oak.api.CommitFailedException
-
Returns the type-specific error code of this exception.
- getCode() - Method in class org.apache.jackrabbit.oak.management.ManagementOperation.Status
-
- 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 interface org.apache.jackrabbit.oak.api.Result
-
Get the list of column names.
- 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 interface org.apache.jackrabbit.oak.api.Result
-
Get the distinct selector names of all columns.
- 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.
- getCommitRevision(Revision) - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
-
Returns the commit revision for the change with the given revision.
- 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
.
- 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
-
- 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.
- getConsecutiveFailedExecutions() - Method in interface org.apache.jackrabbit.oak.api.jmx.IndexStatsMBean
-
- getConsistencyCheckStatus() - Method in class org.apache.jackrabbit.oak.plugins.blob.BlobGC
-
- getConsistencyCheckStatus() - Method in interface org.apache.jackrabbit.oak.plugins.blob.BlobGCMBean
-
Consistency check status
- getConsolidatedExecutionStats() - Method in interface org.apache.jackrabbit.oak.api.jmx.IndexStatsMBean
-
Returns the consolidated execution stats since last reset
- 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
-
- getContentIdentity() - Method in interface org.apache.jackrabbit.oak.api.Blob
-
A unique identifier of the content of this value.
- getContentIdentity() - Method in class org.apache.jackrabbit.oak.plugins.blob.BlobStoreBlob
-
- getContentIdentity() - Method in class org.apache.jackrabbit.oak.plugins.memory.AbstractBlob
-
- getContentIdentity() - Method in class org.apache.jackrabbit.oak.plugins.value.BinaryBasedBlob
-
- getContentIdentity() - Method in class org.apache.jackrabbit.oak.plugins.value.ValueImpl
-
- getContentRepository() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.callback.RepositoryCallback
-
- getContentSession() - Method in interface org.apache.jackrabbit.oak.api.Root
-
Get the ContentSession
from which this root was acquired
- 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
-
- getConverter() - Method in class org.apache.jackrabbit.oak.plugins.memory.BinaryPropertyState
-
- getConverter() - Method in class org.apache.jackrabbit.oak.plugins.memory.BooleanPropertyState
-
- getConverter() - Method in class org.apache.jackrabbit.oak.plugins.memory.DecimalPropertyState
-
- getConverter() - Method in class org.apache.jackrabbit.oak.plugins.memory.DoublePropertyState
-
- getConverter() - Method in class org.apache.jackrabbit.oak.plugins.memory.GenericPropertyState
-
- getConverter() - Method in class org.apache.jackrabbit.oak.plugins.memory.LongPropertyState
-
- getConverter(Blob) - Method in class org.apache.jackrabbit.oak.plugins.memory.MultiBinaryPropertyState
-
- getConverter(Boolean) - Method in class org.apache.jackrabbit.oak.plugins.memory.MultiBooleanPropertyState
-
- getConverter(BigDecimal) - Method in class org.apache.jackrabbit.oak.plugins.memory.MultiDecimalPropertyState
-
- getConverter(Double) - Method in class org.apache.jackrabbit.oak.plugins.memory.MultiDoublePropertyState
-
- getConverter(String) - Method in class org.apache.jackrabbit.oak.plugins.memory.MultiGenericPropertyState
-
- getConverter(Long) - Method in class org.apache.jackrabbit.oak.plugins.memory.MultiLongPropertyState
-
- getConverter(String) - Method in class org.apache.jackrabbit.oak.plugins.memory.MultiStringPropertyState
-
- getConverter() - Method in class org.apache.jackrabbit.oak.plugins.memory.StringPropertyState
-
- 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
-
- getCost(Filter, NodeState) - Method in interface org.apache.jackrabbit.oak.spi.query.QueryIndex
-
Estimate the worst-case cost to query with the given filter.
- getCostPerEntry() - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndexPlan
-
- getCostPerEntry() - Method in interface org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan
-
The cost to read one entry from the cursor.
- getCostPerExecution() - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndexPlan
-
- getCostPerExecution() - Method in interface org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan
-
The cost to execute the query once.
- getCount() - Method in class org.apache.jackrabbit.oak.query.facet.FacetResult.Facet
-
get the facet count
- getCount() - Method in interface org.apache.jackrabbit.oak.stats.Counting
-
Returns the current count.
- getCount() - Method in class org.apache.jackrabbit.oak.stats.NoopStats
-
- getCount() - Method in class org.apache.jackrabbit.oak.stats.SimpleStats
-
- getCounter() - Method in class org.apache.jackrabbit.oak.plugins.document.Revision
-
- getCounterStats(String, StatsOptions) - Method in class org.apache.jackrabbit.oak.plugins.metric.MetricStatisticsProvider
-
- getCounterStats(String, StatsOptions) - Method in class org.apache.jackrabbit.oak.stats.DefaultStatisticsProvider
-
- getCounterStats(String, StatsOptions) - Method in interface org.apache.jackrabbit.oak.stats.StatisticsProvider
-
- getCountSync(NodeState) - Static method in class org.apache.jackrabbit.oak.util.ApproximateCounter
-
Get the count estimation.
- getCreated() - Method in interface org.apache.jackrabbit.oak.plugins.document.CachedNodeDocument
-
- getCreated() - Method in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfoDocument
-
- getCreated() - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
-
- 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
-
- getCredentials() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.AbstractLoginModule
-
- getCredentials() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.callback.CredentialsCallback
-
- 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
-
- getDataStore() - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore
-
- getDataStoreGCStatus() - Method in interface org.apache.jackrabbit.oak.api.jmx.RepositoryManagementMBean
-
Data store garbage collection status
- getDataStoreGCStatus() - Method in class org.apache.jackrabbit.oak.management.RepositoryManager
-
- getDataTableCreationStatement(String) - Method in enum org.apache.jackrabbit.oak.plugins.document.rdb.RDBBlobStoreDB
-
- getDate() - Method in class org.apache.jackrabbit.oak.plugins.value.ValueImpl
-
- getDate() - Method in class org.apache.jackrabbit.oak.spi.commit.CommitInfo
-
- getDate() - Method in class org.apache.jackrabbit.oak.stats.Clock
-
- getDateIncreasing() - Method in class org.apache.jackrabbit.oak.stats.Clock
-
- getDateMonotonic() - Method in class org.apache.jackrabbit.oak.stats.Clock
-
- 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.
- getDecimal() - Method in class org.apache.jackrabbit.oak.plugins.value.ValueImpl
-
- 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.util.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.
- 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.query.QueryIndex.IndexPlan
-
The node state with the index definition.
- 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
-
- getDepthFromId(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
-
- getDescription() - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.AbstractDataStoreService
-
- getDescription() - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.FileDataStoreService
-
- getDescription() - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.S3DataStoreService
-
- getDescription() - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.SharedS3DataStoreService
-
- getDescription() - Method in enum org.apache.jackrabbit.oak.plugins.version.VersionExceptionCode
-
- getDescriptors() - Method in interface org.apache.jackrabbit.oak.api.ContentRepository
-
Returns the repository descriptors which contain all or a subset of the descriptors defined in
Repository
.
- getDescriptors() - Method in class org.apache.jackrabbit.oak.core.ContentRepositoryImpl
-
- getDestPath(String) - Method in class org.apache.jackrabbit.oak.spi.commit.MoveTracker
-
- 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.query.facet.FacetResult
-
- getDirection() - Method in enum org.apache.jackrabbit.oak.plugins.index.property.OrderedIndex.OrderDirection
-
- getDocChildrenCacheSize() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
-
- getDocChildrenCacheStats() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
-
- getDocumentCacheSize() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
-
- 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
-
- getDocumentStoreStatsCollector() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
-
- getDone() - Method in interface org.apache.jackrabbit.oak.api.jmx.IndexStatsMBean
-
- getDouble() - Method in class org.apache.jackrabbit.oak.plugins.value.ValueImpl
-
- getDownloadCount() - Method in class org.apache.jackrabbit.oak.plugins.blob.BlobStoreStats
-
- getDownloadCountHistory() - Method in class org.apache.jackrabbit.oak.plugins.blob.BlobStoreStats
-
- getDownloadRateHistory() - Method in class org.apache.jackrabbit.oak.plugins.blob.BlobStoreStats
-
- getDownloadSizeHistory() - Method in class org.apache.jackrabbit.oak.plugins.blob.BlobStoreStats
-
- getDownloadTotalSeconds() - Method in class org.apache.jackrabbit.oak.plugins.blob.BlobStoreStats
-
- getDownloadTotalSize() - Method in class org.apache.jackrabbit.oak.plugins.blob.BlobStoreStats
-
- getDroppedTables() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
-
- getEarliestRecord(List<DataRecord>) - Static method in class org.apache.jackrabbit.oak.plugins.blob.datastore.SharedDataStoreUtils
-
Gets the earliest record of the available reference records.
- 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.util.TreeUtil
-
Returns the effective node types of the given node.
- getElementCount() - Method in interface org.apache.jackrabbit.oak.api.jmx.CacheStatsMBean
-
Get the number of elements/objects in the cache.
- getElementCount() - Method in class org.apache.jackrabbit.oak.cache.CacheStats
-
- getEndTime() - Method in class org.apache.jackrabbit.oak.plugins.blob.GarbageCollectionRepoStats
-
- 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.spi.query.QueryIndex.IndexPlan
-
The estimated number of entries in the cursor that is returned by the query method,
when using this plan.
- 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.
- getEveryone() - Method in class org.apache.jackrabbit.oak.spi.security.principal.PrincipalManagerImpl
-
- getEvictionCount() - Method in interface org.apache.jackrabbit.oak.api.jmx.CacheStatsMBean
-
Returns the number of times an entry has been evicted.
- getEvictionCount() - Method in class org.apache.jackrabbit.oak.cache.CacheStats
-
- getExceptionCount() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCache
-
- getExcerpt(String, String, Query, boolean) - Static method in class org.apache.jackrabbit.oak.query.fulltext.SimpleExcerptProvider
-
- getExcerpt(PropertyValue) - Static method in class org.apache.jackrabbit.oak.query.fulltext.SimpleExcerptProvider
-
- 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
-
- getExecutionCount() - Method in interface org.apache.jackrabbit.oak.api.jmx.IndexStatsMBean
-
Returns the number of executions as a TimeSeries
.
- getExecutionPlan() - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
-
- getExecutionTime() - Method in interface org.apache.jackrabbit.oak.api.jmx.IndexStatsMBean
-
Returns the execution time as a TimeSeries
.
- 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
-
- getExternalEventCount() - Method in interface org.apache.jackrabbit.oak.spi.commit.BackgroundObserverMBean
-
- getExtractedText() - Method in class org.apache.jackrabbit.oak.plugins.index.fulltext.ExtractedText
-
- getExtractionResult() - Method in class org.apache.jackrabbit.oak.plugins.index.fulltext.ExtractedText
-
- getFacets(String) - Method in class org.apache.jackrabbit.oak.query.facet.FacetResult
-
- getFailingSince() - Method in interface org.apache.jackrabbit.oak.api.jmx.IndexStatsMBean
-
- 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.
- getFilter() - Method in interface org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan
-
The filter to use.
- 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
-
- getFulltextConditions() - Method in interface org.apache.jackrabbit.oak.spi.query.Filter
-
Deprecated.
- 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
-
- getFullTextConstraint() - Method in interface org.apache.jackrabbit.oak.spi.query.Filter
-
Get the fulltext search condition expression, if any.
- getFullTextSearchExpression() - Method in class org.apache.jackrabbit.oak.query.ast.FullTextSearchImpl
-
- getGarbage() - Method in class org.apache.jackrabbit.oak.plugins.blob.GarbageCollectorFileState
-
Gets the storing the garbage.
- getGcCandidates() - Method in class org.apache.jackrabbit.oak.plugins.blob.GarbageCollectorFileState
-
Gets the file storing the gc candidates.
- getGlobalMarkStats() - Method in class org.apache.jackrabbit.oak.plugins.blob.BlobGC
-
- getGlobalMarkStats() - Method in interface org.apache.jackrabbit.oak.plugins.blob.BlobGCMBean
-
Show details of the data Store garbage collection process.
- 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.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
-
- getHead() - Method in interface org.apache.jackrabbit.oak.spi.state.NodeStoreBranch
-
Returns the head state of this branch.
- 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
-
- getHistogram(String, StatsOptions) - Method in class org.apache.jackrabbit.oak.stats.DefaultStatisticsProvider
-
- getHistogram(String, StatsOptions) - Method in interface org.apache.jackrabbit.oak.stats.StatisticsProvider
-
- getHitCount() - Method in interface org.apache.jackrabbit.oak.api.jmx.CacheStatsMBean
-
Returns the number of times Cache
lookup methods have returned a cached value.
- getHitCount() - Method in class org.apache.jackrabbit.oak.cache.CacheStats
-
- getHitRate() - Method in interface org.apache.jackrabbit.oak.api.jmx.CacheStatsMBean
-
Returns the ratio of cache requests which were hits.
- getHitRate() - Method in class org.apache.jackrabbit.oak.cache.CacheStats
-
- getId() - Method in class org.apache.jackrabbit.oak.management.ManagementOperation
-
Each instance of a ManagementOperation
has an unique id
associated with it.
- getId() - Method in class org.apache.jackrabbit.oak.management.ManagementOperation.Status
-
- getId() - Method in class org.apache.jackrabbit.oak.plugins.blob.ReferencedBlob
-
- 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
-
- getId(NodeStore) - Static method in class org.apache.jackrabbit.oak.plugins.identifier.ClusterRepositoryInfo
-
Retrieves the {# CLUSTER_ID_PROP}
- 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
-
- getIdFromName(String) - Method in enum org.apache.jackrabbit.oak.plugins.blob.datastore.SharedDataStoreUtils.SharedStoreRecordType
-
- 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(Object) - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS
-
Get the value for the given key if the entry is cached.
- 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
-
- 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
-
- 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.spi.whiteboard.WhiteboardIndexEditorProvider
-
- getIndexedNodesCount() - Method in interface org.apache.jackrabbit.oak.api.jmx.IndexStatsMBean
-
Returns the number of indexed nodes as a TimeSeries
.
- 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
-
- getIndexName() - Method in interface org.apache.jackrabbit.oak.spi.query.QueryIndex
-
Get the unique index name.
- getIndexPlan() - Method in class org.apache.jackrabbit.oak.query.plan.SelectorExecutionPlan
-
- getIndexProvider() - Method in class org.apache.jackrabbit.oak.query.ExecutionContext
-
- getIndexStats() - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate
-
- getInfo() - Method in class org.apache.jackrabbit.oak.spi.commit.CommitInfo
-
Return the info map
- getInitializationStatement() - Method in enum org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStoreDB
-
Query for any required initialization of the DB.
- getInitStackTrace() - Method in interface org.apache.jackrabbit.oak.api.jmx.SessionMBean
-
- 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.blob.datastore.DataStoreBlobStore
-
- 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(Root, NamePathMapper) - Static method in class org.apache.jackrabbit.oak.plugins.nodetype.ReadOnlyNodeTypeManager
-
- 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
-
- 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
-
- getInstanceId() - Method in interface org.apache.jackrabbit.oak.spi.state.Clusterable
-
Will return a unique number per instance across the cluster.
- getInternalNodeNames() - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractTree
-
- getInternalNodeNames() - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.ImmutableTree
-
- 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
-
- getJournalReadCount() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentStoreStats
-
- getJournalReadCount() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStoreStatsMBean
-
- 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
.
- getKeys() - Method in interface org.apache.jackrabbit.oak.api.Descriptors
-
Returns a string array holding all descriptor keys available for this
implementation, both the standard descriptors defined by the string
constants in this interface and any implementation-specific descriptors.
- getKeys() - Method in class org.apache.jackrabbit.oak.util.AggregatingDescriptors
-
- getKeys() - Method in class org.apache.jackrabbit.oak.util.GenericDescriptors
-
Returns a string array holding all descriptor keys available for this
implementation, both the standard descriptors defined by the string
constants in this interface and any implementation-specific descriptors.
- 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
- getLastCheckTime() - Method in interface org.apache.jackrabbit.oak.plugins.document.CachedNodeDocument
-
- getLastCheckTime() - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
-
Returns the last time when this object was checked for consistency.
- getLastFailedSave() - Method in interface org.apache.jackrabbit.oak.api.jmx.SessionMBean
-
- getLastIndexedTime() - Method in interface org.apache.jackrabbit.oak.api.jmx.IndexStatsMBean
-
- getLastKnownRevisions() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreMBean
-
- getLastMod() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoBlob
-
- getLastProcessedPath() - Method in class org.apache.jackrabbit.oak.plugins.blob.migration.BlobMigrator
-
- getLastReadAccess() - Method in interface org.apache.jackrabbit.oak.api.jmx.SessionMBean
-
- getLastRefresh() - Method in interface org.apache.jackrabbit.oak.api.jmx.SessionMBean
-
- getLastRev() - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
-
- getLastRevRecoveryAgent() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
-
- getLastSave() - Method in interface org.apache.jackrabbit.oak.api.jmx.SessionMBean
-
- getLastWriteAccess() - Method in interface org.apache.jackrabbit.oak.api.jmx.SessionMBean
-
- getLastWrittenRootRev() - Method in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfoDocument
-
the root-revision of the last background write (of unsaved modifications)
- getLatestError() - Method in interface org.apache.jackrabbit.oak.api.jmx.IndexStatsMBean
-
- getLatestErrorTime() - Method in interface org.apache.jackrabbit.oak.api.jmx.IndexStatsMBean
-
- getLatestRoot() - Method in interface org.apache.jackrabbit.oak.api.ContentSession
-
The current head root as seen by this content session.
- 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.ClusterNodeInfoDocument
-
- getLeaseFailureHandler() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
-
- getLeaseTime() - Method in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfo
-
- getLeft() - Method in class org.apache.jackrabbit.oak.query.ast.JoinImpl
-
- getLeftPlan() - Method in class org.apache.jackrabbit.oak.query.plan.JoinExecutionPlan
-
- getLength() - Method in class org.apache.jackrabbit.oak.plugins.blob.GarbageCollectionRepoStats
-
- 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 interface org.apache.jackrabbit.oak.api.jmx.QueryEngineSettingsMBean
-
Get the limit on how many nodes a query may read at most into memory, for
"order by" and "distinct" queries.
- getLimitInMemory() - Method in class org.apache.jackrabbit.oak.query.QueryEngineSettings
-
Get the limit on how many nodes a query may read at most into memory, for
"order by" and "distinct" queries.
- getLimitReads() - Method in interface org.apache.jackrabbit.oak.api.jmx.QueryEngineSettingsMBean
-
Get the limit on how many nodes a query may read at most (raw read
operations, including skipped nodes).
- getLimitReads() - Method in class org.apache.jackrabbit.oak.query.QueryEngineSettings
-
Get the limit on how many nodes a query may read at most (raw read
operations, including skipped nodes).
- 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 interface org.apache.jackrabbit.oak.api.jmx.CacheStatsMBean
-
Returns the total number of times that Cache
lookup methods attempted to load new
values.
- getLoadCount() - Method in class org.apache.jackrabbit.oak.cache.CacheStats
-
- getLoadExceptionCount() - Method in interface org.apache.jackrabbit.oak.api.jmx.CacheStatsMBean
-
Returns the number of times Cache
lookup methods threw an exception while loading a
new value.
- getLoadExceptionCount() - Method in class org.apache.jackrabbit.oak.cache.CacheStats
-
- getLoadExceptionRate() - Method in interface org.apache.jackrabbit.oak.api.jmx.CacheStatsMBean
-
Returns the ratio of cache loading attempts which threw exceptions.
- getLoadExceptionRate() - Method in class org.apache.jackrabbit.oak.cache.CacheStats
-
- getLoadSuccessCount() - Method in interface org.apache.jackrabbit.oak.api.jmx.CacheStatsMBean
-
Returns the number of times Cache
lookup methods have successfully loaded a new value.
- getLoadSuccessCount() - Method in class org.apache.jackrabbit.oak.cache.CacheStats
-
- getLocalDiffCacheSize() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
-
- getLocalEventCount() - Method in interface org.apache.jackrabbit.oak.spi.commit.BackgroundObserverMBean
-
- getLockAcquisitionCount() - Method in class org.apache.jackrabbit.oak.plugins.document.locks.TreeNodeDocumentLocks
-
- 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
-
- getLoginTimeStamp() - Method in interface org.apache.jackrabbit.oak.api.jmx.SessionMBean
-
- getLong(String) - Method in class org.apache.jackrabbit.oak.plugins.memory.EmptyNodeState
-
- getLong() - Method in class org.apache.jackrabbit.oak.plugins.value.ValueImpl
-
- getLong(NodeState, String) - Static method in class org.apache.jackrabbit.oak.spi.state.AbstractNodeState
-
- getLong(String) - Method in class org.apache.jackrabbit.oak.spi.state.AbstractNodeState
-
- getLong(String) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeState
-
Returns the long value of the named property.
- getLong(String, long) - Method in class org.apache.jackrabbit.oak.util.NodeUtil
-
- getLowerBound() - Method in class org.apache.jackrabbit.oak.query.fulltext.LikePattern
-
Get the lower bound if any.
- 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.
- getMarkedRefs() - Method in class org.apache.jackrabbit.oak.plugins.blob.GarbageCollectorFileState
-
Gets the file storing the marked references.
- 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.
- getMaxMemory() - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS
-
Get the maximum memory to use.
- getMaxQueueLength() - Method in class org.apache.jackrabbit.oak.spi.commit.BackgroundObserver
-
- getMaxQueueSize() - Method in interface org.apache.jackrabbit.oak.spi.commit.BackgroundObserverMBean
-
- getMaxReplicationLagMillis() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
-
- getMaxSize() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.PersistentCache
-
- getMaxTotalWeight() - Method in interface org.apache.jackrabbit.oak.api.jmx.CacheStatsMBean
-
The maximum weight of entries the cache may contain.
- getMaxTotalWeight() - Method in class org.apache.jackrabbit.oak.cache.CacheStats
-
- getMBean() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
-
- getMBean() - Method in class org.apache.jackrabbit.oak.spi.commit.BackgroundObserver
-
- getMembershipSizeThreshold() - Method in class org.apache.jackrabbit.oak.security.user.MembershipWriter
-
- getMemory(K) - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS
-
Get the memory used for the given key.
- getMemory() - Method in interface org.apache.jackrabbit.oak.cache.CacheValue
-
The estimated amount of memory used by this object, in bytes.
- 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
-
- getMessage() - Method in class org.apache.jackrabbit.oak.management.ManagementOperation.Status
-
- 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
-
- getMetadataRecord(String) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore
-
- getMetadataRecord(String) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.OakFileDataStore
-
- getMetadataRecord(String) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.SharedS3DataStore
-
- getMetadataRecord(String) - Method in interface org.apache.jackrabbit.oak.plugins.blob.SharedDataStore
-
Retrieves the metadata record with the given name
- 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
-
- getMeter(String, StatsOptions) - Method in class org.apache.jackrabbit.oak.stats.DefaultStatisticsProvider
-
- getMeter(RepositoryStatistics.Type) - Method in class org.apache.jackrabbit.oak.stats.StatisticManager
-
- getMeter(String, StatsOptions) - Method in interface org.apache.jackrabbit.oak.stats.StatisticsProvider
-
- 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
-
- getMinimumCost() - Method in interface org.apache.jackrabbit.oak.spi.query.QueryIndex
-
- getMinRecordLength() - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore
-
- 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
.
- getMissCount() - Method in interface org.apache.jackrabbit.oak.api.jmx.CacheStatsMBean
-
Returns the number of times Cache
lookup methods have returned an uncached (newly
loaded) value, or null.
- getMissCount() - Method in class org.apache.jackrabbit.oak.cache.CacheStats
-
- getMissRate() - Method in interface org.apache.jackrabbit.oak.api.jmx.CacheStatsMBean
-
Returns the ratio of cache requests which were misses.
- getMissRate() - Method in class org.apache.jackrabbit.oak.cache.CacheStats
-
- getMixinNodeTypes() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.ReadOnlyNodeTypeManager
-
- 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
-
- getMixinTypes() - Method in interface org.apache.jackrabbit.oak.spi.query.Filter
-
Returns the names of all matching mixin node types.
- getModCount() - Method in interface org.apache.jackrabbit.oak.plugins.document.CachedNodeDocument
-
- 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
- getName() - Method in interface org.apache.jackrabbit.oak.api.jmx.CacheStatsMBean
-
- getName() - Method in interface org.apache.jackrabbit.oak.api.PropertyState
-
- getName() - Method in interface org.apache.jackrabbit.oak.api.Tree
-
- getName() - Method in class org.apache.jackrabbit.oak.cache.CacheStats
-
- getName() - Method in class org.apache.jackrabbit.oak.management.ManagementOperation
-
Informal name
- getName() - Method in class org.apache.jackrabbit.oak.management.ManagementOperation.Status
-
- 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.UpdateOp.Key
-
- getName() - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate
-
- getName(String) - Method in class org.apache.jackrabbit.oak.plugins.memory.EmptyNodeState
-
- getName() - Method in class org.apache.jackrabbit.oak.plugins.memory.EmptyPropertyState
-
- getName() - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryChildNodeEntry
-
- getName() - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeBuilder
-
Accessor for name
- getName(String) - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeBuilder
-
- getName() - Method in class org.apache.jackrabbit.oak.plugins.memory.PropertyBuilder
-
- 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() - 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(NodeState, String) - Static method in class org.apache.jackrabbit.oak.spi.state.AbstractNodeState
-
- getName(String) - Method in class org.apache.jackrabbit.oak.spi.state.AbstractNodeState
-
- getName() - Method in interface org.apache.jackrabbit.oak.spi.state.ChildNodeEntry
-
The name of the child node state wrt.
- getName() - Method in enum org.apache.jackrabbit.oak.spi.state.ConflictType
-
- getName(String) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeBuilder
-
Returns the name value of the named property.
- getName(String) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeState
-
Returns the name value of the named property.
- getName(String) - Method in class org.apache.jackrabbit.oak.spi.state.ReadOnlyBuilder
-
- 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
-
- getName() - Method in class org.apache.jackrabbit.oak.util.NodeUtil
-
- getName(String, String) - Method in class org.apache.jackrabbit.oak.util.NodeUtil
-
- getName(Tree, String) - Static method in class org.apache.jackrabbit.oak.util.TreeUtil
-
- 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.
- getNameFromId(String) - Method in enum org.apache.jackrabbit.oak.plugins.blob.datastore.SharedDataStoreUtils.SharedStoreRecordType
-
- 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.memory.EmptyNodeState
-
- getNames(String) - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeBuilder
-
- getNames(long) - Static method in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
-
Returns names of the specified permissions.
- getNames(NodeState, String) - Static method in class org.apache.jackrabbit.oak.spi.state.AbstractNodeState
-
- getNames(String) - Method in class org.apache.jackrabbit.oak.spi.state.AbstractNodeState
-
- getNames(String) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeBuilder
-
Returns the name values of the named property.
- getNames(String) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeState
-
Returns the name values of the named property.
- getNames(String) - Method in class org.apache.jackrabbit.oak.spi.state.ReadOnlyBuilder
-
- getNames(Tree, String) - Static method in class org.apache.jackrabbit.oak.util.TreeUtil
-
- 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
-
- 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
-
- getNewStream() - Method in interface org.apache.jackrabbit.oak.api.Blob
-
Returns a new stream for this blob.
- getNewStream() - Method in class org.apache.jackrabbit.oak.plugins.blob.BlobStoreBlob
-
- getNewStream() - Method in class org.apache.jackrabbit.oak.plugins.memory.ArrayBasedBlob
-
- getNewStream() - Method in class org.apache.jackrabbit.oak.plugins.memory.StringBasedBlob
-
This implementation returns the bytes of the UTF-8 encoding
of the underlying string.
- getNewStream() - Method in class org.apache.jackrabbit.oak.plugins.value.BinaryBasedBlob
-
Delegates to
Binary.getStream()
and returns an input stream the always
throws an
IOException
if the underlying binary failed to produce one.
- getNode(NodeState, String) - Static method in class org.apache.jackrabbit.oak.spi.state.NodeStateUtils
-
Get a possibly non existing child node of a node.
- getNodeAggregator() - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndex
-
- getNodeAggregator() - Method in interface org.apache.jackrabbit.oak.spi.query.QueryIndex.FulltextQueryIndex
-
Returns the NodeAggregator responsible for providing the aggregation
settings or null if aggregation is not available/desired.
- getNodeAtRevision(DocumentNodeStore, RevisionVector, Revision) - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
-
- 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
-
- getNodeCacheSize() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
-
- getNodeCacheStats() - 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
-
- 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
-
- getNodeState() - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryChildNodeEntry
-
- getNodeState() - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeBuilder
-
- getNodeState() - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractTree
-
- getNodeState() - Method in interface org.apache.jackrabbit.oak.spi.state.ChildNodeEntry
-
The child node state
- getNodeState() - Method in interface org.apache.jackrabbit.oak.spi.state.NodeBuilder
-
Returns an immutable node state that matches the current state of
the builder.
- getNodeState() - Method in class org.apache.jackrabbit.oak.spi.state.ReadOnlyBuilder
-
- getNodeStore() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
-
- getNodeStore() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK
-
- getNodeStore() - Method in class org.apache.jackrabbit.oak.spi.state.ProxyNodeStore
-
- 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
-
- getNodeType() - Method in interface org.apache.jackrabbit.oak.spi.query.Filter
-
Returns the name of the filter node type.
- getNodeTypeManager() - Method in class org.apache.jackrabbit.oak.plugins.version.ReadOnlyVersionManager
-
- getNodeTypeName(AuthorizableType) - Static method in class org.apache.jackrabbit.oak.security.user.query.QueryUtil
-
Retrieve the node type name for the specified authorizable type.
- getNumLines() - Method in class org.apache.jackrabbit.oak.plugins.blob.GarbageCollectionRepoStats
-
- 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(String, NamePathMapper) - Static method in class org.apache.jackrabbit.oak.spi.query.PropertyValues
-
- 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
-
- getOakString() - Method in class org.apache.jackrabbit.oak.plugins.value.ValueImpl
-
Same as
ValueImpl.getString()
unless that names and paths are returned in their
Oak representation instead of being mapped to their JCR representation.
- getOakURIOrNull(String) - Method in class org.apache.jackrabbit.oak.namepath.GlobalNameMapper
-
- getObservationEventAverage() - Method in interface org.apache.jackrabbit.oak.api.jmx.RepositoryStatsMBean
-
- getObservationEventAverage() - Method in class org.apache.jackrabbit.oak.stats.RepositoryStats
-
- getObservationEventCount() - Method in interface org.apache.jackrabbit.oak.api.jmx.RepositoryStatsMBean
-
- getObservationEventCount() - Method in class org.apache.jackrabbit.oak.stats.RepositoryStats
-
- getObservationEventDuration() - Method in interface org.apache.jackrabbit.oak.api.jmx.RepositoryStatsMBean
-
- getObservationEventDuration() - Method in class org.apache.jackrabbit.oak.stats.RepositoryStats
-
- getObservationQueueMaxLength() - Method in interface org.apache.jackrabbit.oak.api.jmx.RepositoryStatsMBean
-
Maximum length of observation queue in the respective time period.
- getObservationQueueMaxLength() - Method in class org.apache.jackrabbit.oak.stats.RepositoryStats
-
- getOldDef() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeDefDiff.ChildNodeDefDiff
-
- getOldDef() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeDefDiff.PropDefDiff
-
- 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.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
-
- getOperator() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore.QueryCondition
-
- getOperator() - Method in class org.apache.jackrabbit.oak.query.ast.ComparisonImpl
-
- getOrAddChild(String, String) - Method in class org.apache.jackrabbit.oak.util.NodeUtil
-
- getOrAddTree(String, String) - Method in class org.apache.jackrabbit.oak.util.NodeUtil
-
TODO: clean up.
- getOrCreateOakIndex(NodeBuilder) - Static method in class org.apache.jackrabbit.oak.plugins.index.IndexUtils
-
- getOrCreateReferenceKey() - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.OakFileDataStore
-
- getOrder() - Method in class org.apache.jackrabbit.oak.spi.query.QueryIndex.OrderEntry
-
- 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 interface org.apache.jackrabbit.oak.api.Tree
-
- getParent() - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeBuilder
-
Accessor for parent builder
- 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.
- getParent() - Method in class org.apache.jackrabbit.oak.util.NodeUtil
-
- 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.
- 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
-
- getParents(NodeState, String) - Method in interface org.apache.jackrabbit.oak.plugins.index.aggregate.NodeAggregator
-
- getParents(NodeState, String) - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.SimpleNodeAggregator
-
- getPath() - Method in interface org.apache.jackrabbit.oak.api.ResultRow
-
The path, assuming there is only one selector.
- getPath(String) - Method in interface org.apache.jackrabbit.oak.api.ResultRow
-
The path for the given selector name.
- getPath() - Method in interface org.apache.jackrabbit.oak.api.Tree
-
- getPath() - Method in class org.apache.jackrabbit.oak.namepath.PathTracker
-
- getPath() - Method in class org.apache.jackrabbit.oak.plugins.blob.migration.DepthFirstNodeIterator
-
- getPath() - Method in interface org.apache.jackrabbit.oak.plugins.document.CachedNodeDocument
-
- getPath() - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
-
- 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.memory.MemoryNodeBuilder
-
- 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.commit.CommitInfo
-
Returns the base path of this commit.
- getPath() - Method in interface org.apache.jackrabbit.oak.spi.query.Filter
-
Get the path, or "/" if there is no path restriction set.
- getPath() - Method in interface org.apache.jackrabbit.oak.spi.query.IndexRow
-
The path of the node, if available.
- 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
-
- getPathPlan() - Method in interface org.apache.jackrabbit.oak.spi.query.Filter
-
Get the plan for the path.
- getPathPrefix() - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndexPlan
-
- getPathPrefix() - Method in interface org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan
-
The path prefix for this index plan.
- getPathRestriction() - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
-
- getPathRestriction() - Method in interface org.apache.jackrabbit.oak.spi.query.Filter
-
Get the path restriction type.
- 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.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
-
- getPattern(String, Tree) - Method in class org.apache.jackrabbit.oak.spi.whiteboard.WhiteboardRestrictionProvider
-
- getPattern(String, Set<Restriction>) - Method in class org.apache.jackrabbit.oak.spi.whiteboard.WhiteboardRestrictionProvider
-
- 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
-
- getPermissions(String, TreeLocation, boolean) - Static method in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
-
- 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
-
- getPersistentCache() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
-
- 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
-
- getPlan(Filter, NodeState) - Method in interface org.apache.jackrabbit.oak.spi.query.QueryIndex
-
Get the query plan for the given filter.
- getPlanDescription(QueryIndex.IndexPlan, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndex
-
- getPlanDescription(QueryIndex.IndexPlan, NodeState) - Method in interface org.apache.jackrabbit.oak.spi.query.QueryIndex.AdvancedQueryIndex
-
Get the query plan description (for logging purposes).
- getPlanName() - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndexPlan
-
- getPlanName() - Method in interface org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan
-
Get the unique plan name.
- getPlans(Filter, List<QueryIndex.OrderEntry>, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndex
-
- getPlans(Filter, List<QueryIndex.OrderEntry>, NodeState) - Method in interface org.apache.jackrabbit.oak.spi.query.QueryIndex.AdvancedQueryIndex
-
Return the possible index plans for the given filter and sort order.
- 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
-
- getPossiblyDeletedDocs(long) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoVersionGCSupport
-
- getPossiblyDeletedDocs(long) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBVersionGCSupport
-
- getPossiblyDeletedDocs(long) - Method in class org.apache.jackrabbit.oak.plugins.document.VersionGCSupport
-
- getPrecedence() - Method in class org.apache.jackrabbit.oak.query.fulltext.FullTextAnd
-
- getPrecedence() - Method in class org.apache.jackrabbit.oak.query.fulltext.FullTextContains
-
- getPrecedence() - Method in class org.apache.jackrabbit.oak.query.fulltext.FullTextExpression
-
Get the operator precedence.
- getPrecedence() - Method in class org.apache.jackrabbit.oak.query.fulltext.FullTextOr
-
- getPrecedence() - Method in class org.apache.jackrabbit.oak.query.fulltext.FullTextTerm
-
- 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
-
- getPrimaryTypeName(NodeState) - Static method in class org.apache.jackrabbit.oak.spi.state.NodeStateUtils
-
- getPrimaryTypeName() - Method in class org.apache.jackrabbit.oak.spi.xml.NodeInfo
-
Returns the name of the primary type of the node being imported.
- getPrimaryTypeName(Tree) - Static method in class org.apache.jackrabbit.oak.util.TreeUtil
-
- getPrimaryTypes() - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
-
- getPrimaryTypes() - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
-
- getPrimaryTypes() - Method in interface org.apache.jackrabbit.oak.spi.query.Filter
-
Returns the names of all matching primary node types.
- 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.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
-
- 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
-
- getPrincipalRoot(Tree, String) - Static method in class org.apache.jackrabbit.oak.security.authorization.permission.PermissionUtil
-
- getPrincipals() - Method in interface org.apache.jackrabbit.oak.api.AuthInfo
-
Returns the set of principals associated with this AuthInfo
instance.
- 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() - 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(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
Principal
s 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.
- getProcessedCheckpoint() - Method in interface org.apache.jackrabbit.oak.api.jmx.IndexStatsMBean
-
Returns the processed checkpoint used by the async indexer.
- getProcessedReferences() - Method in class org.apache.jackrabbit.oak.spi.xml.ReferenceChangeTracker
-
Returns an iterator over all processed reference properties.
- getProperties() - Method in interface org.apache.jackrabbit.oak.api.Tree
-
All accessible property states.
- getProperties() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState
-
- getProperties() - Method in class org.apache.jackrabbit.oak.plugins.memory.EmptyNodeState
-
- getProperties() - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeBuilder
-
- getProperties() - Method in class org.apache.jackrabbit.oak.plugins.memory.ModifiedNodeState
-
- getProperties() - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractTree
-
- getProperties() - Method in interface org.apache.jackrabbit.oak.spi.state.NodeBuilder
-
Returns the current properties.
- getProperties() - Method in interface org.apache.jackrabbit.oak.spi.state.NodeState
-
Returns an iterable of the properties of this node.
- getProperties() - Method in class org.apache.jackrabbit.oak.spi.state.ReadOnlyBuilder
-
- getProperty(String) - Method in interface org.apache.jackrabbit.oak.api.Tree
-
Get a property state
- getProperty(String) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeState
-
- getProperty(String) - Method in class org.apache.jackrabbit.oak.plugins.memory.EmptyNodeState
-
- getProperty(String) - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeBuilder
-
- getProperty(String) - Method in class org.apache.jackrabbit.oak.plugins.memory.ModifiedNodeState
-
- getProperty(String) - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractTree
-
- getProperty() - Method in class org.apache.jackrabbit.oak.plugins.tree.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
-
- getProperty(String) - Method in class org.apache.jackrabbit.oak.spi.state.AbstractNodeState
-
- getProperty(String) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeBuilder
-
Returns the current state of the named property, or null
if the property is not set.
- getProperty(String) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeState
-
Returns the named property, or null
if no such property exists.
- getProperty(String) - Method in class org.apache.jackrabbit.oak.spi.state.ReadOnlyBuilder
-
- getPropertyCount() - Method in interface org.apache.jackrabbit.oak.api.Tree
-
Determine the number of properties accessible to the current content session.
- getPropertyCount() - Method in class org.apache.jackrabbit.oak.plugins.memory.EmptyNodeState
-
- getPropertyCount() - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeBuilder
-
- getPropertyCount() - Method in class org.apache.jackrabbit.oak.plugins.memory.ModifiedNodeState
-
- getPropertyCount() - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractTree
-
- getPropertyCount() - Method in class org.apache.jackrabbit.oak.spi.state.AbstractNodeState
-
- getPropertyCount() - Method in interface org.apache.jackrabbit.oak.spi.state.NodeBuilder
-
Returns the current number of properties.
- getPropertyCount() - Method in interface org.apache.jackrabbit.oak.spi.state.NodeState
-
Returns the number of properties of this node.
- getPropertyCount() - Method in class org.apache.jackrabbit.oak.spi.state.ReadOnlyBuilder
-
- 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 interface org.apache.jackrabbit.oak.api.jmx.RepositoryManagementMBean
-
Asynchronous Property Index reindexing status
- 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
-
- getPropertyName() - Method in class org.apache.jackrabbit.oak.query.fulltext.FullTextContains
-
- getPropertyName() - Method in class org.apache.jackrabbit.oak.query.fulltext.FullTextTerm
-
- getPropertyName() - Method in class org.apache.jackrabbit.oak.spi.query.QueryIndex.OrderEntry
-
- getPropertyRestriction() - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndexPlan
-
- getPropertyRestriction(String) - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
-
- getPropertyRestriction(String) - Method in interface org.apache.jackrabbit.oak.spi.query.Filter
-
Get the most restrictive property restriction for the given property, if
any.
- getPropertyRestriction() - Method in interface org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan
-
The property restriction for this index plan or null
if
this index plan isn't base on a property restriction.
- getPropertyRestrictions() - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
-
- getPropertyRestrictions(String) - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
-
- getPropertyRestrictions() - Method in interface org.apache.jackrabbit.oak.spi.query.Filter
-
Get the list of property restrictions, if any.
- getPropertyRestrictions(String) - Method in interface org.apache.jackrabbit.oak.spi.query.Filter
-
Get the all property restriction for the given property.
- getPropertyState() - Method in class org.apache.jackrabbit.oak.plugins.memory.PropertyBuilder
-
- getPropertyStatus(String) - Method in interface org.apache.jackrabbit.oak.api.Tree
-
Get the Status
of a property state or null
.
- getPropertyStatus(String) - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractTree
-
- getPropertyType() - Method in class org.apache.jackrabbit.oak.spi.query.QueryIndex.OrderEntry
-
- getPropertyTypeFromName(String) - Static method in class org.apache.jackrabbit.oak.query.SQL2Parser
-
Get the property type from the given case insensitive name.
- getPropertyValue() - Method in class org.apache.jackrabbit.oak.query.ast.LengthImpl
-
- 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.
- getQuery() - Method in class org.apache.jackrabbit.oak.query.ast.SelectorImpl
-
- getQueryAverage() - Method in interface org.apache.jackrabbit.oak.api.jmx.RepositoryStatsMBean
-
- getQueryAverage() - Method in class org.apache.jackrabbit.oak.stats.RepositoryStats
-
- getQueryCount() - Method in interface org.apache.jackrabbit.oak.api.jmx.RepositoryStatsMBean
-
- getQueryCount() - Method in class org.apache.jackrabbit.oak.stats.RepositoryStats
-
- getQueryDuration() - Method in interface org.apache.jackrabbit.oak.api.jmx.RepositoryStatsMBean
-
- getQueryDuration() - Method in class org.apache.jackrabbit.oak.stats.RepositoryStats
-
- getQueryEngine() - Method in interface org.apache.jackrabbit.oak.api.Root
-
Get the query engine.
- getQueryEngine() - Method in class org.apache.jackrabbit.oak.core.ImmutableRoot
-
- getQueryEngineSettings() - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
-
- getQueryEngineSettings() - Method in interface org.apache.jackrabbit.oak.spi.query.Filter
-
- 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
-
- getQueryIndexes(NodeState) - Method in class org.apache.jackrabbit.oak.spi.query.CompositeQueryIndexProvider
-
- getQueryIndexes(NodeState) - Method in interface org.apache.jackrabbit.oak.spi.query.QueryIndexProvider
-
Get the currently configured indexes.
- getQueryIndexes(NodeState) - Method in class org.apache.jackrabbit.oak.spi.whiteboard.WhiteboardIndexProvider
-
- getQueryJournalHistory() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentStoreStats
-
- getQueryJournalHistory() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentStoreStatsMBean
-
- 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
-
- getQueryStatement() - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
-
- getQueryStatement() - Method in interface org.apache.jackrabbit.oak.spi.query.Filter
-
Get the complete query statement.
- getQueueSize() - Method in interface org.apache.jackrabbit.oak.spi.commit.BackgroundObserverMBean
-
- getRawText() - Method in class org.apache.jackrabbit.oak.query.fulltext.FullTextContains
-
- getReadCount() - Method in interface org.apache.jackrabbit.oak.api.jmx.SessionMBean
-
- getReadPreference() - Method in class org.apache.jackrabbit.oak.plugins.document.memory.MemoryDocumentStore
-
- getReadRate() - Method in interface org.apache.jackrabbit.oak.api.jmx.SessionMBean
-
- getRecord(DataIdentifier) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore
-
- getRecordFromReference(String) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore
-
- getRecordIfStored(DataIdentifier) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore
-
- getRecoveryCandidateNodes() - Method in class org.apache.jackrabbit.oak.plugins.document.LastRevRecoveryAgent
-
Gets the _lastRev recovery candidate cluster nodes.
- getReference() - Method in interface org.apache.jackrabbit.oak.api.Blob
-
Returns a secure reference to this blob, or null
if such
a reference is not available.
- getReference() - Method in class org.apache.jackrabbit.oak.plugins.blob.BlobStoreBlob
-
- getReference(String) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore
-
- getReference(String) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.BlobCache
-
- getReference() - Method in class org.apache.jackrabbit.oak.plugins.memory.AbstractBlob
-
- getReference() - Method in class org.apache.jackrabbit.oak.plugins.value.BinaryBasedBlob
-
- getReferenceCheckpoint() - Method in interface org.apache.jackrabbit.oak.api.jmx.IndexStatsMBean
-
Returns the current reference checkpoint used by the async indexer
- 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, 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.
- getRefreshCount() - Method in interface org.apache.jackrabbit.oak.api.jmx.SessionMBean
-
- getRefreshPending() - Method in interface org.apache.jackrabbit.oak.api.jmx.SessionMBean
-
- getRefreshRate() - Method in interface org.apache.jackrabbit.oak.api.jmx.SessionMBean
-
- getRefreshStrategy() - Method in interface org.apache.jackrabbit.oak.api.jmx.SessionMBean
-
- getRegistry() - Method in class org.apache.jackrabbit.oak.plugins.metric.MetricStatisticsProvider
-
- getReindexedDefinitions() - Method in class org.apache.jackrabbit.oak.plugins.index.IndexUpdate
-
- getReindexStats() - Method in class org.apache.jackrabbit.oak.plugins.index.IndexUpdate
-
- getRepositoryId() - Method in class org.apache.jackrabbit.oak.plugins.blob.GarbageCollectionRepoStats
-
- 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 Principal
s
associated with this provider instance.
- getRequestCount() - Method in interface org.apache.jackrabbit.oak.api.jmx.CacheStatsMBean
-
Returns the number of times Cache
lookup methods have returned either a cached or
uncached value.
- getRequestCount() - Method in class org.apache.jackrabbit.oak.cache.CacheStats
-
- 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
-
- 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 interface org.apache.jackrabbit.oak.api.jmx.FileStoreBackupRestoreMBean
-
Restore status
- getRestoreStatus() - Method in interface org.apache.jackrabbit.oak.api.jmx.RepositoryManagementMBean
-
Restore status
- 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 interface org.apache.jackrabbit.oak.api.jmx.RepositoryManagementMBean
-
Revision garbage collection status
- getRevisionGCStatus() - Method in class org.apache.jackrabbit.oak.management.RepositoryManager
-
- getRevisionGCStatus() - Method in class org.apache.jackrabbit.oak.spi.state.RevisionGC
-
- getRevisionGCStatus() - Method in interface org.apache.jackrabbit.oak.spi.state.RevisionGCMBean
-
Revision garbage collection status
- 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.document.DocumentNodeStore
-
- getRoot() - Method in class org.apache.jackrabbit.oak.plugins.document.MissingLastRevSeeker
-
- getRoot() - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeStore
-
- 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
-
- getRoot() - Method in interface org.apache.jackrabbit.oak.spi.state.NodeStore
-
Returns the latest state of the tree.
- getRoot() - Method in class org.apache.jackrabbit.oak.spi.state.ProxyNodeStore
-
- getRootDefinition() - Method in interface org.apache.jackrabbit.oak.plugins.nodetype.DefinitionProvider
-
- getRootDefinition() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.ReadOnlyNodeTypeManager
-
- getRootDiff(NodeState, NodeState, CommitInfo) - Method in class org.apache.jackrabbit.oak.spi.commit.DiffObserver
-
Returns the diff handler to be used for the given content change.
- 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
-
- getRootEditor(NodeState, NodeState, NodeBuilder, CommitInfo) - Method in class org.apache.jackrabbit.oak.plugins.version.VersionEditorProvider
-
- getRootEditor(NodeState, NodeState, NodeBuilder, CommitInfo) - Method in class org.apache.jackrabbit.oak.spi.commit.CompositeEditorProvider
-
- getRootEditor(NodeState, NodeState, NodeBuilder, CommitInfo) - Method in interface org.apache.jackrabbit.oak.spi.commit.EditorProvider
-
Returns an editor for processing changes between the given two states.
- getRootEditor(NodeState, NodeState, NodeBuilder, CommitInfo) - Method in class org.apache.jackrabbit.oak.spi.commit.ValidatorProvider
-
- getRootEditor(NodeState, NodeState, NodeBuilder, CommitInfo) - Method in class org.apache.jackrabbit.oak.spi.whiteboard.WhiteboardEditorProvider
-
- 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.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
-
- getRootValidator(NodeState, NodeState, CommitInfo) - Method in class org.apache.jackrabbit.oak.spi.commit.ValidatorProvider
-
Returns a validator for checking the changes between the given
two root states.
- getRows() - Method in interface org.apache.jackrabbit.oak.api.Result
-
Get the rows.
- 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.
- getSaveCount() - Method in interface org.apache.jackrabbit.oak.api.jmx.SessionMBean
-
- getSaveRate() - Method in interface org.apache.jackrabbit.oak.api.jmx.SessionMBean
-
- 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.
- getSecretKey() - Method in class org.apache.jackrabbit.oak.plugins.blob.cloud.CloudBlobStore
-
- 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) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
-
Returns an
Iterable
over all
NodeDocument
s in the given
store matching a condition on an
indexed property.
- 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
-
- getSelector() - Method in interface org.apache.jackrabbit.oak.spi.query.Filter
-
Get the selector associated with this filter.
- 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.api.Result
-
Get the list of selector names.
- 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
-
- getService(Whiteboard, Class<T>) - Static method in class org.apache.jackrabbit.oak.spi.whiteboard.WhiteboardUtils
-
Returns the one of the currently available services from the whiteboard of the tracked type.
- getService(Whiteboard, Class<T>, Predicate<T>) - Static method in class org.apache.jackrabbit.oak.spi.whiteboard.WhiteboardUtils
-
Returns the one of the currently available services from the whiteboard of the tracked type.
- getServices() - Method in class org.apache.jackrabbit.oak.spi.whiteboard.AbstractServiceTracker
-
Returns all services of type T
that are currently available.
- getServices() - Method in interface org.apache.jackrabbit.oak.spi.whiteboard.Tracker
-
Returns the currently available services of the tracked type.
- getServices(Whiteboard, Class<T>) - Static method in class org.apache.jackrabbit.oak.spi.whiteboard.WhiteboardUtils
-
Returns the currently available services from the whiteboard of the tracked type.
- getServices(Whiteboard, Class<T>, Predicate<T>) - Static method in class org.apache.jackrabbit.oak.spi.whiteboard.WhiteboardUtils
-
Returns the currently available services from the whiteboard of the tracked type.
- getSessionAttributes() - Method in interface org.apache.jackrabbit.oak.api.jmx.SessionMBean
-
- getSessionCount() - Method in interface org.apache.jackrabbit.oak.api.jmx.RepositoryStatsMBean
-
- getSessionCount() - Method in class org.apache.jackrabbit.oak.stats.RepositoryStats
-
- getSessionId() - Method in class org.apache.jackrabbit.oak.spi.commit.CommitInfo
-
- 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
-
- getSessionLogin() - Method in interface org.apache.jackrabbit.oak.api.jmx.RepositoryStatsMBean
-
- getSessionLogin() - Method in class org.apache.jackrabbit.oak.stats.RepositoryStats
-
- getSessionReadAverage() - Method in interface org.apache.jackrabbit.oak.api.jmx.RepositoryStatsMBean
-
- getSessionReadAverage() - Method in class org.apache.jackrabbit.oak.stats.RepositoryStats
-
- getSessionReadCount() - Method in interface org.apache.jackrabbit.oak.api.jmx.RepositoryStatsMBean
-
- getSessionReadCount() - Method in class org.apache.jackrabbit.oak.stats.RepositoryStats
-
- getSessionReadDuration() - Method in interface org.apache.jackrabbit.oak.api.jmx.RepositoryStatsMBean
-
- getSessionReadDuration() - Method in class org.apache.jackrabbit.oak.stats.RepositoryStats
-
- getSessionWriteAverage() - Method in interface org.apache.jackrabbit.oak.api.jmx.RepositoryStatsMBean
-
- getSessionWriteAverage() - Method in class org.apache.jackrabbit.oak.stats.RepositoryStats
-
- getSessionWriteCount() - Method in interface org.apache.jackrabbit.oak.api.jmx.RepositoryStatsMBean
-
- getSessionWriteCount() - Method in class org.apache.jackrabbit.oak.stats.RepositoryStats
-
- getSessionWriteDuration() - Method in interface org.apache.jackrabbit.oak.api.jmx.RepositoryStatsMBean
-
- getSessionWriteDuration() - Method in class org.apache.jackrabbit.oak.stats.RepositoryStats
-
- 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() - Method in interface org.apache.jackrabbit.oak.api.Result
-
Get the number of rows, if known.
- getSize(Result.SizePrecision, long) - Method in interface org.apache.jackrabbit.oak.api.Result
-
Get the number of rows, if known.
- 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
-
- getSize(Result.SizePrecision, long) - Method in interface org.apache.jackrabbit.oak.spi.query.Cursor
-
Get the size if known.
- getSize(Result.SizePrecision, long) - Method in class org.apache.jackrabbit.oak.spi.query.Cursors.AbstractCursor
-
- 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.
- getSortOrder() - Method in interface org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan
-
The sort order of the returned entries, or null if unsorted.
- getSource() - Method in exception org.apache.jackrabbit.oak.api.CommitFailedException
-
Returns the name of the source of this exception.
- getSource() - Method in class org.apache.jackrabbit.oak.query.QueryImpl
-
- getSourcePath(String) - Method in class org.apache.jackrabbit.oak.spi.commit.MoveTracker
-
- getSplitDocType() - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
-
Determines the type of split document
- getStart() - Method in interface org.apache.jackrabbit.oak.api.jmx.IndexStatsMBean
-
- getStartTime() - Method in class org.apache.jackrabbit.oak.plugins.blob.GarbageCollectionRepoStats
-
- 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.blob.datastore.AbstractDataStoreService
-
- getStats() - Method in interface org.apache.jackrabbit.oak.plugins.blob.BlobGarbageCollector
-
Retuns the list of stats
- getStats() - Method in class org.apache.jackrabbit.oak.plugins.blob.MarkSweepGarbageCollector
-
Returns the stats related to GC for all repos
- 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.metric.MetricStatisticsProvider
-
- getStats() - Method in class org.apache.jackrabbit.oak.stats.DefaultStatisticsProvider
-
- getStats() - Method in interface org.apache.jackrabbit.oak.stats.StatisticsProvider
-
- getStatsCounter(RepositoryStatistics.Type) - Method in class org.apache.jackrabbit.oak.stats.StatisticManager
-
- getStatus() - Method in interface org.apache.jackrabbit.oak.api.jmx.IndexStatsMBean
-
Returns the current status of the indexing job
- getStatus() - Method in interface org.apache.jackrabbit.oak.api.Tree
-
Get the Status
of this tree instance.
- getStatus() - Method in class org.apache.jackrabbit.oak.management.ManagementOperation
-
The
status
of this operation:
running
if the operation is currently
being executed.
succeeded
if the operation has terminated
without errors.
failed
if the operation has been cancelled,
its thread has been interrupted during execution or the operation has failed
with an exception.
- getStatus() - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.AbstractTree
-
- getStream() - Method in class org.apache.jackrabbit.oak.plugins.value.ValueImpl
-
- getString(String) - Method in class org.apache.jackrabbit.oak.plugins.memory.EmptyNodeState
-
- getString(String) - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeBuilder
-
- getString() - Method in class org.apache.jackrabbit.oak.plugins.value.ValueImpl
-
- 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(NodeState, String) - Static method in class org.apache.jackrabbit.oak.spi.state.AbstractNodeState
-
- getString(String) - Method in class org.apache.jackrabbit.oak.spi.state.AbstractNodeState
-
- getString(String) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeBuilder
-
Returns the name value of the named property.
- getString(String) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeState
-
Returns the string value of the named property.
- getString(String) - Method in class org.apache.jackrabbit.oak.spi.state.ReadOnlyBuilder
-
- getString() - Method in interface org.apache.jackrabbit.oak.spi.xml.TextValue
-
- getString(String, String) - Method in class org.apache.jackrabbit.oak.util.NodeUtil
-
- getString(Tree, String) - Static method in class org.apache.jackrabbit.oak.util.TreeUtil
-
- getStrings(String) - Method in class org.apache.jackrabbit.oak.plugins.memory.EmptyNodeState
-
- getStrings(NodeState, String) - Static method in class org.apache.jackrabbit.oak.spi.state.AbstractNodeState
-
- getStrings(String) - Method in class org.apache.jackrabbit.oak.spi.state.AbstractNodeState
-
- getStrings(String) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeState
-
Returns the string values of the named property.
- getStrings(Tree, String) - Static method in class org.apache.jackrabbit.oak.util.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.FilterConfigMBean
-
A set of paths whose subtrees include all events of this filter.
- 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 class org.apache.jackrabbit.oak.query.ast.SelectorImpl
-
- getSupertypes() - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
-
- getSupertypes() - Method in interface org.apache.jackrabbit.oak.spi.query.Filter
-
Returns the names of the filter node type and all its supertypes.
- 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 interface org.apache.jackrabbit.oak.api.QueryEngine
-
Get the set of supported query languages.
- 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.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.
- getSupportedRestrictions(String) - Method in class org.apache.jackrabbit.oak.spi.whiteboard.WhiteboardRestrictionProvider
-
- getTable(Collection<T>) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
-
- getTableCreationStatement(String) - 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
-
- getTargetType(PropertyDefinition) - Method in class org.apache.jackrabbit.oak.spi.xml.PropInfo
-
- getTemporaryCheckpoints() - Method in interface org.apache.jackrabbit.oak.api.jmx.IndexStatsMBean
-
Temporary checkpoints represent old checkpoints that have been processed
but the cleanup was not successful of did not happen at all (like in the
event the system was forcibly stopped).
- getText(String, Blob) - Method in class org.apache.jackrabbit.oak.plugins.blob.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
- getText() - Method in class org.apache.jackrabbit.oak.query.fulltext.FullTextTerm
-
- 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.stats.Clock.Fast
-
- getTime() - Method in class org.apache.jackrabbit.oak.stats.Clock
-
Returns the current time in milliseconds since the epoch.
- getTime() - Method in class org.apache.jackrabbit.oak.stats.Clock.Virtual
-
- getTimeIncreasing() - Method in class org.apache.jackrabbit.oak.stats.Clock
-
Returns a strictly increasing timestamp based on the current time.
- getTimeMonotonic() - Method in class org.apache.jackrabbit.oak.stats.Clock
-
Returns a monotonically increasing timestamp based on the current time.
- getTimer(String, StatsOptions) - Method in class org.apache.jackrabbit.oak.plugins.metric.MetricStatisticsProvider
-
- getTimer(String, StatsOptions) - Method in class org.apache.jackrabbit.oak.stats.DefaultStatisticsProvider
-
- getTimer(RepositoryStatistics.Type) - Method in class org.apache.jackrabbit.oak.stats.StatisticManager
-
- getTimer(String, StatsOptions) - Method in interface org.apache.jackrabbit.oak.stats.StatisticsProvider
-
- 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.
- 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
-
- getTokenProvider() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.callback.TokenProviderCallback
-
- 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
-
- getTotalLoadTime() - Method in interface org.apache.jackrabbit.oak.api.jmx.CacheStatsMBean
-
Returns the total number of nanoseconds the cache has spent loading new values.
- getTotalLoadTime() - Method in class org.apache.jackrabbit.oak.cache.CacheStats
-
- getTotalMigratedNodes() - Method in class org.apache.jackrabbit.oak.plugins.blob.migration.BlobMigrator
-
- getTree(String) - Method in interface org.apache.jackrabbit.oak.api.ResultRow
-
The tree for the given selector name.
- getTree(String) - Method in interface org.apache.jackrabbit.oak.api.Root
-
Retrieve the possible non existing Tree
at the given absolute path
.
- 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(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
-
- getTree() - Method in class org.apache.jackrabbit.oak.util.NodeUtil
-
- getTree(Tree, String) - Static method in class org.apache.jackrabbit.oak.util.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.
- 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 Principal
s 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 Principal
s associated
with this provider at the specified tree
.
- getType() - Method in exception org.apache.jackrabbit.oak.api.CommitFailedException
-
Return the name of the type of this exception.
- getType() - Method in interface org.apache.jackrabbit.oak.api.PropertyState
-
Determine the type of this property
- getType() - Method in interface org.apache.jackrabbit.oak.api.PropertyValue
-
Determine the type of this value
- getType() - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore
-
- getType() - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.OakFileDataStore
-
- getType() - Method in enum org.apache.jackrabbit.oak.plugins.blob.datastore.SharedDataStoreUtils.SharedStoreRecordType
-
- getType() - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.SharedS3DataStore
-
- getType() - Method in interface org.apache.jackrabbit.oak.plugins.blob.SharedDataStore
-
Gets the type.
- getType() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.BlobCache
-
- getType() - Method in class org.apache.jackrabbit.oak.plugins.memory.BinaryPropertyState
-
- getType() - Method in class org.apache.jackrabbit.oak.plugins.memory.BooleanPropertyState
-
- getType() - Method in class org.apache.jackrabbit.oak.plugins.memory.DecimalPropertyState
-
- getType() - Method in class org.apache.jackrabbit.oak.plugins.memory.DoublePropertyState
-
- getType() - Method in class org.apache.jackrabbit.oak.plugins.memory.GenericPropertyState
-
- getType() - Method in class org.apache.jackrabbit.oak.plugins.memory.LongPropertyState
-
- getType() - Method in class org.apache.jackrabbit.oak.plugins.memory.MultiBinaryPropertyState
-
- getType() - Method in class org.apache.jackrabbit.oak.plugins.memory.MultiBooleanPropertyState
-
- getType() - Method in class org.apache.jackrabbit.oak.plugins.memory.MultiDecimalPropertyState
-
- getType() - Method in class org.apache.jackrabbit.oak.plugins.memory.MultiDoublePropertyState
-
- getType() - Method in class org.apache.jackrabbit.oak.plugins.memory.MultiGenericPropertyState
-
- getType() - Method in class org.apache.jackrabbit.oak.plugins.memory.MultiLongPropertyState
-
- getType() - Method in class org.apache.jackrabbit.oak.plugins.memory.MultiStringPropertyState
-
- getType() - Method in class org.apache.jackrabbit.oak.plugins.memory.StringPropertyState
-
- 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() - Method in class org.apache.jackrabbit.oak.plugins.value.ValueImpl
-
- getType() - Method in class org.apache.jackrabbit.oak.spi.query.PropertyStateValue
-
- 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
-
- getUnchecked(K) - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS
-
Get the value, loading it if needed.
- getUnmergedBranchCount() - Method in interface org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreMBean
-
- 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
-
- getUpdates() - Method in interface org.apache.jackrabbit.oak.api.jmx.IndexStatsMBean
-
Returns the number of updates from the current run cycle.
- getUploadCount() - Method in class org.apache.jackrabbit.oak.plugins.blob.BlobStoreStats
-
- getUploadCountHistory() - Method in class org.apache.jackrabbit.oak.plugins.blob.BlobStoreStats
-
- getUploadRateHistory() - Method in class org.apache.jackrabbit.oak.plugins.blob.BlobStoreStats
-
- getUploadSizeHistory() - Method in class org.apache.jackrabbit.oak.plugins.blob.BlobStoreStats
-
- getUploadTotalSeconds() - Method in class org.apache.jackrabbit.oak.plugins.blob.BlobStoreStats
-
- getUploadTotalSize() - Method in class org.apache.jackrabbit.oak.plugins.blob.BlobStoreStats
-
- getUpperBound() - Method in class org.apache.jackrabbit.oak.query.fulltext.LikePattern
-
Get the upper bound if any.
- getURI(String) - Method in class org.apache.jackrabbit.oak.plugins.name.ReadOnlyNamespaceRegistry
-
- getURIs() - Method in class org.apache.jackrabbit.oak.plugins.name.ReadOnlyNamespaceRegistry
-
- getUsedMemory() - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS
-
Get the currently used memory.
- getUserID() - Method in interface org.apache.jackrabbit.oak.api.AuthInfo
-
Return the user ID to be exposed on the JCR Session object.
- getUserId() - Method in class org.apache.jackrabbit.oak.spi.commit.CommitInfo
-
- getUserID() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.AuthInfoImpl
-
- 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
- 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(String) - Method in interface org.apache.jackrabbit.oak.api.Descriptors
-
The value of a single-value descriptor is found by passing the key for
that descriptor to this method.
- getValue(Type<T>) - Method in interface org.apache.jackrabbit.oak.api.PropertyState
-
Value of this property.
- getValue(Type<T>, int) - Method in interface org.apache.jackrabbit.oak.api.PropertyState
-
Value at the given index
.
- getValue(Type<T>) - Method in interface org.apache.jackrabbit.oak.api.PropertyValue
-
Value of this object.
- getValue(Type<T>, int) - Method in interface org.apache.jackrabbit.oak.api.PropertyValue
-
Value at the given index
.
- getValue(String) - Method in interface org.apache.jackrabbit.oak.api.ResultRow
-
The property value.
- 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() - Method in class org.apache.jackrabbit.oak.plugins.memory.BinaryPropertyState
-
- getValue() - Method in class org.apache.jackrabbit.oak.plugins.memory.BooleanPropertyState
-
- getValue() - Method in class org.apache.jackrabbit.oak.plugins.memory.DecimalPropertyState
-
- getValue() - Method in class org.apache.jackrabbit.oak.plugins.memory.DoublePropertyState
-
- getValue(Type<T>) - Method in class org.apache.jackrabbit.oak.plugins.memory.EmptyPropertyState
-
- getValue(Type<T>, int) - Method in class org.apache.jackrabbit.oak.plugins.memory.EmptyPropertyState
-
- getValue() - Method in class org.apache.jackrabbit.oak.plugins.memory.GenericPropertyState
-
- getValue() - Method in class org.apache.jackrabbit.oak.plugins.memory.LongPropertyState
-
- getValue() - Method in class org.apache.jackrabbit.oak.plugins.memory.PropertyBuilder
-
- getValue(int) - Method in class org.apache.jackrabbit.oak.plugins.memory.PropertyBuilder
-
- getValue() - Method in class org.apache.jackrabbit.oak.plugins.memory.StringPropertyState
-
- 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(String) - Method in interface org.apache.jackrabbit.oak.spi.query.IndexRow
-
The value of the given property, if available.
- getValue(Type<T>) - Method in class org.apache.jackrabbit.oak.spi.query.PropertyStateValue
-
- getValue(Type<T>, int) - Method in class org.apache.jackrabbit.oak.spi.query.PropertyStateValue
-
- getValue(int) - Method in class org.apache.jackrabbit.oak.spi.xml.PropInfo
-
- getValue(int) - Method in interface org.apache.jackrabbit.oak.spi.xml.TextValue
-
- getValue(String) - Method in class org.apache.jackrabbit.oak.util.AggregatingDescriptors
-
- getValue(String) - Method in class org.apache.jackrabbit.oak.util.GenericDescriptors
-
The value of a single-value descriptor is found by passing the key for
that descriptor to this method.
- 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(String) - Method in interface org.apache.jackrabbit.oak.api.Descriptors
-
The value array of a multi-value descriptor is found by passing the key
for that descriptor to this method.
- getValues() - Method in interface org.apache.jackrabbit.oak.api.ResultRow
-
Get the list of values.
- getValues() - Method in class org.apache.jackrabbit.oak.plugins.memory.PropertyBuilder
-
- getValues() - Method in class org.apache.jackrabbit.oak.query.ResultRowImpl
-
- getValues(int) - Method in class org.apache.jackrabbit.oak.spi.xml.PropInfo
-
- getValues(String) - Method in class org.apache.jackrabbit.oak.util.AggregatingDescriptors
-
- getValues(String) - Method in class org.apache.jackrabbit.oak.util.GenericDescriptors
-
The value array of a multi-value descriptor is found by passing the key
for that descriptor to this method.
- getVersion(String) - Method in class org.apache.jackrabbit.oak.plugins.version.ReadOnlyVersionManager
-
Returns the version tree with the given uuid.
- getVersion() - Static method in class org.apache.jackrabbit.oak.util.OakVersion
-
Returns the version of oak-core.
- 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
-
- 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
-
- getWhiteboard() - Method in interface org.apache.jackrabbit.oak.spi.whiteboard.WhiteboardAware
-
Returns the whiteboard
- 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 interface org.apache.jackrabbit.oak.api.ContentSession
-
The name of the workspace this ContentSession
instance has
been created for.
- getWorkspaceName() - Method in class org.apache.jackrabbit.oak.spi.security.authentication.callback.RepositoryCallback
-
- getWorkspaceRoot() - Method in class org.apache.jackrabbit.oak.plugins.version.ReadOnlyVersionManager
-
/**
- getWriteConcern() - Method in class org.apache.jackrabbit.oak.plugins.document.memory.MemoryDocumentStore
-
- getWriteCount() - Method in interface org.apache.jackrabbit.oak.api.jmx.SessionMBean
-
- getWriteRate() - Method in interface org.apache.jackrabbit.oak.api.jmx.SessionMBean
-
- 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) - Constructor for class org.apache.jackrabbit.oak.plugins.observation.filter.GlobbingPathFilter
-
- 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
-
- 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
-
- id - Variable in class org.apache.jackrabbit.oak.management.ManagementOperation
-
- 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>, long) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoVersionGCSupport
-
- identifyGarbage(Set<NodeDocument.SplitDocType>, long) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBVersionGCSupport
-
- identifyGarbage(Set<NodeDocument.SplitDocType>, long) - Method in class org.apache.jackrabbit.oak.plugins.document.VersionGCSupport
-
- IDSIZE - Static variable in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBBlobStore
-
- 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 but otherwise ignored.
- IllegalRepositoryStateException - Exception in org.apache.jackrabbit.oak.api
-
This exception can be thrown by implementers of this API to signal an error
condition caused by an invalid state of the repository.
- IllegalRepositoryStateException() - Constructor for exception org.apache.jackrabbit.oak.api.IllegalRepositoryStateException
-
- IllegalRepositoryStateException(String) - Constructor for exception org.apache.jackrabbit.oak.api.IllegalRepositoryStateException
-
- IllegalRepositoryStateException(String, Throwable) - Constructor for exception org.apache.jackrabbit.oak.api.IllegalRepositoryStateException
-
- IllegalRepositoryStateException(Throwable) - Constructor for exception org.apache.jackrabbit.oak.api.IllegalRepositoryStateException
-
- 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
-
- 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.
- 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
-
- inc() - Method in interface org.apache.jackrabbit.oak.stats.CounterStats
-
Increment the counter by one.
- inc(long) - Method in interface org.apache.jackrabbit.oak.stats.CounterStats
-
Increment the counter by n
.
- inc() - Method in class org.apache.jackrabbit.oak.stats.NoopStats
-
- inc(long) - Method in class org.apache.jackrabbit.oak.stats.NoopStats
-
- inc() - Method in class org.apache.jackrabbit.oak.stats.SimpleStats
-
- inc(long) - Method in class org.apache.jackrabbit.oak.stats.SimpleStats
-
- 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.
- includesNodeData - Variable in class org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan.Builder
-
- includesNodeData() - Method in interface org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan
-
Whether the cursor is able to read all properties from a node.
- 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_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
-
- IndexConstants - Interface in org.apache.jackrabbit.oak.plugins.index
-
TODO document
- 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.
- IndexMBeanRegistration - Class in org.apache.jackrabbit.oak.plugins.index
-
- IndexMBeanRegistration(Whiteboard) - Constructor for class org.apache.jackrabbit.oak.plugins.index.IndexMBeanRegistration
-
- IndexRow - Interface in org.apache.jackrabbit.oak.spi.query
-
A row returned by the index.
- 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
-
- IndexStatsMBean - Interface in org.apache.jackrabbit.oak.api.jmx
-
- 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
- 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() - Method in interface org.apache.jackrabbit.oak.plugins.index.IndexUpdateCallback
-
Invoked by the
IndexEditor
for every NodeState
indexed it.
- IndexUpdate.MissingIndexProviderStrategy - Class in org.apache.jackrabbit.oak.plugins.index
-
- IndexUpdate.MissingIndexProviderStrategy() - Constructor for class org.apache.jackrabbit.oak.plugins.index.IndexUpdate.MissingIndexProviderStrategy
-
- IndexUpdateCallback - Interface in org.apache.jackrabbit.oak.plugins.index
-
- IndexUpdateProvider - Class in org.apache.jackrabbit.oak.plugins.index
-
- IndexUpdateProvider(IndexEditorProvider) - Constructor for class org.apache.jackrabbit.oak.plugins.index.IndexUpdateProvider
-
- IndexUpdateProvider(IndexEditorProvider, String) - Constructor for class org.apache.jackrabbit.oak.plugins.index.IndexUpdateProvider
-
- IndexUtils - Class in org.apache.jackrabbit.oak.plugins.index
-
TODO document
- IndexUtils() - Constructor for class org.apache.jackrabbit.oak.plugins.index.IndexUtils
-
- info(String, Object...) - Method in class org.apache.jackrabbit.oak.spi.gc.DelegatingGCMonitor
-
- info(String, Object[]) - Method in class org.apache.jackrabbit.oak.spi.gc.GCMonitor.Empty
-
- info(String, Object...) - Method in interface org.apache.jackrabbit.oak.spi.gc.GCMonitor
-
Informal notification on the progress of garbage collection.
- info(String, Object...) - Method in class org.apache.jackrabbit.oak.spi.gc.GCMonitorTracker
-
- 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() - Method in class org.apache.jackrabbit.oak.plugins.blob.cloud.CloudBlobStore
-
Instantiates a connection to the cloud blob store.
- init(String) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore
-
- 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.plugins.nodetype.write.InitialContent
-
- InitialContent - Class in org.apache.jackrabbit.oak.plugins.nodetype.write
-
InitialContent
implements a
RepositoryInitializer
and
registers built-in node types when the micro kernel becomes available.
- InitialContent() - Constructor for class org.apache.jackrabbit.oak.plugins.nodetype.write.InitialContent
-
- initialize(NodeBuilder) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.write.InitialContent
-
- initialize(NodeBuilder) - Method in class org.apache.jackrabbit.oak.spi.lifecycle.CompositeInitializer
-
- initialize(NodeBuilder, String) - Method in class org.apache.jackrabbit.oak.spi.lifecycle.CompositeWorkspaceInitializer
-
- initialize(NodeStore, RepositoryInitializer, IndexEditorProvider) - Static method in class org.apache.jackrabbit.oak.spi.lifecycle.OakInitializer
-
- initialize(Iterable<WorkspaceInitializer>, NodeStore, String, IndexEditorProvider) - Static method in class org.apache.jackrabbit.oak.spi.lifecycle.OakInitializer
-
- initialize(NodeBuilder) - Method in interface org.apache.jackrabbit.oak.spi.lifecycle.RepositoryInitializer
-
Initializes repository content.
- initialize(NodeBuilder, String) - Method in interface org.apache.jackrabbit.oak.spi.lifecycle.WorkspaceInitializer
-
Initialize the content of a new workspace.
- 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
-
- initiated(String) - Static method in class org.apache.jackrabbit.oak.management.ManagementOperation.Status
-
- 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.commit.DefaultEditor
-
- INSTANCE - Static variable in class org.apache.jackrabbit.oak.spi.commit.DefaultValidator
-
- INSTANCE - Static variable in class org.apache.jackrabbit.oak.spi.commit.EmptyHook
-
Static instance of this class, useful as a "null object".
- INSTANCE - Static variable in class org.apache.jackrabbit.oak.spi.commit.EmptyObserver
-
Static instance of this class, useful as a "null object".
- 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.SystemPrincipal
-
- INSTANCE - Static variable in class org.apache.jackrabbit.oak.stats.NoopStats
-
- INTEGRITY - Static variable in exception org.apache.jackrabbit.oak.api.CommitFailedException
-
Type name for referential integrity violation errors.
- INTERNAL_SQL2_QUERY - Static variable in interface org.apache.jackrabbit.oak.api.QueryEngine
-
The suffix for internal SQL-2 statements.
- invalidate(Object) - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS
-
Remove an entry.
- invalidate(String) - Method in class org.apache.jackrabbit.oak.plugins.document.cache.NodeDocumentCache
-
Invalidate document with given key.
- invalidateAll() - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS
-
Remove all entries.
- invalidateAll(Iterable<?>) - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS
-
- 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
-
- invalidateOutdated(Map<String, Long>) - Method in class org.apache.jackrabbit.oak.plugins.document.cache.NodeDocumentCache
-
Invalidate document with given keys iff their mod counts 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.
- isAccessControlViolation() - Method in exception org.apache.jackrabbit.oak.api.CommitFailedException
-
Checks whether this is an access control violation exception.
- isAccessible(String) - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
-
- isAccessible(String) - Method in interface org.apache.jackrabbit.oak.spi.query.Filter
-
check whether a certain (valid) path is accessible (can be read) from the user associated with the query Session
- isAccessViolation() - Method in exception org.apache.jackrabbit.oak.api.CommitFailedException
-
Checks whether this is an access violation exception.
- 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
-
- isAllow() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.ACE
-
- isAlwaysFalse() - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
-
- isAlwaysFalse() - Method in interface org.apache.jackrabbit.oak.spi.query.Filter
-
If the filter condition can not possibly match any row, due to a
contradiction in the query (for example "x=1 and x=2").
- isArray() - Method in interface org.apache.jackrabbit.oak.api.PropertyState
-
Determine whether the value is an array of atoms
- isArray() - Method in interface org.apache.jackrabbit.oak.api.PropertyValue
-
Determine whether the value is an array of atoms
- isArray() - Method in class org.apache.jackrabbit.oak.api.Type
-
Determine whether this is an array type
- isArray() - Method in class org.apache.jackrabbit.oak.plugins.memory.EmptyPropertyState
-
- isArray() - Method in class org.apache.jackrabbit.oak.plugins.memory.PropertyBuilder
-
- isArray() - Method in class org.apache.jackrabbit.oak.spi.query.PropertyStateValue
-
- 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
- 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
-
- isBranch() - Method in class org.apache.jackrabbit.oak.plugins.document.Revision
-
- isBranch() - Method in class org.apache.jackrabbit.oak.plugins.document.RevisionVector
-
- 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(Revision) - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
-
Returns true
if the given revision
is marked
committed.
- 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.
- isConstraintViolation() - Method in exception org.apache.jackrabbit.oak.api.CommitFailedException
-
Checks whether this is a constraint violation exception.
- isDebugEnabled() - Method in class org.apache.jackrabbit.oak.util.PerfLogger
-
Whether or not the delegate has log level DEBUG configured
- isDelayed() - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndexPlan
-
Whether any base plan is delayed.
- isDelayed - Variable in class org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan.Builder
-
- isDelayed() - Method in interface org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan
-
Whether the index is not always up-to-date.
- 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.cache.CacheLIRS
-
- isEmpty() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.MultiGenerationMap
-
- isEmpty() - Method in class org.apache.jackrabbit.oak.plugins.memory.PropertyBuilder
-
- isEmpty() - Method in class org.apache.jackrabbit.oak.spi.commit.MoveTracker
-
- 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.
- isEmpty() - Method in class org.apache.jackrabbit.oak.util.BlobByteSource
-
- isEmptyState(NodeState) - Static method in class org.apache.jackrabbit.oak.plugins.memory.EmptyNodeState
-
- isEnabled() - Method in class org.apache.jackrabbit.oak.stats.StopwatchLogger
-
- 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 interface org.apache.jackrabbit.oak.api.jmx.IndexStatsMBean
-
- isFailing() - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate
-
- isFailure() - Method in class org.apache.jackrabbit.oak.management.ManagementOperation.Status
-
- isFinished() - Method in class org.apache.jackrabbit.oak.plugins.index.AsyncIndexUpdate
-
- isFullTextCharacter(char) - Static method in class org.apache.jackrabbit.oak.query.fulltext.FullTextTerm
-
Whether or not the given character is part of a full-text term that
should be indexed.
- isFulltextIndex() - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndexPlan
-
Whether any base plan is a full text index.
- isFulltextIndex - Variable in class org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan.Builder
-
- isFulltextIndex() - Method in interface org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan
-
Whether the fulltext part of the filter is evaluated (possibly with
an extended syntax).
- 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 Principal
s
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 Principal
s
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 Principal
s 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.
- 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
-
- isHidden(String) - Static method in class org.apache.jackrabbit.oak.spi.state.NodeStateUtils
-
Check whether the node or property with the given name is hidden, that
is, if the node name starts with a ":".
- 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
-
- isHiddenPath(String) - Static method in class org.apache.jackrabbit.oak.spi.state.NodeStateUtils
-
Check whether the given path contains a hidden node.
- 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.UnionQueryImpl
-
- 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
- isLike - Variable in class org.apache.jackrabbit.oak.spi.query.Filter.PropertyRestriction
-
Whether this is a like constraint.
- isLocal() - Method in class org.apache.jackrabbit.oak.plugins.blob.GarbageCollectionRepoStats
-
- 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
-
- 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
-
- isMarkEnabled() - Method in class org.apache.jackrabbit.oak.plugins.blob.cloud.CloudBlobStore
-
- isMarkEnabled() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoBlobStore
-
- isMarkEnabled() - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBBlobStore
-
- 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
-
- isMetricsEnabled() - Method in class org.apache.jackrabbit.oak.stats.StatsOptions
-
- isModified() - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeBuilder
-
- isModified() - Method in class org.apache.jackrabbit.oak.plugins.nodetype.NodeTypeDefDiff
-
- isModified() - Method in interface org.apache.jackrabbit.oak.spi.state.NodeBuilder
-
Check whether this builder represents a modified node, which has either modified properties
or removed or added child nodes.
- isModified() - Method in class org.apache.jackrabbit.oak.spi.state.ReadOnlyBuilder
-
- isNew() - Method in class org.apache.jackrabbit.oak.plugins.document.UpdateOp
-
- isNew() - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeBuilder
-
- isNew(String) - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeBuilder
-
- isNew() - Method in interface org.apache.jackrabbit.oak.spi.state.NodeBuilder
-
Check whether this builder represents a new node, which is not present in the base state.
- isNew(String) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeBuilder
-
Check whether the named property is new, i.e.
- isNew() - Method in class org.apache.jackrabbit.oak.spi.state.ReadOnlyBuilder
-
- isNew(String) - Method in class org.apache.jackrabbit.oak.spi.state.ReadOnlyBuilder
-
- 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.util.TreeUtil
-
- isNot() - Method in class org.apache.jackrabbit.oak.query.fulltext.FullTextContains
-
- isNot() - Method in class org.apache.jackrabbit.oak.query.fulltext.FullTextExpression
-
- isNot() - Method in class org.apache.jackrabbit.oak.query.fulltext.FullTextTerm
-
- isNotNullRestriction() - Method in class org.apache.jackrabbit.oak.spi.query.Filter.PropertyRestriction
-
- isNullRestriction() - Method in class org.apache.jackrabbit.oak.spi.query.Filter.PropertyRestriction
-
- isOfType(String) - Method in exception org.apache.jackrabbit.oak.api.CommitFailedException
-
Checks whether this exception is of the given type.
- isolationLevelToString(int) - Static method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBJDBCTools
-
Return string representation of transaction isolation level.
- isOnlyMetricEnabled() - Method in class org.apache.jackrabbit.oak.stats.StatsOptions
-
- isOnlyTimeSeriesEnabled() - Method in class org.apache.jackrabbit.oak.stats.StatsOptions
-
- 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
-
- isPartialObject() - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.RevisionEntry
-
- isPaused() - Method in interface org.apache.jackrabbit.oak.api.jmx.IndexStatsMBean
-
Returns the value of the 'paused' flag
- 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.
- 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.blob.datastore.DataStoreTextWriter
-
- isProcessed(String) - Method in interface org.apache.jackrabbit.oak.plugins.blob.datastore.TextWriter
-
- isPropertyName(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
-
- isReadOnlyTree(Tree) - Static method in class org.apache.jackrabbit.oak.util.TreeUtil
-
- 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(long) - Method in class org.apache.jackrabbit.oak.plugins.document.MissingLastRevSeeker
-
- isRecoveryNeeded(long) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoMissingLastRevSeeker
-
- isReindexingPerformed() - Method in class org.apache.jackrabbit.oak.plugins.index.IndexUpdate
-
- isReplaced() - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeBuilder
-
- isReplaced(String) - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeBuilder
-
- isReplaced() - Method in interface org.apache.jackrabbit.oak.spi.state.NodeBuilder
-
Check whether this builder represents a node that used to exist but
was then replaced with other content, for example as a result of
a
NodeBuilder.setChildNode(String)
call.
- isReplaced(String) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeBuilder
-
- isReplaced() - Method in class org.apache.jackrabbit.oak.spi.state.ReadOnlyBuilder
-
- isReplaced(String) - Method in class org.apache.jackrabbit.oak.spi.state.ReadOnlyBuilder
-
- 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 interface org.apache.jackrabbit.oak.api.Tree
-
- isRoot() - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeBuilder
-
- 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
-
- 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
- isShared(BlobStore) - Static method in class org.apache.jackrabbit.oak.plugins.blob.datastore.SharedDataStoreUtils
-
Checks if the blob store shared.
- isSingleValueDescriptor(String) - Method in interface org.apache.jackrabbit.oak.api.Descriptors
-
Returns true
if key
is a valid single-value
descriptor; otherwise returns false
- isSingleValueDescriptor(String) - Method in class org.apache.jackrabbit.oak.util.AggregatingDescriptors
-
- isSingleValueDescriptor(String) - Method in class org.apache.jackrabbit.oak.util.GenericDescriptors
-
Returns true
if key
is a valid single-value
descriptor; otherwise returns false
- 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
-
- isStandardDescriptor(String) - Method in interface org.apache.jackrabbit.oak.api.Descriptors
-
Returns true
if key
is a standard descriptor
defined by the string constants in this interface and false
if it is either a valid implementation-specific key or not a valid key.
- isStandardDescriptor(String) - Method in class org.apache.jackrabbit.oak.util.AggregatingDescriptors
-
- isStandardDescriptor(String) - Method in class org.apache.jackrabbit.oak.util.GenericDescriptors
-
Returns true
if key
is a standard descriptor
defined by the string constants in this interface and false
if it is either a valid implementation-specific key or not a valid key.
- isStarted() - Method in class org.apache.jackrabbit.oak.stats.StopwatchLogger
-
- isSuccess() - Method in class org.apache.jackrabbit.oak.management.ManagementOperation.Status
-
- isSystemUser(Tree) - Static method in class org.apache.jackrabbit.oak.spi.security.user.util.UserUtil
-
- isTimedOut(long) - Static method in class org.apache.jackrabbit.oak.plugins.atomic.AtomicCounterEditor.ConsolidatorTask
-
- isTimeSeriesEnabled() - Method in class org.apache.jackrabbit.oak.stats.StatsOptions
-
- isTraceEnabled() - Method in class org.apache.jackrabbit.oak.util.PerfLogger
-
Whether or not the delegate has log level TRACE configured
- 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
.
- isUpToDate(long) - Method in interface org.apache.jackrabbit.oak.plugins.document.CachedNodeDocument
-
- isUpToDate(long) - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
-
Returns true if the document has already been checked for consistency
in current cycle.
- isUseSimpleRevision() - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
-
- isValidLocalName(String) - Static method in class org.apache.jackrabbit.oak.plugins.name.Namespaces
-
- isValidName(String) - Static method in class org.apache.jackrabbit.oak.spi.state.AbstractNodeState
-
- 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
-
- isVirtualRow() - Method in class org.apache.jackrabbit.oak.query.index.IndexRowImpl
-
- isVirtualRow() - Method in interface org.apache.jackrabbit.oak.spi.query.IndexRow
-
Marks if the row is virtual and behavior of getPath
is undefined.
- ITEM_CODE - Static variable in class org.apache.jackrabbit.oak.management.ManagementOperation.Status
-
- ITEM_ID - Static variable in class org.apache.jackrabbit.oak.management.ManagementOperation.Status
-
- ITEM_MESSAGE - Static variable in class org.apache.jackrabbit.oak.management.ManagementOperation.Status
-
- ITEM_NAMES - Static variable in class org.apache.jackrabbit.oak.management.ManagementOperation.Status
-
- ITEM_TYPES - Static variable in class org.apache.jackrabbit.oak.management.ManagementOperation.Status
-
- 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
-
- iterable(Iterable<E>) - Static method in class org.apache.jackrabbit.oak.plugins.memory.MemoryChildNodeEntry
-
- iterateNodeTree(GarbageCollectorFileState) - Method in class org.apache.jackrabbit.oak.plugins.blob.MarkSweepGarbageCollector
-
Iterates the complete node tree and collect all blob references
- iterator() - Method in class org.apache.jackrabbit.oak.plugins.document.RevisionVector
-
- iterator() - Method in class org.apache.jackrabbit.oak.plugins.document.util.CloseableIterable
-
- 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
-
- 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_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_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) - Static method in class org.apache.jackrabbit.oak.query.fulltext.FullTextParser
-
- 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
-
- parseDel(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBExport
-
- PartialConflictHandler - Interface in org.apache.jackrabbit.oak.spi.commit
-
A
PartialConflictHandler
is responsible for handling conflicts which happen
on
Root.rebase()
and on the implicit rebase operation which
takes part on
Root.commit()
.
- PartialConflictHandler.Resolution - Enum in org.apache.jackrabbit.oak.spi.commit
-
Resolutions for conflicts
- 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.api.Type
-
- PATH - Static variable in class org.apache.jackrabbit.oak.plugins.blob.datastore.FileDataStoreService
-
- 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
-
- pathDepth(String) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
-
- 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.
- pathPrefix - Variable in class org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan.Builder
-
- pathProperty(String, String) - Static method in class org.apache.jackrabbit.oak.plugins.memory.GenericPropertyState
-
Create a PropertyState
from a path.
- pathProperty(String, Iterable<String>) - Static method in class org.apache.jackrabbit.oak.plugins.memory.MultiGenericPropertyState
-
Create a multi valued PropertyState
from a list of paths.
- 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
-
- PATHS - Static variable in class org.apache.jackrabbit.oak.api.Type
-
- pathToId(Iterable<String>) - Static method in class org.apache.jackrabbit.oak.plugins.document.util.Utils
-
- 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
-
- pause() - Method in interface org.apache.jackrabbit.oak.api.jmx.IndexStatsMBean
-
Pauses the background indexing process.
- peek(K) - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS
-
Get the value for the given key if the entry is cached.
- PERF_LOG_THRESHOLD - Static variable in class org.apache.jackrabbit.oak.plugins.document.DocumentStoreStats
-
- PerfLogger - Class in org.apache.jackrabbit.oak.util
-
PerfLogger is a simpler wrapper around a slf4j Logger which
comes with the capability to issue log statements containing
the measurement between start() and end() methods.
- PerfLogger(Logger) - Constructor for class org.apache.jackrabbit.oak.util.PerfLogger
-
Create a new PerfLogger that shall use the given Logger object for logging
- performLeaseCheck() - Method in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfo
-
- 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) - 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
-
- 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
-
- Permutations<T> - Class in org.apache.jackrabbit.oak.query.plan
-
A class to iterate over all permutations of an array.
- 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
-
- planName - Variable in class org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan.Builder
-
- 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.
- PostValidationHook - Interface in org.apache.jackrabbit.oak.spi.commit
-
Extension to the CommitHook
interface that indicates that this
commit hook implementation must be executed after the
validation hooks.
- 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
-
- PRECEDENCE_AND - Static variable in class org.apache.jackrabbit.oak.query.fulltext.FullTextExpression
-
The operator precedence for AND conditions.
- PRECEDENCE_OR - Static variable in class org.apache.jackrabbit.oak.query.fulltext.FullTextExpression
-
The operator precedence for OR conditions.
- PRECEDENCE_TERM - Static variable in class org.apache.jackrabbit.oak.query.fulltext.FullTextExpression
-
The operator precedence for terms.
- 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() - 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 Principal
s.
- 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
Principal
s.
- PrincipalProviderCallback - Class in org.apache.jackrabbit.oak.spi.security.authentication.callback
-
- 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
-
- 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.
- process(Editor, NodeState, NodeState) - Static method in class org.apache.jackrabbit.oak.spi.commit.EditorDiff
-
Validates and possibly edits the given subtree by diffing
and recursing through it.
- 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.security.authorization.permission.PermissionHook
-
- processCommit(NodeState, NodeState, CommitInfo) - Method in interface org.apache.jackrabbit.oak.spi.commit.CommitHook
-
Validates and/or modifies the given content change before it gets
persisted.
- processCommit(NodeState, NodeState, CommitInfo) - Method in class org.apache.jackrabbit.oak.spi.commit.CompositeHook
-
- processCommit(NodeState, NodeState, CommitInfo) - Method in class org.apache.jackrabbit.oak.spi.commit.EditorHook
-
- processCommit(NodeState, NodeState, CommitInfo) - Method in class org.apache.jackrabbit.oak.spi.commit.EmptyHook
-
- processedReference(Object) - Method in class org.apache.jackrabbit.oak.spi.xml.ReferenceChangeTracker
-
- 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.
- ProgressNotificationEditor - Class in org.apache.jackrabbit.oak.spi.commit
-
This Editor
instance logs invocations to the logger
passed to its constructor after each 10000 calls to it
enter()
method.
- PROP_BLOB_GC_MAX_AGE - Static variable in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreService
-
- PROP_CACHE_SIZE - Static variable in class org.apache.jackrabbit.oak.plugins.blob.datastore.AbstractDataStoreService
-
- PROP_COUNTER - Static variable in class org.apache.jackrabbit.oak.plugins.atomic.AtomicCounterEditor
-
property with the consolidated counter
- PROP_DS_TYPE - Static variable in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStoreService
-
- PROP_ENCODE_LENGTH - Static variable in class org.apache.jackrabbit.oak.plugins.blob.datastore.AbstractDataStoreService
-
- 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_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_SHARED_DS_REPO_ID - 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.json.JsopDiff
-
- 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.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
-
- propertyAdded(PropertyState) - Method in class org.apache.jackrabbit.oak.spi.commit.CompositeEditor
-
- propertyAdded(PropertyState) - Method in class org.apache.jackrabbit.oak.spi.commit.DefaultEditor
-
- propertyAdded(PropertyState) - Method in class org.apache.jackrabbit.oak.spi.commit.DefaultValidator
-
- propertyAdded(PropertyState) - Method in interface org.apache.jackrabbit.oak.spi.commit.Editor
-
Processes an added property.
- propertyAdded(PropertyState) - Method in class org.apache.jackrabbit.oak.spi.commit.EditorDiff
-
- propertyAdded(PropertyState) - Method in class org.apache.jackrabbit.oak.spi.commit.FailingValidator
-
- propertyAdded(PropertyState) - Method in class org.apache.jackrabbit.oak.spi.commit.ProgressNotificationEditor
-
- propertyAdded(PropertyState) - Method in class org.apache.jackrabbit.oak.spi.commit.SubtreeExcludingValidator
-
- propertyAdded(PropertyState) - Method in interface org.apache.jackrabbit.oak.spi.commit.Validator
-
Validate an added property
- propertyAdded(PropertyState) - Method in class org.apache.jackrabbit.oak.spi.commit.VisibleEditor
-
- propertyAdded(PropertyState) - Method in class org.apache.jackrabbit.oak.spi.commit.VisibleValidator
-
- propertyAdded(PropertyState) - Method in class org.apache.jackrabbit.oak.spi.state.AbstractRebaseDiff
-
- propertyAdded(PropertyState) - Method in class org.apache.jackrabbit.oak.spi.state.ApplyDiff
-
- propertyAdded(PropertyState) - Method in class org.apache.jackrabbit.oak.spi.state.DefaultNodeStateDiff
-
- propertyAdded(PropertyState) - Method in class org.apache.jackrabbit.oak.spi.state.EqualsDiff
-
- propertyAdded(PropertyState) - Method in class org.apache.jackrabbit.oak.spi.state.MoveDetector
-
- propertyAdded(PropertyState) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeStateDiff
-
Called for all added properties.
- PropertyBuilder<T> - Class in org.apache.jackrabbit.oak.plugins.memory
-
PropertyBuilder
for building in memory PropertyState
instances.
- PropertyBuilder(Type<T>) - Constructor for class org.apache.jackrabbit.oak.plugins.memory.PropertyBuilder
-
Create a new instance for building PropertyState
instances
of the given type
.
- propertyChanged(PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.json.JsopDiff
-
- propertyChanged(PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.commit.ConflictValidator
-
- 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
-
- propertyChanged(PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.spi.commit.CompositeEditor
-
- propertyChanged(PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.spi.commit.DefaultEditor
-
- propertyChanged(PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.spi.commit.DefaultValidator
-
- propertyChanged(PropertyState, PropertyState) - Method in interface org.apache.jackrabbit.oak.spi.commit.Editor
-
Processes a changed property.
- propertyChanged(PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.spi.commit.EditorDiff
-
- propertyChanged(PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.spi.commit.FailingValidator
-
- propertyChanged(PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.spi.commit.ProgressNotificationEditor
-
- propertyChanged(PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.spi.commit.SubtreeExcludingValidator
-
- propertyChanged(PropertyState, PropertyState) - Method in interface org.apache.jackrabbit.oak.spi.commit.Validator
-
Validate a changed property
- propertyChanged(PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.spi.commit.VisibleEditor
-
- propertyChanged(PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.spi.commit.VisibleValidator
-
- propertyChanged(PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.spi.state.AbstractRebaseDiff
-
- propertyChanged(PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.spi.state.ApplyDiff
-
- propertyChanged(PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.spi.state.DefaultNodeStateDiff
-
- propertyChanged(PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.spi.state.EqualsDiff
-
- propertyChanged(PropertyState, PropertyState) - Method in class org.apache.jackrabbit.oak.spi.state.MoveDetector
-
- propertyChanged(PropertyState, PropertyState) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeStateDiff
-
Called for all changed properties.
- propertyDeleted(PropertyState) - Method in class org.apache.jackrabbit.oak.json.JsopDiff
-
- 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
-
- propertyDeleted(PropertyState) - Method in class org.apache.jackrabbit.oak.spi.commit.CompositeEditor
-
- propertyDeleted(PropertyState) - Method in class org.apache.jackrabbit.oak.spi.commit.DefaultEditor
-
- propertyDeleted(PropertyState) - Method in class org.apache.jackrabbit.oak.spi.commit.DefaultValidator
-
- propertyDeleted(PropertyState) - Method in interface org.apache.jackrabbit.oak.spi.commit.Editor
-
Processes a removed property.
- propertyDeleted(PropertyState) - Method in class org.apache.jackrabbit.oak.spi.commit.EditorDiff
-
- propertyDeleted(PropertyState) - Method in class org.apache.jackrabbit.oak.spi.commit.FailingValidator
-
- propertyDeleted(PropertyState) - Method in class org.apache.jackrabbit.oak.spi.commit.ProgressNotificationEditor
-
- propertyDeleted(PropertyState) - Method in class org.apache.jackrabbit.oak.spi.commit.SubtreeExcludingValidator
-
- propertyDeleted(PropertyState) - Method in interface org.apache.jackrabbit.oak.spi.commit.Validator
-
Validate a deleted property
- propertyDeleted(PropertyState) - Method in class org.apache.jackrabbit.oak.spi.commit.VisibleEditor
-
- propertyDeleted(PropertyState) - Method in class org.apache.jackrabbit.oak.spi.commit.VisibleValidator
-
- propertyDeleted(PropertyState) - Method in class org.apache.jackrabbit.oak.spi.state.AbstractRebaseDiff
-
- propertyDeleted(PropertyState) - Method in class org.apache.jackrabbit.oak.spi.state.ApplyDiff
-
- propertyDeleted(PropertyState) - Method in class org.apache.jackrabbit.oak.spi.state.DefaultNodeStateDiff
-
- propertyDeleted(PropertyState) - Method in class org.apache.jackrabbit.oak.spi.state.EqualsDiff
-
- propertyDeleted(PropertyState) - Method in class org.apache.jackrabbit.oak.spi.state.MoveDetector
-
- propertyDeleted(PropertyState) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeStateDiff
-
Called for all deleted properties.
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- propertyName - Variable in class org.apache.jackrabbit.oak.spi.query.Filter.PropertyRestriction
-
The name of the property.
- 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
-
- PropertyState - Interface in org.apache.jackrabbit.oak.api
-
Immutable property state.
- PropertyStates - Class in org.apache.jackrabbit.oak.plugins.memory
-
- PropertyStateValue - Class in org.apache.jackrabbit.oak.spi.query
-
- PropertyStateValue(PropertyState) - Constructor for class org.apache.jackrabbit.oak.spi.query.PropertyStateValue
-
- propertyType - Variable in class org.apache.jackrabbit.oak.spi.query.Filter.PropertyRestriction
-
The property type, if restricted.
- PropertyValue - Interface in org.apache.jackrabbit.oak.api
-
Immutable property value.
- 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
-
- PropertyValues - Class in org.apache.jackrabbit.oak.spi.query
-
- 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
- propRestriction - Variable in class org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan.Builder
-
- ProtectedItemImporter - Interface in org.apache.jackrabbit.oak.spi.xml
-
- ProtectedNodeImporter - Interface in org.apache.jackrabbit.oak.spi.xml
-
ProtectedNodeImporter
provides means to import protected
Node
s 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
.
- ProxyNodeStore - Class in org.apache.jackrabbit.oak.spi.state
-
- ProxyNodeStore() - Constructor for class org.apache.jackrabbit.oak.spi.state.ProxyNodeStore
-
- put(K, V, int) - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS
-
Add an entry to the cache.
- put(K, V) - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS
-
Add an entry to the cache using the average memory size.
- 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
-
- put(String, Value[], boolean, boolean) - Method in class org.apache.jackrabbit.oak.util.GenericDescriptors
-
Adds a new descriptor to this set of descriptors which overlay the ones from the base set.
- put(String, Value, boolean, boolean) - Method in class org.apache.jackrabbit.oak.util.GenericDescriptors
-
Adds a new descriptor to this set of descriptors which overlay the ones from the base set.
- putAll(Map<? extends K, ? extends V>) - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS
-
- 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
- putIfAbsent(K, V) - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS
-
- 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.
- PWD_PROPERTY_NAMES - Static variable in interface org.apache.jackrabbit.oak.spi.security.user.UserConstants
-
- 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
-
- RDBBlobStore - Class in org.apache.jackrabbit.oak.plugins.document.rdb
-
- RDBBlobStore(DataSource, RDBOptions) - Constructor for class org.apache.jackrabbit.oak.plugins.document.rdb.RDBBlobStore
-
- RDBBlobStore(DataSource) - Constructor for class org.apache.jackrabbit.oak.plugins.document.rdb.RDBBlobStore
-
- 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
DataSource
s 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
-
- RDBDocumentStore(DataSource, DocumentMK.Builder, RDBOptions) - Constructor for class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
-
- RDBDocumentStore(DataSource, DocumentMK.Builder) - Constructor for class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore
-
- RDBDocumentStore.QueryCondition - Class in org.apache.jackrabbit.oak.plugins.document.rdb
-
- RDBDocumentStore.QueryCondition(String, String, long) - Constructor for class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStore.QueryCondition
-
- 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
-
- 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
-
- 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, boolean, 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) - Method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentStoreJDBC
-
- 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.blob.datastore.DataStoreBlobStore
-
- 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.blob.cloud.CloudBlobStore
-
Reads the data from the actual cloud service.
- 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
-
- readDefinition(Tree) - Static method in class org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeUtil
-
Reads the privilege definition stored in the specified definition tree.
- ReadOnlyBuilder - Class in org.apache.jackrabbit.oak.spi.state
-
- ReadOnlyBuilder(NodeState) - Constructor for class org.apache.jackrabbit.oak.spi.state.ReadOnlyBuilder
-
- 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
-
- 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.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.
- readRestrictions(String, Tree) - Method in class org.apache.jackrabbit.oak.spi.whiteboard.WhiteboardRestrictionProvider
-
- 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() - Constructor for class org.apache.jackrabbit.oak.plugins.nodetype.write.ReadWriteNodeTypeManager
-
- rebase() - Method in interface org.apache.jackrabbit.oak.api.Root
-
Rebase this root instance to the latest revision.
- rebase() - Method in class org.apache.jackrabbit.oak.core.ImmutableRoot
-
- 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
-
- rebase(NodeBuilder) - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeStore
-
This implementation is equal to applying the differences between the builders base state
and its head state to a fresh builder on the stores root state using
ConflictAnnotatingRebaseDiff
for resolving
conflicts.
- rebase(NodeBuilder) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeStore
-
Rebases the changes between the
base
and
head
states
of the given builder on top of the current root state.
- rebase() - Method in interface org.apache.jackrabbit.oak.spi.state.NodeStoreBranch
-
Rebase the changes from this branch on top of the current
root.
- rebase(NodeBuilder) - Method in class org.apache.jackrabbit.oak.spi.state.ProxyNodeStore
-
- 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
-
- recordStats() - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS.Builder
-
- recover(int) - Method in class org.apache.jackrabbit.oak.plugins.document.LastRevRecoveryAgent
-
Recover the correct _lastRev updates for potentially missing candidate nodes.
- recover(Iterator<NodeDocument>, int) - Method in class org.apache.jackrabbit.oak.plugins.document.LastRevRecoveryAgent
-
Recover the correct _lastRev updates for the given candidate nodes.
- recover(Iterator<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
-
- REFERENCE - Static variable in class org.apache.jackrabbit.oak.api.Type
-
- 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
-
- ReferenceCollector - Interface in org.apache.jackrabbit.oak.plugins.blob
-
Callback interface for collecting all blob references that are
potentially accessible.
- ReferenceConstraint - Class in org.apache.jackrabbit.oak.plugins.nodetype.constraint
-
- ReferenceConstraint(String) - Constructor for class org.apache.jackrabbit.oak.plugins.nodetype.constraint.ReferenceConstraint
-
- ReferencedBlob - Class in org.apache.jackrabbit.oak.plugins.blob
-
Exposes the blob along with the Node id from which referenced
- ReferencedBlob(Blob, String) - Constructor for class org.apache.jackrabbit.oak.plugins.blob.ReferencedBlob
-
- 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
-
- referenceProperty(String, String) - Static method in class org.apache.jackrabbit.oak.plugins.memory.GenericPropertyState
-
Create a PropertyState
from a reference.
- referenceProperty(String, Iterable<String>) - Static method in class org.apache.jackrabbit.oak.plugins.memory.MultiGenericPropertyState
-
Create a multi valued PropertyState
from a list of references.
- REFERENCES - Static variable in class org.apache.jackrabbit.oak.api.Type
-
- refresh() - Method in interface org.apache.jackrabbit.oak.api.jmx.SessionMBean
-
Refresh this session.
- refresh() - Method in interface org.apache.jackrabbit.oak.api.Root
-
Reverts all changes made to this root and refreshed to the latest trunk.
- refresh(K) - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS
-
Re-load the value for the given key.
- 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 interface org.apache.jackrabbit.oak.api.jmx.RepositoryManagementMBean
-
Refresh all currently open sessions.
- refreshAllSessions() - Method in class org.apache.jackrabbit.oak.management.RepositoryManager
-
- refsNotAvailableFromRepos(List<DataRecord>, List<DataRecord>) - Static method in class org.apache.jackrabbit.oak.plugins.blob.datastore.SharedDataStoreUtils
-
Repositories from which marked references not available.
- register(Class<T>, T, Map<?, ?>) - Method in class org.apache.jackrabbit.oak.osgi.OsgiWhiteboard
-
- 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
.
- register(Class<T>, T, Map<?, ?>) - Method in class org.apache.jackrabbit.oak.spi.whiteboard.DefaultWhiteboard
-
- register(Class<T>, T, Map<?, ?>) - Method in interface org.apache.jackrabbit.oak.spi.whiteboard.Whiteboard
-
Publishes the given service to the whiteboard.
- registerAsyncIndexer(String, long) - Method in interface org.apache.jackrabbit.oak.api.jmx.IndexStatsMBean
-
Starts a new background indexing task and registers the JMX MBeans for it
- registerAsyncIndexer(AsyncIndexUpdate, long) - Method in class org.apache.jackrabbit.oak.plugins.index.IndexMBeanRegistration
-
- registerGCMonitor(GCMonitor) - Method in class org.apache.jackrabbit.oak.spi.gc.DelegatingGCMonitor
-
- registerMBean(Whiteboard, Class<T>, T, String, String) - Static method in class org.apache.jackrabbit.oak.spi.whiteboard.WhiteboardUtils
-
- registerMBean(Whiteboard, Class<T>, T, String, String, Map<String, String>) - Static method in class org.apache.jackrabbit.oak.spi.whiteboard.WhiteboardUtils
-
- 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
-
- 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
-
- registerNodeTypes(NodeTypeDefinition[], boolean) - Method in class org.apache.jackrabbit.oak.plugins.nodetype.write.ReadWriteNodeTypeManager
-
- registerObserver(Whiteboard, Observer) - Static method in class org.apache.jackrabbit.oak.spi.whiteboard.WhiteboardUtils
-
- Registration - Interface in org.apache.jackrabbit.oak.spi.whiteboard
-
Whiteboard service registration.
- 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
-
- 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.document.DocumentNodeStore
-
- release(String) - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeStore
-
- release(String) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeStore
-
Releases the provided checkpoint.
- release(String) - Method in class org.apache.jackrabbit.oak.spi.state.ProxyNodeStore
-
- releaseCheckpoint(String) - Method in interface org.apache.jackrabbit.oak.api.jmx.CheckpointMBean
-
Release the checkpoint with the given id
.
- releaseCheckpoint(String) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentCheckpointMBean
-
- releaseRecoveryLock(int) - Method in class org.apache.jackrabbit.oak.plugins.document.MissingLastRevSeeker
-
- remove() - Method in interface org.apache.jackrabbit.oak.api.Tree
-
Remove this tree instance.
- remove(Object) - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS
-
Remove an entry.
- remove() - Method in class org.apache.jackrabbit.oak.plugins.document.BlobReferenceIterator
-
- 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) - 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) - 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(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(int) - Method in class org.apache.jackrabbit.oak.plugins.document.RevisionVector
-
Returns a RevisionVector without the revision element with the given
clusterId
.
- 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) - 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() - 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) - 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() - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeBuilder
-
- 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 class org.apache.jackrabbit.oak.spi.query.Cursors.AbstractCursor
-
- 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() - Method in interface org.apache.jackrabbit.oak.spi.state.NodeBuilder
-
Remove this child node from its parent.
- remove() - Method in class org.apache.jackrabbit.oak.spi.state.ReadOnlyBuilder
-
- 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
-
- 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
-
- removedService(ServiceReference, Object) - Method in class org.apache.jackrabbit.oak.osgi.ObserverTracker
-
- 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
-
- removeNodeDiff(String) - Method in class org.apache.jackrabbit.oak.plugins.document.Commit
-
- removeObserver(Observer) - Method in class org.apache.jackrabbit.oak.spi.commit.CompositeObserver
-
- 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 interface org.apache.jackrabbit.oak.api.Tree
-
Remove the property with the given name.
- removeProperty(String) - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeBuilder
-
- 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
-
- removeProperty(String) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeBuilder
-
Remove the named property.
- removeProperty(String) - Method in class org.apache.jackrabbit.oak.spi.state.ReadOnlyBuilder
-
- removeProperty(String) - Method in class org.apache.jackrabbit.oak.util.NodeUtil
-
- 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
-
- removeValue(int) - Method in class org.apache.jackrabbit.oak.plugins.memory.PropertyBuilder
-
- removeValue(Object) - Method in class org.apache.jackrabbit.oak.plugins.memory.PropertyBuilder
-
- 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_EXCERPT - Static variable in class org.apache.jackrabbit.oak.query.QueryImpl
-
The "rep:excerpt" pseudo-property.
- REP_EXCERPT_FN - Static variable in class org.apache.jackrabbit.oak.query.fulltext.SimpleExcerptProvider
-
- REP_FACET - Static variable in class org.apache.jackrabbit.oak.query.QueryImpl
-
The "rep:facet" pseudo-property.
- 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_SPELLCHECK - Static variable in class org.apache.jackrabbit.oak.query.QueryImpl
-
The "rep:spellcheck" pseudo-property.
- REP_SUGGEST - Static variable in class org.apache.jackrabbit.oak.query.QueryImpl
-
The "rep:suggest" pseudo-property.
- 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.
- 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
-
- RepositoryInitializer - Interface in org.apache.jackrabbit.oak.spi.lifecycle
-
Initializer of repository content.
- RepositoryManagementMBean - Interface in org.apache.jackrabbit.oak.api.jmx
-
This interface exposes repository management operations and the status
of such operations.
- RepositoryManagementMBean.StatusCode - Enum in org.apache.jackrabbit.oak.api.jmx
-
Enum whose ordinals correspond to the status codes.
- RepositoryManager - Class in org.apache.jackrabbit.oak.management
-
- 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.
- RepositoryStats - Class in org.apache.jackrabbit.oak.stats
-
- RepositoryStats(RepositoryStatistics, TimeSeries) - Constructor for class org.apache.jackrabbit.oak.stats.RepositoryStats
-
- RepositoryStatsMBean - Interface in org.apache.jackrabbit.oak.api.jmx
-
MBean for providing repository wide statistics.
- 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() - Method in class org.apache.jackrabbit.oak.plugins.blob.migration.DepthFirstNodeIterator
-
- 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(NodeState) - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeBuilder
-
Throws away all changes in this builder and resets the base to the
given node state.
- reset(NodeBuilder) - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeStore
-
This implementation is equal resetting the builder to the root of the store and returning
the resulting node state from the builder.
- reset(NodeBuilder) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeStore
-
Reset the passed builder
by throwing away all its changes and
setting its base state to the current root state.
- reset(NodeBuilder) - Method in class org.apache.jackrabbit.oak.spi.state.ProxyNodeStore
-
- resetConsolidatedExecutionStats() - Method in interface org.apache.jackrabbit.oak.api.jmx.IndexStatsMBean
-
Resets the consolidated stats.
- 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
.
- resetLockAcquisitionCount() - Method in class org.apache.jackrabbit.oak.plugins.document.locks.TreeNodeDocumentLocks
-
- resetStats() - Method in interface org.apache.jackrabbit.oak.api.jmx.CacheStatsMBean
-
Reset the cache stats
- resetStats() - Method in class org.apache.jackrabbit.oak.cache.CacheStats
-
- 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.blob.datastore.DataStoreBlobStore
-
- 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_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
-
- 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.
- RESTRICTION_LOCAL_NAME - Static variable in class org.apache.jackrabbit.oak.spi.query.QueryConstants
-
Name of the property restriction used to express query performed
via NAME and LOCALNAME functions
- 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
-
- 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
-
- 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
-
- 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
-
- Result - Interface in org.apache.jackrabbit.oak.api
-
A result from executing a query.
- Result.SizePrecision - Enum in org.apache.jackrabbit.oak.api
-
- 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.
- ResultRow - Interface in org.apache.jackrabbit.oak.api
-
A query result row.
- ResultRowImpl - Class in org.apache.jackrabbit.oak.query
-
A query result row that keeps all data (for this row only) in memory.
- resume() - Method in interface org.apache.jackrabbit.oak.api.jmx.IndexStatsMBean
-
Resumes the indexing process.
- 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.document.DocumentNodeStore
-
- retrieve(String) - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeStore
-
- retrieve(String) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeStore
-
Retrieves the root node from a previously created repository checkpoint.
- retrieve(String) - Method in class org.apache.jackrabbit.oak.spi.state.ProxyNodeStore
-
- 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
-
- 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
-
- RevisionGC - Class in org.apache.jackrabbit.oak.spi.state
-
- RevisionGC(Runnable, Executor) - Constructor for class org.apache.jackrabbit.oak.spi.state.RevisionGC
-
- RevisionGCMBean - Interface in org.apache.jackrabbit.oak.spi.state
-
MBean for starting and monitoring the progress of
revision garbage collection.
- RevisionsKey - Class in org.apache.jackrabbit.oak.plugins.document.util
-
A cache key implementation which consists of two
Revision
s.
- 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
-
- Root - Interface in org.apache.jackrabbit.oak.api
-
A
Root
instance serves as a container for a
Tree
.
- 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.
- 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
- running(String) - Static method in class org.apache.jackrabbit.oak.management.ManagementOperation.Status
-
- S3DataStoreService - Class in org.apache.jackrabbit.oak.plugins.blob.datastore
-
- S3DataStoreService() - Constructor for class org.apache.jackrabbit.oak.plugins.blob.datastore.S3DataStoreService
-
- 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.
- scalar(Type<T>) - Static method in class org.apache.jackrabbit.oak.plugins.memory.PropertyBuilder
-
Create a new instance for building scalar PropertyState
instances
of the given type
.
- scalar(Type<T>, String) - Static method in class org.apache.jackrabbit.oak.plugins.memory.PropertyBuilder
-
Create a new instance for building scalar PropertyState
instances
of the given type
.
- scheduleWithFixedDelay(Whiteboard, Runnable, long) - Static method in class org.apache.jackrabbit.oak.spi.whiteboard.WhiteboardUtils
-
- scheduleWithFixedDelay(Whiteboard, Runnable, long, boolean) - Static method in class org.apache.jackrabbit.oak.spi.whiteboard.WhiteboardUtils
-
- 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.
- 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.
- SecurityConfiguration.Default() - Constructor for class org.apache.jackrabbit.oak.spi.security.SecurityConfiguration.Default
-
- 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
-
- 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
-
- segmentCount(int) - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS.Builder
-
- 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(NodeState, 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(NodeState, 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
-
- serialize(Blob) - Method in class org.apache.jackrabbit.oak.json.BlobSerializer
-
- serialize(NodeState) - Method in class org.apache.jackrabbit.oak.json.JsonSerializer
-
- serialize(PropertyState) - Method in class org.apache.jackrabbit.oak.json.JsonSerializer
-
- serialize(PropertyState, Type<?>, int) - Method in class org.apache.jackrabbit.oak.json.JsonSerializer
-
- SessionMBean - Interface in org.apache.jackrabbit.oak.api.jmx
-
MBean providing basic Session
information and statistics.
- 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(NodeState) - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeBuilder
-
Replaces the current state of this builder with the given node state.
- SET_PROPERTY - Static variable in class org.apache.jackrabbit.oak.spi.security.authorization.permission.Permissions
-
- setAccessKey(String) - Method in class org.apache.jackrabbit.oak.plugins.blob.cloud.CloudBlobStore
-
- 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
-
- setArray() - Method in class org.apache.jackrabbit.oak.plugins.memory.PropertyBuilder
-
- 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
-
- setAttribute(String, Object) - Method in class org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan.Builder
-
- setAuthInfo(AuthInfo, Subject) - Static method in class org.apache.jackrabbit.oak.spi.security.authentication.AbstractLoginModule
-
- setAverageMemory(int) - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS
-
Set the average memory used per entry.
- setBlob(Blob) - Method in class org.apache.jackrabbit.oak.plugins.blob.ReferencedBlob
-
- setBlobStatsCollector(BlobStatsCollector) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore
-
- 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.blob.datastore.DataStoreBlobStore
-
- setBlockSize(int) - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.BlobCache
-
- setBoolean(String, boolean) - Method in class org.apache.jackrabbit.oak.util.NodeUtil
-
- 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
-
- 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
-
- setChildNode(String) - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeBuilder
-
- setChildNode(String, NodeState) - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeBuilder
-
- setChildNode(String) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeBuilder
-
Adds the named child node and returns a builder for modifying it.
- setChildNode(String, NodeState) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeBuilder
-
Adds or replaces a subtree.
- setChildNode(String, NodeState) - Method in class org.apache.jackrabbit.oak.spi.state.ReadOnlyBuilder
-
- setChildNode(String) - Method in class org.apache.jackrabbit.oak.spi.state.ReadOnlyBuilder
-
- 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
-
- setCloudContainer(String) - Method in class org.apache.jackrabbit.oak.plugins.blob.cloud.CloudBlobStore
-
- setCloudProvider(String) - Method in class org.apache.jackrabbit.oak.plugins.blob.cloud.CloudBlobStore
-
- 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
-
- setContentRepository(ContentRepository) - Method in class org.apache.jackrabbit.oak.spi.security.authentication.callback.RepositoryCallback
-
- setCostPerEntry(double) - Method in class org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan.Builder
-
- setCostPerExecution(double) - Method in class org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan.Builder
-
- 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
-
- setDate(String, long) - Method in class org.apache.jackrabbit.oak.util.NodeUtil
-
- setDefaultConfig(T) - Method in class org.apache.jackrabbit.oak.spi.security.CompositeConfiguration
-
- setDefinition(NodeState) - Method in class org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan.Builder
-
- setDelay(long) - Method in class org.apache.jackrabbit.oak.plugins.observation.CommitRateLimiter
-
Number of milli seconds to delay commits going through this hook.
- setDelayed(boolean) - Method in class org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan.Builder
-
- 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
-
- setEndTime(long) - Method in class org.apache.jackrabbit.oak.plugins.blob.GarbageCollectionRepoStats
-
- setEstimatedEntryCount(long) - Method in class org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan.Builder
-
- 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
-
- setFilter(Filter) - Method in class org.apache.jackrabbit.oak.plugins.index.aggregate.AggregateIndexPlan
-
- setFilter(Filter) - Method in class org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan.Builder
-
- setFilter(Filter) - Method in interface org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan
-
Use the given filter.
- setFullTextComparisonWithoutIndex(boolean) - Method in class org.apache.jackrabbit.oak.query.QueryEngineSettings
-
- setFullTextConstraint(FullTextExpression) - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
-
- setFulltextIndex(boolean) - Method in class org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan.Builder
-
- setHasBinary(UpdateOp) - Static method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
-
- setId(String) - Method in class org.apache.jackrabbit.oak.plugins.blob.ReferencedBlob
-
- setId(String) - Method in class org.apache.jackrabbit.oak.plugins.document.mongo.MongoBlob
-
- setIncludeSelectorNameInWildcardColumns(boolean) - Method in class org.apache.jackrabbit.oak.query.SQL2Parser
-
- setIncludesNodeData(boolean) - Method in class org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan.Builder
-
- 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.UnionQueryImpl
-
- 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
-
- 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
- setLength(long) - Method in class org.apache.jackrabbit.oak.plugins.blob.GarbageCollectionRepoStats
-
- 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 interface org.apache.jackrabbit.oak.api.jmx.QueryEngineSettingsMBean
-
Change the limit.
- setLimitInMemory(long) - Method in class org.apache.jackrabbit.oak.query.QueryEngineSettings
-
Change the limit.
- setLimitReads(long) - Method in interface org.apache.jackrabbit.oak.api.jmx.QueryEngineSettingsMBean
-
Change the limit.
- setLimitReads(long) - Method in class org.apache.jackrabbit.oak.query.QueryEngineSettings
-
Change the limit.
- setLocal(boolean) - Method in class org.apache.jackrabbit.oak.plugins.blob.GarbageCollectionRepoStats
-
- setLogging(boolean) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
-
- setLong(String, long) - Method in class org.apache.jackrabbit.oak.util.NodeUtil
-
- setMatchesAllTypes(boolean) - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
-
- setMaxBackOffMillis(int) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
-
- setMaxCachedBinarySize(int) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore
-
- setMaxMemory(long) - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS
-
Set the maximum memory this cache should use.
- 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
-
- setMembers(NodeBuilder, Set<String>) - Method in class org.apache.jackrabbit.oak.security.user.MembershipWriter
-
Sets the given set of members to the specified group.
- 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.
- setName(String) - Method in class org.apache.jackrabbit.oak.plugins.memory.PropertyBuilder
-
- setName(String, String) - Method in class org.apache.jackrabbit.oak.util.NodeUtil
-
- setNames(String, String...) - Method in class org.apache.jackrabbit.oak.util.NodeUtil
-
- setNew(boolean) - Method in class org.apache.jackrabbit.oak.plugins.document.UpdateOp
-
- setNumLines(int) - Method in class org.apache.jackrabbit.oak.plugins.blob.GarbageCollectionRepoStats
-
- 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
-
- setOrderableChildren(boolean) - Method in interface org.apache.jackrabbit.oak.api.Tree
-
Changes the nature of this tree such that the order of the children
is kept stable.
- 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.
- setOverflowToDiskThreshold(int) - Method in class org.apache.jackrabbit.oak.plugins.document.VersionGarbageCollector
-
- setParameters(PreparedStatement, int) - Method in interface org.apache.jackrabbit.oak.plugins.document.rdb.RDBJDBCTools.PreparedStatementComponent
-
- setParameters(ConfigurationParameters) - Method in class org.apache.jackrabbit.oak.spi.security.ConfigurationBase
-
- setPath(String) - Method in class org.apache.jackrabbit.oak.query.index.FilterImpl
-
- setPathPrefix(String) - Method in class org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan.Builder
-
- setPersistentCache(String) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
-
Sets the persistent cache option.
- setPersistentCache(PersistentCache) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore
-
- setPlanName(String) - Method in class org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan.Builder
-
- setPolicy(String, AccessControlPolicy) - Method in class org.apache.jackrabbit.oak.security.authorization.accesscontrol.AccessControlManagerImpl
-
- 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 interface org.apache.jackrabbit.oak.api.Tree
-
Set a property state
- setProperty(String, T) - Method in interface org.apache.jackrabbit.oak.api.Tree
-
Set a property state
- setProperty(String, T, Type<T>) - Method in interface org.apache.jackrabbit.oak.api.Tree
-
Set a property state
- setProperty(PropertyState) - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeBuilder
-
- setProperty(String, T) - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeBuilder
-
- setProperty(String, T, Type<T>) - Method in class org.apache.jackrabbit.oak.plugins.memory.MemoryNodeBuilder
-
- 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
-
- setProperty(PropertyState) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeBuilder
-
Set a property state
- setProperty(String, T) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeBuilder
-
Set a property state
- setProperty(String, T, Type<T>) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeBuilder
-
Set a property state
- setProperty(PropertyState) - Method in class org.apache.jackrabbit.oak.spi.state.ReadOnlyBuilder
-
- setProperty(String, T) - Method in class org.apache.jackrabbit.oak.spi.state.ReadOnlyBuilder
-
- setProperty(String, T, Type<T>) - Method in class org.apache.jackrabbit.oak.spi.state.ReadOnlyBuilder
-
- setPropertyRestriction(Filter.PropertyRestriction) - Method in class org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan.Builder
-
- 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 ...
- 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
-
- setRDBConnection(DataSource, DataSource) - Method in class org.apache.jackrabbit.oak.plugins.document.DocumentMK.Builder
-
Sets a
DataSource
s to use for the RDB document and blob
stores.
- 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
-
- setReferenceKey(byte[]) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.OakFileDataStore
-
- setReferenceKeyEncoded(String) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.OakFileDataStore
-
Set Base64 encoded signing key
- setReferenceKeyPlainText(String) - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.OakFileDataStore
-
Set the referenceKey from plain text.
- setRepositoryId(String) - Method in class org.apache.jackrabbit.oak.plugins.blob.GarbageCollectionRepoStats
-
- setRevision(UpdateOp, Revision, String) - Static method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
-
- setRoot(NodeState) - Method in interface org.apache.jackrabbit.oak.spi.state.NodeStoreBranch
-
Updates the state of the content tree of this private branch.
- setScalar() - Method in class org.apache.jackrabbit.oak.plugins.memory.PropertyBuilder
-
- setSecretKey(String) - Method in class org.apache.jackrabbit.oak.plugins.blob.cloud.CloudBlobStore
-
- 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
-
- setSortOrder(List<QueryIndex.OrderEntry>) - Method in class org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan.Builder
-
- setStalePrevious(UpdateOp, Revision, int) - Static method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
-
- setStartTime(long) - Method in class org.apache.jackrabbit.oak.plugins.blob.GarbageCollectionRepoStats
-
- 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
-
- setString(String, String) - Method in class org.apache.jackrabbit.oak.util.NodeUtil
-
- setStrings(String, String...) - Method in class org.apache.jackrabbit.oak.util.NodeUtil
-
- setSupportSQL1(boolean) - Method in class org.apache.jackrabbit.oak.query.SQL2Parser
-
Enable or disable support for SQL-1 queries.
- 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
-
- setType(TreeType) - Method in class org.apache.jackrabbit.oak.plugins.tree.impl.ImmutableTree
-
- 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
-
- setValue(T) - Method in class org.apache.jackrabbit.oak.plugins.memory.PropertyBuilder
-
- setValue(T, int) - Method in class org.apache.jackrabbit.oak.plugins.memory.PropertyBuilder
-
- setValues(Iterable<T>) - Method in class org.apache.jackrabbit.oak.plugins.memory.PropertyBuilder
-
- setValues(String, Value[]) - Method in class org.apache.jackrabbit.oak.util.NodeUtil
-
- 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.
- setWhiteboard(Whiteboard) - Method in interface org.apache.jackrabbit.oak.spi.whiteboard.WhiteboardAware
-
Sets the whiteboard.
- 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
-
- sha256() - Method in class org.apache.jackrabbit.oak.plugins.memory.AbstractBlob
-
This hash code implementation returns the hash code of the underlying stream
- 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.
- SharedDataStore - Interface in org.apache.jackrabbit.oak.plugins.blob
-
Interface to be implemented by a shared data store.
- SharedDataStore.Type - Enum in org.apache.jackrabbit.oak.plugins.blob
-
Explicitly identifies the type of the data store
- SharedDataStoreUtils - Class in org.apache.jackrabbit.oak.plugins.blob.datastore
-
- SharedDataStoreUtils() - Constructor for class org.apache.jackrabbit.oak.plugins.blob.datastore.SharedDataStoreUtils
-
- SharedDataStoreUtils.SharedStoreRecordType - Enum in org.apache.jackrabbit.oak.plugins.blob.datastore
-
Encapsulates the different type of records at the data store root.
- SharedS3DataStore - Class in org.apache.jackrabbit.oak.plugins.blob.datastore
-
- SharedS3DataStore() - Constructor for class org.apache.jackrabbit.oak.plugins.blob.datastore.SharedS3DataStore
-
- SharedS3DataStoreService - Class in org.apache.jackrabbit.oak.plugins.blob.datastore
-
- SharedS3DataStoreService() - Constructor for class org.apache.jackrabbit.oak.plugins.blob.datastore.SharedS3DataStoreService
-
- sharedState - Variable in class org.apache.jackrabbit.oak.spi.security.authentication.AbstractLoginModule
-
- 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(...)
- SIMPLE - Static variable in class org.apache.jackrabbit.oak.stats.Clock
-
- SimpleExcerptProvider - Class in org.apache.jackrabbit.oak.query.fulltext
-
This class can extract excerpts from node.
- SimpleExcerptProvider() - Constructor for class org.apache.jackrabbit.oak.query.fulltext.SimpleExcerptProvider
-
- 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
-
- SimpleStats - Class in org.apache.jackrabbit.oak.stats
-
- SimpleStats(AtomicLong, SimpleStats.Type) - Constructor for class org.apache.jackrabbit.oak.stats.SimpleStats
-
- SimpleStats.Type - Enum in org.apache.jackrabbit.oak.stats
-
- 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
-
- simplify() - Method in class org.apache.jackrabbit.oak.query.fulltext.FullTextAnd
-
- simplify() - Method in class org.apache.jackrabbit.oak.query.fulltext.FullTextOr
-
- simplify() - Method in class org.apache.jackrabbit.oak.query.fulltext.FullTextTerm
-
- size() - Method in interface org.apache.jackrabbit.oak.api.PropertyState
-
The size of the value of this property.
- size(int) - Method in interface org.apache.jackrabbit.oak.api.PropertyState
-
The size of the value at the given index
.
- size() - Method in interface org.apache.jackrabbit.oak.api.PropertyValue
-
The size of the value of this object.
- size(int) - Method in interface org.apache.jackrabbit.oak.api.PropertyValue
-
The size of the value at the given index
.
- size() - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS
-
Get the number of resident entries.
- size() - Method in class org.apache.jackrabbit.oak.plugins.document.persistentCache.MultiGenerationMap
-
- size() - Method in class org.apache.jackrabbit.oak.plugins.memory.BinaryPropertyState
-
- size() - Method in class org.apache.jackrabbit.oak.plugins.memory.EmptyPropertyState
-
- size(int) - Method in class org.apache.jackrabbit.oak.plugins.memory.EmptyPropertyState
-
- size() - Method in class org.apache.jackrabbit.oak.spi.query.PropertyStateValue
-
- size(int) - Method in class org.apache.jackrabbit.oak.spi.query.PropertyStateValue
-
- size() - Method in class org.apache.jackrabbit.oak.spi.security.authorization.accesscontrol.AbstractAccessControlList
-
- size() - Method in class org.apache.jackrabbit.oak.spi.security.ConfigurationParameters
- size() - Method in class org.apache.jackrabbit.oak.util.BlobByteSource
-
- sizeHot() - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS
-
Get the number of hot entries in the cache.
- sizeMapArray() - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS
-
Get the length of the internal map array.
- sizeNonResident() - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS
-
Get the number of non-resident entries in the cache.
- sizeOf(K, V) - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS
-
Get the size of the given value.
- skipped(String, Object...) - Method in class org.apache.jackrabbit.oak.spi.gc.DelegatingGCMonitor
-
- skipped(String, Object[]) - Method in class org.apache.jackrabbit.oak.spi.gc.GCMonitor.Empty
-
- skipped(String, Object...) - Method in interface org.apache.jackrabbit.oak.spi.gc.GCMonitor
-
A garbage collection cycle is skipped for a specific reason
.
- skipped(String, Object...) - Method in class org.apache.jackrabbit.oak.spi.gc.GCMonitorTracker
-
- sort(File) - Static method in class org.apache.jackrabbit.oak.plugins.blob.GarbageCollectorFileState
-
Sorts the given file externally.
- sort(File, Comparator<String>) - Static method in class org.apache.jackrabbit.oak.plugins.blob.GarbageCollectorFileState
-
Sorts the given file externally with the given comparator.
- sortOrder() - Method in class org.apache.jackrabbit.oak.spi.query.Filter.PropertyRestriction
-
How restrictive a condition is.
- sortOrder - Variable in class org.apache.jackrabbit.oak.spi.query.QueryIndex.IndexPlan.Builder
-
- SOURCE_PATH - Static variable in class org.apache.jackrabbit.oak.spi.state.MoveDetector
-
- 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(String) - Static method in class org.apache.jackrabbit.oak.json.TypeCodes
-
Splits a jsonString
, which is prefixed with a type code
at the location where the prefix ends.
- split(RevisionContext, RevisionVector) - Method in class org.apache.jackrabbit.oak.plugins.document.NodeDocument
-
Returns update operations to split this document.
- split(String) - Method in class org.apache.jackrabbit.oak.stats.StopwatchLogger
-
track of an intermediate time without stopping the ticking.
- 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
-
- splitIndexingTask(String, String) - Method in interface org.apache.jackrabbit.oak.api.jmx.IndexStatsMBean
-
Splits the current indexing tasks into 2, indexes that are passed in as
an input will have their 'async' property updated to
newIndexTaskName
.
- 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
Query
object.
- SQL2Parser - Class in org.apache.jackrabbit.oak.query
-
The SQL2 parser can convert a JCR-SQL2 query to a query.
- SQL2Parser(NamePathMapper, NodeState, QueryEngineSettings) - Constructor for class org.apache.jackrabbit.oak.query.SQL2Parser
-
Create a new parser.
- squeeze(NodeState) - Static method in class org.apache.jackrabbit.oak.plugins.memory.ModifiedNodeState
-
- 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.
- stackMoveDistance(int) - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS.Builder
-
- 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(BundleContext) - Method in class org.apache.jackrabbit.oak.osgi.ObserverTracker
-
- start() - Method in class org.apache.jackrabbit.oak.plugins.blob.migration.BlobMigrator
-
- start(Tree) - Method in class org.apache.jackrabbit.oak.security.authorization.accesscontrol.AccessControlImporter
-
- start(Whiteboard) - Method in class org.apache.jackrabbit.oak.spi.whiteboard.AbstractServiceTracker
-
- 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() - Method in class org.apache.jackrabbit.oak.stats.StopwatchLogger
-
starts the clock
- start() - Method in class org.apache.jackrabbit.oak.util.PerfLogger
-
Returns quickly if log level is not DEBUG or TRACE - otherwise just
returns the current time in millis.
- start(String) - Method in class org.apache.jackrabbit.oak.util.PerfLogger
-
Returns quickly if log level is not DEBUG or TRACE - if it is DEBUG, then
just returns the current time in millis, if it is TRACE, then log the
given message and also return the current time in millis.
- START_TIME_KEY - Static variable in class org.apache.jackrabbit.oak.plugins.document.ClusterNodeInfo
-
The start time.
- startBackup() - Method in interface org.apache.jackrabbit.oak.api.jmx.FileStoreBackupRestoreMBean
-
Initiate a backup operation.
- startBackup() - Method in interface org.apache.jackrabbit.oak.api.jmx.RepositoryManagementMBean
-
Initiate a backup operation.
- startBackup() - Method in class org.apache.jackrabbit.oak.management.RepositoryManager
-
- startBlobGC(boolean) - Method in class org.apache.jackrabbit.oak.plugins.blob.BlobGC
-
- startBlobGC(boolean) - Method in interface org.apache.jackrabbit.oak.plugins.blob.BlobGCMBean
-
Initiate a data store garbage collection operation.
- startBlobMigration(boolean) - Method in class org.apache.jackrabbit.oak.plugins.blob.migration.BlobMigration
-
- startBlobMigration(boolean) - Method in interface org.apache.jackrabbit.oak.plugins.blob.migration.BlobMigrationMBean
-
- 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 interface org.apache.jackrabbit.oak.api.jmx.RepositoryManagementMBean
-
Initiate a data store garbage collection operation
- startDataStoreGC(boolean) - Method in class org.apache.jackrabbit.oak.management.RepositoryManager
-
- startMark() - Method in class org.apache.jackrabbit.oak.plugins.blob.cloud.CloudBlobStore
-
- startMark() - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore
-
- 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 interface org.apache.jackrabbit.oak.api.jmx.RepositoryManagementMBean
-
Initiate a reindex operation for the property indexes marked for
reindexing
- 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
- startRestore() - Method in interface org.apache.jackrabbit.oak.api.jmx.FileStoreBackupRestoreMBean
-
Initiate a restore operation.
- startRestore() - Method in interface org.apache.jackrabbit.oak.api.jmx.RepositoryManagementMBean
-
Initiate a restore operation.
- startRestore() - Method in class org.apache.jackrabbit.oak.management.RepositoryManager
-
- startRevisionGC() - Method in interface org.apache.jackrabbit.oak.api.jmx.RepositoryManagementMBean
-
Initiate a revision garbage collection operation
- startRevisionGC() - Method in class org.apache.jackrabbit.oak.management.RepositoryManager
-
- startRevisionGC() - Method in class org.apache.jackrabbit.oak.spi.state.RevisionGC
-
- startRevisionGC() - Method in interface org.apache.jackrabbit.oak.spi.state.RevisionGCMBean
-
Initiate a revision garbage collection operation
- STATE - Static variable in exception org.apache.jackrabbit.oak.api.CommitFailedException
-
Type name for state violation errors.
- 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
-
- StatisticManager - Class in org.apache.jackrabbit.oak.stats
-
Manager for all repository wide statistics.
- StatisticManager(Whiteboard, ScheduledExecutorService) - Constructor for class org.apache.jackrabbit.oak.stats.StatisticManager
-
Create a new instance of this class registering all repository wide
statistics with the passed whiteboard
.
- StatisticsProvider - Interface in org.apache.jackrabbit.oak.stats
-
- 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() - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS
-
- stats - Variable in class org.apache.jackrabbit.oak.plugins.document.SplitDocumentCleanUp
-
- Stats - Interface in org.apache.jackrabbit.oak.stats
-
A tag interface to indicate that a class is a Stat.
- StatsOptions - Class in org.apache.jackrabbit.oak.stats
-
- STATUS_DONE - Static variable in interface org.apache.jackrabbit.oak.api.jmx.IndexStatsMBean
-
- STATUS_INIT - Static variable in interface org.apache.jackrabbit.oak.api.jmx.IndexStatsMBean
-
- STATUS_RUNNING - Static variable in interface org.apache.jackrabbit.oak.api.jmx.IndexStatsMBean
-
- stop() - Method in class org.apache.jackrabbit.oak.osgi.ObserverTracker
-
- stop() - Method in class org.apache.jackrabbit.oak.plugins.blob.migration.BlobMigrator
-
- stop() - Method in class org.apache.jackrabbit.oak.spi.whiteboard.AbstractServiceTracker
-
- stop() - Method in interface org.apache.jackrabbit.oak.spi.whiteboard.Tracker
-
Stops tracking.
- stop(String) - Method in class org.apache.jackrabbit.oak.stats.StopwatchLogger
-
track the time and stop the clock.
- stop() - Method in interface org.apache.jackrabbit.oak.stats.TimerStats.Context
-
Updates the timer with the difference between current and start time.
- stopBlobMigration() - Method in class org.apache.jackrabbit.oak.plugins.blob.migration.BlobMigration
-
- stopBlobMigration() - Method in interface org.apache.jackrabbit.oak.plugins.blob.migration.BlobMigrationMBean
-
- StopwatchLogger - Class in org.apache.jackrabbit.oak.stats
-
Utility class to be used for tracking of timing within methods.
- StopwatchLogger(String) - Constructor for class org.apache.jackrabbit.oak.stats.StopwatchLogger
-
Create a class with the provided class.
- StopwatchLogger(Class<?>) - Constructor for class org.apache.jackrabbit.oak.stats.StopwatchLogger
-
instantiate a class with the provided class
- StopwatchLogger(Logger, Class<?>) - Constructor for class org.apache.jackrabbit.oak.stats.StopwatchLogger
-
Instantiate a class with the provided class and custom logger.
- StopwatchLogger(Logger, String) - Constructor for class org.apache.jackrabbit.oak.stats.StopwatchLogger
-
Instantiate a class with the provided class and custom logger.
- 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.DocumentNodeStore
-
The document store (might be used by multiple node stores).
- store - Variable in class org.apache.jackrabbit.oak.plugins.document.SplitDocumentCleanUp
-
- storeBlock(byte[], int, byte[]) - Method in class org.apache.jackrabbit.oak.plugins.blob.cloud.CloudBlobStore
-
Uploads the block to the cloud service.
- 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
-
- STRING - Static variable in class org.apache.jackrabbit.oak.api.Type
-
- StringBasedBlob - Class in org.apache.jackrabbit.oak.plugins.memory
-
This Blob
implementations is based on a string.
- StringBasedBlob(String) - Constructor for class org.apache.jackrabbit.oak.plugins.memory.StringBasedBlob
-
- StringCache - Class in org.apache.jackrabbit.oak.cache
-
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
-
- stringProperty(String, Iterable<String>) - Static method in class org.apache.jackrabbit.oak.plugins.memory.MultiStringPropertyState
-
Create a multi valued PropertyState
from a list of strings.
- stringProperty(String, String) - Static method in class org.apache.jackrabbit.oak.plugins.memory.StringPropertyState
-
Create a PropertyState
from a string.
- StringPropertyState - Class in org.apache.jackrabbit.oak.plugins.memory
-
- StringPropertyState(String, String) - Constructor for class org.apache.jackrabbit.oak.plugins.memory.StringPropertyState
-
- STRINGS - Static variable in class org.apache.jackrabbit.oak.api.Type
-
- 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
-
- SubtreeEditor - Class in org.apache.jackrabbit.oak.spi.commit
-
Editor wrapper that passes only changes in the specified subtree to
the given delegate editor.
- SubtreeEditor(Editor, String...) - Constructor for class org.apache.jackrabbit.oak.spi.commit.SubtreeEditor
-
- SubtreeExcludingValidator - Class in org.apache.jackrabbit.oak.spi.commit
-
Validator that excludes a subtree from the validation process and delegates
validation of other changes to another given validator.
- SubtreeExcludingValidator(Validator, List<String>) - Constructor for class org.apache.jackrabbit.oak.spi.commit.SubtreeExcludingValidator
-
- SubtreeValidator - Class in org.apache.jackrabbit.oak.spi.commit
-
Validator that detects changes to a specified subtree and delegates the
validation of such changes to another given validator.
- SubtreeValidator(Validator, String...) - Constructor for class org.apache.jackrabbit.oak.spi.commit.SubtreeValidator
-
- succeeded(String) - Static method in class org.apache.jackrabbit.oak.management.ManagementOperation.Status
-
- 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
-
- supportedPermissions(TreeLocation, long) - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.AggregatedPermissionProvider
-
- supportedPermissions(TreePermission, PropertyState, long) - Method in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.AggregatedPermissionProvider
-
- 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 at the specified path 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.blob.cloud.CloudBlobStore
-
- sweep() - Method in class org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore
-
- sweep(GarbageCollectorFileState, long) - Method in class org.apache.jackrabbit.oak.plugins.blob.MarkSweepGarbageCollector
-
Sweep phase of gc candidate deletion.
- 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
-
- 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
-
- 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.
- SystemRoot(NodeStore, CommitHook, String, SecurityProvider, QueryEngineSettings, QueryIndexProvider) - Constructor for class org.apache.jackrabbit.oak.core.SystemRoot
-
- 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.
- 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.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.
- validateRestrictions(String, Tree) - Method in class org.apache.jackrabbit.oak.spi.whiteboard.WhiteboardRestrictionProvider
-
- Validator - Interface in org.apache.jackrabbit.oak.spi.commit
-
Content change validator.
- ValidatorProvider - Class in org.apache.jackrabbit.oak.spi.commit
-
Extension point for plugging in different kinds of validation rules
for content changes.
- ValidatorProvider() - Constructor for class org.apache.jackrabbit.oak.spi.commit.ValidatorProvider
-
- 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_PERMISSIONS_JR2 - Static variable in interface org.apache.jackrabbit.oak.spi.security.authorization.permission.PermissionConstants
-
- valueConstraint(int, String) - Static method in class org.apache.jackrabbit.oak.plugins.nodetype.constraint.Constraints
-
- 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
-
- ValueFactoryImpl(Root, NamePathMapper) - Constructor for class org.apache.jackrabbit.oak.plugins.value.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
-
- ValueImpl - Class in org.apache.jackrabbit.oak.plugins.value
-
Implementation of
Value
based on
PropertyState
.
- valueOf(String) - Static method in enum org.apache.jackrabbit.oak.api.jmx.RepositoryManagementMBean.StatusCode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.jackrabbit.oak.api.Result.SizePrecision
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.jackrabbit.oak.api.Tree.Status
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.jackrabbit.oak.plugins.blob.datastore.SharedDataStoreUtils.SharedStoreRecordType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.jackrabbit.oak.plugins.blob.SharedDataStore.Type
-
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 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.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.spi.commit.PartialConflictHandler.Resolution
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.jackrabbit.oak.spi.query.Filter.PathRestriction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.jackrabbit.oak.spi.query.QueryIndex.OrderEntry.Order
-
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.state.ConflictType
-
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.
- valueOf(String) - Static method in enum org.apache.jackrabbit.oak.stats.SimpleStats.Type
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.apache.jackrabbit.oak.api.jmx.RepositoryManagementMBean.StatusCode
-
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.api.Result.SizePrecision
-
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.api.Tree.Status
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.jackrabbit.oak.cache.CacheLIRS
-
- values() - Static method in enum org.apache.jackrabbit.oak.plugins.blob.datastore.SharedDataStoreUtils.SharedStoreRecordType
-
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.blob.SharedDataStore.Type
-
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 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.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.spi.commit.PartialConflictHandler.Resolution
-
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.query.Filter.PathRestriction
-
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.query.QueryIndex.OrderEntry.Order
-
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.state.ConflictType
-
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.
- values() - Static method in enum org.apache.jackrabbit.oak.stats.SimpleStats.Type
-
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
-
- VERSION - Static variable in exception org.apache.jackrabbit.oak.api.CommitFailedException
-
Type name for version violation errors.
- 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, String) - Static method in class org.apache.jackrabbit.oak.plugins.document.rdb.RDBJDBCTools
-
Generate version diagnostics.
- VersionConstants - Interface in org.apache.jackrabbit.oak.plugins.version
-
VersionConstants...
- VersionEditorProvider - Class in org.apache.jackrabbit.oak.plugins.version
-
- VersionEditorProvider() - Constructor for class org.apache.jackrabbit.oak.plugins.version.VersionEditorProvider
-
- 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.VersionGCStats - Class in org.apache.jackrabbit.oak.plugins.document
-
- VersionGarbageCollector.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
-
- 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
-
- VisibleEditor - Class in org.apache.jackrabbit.oak.spi.commit
-
Editor wrapper that passes only changes to non-hidden nodes and properties
(i.e.
- VisibleEditor(Editor) - Constructor for class org.apache.jackrabbit.oak.spi.commit.VisibleEditor
-
- VisibleFilter - Class in org.apache.jackrabbit.oak.plugins.observation.filter
-
Event filter that hides all non-visible content.
- VisibleValidator - Class in org.apache.jackrabbit.oak.spi.commit
-
Validator implementation that allows to exclude hidden nodes and/or properties
for the validation process.
- VisibleValidator(Validator, boolean, boolean) - Constructor for class org.apache.jackrabbit.oak.spi.commit.VisibleValidator
-
- 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.
- visit(FullTextContains) - Method in class org.apache.jackrabbit.oak.query.fulltext.FullTextVisitor.FullTextVisitorBase
-
- visit(FullTextAnd) - Method in class org.apache.jackrabbit.oak.query.fulltext.FullTextVisitor.FullTextVisitorBase
-
- visit(FullTextOr) - Method in class org.apache.jackrabbit.oak.query.fulltext.FullTextVisitor.FullTextVisitorBase
-
- visit(FullTextContains) - Method in interface org.apache.jackrabbit.oak.query.fulltext.FullTextVisitor
-
Visit an "contains" expression.
- visit(FullTextAnd) - Method in interface org.apache.jackrabbit.oak.query.fulltext.FullTextVisitor
-
Visit an "and" expression.
- visit(FullTextOr) - Method in interface org.apache.jackrabbit.oak.query.fulltext.FullTextVisitor
-
Visit an "or" expression.
- visit(FullTextTerm) - Method in interface org.apache.jackrabbit.oak.query.fulltext.FullTextVisitor
-
Visit a term