You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@jackrabbit.apache.org by md...@apache.org on 2011/09/02 18:58:52 UTC

svn commit: r1164631 [2/2] - in /jackrabbit/sandbox/jackrabbit-mk: jackrabbit-jcr-commons/src/main/java/org/apache/jackrabbit/commons/ jackrabbit-jcr-commons/src/main/java/org/apache/jackrabbit/commons/flat/ jackrabbit-spi-commons/src/main/java/org/apa...

Modified: jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi/src/main/java/org/apache/jackrabbit/spi/RepositoryService.java
URL: http://svn.apache.org/viewvc/jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi/src/main/java/org/apache/jackrabbit/spi/RepositoryService.java?rev=1164631&r1=1164630&r2=1164631&view=diff
==============================================================================
--- jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi/src/main/java/org/apache/jackrabbit/spi/RepositoryService.java (original)
+++ jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi/src/main/java/org/apache/jackrabbit/spi/RepositoryService.java Fri Sep  2 16:58:50 2011
@@ -85,7 +85,7 @@ public interface RepositoryService {
      * @return The <code>IdFactory</code>.
      * @throws RepositoryException If an error occurs.
      */
-    public IdFactory getIdFactory() throws RepositoryException;
+    IdFactory getIdFactory() throws RepositoryException;
 
     /**
      * Return the <code>NameFactory</code>.
@@ -93,7 +93,7 @@ public interface RepositoryService {
      * @return The <code>NameFactory</code>.
      * @throws RepositoryException If an error occurs.
      */
-    public NameFactory getNameFactory() throws RepositoryException;
+    NameFactory getNameFactory() throws RepositoryException;
 
     /**
      * Return the <code>PathFactory</code>.
@@ -101,7 +101,7 @@ public interface RepositoryService {
      * @return The <code>PathFactory</code>.
      * @throws RepositoryException If an error occurs.
      */
-    public PathFactory getPathFactory() throws RepositoryException;
+    PathFactory getPathFactory() throws RepositoryException;
 
     /**
      * Return the <code>QValueFactory</code> defined with this SPI implementation.
@@ -109,7 +109,7 @@ public interface RepositoryService {
      * @return The <code>QValueFactory</code>.
      * @throws RepositoryException If an error occurs.
      */
-    public QValueFactory getQValueFactory() throws RepositoryException;
+    QValueFactory getQValueFactory() throws RepositoryException;
 
     /**
      * Returns a {@link ItemInfoCache} for the given <code>SessionInfo</code>.
@@ -117,7 +117,7 @@ public interface RepositoryService {
      * @return
      * @throws RepositoryException
      */
-    public ItemInfoCache getItemInfoCache(SessionInfo sessionInfo) throws RepositoryException;
+    ItemInfoCache getItemInfoCache(SessionInfo sessionInfo) throws RepositoryException;
 
     //--------------------------------------------------------------------------
     /**
@@ -130,7 +130,7 @@ public interface RepositoryService {
      * @see javax.jcr.Repository#getDescriptorKeys()
      * @see javax.jcr.Repository#getDescriptor(String)
      */
-    public Map<String, QValue[]> getRepositoryDescriptors() throws RepositoryException;
+    Map<String, QValue[]> getRepositoryDescriptors() throws RepositoryException;
 
     //-----------------------------------< SessionInfo creation and release >---
     /**
@@ -149,7 +149,7 @@ public interface RepositoryService {
      *                                  is not recognized.
      * @throws RepositoryException      if an error occurs.
      */
-    public SessionInfo obtain(Credentials credentials, String workspaceName)
+    SessionInfo obtain(Credentials credentials, String workspaceName)
             throws LoginException, NoSuchWorkspaceException, RepositoryException;
 
     /**
@@ -166,7 +166,7 @@ public interface RepositoryService {
      *                                  is not recognized.
      * @throws RepositoryException      if an error occurs.
      */
-    public SessionInfo obtain(SessionInfo sessionInfo, String workspaceName)
+    SessionInfo obtain(SessionInfo sessionInfo, String workspaceName)
             throws LoginException, NoSuchWorkspaceException, RepositoryException;
 
     /**
@@ -180,7 +180,7 @@ public interface RepositoryService {
      * @throws RepositoryException
      * @see javax.jcr.Session#impersonate(javax.jcr.Credentials)
      */
-    public SessionInfo impersonate(SessionInfo sessionInfo, Credentials credentials) throws LoginException, RepositoryException;
+    SessionInfo impersonate(SessionInfo sessionInfo, Credentials credentials) throws LoginException, RepositoryException;
 
     /**
      * Indicates to the <code>RepositoryService</code>, that the given SessionInfo
@@ -189,7 +189,7 @@ public interface RepositoryService {
      * @param sessionInfo
      * @throws javax.jcr.RepositoryException
      */
-    public void dispose(SessionInfo sessionInfo) throws RepositoryException;
+    void dispose(SessionInfo sessionInfo) throws RepositoryException;
 
     //--------------------------------------------------------------------------
     /**
@@ -201,7 +201,7 @@ public interface RepositoryService {
      * @see javax.jcr.Workspace#getAccessibleWorkspaceNames()
      * @see javax.jcr.Workspace#getName()
      */
-    public String[] getWorkspaceNames(SessionInfo sessionInfo) throws RepositoryException;
+    String[] getWorkspaceNames(SessionInfo sessionInfo) throws RepositoryException;
 
     //-----------------------------------------------------< Access Control >---
     /**
@@ -217,7 +217,7 @@ public interface RepositoryService {
      * @see javax.jcr.Session#checkPermission(String, String)
      * @see javax.jcr.Session#hasPermission(String, String) 
      */
-    public boolean isGranted(SessionInfo sessionInfo, ItemId itemId, String[] actions) throws RepositoryException;
+    boolean isGranted(SessionInfo sessionInfo, ItemId itemId, String[] actions) throws RepositoryException;
 
     //------------------------------------------------------< Reading items >---
     /**
@@ -233,7 +233,7 @@ public interface RepositoryService {
      * by the given id.
      * @throws javax.jcr.RepositoryException
      */
-    public QNodeDefinition getNodeDefinition(SessionInfo sessionInfo, NodeId nodeId) throws RepositoryException;
+    QNodeDefinition getNodeDefinition(SessionInfo sessionInfo, NodeId nodeId) throws RepositoryException;
 
     /**
      * Returns the <code>QPropertyDefinition</code> for the <code>Property</code>
@@ -247,7 +247,7 @@ public interface RepositoryService {
      * identified by the given id.
      * @throws javax.jcr.RepositoryException
      */
-    public QPropertyDefinition getPropertyDefinition(SessionInfo sessionInfo, PropertyId propertyId) throws RepositoryException;
+    QPropertyDefinition getPropertyDefinition(SessionInfo sessionInfo, PropertyId propertyId) throws RepositoryException;
 
     /**
      * Method used to 'batch-read' from the persistent storage. It returns the
@@ -274,7 +274,8 @@ public interface RepositoryService {
      * @see javax.jcr.Node#getVersionHistory()
      * @see javax.jcr.version.Version#getContainingHistory()
      */
-    public Iterator<? extends ItemInfo> getItemInfos(SessionInfo sessionInfo, ItemId itemId) throws ItemNotFoundException, RepositoryException;
+    Iterator<? extends ItemInfo> getItemInfos(SessionInfo sessionInfo, ItemId itemId) throws ItemNotFoundException,
+            RepositoryException;
 
     /**
      * Returns an Iterator of <code>ChildInfo</code>s present on the
@@ -287,7 +288,8 @@ public interface RepositoryService {
      * @throws ItemNotFoundException
      * @throws RepositoryException
      */
-    public Iterator<ChildInfo> getChildInfos(SessionInfo sessionInfo, NodeId parentId) throws ItemNotFoundException, RepositoryException;
+    Iterator<ChildInfo> getChildInfos(SessionInfo sessionInfo, NodeId parentId) throws ItemNotFoundException,
+            RepositoryException;
 
     /**
      * Returns the {@link PropertyId Id}s of the properties that are referencing
@@ -311,7 +313,8 @@ public interface RepositoryService {
      * @see PropertyInfo#getId()
      * @since JCR 2.0
      */
-    public Iterator<PropertyId> getReferences(SessionInfo sessionInfo, NodeId nodeId, Name propertyName, boolean weakReferences) throws ItemNotFoundException, RepositoryException;
+    Iterator<PropertyId> getReferences(SessionInfo sessionInfo, NodeId nodeId, Name propertyName, boolean weakReferences)
+            throws ItemNotFoundException, RepositoryException;
 
     //-----------------------------------------------< general modification >---
     /**
@@ -331,7 +334,7 @@ public interface RepositoryService {
      * @see javax.jcr.Session#save()
      * @see Batch
      */
-    public Batch createBatch(SessionInfo sessionInfo, ItemId itemId) throws RepositoryException;
+    Batch createBatch(SessionInfo sessionInfo, ItemId itemId) throws RepositoryException;
 
     /**
      * Completes the given {@link Batch} or discard all the previous modifications.
@@ -351,7 +354,9 @@ public interface RepositoryService {
      * @throws RepositoryException
      * @see Batch
      */
-    public void submit(Batch batch) throws PathNotFoundException, ItemNotFoundException, NoSuchNodeTypeException, ValueFormatException, VersionException, LockException, ConstraintViolationException, AccessDeniedException, UnsupportedRepositoryOperationException, RepositoryException;
+    void submit(Batch batch) throws PathNotFoundException, ItemNotFoundException, NoSuchNodeTypeException,
+            ValueFormatException, VersionException, LockException, ConstraintViolationException, AccessDeniedException,
+            UnsupportedRepositoryOperationException, RepositoryException;
 
     //-------------------------------------------------------------< Import >---
     /**
@@ -374,7 +379,8 @@ public interface RepositoryService {
      * @throws RepositoryException
      * @see javax.jcr.Workspace#importXML(String, java.io.InputStream, int)
      */
-    public void importXml(SessionInfo sessionInfo, NodeId parentId, InputStream xmlStream, int uuidBehaviour) throws ItemExistsException, PathNotFoundException, VersionException, ConstraintViolationException, LockException, AccessDeniedException, UnsupportedRepositoryOperationException, RepositoryException;
+    void importXml(SessionInfo sessionInfo, NodeId parentId, InputStream xmlStream, int uuidBehaviour)
+            throws ItemExistsException, PathNotFoundException, VersionException, ConstraintViolationException, LockException, AccessDeniedException, UnsupportedRepositoryOperationException, RepositoryException;
 
     //---------------------------------------------------------< Copy, Move >---
     /**
@@ -396,7 +402,8 @@ public interface RepositoryService {
      * @throws javax.jcr.RepositoryException
      * @see javax.jcr.Workspace#move(String, String)
      */
-    public void move(SessionInfo sessionInfo, NodeId srcNodeId, NodeId destParentNodeId, Name destName) throws ItemExistsException, PathNotFoundException, VersionException, ConstraintViolationException, LockException, AccessDeniedException, UnsupportedRepositoryOperationException, RepositoryException;
+    void move(SessionInfo sessionInfo, NodeId srcNodeId, NodeId destParentNodeId, Name destName)
+            throws ItemExistsException, PathNotFoundException, VersionException, ConstraintViolationException, LockException, AccessDeniedException, UnsupportedRepositoryOperationException, RepositoryException;
 
     /**
      * Clone the subtree identified by the given <code>srcNodeId</code>
@@ -425,7 +432,8 @@ public interface RepositoryService {
      * @see javax.jcr.Workspace#copy(String, String)
      * @see javax.jcr.Workspace#copy(String, String, String)
      */
-    public void copy(SessionInfo sessionInfo, String srcWorkspaceName, NodeId srcNodeId, NodeId destParentNodeId, Name destName) throws NoSuchWorkspaceException, ConstraintViolationException, VersionException, AccessDeniedException, PathNotFoundException, ItemExistsException, LockException, UnsupportedRepositoryOperationException, RepositoryException;
+    void copy(SessionInfo sessionInfo, String srcWorkspaceName, NodeId srcNodeId, NodeId destParentNodeId, Name destName)
+            throws NoSuchWorkspaceException, ConstraintViolationException, VersionException, AccessDeniedException, PathNotFoundException, ItemExistsException, LockException, UnsupportedRepositoryOperationException, RepositoryException;
 
     //------------------------------------------------------< Update, Clone >---
     /**
@@ -443,7 +451,7 @@ public interface RepositoryService {
      * @throws javax.jcr.RepositoryException
      * @see javax.jcr.Node#update(String)
      */
-    public void update(SessionInfo sessionInfo, NodeId nodeId, String srcWorkspaceName) throws NoSuchWorkspaceException, AccessDeniedException, LockException, InvalidItemStateException, RepositoryException;
+    void update(SessionInfo sessionInfo, NodeId nodeId, String srcWorkspaceName) throws NoSuchWorkspaceException, AccessDeniedException, LockException, InvalidItemStateException, RepositoryException;
 
     /**
      * Clone the subtree identified by the given <code>srcNodeId</code>
@@ -469,7 +477,10 @@ public interface RepositoryService {
      * @throws javax.jcr.RepositoryException
      * @see javax.jcr.Workspace#clone(String, String, String, boolean)
      */
-    public void clone(SessionInfo sessionInfo, String srcWorkspaceName, NodeId srcNodeId, NodeId destParentNodeId, Name destName, boolean removeExisting) throws NoSuchWorkspaceException, ConstraintViolationException, VersionException, AccessDeniedException, PathNotFoundException, ItemExistsException, LockException, UnsupportedRepositoryOperationException, RepositoryException;
+    void clone(SessionInfo sessionInfo, String srcWorkspaceName, NodeId srcNodeId, NodeId destParentNodeId, Name destName,
+            boolean removeExisting) throws NoSuchWorkspaceException, ConstraintViolationException, VersionException,
+            AccessDeniedException, PathNotFoundException, ItemExistsException, LockException,
+            UnsupportedRepositoryOperationException, RepositoryException;
 
     //------------------------------------------------------------< Locking >---
     /**
@@ -485,7 +496,7 @@ public interface RepositoryService {
      * @throws javax.jcr.RepositoryException If some other error occurs.
      * @see Node#getLock()
      */
-    public LockInfo getLockInfo(SessionInfo sessionInfo, NodeId nodeId) throws AccessDeniedException, RepositoryException;
+    LockInfo getLockInfo(SessionInfo sessionInfo, NodeId nodeId) throws AccessDeniedException, RepositoryException;
 
     /**
      * Create a lock on the <code>Node</code> identified by the given id.
@@ -504,7 +515,8 @@ public interface RepositoryService {
      * @throws javax.jcr.RepositoryException If another error occurs.
      * @see javax.jcr.Node#lock(boolean, boolean)
      */
-    public LockInfo lock(SessionInfo sessionInfo, NodeId nodeId, boolean deep, boolean sessionScoped) throws UnsupportedRepositoryOperationException, LockException, AccessDeniedException, RepositoryException;
+    LockInfo lock(SessionInfo sessionInfo, NodeId nodeId, boolean deep, boolean sessionScoped)
+            throws UnsupportedRepositoryOperationException, LockException, AccessDeniedException, RepositoryException;
 
     /**
      * Create a lock on the <code>Node</code> identified by the given id.
@@ -528,7 +540,9 @@ public interface RepositoryService {
      * @see javax.jcr.lock.LockManager#lock(String, boolean, boolean, long, String)
      * @since JCR 2.0
      */
-    public LockInfo lock(SessionInfo sessionInfo, NodeId nodeId, boolean deep, boolean sessionScoped, long timeoutHint, String ownerHint) throws UnsupportedRepositoryOperationException, LockException, AccessDeniedException, RepositoryException;
+    LockInfo lock(SessionInfo sessionInfo, NodeId nodeId, boolean deep, boolean sessionScoped, long timeoutHint,
+            String ownerHint) throws UnsupportedRepositoryOperationException, LockException, AccessDeniedException,
+            RepositoryException;
 
     /**
      * Explicit refresh of an existing lock. Existing locks should be refreshed
@@ -545,7 +559,8 @@ public interface RepositoryService {
      * @throws javax.jcr.RepositoryException If another error occurs.
      * @see javax.jcr.lock.Lock
      */
-    public void refreshLock(SessionInfo sessionInfo, NodeId nodeId) throws UnsupportedRepositoryOperationException, LockException, AccessDeniedException, RepositoryException;
+    void refreshLock(SessionInfo sessionInfo, NodeId nodeId) throws UnsupportedRepositoryOperationException,
+            LockException, AccessDeniedException, RepositoryException;
 
     /**
      * Releases the lock on the <code>Node</code> identified by the given
@@ -564,9 +579,11 @@ public interface RepositoryService {
      * @throws javax.jcr.RepositoryException If another error occurs.
      * @see javax.jcr.Node#unlock()
      */
-    public void unlock(SessionInfo sessionInfo, NodeId nodeId) throws UnsupportedRepositoryOperationException, LockException, AccessDeniedException, RepositoryException;
+    void unlock(SessionInfo sessionInfo, NodeId nodeId) throws UnsupportedRepositoryOperationException, LockException,
+            AccessDeniedException, RepositoryException;
 
     //---------------------------------------------------------< Versioning >---
+
     /**
      * Performs a checkin for the <code>Node</code> identified by the given
      * <code>NodeId</code>.
@@ -581,7 +598,8 @@ public interface RepositoryService {
      * @throws javax.jcr.RepositoryException
      * @see javax.jcr.Node#checkin()
      */
-    public NodeId checkin(SessionInfo sessionInfo, NodeId nodeId) throws VersionException, UnsupportedRepositoryOperationException, InvalidItemStateException, LockException, RepositoryException;
+    NodeId checkin(SessionInfo sessionInfo, NodeId nodeId) throws VersionException, UnsupportedRepositoryOperationException,
+            InvalidItemStateException, LockException, RepositoryException;
 
     /**
      * Performs a checkout for the <code>Node</code> identified by the given
@@ -595,7 +613,8 @@ public interface RepositoryService {
      * @throws javax.jcr.RepositoryException
      * @see javax.jcr.Node#checkout()
      */
-    public void checkout(SessionInfo sessionInfo, NodeId nodeId) throws UnsupportedRepositoryOperationException, LockException, RepositoryException;
+    void checkout(SessionInfo sessionInfo, NodeId nodeId) throws UnsupportedRepositoryOperationException, LockException,
+            RepositoryException;
 
     /**
      * Performs a checkout for the <code>Node</code> identified by the given
@@ -612,7 +631,8 @@ public interface RepositoryService {
      * @throws RepositoryException
      * @since JCR 2.0
      */
-    public void checkout(SessionInfo sessionInfo, NodeId nodeId, NodeId activityId) throws UnsupportedRepositoryOperationException, LockException, RepositoryException;
+    void checkout(SessionInfo sessionInfo, NodeId nodeId, NodeId activityId)
+            throws UnsupportedRepositoryOperationException, LockException, RepositoryException;
 
     /**
      * Performs a checkpoint for the <code>Node</code> identified by the given
@@ -626,7 +646,8 @@ public interface RepositoryService {
      * @see javax.jcr.version.VersionManager#checkpoint(String)
      * @since JCR 2.0
      */
-    public NodeId checkpoint(SessionInfo sessionInfo, NodeId nodeId) throws UnsupportedRepositoryOperationException, RepositoryException;
+    NodeId checkpoint(SessionInfo sessionInfo, NodeId nodeId) throws UnsupportedRepositoryOperationException,
+            RepositoryException;
 
     /**
      * Performs a checkpoint for the <code>Node</code> identified by the given
@@ -642,7 +663,9 @@ public interface RepositoryService {
      * @throws RepositoryException
      * @since JCR 2.0
      */
-    public NodeId checkpoint(SessionInfo sessionInfo, NodeId nodeId, NodeId activityId)  throws UnsupportedRepositoryOperationException, RepositoryException;
+    NodeId checkpoint(SessionInfo sessionInfo, NodeId nodeId, NodeId activityId)
+            throws UnsupportedRepositoryOperationException, RepositoryException;
+
     /**
      * Remove the version identified by the specified <code>versionId</code>.
      *
@@ -657,7 +680,9 @@ public interface RepositoryService {
      * @throws RepositoryException
      * @see javax.jcr.version.VersionHistory#removeVersion(String)
      */
-    public void removeVersion(SessionInfo sessionInfo, NodeId versionHistoryId, NodeId versionId) throws ReferentialIntegrityException, AccessDeniedException, UnsupportedRepositoryOperationException, VersionException, RepositoryException;
+    void removeVersion(SessionInfo sessionInfo, NodeId versionHistoryId, NodeId versionId)
+            throws ReferentialIntegrityException, AccessDeniedException, UnsupportedRepositoryOperationException,
+            VersionException, RepositoryException;
 
     /**
      * Restores the node identified by <code>nodeId</code> to the state defined
@@ -684,7 +709,9 @@ public interface RepositoryService {
      * @see javax.jcr.Node#restore(javax.jcr.version.Version, String, boolean)
      * @see javax.jcr.Node#restoreByLabel(String, boolean)
      */
-    public void restore(SessionInfo sessionInfo, NodeId nodeId, NodeId versionId, boolean removeExisting) throws VersionException, PathNotFoundException, ItemExistsException, UnsupportedRepositoryOperationException, LockException, InvalidItemStateException, RepositoryException;
+    void restore(SessionInfo sessionInfo, NodeId nodeId, NodeId versionId, boolean removeExisting) throws VersionException,
+            PathNotFoundException, ItemExistsException, UnsupportedRepositoryOperationException, LockException,
+            InvalidItemStateException, RepositoryException;
 
     /**
      * Restore multiple versions at once. The versions to be restored are
@@ -706,7 +733,9 @@ public interface RepositoryService {
      * @throws javax.jcr.RepositoryException
      * @see javax.jcr.Workspace#restore(javax.jcr.version.Version[], boolean)
      */
-    public void restore(SessionInfo sessionInfo, NodeId[] versionIds, boolean removeExisting) throws ItemExistsException, UnsupportedRepositoryOperationException, VersionException, LockException, InvalidItemStateException, RepositoryException;
+    void restore(SessionInfo sessionInfo, NodeId[] versionIds, boolean removeExisting) throws ItemExistsException,
+            UnsupportedRepositoryOperationException, VersionException, LockException, InvalidItemStateException,
+            RepositoryException;
 
     /**
      * Merge the node identified by the given <code>NodeId</code> and its subtree
@@ -727,7 +756,9 @@ public interface RepositoryService {
      * @throws javax.jcr.RepositoryException
      * @see javax.jcr.Node#merge(String, boolean)
      */
-    public Iterator<NodeId> merge(SessionInfo sessionInfo, NodeId nodeId, String srcWorkspaceName, boolean bestEffort) throws NoSuchWorkspaceException, AccessDeniedException, MergeException, LockException, InvalidItemStateException, RepositoryException;
+    Iterator<NodeId> merge(SessionInfo sessionInfo, NodeId nodeId, String srcWorkspaceName, boolean bestEffort)
+            throws NoSuchWorkspaceException, AccessDeniedException, MergeException, LockException,
+            InvalidItemStateException, RepositoryException;
 
     /**
      * Merge the node identified by the given <code>NodeId</code> and its subtree
@@ -749,7 +780,9 @@ public interface RepositoryService {
      * @see javax.jcr.version.VersionManager#merge(String, String, boolean, boolean)
      * @since JCR 2.0
      */
-    public Iterator<NodeId> merge(SessionInfo sessionInfo, NodeId nodeId, String srcWorkspaceName, boolean bestEffort, boolean isShallow) throws NoSuchWorkspaceException, AccessDeniedException, MergeException, LockException, InvalidItemStateException, RepositoryException;
+    Iterator<NodeId> merge(SessionInfo sessionInfo, NodeId nodeId, String srcWorkspaceName, boolean bestEffort,
+            boolean isShallow) throws NoSuchWorkspaceException, AccessDeniedException, MergeException, LockException,
+            InvalidItemStateException, RepositoryException;
 
     /**
      * Resolve an existing merge conflict present with the node identified by
@@ -771,7 +804,9 @@ public interface RepositoryService {
      * @see javax.jcr.Node#cancelMerge(javax.jcr.version.Version)
      * @see javax.jcr.Node#doneMerge(javax.jcr.version.Version)
      */
-    public void resolveMergeConflict(SessionInfo sessionInfo, NodeId nodeId, NodeId[] mergeFailedIds, NodeId[] predecessorIds) throws VersionException, InvalidItemStateException, UnsupportedRepositoryOperationException, RepositoryException;
+    void resolveMergeConflict(SessionInfo sessionInfo, NodeId nodeId, NodeId[] mergeFailedIds, NodeId[] predecessorIds)
+            throws VersionException, InvalidItemStateException, UnsupportedRepositoryOperationException,
+            RepositoryException;
 
     /**
      * Add the given version label in the persistent layer.
@@ -791,7 +826,8 @@ public interface RepositoryService {
      * @throws javax.jcr.RepositoryException
      * @see javax.jcr.version.VersionHistory#addVersionLabel(String, String, boolean)
      */
-    public void addVersionLabel(SessionInfo sessionInfo, NodeId versionHistoryId, NodeId versionId, Name label, boolean moveLabel) throws VersionException, RepositoryException;
+    void addVersionLabel(SessionInfo sessionInfo, NodeId versionHistoryId, NodeId versionId, Name label, boolean moveLabel)
+            throws VersionException, RepositoryException;
 
     /**
      * Remove the given version label in the persistent layer.
@@ -806,7 +842,8 @@ public interface RepositoryService {
      * @throws javax.jcr.RepositoryException
      * @see javax.jcr.version.VersionHistory#removeVersionLabel(String)
      */
-    public void removeVersionLabel(SessionInfo sessionInfo, NodeId versionHistoryId, NodeId versionId, Name label) throws VersionException, RepositoryException;
+    void removeVersionLabel(SessionInfo sessionInfo, NodeId versionHistoryId, NodeId versionId, Name label)
+            throws VersionException, RepositoryException;
 
     /**
      * Create a new activity.
@@ -819,7 +856,8 @@ public interface RepositoryService {
      * @see javax.jcr.version.VersionManager#createActivity(String)
      * @since JCR 2.0
      */
-    public NodeId createActivity(SessionInfo sessionInfo, String title) throws UnsupportedRepositoryOperationException, RepositoryException;
+    NodeId createActivity(SessionInfo sessionInfo, String title)
+            throws UnsupportedRepositoryOperationException, RepositoryException;
 
     /**
      * Removes the activity identified by the specified <code>activityId</code>.
@@ -831,7 +869,8 @@ public interface RepositoryService {
      * @see javax.jcr.version.VersionManager#removeActivity(Node)
      * @since JCR 2.0
      */
-    public void removeActivity(SessionInfo sessionInfo, NodeId activityId) throws UnsupportedRepositoryOperationException, RepositoryException;
+    void removeActivity(SessionInfo sessionInfo, NodeId activityId)
+            throws UnsupportedRepositoryOperationException, RepositoryException;
 
     /**
      * Merges the activity identified by the given <code>activityId</code> into
@@ -844,7 +883,8 @@ public interface RepositoryService {
      * @throws UnsupportedRepositoryOperationException
      * @throws RepositoryException
      */
-    public Iterator<NodeId> mergeActivity(SessionInfo sessionInfo, NodeId activityId) throws UnsupportedRepositoryOperationException, RepositoryException;
+    Iterator<NodeId> mergeActivity(SessionInfo sessionInfo, NodeId activityId)
+            throws UnsupportedRepositoryOperationException, RepositoryException;
 
     /**
      *
@@ -855,7 +895,8 @@ public interface RepositoryService {
      * @throws RepositoryException
      * @see javax.jcr.version.VersionManager#createConfiguration(String)
      */
-    public NodeId createConfiguration(SessionInfo sessionInfo, NodeId nodeId) throws UnsupportedRepositoryOperationException, RepositoryException;
+    NodeId createConfiguration(SessionInfo sessionInfo, NodeId nodeId) throws UnsupportedRepositoryOperationException,
+            RepositoryException;
 
     //----------------------------------------------------------< Searching >---
     /**
@@ -868,7 +909,7 @@ public interface RepositoryService {
      * @throws javax.jcr.RepositoryException
      * @see javax.jcr.query.QueryManager#getSupportedQueryLanguages()
      */
-    public String[] getSupportedQueryLanguages(SessionInfo sessionInfo) throws RepositoryException;
+    String[] getSupportedQueryLanguages(SessionInfo sessionInfo) throws RepositoryException;
 
     /**
      * Checks if the query <code>statement</code> is valid according to the
@@ -887,7 +928,8 @@ public interface RepositoryService {
      *                               statement.
      * @see javax.jcr.query.QueryManager#createQuery(String, String)
      */
-    public String[] checkQueryStatement(SessionInfo sessionInfo, String statement, String language, Map<String, String> namespaces) throws InvalidQueryException, RepositoryException;
+    String[] checkQueryStatement(SessionInfo sessionInfo, String statement, String language,
+            Map<String, String> namespaces) throws InvalidQueryException, RepositoryException;
 
     /**
      * Execute the given query statement with the specified query language. The
@@ -912,14 +954,8 @@ public interface RepositoryService {
      * @throws RepositoryException if an error occurs.
      * @see javax.jcr.query.Query#execute()
      */
-    public QueryInfo executeQuery(SessionInfo sessionInfo,
-                                  String statement,
-                                  String language,
-                                  Map<String, String> namespaces,
-                                  long limit,
-                                  long offset,
-                                  Map<String, QValue> values)
-            throws RepositoryException;
+    QueryInfo executeQuery(SessionInfo sessionInfo, String statement, String language, Map<String, String> namespaces,
+            long limit, long offset, Map<String, QValue> values) throws RepositoryException;
 
     //--------------------------------------------------------< Observation >---
 
@@ -928,7 +964,7 @@ public interface RepositoryService {
      * observation is disabled.
      * @return
      */
-    public ExecutorService getChangePollingExecutor() throws RepositoryException;
+    ExecutorService getChangePollingExecutor() throws RepositoryException;
 
     /**
      * Creates an event filter. If the repository supports observation, the
@@ -953,11 +989,8 @@ public interface RepositoryService {
      * EventFilter.
      * @see javax.jcr.observation.ObservationManager#addEventListener(javax.jcr.observation.EventListener, int, String, boolean, String[], String[], boolean)
      */
-    public EventFilter createEventFilter(SessionInfo sessionInfo, int eventTypes,
-                                         Path absPath, boolean isDeep,
-                                         String[] uuid, Name[] nodeTypeName,
-                                         boolean noLocal)
-            throws UnsupportedRepositoryOperationException, RepositoryException;
+    EventFilter createEventFilter(SessionInfo sessionInfo, int eventTypes, Path absPath, boolean isDeep, String[] uuid,
+            Name[] nodeTypeName, boolean noLocal) throws UnsupportedRepositoryOperationException, RepositoryException;
 
     /**
      * Creates a new {@link Subscription} for events with an initial set of
@@ -976,7 +1009,7 @@ public interface RepositoryService {
      * @throws RepositoryException if an error occurs while creating the
      *                             Subscription.
      */
-    public Subscription createSubscription(SessionInfo sessionInfo, EventFilter[] filters)
+    Subscription createSubscription(SessionInfo sessionInfo, EventFilter[] filters)
             throws UnsupportedRepositoryOperationException, RepositoryException;
 
     /**
@@ -1010,8 +1043,7 @@ public interface RepositoryService {
      * @throws RepositoryException  if an error occurs while updating the event
      *                              filters.
      */
-    public void updateEventFilters(Subscription subscription, EventFilter[] filters)
-            throws RepositoryException;
+    void updateEventFilters(Subscription subscription, EventFilter[] filters) throws RepositoryException;
 
     /**
      * Retrieves the events that occurred since the last call to this method for
@@ -1036,8 +1068,7 @@ public interface RepositoryService {
      *                              waiting for events within the specified
      *                              <code>timeout</code>.
      */
-    public EventBundle[] getEvents(Subscription subscription, long timeout)
-            throws RepositoryException, InterruptedException;
+    EventBundle[] getEvents(Subscription subscription, long timeout) throws RepositoryException, InterruptedException;
 
     /**
      * Returns events from the <code>EventJournal</code> after a given point in
@@ -1057,8 +1088,8 @@ public interface RepositoryService {
      *                             if the underlying implementation does not
      *                             support event journaling.
      */
-    public EventBundle getEvents(SessionInfo sessionInfo, EventFilter filter, long after)
-            throws RepositoryException, UnsupportedRepositoryOperationException;
+    EventBundle getEvents(SessionInfo sessionInfo, EventFilter filter, long after) throws RepositoryException,
+            UnsupportedRepositoryOperationException;
 
     /**
      * Indicates that the passed subscription is no longer needed.
@@ -1071,7 +1102,7 @@ public interface RepositoryService {
      * @throws RepositoryException if an error occurs while the subscription is
      *                             disposed.
      */
-    public void dispose(Subscription subscription) throws RepositoryException;
+    void dispose(Subscription subscription) throws RepositoryException;
 
     //---------------------------------------------------------< Namespaces >---
     /**
@@ -1085,7 +1116,7 @@ public interface RepositoryService {
      * @see javax.jcr.NamespaceRegistry#getPrefixes()
      * @see javax.jcr.NamespaceRegistry#getURIs()
      */
-    public Map<String, String> getRegisteredNamespaces(SessionInfo sessionInfo) throws RepositoryException;
+    Map<String, String> getRegisteredNamespaces(SessionInfo sessionInfo) throws RepositoryException;
 
     /**
      * Returns the namespace URI for the given namespace <code>prefix</code>.
@@ -1097,8 +1128,7 @@ public interface RepositoryService {
      * @throws RepositoryException if another error occurs.
      * @see javax.jcr.NamespaceRegistry#getURI(String)
      */
-    public String getNamespaceURI(SessionInfo sessionInfo, String prefix)
-            throws NamespaceException, RepositoryException;
+    String getNamespaceURI(SessionInfo sessionInfo, String prefix) throws NamespaceException, RepositoryException;
 
     /**
      * Returns the namespace prefix for the given namespace <code>uri</code>.
@@ -1110,8 +1140,7 @@ public interface RepositoryService {
      * @throws RepositoryException if another error occurs.
      * @see javax.jcr.NamespaceRegistry#getPrefix(String)
      */
-    public String getNamespacePrefix(SessionInfo sessionInfo, String uri)
-            throws NamespaceException, RepositoryException;
+    String getNamespacePrefix(SessionInfo sessionInfo, String uri) throws NamespaceException, RepositoryException;
 
     /**
      * Register a new namespace with the given prefix and uri.
@@ -1125,7 +1154,8 @@ public interface RepositoryService {
      * @throws javax.jcr.RepositoryException
      * @see javax.jcr.NamespaceRegistry#registerNamespace(String, String)
      */
-    public void registerNamespace(SessionInfo sessionInfo, String prefix, String uri) throws NamespaceException, UnsupportedRepositoryOperationException, AccessDeniedException, RepositoryException;
+    void registerNamespace(SessionInfo sessionInfo, String prefix, String uri) throws NamespaceException,
+            UnsupportedRepositoryOperationException, AccessDeniedException, RepositoryException;
 
     /**
      * Unregister the namespace identified by the given uri
@@ -1138,7 +1168,8 @@ public interface RepositoryService {
      * @throws javax.jcr.RepositoryException
      * @see javax.jcr.NamespaceRegistry#unregisterNamespace(String)
      */
-    public void unregisterNamespace(SessionInfo sessionInfo, String uri) throws NamespaceException, UnsupportedRepositoryOperationException, AccessDeniedException, RepositoryException;
+    void unregisterNamespace(SessionInfo sessionInfo, String uri) throws NamespaceException,
+            UnsupportedRepositoryOperationException, AccessDeniedException, RepositoryException;
 
     //----------------------------------------------------------< NodeTypes >---
     /**
@@ -1153,7 +1184,7 @@ public interface RepositoryService {
      * @see javax.jcr.nodetype.NodeTypeManager#getPrimaryNodeTypes()
      * @see javax.jcr.nodetype.NodeTypeManager#getNodeType(String)
      */
-    public Iterator<QNodeTypeDefinition> getQNodeTypeDefinitions(SessionInfo sessionInfo) throws RepositoryException;
+    Iterator<QNodeTypeDefinition> getQNodeTypeDefinitions(SessionInfo sessionInfo) throws RepositoryException;
 
     /**
      * Retrieve <code>QNodeTypeDefinition</code>s for the given names. The
@@ -1175,7 +1206,8 @@ public interface RepositoryService {
      * @see javax.jcr.nodetype.NodeTypeManager#getPrimaryNodeTypes()
      * @see javax.jcr.nodetype.NodeTypeManager#getNodeType(String)
      */
-    public Iterator<QNodeTypeDefinition> getQNodeTypeDefinitions(SessionInfo sessionInfo, Name[] nodetypeNames) throws RepositoryException;
+    Iterator<QNodeTypeDefinition> getQNodeTypeDefinitions(SessionInfo sessionInfo, Name[] nodetypeNames)
+            throws RepositoryException;
 
     /**
      * Registers the node types with the specified <code>QNodeTypeDefinition</code>s.
@@ -1196,7 +1228,8 @@ public interface RepositoryService {
      * @throws RepositoryException If another error occurs.
      * @see javax.jcr.nodetype.NodeTypeManager#registerNodeTypes(javax.jcr.nodetype.NodeTypeDefinition[], boolean)
      */
-    public void registerNodeTypes(SessionInfo sessionInfo, QNodeTypeDefinition[] nodeTypeDefinitions, boolean allowUpdate) throws InvalidNodeTypeDefinitionException, NodeTypeExistsException, UnsupportedRepositoryOperationException, RepositoryException;
+    void registerNodeTypes(SessionInfo sessionInfo, QNodeTypeDefinition[] nodeTypeDefinitions, boolean allowUpdate)
+            throws InvalidNodeTypeDefinitionException, NodeTypeExistsException, UnsupportedRepositoryOperationException, RepositoryException;
 
     /**
      * Unregisters the node types with the specified <code>names</code>.
@@ -1210,7 +1243,8 @@ public interface RepositoryService {
      * @throws RepositoryException If another error occurs.
      * @see javax.jcr.nodetype.NodeTypeManager#unregisterNodeTypes(String[])
      */
-    public void unregisterNodeTypes(SessionInfo sessionInfo, Name[] nodeTypeNames) throws UnsupportedRepositoryOperationException, NoSuchNodeTypeException, RepositoryException;
+    void unregisterNodeTypes(SessionInfo sessionInfo, Name[] nodeTypeNames)
+            throws UnsupportedRepositoryOperationException, NoSuchNodeTypeException, RepositoryException;
 
     //-----------------------------------------------< Workspace Management >---
     /**
@@ -1231,7 +1265,8 @@ public interface RepositoryService {
      * @see javax.jcr.Workspace#createWorkspace(String, String)
      * @since JCR 2.0
      */
-    public void createWorkspace(SessionInfo sessionInfo, String name, String srcWorkspaceName) throws AccessDeniedException, UnsupportedRepositoryOperationException, NoSuchWorkspaceException, RepositoryException;
+    void createWorkspace(SessionInfo sessionInfo, String name, String srcWorkspaceName) throws AccessDeniedException,
+            UnsupportedRepositoryOperationException, NoSuchWorkspaceException, RepositoryException;
 
     /**
      * Deletes the workspace with the specified <code>name</code>.
@@ -1245,6 +1280,7 @@ public interface RepositoryService {
      * @see javax.jcr.Workspace#deleteWorkspace(String)
      * @since JCR 2.0
      */
-    public void deleteWorkspace(SessionInfo sessionInfo, String name) throws AccessDeniedException, UnsupportedRepositoryOperationException, NoSuchWorkspaceException, RepositoryException;
+    void deleteWorkspace(SessionInfo sessionInfo, String name) throws AccessDeniedException,
+            UnsupportedRepositoryOperationException, NoSuchWorkspaceException, RepositoryException;
 
 }

Modified: jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi/src/main/java/org/apache/jackrabbit/spi/RepositoryServiceFactory.java
URL: http://svn.apache.org/viewvc/jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi/src/main/java/org/apache/jackrabbit/spi/RepositoryServiceFactory.java?rev=1164631&r1=1164630&r2=1164631&view=diff
==============================================================================
--- jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi/src/main/java/org/apache/jackrabbit/spi/RepositoryServiceFactory.java (original)
+++ jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi/src/main/java/org/apache/jackrabbit/spi/RepositoryServiceFactory.java Fri Sep  2 16:58:50 2011
@@ -34,5 +34,5 @@ public interface RepositoryServiceFactor
      * @throws RepositoryException  If there was an error creating the
      *     <code>RepositoryService</code> instance
      */
-    public RepositoryService createRepositoryService(Map<?, ?> parameters) throws RepositoryException;
+    RepositoryService createRepositoryService(Map<?, ?> parameters) throws RepositoryException;
 }

Modified: jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi/src/main/java/org/apache/jackrabbit/spi/SessionInfo.java
URL: http://svn.apache.org/viewvc/jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi/src/main/java/org/apache/jackrabbit/spi/SessionInfo.java?rev=1164631&r1=1164630&r2=1164631&view=diff
==============================================================================
--- jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi/src/main/java/org/apache/jackrabbit/spi/SessionInfo.java (original)
+++ jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi/src/main/java/org/apache/jackrabbit/spi/SessionInfo.java Fri Sep  2 16:58:50 2011
@@ -39,7 +39,7 @@ public interface SessionInfo {
      * @return The user identification.
      * @see RepositoryService#obtain(javax.jcr.Credentials, String)
      */
-    public String getUserID();
+    String getUserID();
 
     /**
      * Returns the workspace name.
@@ -49,7 +49,7 @@ public interface SessionInfo {
      * @see RepositoryService#obtain(javax.jcr.Credentials, String)
      * @see javax.jcr.Workspace#getName()
      */
-    public String getWorkspaceName();
+    String getWorkspaceName();
 
     /**
      * Returns the lock tokens present on this <code>SessionInfo</code>.
@@ -58,7 +58,7 @@ public interface SessionInfo {
      * @throws UnsupportedRepositoryOperationException If locking is not supported.
      * @throws RepositoryException If another error occurs.
      */
-    public String[] getLockTokens() throws UnsupportedRepositoryOperationException, RepositoryException;
+    String[] getLockTokens() throws UnsupportedRepositoryOperationException, RepositoryException;
 
     /**
      * Add the given lock token to this <code>SessionInfo</code>. The token will
@@ -71,7 +71,7 @@ public interface SessionInfo {
      * @throws LockException If the token cannot be added.
      * @throws RepositoryException If another error occurs.
      */
-    public void addLockToken(String lockToken) throws UnsupportedRepositoryOperationException, LockException, RepositoryException;
+    void addLockToken(String lockToken) throws UnsupportedRepositoryOperationException, LockException, RepositoryException;
 
     /**
      * Removes the given lock token from this <code>SessionInfo</code>.
@@ -86,7 +86,7 @@ public interface SessionInfo {
      * @throws LockException If the token cannot be removed.
      * @throws RepositoryException If another error occurs.
      */
-    public void removeLockToken(String lockToken) throws UnsupportedRepositoryOperationException, LockException, RepositoryException;
+    void removeLockToken(String lockToken) throws UnsupportedRepositoryOperationException, LockException, RepositoryException;
 
     /**
      * Sets the user data used for {@link org.apache.jackrabbit.spi.Event#getUserData()}.
@@ -95,5 +95,5 @@ public interface SessionInfo {
      * @throws RepositoryException
      * @see javax.jcr.observation.ObservationManager#setUserData(String)
      */
-    public void setUserData(String userData) throws RepositoryException;
+    void setUserData(String userData) throws RepositoryException;
 }

Modified: jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi/src/main/java/org/apache/jackrabbit/spi/XASessionInfo.java
URL: http://svn.apache.org/viewvc/jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi/src/main/java/org/apache/jackrabbit/spi/XASessionInfo.java?rev=1164631&r1=1164630&r2=1164631&view=diff
==============================================================================
--- jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi/src/main/java/org/apache/jackrabbit/spi/XASessionInfo.java (original)
+++ jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi/src/main/java/org/apache/jackrabbit/spi/XASessionInfo.java Fri Sep  2 16:58:50 2011
@@ -31,5 +31,5 @@ public interface XASessionInfo extends S
      *
      * @return the <code>XAResource</code> object.
      */
-    public XAResource getXAResource();
+    XAResource getXAResource();
 }