|
||||||||||
| PREV NEXT | FRAMES NO FRAMES | |||||||||
ConstraintViolationException.
JackrabbitAccessControlList
interface.JackrabbitAccessControlManager interface.AuthorizableAction interface that
doesn't perform any action.Blob implementations.ChildNodeEntry implementations.LoginModule interface that can act
as base class for login modules that aim to authenticate subjects against
information stored in the content repository.NodeState implementations.PropertyState implementations.AbstractRebaseDiff serves as base for rebase implementations.AbstractServiceTracker is a base class for composite components
that dynamically look up the available component services from the
whiteboard.AbstractTree provides default implementations for most
read methods of Tree.AbstractTree instance
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.ProtectedNodeImporter implementation that handles access control lists,
entries and restrictions.JackrabbitAccessControlManager interface.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.System.nanoTime() method to calculate an as accurate as possible
time based on occasional calls to System.currentTimeMillis()
to prevent clock drift.
JackrabbitAccessControlEntry interface.EventTypeFilter filters based on the access rights of the observing session.Filter instance that includes an event when the
observing session has sufficient permissions to read the associated item.
name.
b from a and adds the result (diff)
to this instance.
path has been added.
ours has been added to parent which conflicts
with node theirs which has been added in the persistence store.
after was added on the branch but the node
exists already in the trunk.
ours has been added to parent which conflicts
with property theirs which has been added in the persistence store.
after was added on the branch but the property
exists already in the trunk.
Observer for receiving notifications about changes reported to
this change dispatcher.
Observer.
EventFilter implementation excludes events for child nodes
of added nodes.RepositoryPermission instance that always returns true.
TreePermission which always returns true and thus grants
all permissions.
CompiledPermissions interface that grants full
permission everywhere.ConflictHandler implementation resolves conflicts to
ConflictHandler.Resolution.THEIRS and in addition marks nodes where a
conflict occurred with the mixin rep:MergeConflict:PropertyState instances
of the given type.
PropertyState instances
of the given type.
Blob implementations is based on an array of bytes.true.
CommitFailedException instance using the
appropriate RepositoryException subclass based on the
type of the given exception.
CommitFailedException instance using the
appropriate RepositoryException subclass based on the
type of the given exception.
false.
Credentials and returns true if
the validation was successful.
Authentication interface defines methods to validate
Credentials during the
login step of the
authentication process.AuthenticationConfiguration with the
following characteristics:
LoginContextProvider: Returns the default implementation of
LoginContextProvider that handles standard JAAS based logins and
deals with pre-authenticated subjects.
AuthInfo instances provide access to information related
to authentication and authorization of a given content session.AuthorizableAction interface provide an implementation
specific way to execute additional validation or write tasks upon
User creation,
Group creation,
Authorizable removal and
User password modification.
Note, that in contrast to Validator
the authorizable actions will only be enforced when user related content
modifications are generated by using the user management API.AuthorizableActionProvider is used to provide AuthorizableActions
for each instance of UserManager.AuthorizableNodeName is in charge of generating a valid node
name from a given authorizable ID.AuthorizableNodeName interface
that uses the specified authorizable identifier as node name
escaping
any illegal JCR chars.AccessControlConfiguration.UnsupportedRepositoryOperationException
Command implementation.ImportBehavior.IGNORE but in addition tries to circumvent the
problem.
Iterable<Blob> to array of PropertyType.BINARY
Blob to PropertyType.BINARY
PropertyState from an array of bytes.
PropertyState from an array of bytes.
PropertyState from a Blob.
PropertyState from a Value.
PropertyState from a list of byte arrays.
PropertyState from a list of Blob.
BlobGCMBean based on a BlobGarbageCollector.NodeStoreBlob instances to corresponding
serialization identifiers.CommitRateLimiter.unblockCommits() is called.
Boolean to PropertyType.BOOLEAN
PropertyState from a boolean.
PropertyState from a list of booleans.
Iterable<Boolean> to array of PropertyType.BOOLEAN
FilterProvider reflecting the current state of this builder.
KernelNodeBuilder unless this is not
a root node or KernelNodeState.isBranch is true in which case a
MemoryNodeBuilder is returned.
PasswordUtil.buildPasswordHash(String, String, int, int) but retrieving
the parameters for hash generation from the specified configuration.
DocumentStore that provides caching information.Tree associated with
this TreePermission instance.
Tree for
which this TreePermission instance has been created.
true if read access is granted to the Tree associated
with this instance and the whole subtree defined by it including all
properties.
true if all properties of the Tree associated with
this instance can be read.
ours has been changed in parent while it was
also changed to a different value (theirs) in the persistence store.
after was changed on the branch but was
already changed to before in the trunk.
path has been changed.
ours has been changed in parent while it was
removed in the persistence store.
after was changed on the branch but was
deleted already in the trunk.
ours has been changed in parent while it was
removed in the persistence store.
after was changed on the branch but was
deleted already in the trunk.
ChangeDispatcher instance dispatches content changes
to registered Observers.tree is versionable and throws a UnsupportedRepositoryOperationException if it is not.
ChildNodeEntry instance represents the child node states of a
NodeState.TreeConstants.OAK_CHILD_ORDER property.LoginModule.login().
Clock.Fast.getTime() method returns
instantaneously thanks to a background task that takes care of the
actual time-keeping work.BackgroundObserver.contentChanged(NodeState, CommitInfo)
calls to the background observer.
Closeable.
BlobStore to store blobs in a cloud blob store.Command framework provides an way to encapsulate specific actions
of the {code MicroKernel}.info
map in Root.commit(java.util.Map)
ContentSession
interface indicating that committing a given set of changes failed.CommitHook can be used to block or delay commits for any length of time.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.
base state with this
state.
PermissionProvider.AuthorizableActionProviders into a single
provider.CompositeAuthorizationConfiguration that combines different
authorization models.SecurityConfigurations that can
combine different implementations.CompositeInitializer.initialize(NodeBuilder) call in sequence to all the
component initializers.RestrictionPatterns into a single pattern.PrincipalConfiguration that combines different principal provider
implementations that share a common principal manager implementation.PrincipalProvider implementation that aggregates a list of principal
providers into a single.QueryIndexProvider aggregates a list of query index providers
into a single query index provider.CompositeRegistration.unregister().RestrictionProvider implementations
into a single provider.TokenConfiguration that combines different token provider implementations.TokenProviders into a single
provider.CompositeWorkspaceInitializer.initialize(org.apache.jackrabbit.oak.spi.state.NodeBuilder, String)
calls in sequence to all the component initializers.Configurations for built-in LoginModule implementations.AbstractRebaseDiff implements a NodeStateDiff,
which performs the conflict handling as defined in MicroKernel.rebase(String, String)
on the Oak SPI state level by annotating conflicting items with conflict
markers.ConflictHandler is responsible for handling conflicts which happen
on Root.rebase() and on the implicit rebase operation which
takes part on Root.commit().ConflictHandler implementation wraps another conflict handler
and forwards all calls to the wrapped handler.Validator which checks the presence of conflict markers
in the tree in fails the commit if any are found.true if this instance contains a configuration entry with
the specified key irrespective of the defined value; false otherwise.
true if this document contains an entry for the
given revision in the NodeDocument.REVISIONS map.
MicroKernel-based implementation of
the ContentRepository interface.Context represents item related information in relation to a
dedicated SecurityConfiguration.Context interface that always returns
false.PropertyStates
of different types.PropertyState instances
of the given type.
TreeLocation instance for a tree
TreeLocation instance for the item
at the given path in root.
create(root, "/")
offset and max.
Blob that
contains that binary.
Blob from the given input stream.
indexNode.
indexNode.
indexNode of the provided propertyIndexType.
indexNode of the provided
propertyIndexType.
indexNode of the provided
propertyIndexType.
PropertyState from a long.
PropertyState from a list of longs.
PropertyState based on a Value.
PropertyState based on a list of
Value instances.
PropertyState from a string.
PropertyState.
PropertyState where the Type of the property state
is inferred from the runtime type of T according to the mapping
established through Type.
Root instance after logging in to the
default workspace with no credentials.
TokenInfo.
userId
and the specified attributes.
Value based on a PropertyState.
Value based on a PropertyValue.
Values based on a PropertyState.
Values based on a PropertyState.
Credentials.User.getCredentials()Cursors.AbstractCursors.PathCursor implements a simple Cursor that iterates
over a String based path Iterable.Backend wrapper over Jackrabbit DataStore which enables using
a CachingDataStore for local file caching.String to PropertyType.DATE
PropertyState from a date.
PropertyState from a list of dates.
Iterable<String> to array of PropertyType.DATE
DateVersionSelector that will select the latest
version of all those that are older than the given timestamp.
BigDecimal to PropertyType.DECIMAL
PropertyState from a decimal.
PropertyState from a list of decimals.
Iterable<BigDecimal> to array of PropertyType.DECIMAL
jsonString given its split.
jsonString given its split.
AuthorizableNodeName instance.
UserConstants.PARAM_ADMIN_ID
UserConstants.PARAM_ANONYMOUS_ID
UserConstants.PARAM_DEFAULT_DEPTH
UserConstants.PARAM_GROUP_PATH
PermissionConstants.PARAM_READ_PATHS configuration parameter.
UserConstants.PARAM_USER_PATH
AuthorizableActionProvider interface
that allows to config all actions provided by the OAK.CommandExecutor interface.ConflictHandler always returns the same resolution.ConflictHandler which always returns resolution.
EventHandler that
does nothing.ExecutorService used for scheduling concurrent tasks.
MoveValidator that does nothing by default and doesn't recurse into subtrees.ScheduledExecutorService used for scheduling background tasks.
AccessManager defines the specified
acceessControlPolicy at the given absPath.
Tree is the root of a subtree defined by
the security module that exposes this Context instance.
TreeLocation is defined by the security
module that exposes this Context instance.
PropertyState is defined by the security
module that exposes this Context instance.
Tree is defined by the security
module that exposes this Context instance.
theirs changed in the persistence store while it has been
deleted locally.
before was deleted in the branch but was
already changed in the trunk.
theirs changed in the persistence store while it has been
deleted locally.
before was deleted in the branch but was
already changed in the trunk.
path has been deleted.
name has been removed in parent while it was
also removed in the persistence store.
before was deleted in the branch but was
already deleted in the trunk.
ours has been removed in parent while it was
also removed in the persistence store.
before was deleted in the branch but was
already deleted in the trunk.
EventFilter implementation excludes events for child nodes
of removed nodes.Repositorypermissions that are not present in
the otherPermissions, i.e.
this is included in other empty
privilege bits is returned.
before and after for
debugging purposes.
{ "propertyNames"="foobar", "direction"="ascending" }
true if the given credentials indicate that a new token
needs to be issued.
BlobReferenceRetriever for the DocumentNodeStore.DocumentStore.DocumentStore.value.
Double to PropertyType.DOUBLE
PropertyState from a double.
PropertyState from a list of doubles.
Iterable<Double> to array of PropertyType.DOUBLE
Editor instance provided by the EditorProvider
passed to the constructor.RepositoryPermission instance that always returns false.
TreePermission which always returns false not granting
any permissions.
RestrictionPattern that always
returns true and thus matches all items or paths.
PrincipalIterator.
PropertyState
PropertyState implementations
providing default implementation which correspond to a property
without any value.name
propertyName of the given propertyType into
a json string, which is prefixed with a type code.
protectedParent has bee completed.
Microkernel
if other is also of type KernelBlob.
Blob instances are considered equal iff they have the
same SHA-256 hash code are equal.
true if there are no
differences.
string for matching in jcr escaped node names
EventHandler callbacks by recursing down a content diff
in a way that guarantees that only a finite number of callbacks
will be made during a EventGenerator.generate() method call, regardless
of how large or complex the content diff is.EventTypeFilter filters based on event types as defined
by ObservationManager.addEventListener().Filter instance that includes all events matching
the eventTypes bit mask.
EventListener
indicates that cluster external observation events must not be reported to that
event listener.Command and returns its result.
Command and returns the result.
Tree or
PropertyState for this TreeLocation
is available.
NodeBuilder implementations to indicate
support for optimised move and copy operations.FileStoreBackupRestoreMBean based on a file.NodeStore.FilterProvider instances.EventFilter for observation
events and a filter for commits.EventFilter instanceskey.
key.
Query.
TreeConstants.OAK_CHILD_ORDER
property.
CompositeData encoding
of a status to a Status instance.
relPath relative to
Selectors.PARENT
Type with the given string representation.
OrderDirection from a provided String.
Type for a given type tag and array flag.
relPath relative to
Selectors.THIS
EventHandler callbacks based
on the content changes that have yet to be processed.
authorizableId.
Descriptors interface.base descriptors as base.
key.
oldUUID has been mapped
or null if no such mapping exists.
null if no attribute
with that attributeName exists.
Credentials originally passed to
Session.impersonate(javax.jcr.Credentials).
null if none exists yet.
MicroKernel.write(java.io.InputStream)
Blob with the given reference.
Blob with the given blobId.
Command for MongoMicroKernel#getLength(String)propertyName.
startTime.
Tree.
name.
null if changes within that child are not to be processed.
TreeConstants.OAK_CHILD_ORDER property is set.
TreePermission for the tree identified by the specified
childName and childState, which is a child of the tree
associated with this instanceof TreePermission.
Tree instance.
Tree instance taking
access restrictions into account.
revision or
null if this document does not have a commit root entry for
the given revision.
configClass.
SecurityConfigurations.
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.
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.
ContentSession from which this root was acquired
type.
CredentialsCallback,
looking for a AbstractLoginModule.SHARED_KEY_CREDENTIALS entry in the
shared state (see also AbstractLoginModule.getSharedCredentials() and finally by
searching for valid credentials in the subject.
Credentials that have been set before using
CredentialsCallback.setCredentials(javax.jcr.Credentials).
Clock.getTime() value
as a Date instance.
Clock.getTimeIncreasing() value
as a Date instance.
Clock.getTimeMonotonic() value
as a Date instance.
DB.
Configuration for the default OAK authentication
setup which only handles login for standard JCR credentials.
parent named
nodeName with a default primary type.
Repository.
Filter for the passed before and after
states.
Cache lookup methods have returned a cached value.
ManagementOperation has an unique id
associated with it.
AuthInfo present with the editing session that want
to impersonate.
ReadOnlyNodeTypeManager that reads node
type information from the tree at NodeTypeConstants.NODE_TYPES_PATH.
Configuration backwards compatible with the default
Jackrabbit 2.x authentication setup.
path.
path.
Cache lookup methods attempted to load new
values.
Cache lookup methods threw an exception while loading a
new value.
Cache lookup methods have successfully loaded a new value.
LoginContextProvider using standard
JAAS
functionality.
Cache lookup methods have returned an uncached (newly
loaded) value, or null.
NameMapper to be used by this node type manager.
DocumentNodeState as seen at the given
readRevision.
Command should be retried in
case of an error or false result.
null if no
such mapping exists because the given JCR name contains an unknown
namespace URI or prefix, or is otherwise invalid.
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.
PathMapper.getOakPath(String), but preserving the index information
ValueImpl.getString() unless that names and paths are returned in their
Oak representation instead of being mapped to their JCR representation.
NodeUtil.getChild(String) and NodeUtil.addChild(String, String)
in case no tree exists with the specified name.
SecurityConfiguration
accessible by this provider.
identifier or null.
PropertyState.
PropertyState.
FilterProvider.getFilter(NodeState, NodeState) applies.
RestrictionPattern for the restriction information
stored with specified tree.
Session.hasPermission(String, String).
null if the
principal does not exist.
PrincipalManager that can be used
to query and retrieve principals such as needed for JCR access control
management.
PrincipalProvider that should be used to handle
this authentication.
PrincipalProviderCallback.setPrincipalProvider(org.apache.jackrabbit.oak.spi.security.principal.PrincipalProvider)
or null.
PrincipalProvider.
AuthInfo instance.
userId for
the configured principal provider.
userID to a valid principal and
it's group membership.
PrivilegeManager.
tree.
Principals associated with this provider instance for the
specified Tree.
PropertyState for this TreeLocation.
null
if the property is not set.
null if no such property exists.
Status of a property state or null.
null if such
a reference is not available.
tree that match
the given name and node type constraints.
RepositoryPermission
associated with the Root as specified in CompiledPermissions.refresh(org.apache.jackrabbit.oak.core.ImmutableRoot, String)
RepositoryPermission for the set of Principals
associated with this provider instance.
Cache lookup methods have returned either a cached or
uncached value.
Root object from the callback handler using
a new RepositoryCallback and keeps the value as private field.
SecurityProvider object from the callback
handler using a new SecurityProviderCallback and keeps the value as
private field.
T that are currently available.
Status of this tree instance.
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.
TokenInfo associated with the specified login token
or null.
TokenProvider.
TokenProviderCallback.setTokenProvider(TokenProvider)
or null.
TokenProvider.
Tree at the given absolute path.
identifier or null.
Tree for this TreeLocation.
path from
the location of the start tree or null if path results
in a parent of the root.
tree.
TreePermission for the set of Principals associated
with this provider at the specified tree.
UserManager that should be used to handle
this authentication.
UserManagerCallback.setUserManager(org.apache.jackrabbit.api.security.user.UserManager)
or null.
index.
index.
PropertyDefinitionImpl.getDefaultValues().
null if none exists yet.
uuid.
Whiteboard object from the callback
handler using a new WhiteboardCallback and keeps the value as
private field.
WhiteboardCallback.setWhiteboard(Whiteboard)
or null.
ContentSession instance has
been created for.
Root instance
that can be used to persist the requested namespace changes (and
nothing else).
ReadWriteNodeTypeManager.registerNodeType(NodeTypeDefinition, boolean),
ReadWriteNodeTypeManager.registerNodeTypes(NodeTypeDefinition[], boolean),
ReadWriteNodeTypeManager.unregisterNodeType(String) and ReadWriteNodeTypeManager.unregisterNodeTypes(String[])
to acquire a fresh Root instance that can be used to persist the
requested node type changes (and nothing else).
Filter implementation supports filtering on paths using
simple glob patterns.GuestLoginModule is intended to provide backwards compatibility
with the login handling present in the JCR reference implementation located
in jackrabbit-core.Tree instance exists.
AbstractPropertyState.equals(Object) method is implemented.
AbstractChildNodeEntry.equals(Object) method is implemented.
AbstractNodeState.equals(Object) method is implemented.
privilegeNames
are granted at the given tree.
PrivilegeManager
is granted the privileges identified by the specified privilege names
for the given tree.
JackrabbitAccessControlList interface that only
allows for reading.UnmodifiableAccessControlList
PrivilegeDefinition interface.NodeState (or ImmutableTree)
passed to the constructor.Tree interface in order to provide
the much feature rich API functionality for a given NodeState.Credentials interface used to distinguish
a regular login request from Session.impersonate(javax.jcr.Credentials).true if all privileges defined by the specified
otherBits are present in this instance.
InitialContent implements a RepositoryInitializer and
registers built-in node types when the micro kernel becomes available.true if the privilege described by this definition
is abstract.
false.
true if the tree is checked out; otherwise
false.
true if the given revision is marked
committed.
true if a revision tagged with the given revision
should be considered committed, false otherwise.
true if this privilege bits includes no privileges
at all.
true if the token has already expired; false otherwise.
true if the given permissions are granted on the
item identified by parent and optionally property.
true if the given permissions are granted on the
tree identified by the specified path.
Principals
associated with this provider instance for the item identified by the
given tree and optionally property.
Principals associated with this provider instance.
true if the specified repository level permissions are
granted; false otherwise.
true if all specified permissions are granted on the
Tree associated with this TreePermission instance;
false otherwise.
true if all specified permissions are granted on the
PropertyState associated with this TreePermission instance;
false otherwise.
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.
true if typeName is of the specified primary node
type or mixin type, or a subtype thereof.
true if the specified string doesn't start with a
valid algorithm name in curly brackets.
NodeBuilder.setChildNode(String) call.
NodeBuilder.setProperty(PropertyState) call.
true if hash of the specified password equals the
given hashed password.
true if hash of the specified password equals the
given hashed password.
true if key is a valid single-value
descriptor; otherwise returns false
true if key is a valid single-value
descriptor; otherwise returns false
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.
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.
true if the specified path is null.
true if the given tree is of type
mix:versionable; false otherwise.
LoginContext class with the
LoginContext interface used by Oak.Privilege.JCR_ADD_CHILD_NODES privilege
Privilege.JCR_ALL privilege
ChildOrderConflictHandler
and AnnotatingConflictHandler.
Privilege.JCR_LIFECYCLE_MANAGEMENT privilege
Privilege.JCR_LOCK_MANAGEMENT privilege
Privilege.JCR_MODIFY_ACCESS_CONTROL privilege
Privilege.JCR_MODIFY_PROPERTIES privilege
Privilege.JCR_NODE_TYPE_MANAGEMENT privilege
Privilege.JCR_READ privilege
Privilege.JCR_READ_ACCESS_CONTROL privilege
Privilege.JCR_REMOVE_CHILD_NODES privilege
Privilege.JCR_REMOVE_NODE privilege
Privilege.JCR_RETENTION_MANAGEMENT privilege
Privilege.JCR_VERSION_MANAGEMENT privilege
Privilege.JCR_WRITE privilege
Blob implementation is backed by a binary stored in
a MicroKernel.NodeState implementation based on the MicroKernel
interface.path and revision.
NodeStore implementations against MicroKernel.NodeStoreBranch based on MicroKernel branching and merging.MicroKernel.
MicroKernel.diff(String, String, String, int)
is used for diffing.
DocumentStore wrapper and logs all calls.ContentSession instance for accessing repository content
inside the specified workspace as the authenticated user.
LoginContext
class.Credentials
against the repository.Long to PropertyType.LONG
Iterable<Long> to array of PropertyType.LONG
ManagementOperation is a background, which that can be
executed by an Executor.ManagementOperation of the given name.
ManagementOperation.true if the specified credentials can be successfully
validated against the information stored in this instance.
true if the underlying restriction matches the specified
tree or property state.
true if the underlying restriction matches the specified
path.
true if the underlying restriction matches for repository
level permissions.
base state.
KernelRootBuilder.merge(CommitHook, CommitInfo)
if builder is a KernelNodeBuilder instance.
builder into
the store.
MergeSortedIterators is a specialized implementation of a
merge sort of already sorted iterators of some type of comparable elements.true if there are
differences within the properties or direct child nodes.
MongoDB representation of a blob.AbstractBlobStore.MongoBlobStore
MongoConnection abstracts connection to the MongoDB.MongoConnection.
BlobStore for MongoDB using GridFS.BlobStoreMongoGridFS
sourcePath to a child at destPath.
MoveDetector is a validator that can detect certain move operations
and reports these to the wrapped MoveValidator by calling
MoveValidator.move(String, String, NodeState).source builder to this builder with the
given new name
newParent is a KernelNodeBuilder this implementation
purges all pending changes before applying the move operation.
newName as a new child of newParent followed
by removing this node.
Root.commit(java.util.Map) .MoveTracker
String to PropertyType.STRING
NamePathMapper interface combines NameMapper and
PathMapper.PropertyState from a name.
PropertyState from a list of names.
Iterable<String> to array of PropertyType.NAME
Exception during the execution and
a given number of retries which has not exceeded.
level of the wrapped cursor c.
Cursors.AbstractCursor over paths.
Cursors.AbstractCursor over paths, and make the result distinct.
Filter.
NodeBuilder for the underlying node state
node states.Observer instances that group changes
by node instead of tracking them down to individual properties.NodeStore to which transient changes can be applied and later merged
back or discarded.NodeStore-based MicroKernel implementation.NodeTypeIndexProvider is a QueryIndexProvider for
NodeTypeIndex instances.CompiledPermission interface that denies all permissions.ContentRepository instances with
a set of specified plugin components.Observable supports attaching Observer instances for
listening to content changes.params sequentially.
AuthorizationConfiguration which grants
full access to any Subject.SecurityProvider implementation that allow every subject
to authenticate and grants it full access everywhere.Tree before the sibling tree with the given
name.
ContentMirrorStoreStrategy but the order of the keys is kept by using the
following structure
:index : {
:start : { :next = n1 },
n0 : { /content/foo/bar(match=true), :next=n3 },
n1 : { /content/foo1/bar(match=true), :next=n0 },
n2 : { /content/foo2/bar(match=true), :next= }, //this is the end of the list
n3 : { /content/foo3/bar(match=true), :next=n2 }
}
ConflictHandler which always return ConflictHandler.Resolution.OURS.
AuthorizableActionProvider
to be used with the given user management implementation.
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.
EventFilter was called.
listener
about the result or any error that may occur during parsing.
PasswordChangeAction asserts that the upon
PasswordChangeAction.onPasswordChange(org.apache.jackrabbit.api.security.user.User, String,
org.apache.jackrabbit.oak.api.Root, org.apache.jackrabbit.oak.namepath.NamePathMapper)
a different, non-null password is specified.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.
String to PropertyType.PATH
PathMapper instances provide methods for mapping paths from their JCR
string representation to their Oak representation and vice versa.PropertyState from a path.
PropertyState from a list of paths.
Iterable<String> to array of PropertyType.PATH
PermissionEntryCache caches the permission entries of principals.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.PermissionStoreImpl...ValidatorProvider implementation for permission evaluation associated
with write operations.toPersist and base
to the underlying store.
AccessControlManager,
namely the interaction of multiple managers within a
single repository.CommitHook interface that indicates that this
commit hook implementation must be executed after the
validation hooks.PreAuthenticatedLogin is used as marker in the shared map of the login context.PrincipalConfigurationJackrabbitPrincipal interface.RangeIteratorAdapter implementing the
PrincipalIterator interface.Iterator of principals.
Principals.
PrincipalManager interface.PermissionEntries holds the permission entries of one principalPrincipalProvider defines methods to provide access to sources
of Principals.PrincipalProvider to the
login module.rep:Privilege node type
PrivilegeDefinition interface defines the characteristics of
a JCR Privilege.ReferenceChangeTracker.getProcessedReferences().
PropertyBuilder for building in memory PropertyState instances.PropertyState instances
of the given type.
PropertyIndexAsyncReindexMBean based on a
Runnable.PropertyState instances.PropertyValue implementation that wraps a PropertyStatePropertyValue instances.ProtectedNodeImporter and ProtectedPropertyImporter.ProtectedNodeImporter provides means to import protected
Nodes and the subtree defined below such nodes.ProtectedPropertyImporter is in charge of importing single
properties with a protected PropertyDefinition.RevisionContext.
key.
ReferenceChangeTracker.get(String).
DataSource.
DataSource.
Command for MongoMicroKernel#read(String, long, byte[], int, int)
FIXME - Reading from large blobs with small increments is slow in this implementation.ReadBlobCommandMongo.
UnsupportedOperationException on
all attempts to modify the given base state.NodeTypeManager with support for reading
node types from the Tree returned by ReadOnlyNodeTypeManager.getTypes().ReadOnlyVersionManager provides implementations for read-only
version operations modeled after the ones available in VersionManager.ReadWriteNodeTypeManager extends the ReadOnlyNodeTypeManager
with support for operations that modify node types.KernelRootBuilder.rebase() if builder
is a KernelNodeBuilder instance.
ConflictAnnotatingRebaseDiff for resolving
conflicts.
builder on top of the current root state.
String to PropertyType.REFERENCE
PropertyState from a reference.
PropertyState from a list of references.
Iterable<String> to array of PropertyType.REFERENCE
ReadWriteNodeTypeManager implementation methods to
refresh the state of the session associated with this instance.
Root.
PermissionProvider.
UnsupportedRepositoryOperationException.
UnsupportedRepositoryOperationException.
RepositoryManagementMBean based
on a Whiteboard instance, which is used to look up individual
service providers for backup (FileStoreBackupRestoreMBean), data store
garbage collections (BlobGCMBean) and revision store garbage
collections (RevisionGCMBean).RepositoryPermission allows to evaluate permissions that have
been defined on the repository level and which consequently are not bound
to a particular item.KernelRootBuilder.reset() if builder
is a KernelNodeBuilder instance.
builder by throwing away all its changes and
setting its base state to the current root state.
TokenInfo.
rev and
the associated commit tag.
Restriction object represents a "live" restriction object that
has been created using the Jackrabbit specific extensions of the
AccessControlEntry interface.RestrictionDefinition interface provides methods for
discovering the static definition of any additional policy-internal refinements
of the access control definitions.RestrictionDefinition interface.RestrictionImplrestriction applies to a given
item or path.AccessControlConstants.REP_GLOB: A simple paths matching pattern.RevisionGCMBean based on a Runnable.Root instance serves as a container for a Tree.PropertyState instances
of the given type.
PropertyState instances
of the given type.
SecurityProvider.SecurityProvider instance with the given configuration
parameters.
BlobReferenceRetriever to retrieve blob references from the
SegmentTracker.Selector implementationsSession information and statistics.PrincipalProvider that is being used during the
authentication process.
DataSource to use for the RDB document and blob
stores.
DataSources to use for the RDB document and blob
stores.
TokenProvider that is being used during the
authentication process.
UserManager that is being used during the
authentication process.
Whiteboard that is being used during the
authentication process.
System.currentTimeMillis(),
which is known to be rather slow on some platforms.
index.
index.
jsonString, which is prefixed with a type code
at the location where the prefix ends.
ModifiedNodeState instances into equivalent
MemoryNodeStates.
StableRevisionComparator implements a revision comparator, which
is only based on stable information available in the two revisions presented
to this comparator.childInfo and it's properties.
whiteboard.
String to PropertyType.STRING
Blob implementations is based on a string.PropertyState from a list of strings.
PropertyState from a string.
Iterable<String> to array of PropertyType.STRING
DocumentStore wrapper which synchronizes on all
methods.MutableRoot to be used
when an usage of the system internal subject is needed.PropertyType.
TextValue represents a serialized property value read
from a System or Document View XML document.ConflictHandler which always return ConflictHandler.Resolution.THEIRS.
EventFilter was
called or a non existing node in the case of a property call back.
CompositeData
encoding of the respective status.
TokenConfiguration interface.TokenInfo provides data associated with a login token and
basic methods to verify the validity of token credentials at given
point in time.LoginModule implementation that is able to handle login request
based on TokenCredentials.ContentRepository
tree at the time the instance was acquired from a ContentSession.TreeTreeLocation denotes a location inside a tree.TreePermission allow to evaluate permissions defined for a given
Tree and it's properties.Tree that are not provided
by the API.property types.Type and the code used to prefix
its json serialisation.node states./test/node, the index
structure will be /oak:index/index/@key:Filter implementation, which can be parametrised by
a UniversalFilter.Selector and a Predicate.Filters to NodeState instances,
which should be used for determining inclusion or exclusion of the associated event.UnsupportedRepositoryOperationException.
UnsupportedRepositoryOperationException.
UpdateOps to
Documents.String to PropertyType.URI
PropertyState from a URI.
PropertyState from a list of URIs.
Iterable<String> to array of PropertyType.URI
UserConfiguration.UserManager to the
login module.Utils provide some utility methods.PermissionConstants.PARAM_PERMISSIONS_JR2 configuration parameter that
contains all value entries.
ValueFactory interface.ValueFactory.
Value based on PropertyState.VersionExceptionCode contains the codes for version related
commit failures.String to PropertyType.WEAKREFERENCE
PropertyState from a weak reference.
PropertyState from a list of weak references.
Iterable<String> to array of PropertyType.WEAKREFERENCE
AuthorizableActionProvider based on the available
whiteboard services.Whiteboard.EditorProvider based on the available
whiteboard services.Executor based on the available whiteboard services.IndexEditorProvider based on the available
whiteboard services.QueryIndexProvider based on the available
whiteboard services.RestrictionProvider based on the available
whiteboard services.null workspace name.
Command for MongoMicroKernel#write(InputStream)WriteBlobCommandMongo
|
||||||||||
| PREV NEXT | FRAMES NO FRAMES | |||||||||