You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@karaf.apache.org by jb...@apache.org on 2016/03/15 00:20:08 UTC

[3/5] karaf git commit: KARAF-4392 - Upgrade to maven-javadoc-plugin 2.10.3 and clean javadoc comments

http://git-wip-us.apache.org/repos/asf/karaf/blob/8a1e7574/log/src/main/java/org/apache/karaf/log/core/internal/layout/PatternParser.java
----------------------------------------------------------------------
diff --git a/log/src/main/java/org/apache/karaf/log/core/internal/layout/PatternParser.java b/log/src/main/java/org/apache/karaf/log/core/internal/layout/PatternParser.java
index d747ea9..26956f4 100644
--- a/log/src/main/java/org/apache/karaf/log/core/internal/layout/PatternParser.java
+++ b/log/src/main/java/org/apache/karaf/log/core/internal/layout/PatternParser.java
@@ -101,10 +101,12 @@ public class PatternParser {
 
 
   /**
-     The option is expected to be in decimal and positive. In case of
-     error, zero is returned.  */
-  protected
-  int extractPrecisionOption() {
+   * The option is expected to be in decimal and positive.
+   * In case of error, zero is returned.
+   *
+   * @return The precision value, or zero in case of error.
+   */
+  protected int extractPrecisionOption() {
     String opt = extractOption();
     int r = 0;
     if(opt != null) {

http://git-wip-us.apache.org/repos/asf/karaf/blob/8a1e7574/main/src/main/java/org/apache/karaf/main/Main.java
----------------------------------------------------------------------
diff --git a/main/src/main/java/org/apache/karaf/main/Main.java b/main/src/main/java/org/apache/karaf/main/Main.java
index 1eae257..7426c8c 100644
--- a/main/src/main/java/org/apache/karaf/main/Main.java
+++ b/main/src/main/java/org/apache/karaf/main/Main.java
@@ -95,7 +95,7 @@ public class Main {
      * when invoked:
      * </p>
      * <ol>
-     *   <li><i><b>Read the system properties file.<b></i> This is a file
+     *   <li><i><b>Read the system properties file.</b></i> This is a file
      *       containing properties to be pushed into <tt>System.setProperty()</tt>
      *       before starting the framework. This mechanism is mainly shorthand
      *       for people starting the framework from the command line to avoid having
@@ -123,8 +123,7 @@ public class Main {
      *       the desired URL using the <tt>felix.config.properties</tt>
      *       system property; this should be set using the <tt>-D</tt> syntax
      *       when executing the JVM. Refer to the
-     *       <a href="Felix.html#Felix(java.util.Map, java.util.List)">
-     *       <tt>Felix</tt></a> constructor documentation for more
+     *       <tt>Felix</tt> constructor documentation for more
      *       information on the framework configuration options.
      *   </li>
      *   <li><i><b>Perform system property variable substitution on configuration
@@ -158,8 +157,7 @@ public class Main {
      * the configuration property file cannot be found, the framework will appear to
      * be hung or deadlocked. This is not the case, it is executing correctly,
      * there is just no way to interact with it. Refer to the
-     * <a href="Felix.html#Felix(java.util.Map, java.util.List)">
-     * <tt>Felix</tt></a> constructor documentation for more information on
+     * <tt>Felix</tt> constructor documentation for more information on
      * framework configuration options.
      * </p>
      * @param args An array of arguments, all of which are ignored.

http://git-wip-us.apache.org/repos/asf/karaf/blob/8a1e7574/main/src/main/java/org/apache/karaf/main/ShutdownCallback.java
----------------------------------------------------------------------
diff --git a/main/src/main/java/org/apache/karaf/main/ShutdownCallback.java b/main/src/main/java/org/apache/karaf/main/ShutdownCallback.java
index bd0bf30..cb70e9a 100644
--- a/main/src/main/java/org/apache/karaf/main/ShutdownCallback.java
+++ b/main/src/main/java/org/apache/karaf/main/ShutdownCallback.java
@@ -18,19 +18,20 @@
  */
 package org.apache.karaf.main;
 
-
 /**
  * <p>
- * This interface is a callback interface for the stoping process. 
+ * This interface is a callback interface for the stopping process.
  * It's main purpose is to give the ServiceWrapper a way of waiting 
  * for the Framework to gracefully stop the Server. 
- * <p>
+ * </p>
  */
 public interface ShutdownCallback {
 
 	/**
 	 * The callback method invoked to inform anyone listening that the 
-	 * Main class is still waiting for the completion of the shutdown. 
+	 * Main class is still waiting for the completion of the shutdown.
+	 *
+	 * @param delay The delay to wait for shutdown.
 	 */
 	void waitingForShutdown(int delay);
 

http://git-wip-us.apache.org/repos/asf/karaf/blob/8a1e7574/main/src/main/java/org/apache/karaf/main/Status.java
----------------------------------------------------------------------
diff --git a/main/src/main/java/org/apache/karaf/main/Status.java b/main/src/main/java/org/apache/karaf/main/Status.java
index 52f6935..4ac8b1a 100644
--- a/main/src/main/java/org/apache/karaf/main/Status.java
+++ b/main/src/main/java/org/apache/karaf/main/Status.java
@@ -31,8 +31,8 @@ public class Status {
      * Checks if the shutdown port is bound. The shutdown port can be configured in config.properties
      * or in the shutdown port file.
      *
-     * @param args
-     * @throws Exception
+     * @param args The arguments to the status main method.
+     * @throws Exception If an error occurs while checking the status.
      */
     public static void main(String[] args) throws Exception {
         ConfigProperties config = new ConfigProperties();

http://git-wip-us.apache.org/repos/asf/karaf/blob/8a1e7574/main/src/main/java/org/apache/karaf/main/Stop.java
----------------------------------------------------------------------
diff --git a/main/src/main/java/org/apache/karaf/main/Stop.java b/main/src/main/java/org/apache/karaf/main/Stop.java
index 3d7d27d..d6af16d 100644
--- a/main/src/main/java/org/apache/karaf/main/Stop.java
+++ b/main/src/main/java/org/apache/karaf/main/Stop.java
@@ -32,11 +32,11 @@ import java.net.Socket;
 public class Stop {
 
     /**
-     * Sends the shutdown command to the running karaf instance. Uses either a shut down port configured in config.properties or
+     * Send the shutdown command to the running Karaf instance. Uses either a shut down port configured in config.properties or
      * the port from the shutdown port file.
      *
-     * @param args
-     * @throws Exception
+     * @param args The arguments to the stop main method.
+     * @throws Exception In case of failure while stopping.
      */
     public static void main(String[] args) throws Exception {
         ConfigProperties config = new ConfigProperties();

http://git-wip-us.apache.org/repos/asf/karaf/blob/8a1e7574/main/src/main/java/org/apache/karaf/main/lock/GenericJDBCLock.java
----------------------------------------------------------------------
diff --git a/main/src/main/java/org/apache/karaf/main/lock/GenericJDBCLock.java b/main/src/main/java/org/apache/karaf/main/lock/GenericJDBCLock.java
index 195e914..fe49e92 100644
--- a/main/src/main/java/org/apache/karaf/main/lock/GenericJDBCLock.java
+++ b/main/src/main/java/org/apache/karaf/main/lock/GenericJDBCLock.java
@@ -32,65 +32,65 @@ import org.apache.karaf.main.ConfigProperties;
 import org.apache.karaf.main.util.BootstrapLogManager;
 
 /**
- * This classs is the base class used to provide a master/slave configuration for
+ * <p>This class is the base class used to provide a master/slave configuration for
  * a given set of active karaf instances using JDBC. </p>
  *
- * This implementation uses two different tables.  A KARAF_NODE_ID, and KARAF_LOCK tables.  The
+ * <p>This implementation uses two different tables.  A KARAF_NODE_ID, and KARAF_LOCK tables.  The
  * KARAF_NODE_ID table is used to generate a unique id for each instance in the cluster.  While
  * the KARAF_LOCK table is used to determine who is the master of these instances. </p>
  *
- * The tables configurations for the different tables are. </p>
+ * <p>The tables configurations for the different tables are. </p>
  *
  * <pre>
  *   CREATE TABLE KARAF_NODE_ID ( ID INTEGER DEFAULT 0 )
  *   CREATE TABLE KARAF_LOCK ( ID INTEGER DEFAULT 0, STATE INTEGER DEFAULT 0, LOCK_DELAY INTEGER DEFAULT 0 )
  * </pre>
  *
- * The two tables will include a single row each that is created by a single instance in the cluster. </p>
+ * <p>The two tables will include a single row each that is created by a single instance in the cluster. </p>
  *
- * The KARAF_NODE_ID table will be updated once for each active karaf instance with there unique id compared
+ * <p>The KARAF_NODE_ID table will be updated once for each active karaf instance with there unique id compared
  * to the other instances within the cluster.  The single row will contain the next available unique id and
  * will not include each clustered instance unique id since these instances can come and go throughout the
  * system lifetime. </p>
  *
- * The KARAF_LOCK table will be used to determine which of the instances will become the master. The master
+ * <p>The KARAF_LOCK table will be used to determine which of the instances will become the master. The master
  * will set the STATE to an initial value and the LOCK_DELAY to a time in milliseconds of when the
  * table will be updated.  It is the responsibility of the master instance to update the STATE field by the
  * allocated lock delay by incrementing the state value.  If the STATE value has not been updated by the 
  * LOCK_DELAY time then a slave has permission to attempt to become the master. </p>
  *
- * While the overview does not describe exactly how this is implemented.  Here is a description of how this
+ * <p>While the overview does not describe exactly how this is implemented.  Here is a description of how this
  * is done and what is provides as a fail safe solution. </p>
  *
- * Each instance of this class provides an initialization step, a lock, isAlive and release interface. </p>
+ * <p>Each instance of this class provides an initialization step, a lock, isAlive and release interface. </p>
  *
- * INITIALIZE:</p>
+ * <p>INITIALIZE:</p>
  *
- * During the initialization step it will determine if the given tables exist within the database.  We only 
+ * <p>During the initialization step it will determine if the given tables exist within the database.  We only
  * check for a single table since we assume that if one is available then the other must exist. We then
  * add a row to each of the tables.  The added row to the KARAF_NODE_ID table will set the ID to zero since 
  * this is consider a non-existent karaf instance.  The added row to the KARAF_LOCK will set the ID to zero
  * which allows a karaf instances to acquire the lock and become the master instance. </p>
  *
  *
- * LOCK:</p>
+ * <p>LOCK:</p>
  *
- * The current instance will try to acquire the master lock by using the following sql statement. </p>
+ * <p>The current instance will try to acquire the master lock by using the following sql statement. </p>
  *
  * <pre>
  *   UPDATE KARAF_LOCK SET ID = unique_id, STATE = state, LOCK_DELAY = lock_delay 
  *       WHERE ID = 0 OR ID = curId
  * </pre>
  *
- * Now you must be asking why are we using this update statement? The reason is that the statement will
+ * <p>Now you must be asking why are we using this update statement? The reason is that the statement will
  * guarantee that only one instance will be able to update this row.  The curId is set to this instance
  * unique id or to the prior master unique id if the row was not updated within that master lock_delay. </p>
  *
- * The current update command will set the curId to this instance unique id.  If this fails then it will
+ * <p>The current update command will set the curId to this instance unique id.  If this fails then it will
  * determine if the current master has not updated the row within its lock_delay.  If it hasn't updated
  * the row within the allocated time then this instance can try to become the master. </p>
  *
- * The current slave instance will then try to steal the lock from the master instance.  Why are we trying
+ * <p>The current slave instance will then try to steal the lock from the master instance.  Why are we trying
  * to steal the lock from the master?  The reason is that it is possible that the master instance had a 
  * hard failure and there is no mechanisms to determine if that is the case. We then assume that it has 
  * crashed without releasing the lock gracefully.  The slave instance then used the following update statement. </p>
@@ -100,31 +100,28 @@ import org.apache.karaf.main.util.BootstrapLogManager;
  *       WHERE ( ID = 0 OR ID = curId ) AND STATE = curState
  * </pre>
  *
- * Now why are we using the state value as part of the where clause?  The reason that even though the row was 
+ * <p>Now why are we using the state value as part of the where clause?  The reason that even though the row was
  * not updated by the allocated delay time.  It is possible that the update statement was performed just after 
  * the current slave check.  This update will insure that the row will be updated if and only if the state was
  * also not updated.  It is possible that the master instance updated the row after the current slave check 
  * and we do not want the slave to update the row and make itself the master.  This will insure that that will
  * not be the case. </p>
  *
- * ISALIVE: </p>
+ * <p>ISALIVE: </p>
  *
- * This just checks if the connection is active and then just updates the row's STATE by using the lock
+ * <p>This just checks if the connection is active and then just updates the row's STATE by using the lock
  * update call mentioned above. </p>
  *
- * RELEASE: </p>
+ * <p>RELEASE: </p>
  *
- * The release process just updates the KARAF_LOCK ID to zero so that other instances will have a chance
+ * <p>The release process just updates the KARAF_LOCK ID to zero so that other instances will have a chance
  * to become the master. </p>
  *
- * There are two main scenarios that we need to worry about.  Soft and Hard failures.  The soft failure 
+ * <p>There are two main scenarios that we need to worry about.  Soft and Hard failures.  The soft failure
  * basically allows the master instance to release the master lock and allow other instances to become
  * the master.  As for a hard failure, the current karaf instance crashes and does not release the lock
  * then the other karaf instances will notice that the KARAF_LOCK has not been updated for the current
  * master id and then they can compete for the master lock. </p>
- *
- * @author Claudio Corsi
- *
  */
 public class GenericJDBCLock implements Lock {
 
@@ -188,7 +185,7 @@ public class GenericJDBCLock implements Lock {
     /**
      * This method is called to create an instance of the JDBCStatements instance.
      *
-     * @return an instance of a JDBCStatement object
+     * @return An instance of a JDBCStatement object.
      */
     GenericStatements createStatements() {
         GenericStatements statements = new GenericStatements(table, table_id, clusterName);
@@ -255,7 +252,7 @@ public class GenericJDBCLock implements Lock {
     /**
      * This method is called to determine if the required database schemas have already been created or not.
      *
-     * @return true, if the schemas are available else false.
+     * @return True, if the schemas are available else false.
      */
     boolean schemaExists() {
         return schemaExist(this.statements.getLockTableName())
@@ -265,9 +262,8 @@ public class GenericJDBCLock implements Lock {
     /**
      * This method is called to determine if the required table is available or not.
      *
-     * @param tableName  The name of the table to determine if it exists
-     *
-     * @return true, if the table exists else false
+     * @param tableName The name of the table to determine if it exists.
+     * @return True, if the table exists else false.
      */
     private boolean schemaExist(String tableName) {
         ResultSet rs = null;
@@ -342,12 +338,11 @@ public class GenericJDBCLock implements Lock {
     }
     
     /**
-     * This method is called to determine if this instance jdbc connection is
+     * This method is called to determine if this instance JDBC connection is
      * still connected.
      *
-     * @return true, if the connection is still connected else false
-     *
-     * @throws SQLException
+     * @return True, if the connection is still connected else false.
+     * @throws SQLException If an SQL error occurs while checking if the lock is connected to the database.
      */
     boolean isConnected() throws SQLException {
         return lockConnection != null && !lockConnection.isClosed();
@@ -356,7 +351,7 @@ public class GenericJDBCLock implements Lock {
     /**
      * This method is called to safely close a Statement.
      *
-     * @param preparedStatement The statement to be closed
+     * @param preparedStatement The statement to be closed.
      */
     void closeSafely(Statement preparedStatement) {
         if (preparedStatement != null) {
@@ -371,7 +366,7 @@ public class GenericJDBCLock implements Lock {
     /**
      * This method is called to safely close a ResultSet instance.
      *
-     * @param rs The result set to be closed
+     * @param rs The result set to be closed.
      */
     void closeSafely(ResultSet rs) {
         if (rs != null) {
@@ -386,9 +381,8 @@ public class GenericJDBCLock implements Lock {
     /**
      * This method will return an active connection for this given jdbc driver.
      *
-     * @return jdbc Connection instance
-     *
-     * @throws Exception
+     * @return The JDBC connection instance
+     * @throws Exception If the JDBC connection can't be retrieved.
      */
     protected Connection getConnection() throws Exception {
         if (!isConnected()) {
@@ -399,14 +393,14 @@ public class GenericJDBCLock implements Lock {
     }
 
     /**
-     * Create a new jdbc connection.
+     * Create a new JDBC connection.
      *
-     * @param driver The fully qualified driver class name
-     * @param url  The database connection url
-     * @param username The username for the database
-     * @param password  The password for the data
-     * @return a new jdbc connection
-     * @throws Exception
+     * @param driver The fully qualified driver class name.
+     * @param url The database connection URL.
+     * @param username The username for the database.
+     * @param password  The password for the database.
+     * @return a new JDBC connection.
+     * @throws Exception If the JDBC connection can't be created.
      */
     protected Connection createConnection(String driver, String url, String username, String password) throws Exception {
         if (url.toLowerCase().startsWith("jdbc:derby")) {
@@ -422,15 +416,15 @@ public class GenericJDBCLock implements Lock {
     }
 
     /**
-     * This method could be used to inject a mock jdbc connection for testing purposes.
+     * This method could be used to inject a mock JDBC connection for testing purposes.
      *
-     * @param driver
-     * @param url
-     * @param username
-     * @param password
-     * @return
-     * @throws ClassNotFoundException
-     * @throws SQLException
+     * @param driver The fully qualified driver class name.
+     * @param url The database connection URL.
+     * @param username The username for the database.
+     * @param password The password for the database.
+     * @return a new JDBC connection.
+     * @throws ClassNotFoundException If the JDBC driver class is not found.
+     * @throws SQLException If the JDBC connection can't be created.
      */
     protected Connection doCreateConnection(String driver, String url, String username, String password) throws ClassNotFoundException, SQLException {
         Class.forName(driver);
@@ -442,7 +436,7 @@ public class GenericJDBCLock implements Lock {
      * The different option depend if we are the competing for the master or the lock delay time
      * has been exceeded or that we are the master and are update the state.
      *
-     * @return true, if we are the master instance else false
+     * @return True, if we are the master instance else false.
      *
      * @see org.apache.karaf.main.lock.Lock#lock()
      */
@@ -509,9 +503,8 @@ public class GenericJDBCLock implements Lock {
      * is already the master instance.  It will try to update the row given the passed data and will
      * succeed if and only if the generated where clause was valid else it would not update the row.
      *
-     * @param lockUpdateIdStatement The sql statement used to execute the update
-     *
-     * @return true, if the row was updated else false
+     * @param lockUpdateIdStatement The sql statement used to execute the update.
+     * @return True, if the row was updated else false.
      */
     private boolean acquireLock(String lockUpdateIdStatement) {
         PreparedStatement preparedStatement = null;
@@ -566,7 +559,7 @@ public class GenericJDBCLock implements Lock {
      * This method will check if the jdbc connection is still active and if we were able to 
      * acquire or update the karaf_table information.
      *
-     * @return true, if the connection is still active and we still have the lock
+     * @return True, if the connection is still active and we still have the lock.
      *
      * @see org.apache.karaf.main.lock.Lock#isAlive()
      *

http://git-wip-us.apache.org/repos/asf/karaf/blob/8a1e7574/main/src/main/java/org/apache/karaf/main/lock/GenericStatements.java
----------------------------------------------------------------------
diff --git a/main/src/main/java/org/apache/karaf/main/lock/GenericStatements.java b/main/src/main/java/org/apache/karaf/main/lock/GenericStatements.java
index e4f1163..88810e9 100644
--- a/main/src/main/java/org/apache/karaf/main/lock/GenericStatements.java
+++ b/main/src/main/java/org/apache/karaf/main/lock/GenericStatements.java
@@ -20,16 +20,16 @@ import java.sql.ResultSet;
 import java.sql.SQLException;
 
 /**
- * This class is used to create the sql statements for the karaf lock tables that are used
- * for clustering of karaf instances.
- * 
- * It will generate sql statement to create two separate tables, a lock table and a lock id table
+ * <p>This class is used to create the sql statements for the Karaf lock tables that are used
+ * for clustering of Karaf instances.</p>
  * 
+ * <p>It will generate sql statement to create two separate tables, a lock table and a lock id table:</p>
+ *
+ * <code>
  *   CREATE TABLE LOCK ( ID INTEGER DEFAULT 0, STATE INTEGER DEFAULT 0, LOCK_DELAY INTEGER DEFAULT 0 )
  *   
  *   CREATE TABLE LOCK_ID ( ID INTEGER DEFAULT 0 )
- *   
- * @author Claudio Corsi
+ * </code>
  * 
  */
 public class GenericStatements {
@@ -39,12 +39,12 @@ public class GenericStatements {
 	private final String clusterName;
 
 	/**
-	 * This constructor is used to determine the name of the karaf lock table, the karaf lock id
+	 * This constructor is used to determine the name of the Karaf lock table, the Karaf lock id
 	 * table and the name of the clustered instances.
 	 *
-	 * @param lockTableName The name of the karaf lock table
-	 * @param lockIdTableName The name of the karaf lock id table
-	 * @param clusterName the name of the cluster being used
+	 * @param lockTableName The name of the karaf lock table.
+	 * @param lockIdTableName The name of the karaf lock id table.
+	 * @param clusterName the name of the cluster being used.
 	 */
 	public GenericStatements(String lockTableName, String lockIdTableName, String clusterName) {
 		this.lockTableName   = lockTableName;
@@ -56,16 +56,16 @@ public class GenericStatements {
 	 * This method will return the name of the cluster that the instances are using to compete for the
 	 * master lock.
 	 *
-	 * @return cluster node name
+	 * @return The cluster node name.
 	 */
 	public final String getNodeName() {
 		return this.clusterName;
 	}
 
 	/**
-	 * This method will return the name of the karaf lock table.
+	 * This method will return the name of the Karaf lock table.
 	 *
-	 * @return name of the karaf lock table
+	 * @return The name of the Karaf lock table.
 	 */
 	public final String getLockTableName() {
 		return lockTableName;
@@ -75,22 +75,30 @@ public class GenericStatements {
 	 * This method will return the insert statement used to create a row in the Lock table and will
 	 * generate the following sql statement.
 	 *
+	 * <code>
 	 * INSERT INTO KARAF_LOCK (ID, STATE, LOCK_DELAY) VALUES (0, 0, 0)
+	 * </code>
 	 * 
-	 * @return sql insert statement
+	 * @return The SQL insert statement.
 	 */
 	private String getLockTableInitialInsertStatement() {
 		return "INSERT INTO " + this.getLockTableName() + "(ID, STATE, LOCK_DELAY) VALUES (0, 0, 0)";
 	}
 
 	/**
-	 * This will be called when trying to acquire the lock and will generate the following sql statemnt.
+	 * This will be called when trying to acquire the lock and will generate the following sql statement.
 	 *
+	 * <code>
 	 *  UPDATE KARAF_LOCK SET ID = ?, STATE = ?, LOCK_DELAY = ? WHERE ID = 0 OR ID = ?
+	 * </code>
 	 * 
 	 * You are then expected to assign the values associated with the sql statement.
 	 *
-	 * @return sql update statement
+	 * @param id The new ID.
+	 * @param state The new lock state.
+	 * @param lock_delay The new lock delay.
+	 * @param curId The current ID.
+	 * @return The SQL update statement.
 	 */
 	public String getLockUpdateIdStatement(int id, int state, int lock_delay, int curId) {
 		return String.format("UPDATE %s SET ID = %d, STATE = %d, LOCK_DELAY = %d WHERE ID = 0 OR ID = %d", 
@@ -98,14 +106,21 @@ public class GenericStatements {
 	}
 
 	/**
-	 * This will be called when trying to steal the lock and will generate the following sql statemnt.
+	 * This will be called when trying to steal the lock and will generate the following sql statement.
 	 *
+	 * <code>
 	 *  UPDATE KARAF_LOCK SET ID = ?, STATE = ?, LOCK_DELAY = ? WHERE ( ID = 0 OR ID = ? ) AND STATE = ?
+	 * </code>
 	 *
-	 * You are then responsible to assign the values of the different fields using standard jdbc statement
+	 * You are then responsible to assign the values of the different fields using standard JDBC statement
 	 * calls.
-	 * 
-	 * @return sql update statement
+	 *
+	 * @param id The new ID.
+	 * @param state The new lock state.
+	 * @param lock_delay The new lock delay.
+	 * @param curId The current ID.
+     * @param curState The current state.
+	 * @return The SQL update statement.
 	 */
 	public String getLockUpdateIdStatementToStealLock(int id, int state, int lock_delay, int curId, int curState) {
 		return String.format("UPDATE %s SET ID = %d, STATE = %d, LOCK_DELAY = %d WHERE ( ID = 0 OR ID = %d ) AND STATE = %d", 
@@ -117,7 +132,8 @@ public class GenericStatements {
 	 * statement.
 	 *
 	 *  UPDATE KARAF_LOCK SET ID = 0 WHERE ID = ?
-	 * 
+	 *
+	 * @param id The current ID.
 	 * @return sql update statement
 	 */
 	public String getLockResetIdStatement(int id) {
@@ -128,7 +144,9 @@ public class GenericStatements {
 	 * This will be called to determine the current master instance for the lock table and will 
 	 * generate the following sql statement.
 	 *
+	 * <code>
 	 * SELECT ID, STATE, LOCK_DELAY FROM KARAF_LOCK
+	 * </code>
 	 *
 	 * @return sql select statement
 	 */
@@ -152,25 +170,26 @@ public class GenericStatements {
 	 * This method should only be called during the creation of the KARAF_LOCK table and will
 	 * generate the following sql statement.
 	 *
+     * <code>
 	 * CREATE TABLE KARAF_LOCK (ID INTEGER DEFAULT 0, STATE INTEGER DEFAULT 0, LOCK_DELAY INTEGER DEFAULT 0)
-	 * 
-	 * @return sql create table statement
+	 * </code>
+     *
+	 * @return The SQL create table statement.
 	 */
 	private String getLockTableCreateStatement() {
 		return "CREATE TABLE " + this.getLockTableName() 
 			   + " ( ID INTEGER DEFAULT 0, STATE INTEGER DEFAULT 0 , LOCK_DELAY INTEGER DEFAULT 0 )";
 	}
 
-	
-	//  ==================  LOCK ID TABLE ========================
-
 	/**
 	 * This method will generate the create table sql statement to create the karaf id table and will
 	 * generate the following sql statement.
 	 *
+     * <code>
 	 * CREATE TABLE KARAF_ID ( ID INTEGER DEFAULT 0 )
+     * </code>
 	 *
-	 * @return sql create table statement
+	 * @return The SQL create table statement.
 	 */
 	private String getLockIdTableCreateStatement() {
 		return "CREATE TABLE " + this.getLockIdTableName() 
@@ -181,9 +200,11 @@ public class GenericStatements {
 	 * This method will return the sql statement to retreive the id of the lock id table and will
 	 * generate the following sql statement.
 	 *
+     * <code>
 	 * SELECT ID FROM KARAF_ID
+     * </code>
 	 *
-	 * @return sql select statement
+	 * @return The SQL select statement.
 	 */
 	public String getLockIdSelectStatement() {
 		return "SELECT ID FROM " + this.getLockIdTableName();
@@ -197,18 +218,22 @@ public class GenericStatements {
 	 * This method will return the update statement for the lock id table and will generate the
 	 * following sql statement.
 	 *
+     * <code>
 	 * UPDATE KARAF_ID SET ID = ? WHERE ID = ?
+     * </code>
 	 *
-	 * @return sql update statement
+     * @param id The new ID.
+     * @param curId The current ID.
+	 * @return The SQL update statement.
 	 */
 	public String getLockIdUpdateIdStatement(int id, int curId) {
 		return String.format("UPDATE %s SET ID = %d WHERE ID = %d", this.getLockIdTableName(), id, curId);
 	}
 	
 	/**
-	 * This method will return the name of the karaf lock id table.
+	 * This method will return the name of the Karaf lock id table.
 	 *
-	 * @return name of the karaf lock id table
+	 * @return The name of the Karaf lock id table.
 	 */
 	public final String getLockIdTableName() {
 		return lockIdTableName;
@@ -217,7 +242,8 @@ public class GenericStatements {
 	/**
 	 * This method will return the required sql statements to initialize the lock database.
 	 *
-	 * @return array of sql statements
+     * @param moment The moment.
+	 * @return The array of SQL statements.
 	 */
 	public String[] getLockCreateSchemaStatements(long moment) {
 		return new String[] {
@@ -232,9 +258,11 @@ public class GenericStatements {
 	 * This method will return the insert statement to insert a row in the lock id table and will
 	 * generate the following sql statement.
 	 *
+     * <code>
 	 * INSERT INTO KARAF_ID (ID) VALUES (0)
+     * </code>
 	 *
-	 * @return sql insert statement
+	 * @return The SQL insert statement.
 	 */
 	private String getLockIdTableInitialInsertStatement() {
 		return "INSERT INTO " + this.getLockIdTableName() + "(ID) VALUES (0)";

http://git-wip-us.apache.org/repos/asf/karaf/blob/8a1e7574/main/src/main/java/org/apache/karaf/main/lock/Lock.java
----------------------------------------------------------------------
diff --git a/main/src/main/java/org/apache/karaf/main/lock/Lock.java b/main/src/main/java/org/apache/karaf/main/lock/Lock.java
index 869849b..9242fd0 100644
--- a/main/src/main/java/org/apache/karaf/main/lock/Lock.java
+++ b/main/src/main/java/org/apache/karaf/main/lock/Lock.java
@@ -24,23 +24,23 @@ public interface Lock {
      * A KeepAlive function to maintain the lock. 
      * Indicates whether or not the lock could be aquired.
      * 
-     * @return true if connection lock retained, false otherwise.
-     * @throws Exception
+     * @return True if connection lock retained, false otherwise.
+     * @throws Exception If the lock can't be acquired.
      */
     boolean lock() throws Exception;
 
     /**
      * Terminate the lock connection safely.
      * 
-     * @throws Exception
+     * @throws Exception If the lock can't be released.
      */
     void release() throws Exception;
 
     /**
-     * Indicates whether or not the lock still exists.
+     * Indicate whether or not the lock still exists.
      * 
-     * @return true, if the lock still exists, otherwise false.
-     * @throws Exception
+     * @return True, if the lock still exists, otherwise false.
+     * @throws Exception If an error occurs while checking if the lock is alive.
      */
     boolean isAlive() throws Exception;
 }

http://git-wip-us.apache.org/repos/asf/karaf/blob/8a1e7574/main/src/main/java/org/apache/karaf/main/util/SimpleMavenResolver.java
----------------------------------------------------------------------
diff --git a/main/src/main/java/org/apache/karaf/main/util/SimpleMavenResolver.java b/main/src/main/java/org/apache/karaf/main/util/SimpleMavenResolver.java
index 69d787a..a5e8550 100644
--- a/main/src/main/java/org/apache/karaf/main/util/SimpleMavenResolver.java
+++ b/main/src/main/java/org/apache/karaf/main/util/SimpleMavenResolver.java
@@ -42,7 +42,7 @@ public class SimpleMavenResolver implements ArtifactResolver {
     /**
      * Resolve from pax-url format for maven URIs to the file that is referenced by the URI
      * The URI format is:
-     * mvn:<groupId>/<artifactId>/<version>/<type>/<classifier>
+     * mvn:&lt;groupId&gt;/&lt;artifactId&gt;/&lt;version&gt;/&lt;type&gt;/&lt;classifier&gt;
      * 
      * If artifactUri does not match the Syntax the local file that corresponds to the path is returned
      * 

http://git-wip-us.apache.org/repos/asf/karaf/blob/8a1e7574/management/server/src/main/java/org/apache/karaf/management/ConnectorServerFactory.java
----------------------------------------------------------------------
diff --git a/management/server/src/main/java/org/apache/karaf/management/ConnectorServerFactory.java b/management/server/src/main/java/org/apache/karaf/management/ConnectorServerFactory.java
index 0e746b5..d0a20f0 100644
--- a/management/server/src/main/java/org/apache/karaf/management/ConnectorServerFactory.java
+++ b/management/server/src/main/java/org/apache/karaf/management/ConnectorServerFactory.java
@@ -137,7 +137,7 @@ public class ConnectorServerFactory {
     /**
      * Authenticator type to use. Acceptable values are "none", "password", and "certificate"
      *
-     * @param value
+     * @param value The authenticator type: "none", "password", "certificate".
      */
     public void setAuthenticatorType(String value) {
         this.authenticatorType = AuthenticatorType.valueOf(value.toUpperCase());
@@ -146,7 +146,7 @@ public class ConnectorServerFactory {
     /**
      * Use this param to allow KeyStoreManager to wait for expected keystores to be loaded by other bundle
      *
-     * @param keyStoreAvailabilityTimeout
+     * @param keyStoreAvailabilityTimeout The keystore timeout.
      */
     public void setKeyStoreAvailabilityTimeout(long keyStoreAvailabilityTimeout) {
         this.keyStoreAvailabilityTimeout = keyStoreAvailabilityTimeout;

http://git-wip-us.apache.org/repos/asf/karaf/blob/8a1e7574/management/server/src/main/java/org/apache/karaf/management/JMXSecurityMBean.java
----------------------------------------------------------------------
diff --git a/management/server/src/main/java/org/apache/karaf/management/JMXSecurityMBean.java b/management/server/src/main/java/org/apache/karaf/management/JMXSecurityMBean.java
index 927dcca..93dc784 100644
--- a/management/server/src/main/java/org/apache/karaf/management/JMXSecurityMBean.java
+++ b/management/server/src/main/java/org/apache/karaf/management/JMXSecurityMBean.java
@@ -21,10 +21,10 @@ import java.util.List;
 import java.util.Map;
 
 /**
- * Security MBean. This MBean can be used to find out whether the currently logged user can access certain MBeans
+ * <p>Security MBean. This MBean can be used to find out whether the currently logged user can access certain MBeans
  * or invoke operations on these MBeans. It can be used when building client-facing consoles to ensure that only
- * operations appropriate for the current user are presented.<p/>
- * This MBean does not actually invoke any operations on the given objects, it only checks permissions.
+ * operations appropriate for the current user are presented.</p>
+ * <p>This MBean does not actually invoke any operations on the given objects, it only checks permissions.</p>
  */
 public interface JMXSecurityMBean {
 
@@ -55,32 +55,32 @@ public interface JMXSecurityMBean {
     /**
      * Checks whether the current user can invoke any methods on a JMX MBean.
      *
-     * @param objectName the Object Name of the JMX MBean.
-     * @return {@code true} if there is at least one method on the MBean that the user can invoke, {@code false} else.
-     * @throws Exception
+     * @param objectName The Object Name of the JMX MBean.
+     * @return {@code True} if there is at least one method on the MBean that the user can invoke, {@code false} else.
+     * @throws Exception If the invocation check fails.
      */
     boolean canInvoke(String objectName) throws Exception;
 
     /**
      * Checks whether the current user can invoke overload of the given method.
      *
-     * @param objectName the Object Name of the JMX MBean.
-     * @param methodName the name of the method to check.
-     * @return {@code true} if there is an overload of the specified method that the user can invoke, {@code false} else.
-     * @throws Exception
+     * @param objectName The Object Name of the JMX MBean.
+     * @param methodName The name of the method to check.
+     * @return {@code True} if there is an overload of the specified method that the user can invoke, {@code false} else.
+     * @throws Exception If the invocation check fails.
      */
     boolean canInvoke(String objectName, String methodName) throws Exception;
 
     /**
      * Checks whether the current user can invoke the given method.
      *
-     * @param objectName the Object Name of the JMX MBean.
-     * @param methodName the name of the method to check.
-     * @param argumentTypes the argument types of the method.
-     * @return {@code true} if the user is allowed to invoke the method, or any of the methods with the given name if
+     * @param objectName The Object Name of the JMX MBean.
+     * @param methodName The name of the method to check.
+     * @param argumentTypes The argument types of the method.
+     * @return {@code True} if the user is allowed to invoke the method, or any of the methods with the given name if
      * {@code null} is used for the arguments. There may still be certain values that the user does not have permissions
      * to pass to the method.
-     * @throws Exception
+     * @throws Exception If the invocation check fails.
      */
     boolean canInvoke(String objectName, String methodName, String[] argumentTypes) throws Exception;
 
@@ -88,10 +88,10 @@ public interface JMXSecurityMBean {
      * Bulk operation to check whether the current user can access the requested MBeans or invoke the requested
      * methods.
      *
-     * @param bulkQuery a map of Object Name to requested operations. Operations can be specified with or without
+     * @param bulkQuery <p>a map of Object Name to requested operations. Operations can be specified with or without
      *                  argument types. An operation without arguments matches any overloaded method with this
      *                  name. If an empty list is provided for the operation names, a check is done whether the
-     *                  current user can invoke <em>any</em> operation on the MBean.<p/>
+     *                  current user can invoke <em>any</em> operation on the MBean.</p>
      *                  Example:
      *                  <pre>{@code
      *                  Map<String, List<String>> query = new HashMap<>();
@@ -104,7 +104,7 @@ public interface JMXSecurityMBean {
      *                  TabularData result = mb.canInvoke(query);
      *                  }</pre>
      * @return A Tabular Data object with the result. This object conforms the structure as defined in {@link #CAN_INVOKE_TABULAR_TYPE}
-     * @throws Exception
+     * @throws Exception If the invocation check fails.
      */
     TabularData canInvoke(Map<String, List<String>> bulkQuery) throws Exception;
 

http://git-wip-us.apache.org/repos/asf/karaf/blob/8a1e7574/management/server/src/main/java/org/apache/karaf/management/KarafMBeanServerGuard.java
----------------------------------------------------------------------
diff --git a/management/server/src/main/java/org/apache/karaf/management/KarafMBeanServerGuard.java b/management/server/src/main/java/org/apache/karaf/management/KarafMBeanServerGuard.java
index 4259326..831ab47 100644
--- a/management/server/src/main/java/org/apache/karaf/management/KarafMBeanServerGuard.java
+++ b/management/server/src/main/java/org/apache/karaf/management/KarafMBeanServerGuard.java
@@ -38,6 +38,7 @@ import java.util.regex.Pattern;
 
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
+
 public class KarafMBeanServerGuard implements InvocationHandler {
 
     private static final Logger LOG = LoggerFactory.getLogger(KarafMBeanServerGuard.class);    
@@ -46,7 +47,6 @@ public class KarafMBeanServerGuard implements InvocationHandler {
     
     private static final String JMX_ACL_WHITELIST = "jmx.acl.whitelist";
 
-
     private static final String JMX_OBJECTNAME_PROPERTY_WILDCARD = "_";
 
     private static final Comparator<String[]> WILDCARD_PID_COMPARATOR = new WildcardPidComparator();
@@ -85,27 +85,27 @@ public class KarafMBeanServerGuard implements InvocationHandler {
     }
 
     /**
-     * Returns whether there is any method that the current user can invoke.
+     * Return whether there is any method that the current user can invoke.
      *
-     * @param mbeanServer the MBeanServer where the object is registered.
-     * @param objectName the ObjectName to check.
-     * @return {@code true} if there is a method on the object that can be invoked, {@code false} else.
-     * @throws JMException
-     * @throws IOException
+     * @param mbeanServer The MBeanServer where the object is registered.
+     * @param objectName The ObjectName to check.
+     * @return {@code True} if there is a method on the object that can be invoked, {@code false} else.
+     * @throws JMException If the invocation fails.
+     * @throws IOException If the invocation fails.
      */
     public boolean canInvoke(MBeanServer mbeanServer, ObjectName objectName) throws JMException, IOException {
         return canInvoke(null, mbeanServer, objectName);
     }
 
     /**
-     * Returns whether there is any method that the current user can invoke.
+     * Return whether there is any method that the current user can invoke.
      *
-     * @param context {@link BulkRequestContext} for optimized ConfigAdmin access, may be <code>null</code>
-     * @param mbeanServer the MBeanServer where the object is registered.
-     * @param objectName the ObjectName to check.
-     * @return {@code true} if there is a method on the object that can be invoked, {@code false} else.
-     * @throws JMException
-     * @throws IOException
+     * @param context {@link BulkRequestContext} for optimized ConfigAdmin access, may be <code>null</code>.
+     * @param mbeanServer The MBeanServer where the object is registered.
+     * @param objectName The ObjectName to check.
+     * @return {@code True} if there is a method on the object that can be invoked, {@code false} else.
+     * @throws JMException If the invocation fails.
+     * @throws IOException If the invocation fails.
      */
     public boolean canInvoke(BulkRequestContext context, MBeanServer mbeanServer, ObjectName objectName) throws JMException, IOException {
         MBeanInfo info = mbeanServer.getMBeanInfo(objectName);
@@ -135,29 +135,29 @@ public class KarafMBeanServerGuard implements InvocationHandler {
     }
 
     /**
-     * Returns whether there is any overload of the specified method that can be invoked by the current user.
+     * Return whether there is any overload of the specified method that can be invoked by the current user.
      *
-     * @param mbeanServer the MBeanServer where the object is registered.
-     * @param objectName the MBean ObjectName.
-     * @param methodName the name of the method.
-     * @return {@code true} if there is an overload of the method that can be invoked by the current user.
-     * @throws JMException
-     * @throws IOException
+     * @param mbeanServer The MBeanServer where the object is registered.
+     * @param objectName The MBean ObjectName.
+     * @param methodName The name of the method.
+     * @return {@code True} if there is an overload of the method that can be invoked by the current user.
+     * @throws JMException If the invocation fails.
+     * @throws IOException If the invocation fails.
      */
     public boolean canInvoke(MBeanServer mbeanServer, ObjectName objectName, String methodName) throws JMException, IOException {
         return canInvoke(null, mbeanServer, objectName, methodName);
     }
 
     /**
-     * Returns whether there is any overload of the specified method that can be invoked by the current user.
+     * Return whether there is any overload of the specified method that can be invoked by the current user.
      *
-     * @param context {@link BulkRequestContext} for optimized ConfigAdmin access, may be <code>null</code>
-     * @param mbeanServer the MBeanServer where the object is registered.
-     * @param objectName the MBean ObjectName.
-     * @param methodName the name of the method.
-     * @return {@code true} if there is an overload of the method that can be invoked by the current user.
-     * @throws JMException
-     * @throws IOException
+     * @param context {@link BulkRequestContext} for optimized ConfigAdmin access, may be <code>null</code>.
+     * @param mbeanServer The MBeanServer where the object is registered.
+     * @param objectName The MBean ObjectName.
+     * @param methodName The name of the method.
+     * @return {@code True} if there is an overload of the method that can be invoked by the current user.
+     * @throws JMException If the invocation fails.
+     * @throws IOException If the invocation fails.
      */
     public boolean canInvoke(BulkRequestContext context, MBeanServer mbeanServer, ObjectName objectName, String methodName) throws JMException, IOException {
         methodName = methodName.trim();
@@ -191,35 +191,35 @@ public class KarafMBeanServerGuard implements InvocationHandler {
     }
 
     /**
-     * Returns true if the method on the MBean with the specified signature can be invoked.
+     * Return true if the method on the MBean with the specified signature can be invoked.
      *
-     * @param mbeanServer the MBeanServer where the object is registered.
-     * @param objectName the MBean ObjectName.
-     * @param methodName the name of the method.
-     * @param signature the signature of the method.
-     * @return {@code true} if the method can be invoked, {@code false} else. Note that if a method name or signature
+     * @param mbeanServer The MBeanServer where the object is registered.
+     * @param objectName The MBean ObjectName.
+     * @param methodName The name of the method.
+     * @param signature The signature of the method.
+     * @return {@code True} if the method can be invoked, {@code false} else. Note that if a method name or signature
      *      is provided that does not exist on the MBean, the behaviour of this method is undefined. In other words,
      *      if you ask whether a method that does not exist can be invoked, the method may return {@code true} but
      *      actually invoking that method will obviously not work.
-     * @throws IOException
+     * @throws IOException If the invocation fails.
      */
     public boolean canInvoke(MBeanServer mbeanServer, ObjectName objectName, String methodName, String[] signature) throws IOException {
         return canInvoke(null, mbeanServer, objectName, methodName, signature);
     }
 
     /**
-     * Returns true if the method on the MBean with the specified signature can be invoked.
+     * Return true if the method on the MBean with the specified signature can be invoked.
      *
-     * @param context {@link BulkRequestContext} for optimized ConfigAdmin access, may be <code>null</code>
-     * @param mbeanServer the MBeanServer where the object is registered.
-     * @param objectName the MBean ObjectName.
-     * @param methodName the name of the method.
-     * @param signature the signature of the method.
-     * @return {@code true} if the method can be invoked, {@code false} else. Note that if a method name or signature
+     * @param context {@link BulkRequestContext} for optimized ConfigAdmin access, may be <code>null</code>.
+     * @param mbeanServer The MBeanServer where the object is registered.
+     * @param objectName The MBean ObjectName.
+     * @param methodName The name of the method.
+     * @param signature The signature of the method.
+     * @return {@code True} if the method can be invoked, {@code false} else. Note that if a method name or signature
      *      is provided that does not exist on the MBean, the behaviour of this method is undefined. In other words,
      *      if you ask whether a method that does not exist can be invoked, the method may return {@code true} but
      *      actually invoking that method will obviously not work.
-     * @throws IOException
+     * @throws IOException If the invocation fails.
      */
     public boolean canInvoke(BulkRequestContext context, MBeanServer mbeanServer, ObjectName objectName, String methodName, String[] signature) throws IOException {
         // no checking done on the MBeanServer of whether the method actually exists...
@@ -451,7 +451,7 @@ public class KarafMBeanServerGuard implements InvocationHandler {
 
     /**
      * <code>nulls</code>-last comparator of PIDs split to segments. {@link #JMX_OBJECTNAME_PROPERTY_WILDCARD}
-     * in a segment makes the PID more generic, thus - with lower prioroty.
+     * in a segment makes the PID more generic, thus - with lower priority.
      */
     private static class WildcardPidComparator implements Comparator<String[]> {
         @Override

http://git-wip-us.apache.org/repos/asf/karaf/blob/8a1e7574/management/server/src/main/java/org/apache/karaf/management/internal/BulkRequestContext.java
----------------------------------------------------------------------
diff --git a/management/server/src/main/java/org/apache/karaf/management/internal/BulkRequestContext.java b/management/server/src/main/java/org/apache/karaf/management/internal/BulkRequestContext.java
index 1b9145b..d4e91ea 100644
--- a/management/server/src/main/java/org/apache/karaf/management/internal/BulkRequestContext.java
+++ b/management/server/src/main/java/org/apache/karaf/management/internal/BulkRequestContext.java
@@ -93,26 +93,30 @@ public class BulkRequestContext {
     }
 
     /**
-     * Returns list of PIDs related to RBAC/ACL
-     * @return
+     * Return list of PIDs related to RBAC/ACL.
+     *
+     * @return The list of PIDs.
      */
     public List<String> getAllPids() {
         return allPids;
     }
 
     /**
-     * Returns list of configurations from
-     * @return
+     * Return list of configurations from the whitelist.
+     *
+     * @return The list of configurations.
      */
     public List<Dictionary<String,Object>> getWhitelistProperties() {
         return whiteListProperties;
     }
 
     /**
-     * Returns {@link Configuration ConfigAdmin configuration} - may be cached in this instance of
+     * Return {@link Configuration ConfigAdmin configuration} - may be cached in this instance of
      * {@link BulkRequestContext context}
-     * @param generalPid
-     * @return
+     *
+     * @param generalPid The configuration PID.
+     * @return The configuration.
+     * @throws IOException If an error ocurrs while retrieving the configuration.
      */
     public Dictionary<String, Object> getConfiguration(String generalPid) throws IOException {
         if (!cachedConfigurations.containsKey(generalPid)) {

http://git-wip-us.apache.org/repos/asf/karaf/blob/8a1e7574/package/src/main/java/org/apache/karaf/packages/core/PackageService.java
----------------------------------------------------------------------
diff --git a/package/src/main/java/org/apache/karaf/packages/core/PackageService.java b/package/src/main/java/org/apache/karaf/packages/core/PackageService.java
index 0ea285b..0e68b43 100644
--- a/package/src/main/java/org/apache/karaf/packages/core/PackageService.java
+++ b/package/src/main/java/org/apache/karaf/packages/core/PackageService.java
@@ -22,29 +22,27 @@ import java.util.SortedMap;
 public interface PackageService {
 
 	/**
-	 * Gets the simplified package exports of a bundle. This does not show the 
+	 * Get the simplified package exports of a bundle. This does not show the
 	 * package versions.
 	 * 
-	 * @param bundleId
-	 * @return
+	 * @param bundleId The bundle ID.
+	 * @return The {@link List} of package exports in the given bundle.
 	 */
     List<String> getExports(long bundleId);
 
     List<String> getImports(long bundleId);
 
 	/**
-	 * Gets a map of all exported packages with their version and the bundles that export them
-	 * The key is in the form packagename:version.
+	 * Get all package exports with their version, and the bundles exporting them.
 	 * 
-	 * @return 
+	 * @return A {@link List} containing all package exports (as {@link PackageVersion}).
 	 */
     List<PackageVersion> getExports();
 
     /**
-     * Gets a map of all package imports. 
-     * The key is the import filter.
+	 * Get all package imports with their requirement.
      *  
-     * @return
+     * @return A {@link List} containing all package imports (as {@link PackageRequirement}).
      */
     List<PackageRequirement> getImports();
 

http://git-wip-us.apache.org/repos/asf/karaf/blob/8a1e7574/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 207f5fd..a5019c8 100644
--- a/pom.xml
+++ b/pom.xml
@@ -1779,7 +1779,7 @@
                 <plugin>
                     <groupId>org.apache.maven.plugins</groupId>
                     <artifactId>maven-javadoc-plugin</artifactId>
-                    <version>2.9.1</version>
+                    <version>2.10.3</version>
                 </plugin>
                 <plugin>
                     <groupId>org.apache.maven.plugins</groupId>
@@ -2101,7 +2101,7 @@
             <plugin>
                 <groupId>org.apache.maven.plugins</groupId>
                 <artifactId>maven-javadoc-plugin</artifactId>
-                <version>2.9.1</version>
+                <version>2.10.3</version>
             </plugin>
             <plugin>
                 <groupId>org.apache.maven.plugins</groupId>

http://git-wip-us.apache.org/repos/asf/karaf/blob/8a1e7574/profile/src/main/java/org/apache/karaf/profile/PlaceholderResolver.java
----------------------------------------------------------------------
diff --git a/profile/src/main/java/org/apache/karaf/profile/PlaceholderResolver.java b/profile/src/main/java/org/apache/karaf/profile/PlaceholderResolver.java
index 7dfeace..740178e 100644
--- a/profile/src/main/java/org/apache/karaf/profile/PlaceholderResolver.java
+++ b/profile/src/main/java/org/apache/karaf/profile/PlaceholderResolver.java
@@ -24,16 +24,19 @@ public interface PlaceholderResolver {
 
     /**
      * The placeholder scheme.
+     *
+     * @return The placeholder scheme.
      */
     public String getScheme();
 
     /**
-     * Resolves the placeholder found inside the value, for the specific key of the pid.
-     * @param profile   The current profile
-     * @param pid       The pid that contains the placeholder.
-     * @param key       The key of the configuration value that contains the placeholder.
-     * @param value     The value with the placeholder.
-     * @return          The resolved value or EMPTY_STRING.
+     * Resolve the placeholder found inside the value, for the specific key of the pid.
+     *
+     * @param profile The current profile.
+     * @param pid The pid that contains the placeholder.
+     * @param key The key of the configuration value that contains the placeholder.
+     * @param value The value with the placeholder.
+     * @return The resolved value or EMPTY_STRING.
      */
     public String resolve(Map<String, Map<String, String>> profile, String pid, String key, String value);
 

http://git-wip-us.apache.org/repos/asf/karaf/blob/8a1e7574/profile/src/main/java/org/apache/karaf/profile/Profile.java
----------------------------------------------------------------------
diff --git a/profile/src/main/java/org/apache/karaf/profile/Profile.java b/profile/src/main/java/org/apache/karaf/profile/Profile.java
index aedd5d8..30097b6 100644
--- a/profile/src/main/java/org/apache/karaf/profile/Profile.java
+++ b/profile/src/main/java/org/apache/karaf/profile/Profile.java
@@ -95,45 +95,62 @@ public interface Profile {
     String getId();
 
     /**
-     * Get the configuration file names that are available on this profile
+     * Get the configuration file names that are available on this profile.
+     *
+     * @return The configuration file names in the profile.
      */
     Set<String> getConfigurationFileNames();
 
     /**
-     * Get all file configurations
+     * Get all file configurations.
+     *
+     * @return The file configurations in the profile.
      */
     Map<String, byte[]> getFileConfigurations();
 
     /**
-     * Get the configuration file for the given name
+     * Get the configuration file for the given name.
+     *
+     * @param fileName The file configuration name to look for in the profile.
+     * @return The file configuration in the profile.
      */
     byte[] getFileConfiguration(String fileName);
 
     /**
-     * Get all configuration properties
+     * Get all configuration properties.
+     *
+     * @return The configurations in the profile.
      */
     Map<String, Map<String, String>> getConfigurations();
 
     /**
-     * Get the configuration properties for the given PID
-     * @return an empty map if the there is no configuration for the given pid
+     * Get the configuration properties for the given PID.
+     *
+     * @param pid The configuration PID to look for.
+     * @return An empty map if the there is no configuration for the given pid.
      */
     Map<String, String> getConfiguration(String pid);
 
     /**
      * Indicate if this profile is an overlay or not.
+     *
+     * @return True if the profile is an overlay, false else.
      */
     boolean isOverlay();
 
     /**
-     * Returns true if this profile is Abstract. 
-     * Abstract profiles should not be provisioned by default, they are intended to be inherited
+     * Return true if this profile is Abstract.
+     * Abstract profiles should not be provisioned by default, they are intended to be inherited.
+     *
+     * @return True if the profile is abstract, false else.
      */
     boolean isAbstract();
 
     /**
-     * Returns true if this profile is hidden.  
+     * Return true if this profile is hidden.
      * Hidden profiles are not listed by default.
+     *
+     * @return True if the profile is hidden, false else.
      */
     boolean isHidden();
 

http://git-wip-us.apache.org/repos/asf/karaf/blob/8a1e7574/profile/src/main/java/org/apache/karaf/profile/ProfileBuilder.java
----------------------------------------------------------------------
diff --git a/profile/src/main/java/org/apache/karaf/profile/ProfileBuilder.java b/profile/src/main/java/org/apache/karaf/profile/ProfileBuilder.java
index d14cc84..e00fedb 100644
--- a/profile/src/main/java/org/apache/karaf/profile/ProfileBuilder.java
+++ b/profile/src/main/java/org/apache/karaf/profile/ProfileBuilder.java
@@ -22,7 +22,6 @@ import java.util.Set;
 
 import org.apache.karaf.profile.impl.ProfileBuilderImpl;
 
-
 /**
  * A profile builder.
  */
@@ -49,11 +48,14 @@ public interface ProfileBuilder {
     Set<String> getConfigurationKeys();
 
     /**
-     * Returns a copy of the configuration with the specified pid
+     * Return a copy of the configuration with the specified pid
      * or an empty map if it does not exist yet.
      * The copy should be used for updates and then used with
      * {@link #addConfiguration(String, java.util.Map)} to keep
      * the layout and comments.
+     *
+     * @param pid The configuration PID.
+     * @return The copy of the configuration with the given PID.
      */
     Map<String, String> getConfiguration(String pid);
     

http://git-wip-us.apache.org/repos/asf/karaf/blob/8a1e7574/profile/src/main/java/org/apache/karaf/profile/ProfileService.java
----------------------------------------------------------------------
diff --git a/profile/src/main/java/org/apache/karaf/profile/ProfileService.java b/profile/src/main/java/org/apache/karaf/profile/ProfileService.java
index 237c1f6..f4aee40 100644
--- a/profile/src/main/java/org/apache/karaf/profile/ProfileService.java
+++ b/profile/src/main/java/org/apache/karaf/profile/ProfileService.java
@@ -23,75 +23,85 @@ import java.util.Collection;
  */
 public interface ProfileService {
 
-    //
-    // Lock management
-    //
 
     /**
      * Acquire a write lock for the profile.
+     *
+     * @return The write lock handler.
      */
     LockHandle acquireWriteLock();
 
     /**
      * Acquire a read lock for the profile.
      * A read lock cannot be upgraded to a write lock.
+     *
+     * @return The read lock handler.
      */
     LockHandle acquireReadLock();
 
-    //
-    // PlaceholderResolver management
-    //
-
     /**
      * Register the given resolver.
-     * @param resolver the resolver to register
+     *
+     * @param resolver The resolver to register.
      */
     void registerResolver(PlaceholderResolver resolver);
 
     /**
      * Unregister the given resolver.
-     * @param resolver the resolver to unregister
+     *
+     * @param resolver The resolver to unregister.
      */
     void unregisterResolver(PlaceholderResolver resolver);
 
-    //
-    // Profile management
-    //
-    
     /**
      * Create the given profile in the data store.
+     *
+     * @param profile The profile to create.
      */
     void createProfile(Profile profile);
     
     /**
      * Create the given profile in the data store.
+     *
+     * @param profile The profile to update.
      */
     void updateProfile(Profile profile);
 
     /**
      * True if the given profile exists in the given version.
+     *
+     * @param profileId The profile ID.
+     * @return True if the given profile exists, false else.
      */
     boolean hasProfile(String profileId);
 
     /**
      * Get the profile for the given version and id.
-     * @return The profile or null
+     *
+     * @param profileId The profile ID.
+     * @return The profile or null if not found.
      */
     Profile getProfile(String profileId);
 
     /**
      * Get the profile for the given version and id.
-     * @throws IllegalStateException if the required profile does not exist
+     *
+     * @param profileId The profile ID.
+     * @return The profile or null if not found.
      */
     Profile getRequiredProfile(String profileId);
 
     /** 
      * Get the list of profiles associated with the given version.
+     *
+     * @return The collection of all profiles.
      */
     Collection<String> getProfiles();
 
     /**
      * Delete the given profile from the data store.
+     *
+     * @param profileId The profile ID to remove.
      */
     void deleteProfile(String profileId);
 
@@ -100,6 +110,9 @@ public interface ProfileService {
      *
      * The overlay profile is computed by getting all the parent profiles
      * and overriding the settings by children profiles.
+     *
+     * @param profile The profile.
+     * @return The overlay profile.
      */
     Profile getOverlayProfile(Profile profile);
 
@@ -108,6 +121,10 @@ public interface ProfileService {
      *
      * The overlay profile is computed by getting all the parent profiles
      * and overriding the settings by children profiles.
+     *
+     * @param profile The profile.
+     * @param environment The environment.
+     * @return The overlay profile.
      */
     Profile getOverlayProfile(Profile profile, String environment);
 
@@ -116,6 +133,9 @@ public interface ProfileService {
      *
      * The effective profile is computed by performing all substitutions
      * in the given profile configurations.
+     *
+     * @param profile The profile to compute.
+     * @return The effective profile.
      */
     Profile getEffectiveProfile(Profile profile);
 
@@ -125,7 +145,9 @@ public interface ProfileService {
      * The effective profile is computed by performing all substitutions
      * in the given profile configurations.
      *
-     * @param defaultsToEmptyString if no substitution is valid, defaults to an empty string
+     * @param profile The profile to compute.
+     * @param defaultsToEmptyString if no substitution is valid, defaults to an empty string.
+     * @return The effective profile.
      */
     Profile getEffectiveProfile(Profile profile, boolean defaultsToEmptyString);
 

http://git-wip-us.apache.org/repos/asf/karaf/blob/8a1e7574/profile/src/main/java/org/apache/karaf/profile/impl/PlaceholderResolvers.java
----------------------------------------------------------------------
diff --git a/profile/src/main/java/org/apache/karaf/profile/impl/PlaceholderResolvers.java b/profile/src/main/java/org/apache/karaf/profile/impl/PlaceholderResolvers.java
index 16bf106..a15a830 100644
--- a/profile/src/main/java/org/apache/karaf/profile/impl/PlaceholderResolvers.java
+++ b/profile/src/main/java/org/apache/karaf/profile/impl/PlaceholderResolvers.java
@@ -71,8 +71,11 @@ public final class PlaceholderResolvers {
     }
 
     /**
-     * Substitutes a placeholder with profile:[property file]/[key], with the target value.
-     * @return  The target value or the key as is.
+     * Substitute a placeholder with profile:[property file]/[key], with the target value.
+     *
+     * @param key The key in the configuration.
+     * @param configs A {@link Map} of configurations where to perform the substitution.
+     * @return The target value or the key as is.
      */
     public static String substituteProfileProperty(String key, Map<String, Map<String, String>> configs) {
         String pid = key.substring("profile:".length(), key.indexOf("/"));
@@ -87,7 +90,10 @@ public final class PlaceholderResolvers {
 
     /**
      * Substitutes bundle property.
-     * @return  The target value or an empty String.
+     *
+     * @param key The key in the configuration.
+     * @param bundleContext The bundle context to use.
+     * @return The target value or an empty String.
      */
     public static String substituteBundleProperty(String key, BundleContext bundleContext) {
         String value = null;

http://git-wip-us.apache.org/repos/asf/karaf/blob/8a1e7574/scheduler/src/main/java/org/apache/karaf/scheduler/ScheduleOptions.java
----------------------------------------------------------------------
diff --git a/scheduler/src/main/java/org/apache/karaf/scheduler/ScheduleOptions.java b/scheduler/src/main/java/org/apache/karaf/scheduler/ScheduleOptions.java
index 695f471..a84ba89 100644
--- a/scheduler/src/main/java/org/apache/karaf/scheduler/ScheduleOptions.java
+++ b/scheduler/src/main/java/org/apache/karaf/scheduler/ScheduleOptions.java
@@ -31,6 +31,7 @@ public interface ScheduleOptions {
      * Add optional configuration for the job.
      *
      * @param config An optional configuration object - this configuration is only passed to the job the job implements {@link Job}.
+     * @return The {@code ScheduleOptions}.
      */
     ScheduleOptions config(final Map<String, Serializable> config);
 
@@ -39,7 +40,8 @@ public interface ScheduleOptions {
      * A job only needs a name if it is scheduled and should be cancelled later on. The name can then be used to cancel the job.
      * If a second job with the same name is started, the second one replaces the first one.
      *
-     * @param name The job name
+     * @param name The job name.
+     * @return The {@code ScheduleOptions}.
      */
     ScheduleOptions name(final String name);
 
@@ -48,6 +50,7 @@ public interface ScheduleOptions {
      * This defaults to false.
      *
      * @param flag Whether this job can run even if previous scheduled runs are still running.
+     * @return The {@code ScheduleOptions}.
      */
     ScheduleOptions canRunConcurrently(final boolean flag);
 
@@ -56,4 +59,5 @@ public interface ScheduleOptions {
     boolean canRunConcurrently();
 
     String schedule();
+
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/karaf/blob/8a1e7574/scheduler/src/main/java/org/apache/karaf/scheduler/Scheduler.java
----------------------------------------------------------------------
diff --git a/scheduler/src/main/java/org/apache/karaf/scheduler/Scheduler.java b/scheduler/src/main/java/org/apache/karaf/scheduler/Scheduler.java
index e267c28..90bd766 100644
--- a/scheduler/src/main/java/org/apache/karaf/scheduler/Scheduler.java
+++ b/scheduler/src/main/java/org/apache/karaf/scheduler/Scheduler.java
@@ -73,9 +73,9 @@ public interface Scheduler {
      * by one of the provided methods from this scheduler.
      *
      * @param job The job to execute (either {@link Job} or {@link Runnable}).
-     * @param options Required options defining how to schedule the job
-     * @throws SchedulerException if the job can't be scheduled
-     * @throws IllegalArgumentException If the preconditions are not met
+     * @param options Required options defining how to schedule the job.
+     * @throws SchedulerException if the job can't be scheduled.
+     * @throws IllegalArgumentException If the preconditions are not met.
      * @see #NOW()
      * @see #NOW(int, long)
      * @see #AT(Date)
@@ -88,7 +88,7 @@ public interface Scheduler {
      * Remove a scheduled job by name.
      *
      * @param jobName The name of the job.
-     * @return <code>true</code> if the job existed and could be stopped, <code>false</code> otherwise.
+     * @return <code>True</code> if the job existed and could be stopped, <code>false</code> otherwise.
      */
     boolean unschedule(String jobName);
 
@@ -96,35 +96,43 @@ public interface Scheduler {
 
     /**
      * Create a schedule options to fire a job immediately and only once.
+     *
+     * @return The corresponding {@link ScheduleOptions}.
      */
     ScheduleOptions NOW();
 
     /**
      * Create a schedule options to fire a job immediately more than once.
-     * @param times The number of times this job should be started (must be higher than 1 or
-     *              -1 for endless)
+     * @param times The number of times this job should be started (must be higher than 1 or -1 for endless).
      * @param period Every period seconds this job is started (must be at higher than 0).
+     * @return The corresponding {@link ScheduleOptions}.
      */
     ScheduleOptions NOW(int times, long period);
 
     /**
-     * Create a schedule options to fire a job once at a specific date
+     * Create a schedule options to fire a job once at a specific date.
+     *
      * @param date The date this job should be run.
+     * @return The corresponding {@link ScheduleOptions}.
      */
     ScheduleOptions AT(final Date date);
 
     /**
-     * Create a schedule options to fire a job period starting at a specific date
+     * Create a schedule options to fire a job period starting at a specific date.
+     *
      * @param date The date this job should be run.
-     * @param times The number of times this job should be started (must be higher than 1 or
-     *              -1 for endless)
+     * @param times The number of times this job should be started (must be higher than 1 or -1 for endless).
      * @param period Every period seconds this job is started (must be at higher than 0).
+     * @return The corresponding {@link ScheduleOptions}.
      */
     ScheduleOptions AT(final Date date, int times, long period);
 
     /**
-     * Create a schedule options to schedule the job based on the expression
-     * @param expression The cron exception
+     * Create a schedule options to schedule the job based on the expression.
+     *
+     * @param expression The cron exception.
+     * @return The corresponding {@link ScheduleOptions}.
      */
     ScheduleOptions EXPR(final String expression);
+
 }

http://git-wip-us.apache.org/repos/asf/karaf/blob/8a1e7574/scr/examples/component-factory/src/main/java/org/apache/karaf/scr/examples/component/factories/impl/GreeterServiceComponentFactoryImpl.java
----------------------------------------------------------------------
diff --git a/scr/examples/component-factory/src/main/java/org/apache/karaf/scr/examples/component/factories/impl/GreeterServiceComponentFactoryImpl.java b/scr/examples/component-factory/src/main/java/org/apache/karaf/scr/examples/component/factories/impl/GreeterServiceComponentFactoryImpl.java
index f6f680e..2a24c5a 100644
--- a/scr/examples/component-factory/src/main/java/org/apache/karaf/scr/examples/component/factories/impl/GreeterServiceComponentFactoryImpl.java
+++ b/scr/examples/component-factory/src/main/java/org/apache/karaf/scr/examples/component/factories/impl/GreeterServiceComponentFactoryImpl.java
@@ -34,8 +34,6 @@ import java.util.concurrent.locks.ReentrantReadWriteLock;
  * configuration includes setting the name attribute and setting the
  * configuration policy to required. The default is optional and when the
  * component attempts to activate it will throw a RuntimeException.
- *
- * @author sully6768
  */
 // the ConfigAdmin PID of our component
 @Component(name = GreeterServiceComponentFactoryImpl.COMPONENT_NAME,
@@ -54,6 +52,8 @@ public class GreeterServiceComponentFactoryImpl implements GreeterServiceCompone
 
     /**
      * Called when all of the SCR Components required dependencies have been satisfied.
+     *
+     * @param properties The activation properties.
      */
     @Activate
     public void activate(final Map<String, ?> properties) {

http://git-wip-us.apache.org/repos/asf/karaf/blob/8a1e7574/scr/examples/managed-service/src/main/java/org/apache/karaf/scr/examples/managed/service/impl/ManagedGreeterServiceImpl.java
----------------------------------------------------------------------
diff --git a/scr/examples/managed-service/src/main/java/org/apache/karaf/scr/examples/managed/service/impl/ManagedGreeterServiceImpl.java b/scr/examples/managed-service/src/main/java/org/apache/karaf/scr/examples/managed/service/impl/ManagedGreeterServiceImpl.java
index 1ba42e2..dae7a3c 100644
--- a/scr/examples/managed-service/src/main/java/org/apache/karaf/scr/examples/managed/service/impl/ManagedGreeterServiceImpl.java
+++ b/scr/examples/managed-service/src/main/java/org/apache/karaf/scr/examples/managed/service/impl/ManagedGreeterServiceImpl.java
@@ -46,6 +46,8 @@ public class ManagedGreeterServiceImpl implements ManagedGreeterService {
 
     /**
      * Called when all of the SCR Components required dependencies have been satisfied.
+     *
+     * @param properties The activation properties.
      */
     @Activate
     public void activate(final Map<String, ?> properties) {
@@ -87,6 +89,8 @@ public class ManagedGreeterServiceImpl implements ManagedGreeterService {
 
     /**
      * Called when the configuration associated with this component has been updated.
+     *
+     * @param properties The updated configuration.
      */
     @Modified
     public void modified(final Map<String, ?> properties) {

http://git-wip-us.apache.org/repos/asf/karaf/blob/8a1e7574/scr/management/src/main/java/org/apache/karaf/scr/management/ScrServiceMBean.java
----------------------------------------------------------------------
diff --git a/scr/management/src/main/java/org/apache/karaf/scr/management/ScrServiceMBean.java b/scr/management/src/main/java/org/apache/karaf/scr/management/ScrServiceMBean.java
index 8831083..663eb90 100644
--- a/scr/management/src/main/java/org/apache/karaf/scr/management/ScrServiceMBean.java
+++ b/scr/management/src/main/java/org/apache/karaf/scr/management/ScrServiceMBean.java
@@ -60,47 +60,47 @@ public interface ScrServiceMBean {
     String[] REFERENCE = {REFERENCE_NAME, REFERENCE_SATISFIED, REFERENCE_CARDINALITY, REFERENCE_AVAILABILITY, REFERENCE_POLICY, REFERENCE_BOUND_SERVICES};
 
     /**
-     * Displays a {@link TabularData} with all the component details.
+     * Display a {@link TabularData} with all the component details.
      *
-     * @return
+     * @return A {@link TabularData} containing all SCR components.
      */
     TabularData getComponents();
 
     /**
-     * Presents a {@String} array of components currently registered with the SCR.
+     * Present a {@code String} array of components currently registered with the SCR.
      *
-     * @return String[]
+     * @return A {@code String[]} containing all SCR components ID.
      */
     String[] listComponents();
 
     /**
-     * Verifies if the named component is currently in an ACTIVE state.
+     * Verify if the named component is currently in an ACTIVE state.
      *
-     * @param componentName the components name
-     * @return true if ACTIVE, otherwise false
-     * @throws Exception
+     * @param componentName The component name.
+     * @return True if the component is ACTIVE, otherwise false.
+     * @throws MBeanException If the check fails.
      */
     boolean isComponentActive(String componentName) throws MBeanException;
 
     /**
-     * Returns the named components state
+     * Return the named components state.
      *
-     * @param componentName the components name
-     * @return
+     * @param componentName The component name.
+     * @return The component status.
      */
     int componentState(String componentName);
 
     /**
-     * Activates a component that is currently in a DISABLED state.
+     * Activate a component that is currently in a DISABLED state.
      *
-     * @param componentName the components name
+     * @param componentName The component name.
      */
     void activateComponent(String componentName);
 
     /**
-     * Disables a component that is not in an ACTIVE state.
+     * Disable a component that is not in an ACTIVE state.
      *
-     * @param componentName the components name
+     * @param componentName The component name.
      */
     void deactivateComponent(String componentName);
 

http://git-wip-us.apache.org/repos/asf/karaf/blob/8a1e7574/scr/management/src/main/java/org/apache/karaf/scr/management/internal/ScrServiceMBeanImpl.java
----------------------------------------------------------------------
diff --git a/scr/management/src/main/java/org/apache/karaf/scr/management/internal/ScrServiceMBeanImpl.java b/scr/management/src/main/java/org/apache/karaf/scr/management/internal/ScrServiceMBeanImpl.java
index 2d93dc3..13ce9f8 100644
--- a/scr/management/src/main/java/org/apache/karaf/scr/management/internal/ScrServiceMBeanImpl.java
+++ b/scr/management/src/main/java/org/apache/karaf/scr/management/internal/ScrServiceMBeanImpl.java
@@ -60,7 +60,7 @@ public class ScrServiceMBeanImpl extends StandardMBean implements ScrServiceMBea
     /**
      * Creates new Declarative Services MBean.
      *
-     * @throws NotCompliantMBeanException
+     * @throws NotCompliantMBeanException If the MBean is not a valid MBean.
      */
     public ScrServiceMBeanImpl() throws NotCompliantMBeanException {
         super(ScrServiceMBean.class);
@@ -69,7 +69,7 @@ public class ScrServiceMBeanImpl extends StandardMBean implements ScrServiceMBea
     /**
      * Service component activation call back.  Called when all dependencies are satisfied.
      *
-     * @throws Exception
+     * @throws Exception If the activation fails.
      */
     @Activate
     public void activate() throws Exception {
@@ -92,7 +92,7 @@ public class ScrServiceMBeanImpl extends StandardMBean implements ScrServiceMBea
      * Service component deactivation call back.  Called after the component is in an active
      * state when any dependencies become unsatisfied.
      *
-     * @throws Exception
+     * @throws Exception If the deactivation fails.
      */
     @Deactivate
     public void deactivate() throws Exception {

http://git-wip-us.apache.org/repos/asf/karaf/blob/8a1e7574/service/guard/src/main/java/org/apache/karaf/service/guard/tools/ACLConfigurationParser.java
----------------------------------------------------------------------
diff --git a/service/guard/src/main/java/org/apache/karaf/service/guard/tools/ACLConfigurationParser.java b/service/guard/src/main/java/org/apache/karaf/service/guard/tools/ACLConfigurationParser.java
index b389a90..d47ada2 100644
--- a/service/guard/src/main/java/org/apache/karaf/service/guard/tools/ACLConfigurationParser.java
+++ b/service/guard/src/main/java/org/apache/karaf/service/guard/tools/ACLConfigurationParser.java
@@ -30,12 +30,13 @@ public class ACLConfigurationParser {
     };
 
     /**
-     * Returns the roles that can invoke the given operation. This is determined by matching the
-     * operation details against configuration provided.<p/>
+     * <p>Returns the roles that can invoke the given operation. This is determined by matching the
+     * operation details against configuration provided.</p>
      *
-     * The following configuration is supported. Keys are used to match an invocation against. The value can contain
+     * <p>The following configuration is supported. Keys are used to match an invocation against. The value can contain
      * a comma-separated list of roles. Spaces are ignored for the role values. Note that comments are allowed in the
-     * value field after the hash {@code #} character:
+     * value field after the hash {@code #} character:</p>
+     *
      * <pre>
      *     {@code
      *     myMethod = role1, role2
@@ -49,7 +50,7 @@ public class ACLConfigurationParser {
      *     }
      * </pre>
      *
-     * The following algorithm is used to find matching roles:
+     * <p>The following algorithm is used to find matching roles:</p>
      * <ol>
      *     <li>Find all regex and exact value matches. For all parameters these matches are found by calling {@code toString()}
      *         on the parameters passed in. If there are multiple matches in this category all the matching roles are collected.

http://git-wip-us.apache.org/repos/asf/karaf/blob/8a1e7574/services/eventadmin/src/main/java/org/apache/felix/eventadmin/impl/Configuration.java
----------------------------------------------------------------------
diff --git a/services/eventadmin/src/main/java/org/apache/felix/eventadmin/impl/Configuration.java b/services/eventadmin/src/main/java/org/apache/felix/eventadmin/impl/Configuration.java
index 02ab0aa..a5e96ba 100644
--- a/services/eventadmin/src/main/java/org/apache/felix/eventadmin/impl/Configuration.java
+++ b/services/eventadmin/src/main/java/org/apache/felix/eventadmin/impl/Configuration.java
@@ -18,7 +18,6 @@
  */
 package org.apache.felix.eventadmin.impl;
 
-
 import java.util.Dictionary;
 import java.util.Hashtable;
 import java.util.StringTokenizer;
@@ -40,61 +39,60 @@ import org.osgi.service.cm.ManagedService;
 import org.osgi.service.event.EventAdmin;
 import org.osgi.service.metatype.MetaTypeProvider;
 
-
 /**
- * The <code>Configuration</code> class encapsules the
- * configuration for the event admin.
+ * <p>The <code>Configuration</code> class encapsules the
+ * configuration for the event admin.</p>
  *
- * The service knows about the following properties which are read at bundle startup:
- * <p>
+ * <p>The service knows about the following properties which are read at bundle startup:</p>
  * <p>
  *      <tt>org.apache.felix.eventadmin.ThreadPoolSize</tt> - The size of the thread
  *          pool.
  * </p>
- * The default value is 10. Increase in case of a large amount of synchronous events
+ *
+ * <p>The default value is 10. Increase in case of a large amount of synchronous events
  * where the <tt>EventHandler</tt> services in turn send new synchronous events in
  * the event dispatching thread or a lot of timeouts are to be expected. A value of
  * less then 2 triggers the default value. A value of 2 effectively disables thread
- * pooling.
- * </p>
- * <p>
+ * pooling.</p>
+ *
  * <p>
  *      <tt>org.apache.felix.eventadmin.Timeout</tt> - The black-listing timeout in
  *          milliseconds
  * </p>
- * The default value is 5000. Increase or decrease at own discretion. A value of less
+ *
+ * <p>The default value is 5000. Increase or decrease at own discretion. A value of less
  * then 100 turns timeouts off. Any other value is the time in milliseconds granted
- * to each <tt>EventHandler</tt> before it gets blacklisted.
- * </p>
- * <p>
+ * to each <tt>EventHandler</tt> before it gets blacklisted.</p>
+ *
  * <p>
  *      <tt>org.apache.felix.eventadmin.RequireTopic</tt> - Are <tt>EventHandler</tt>
  *          required to be registered with a topic?
  * </p>
- * The default is <tt>true</tt>. The specification says that <tt>EventHandler</tt>
+ *
+ * <p>The default is <tt>true</tt>. The specification says that <tt>EventHandler</tt>
  * must register with a list of topics they are interested in. Setting this value to
  * <tt>false</tt> will enable that handlers without a topic are receiving all events
- * (i.e., they are treated the same as with a topic=*).
- * </p>
- * <p>
+ * (i.e., they are treated the same as with a topic=*).</p>
+ *
  * <p>
  *      <tt>org.apache.felix.eventadmin.IgnoreTimeout</tt> - Configure
  *         <tt>EventHandler</tt>s to be called without a timeout.
  * </p>
- * If a timeout is configured by default all event handlers are called using the timeout.
+ *
+ * <p>If a timeout is configured by default all event handlers are called using the timeout.
  * For performance optimization it is possible to configure event handlers where the
  * timeout handling is not used - this reduces the thread usage from the thread pools
  * as the timout handling requires an additional thread to call the event handler.
  * However, the application should work without this configuration property. It is a
- * pure optimization!
+ * pure optimization.
  * The value is a list of string (separated by comma). If the string ends with a dot,
  * all handlers in exactly this package are ignored. If the string ends with a star,
  * all handlers in this package and all subpackages are ignored. If the string neither
- * ends with a dot nor with a start, this is assumed to define an exact class name.
+ * ends with a dot nor with a start, this is assumed to define an exact class name.</p>
  *
- * These properties are read at startup and serve as a default configuration.
+ * <p>These properties are read at startup and serve as a default configuration.
  * If a configuration admin is configured, the event admin can be configured
- * through the config admin.
+ * through the config admin.</p>
  *
  * @author <a href="mailto:dev@felix.apache.org">Felix Project Team</a>
  */