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/07 14:00:20 UTC

svn commit: r1166138 [5/12] - in /jackrabbit/sandbox/jackrabbit-mk: jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/ jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/batch/ jackrabbit-spi-commons/src/main/ja...

Modified: jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/logging/RepositoryServiceLogger.java
URL: http://svn.apache.org/viewvc/jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/logging/RepositoryServiceLogger.java?rev=1166138&r1=1166137&r2=1166138&view=diff
==============================================================================
--- jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/logging/RepositoryServiceLogger.java (original)
+++ jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/logging/RepositoryServiceLogger.java Wed Sep  7 12:00:14 2011
@@ -16,18 +16,6 @@
  */
 package org.apache.jackrabbit.spi.commons.logging;
 
-import java.io.InputStream;
-import java.util.Iterator;
-import java.util.Map;
-import java.util.concurrent.ExecutorService;
-
-import javax.jcr.Credentials;
-import javax.jcr.RepositoryException;
-import javax.jcr.UnsupportedRepositoryOperationException;
-import javax.jcr.nodetype.InvalidNodeTypeDefinitionException;
-import javax.jcr.nodetype.NoSuchNodeTypeException;
-import javax.jcr.nodetype.NodeTypeExistsException;
-
 import org.apache.jackrabbit.spi.Batch;
 import org.apache.jackrabbit.spi.ChildInfo;
 import org.apache.jackrabbit.spi.EventBundle;
@@ -40,11 +28,9 @@ import org.apache.jackrabbit.spi.LockInf
 import org.apache.jackrabbit.spi.Name;
 import org.apache.jackrabbit.spi.NameFactory;
 import org.apache.jackrabbit.spi.NodeId;
-import org.apache.jackrabbit.spi.NodeInfo;
 import org.apache.jackrabbit.spi.Path;
 import org.apache.jackrabbit.spi.PathFactory;
 import org.apache.jackrabbit.spi.PropertyId;
-import org.apache.jackrabbit.spi.PropertyInfo;
 import org.apache.jackrabbit.spi.QNodeDefinition;
 import org.apache.jackrabbit.spi.QNodeTypeDefinition;
 import org.apache.jackrabbit.spi.QPropertyDefinition;
@@ -55,6 +41,13 @@ import org.apache.jackrabbit.spi.Reposit
 import org.apache.jackrabbit.spi.SessionInfo;
 import org.apache.jackrabbit.spi.Subscription;
 
+import javax.jcr.Credentials;
+import javax.jcr.RepositoryException;
+import java.io.InputStream;
+import java.util.Iterator;
+import java.util.Map;
+import java.util.concurrent.ExecutorService;
+
 /**
  * Log wrapper for a {@link RepositoryService}.
  */
@@ -62,8 +55,8 @@ public class RepositoryServiceLogger ext
     private final RepositoryService service;
 
     /**
-     * Create a new instance for the given <code>service</code> which uses
-     * <code>writer</code> for persisting log messages.
+     * Create a new instance for the given {@code service} which uses
+     * {@code writer} for persisting log messages.
      * @param service
      * @param writer
      */
@@ -79,86 +72,106 @@ public class RepositoryServiceLogger ext
         return service;
     }
 
+    @Override
     public NameFactory getNameFactory() throws RepositoryException {
         return (NameFactory) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.getNameFactory();
             }
         }, "getNameFactory()", new Object[]{});
     }
 
+    @Override
     public PathFactory getPathFactory() throws RepositoryException {
         return (PathFactory) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.getPathFactory();
             }
         }, "getPathFactory()", new Object[]{});
     }
 
+    @Override
     public IdFactory getIdFactory() throws RepositoryException {
         return (IdFactory) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.getIdFactory();
             }
         }, "getIdFactory()", new Object[]{});
     }
 
+    @Override
     public QValueFactory getQValueFactory() throws RepositoryException {
         return (QValueFactory) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.getQValueFactory();
             }
         }, "getQValueFactory()", new Object[]{});
     }
 
+    @Override
     public Map<String, QValue[]> getRepositoryDescriptors() throws RepositoryException {
         return (Map<String, QValue[]>) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.getRepositoryDescriptors();
             }
         }, "getRepositoryDescriptors()", new Object[]{});
     }
 
+    @Override
     public ItemInfoCache getItemInfoCache(final SessionInfo sessionInfo) throws RepositoryException {
         return (ItemInfoCache) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.getItemInfoCache(sessionInfo);
             }
         }, "getItemInfoCache(SessionInfo)", new Object[]{sessionInfo});
     }
 
+    @Override
     public SessionInfo obtain(final Credentials credentials, final String workspaceName)
             throws RepositoryException {
 
         return (SessionInfo) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.obtain(credentials, workspaceName);
             }
         }, "obtain(Credentials, String)", new Object[]{credentials, workspaceName});
     }
 
+    @Override
     public SessionInfo obtain(final SessionInfo sessionInfo, final String workspaceName)
             throws RepositoryException {
 
         return (SessionInfo) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.obtain(unwrap(sessionInfo), workspaceName);
             }
         }, "obtain(SessionInfo, String)", new Object[]{unwrap(sessionInfo), workspaceName});
     }
 
+    @Override
     public SessionInfo impersonate(final SessionInfo sessionInfo, final Credentials credentials)
             throws RepositoryException {
 
         return (SessionInfo) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.impersonate(unwrap(sessionInfo), credentials);
             }
         }, "impersonate(SessionInfo, Credentials)", new Object[]{unwrap(sessionInfo), credentials});
     }
 
+    @Override
     public void dispose(final SessionInfo sessionInfo) throws RepositoryException {
         execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 service.dispose(unwrap(sessionInfo));
                 return null;
@@ -166,83 +179,101 @@ public class RepositoryServiceLogger ext
         }, "dispose(SessionInfo)", new Object[]{unwrap(sessionInfo)});
     }
 
+    @Override
     public String[] getWorkspaceNames(final SessionInfo sessionInfo) throws RepositoryException {
         return (String[]) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.getWorkspaceNames(unwrap(sessionInfo));
             }
         }, "getWorkspaceNames(SessionInfo)", new Object[]{unwrap(sessionInfo)});
     }
 
+    @Override
     public boolean isGranted(final SessionInfo sessionInfo, final ItemId itemId, final String[] actions)
             throws RepositoryException {
 
         return (Boolean) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
-                return Boolean.valueOf(service.isGranted(unwrap(sessionInfo), itemId, actions));
+                return service.isGranted(unwrap(sessionInfo), itemId, actions);
             }
         }, "isGranted(SessionInfo, ItemId, String[])", new Object[] { unwrap(sessionInfo), itemId, actions });
     }
 
+    @Override
     public QNodeDefinition getNodeDefinition(final SessionInfo sessionInfo, final NodeId nodeId)
             throws RepositoryException {
 
         return (QNodeDefinition) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.getNodeDefinition(unwrap(sessionInfo), nodeId);
             }
         }, "getNodeDefinition(SessionInfo, NodeId)", new Object[]{unwrap(sessionInfo), nodeId});
     }
 
+    @Override
     public QPropertyDefinition getPropertyDefinition(final SessionInfo sessionInfo,
             final PropertyId propertyId) throws RepositoryException {
 
         return (QPropertyDefinition) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.getPropertyDefinition(unwrap(sessionInfo), propertyId);
             }
         }, "getPropertyDefinition(SessionInfo, PropertyId)", new Object[]{unwrap(sessionInfo), propertyId});
     }
 
+    @Override
     public Iterator<? extends ItemInfo> getItemInfos(final SessionInfo sessionInfo, final ItemId itemId)
             throws RepositoryException {
 
         return (Iterator<? extends ItemInfo>) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.getItemInfos(unwrap(sessionInfo), itemId);
             }
         }, "getItemInfos(SessionInfo, NodeId)", new Object[]{unwrap(sessionInfo), itemId});
     }
 
+    @Override
     public Iterator<ChildInfo> getChildInfos(final SessionInfo sessionInfo, final NodeId parentId)
             throws RepositoryException {
 
         return (Iterator<ChildInfo>) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.getChildInfos(unwrap(sessionInfo), parentId);
             }
         }, "getChildInfos(SessionInfo, NodeId)", new Object[]{unwrap(sessionInfo), parentId});
     }
 
+    @Override
     public Iterator<PropertyId> getReferences(final SessionInfo sessionInfo, final NodeId nodeId, final Name propertyName, final boolean weakReferences) throws RepositoryException {
         return (Iterator<PropertyId>) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.getReferences(unwrap(sessionInfo), nodeId, propertyName, weakReferences);
             }
         }, "getReferences(SessionInfo, NodeId, Name, boolean)", new Object[]{unwrap(sessionInfo), nodeId, propertyName, weakReferences});
     }
 
+    @Override
     public Batch createBatch(final SessionInfo sessionInfo, final ItemId itemId) throws RepositoryException {
         return (Batch) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.createBatch(unwrap(sessionInfo), itemId);
             }
         }, "createBatch(SessionInfo, ItemId)", new Object[]{unwrap(sessionInfo), itemId});
     }
 
+    @Override
     public void submit(final Batch batch) throws RepositoryException {
 
         execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 service.submit(unwrap(batch));
                 return null;
@@ -250,10 +281,12 @@ public class RepositoryServiceLogger ext
         }, "submit(Batch)", new Object[]{unwrap(batch)});
     }
 
+    @Override
     public void importXml(final SessionInfo sessionInfo, final NodeId parentId, final InputStream xmlStream,
             final int uuidBehaviour) throws RepositoryException {
 
         execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 service.importXml(unwrap(sessionInfo), parentId, xmlStream, uuidBehaviour);
                 return null;
@@ -262,10 +295,12 @@ public class RepositoryServiceLogger ext
                 new Object[]{unwrap(sessionInfo), parentId, xmlStream, uuidBehaviour});
     }
 
+    @Override
     public void move(final SessionInfo sessionInfo, final NodeId srcNodeId, final NodeId destParentNodeId,
             final Name destName) throws RepositoryException {
 
         execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 service.move(unwrap(sessionInfo), srcNodeId, destParentNodeId, destName);
                 return null;
@@ -274,10 +309,12 @@ public class RepositoryServiceLogger ext
                 new Object[]{unwrap(sessionInfo), srcNodeId, destParentNodeId, destName});
     }
 
+    @Override
     public void copy(final SessionInfo sessionInfo, final String srcWorkspaceName, final NodeId srcNodeId,
             final NodeId destParentNodeId, final Name destName) throws RepositoryException {
 
         execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 service.copy(unwrap(sessionInfo), srcWorkspaceName, srcNodeId, destParentNodeId, destName);
                 return null;
@@ -286,10 +323,12 @@ public class RepositoryServiceLogger ext
                 new Object[]{unwrap(sessionInfo), srcWorkspaceName, srcNodeId, destParentNodeId, destName});
     }
 
+    @Override
     public void update(final SessionInfo sessionInfo, final NodeId nodeId, final String srcWorkspaceName)
             throws RepositoryException {
 
         execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 service.update(unwrap(sessionInfo), nodeId, srcWorkspaceName);
                 return null;
@@ -297,11 +336,13 @@ public class RepositoryServiceLogger ext
         }, "update(SessionInfo, NodeId, String)", new Object[]{unwrap(sessionInfo), nodeId, srcWorkspaceName});
     }
 
+    @Override
     public void clone(final SessionInfo sessionInfo, final String srcWorkspaceName, final NodeId srcNodeId,
             final NodeId destParentNodeId, final Name destName, final boolean removeExisting)
             throws RepositoryException {
 
         execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 service.clone(unwrap(sessionInfo), srcWorkspaceName, srcNodeId, destParentNodeId, destName,
                         removeExisting);
@@ -311,20 +352,24 @@ public class RepositoryServiceLogger ext
                 new Object[] { unwrap(sessionInfo), srcWorkspaceName, srcNodeId, destParentNodeId, destName, removeExisting});
     }
 
+    @Override
     public LockInfo getLockInfo(final SessionInfo sessionInfo, final NodeId nodeId)
             throws RepositoryException {
 
         return (LockInfo) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.getLockInfo(unwrap(sessionInfo), nodeId);
             }
         }, "getLockInfo(SessionInfo, NodeId)", new Object[]{unwrap(sessionInfo), nodeId});
     }
 
+    @Override
     public LockInfo lock(final SessionInfo sessionInfo, final NodeId nodeId, final boolean deep,
             final boolean sessionScoped) throws RepositoryException {
 
         return (LockInfo) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.lock(unwrap(sessionInfo), nodeId, deep, sessionScoped);
             }
@@ -332,11 +377,13 @@ public class RepositoryServiceLogger ext
                 new Object[]{unwrap(sessionInfo), nodeId, deep, sessionScoped});
     }
 
+    @Override
     public LockInfo lock(final SessionInfo sessionInfo, final NodeId nodeId, final boolean deep,
             final boolean sessionScoped, final long timeoutHint, final String ownerHint)
             throws RepositoryException {
 
         return (LockInfo) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.lock(unwrap(sessionInfo), nodeId, deep, sessionScoped, timeoutHint, ownerHint);
             }
@@ -346,10 +393,12 @@ public class RepositoryServiceLogger ext
                 ownerHint });
     }
 
+    @Override
     public void refreshLock(final SessionInfo sessionInfo, final NodeId nodeId)
             throws RepositoryException {
 
         execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 service.refreshLock(unwrap(sessionInfo), nodeId);
                 return null;
@@ -357,10 +406,12 @@ public class RepositoryServiceLogger ext
         }, "refreshLock(SessionInfo, NodeId)", new Object[]{unwrap(sessionInfo), nodeId});
     }
 
+    @Override
     public void unlock(final SessionInfo sessionInfo, final NodeId nodeId)
             throws RepositoryException {
 
         execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 service.unlock(unwrap(sessionInfo), nodeId);
                 return null;
@@ -368,19 +419,23 @@ public class RepositoryServiceLogger ext
         }, "unlock(SessionInfo, NodeId)", new Object[]{unwrap(sessionInfo), nodeId});
     }
 
+    @Override
     public NodeId checkin(final SessionInfo sessionInfo, final NodeId nodeId) throws RepositoryException {
 
         return (NodeId) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.checkin(unwrap(sessionInfo), nodeId);
             }
         }, "checkin(SessionInfo, NodeId)", new Object[]{unwrap(sessionInfo), nodeId});
     }
 
+    @Override
     public void checkout(final SessionInfo sessionInfo, final NodeId nodeId)
             throws RepositoryException {
 
         execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 service.checkout(unwrap(sessionInfo), nodeId);
                 return null;
@@ -388,10 +443,12 @@ public class RepositoryServiceLogger ext
         }, "checkout(SessionInfo, NodeId)", new Object[]{unwrap(sessionInfo), nodeId});
     }
 
+    @Override
     public void checkout(final SessionInfo sessionInfo, final NodeId nodeId, final NodeId activityId)
             throws RepositoryException {
 
         execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 service.checkout(unwrap(sessionInfo), nodeId, activityId);
                 return null;
@@ -399,26 +456,32 @@ public class RepositoryServiceLogger ext
         }, "checkout(SessionInfo, NodeId, NodeId)", new Object[]{unwrap(sessionInfo), nodeId, activityId});
     }
 
-    public NodeId checkpoint(final SessionInfo sessionInfo, final NodeId nodeId) throws UnsupportedRepositoryOperationException, RepositoryException {
+    @Override
+    public NodeId checkpoint(final SessionInfo sessionInfo, final NodeId nodeId) throws RepositoryException {
         return (NodeId) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.checkpoint(unwrap(sessionInfo), nodeId);
             }
         }, "checkpoint(SessionInfo, NodeId)", new Object[]{unwrap(sessionInfo), nodeId});
     }
 
-    public NodeId checkpoint(final SessionInfo sessionInfo, final NodeId nodeId, final NodeId activityId) throws UnsupportedRepositoryOperationException, RepositoryException {
+    @Override
+    public NodeId checkpoint(final SessionInfo sessionInfo, final NodeId nodeId, final NodeId activityId) throws RepositoryException {
         return (NodeId) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.checkpoint(unwrap(sessionInfo), nodeId, activityId);
             }
         }, "checkpoint(SessionInfo, NodeId, NodeId)", new Object[]{unwrap(sessionInfo), nodeId, activityId});
     }
 
+    @Override
     public void removeVersion(final SessionInfo sessionInfo, final NodeId versionHistoryId,
             final NodeId versionId) throws RepositoryException {
 
         execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 service.removeVersion(unwrap(sessionInfo), versionHistoryId, versionId);
                 return null;
@@ -427,10 +490,12 @@ public class RepositoryServiceLogger ext
                 new Object[]{unwrap(sessionInfo), versionHistoryId, versionId});
     }
 
+    @Override
     public void restore(final SessionInfo sessionInfo, final NodeId nodeId, final NodeId versionId,
             final boolean removeExisting) throws RepositoryException {
 
         execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 service.restore(unwrap(sessionInfo), nodeId, versionId, removeExisting);
                 return null;
@@ -439,10 +504,12 @@ public class RepositoryServiceLogger ext
                 new Object[]{unwrap(sessionInfo), nodeId, versionId, removeExisting});
     }
 
+    @Override
     public void restore(final SessionInfo sessionInfo, final NodeId[] nodeIds, final boolean removeExisting)
             throws RepositoryException {
 
         execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 service.restore(unwrap(sessionInfo), nodeIds, removeExisting);
                 return null;
@@ -451,10 +518,12 @@ public class RepositoryServiceLogger ext
                 new Object[]{unwrap(sessionInfo), nodeIds, removeExisting});
     }
 
+    @Override
     public Iterator<NodeId> merge(final SessionInfo sessionInfo, final NodeId nodeId, final String srcWorkspaceName,
             final boolean bestEffort) throws RepositoryException {
 
         return (Iterator<NodeId>) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.merge(unwrap(sessionInfo), nodeId, srcWorkspaceName, bestEffort);
             }
@@ -462,10 +531,12 @@ public class RepositoryServiceLogger ext
                 new Object[]{unwrap(sessionInfo), nodeId, srcWorkspaceName, bestEffort});
     }
 
+    @Override
     public Iterator<NodeId> merge(final SessionInfo sessionInfo, final NodeId nodeId, final String srcWorkspaceName,
             final boolean bestEffort, final boolean isShallow) throws RepositoryException {
 
         return (Iterator<NodeId>) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.merge(unwrap(sessionInfo), nodeId, srcWorkspaceName, bestEffort, isShallow);
             }
@@ -473,10 +544,12 @@ public class RepositoryServiceLogger ext
                 new Object[]{unwrap(sessionInfo), nodeId, srcWorkspaceName, bestEffort});
     }
 
+    @Override
     public void resolveMergeConflict(final SessionInfo sessionInfo, final NodeId nodeId,
             final NodeId[] mergeFailedIds, final NodeId[] predecessorIds) throws RepositoryException {
 
         execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 service.resolveMergeConflict(unwrap(sessionInfo), nodeId, mergeFailedIds, predecessorIds);
                 return null;
@@ -485,10 +558,12 @@ public class RepositoryServiceLogger ext
                 new Object[]{unwrap(sessionInfo), nodeId, mergeFailedIds, predecessorIds});
     }
 
+    @Override
     public void addVersionLabel(final SessionInfo sessionInfo, final NodeId versionHistoryId,
             final NodeId versionId, final Name label, final boolean moveLabel) throws RepositoryException {
 
         execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 service.addVersionLabel(unwrap(sessionInfo), versionHistoryId, versionId, label, moveLabel);
                 return null;
@@ -497,10 +572,12 @@ public class RepositoryServiceLogger ext
                 new Object[]{unwrap(sessionInfo), versionHistoryId, versionId, label, moveLabel});
     }
 
+    @Override
     public void removeVersionLabel(final SessionInfo sessionInfo, final NodeId versionHistoryId,
             final NodeId versionId, final Name label) throws RepositoryException {
 
         execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 service.removeVersionLabel(unwrap(sessionInfo), versionHistoryId, versionId, label);
                 return null;
@@ -509,16 +586,20 @@ public class RepositoryServiceLogger ext
                 new Object[]{unwrap(sessionInfo), versionHistoryId, versionId, label});
     }
 
-    public NodeId createActivity(final SessionInfo sessionInfo, final String title) throws UnsupportedRepositoryOperationException, RepositoryException {
+    @Override
+    public NodeId createActivity(final SessionInfo sessionInfo, final String title) throws RepositoryException {
         return (NodeId) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.createActivity(unwrap(sessionInfo), title);
             }
         }, "createActivity(SessionInfo, String)", new Object[]{unwrap(sessionInfo), title});
     }
 
-    public void removeActivity(final SessionInfo sessionInfo, final NodeId activityId) throws UnsupportedRepositoryOperationException, RepositoryException {
+    @Override
+    public void removeActivity(final SessionInfo sessionInfo, final NodeId activityId) throws RepositoryException {
         execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 service.removeActivity(unwrap(sessionInfo), activityId);
                 return null;
@@ -527,34 +608,42 @@ public class RepositoryServiceLogger ext
                 new Object[]{unwrap(sessionInfo), activityId});
     }
 
-    public Iterator<NodeId> mergeActivity(final SessionInfo sessionInfo, final NodeId activityId) throws UnsupportedRepositoryOperationException, RepositoryException {
+    @Override
+    public Iterator<NodeId> mergeActivity(final SessionInfo sessionInfo, final NodeId activityId) throws RepositoryException {
         return (Iterator<NodeId>) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.mergeActivity(unwrap(sessionInfo), activityId);
             }
         }, "mergeActivity(SessionInfo, NodeId)", new Object[]{unwrap(sessionInfo), activityId});
     }
 
-    public NodeId createConfiguration(final SessionInfo sessionInfo, final NodeId nodeId) throws UnsupportedRepositoryOperationException, RepositoryException {
+    @Override
+    public NodeId createConfiguration(final SessionInfo sessionInfo, final NodeId nodeId) throws RepositoryException {
         return (NodeId) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.createConfiguration(unwrap(sessionInfo), nodeId);
             }
         }, "createConfiguration(SessionInfo, NodeId, NodeId)", new Object[]{unwrap(sessionInfo), nodeId});
     }
 
+    @Override
     public String[] getSupportedQueryLanguages(final SessionInfo sessionInfo) throws RepositoryException {
         return (String[]) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.getSupportedQueryLanguages(unwrap(sessionInfo));
             }
         }, "getSupportedQueryLanguages(SessionInfo)", new Object[]{unwrap(sessionInfo)});
     }
 
+    @Override
     public String[] checkQueryStatement(final SessionInfo sessionInfo, final String statement,
             final String language, final Map<String, String> namespaces) throws RepositoryException {
 
         return (String[]) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.checkQueryStatement(unwrap(sessionInfo), statement, language, namespaces);
             }
@@ -562,10 +651,12 @@ public class RepositoryServiceLogger ext
                 new Object[]{unwrap(sessionInfo), statement, language, namespaces});
     }
 
+    @Override
     public QueryInfo executeQuery(final SessionInfo sessionInfo, final String statement,
                                   final String language, final Map<String, String> namespaces, final long limit, final long offset, final Map<String, QValue> values) throws RepositoryException {
 
         return (QueryInfo) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.executeQuery(unwrap(sessionInfo), statement, language, namespaces, limit, offset, values);
             }
@@ -573,11 +664,13 @@ public class RepositoryServiceLogger ext
                 new Object[]{unwrap(sessionInfo), statement, language, namespaces, limit, offset, values});
     }
 
+    @Override
     public EventFilter createEventFilter(final SessionInfo sessionInfo, final int eventTypes,
             final Path absPath, final boolean isDeep, final String[] uuid, final Name[] qnodeTypeName,
             final boolean noLocal) throws RepositoryException {
 
         return (EventFilter) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.createEventFilter(unwrap(sessionInfo), eventTypes, absPath, isDeep, uuid,
                        qnodeTypeName, noLocal);
@@ -590,16 +683,19 @@ public class RepositoryServiceLogger ext
     @Override
     public ExecutorService getChangePollingExecutor() throws RepositoryException {
         return (ExecutorService) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.getChangePollingExecutor();
             }
         }, "getChangePollingExecutor()", new Object[]{});
     }
 
+    @Override
     public Subscription createSubscription(final SessionInfo sessionInfo, final EventFilter[] filters)
             throws RepositoryException {
 
         return (Subscription) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.createSubscription(unwrap(sessionInfo), filters);
             }
@@ -607,6 +703,7 @@ public class RepositoryServiceLogger ext
                 new Object[]{unwrap(sessionInfo), filters});
     }
 
+    @Override
     public EventBundle[] getEvents(final Subscription subscription, final long timeout)
             throws RepositoryException, InterruptedException {
 
@@ -615,6 +712,7 @@ public class RepositoryServiceLogger ext
         final InterruptedException[] ex = new InterruptedException[1];
 
         EventBundle[] result = (EventBundle[]) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 try {
                     return service.getEvents(subscription, timeout);
@@ -633,11 +731,12 @@ public class RepositoryServiceLogger ext
         return result;
     }
 
+    @Override
     public EventBundle getEvents(final SessionInfo sessionInfo,
                                  final EventFilter filter,
-                                 final long after) throws RepositoryException,
-            UnsupportedRepositoryOperationException {
+                                 final long after) throws RepositoryException {
         return (EventBundle) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.getEvents(sessionInfo, filter, after);
             }
@@ -645,10 +744,12 @@ public class RepositoryServiceLogger ext
                 new Object[]{unwrap(sessionInfo), filter, after});
     }
 
+    @Override
     public void updateEventFilters(final Subscription subscription, final EventFilter[] eventFilters)
             throws RepositoryException {
 
         execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 service.updateEventFilters(subscription, eventFilters);
                 return null;
@@ -657,8 +758,10 @@ public class RepositoryServiceLogger ext
                 new Object[]{subscription, eventFilters});
     }
 
+    @Override
     public void dispose(final Subscription subscription) throws RepositoryException {
         execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 service.dispose(subscription);
                 return null;
@@ -666,37 +769,45 @@ public class RepositoryServiceLogger ext
         }, "dispose(Subscription)", new Object[]{});
     }
 
+    @Override
     public Map<String, String> getRegisteredNamespaces(final SessionInfo sessionInfo) throws RepositoryException {
         return (Map<String, String>) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.getRegisteredNamespaces(unwrap(sessionInfo));
             }
         }, "getRegisteredNamespaces(SessionInfo)", new Object[]{unwrap(sessionInfo)});
     }
 
+    @Override
     public String getNamespaceURI(final SessionInfo sessionInfo, final String prefix)
             throws RepositoryException {
         return (String) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.getNamespaceURI(unwrap(sessionInfo), prefix);
             }
         }, "getNamespaceURI(SessionInfo, String)", new Object[]{unwrap(sessionInfo), prefix});
     }
 
+    @Override
     public String getNamespacePrefix(final SessionInfo sessionInfo, final String uri)
             throws RepositoryException {
 
         return (String) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.getNamespacePrefix(unwrap(sessionInfo), uri);
             }
         }, "getNamespacePrefix(SessionInfo, String)", new Object[]{unwrap(sessionInfo), uri});
     }
 
+    @Override
     public void registerNamespace(final SessionInfo sessionInfo, final String prefix, final String uri)
             throws RepositoryException {
 
         execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 service.registerNamespace(unwrap(sessionInfo), prefix, uri);
                 return null;
@@ -704,10 +815,12 @@ public class RepositoryServiceLogger ext
         }, "registerNamespace(SessionInfo, String, String)", new Object[]{unwrap(sessionInfo), prefix, uri});
     }
 
+    @Override
     public void unregisterNamespace(final SessionInfo sessionInfo, final String uri)
             throws RepositoryException {
 
         execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 service.unregisterNamespace(unwrap(sessionInfo), uri);
                 return null;
@@ -715,26 +828,32 @@ public class RepositoryServiceLogger ext
         }, "unregisterNamespace(SessionInfo, String)", new Object[]{unwrap(sessionInfo), uri});
     }
 
+    @Override
     public Iterator<QNodeTypeDefinition> getQNodeTypeDefinitions(final SessionInfo sessionInfo) throws RepositoryException {
         return (Iterator<QNodeTypeDefinition>) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.getQNodeTypeDefinitions(unwrap(sessionInfo));
             }
         }, "getQNodeTypeDefinitions(SessionInfo)", new Object[]{unwrap(sessionInfo)});
     }
 
+    @Override
     public Iterator<QNodeTypeDefinition> getQNodeTypeDefinitions(final SessionInfo sessionInfo, final Name[] nodetypeNames)
             throws RepositoryException {
 
         return (Iterator) execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 return service.getQNodeTypeDefinitions(unwrap(sessionInfo), nodetypeNames);
             }
         }, "getQNodeTypeDefinitions(SessionInfo, Name[])", new Object[]{unwrap(sessionInfo), nodetypeNames});
     }
 
-    public void registerNodeTypes(final SessionInfo sessionInfo, final QNodeTypeDefinition[] nodeTypeDefinitions, final boolean allowUpdate) throws InvalidNodeTypeDefinitionException, NodeTypeExistsException, UnsupportedRepositoryOperationException, RepositoryException {
+    @Override
+    public void registerNodeTypes(final SessionInfo sessionInfo, final QNodeTypeDefinition[] nodeTypeDefinitions, final boolean allowUpdate) throws RepositoryException {
         execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 service.registerNodeTypes(unwrap(sessionInfo), nodeTypeDefinitions, allowUpdate);
                 return null;
@@ -742,8 +861,10 @@ public class RepositoryServiceLogger ext
         }, "registerNodeTypes(SessionInfo, QNodeTypeDefinition[], boolean)", new Object[]{unwrap(sessionInfo), nodeTypeDefinitions, allowUpdate});
     }
 
-    public void unregisterNodeTypes(final SessionInfo sessionInfo, final Name[] nodeTypeNames) throws UnsupportedRepositoryOperationException, NoSuchNodeTypeException, RepositoryException {
+    @Override
+    public void unregisterNodeTypes(final SessionInfo sessionInfo, final Name[] nodeTypeNames) throws RepositoryException {
         execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 service.unregisterNodeTypes(unwrap(sessionInfo), nodeTypeNames);
                 return null;
@@ -751,8 +872,10 @@ public class RepositoryServiceLogger ext
         }, "unregisterNodeTypes(SessionInfo, Name[])", new Object[]{unwrap(sessionInfo), nodeTypeNames});
     }
 
+    @Override
     public void createWorkspace(final SessionInfo sessionInfo, final String name, final String srcWorkspaceName) throws RepositoryException {
         execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 service.createWorkspace(unwrap(sessionInfo), name, srcWorkspaceName);
                 return null;
@@ -760,8 +883,10 @@ public class RepositoryServiceLogger ext
         }, "createWorkspace(SessionInfo, String, String)", new Object[]{unwrap(sessionInfo), name, srcWorkspaceName});
     }
 
+    @Override
     public void deleteWorkspace(final SessionInfo sessionInfo, final String name) throws RepositoryException {
         execute(new Callable() {
+            @Override
             public Object call() throws RepositoryException {
                 service.deleteWorkspace(unwrap(sessionInfo), name);
                 return null;

Modified: jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/logging/Slf4jLogWriter.java
URL: http://svn.apache.org/viewvc/jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/logging/Slf4jLogWriter.java?rev=1166138&r1=1166137&r2=1166138&view=diff
==============================================================================
--- jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/logging/Slf4jLogWriter.java (original)
+++ jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/logging/Slf4jLogWriter.java Wed Sep  7 12:00:14 2011
@@ -16,11 +16,11 @@
  */
 package org.apache.jackrabbit.spi.commons.logging;
 
+import org.slf4j.Logger;
+
 import java.io.PrintWriter;
 import java.io.StringWriter;
 
-import org.slf4j.Logger;
-
 /**
  * {@link LogWriter} implementation which uses SLF4J for persisting log messages.
  */
@@ -33,7 +33,6 @@ public class Slf4jLogWriter implements L
      * @param log
      */
     public Slf4jLogWriter(Logger log) {
-        super();
         this.log = log;
     }
 
@@ -44,6 +43,7 @@ public class Slf4jLogWriter implements L
      * </pre>
      * {@inheritDoc}
      */
+    @Override
     public long systemTime() {
         return System.currentTimeMillis();
     }
@@ -52,9 +52,10 @@ public class Slf4jLogWriter implements L
      * Logs the call at debug level is debug level is enabled.
      * {@inheritDoc}
      */
-    public void enter(final String methodName, final Object[] args) {
+    @Override
+    public void enter(String methodName, Object[] args) {
         if (log.isDebugEnabled()) {
-            log.debug("ENTER(" + systemTime() + ") | " + methodName + "(" + formatArgs(args) + ")");
+            log.debug("ENTER(" + systemTime() + ") | " + methodName + '(' + formatArgs(args) + ')');
         }
     }
 
@@ -62,9 +63,10 @@ public class Slf4jLogWriter implements L
      * Logs the call at debug level is debug level is enabled.
      * {@inheritDoc}
      */
-    public void leave(final String methodName, final Object[] args, final Object result) {
+    @Override
+    public void leave(String methodName, Object[] args, Object result) {
         if (log.isDebugEnabled()) {
-            log.debug("LEAVE(" + systemTime() + ") | " + methodName + "(" + formatArgs(args) + ") = "
+            log.debug("LEAVE(" + systemTime() + ") | " + methodName + '(' + formatArgs(args) + ") = "
                     + formatResult(result));
         }
     }
@@ -73,9 +75,10 @@ public class Slf4jLogWriter implements L
      * Logs the exception including a stack trace at debug level is debug level is enabled.
      * {@inheritDoc}
      */
-    public void error(final String methodName, final Object[] args, final Exception e) {
+    @Override
+    public void error(String methodName, Object[] args, Exception e) {
         if (log.isDebugEnabled()) {
-            log.debug("ERROR(" + systemTime() + ") | " + methodName + "(" + formatArgs(args) + ") | "
+            log.debug("ERROR(" + systemTime() + ") | " + methodName + '(' + formatArgs(args) + ") | "
                     + formatException(e));
         }
     }
@@ -94,7 +97,7 @@ public class Slf4jLogWriter implements L
         return b.toString();
     }
 
-    private String formatException(Exception e) {
+    private static String formatException(Exception e) {
         StringWriter sw = new StringWriter();
         e.printStackTrace(new PrintWriter(sw));
         return sw.toString();
@@ -102,9 +105,9 @@ public class Slf4jLogWriter implements L
 
     private void formatArgs(Object[] args, StringBuffer b) {
         String separator = "";
-        for (int k = 0; k < args.length; k++) {
+        for (Object arg : args) {
             b.append(separator);
-            formatArg(args[k], b);
+            formatArg(arg, b);
             separator = ", ";
         }
     }

Modified: jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/logging/Slf4jLogWriterProvider.java
URL: http://svn.apache.org/viewvc/jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/logging/Slf4jLogWriterProvider.java?rev=1166138&r1=1166137&r2=1166138&view=diff
==============================================================================
--- jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/logging/Slf4jLogWriterProvider.java (original)
+++ jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/logging/Slf4jLogWriterProvider.java Wed Sep  7 12:00:14 2011
@@ -32,71 +32,78 @@ import org.slf4j.LoggerFactory;
 public class Slf4jLogWriterProvider implements LogWriterProvider {
 
     /**
-     * Returns a {@link Slf4jLogWriter} if the logger for <code>
+     * Returns a {@link Slf4jLogWriter} if the logger for {@code }
      * service.getClass()</code> has debug level enabled. Returns
-     * <code>null</code> otherwise.
+     * {@code null} otherwise.
      * {@inheritDoc}
      */
+    @Override
     public LogWriter getLogWriter(RepositoryService service) {
         return getLogWriterInternal(service);
     }
 
     /**
-     * Returns a {@link Slf4jLogWriter} if the logger for <code>
+     * Returns a {@link Slf4jLogWriter} if the logger for {@code }
      * nameFactory.getClass()</code> has debug level enabled. Returns
-     * <code>null</code> otherwise.
+     * {@code null} otherwise.
      * {@inheritDoc}
      */
+    @Override
     public LogWriter getLogWriter(NameFactory nameFactory) {
         return getLogWriterInternal(nameFactory);
     }
 
     /**
-     * Returns a {@link Slf4jLogWriter} if the logger for <code>
+     * Returns a {@link Slf4jLogWriter} if the logger for {@code }
      * pathFactory.getClass()</code> has debug level enabled. Returns
-     * <code>null</code> otherwise.
+     * {@code null} otherwise.
      * {@inheritDoc}
      */
+    @Override
     public LogWriter getLogWriter(PathFactory pathFactory) {
         return getLogWriterInternal(pathFactory);
     }
 
     /**
-     * Returns a {@link Slf4jLogWriter} if the logger for <code>
+     * Returns a {@link Slf4jLogWriter} if the logger for {@code }
      * idFactory.getClass()</code> has debug level enabled. Returns
-     * <code>null</code> otherwise.
+     * {@code null} otherwise.
      * {@inheritDoc}
      */
+    @Override
     public LogWriter getLogWriter(IdFactory idFactory) {
         return getLogWriterInternal(idFactory);
     }
 
     /**
-     * Returns a {@link Slf4jLogWriter} if the logger for <code>
+     * Returns a {@link Slf4jLogWriter} if the logger for {@code }
      * valueFactory.getClass()</code> has debug level enabled. Returns
-     * <code>null</code> otherwise.
+     * {@code null} otherwise.
      * {@inheritDoc}
      */
+    @Override
     public LogWriter getLogWriter(QValueFactory valueFactory) {
         return getLogWriterInternal(valueFactory);
     }
 
     /**
-     * Returns a {@link Slf4jLogWriter} if the logger for <code>
+     * Returns a {@link Slf4jLogWriter} if the logger for {@code }
      * sessionInfo.getClass()</code> has debug level enabled. Returns
-     * <code>null</code> otherwise.
+     * {@code null} otherwise.
      * {@inheritDoc}
      */
+    @Override
     public LogWriter getLogWriter(SessionInfo sessionInfo) {
         return getLogWriterInternal(sessionInfo);
     }
 
     /**
-     * Returns a {@link Slf4jLogWriter} if the logger for <code>
+     * Returns a {@link Slf4jLogWriter} if the logger for {@code }
      * batch.getClass()</code> has debug level enabled. Returns
-     * <code>null</code> otherwise.
+     * {@code null} otherwise.
      * {@inheritDoc}
      */
+    @Override
     public LogWriter getLogWriter(Batch batch) {
         return getLogWriterInternal(batch);
     }

Modified: jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/logging/SpiLoggerFactory.java
URL: http://svn.apache.org/viewvc/jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/logging/SpiLoggerFactory.java?rev=1166138&r1=1166137&r2=1166138&view=diff
==============================================================================
--- jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/logging/SpiLoggerFactory.java (original)
+++ jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/logging/SpiLoggerFactory.java Wed Sep  7 12:00:14 2011
@@ -16,9 +16,6 @@
  */
 package org.apache.jackrabbit.spi.commons.logging;
 
-import javax.jcr.Credentials;
-import javax.jcr.RepositoryException;
-
 import org.apache.jackrabbit.spi.Batch;
 import org.apache.jackrabbit.spi.IdFactory;
 import org.apache.jackrabbit.spi.ItemId;
@@ -28,6 +25,9 @@ import org.apache.jackrabbit.spi.QValueF
 import org.apache.jackrabbit.spi.RepositoryService;
 import org.apache.jackrabbit.spi.SessionInfo;
 
+import javax.jcr.Credentials;
+import javax.jcr.RepositoryException;
+
 /**
  * Static factory for creating instances of the various spi loggers derived from
  * {@link AbstractLogger}.
@@ -35,9 +35,9 @@ import org.apache.jackrabbit.spi.Session
  * <pre>
  *   RepositoryService loggingService = SpiLoggerFactory.create(service);
  * </pre>
- * creates a log wrapper for <code>service</code> which logs all calls to its methods
+ * creates a log wrapper for {@code service} which logs all calls to its methods
  * if logging at the debug level is enabled. If logging is not enabled, no log wrapper
- * is created at all and <code>service</code> itself is returned. There is thus virtually
+ * is created at all and {@code service} itself is returned. There is thus virtually
  * no overhead from disabled loggers. Loggers are enabled and disabled via the
  * configuration mechanism of the logging framework which is in place.
  *
@@ -67,7 +67,6 @@ import org.apache.jackrabbit.spi.Session
 public final class SpiLoggerFactory {
 
     private SpiLoggerFactory() {
-        super();
     }
 
     /**
@@ -84,13 +83,13 @@ public final class SpiLoggerFactory {
     }
 
     /**
-     * Returns a log wrapper for the given <code>service</code> which logs a calls to its
-     * methods if <code>logWriterProvider</code> returns a {@link LogWriter} instance for
-     * <code>service</code>. Otherwise returns <code>service</code>.
+     * Returns a log wrapper for the given {@code service} which logs a calls to its
+     * methods if {@code logWriterProvider} returns a {@link LogWriter} instance for
+     * {@code service}. Otherwise returns {@code service}.
      * @param service
      * @param logWriterProvider
      * @return
-     * @throws IllegalArgumentException if either argument is <code>null</code>
+     * @throws IllegalArgumentException if either argument is {@code null}
      */
     public static RepositoryService create(RepositoryService service, LogWriterProvider logWriterProvider) {
         if (service == null) {
@@ -110,13 +109,13 @@ public final class SpiLoggerFactory {
     }
 
     /**
-     * Returns a log wrapper for the given <code>nameFactory</code> which logs a calls to its
-     * methods if <code>logWriterProvider</code> returns a {@link LogWriter} instance for
-     * <code>nameFactory</code>. Otherwise returns <code>nameFactory</code>.
+     * Returns a log wrapper for the given {@code nameFactory} which logs a calls to its
+     * methods if {@code logWriterProvider} returns a {@link LogWriter} instance for
+     * {@code nameFactory}. Otherwise returns {@code nameFactory}.
      * @param nameFactory
      * @param logWriterProvider
      * @return
-     * @throws IllegalArgumentException if either argument is <code>null</code>
+     * @throws IllegalArgumentException if either argument is {@code null}
      */
     public static NameFactory create(NameFactory nameFactory, LogWriterProvider logWriterProvider) {
         if (nameFactory == null) {
@@ -136,13 +135,13 @@ public final class SpiLoggerFactory {
     }
 
     /**
-     * Returns a log wrapper for the given <code>pathFactory</code> which logs a calls to its
-     * methods if <code>logWriterProvider</code> returns a {@link LogWriter} instance for
-     * <code>pathFactory</code>. Otherwise returns <code>pathFactory</code>.
+     * Returns a log wrapper for the given {@code pathFactory} which logs a calls to its
+     * methods if {@code logWriterProvider} returns a {@link LogWriter} instance for
+     * {@code pathFactory}. Otherwise returns {@code pathFactory}.
      * @param pathFactory
      * @param logWriterProvider
      * @return
-     * @throws IllegalArgumentException if either argument is <code>null</code>
+     * @throws IllegalArgumentException if either argument is {@code null}
      */
     public static PathFactory create(PathFactory pathFactory, LogWriterProvider logWriterProvider) {
         if (pathFactory == null) {
@@ -162,13 +161,13 @@ public final class SpiLoggerFactory {
     }
 
     /**
-     * Returns a log wrapper for the given <code>idFactory</code> which logs a calls to its
-     * methods if <code>logWriterProvider</code> returns a {@link LogWriter} instance for
-     * <code>idFactory</code>. Otherwise returns <code>idFactory</code>.
+     * Returns a log wrapper for the given {@code idFactory} which logs a calls to its
+     * methods if {@code logWriterProvider} returns a {@link LogWriter} instance for
+     * {@code idFactory}. Otherwise returns {@code idFactory}.
      * @param idFactory
      * @param logWriterProvider
      * @return
-     * @throws IllegalArgumentException if either argument is <code>null</code>
+     * @throws IllegalArgumentException if either argument is {@code null}
      */
     public static IdFactory create(IdFactory idFactory, LogWriterProvider logWriterProvider) {
         if (idFactory == null) {
@@ -188,13 +187,13 @@ public final class SpiLoggerFactory {
     }
 
     /**
-     * Returns a log wrapper for the given <code>qValueFactory</code> which logs a calls to its
-     * methods if <code>logWriterProvider</code> returns a {@link LogWriter} instance for
-     * <code>qValueFactory</code>. Otherwise returns <code>qValueFactory</code>.
+     * Returns a log wrapper for the given {@code qValueFactory} which logs a calls to its
+     * methods if {@code logWriterProvider} returns a {@link LogWriter} instance for
+     * {@code qValueFactory}. Otherwise returns {@code qValueFactory}.
      * @param qValueFactory
      * @param logWriterProvider
      * @return
-     * @throws IllegalArgumentException if either argument is <code>null</code>
+     * @throws IllegalArgumentException if either argument is {@code null}
      */
     public static QValueFactory create(QValueFactory qValueFactory, LogWriterProvider logWriterProvider) {
         if (qValueFactory == null) {
@@ -214,13 +213,13 @@ public final class SpiLoggerFactory {
     }
 
     /**
-     * Returns a log wrapper for the given <code>sessionInfo</code> which logs a calls to its
-     * methods if <code>logWriterProvider</code> returns a {@link LogWriter} instance for
-     * <code>sessionInfo</code>. Otherwise returns <code>sessionInfo</code>.
+     * Returns a log wrapper for the given {@code sessionInfo} which logs a calls to its
+     * methods if {@code logWriterProvider} returns a {@link LogWriter} instance for
+     * {@code sessionInfo}. Otherwise returns {@code sessionInfo}.
      * @param sessionInfo
      * @param logWriterProvider
      * @return
-     * @throws IllegalArgumentException if either argument is <code>null</code>
+     * @throws IllegalArgumentException if either argument is {@code null}
      */
     public static SessionInfo create(SessionInfo sessionInfo, LogWriterProvider logWriterProvider) {
         if (sessionInfo == null) {
@@ -240,13 +239,13 @@ public final class SpiLoggerFactory {
     }
 
     /**
-     * Returns a log wrapper for the given <code>batch</code> which logs a calls to its
-     * methods if <code>logWriterProvider</code> returns a {@link LogWriter} instance for
-     * <code>batch</code>. Otherwise returns <code>batch</code>.
+     * Returns a log wrapper for the given {@code batch} which logs a calls to its
+     * methods if {@code logWriterProvider} returns a {@link LogWriter} instance for
+     * {@code batch}. Otherwise returns {@code batch}.
      * @param batch
      * @param logWriterProvider
      * @return
-     * @throws IllegalArgumentException if either argument is <code>null</code>
+     * @throws IllegalArgumentException if either argument is {@code null}
      */
     public static Batch create(Batch batch, LogWriterProvider logWriterProvider) {
         if (batch == null) {
@@ -311,7 +310,7 @@ public final class SpiLoggerFactory {
         }
 
         @Override
-        public SessionInfo obtain(final Credentials credentials, final String workspaceName)
+        public SessionInfo obtain(Credentials credentials, String workspaceName)
                 throws RepositoryException {
 
             SessionInfo result = super.obtain(credentials, workspaceName);
@@ -321,7 +320,7 @@ public final class SpiLoggerFactory {
         }
 
         @Override
-        public SessionInfo obtain(final SessionInfo sessionInfo, final String workspaceName)
+        public SessionInfo obtain(SessionInfo sessionInfo, String workspaceName)
                 throws RepositoryException {
 
             SessionInfo result = super.obtain(sessionInfo, workspaceName);
@@ -331,7 +330,7 @@ public final class SpiLoggerFactory {
         }
 
         @Override
-        public SessionInfo impersonate(final SessionInfo sessionInfo, final Credentials credentials)
+        public SessionInfo impersonate(SessionInfo sessionInfo, Credentials credentials)
                 throws RepositoryException {
 
             SessionInfo result = super.impersonate(sessionInfo, credentials);
@@ -341,7 +340,7 @@ public final class SpiLoggerFactory {
         }
 
         @Override
-        public Batch createBatch(final SessionInfo sessionInfo, final ItemId itemId)
+        public Batch createBatch(SessionInfo sessionInfo, ItemId itemId)
                 throws RepositoryException {
 
             Batch result = super.createBatch(sessionInfo, itemId);

Modified: jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/logging/WriterLogWriter.java
URL: http://svn.apache.org/viewvc/jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/logging/WriterLogWriter.java?rev=1166138&r1=1166137&r2=1166138&view=diff
==============================================================================
--- jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/logging/WriterLogWriter.java (original)
+++ jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/logging/WriterLogWriter.java Wed Sep  7 12:00:14 2011
@@ -36,7 +36,6 @@ public class WriterLogWriter implements 
      * @param category log category
      */
     public WriterLogWriter(Writer log, String category) {
-        super();
         this.log = new PrintWriter(log);
         this.category = category;
     }
@@ -48,6 +47,7 @@ public class WriterLogWriter implements 
      * </pre>
      * {@inheritDoc}
      */
+    @Override
     public long systemTime() {
         return System.currentTimeMillis();
     }
@@ -56,16 +56,18 @@ public class WriterLogWriter implements 
      * Logs the call at debug level is debug level is enabled.
      * {@inheritDoc}
      */
-    public void enter(final String methodName, final Object[] args) {
-        print("ENTER(" + systemTime() + ") | " + methodName + "(" + formatArgs(args) + ")");
+    @Override
+    public void enter(String methodName, Object[] args) {
+        print("ENTER(" + systemTime() + ") | " + methodName + '(' + formatArgs(args) + ')');
     }
 
     /**
      * Logs the call at debug level is debug level is enabled.
      * {@inheritDoc}
      */
-    public void leave(final String methodName, final Object[] args, final Object result) {
-        print("LEAVE(" + systemTime() + ") | " + methodName + "(" + formatArgs(args) + ") = "
+    @Override
+    public void leave(String methodName, Object[] args, Object result) {
+        print("LEAVE(" + systemTime() + ") | " + methodName + '(' + formatArgs(args) + ") = "
                 + formatResult(result));
     }
 
@@ -73,8 +75,9 @@ public class WriterLogWriter implements 
      * Logs the exception including a stack trace at debug level is debug level is enabled.
      * {@inheritDoc}
      */
-    public void error(final String methodName, final Object[] args, final Exception e) {
-        print("ERROR(" + systemTime() + ") | " + methodName + "(" + formatArgs(args) + ") | "
+    @Override
+    public void error(String methodName, Object[] args, Exception e) {
+        print("ERROR(" + systemTime() + ") | " + methodName + '(' + formatArgs(args) + ") | "
                 + formatException(e));
     }
 
@@ -98,7 +101,7 @@ public class WriterLogWriter implements 
         return b.toString();
     }
 
-    private String formatException(Exception e) {
+    private static String formatException(Exception e) {
         StringWriter sw = new StringWriter();
         e.printStackTrace(new PrintWriter(sw));
         return sw.toString();

Modified: jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/logging/WriterLogWriterProvider.java
URL: http://svn.apache.org/viewvc/jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/logging/WriterLogWriterProvider.java?rev=1166138&r1=1166137&r2=1166138&view=diff
==============================================================================
--- jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/logging/WriterLogWriterProvider.java (original)
+++ jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/logging/WriterLogWriterProvider.java Wed Sep  7 12:00:14 2011
@@ -16,8 +16,6 @@
  */
 package org.apache.jackrabbit.spi.commons.logging;
 
-import java.io.Writer;
-
 import org.apache.jackrabbit.spi.Batch;
 import org.apache.jackrabbit.spi.IdFactory;
 import org.apache.jackrabbit.spi.NameFactory;
@@ -26,6 +24,8 @@ import org.apache.jackrabbit.spi.QValueF
 import org.apache.jackrabbit.spi.RepositoryService;
 import org.apache.jackrabbit.spi.SessionInfo;
 
+import java.io.Writer;
+
 /**
  * {@link LogWriterProvider} instance which provides {@link WriterLogWriter}s.
  */
@@ -45,71 +45,78 @@ public class WriterLogWriterProvider imp
     }
 
     /**
-     * Returns a {@link WriterLogWriter} if the logger for <code>
+     * Returns a {@link WriterLogWriter} if the logger for {@code }
      * service.getClass()</code> has debug level enabled. Returns
-     * <code>null</code> otherwise.
+     * {@code null} otherwise.
      * {@inheritDoc}
      */
+    @Override
     public LogWriter getLogWriter(RepositoryService service) {
         return getLogWriterInternal(log, service);
     }
 
     /**
-     * Returns a {@link WriterLogWriter} if the logger for <code>
+     * Returns a {@link WriterLogWriter} if the logger for {@code }
      * nameFactory.getClass()</code> has debug level enabled. Returns
-     * <code>null</code> otherwise.
+     * {@code null} otherwise.
      * {@inheritDoc}
      */
+    @Override
     public LogWriter getLogWriter(NameFactory nameFactory) {
         return getLogWriterInternal(log, nameFactory);
     }
 
     /**
-     * Returns a {@link WriterLogWriter} if the logger for <code>
+     * Returns a {@link WriterLogWriter} if the logger for {@code }
      * pathFactory.getClass()</code> has debug level enabled. Returns
-     * <code>null</code> otherwise.
+     * {@code null} otherwise.
      * {@inheritDoc}
      */
+    @Override
     public LogWriter getLogWriter(PathFactory pathFactory) {
         return getLogWriterInternal(log, pathFactory);
     }
 
     /**
-     * Returns a {@link WriterLogWriter} if the logger for <code>
+     * Returns a {@link WriterLogWriter} if the logger for {@code }
      * idFactory.getClass()</code> has debug level enabled. Returns
-     * <code>null</code> otherwise.
+     * {@code null} otherwise.
      * {@inheritDoc}
      */
+    @Override
     public LogWriter getLogWriter(IdFactory idFactory) {
         return getLogWriterInternal(log, idFactory);
     }
 
     /**
-     * Returns a {@link WriterLogWriter} if the logger for <code>
+     * Returns a {@link WriterLogWriter} if the logger for {@code }
      * valueFactory.getClass()</code> has debug level enabled. Returns
-     * <code>null</code> otherwise.
+     * {@code null} otherwise.
      * {@inheritDoc}
      */
+    @Override
     public LogWriter getLogWriter(QValueFactory valueFactory) {
         return getLogWriterInternal(log, valueFactory);
     }
 
     /**
-     * Returns a {@link WriterLogWriter} if the logger for <code>
+     * Returns a {@link WriterLogWriter} if the logger for {@code }
      * sessionInfo.getClass()</code> has debug level enabled. Returns
-     * <code>null</code> otherwise.
+     * {@code null} otherwise.
      * {@inheritDoc}
      */
+    @Override
     public LogWriter getLogWriter(SessionInfo sessionInfo) {
         return getLogWriterInternal(log, sessionInfo);
     }
 
     /**
-     * Returns a {@link WriterLogWriter} if the logger for <code>
+     * Returns a {@link WriterLogWriter} if the logger for {@code }
      * batch.getClass()</code> has debug level enabled. Returns
-     * <code>null</code> otherwise.
+     * {@code null} otherwise.
      * {@inheritDoc}
      */
+    @Override
     public LogWriter getLogWriter(Batch batch) {
         return getLogWriterInternal(log, batch);
     }

Modified: jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/name/AbstractPath.java
URL: http://svn.apache.org/viewvc/jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/name/AbstractPath.java?rev=1166138&r1=1166137&r2=1166138&view=diff
==============================================================================
--- jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/name/AbstractPath.java (original)
+++ jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/name/AbstractPath.java Wed Sep  7 12:00:14 2011
@@ -16,10 +16,10 @@
  */
 package org.apache.jackrabbit.spi.commons.name;
 
-import javax.jcr.RepositoryException;
-
 import org.apache.jackrabbit.spi.Path;
 
+import javax.jcr.RepositoryException;
+
 /**
  * Abstract base class for paths.
  */
@@ -34,6 +34,7 @@ abstract class AbstractPath implements P
      *
      * @return {@link Path#INDEX_UNDEFINED}
      */
+    @Override
     public int getIndex() {
         return INDEX_UNDEFINED;
     }
@@ -44,70 +45,78 @@ abstract class AbstractPath implements P
      *
      * @return {@link Path#INDEX_DEFAULT}
      */
+    @Override
     public int getNormalizedIndex() {
         return INDEX_DEFAULT;
     }
 
     /**
-     * Returns <code>null</code>, except when overridden by the
+     * Returns {@code null}, except when overridden by the
      * {@link IdentifierPath} subclass.
      *
-     * @return <code>null</code>
+     * @return {@code null}
      */
+    @Override
     public String getIdentifier() {
         return null;
     }
 
     /**
-     * Returns <code>false</code>, except when overridden by the
+     * Returns {@code false}, except when overridden by the
      * {@link RootPath} subclass.
      *
-     * @return <code>false</code>
+     * @return {@code false}
      */
+    @Override
     public boolean denotesRoot() {
         return false;
     }
 
     /**
-     * Returns <code>false</code>, except when overridden by the
+     * Returns {@code false}, except when overridden by the
      * {@link IdentifierPath} subclass.
      *
-     * @return <code>false</code>
+     * @return {@code false}
      */
+    @Override
     public boolean denotesIdentifier() {
         return false;
     }
 
     /**
-     * Returns <code>false</code>, except when overridden by the
+     * Returns {@code false}, except when overridden by the
      * {@link ParentPath} subclass.
      *
-     * @return <code>false</code>
+     * @return {@code false}
      */
+    @Override
     public boolean denotesParent() {
         return false;
     }
 
     /**
-     * Returns <code>false</code>, except when overridden by the
+     * Returns {@code false}, except when overridden by the
      * {@link CurrentPath} subclass.
      *
-     * @return <code>false</code>
+     * @return {@code false}
      */
+    @Override
     public boolean denotesCurrent() {
         return false;
     }
 
     /**
-     * Returns <code>false</code>, except when overridden by the
+     * Returns {@code false}, except when overridden by the
      * {@link NamePath} subclass.
      *
-     * @return <code>false</code>
+     * @return {@code false}
      */
+    @Override
     public boolean denotesName() {
         return false;
     }
 
+    @Override
     public Element getNameElement() {
         return getLastElement();
     }
@@ -118,20 +127,23 @@ abstract class AbstractPath implements P
      *
      * @return this path
      */
+    @Override
     public AbstractPath getLastElement() {
         return this;
     }
 
     /**
-     * Returns <code>null</code>, except when overridden by the
+     * Returns {@code null}, except when overridden by the
      * {@link RelativePath} subclass.
      *
-     * @return <code>null</code>
+     * @return {@code null}
      */
+    @Override
     public Path getFirstElements() {
         return null;
     }
 
+    @Override
     public final Path resolve(Element element) {
         if (element.denotesName()) {
             return new NamePath(this, element.getName(), element.getIndex());
@@ -153,6 +165,7 @@ abstract class AbstractPath implements P
         }
     }
 
+    @Override
     public final Path resolve(Path relative) {
         if (relative.isAbsolute()) {
             return relative;
@@ -180,6 +193,7 @@ abstract class AbstractPath implements P
      * @return relative path
      * @throws RepositoryException if the relative path can not be computed
      */
+    @Override
     public final Path computeRelativePath(Path other)
             throws RepositoryException {
         if (other != null && isAbsolute() && other.isAbsolute()) {
@@ -238,18 +252,19 @@ abstract class AbstractPath implements P
      * comparing the normalized paths for equality.
      *
      * @param other other path
-     * @return <code>true</code> if this path is equivalent to the other path,
-     *         <code>false</code> otherwise
-     * @throws IllegalArgumentException if the other path is <code>null</code>
+     * @return {@code true} if this path is equivalent to the other path,
+     *         {@code false} otherwise
+     * @throws IllegalArgumentException if the other path is {@code null}
      * @throws RepositoryException if an error occurs
      */
+    @Override
     public final boolean isEquivalentTo(Path other)
             throws IllegalArgumentException, RepositoryException {
         if (other != null) {
             return getNormalizedPath().equals(other.getNormalizedPath());
         } else {
             throw new IllegalArgumentException(
-                    this + ".isEquivalentTo(" + other + ")");
+                    this + ".isEquivalentTo(" + other + ')');
         }
     }
 
@@ -259,13 +274,14 @@ abstract class AbstractPath implements P
      * ancestor of the given other path is equivalent to this path.
      *
      * @param other other path
-     * @return <code>true</code> if this path is an ancestor of the other path,
-     *         <code>false</code> otherwise
-     * @throws IllegalArgumentException if the other path is <code>null</code>,
+     * @return {@code true} if this path is an ancestor of the other path,
+     *         {@code false} otherwise
+     * @throws IllegalArgumentException if the other path is {@code null},
      *                                  or relative when this path is absolute,
      *                                  or vice versa
      * @throws RepositoryException if an error occurs
      */
+    @Override
     public final boolean isAncestorOf(Path other)
             throws IllegalArgumentException, RepositoryException {
         if (other != null
@@ -275,7 +291,7 @@ abstract class AbstractPath implements P
             return d > 0 && isEquivalentTo(other.getAncestor(d));
         } else {
             throw new IllegalArgumentException(
-                    this + ".isAncestorOf(" + other + ")");
+                    this + ".isAncestorOf(" + other + ')');
         }
     }
 
@@ -285,13 +301,14 @@ abstract class AbstractPath implements P
      * ancestor of this path is equivalent to the given other path.
      *
      * @param other other path
-     * @return <code>true</code> if this path is a descendant of the other path,
-     *         <code>false</code> otherwise
-     * @throws IllegalArgumentException if the other path is <code>null</code>,
+     * @return {@code true} if this path is a descendant of the other path,
+     *         {@code false} otherwise
+     * @throws IllegalArgumentException if the other path is {@code null},
      *                                  or relative when this path is absolute,
      *                                  or vice versa
      * @throws RepositoryException if an error occurs
      */
+    @Override
     public final boolean isDescendantOf(Path other)
             throws IllegalArgumentException, RepositoryException {
         if (other != null
@@ -301,7 +318,7 @@ abstract class AbstractPath implements P
             return d > 0 && getAncestor(d).isEquivalentTo(other);
         } else {
             throw new IllegalArgumentException(
-                    this + ".isDescendantOf(" + other + ")");
+                    this + ".isDescendantOf(" + other + ')');
         }
     }
 

Modified: jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/name/CurrentPath.java
URL: http://svn.apache.org/viewvc/jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/name/CurrentPath.java?rev=1166138&r1=1166137&r2=1166138&view=diff
==============================================================================
--- jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/name/CurrentPath.java (original)
+++ jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/name/CurrentPath.java Wed Sep  7 12:00:14 2011
@@ -16,15 +16,13 @@
  */
 package org.apache.jackrabbit.spi.commons.name;
 
-import javax.jcr.RepositoryException;
-
 import org.apache.jackrabbit.spi.Name;
 import org.apache.jackrabbit.spi.Path;
 
+import javax.jcr.RepositoryException;
+
 /**
  * A relative path whose last element is the current path element, i.e. ".".
- *
- * @see CurrentElement
  */
 final class CurrentPath extends RelativePath {
 
@@ -42,10 +40,12 @@ final class CurrentPath extends Relative
         super(parent);
     }
 
+    @Override
     protected int getDepthModifier() {
         return 0;
     }
 
+    @Override
     protected Path getParent() throws RepositoryException {
         if (parent != null) {
             return parent.getAncestor(1);
@@ -54,18 +54,20 @@ final class CurrentPath extends Relative
         }
     }
 
+    @Override
     protected String getElementString() {
         return NAME.getLocalName();
     }
 
+    @Override
     public Name getName() {
         return NAME;
     }
 
     /**
-     * Returns <code>true</code> as this path ends in the current element.
+     * Returns {@code true} as this path ends in the current element.
      *
-     * @return <code>true</code>
+     * @return {@code true}
      */
     @Override
     public boolean denotesCurrent() {
@@ -73,19 +75,22 @@ final class CurrentPath extends Relative
     }
 
     /**
-     * Returns <code>false</code> as a path with a "." element is
+     * Returns {@code false} as a path with a "." element is
      * never canonical.
      *
-     * @return <code>false</code>
+     * @return {@code false}
      */
+    @Override
     public boolean isCanonical() {
         return false;
     }
 
+    @Override
     public boolean isNormalized() {
         return parent == null;
     }
 
+    @Override
     public Path getNormalizedPath() throws RepositoryException {
         if (parent != null) {
             return parent.getNormalizedPath();
@@ -94,6 +99,7 @@ final class CurrentPath extends Relative
         }
     }
 
+    @Override
     public Path getCanonicalPath() throws RepositoryException {
         if (parent != null) {
             return parent.getCanonicalPath();

Modified: jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/name/HashCache.java
URL: http://svn.apache.org/viewvc/jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/name/HashCache.java?rev=1166138&r1=1166137&r2=1166138&view=diff
==============================================================================
--- jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/name/HashCache.java (original)
+++ jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/name/HashCache.java Wed Sep  7 12:00:14 2011
@@ -23,7 +23,7 @@ package org.apache.jackrabbit.spi.common
  * hash to the same location, only the most recently accessed object is
  * kept in the cache.
  *
- * @see https://issues.apache.org/jira/browse/JCR-1663
+ * see https://issues.apache.org/jira/browse/JCR-1663
  */
 public class HashCache<T> {
 
@@ -41,13 +41,13 @@ public class HashCache<T> {
     }
 
     /**
-     * Creates a hash cache with 2^<code>exponent</code> slots.
+     * Creates a hash cache with 2^{@code exponent} slots.
      *
      * @param exponent the exponent.
      */
     @SuppressWarnings("unchecked")
     public HashCache(int exponent) {
-        this.array = (T[]) new Object[2 << exponent];
+        array = (T[]) new Object[2 << exponent];
     }
 
     /**
@@ -58,7 +58,7 @@ public class HashCache<T> {
      * @return the given object or a previously cached copy
      */
     public T get(T object) {
-        int position = object.hashCode() & (array.length - 1);
+        int position = object.hashCode() & array.length - 1;
         T previous = array[position];
         if (object.equals(previous)) {
             return previous;

Modified: jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/name/IdentifierPath.java
URL: http://svn.apache.org/viewvc/jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/name/IdentifierPath.java?rev=1166138&r1=1166137&r2=1166138&view=diff
==============================================================================
--- jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/name/IdentifierPath.java (original)
+++ jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/name/IdentifierPath.java Wed Sep  7 12:00:14 2011
@@ -16,11 +16,11 @@
  */
 package org.apache.jackrabbit.spi.commons.name;
 
-import javax.jcr.RepositoryException;
-
 import org.apache.jackrabbit.spi.Name;
 import org.apache.jackrabbit.spi.Path;
 
+import javax.jcr.RepositoryException;
+
 final class IdentifierPath extends AbstractPath {
 
     /** Serial version UID */
@@ -34,22 +34,24 @@ final class IdentifierPath extends Abstr
     }
 
     /**
-     * Returns <code>null</code> as an identifier element has no name.
+     * Returns {@code null} as an identifier element has no name.
      *
-     * @return <code>null</code>
+     * @return {@code null}
      */
+    @Override
     public Name getName() {
         return null;
     }
 
+    @Override
     public String getIdentifier() {
         return identifier;
     }
 
     /**
-     * Returns <code>true</code> as this is an identifier-based path.
+     * Returns {@code true} as this is an identifier-based path.
      *
-     * @return <code>true</code>
+     * @return {@code true}
      */
     @Override
     public boolean denotesIdentifier() {
@@ -57,58 +59,65 @@ final class IdentifierPath extends Abstr
     }
 
     /**
-     * Returns <code>true</code> as this is an identifier-based path.
+     * Returns {@code true} as this is an identifier-based path.
      *
-     * @return <code>true</code>
+     * @return {@code true}
      */
+    @Override
     public boolean isIdentifierBased() {
         return true;
     }
 
     /**
-     * Returns <code>true</code> as an identifier-based path with no other
+     * Returns {@code true} as an identifier-based path with no other
      * elements is absolute.
      *
-     * @return <code>true</code>
+     * @return {@code true}
      */
+    @Override
     public boolean isAbsolute() {
         return true;
     }
 
     /**
-     * Returns <code>true</code> as an identifier-based path with no other
+     * Returns {@code true} as an identifier-based path with no other
      * elements is canonical.
      *
-     * @return <code>true</code>
+     * @return {@code true}
      */
+    @Override
     public boolean isCanonical() {
         return true;
     }
 
     /**
-     * Returns <code>false</code> as an identifier-based path is never
+     * Returns {@code false} as an identifier-based path is never
      * normalized.
      *
-     * @return <code>false</code>
+     * @return {@code false}
      */
+    @Override
     public boolean isNormalized() {
         return false;
     }
 
+    @Override
     public Path getNormalizedPath() throws RepositoryException {
         throw new RepositoryException(
                 "Cannot normalize the identifier-based path " + this);
     }
 
+    @Override
     public Path getCanonicalPath() {
         return this;
     }
 
+    @Override
     public Path getAncestor(int degree)
             throws IllegalArgumentException, RepositoryException {
         if (degree < 0) {
             throw new IllegalArgumentException(
-                    this + ".getAncestor(" + degree + ")");
+                    this + ".getAncestor(" + degree + ')');
         } else if (degree > 0) {
             throw new RepositoryException(
                     "Cannot construct ancestor path from an identifier");
@@ -117,33 +126,39 @@ final class IdentifierPath extends Abstr
         }
     }
 
+    @Override
     public int getAncestorCount() {
         return 0;
     }
 
+    @Override
     public int getLength() {
         return 1;
     }
 
+    @Override
     public int getDepth() {
         return 0;
     }
 
+    @Override
     public Path subPath(int from, int to) throws IllegalArgumentException {
         if (from == 0 && to == 1) {
             return this;
         } else {
             throw new IllegalArgumentException(
-                    this + ".subPath(" + from + ", " + to + ")");
+                    this + ".subPath(" + from + ", " + to + ')');
         }
     }
 
+    @Override
     public Element[] getElements() {
         return new Element[] { getNameElement() };
     }
 
+    @Override
     public String getString() {
-        return "[" + identifier + "]";
+        return '[' + identifier + ']';
     }
 
     //--------------------------------------------------------------< Object >

Modified: jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/name/MatchResult.java
URL: http://svn.apache.org/viewvc/jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/name/MatchResult.java?rev=1166138&r1=1166137&r2=1166138&view=diff
==============================================================================
--- jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/name/MatchResult.java (original)
+++ jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/name/MatchResult.java Wed Sep  7 12:00:14 2011
@@ -33,21 +33,20 @@ public class MatchResult {
     }
 
     MatchResult(Path path, int pos, int length) {
-        super();
         if (!path.isNormalized()) {
             throw new IllegalArgumentException("Path not normalized");
         }
         this.path = path;
-        this.matchPos = pos;
-        this.matchLength = length;
-        this.pathLength = path.getLength();
+        matchPos = pos;
+        matchLength = length;
+        pathLength = path.getLength();
     }
 
     /**
      * Returns the remaining path after the matching part.
-     * @return  The remaining path after the matching part such that the path constructed from
+     * @return The remaining path after the matching part such that the path constructed from
      *   {@link #getMatch()} followed by {@link #getRemainder()} is the original path or
-     *   <code>null</code> if {@link #isFullMatch()} is <code>true</code>.
+     *   {@code null} if {@link #isFullMatch()} is {@code true}.
      */
     public Path getRemainder() {
         if (matchPos + matchLength >= pathLength) {
@@ -61,7 +60,7 @@ public class MatchResult {
      * Returns the path which was matched by the {@link Pattern}.
      * @return The path which was matched such that the path constructed from
      *   {@link #getMatch()} followed by {@link #getRemainder()} is the original path or
-     *   <code>null</code> if {@link #getMatchLength()} is <code>0</code>.
+     *   {@code null} if {@link #getMatchLength()} is {@code 0}.
      */
     public Path getMatch() {
         if (matchLength == 0) {

Modified: jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/name/Matcher.java
URL: http://svn.apache.org/viewvc/jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/name/Matcher.java?rev=1166138&r1=1166137&r2=1166138&view=diff
==============================================================================
--- jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/name/Matcher.java (original)
+++ jackrabbit/sandbox/jackrabbit-mk/jackrabbit-spi-commons/src/main/java/org/apache/jackrabbit/spi/commons/name/Matcher.java Wed Sep  7 12:00:14 2011
@@ -31,7 +31,7 @@ public final class Matcher {
      * Match a pattern against an input path and return the remaining path.
      * @param pattern
      * @param input
-     * @return The remaining path after the match or <code>null</code> if the whole path
+     * @return The remaining path after the match or {@code null} if the whole path
      *   was matched.
      * @see MatchResult#getRemainder()
      */
@@ -43,7 +43,7 @@ public final class Matcher {
      * Checks whether a pattern matches an input path.
      * @param pattern
      * @param input
-     * @return <code>true</code> if <code>pattern</code> matches the whole <code>input</code>.
+     * @return {@code true} if {@code pattern} matches the whole {@code input}.
      * @see MatchResult#isFullMatch()
      */
     public static boolean matches(Pattern pattern, Path input) {
@@ -56,7 +56,7 @@ public final class Matcher {
      * @param input
      * @return A {@link MatchResult} or null if the pattern does not occur in the
      *   input.
-     * @throws IllegalArgumentException if <code>input</code> is not normalized.
+     * @throws IllegalArgumentException if {@code input} is not normalized.
      */
     public static MatchResult findMatch(Pattern pattern, Path input) {
         return findMatch(pattern, input, 0);
@@ -69,7 +69,7 @@ public final class Matcher {
      * @param pos
      * @return A {@link MatchResult} or null if the pattern does not occur in the
      *   input.
-     * @throws IllegalArgumentException if <code>input</code> is not normalized.
+     * @throws IllegalArgumentException if {@code input} is not normalized.
      */
     public static MatchResult findMatch(Pattern pattern, Path input, int pos) {
         int length = input.getLength();