You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@gora.apache.org by le...@apache.org on 2016/05/23 15:35:27 UTC

[1/2] gora git commit: GORA-445 Fixed javadocs errors

Repository: gora
Updated Branches:
  refs/heads/master 8a7101781 -> f5a6d842d


http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-mongodb/src/main/java/org/apache/gora/mongodb/store/MongoStore.java
----------------------------------------------------------------------
diff --git a/gora-mongodb/src/main/java/org/apache/gora/mongodb/store/MongoStore.java b/gora-mongodb/src/main/java/org/apache/gora/mongodb/store/MongoStore.java
index 79c5e91..c0a1d25 100644
--- a/gora-mongodb/src/main/java/org/apache/gora/mongodb/store/MongoStore.java
+++ b/gora-mongodb/src/main/java/org/apache/gora/mongodb/store/MongoStore.java
@@ -63,11 +63,11 @@ import com.mongodb.*;
  *          class to be used for the key
  * @param <T>
  *          class to be persisted within the store
- * @author Fabien Poulard <fp...@dictanova.com>
- * @author Damien Raude-Morvan <dr...@dictanova.com>
+ * @author Fabien Poulard fpoulard@dictanova.com
+ * @author Damien Raude-Morvan draudemorvan@dictanova.com
  */
 public class MongoStore<K, T extends PersistentBase> extends
-    DataStoreBase<K, T> {
+DataStoreBase<K, T> {
 
   public static final Logger LOG = LoggerFactory.getLogger(MongoStore.class);
 
@@ -123,7 +123,7 @@ public class MongoStore<K, T extends PersistentBase> extends
           .getCollection(mapping.getCollectionName());
 
       LOG.info("Initialized Mongo store for database {} of {}.", new Object[] {
-              parameters.getDbname(), parameters.getServers() });
+          parameters.getDbname(), parameters.getServers() });
     } catch (IOException e) {
       LOG.error("Error while initializing MongoDB store: {}",
           new Object[] { e.getMessage() });
@@ -145,7 +145,7 @@ public class MongoStore<K, T extends PersistentBase> extends
       throws UnknownHostException {
     // Configure options
     MongoClientOptions.Builder optBuilder = new MongoClientOptions.Builder()
-            .dbEncoderFactory(GoraDBEncoder.FACTORY); // Utf8 serialization!
+        .dbEncoderFactory(GoraDBEncoder.FACTORY); // Utf8 serialization!
     if (params.getReadPreference() != null) {
       optBuilder.readPreference(ReadPreference.valueOf(params.getReadPreference()));
     }
@@ -284,7 +284,6 @@ public class MongoStore<K, T extends PersistentBase> extends
    *          identifier of the document in the database
    * @param fields
    *          list of fields to be loaded from the database
-   * @throws IOException
    */
   @Override
   public T get(final K key, final String[] fields) {
@@ -448,7 +447,6 @@ public class MongoStore<K, T extends PersistentBase> extends
    *          the list of fields to be mapped to the persistence class instance
    * @return a persistence class instance which content was deserialized from
    *         the {@link DBObject}
-   * @throws IOException
    */
   public T newInstance(final DBObject obj, final String[] fields) {
     if (obj == null)
@@ -579,22 +577,22 @@ public class MongoStore<K, T extends PersistentBase> extends
           .getDocumentFieldType(innerSchema.getName());
       String innerDocField = mapping.getDocumentField(recField.name()) != null ? mapping
           .getDocumentField(recField.name()) : recField.name();
-      String fieldPath = docf + "." + innerDocField;
-      LOG.debug(
-          "Load from DBObject (RECORD), field:{}, schemaType:{}, docField:{}, storeType:{}",
-          new Object[] { recField.name(), innerSchema.getType(), fieldPath,
-              innerStoreType });
-      record.put(
-          recField.pos(),
-          fromDBObject(innerSchema, innerStoreType, recField, innerDocField,
-              innerBson));
+          String fieldPath = docf + "." + innerDocField;
+          LOG.debug(
+              "Load from DBObject (RECORD), field:{}, schemaType:{}, docField:{}, storeType:{}",
+              new Object[] { recField.name(), innerSchema.getType(), fieldPath,
+                  innerStoreType });
+          record.put(
+              recField.pos(),
+              fromDBObject(innerSchema, innerStoreType, recField, innerDocField,
+                  innerBson));
     }
     result = record;
     return result;
   }
 
   /* pp */ Object fromMongoList(final String docf, final Schema fieldSchema,
-                       final BSONDecorator easybson, final Field f) {
+      final BSONDecorator easybson, final Field f) {
     List<Object> list = easybson.getDBList(docf);
     List<Object> rlist = new ArrayList<>();
     if (list == null) {
@@ -612,11 +610,11 @@ public class MongoStore<K, T extends PersistentBase> extends
   }
 
   /* pp */ Object fromMongoMap(final String docf, final Schema fieldSchema,
-                      final BSONDecorator easybson, final Field f) {
+      final BSONDecorator easybson, final Field f) {
     BasicDBObject map = easybson.getDBObject(docf);
     Map<Utf8, Object> rmap = new HashMap<>();
     if (map == null) {
-        return new DirtyMapWrapper(rmap);
+      return new DirtyMapWrapper(rmap);
     }
     for (Entry<String, Object> e : map.entrySet()) {
       String mapKey = e.getKey();
@@ -843,7 +841,7 @@ public class MongoStore<K, T extends PersistentBase> extends
         } catch (IllegalArgumentException e1) {
           // Unable to parse anything from Utf8 value, throw error
           throw new IllegalStateException("Field " + fieldSchema.getType()
-              + ": Invalid string: unable to convert to ObjectId");
+          + ": Invalid string: unable to convert to ObjectId");
         }
         result = id;
       }
@@ -865,7 +863,7 @@ public class MongoStore<K, T extends PersistentBase> extends
         if (calendar == null) {
           // Unable to parse anything from Utf8 value, throw error
           throw new IllegalStateException("Field " + fieldSchema.getType()
-              + ": Invalid date format '" + value + "'");
+          + ": Invalid date format '" + value + "'");
         }
         result = calendar.getTime();
       }
@@ -942,7 +940,7 @@ public class MongoStore<K, T extends PersistentBase> extends
   // //////////////////////////////////////////////////////// CLEANUP
 
   /**
-   * Ensure Key encoding -> dots replaced with middle dots
+   * Ensure Key encoding -&gt; dots replaced with middle dots
    * 
    * @param key
    *          char with only dots.
@@ -956,7 +954,7 @@ public class MongoStore<K, T extends PersistentBase> extends
   }
 
   /**
-   * Ensure Key decoding -> middle dots replaced with dots
+   * Ensure Key decoding -&gt; middle dots replaced with dots
    * 
    * @param key
    *          encoded string with "\u00B7" chars.

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-mongodb/src/main/java/org/apache/gora/mongodb/utils/BSONDecorator.java
----------------------------------------------------------------------
diff --git a/gora-mongodb/src/main/java/org/apache/gora/mongodb/utils/BSONDecorator.java b/gora-mongodb/src/main/java/org/apache/gora/mongodb/utils/BSONDecorator.java
index ec48329..ac98096 100644
--- a/gora-mongodb/src/main/java/org/apache/gora/mongodb/utils/BSONDecorator.java
+++ b/gora-mongodb/src/main/java/org/apache/gora/mongodb/utils/BSONDecorator.java
@@ -30,7 +30,7 @@ import java.util.Date;
  * Utility class to build {@link DBObject} used by MongoDB in an easy way by
  * directly specifying the fully qualified names of fields.
  *
- * @author Fabien Poulard <fp...@dictanova.com>
+ * @author Fabien Poulard fpoulard@dictanova.com
  */
 public class BSONDecorator {
 

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-shims-hadoop/src/main/java/org/apache/gora/shims/hadoop/HadoopShim.java
----------------------------------------------------------------------
diff --git a/gora-shims-hadoop/src/main/java/org/apache/gora/shims/hadoop/HadoopShim.java b/gora-shims-hadoop/src/main/java/org/apache/gora/shims/hadoop/HadoopShim.java
index 78d746a..dc8e975 100644
--- a/gora-shims-hadoop/src/main/java/org/apache/gora/shims/hadoop/HadoopShim.java
+++ b/gora-shims-hadoop/src/main/java/org/apache/gora/shims/hadoop/HadoopShim.java
@@ -38,7 +38,7 @@ public abstract class HadoopShim {
    * @param configuration
    *            The job's configuration.
    * @return A newly created instance backed by the provided configuration.
-   * @throws IOException
+   * @throws IOException if the job cannot be created successfully from given configuration
    */
   public abstract Job createJob(Configuration configuration)
       throws IOException;

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-tutorial/src/main/java/org/apache/gora/tutorial/log/generated/MetricDatum.java
----------------------------------------------------------------------
diff --git a/gora-tutorial/src/main/java/org/apache/gora/tutorial/log/generated/MetricDatum.java b/gora-tutorial/src/main/java/org/apache/gora/tutorial/log/generated/MetricDatum.java
index d993033..0d7be00 100644
--- a/gora-tutorial/src/main/java/org/apache/gora/tutorial/log/generated/MetricDatum.java
+++ b/gora-tutorial/src/main/java/org/apache/gora/tutorial/log/generated/MetricDatum.java
@@ -106,7 +106,6 @@ public class MetricDatum extends org.apache.gora.persistency.impl.PersistentBase
   
   /**
    * Checks the dirty status of the 'metricDimension' field. A field is dirty if it represents a change that has not yet been written to the database.
-   * @param value the value to set.
    */
   public boolean isMetricDimensionDirty() {
     return isDirty(0);
@@ -130,7 +129,6 @@ public class MetricDatum extends org.apache.gora.persistency.impl.PersistentBase
   
   /**
    * Checks the dirty status of the 'timestamp' field. A field is dirty if it represents a change that has not yet been written to the database.
-   * @param value the value to set.
    */
   public boolean isTimestampDirty() {
     return isDirty(1);
@@ -154,7 +152,6 @@ public class MetricDatum extends org.apache.gora.persistency.impl.PersistentBase
   
   /**
    * Checks the dirty status of the 'metric' field. A field is dirty if it represents a change that has not yet been written to the database.
-   * @param value the value to set.
    */
   public boolean isMetricDirty() {
     return isDirty(2);
@@ -353,7 +350,6 @@ public class MetricDatum extends org.apache.gora.persistency.impl.PersistentBase
 	  
 	  /**
 	   * Checks the dirty status of the 'metricDimension' field. A field is dirty if it represents a change that has not yet been written to the database.
-		   * @param value the value to set.
 	   */
 	  public boolean isMetricDimensionDirty() {
 	    throw new java.lang.UnsupportedOperationException("IsDirty is not supported on tombstones");
@@ -376,7 +372,6 @@ public class MetricDatum extends org.apache.gora.persistency.impl.PersistentBase
 	  
 	  /**
 	   * Checks the dirty status of the 'timestamp' field. A field is dirty if it represents a change that has not yet been written to the database.
-		   * @param value the value to set.
 	   */
 	  public boolean isTimestampDirty() {
 	    throw new java.lang.UnsupportedOperationException("IsDirty is not supported on tombstones");
@@ -399,7 +394,6 @@ public class MetricDatum extends org.apache.gora.persistency.impl.PersistentBase
 	  
 	  /**
 	   * Checks the dirty status of the 'metric' field. A field is dirty if it represents a change that has not yet been written to the database.
-		   * @param value the value to set.
 	   */
 	  public boolean isMetricDirty() {
 	    throw new java.lang.UnsupportedOperationException("IsDirty is not supported on tombstones");

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-tutorial/src/main/java/org/apache/gora/tutorial/log/generated/Pageview.java
----------------------------------------------------------------------
diff --git a/gora-tutorial/src/main/java/org/apache/gora/tutorial/log/generated/Pageview.java b/gora-tutorial/src/main/java/org/apache/gora/tutorial/log/generated/Pageview.java
index 3238db5..4ace856 100644
--- a/gora-tutorial/src/main/java/org/apache/gora/tutorial/log/generated/Pageview.java
+++ b/gora-tutorial/src/main/java/org/apache/gora/tutorial/log/generated/Pageview.java
@@ -132,7 +132,6 @@ public class Pageview extends org.apache.gora.persistency.impl.PersistentBase im
   
   /**
    * Checks the dirty status of the 'url' field. A field is dirty if it represents a change that has not yet been written to the database.
-   * @param value the value to set.
    */
   public boolean isUrlDirty() {
     return isDirty(0);
@@ -156,7 +155,6 @@ public class Pageview extends org.apache.gora.persistency.impl.PersistentBase im
   
   /**
    * Checks the dirty status of the 'timestamp' field. A field is dirty if it represents a change that has not yet been written to the database.
-   * @param value the value to set.
    */
   public boolean isTimestampDirty() {
     return isDirty(1);
@@ -180,7 +178,6 @@ public class Pageview extends org.apache.gora.persistency.impl.PersistentBase im
   
   /**
    * Checks the dirty status of the 'ip' field. A field is dirty if it represents a change that has not yet been written to the database.
-   * @param value the value to set.
    */
   public boolean isIpDirty() {
     return isDirty(2);
@@ -204,7 +201,6 @@ public class Pageview extends org.apache.gora.persistency.impl.PersistentBase im
   
   /**
    * Checks the dirty status of the 'httpMethod' field. A field is dirty if it represents a change that has not yet been written to the database.
-   * @param value the value to set.
    */
   public boolean isHttpMethodDirty() {
     return isDirty(3);
@@ -228,7 +224,6 @@ public class Pageview extends org.apache.gora.persistency.impl.PersistentBase im
   
   /**
    * Checks the dirty status of the 'httpStatusCode' field. A field is dirty if it represents a change that has not yet been written to the database.
-   * @param value the value to set.
    */
   public boolean isHttpStatusCodeDirty() {
     return isDirty(4);
@@ -252,7 +247,6 @@ public class Pageview extends org.apache.gora.persistency.impl.PersistentBase im
   
   /**
    * Checks the dirty status of the 'responseSize' field. A field is dirty if it represents a change that has not yet been written to the database.
-   * @param value the value to set.
    */
   public boolean isResponseSizeDirty() {
     return isDirty(5);
@@ -276,7 +270,6 @@ public class Pageview extends org.apache.gora.persistency.impl.PersistentBase im
   
   /**
    * Checks the dirty status of the 'referrer' field. A field is dirty if it represents a change that has not yet been written to the database.
-   * @param value the value to set.
    */
   public boolean isReferrerDirty() {
     return isDirty(6);
@@ -300,7 +293,6 @@ public class Pageview extends org.apache.gora.persistency.impl.PersistentBase im
   
   /**
    * Checks the dirty status of the 'userAgent' field. A field is dirty if it represents a change that has not yet been written to the database.
-   * @param value the value to set.
    */
   public boolean isUserAgentDirty() {
     return isDirty(7);
@@ -653,7 +645,6 @@ public class Pageview extends org.apache.gora.persistency.impl.PersistentBase im
 	  
 	  /**
 	   * Checks the dirty status of the 'url' field. A field is dirty if it represents a change that has not yet been written to the database.
-		   * @param value the value to set.
 	   */
 	  public boolean isUrlDirty() {
 	    throw new java.lang.UnsupportedOperationException("IsDirty is not supported on tombstones");
@@ -676,7 +667,6 @@ public class Pageview extends org.apache.gora.persistency.impl.PersistentBase im
 	  
 	  /**
 	   * Checks the dirty status of the 'timestamp' field. A field is dirty if it represents a change that has not yet been written to the database.
-		   * @param value the value to set.
 	   */
 	  public boolean isTimestampDirty() {
 	    throw new java.lang.UnsupportedOperationException("IsDirty is not supported on tombstones");
@@ -699,7 +689,6 @@ public class Pageview extends org.apache.gora.persistency.impl.PersistentBase im
 	  
 	  /**
 	   * Checks the dirty status of the 'ip' field. A field is dirty if it represents a change that has not yet been written to the database.
-		   * @param value the value to set.
 	   */
 	  public boolean isIpDirty() {
 	    throw new java.lang.UnsupportedOperationException("IsDirty is not supported on tombstones");
@@ -722,7 +711,6 @@ public class Pageview extends org.apache.gora.persistency.impl.PersistentBase im
 	  
 	  /**
 	   * Checks the dirty status of the 'httpMethod' field. A field is dirty if it represents a change that has not yet been written to the database.
-		   * @param value the value to set.
 	   */
 	  public boolean isHttpMethodDirty() {
 	    throw new java.lang.UnsupportedOperationException("IsDirty is not supported on tombstones");
@@ -745,7 +733,6 @@ public class Pageview extends org.apache.gora.persistency.impl.PersistentBase im
 	  
 	  /**
 	   * Checks the dirty status of the 'httpStatusCode' field. A field is dirty if it represents a change that has not yet been written to the database.
-		   * @param value the value to set.
 	   */
 	  public boolean isHttpStatusCodeDirty() {
 	    throw new java.lang.UnsupportedOperationException("IsDirty is not supported on tombstones");
@@ -768,7 +755,6 @@ public class Pageview extends org.apache.gora.persistency.impl.PersistentBase im
 	  
 	  /**
 	   * Checks the dirty status of the 'responseSize' field. A field is dirty if it represents a change that has not yet been written to the database.
-		   * @param value the value to set.
 	   */
 	  public boolean isResponseSizeDirty() {
 	    throw new java.lang.UnsupportedOperationException("IsDirty is not supported on tombstones");
@@ -788,12 +774,11 @@ public class Pageview extends org.apache.gora.persistency.impl.PersistentBase im
 	  public void setReferrer(java.lang.CharSequence value) {
 	    throw new java.lang.UnsupportedOperationException("Set is not supported on tombstones");
 	  }
-	  
-	  /**
-	   * Checks the dirty status of the 'referrer' field. A field is dirty if it represents a change that has not yet been written to the database.
-		   * @param value the value to set.
-	   */
-	  public boolean isReferrerDirty() {
+
+    /**
+     * Checks the dirty status of the 'referrer' field. A field is dirty if it represents a change that has not yet been written to the database.
+     */
+    public boolean isReferrerDirty() {
 	    throw new java.lang.UnsupportedOperationException("IsDirty is not supported on tombstones");
 	  }
 	
@@ -803,10 +788,10 @@ public class Pageview extends org.apache.gora.persistency.impl.PersistentBase im
 	  public java.lang.CharSequence getUserAgent() {
 	    throw new java.lang.UnsupportedOperationException("Get is not supported on tombstones");
 	  }
-	
-	  /**
-	   * Sets the value of the 'userAgent' field.
-		   * @param value the value to set.
+
+    /**
+     * Sets the value of the 'userAgent' field.
+     * @param value the value to set.
 	   */
 	  public void setUserAgent(java.lang.CharSequence value) {
 	    throw new java.lang.UnsupportedOperationException("Set is not supported on tombstones");
@@ -814,7 +799,6 @@ public class Pageview extends org.apache.gora.persistency.impl.PersistentBase im
 	  
 	  /**
 	   * Checks the dirty status of the 'userAgent' field. A field is dirty if it represents a change that has not yet been written to the database.
-		   * @param value the value to set.
 	   */
 	  public boolean isUserAgentDirty() {
 	    throw new java.lang.UnsupportedOperationException("IsDirty is not supported on tombstones");


[2/2] gora git commit: GORA-445 Fixed javadocs errors

Posted by le...@apache.org.
GORA-445 Fixed javadocs errors


Project: http://git-wip-us.apache.org/repos/asf/gora/repo
Commit: http://git-wip-us.apache.org/repos/asf/gora/commit/f5a6d842
Tree: http://git-wip-us.apache.org/repos/asf/gora/tree/f5a6d842
Diff: http://git-wip-us.apache.org/repos/asf/gora/diff/f5a6d842

Branch: refs/heads/master
Commit: f5a6d842d45bb592153b616085634b8fa3664d2d
Parents: 8a71017
Author: cihad guzel <cg...@gmail.com>
Authored: Sat May 21 13:38:05 2016 +0300
Committer: cihad guzel <cg...@gmail.com>
Committed: Sun May 22 01:51:44 2016 +0300

----------------------------------------------------------------------
 .../gora/cassandra/store/CassandraClient.java   |  44 ++++----
 .../gora/cassandra/store/CassandraStore.java    |  43 ++++----
 .../gora/cassandra/store/HectorUtils.java       |   2 +-
 .../org/apache/gora/compiler/GoraCompiler.java  |   7 +-
 .../org/apache/gora/avro/mapreduce/FsInput.java |   8 +-
 .../java/org/apache/gora/filter/Filter.java     |   8 +-
 .../java/org/apache/gora/filter/FilterList.java |   2 +-
 .../apache/gora/filter/MapFieldValueFilter.java |   2 +-
 .../apache/gora/mapreduce/GoraInputFormat.java  |  24 +++--
 .../org/apache/gora/mapreduce/GoraMapper.java   | 108 ++++++++++++-------
 .../apache/gora/mapreduce/GoraOutputFormat.java |  20 ++--
 .../org/apache/gora/mapreduce/GoraReducer.java  |  45 +++++---
 .../gora/mapreduce/PersistentSerializer.java    |   5 +-
 .../apache/gora/persistency/BeanFactory.java    |  30 ++++--
 .../gora/persistency/impl/BeanFactoryImpl.java  |  13 ++-
 .../persistency/ws/impl/BeanFactoryWSImpl.java  |   9 +-
 .../main/java/org/apache/gora/query/Query.java  |  34 +++---
 .../main/java/org/apache/gora/query/Result.java |  25 +++--
 .../org/apache/gora/query/impl/ResultBase.java  |  65 +++++------
 .../org/apache/gora/spark/GoraSparkEngine.java  |  46 +++++---
 .../java/org/apache/gora/store/DataStore.java   |  11 +-
 .../apache/gora/store/impl/DataStoreBase.java   |   5 +
 .../store/impl/FileBackedDataStoreBase.java     |  19 +++-
 .../java/org/apache/gora/util/AvroUtils.java    |   5 +-
 .../java/org/apache/gora/util/ByteUtils.java    |   4 +-
 .../dynamodb/compiler/GoraDynamoDBCompiler.java |   5 +-
 .../gora/dynamodb/query/DynamoDBQuery.java      |   3 -
 .../gora/dynamodb/store/DynamoDBAvroStore.java  |   5 +-
 .../gora/dynamodb/store/DynamoDBMapping.java    |   5 +-
 .../dynamodb/store/DynamoDBNativeStore.java     |  22 ++--
 .../gora/dynamodb/store/DynamoDBStore.java      |   9 +-
 .../gora/dynamodb/store/DynamoDBUtils.java      |   8 +-
 .../apache/gora/dynamodb/store/IDynamoDB.java   |   3 +-
 .../apache/gora/goraci/generated/CINode.java    |   6 --
 .../apache/gora/goraci/generated/Flushed.java   |   2 -
 .../org/apache/gora/hbase/store/HBaseStore.java |   2 +-
 .../gora/hbase/util/HBaseByteInterface.java     |   3 +-
 .../gora/mongodb/filters/BaseFactory.java       |   2 +-
 .../gora/mongodb/filters/FilterFactory.java     |   2 +-
 .../gora/mongodb/filters/MongoFilterUtil.java   |   2 +-
 .../apache/gora/mongodb/query/MongoDBQuery.java |   2 +-
 .../gora/mongodb/query/MongoDBResult.java       |   4 +-
 .../apache/gora/mongodb/store/MongoMapping.java |   2 +-
 .../gora/mongodb/store/MongoMappingBuilder.java |  16 ++-
 .../apache/gora/mongodb/store/MongoStore.java   |  44 ++++----
 .../gora/mongodb/utils/BSONDecorator.java       |   2 +-
 .../apache/gora/shims/hadoop/HadoopShim.java    |   2 +-
 .../tutorial/log/generated/MetricDatum.java     |   6 --
 .../gora/tutorial/log/generated/Pageview.java   |  34 ++----
 49 files changed, 437 insertions(+), 338 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-cassandra/src/main/java/org/apache/gora/cassandra/store/CassandraClient.java
----------------------------------------------------------------------
diff --git a/gora-cassandra/src/main/java/org/apache/gora/cassandra/store/CassandraClient.java b/gora-cassandra/src/main/java/org/apache/gora/cassandra/store/CassandraClient.java
index 661bb21..353a7c3 100644
--- a/gora-cassandra/src/main/java/org/apache/gora/cassandra/store/CassandraClient.java
+++ b/gora-cassandra/src/main/java/org/apache/gora/cassandra/store/CassandraClient.java
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
  * {@link org.apache.gora.cassandra.store.CassandraStore#initialize(Class, Class, Properties)}.
  * CassandraClient deals with Cassandra data model definition, mutation, 
  * and general/specific mappings.
- * @see {@link org.apache.gora.cassandra.store.CassandraStore#initialize(Class, Class, Properties)} 
+ * {@link org.apache.gora.cassandra.store.CassandraStore#initialize} .
  *
  * @param <K>
  * @param <T>
@@ -100,20 +100,21 @@ public class CassandraClient<K, T extends PersistentBase> {
     throws Exception {
 	initialize(keyClass, persistentClass, null);
   }
-  
+
   /**
-   * Given our key, persistentClass from 
+   * Given our key, persistentClass from
    * {@link org.apache.gora.cassandra.store.CassandraStore#initialize(Class, Class, Properties)}
-   * we make best efforts to dictate our data model. 
-   * We make a quick check within {@link org.apache.gora.cassandra.store.CassandraClient#checkKeyspace(String)
-   * to see if our keyspace has already been invented, this simple check prevents us from 
-   * recreating the keyspace if it already exists. 
+   * we make best efforts to dictate our data model.
+   * We make a quick check within {@link org.apache.gora.cassandra.store.CassandraClient#checkKeyspace() }
+   * to see if our keyspace has already been invented, this simple check prevents us from
+   * recreating the keyspace if it already exists.
    * We then simple specify (based on the input keyclass) an appropriate serializer
    * via {@link org.apache.gora.cassandra.serializers.GoraSerializerTypeInferer} before
    * defining a mutator from and by which we can mutate this object.
-   * @param keyClass the Key by which we wish o assign a record object
-   * @param persistentClass the generated {@link org.apache.org.gora.persistency.Peristent} bean representing the data.
-   * @param properties key value pairs from gora.properties
+   *
+   * @param keyClass        the Key by which we wish o assign a record object
+   * @param persistentClass the generated {@link org.apache.gora.persistency.Persistent} bean representing the data.
+   * @param properties      key value pairs from gora.properties
    * @throws Exception
    */
   public void initialize(Class<K> keyClass, Class<T> persistentClass, Properties properties) throws Exception {
@@ -160,20 +161,20 @@ public class CassandraClient<K, T extends PersistentBase> {
     KeyspaceDefinition keyspaceDefinition = this.cluster.describeKeyspace(this.cassandraMapping.getKeyspaceName());
     return (keyspaceDefinition != null);
   }
-  
+
   /**
    * Check if keyspace already exists. If not, create it.
-   * In this method, we also utilize Hector's 
-   * {@link me.prettyprint.cassandra.model.ConfigurableConsistencyLevel} logic. 
-   * It is set by passing a 
-   * {@link me.prettyprint.cassandra.model.ConfigurableConsistencyLevel} object right 
-   * when the {@link me.prettyprint.hector.api.Keyspace} is created. 
-   * If we cannot find a consistency level within <code>gora.properites</code>, 
-   * then column family consistency level is set to QUORUM (by default) which permits 
+   * In this method, we also utilize Hector's
+   * {@link me.prettyprint.cassandra.model.ConfigurableConsistencyLevel} logic.
+   * It is set by passing a
+   * {@link me.prettyprint.cassandra.model.ConfigurableConsistencyLevel} object right
+   * when the {@link me.prettyprint.hector.api.Keyspace} is created.
+   * If we cannot find a consistency level within <code>gora.properites</code>,
+   * then column family consistency level is set to QUORUM (by default) which permits
    * consistency to wait for a quorum of replicas to respond regardless of data center.
    * QUORUM is Hector Client's default setting and we respect that here as well.
-   * 
-   * @see http://hector-client.github.io/hector/build/html/content/consistency_level.html
+   *
+   * @see <a href="http://hector-client.github.io/hector/build/html/content/consistency_level.html">Consistency Level</a>
    */
   public void checkKeyspace() {
     // "describe keyspace <keyspaceName>;" query
@@ -296,8 +297,9 @@ public class CassandraClient<K, T extends PersistentBase> {
 
   /**
    * Delete a row within the keyspace.
+   *
    * @param key
-   * @param fieldName
+   * @param familyName
    * @param columnName
    */
   public void deleteColumn(K key, String familyName, ByteBuffer columnName) {

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-cassandra/src/main/java/org/apache/gora/cassandra/store/CassandraStore.java
----------------------------------------------------------------------
diff --git a/gora-cassandra/src/main/java/org/apache/gora/cassandra/store/CassandraStore.java b/gora-cassandra/src/main/java/org/apache/gora/cassandra/store/CassandraStore.java
index 2619129..5f21aca 100644
--- a/gora-cassandra/src/main/java/org/apache/gora/cassandra/store/CassandraStore.java
+++ b/gora-cassandra/src/main/java/org/apache/gora/cassandra/store/CassandraStore.java
@@ -65,10 +65,10 @@ import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
 /**
- * {@link org.apache.gora.cassandra.store.CassandraStore} is the primary class 
- * responsible for directing Gora CRUD operations into Cassandra. We (delegate) rely 
+ * {@link org.apache.gora.cassandra.store.CassandraStore} is the primary class
+ * responsible for directing Gora CRUD operations into Cassandra. We (delegate) rely
  * heavily on {@link org.apache.gora.cassandra.store.CassandraClient} for many operations
- * such as initialization, creating and deleting schemas (Cassandra Keyspaces), etc.  
+ * such as initialization, creating and deleting schemas (Cassandra Keyspaces), etc.
  */
 public class CassandraStore<K, T extends PersistentBase> extends DataStoreBase<K, T> {
 
@@ -132,9 +132,13 @@ public class CassandraStore<K, T extends PersistentBase> extends DataStoreBase<K
 
   /** 
    * Initialize is called when then the call to 
-   * {@link org.apache.gora.store.DataStoreFactory#createDataStore(Class<D> dataStoreClass, Class<K> keyClass, Class<T> persistent, org.apache.hadoop.conf.Configuration conf)}
+   * {@link org.apache.gora.store.DataStoreFactory#createDataStore}
    * is made. In this case, we merely delegate the store initialization to the 
-   * {@link org.apache.gora.cassandra.store.CassandraClient#initialize(Class<K> keyClass, Class<T> persistentClass)}. 
+   * {@link org.apache.gora.cassandra.store.CassandraClient#initialize}.
+   *
+   * @param keyClass
+   * @param persistent
+   * @param properties
    */
   public void initialize(Class<K> keyClass, Class<T> persistent, Properties properties) {
     try {
@@ -375,38 +379,37 @@ public class CassandraStore<K, T extends PersistentBase> extends DataStoreBase<K
   }
 
   /**
-   * 
-   * When doing the 
+   * When doing the
    * {@link org.apache.gora.cassandra.store.CassandraStore#put(Object, PersistentBase)}
    * operation, the logic is as follows:
    * <ol>
    * <li>Obtain the Avro {@link org.apache.avro.Schema} for the object.</li>
    * <li>Create a new duplicate instance of the object (explained in more detail below) **.</li>
-   * <li>Obtain a {@link java.util.List} of the {@link org.apache.avro.Schema} 
+   * <li>Obtain a {@link java.util.List} of the {@link org.apache.avro.Schema}
    * {@link org.apache.avro.Schema.Field}'s.</li>
-   * <li>Iterate through the field {@link java.util.List}. This allows us to 
+   * <li>Iterate through the field {@link java.util.List}. This allows us to
    * consequently process each item.</li>
-   * <li>Check to see if the {@link org.apache.avro.Schema.Field} is NOT dirty. 
+   * <li>Check to see if the {@link org.apache.avro.Schema.Field} is NOT dirty.
    * If this condition is true then we DO NOT process this field.</li>
-   * <li>Obtain the element at the specified position in this list so we can 
+   * <li>Obtain the element at the specified position in this list so we can
    * directly operate on it.</li>
-   * <li>Obtain the {@link org.apache.avro.Schema.Type} of the element obtained 
+   * <li>Obtain the {@link org.apache.avro.Schema.Type} of the element obtained
    * above and process it accordingly. N.B. For nested type ARRAY, MAP
-   * RECORD or UNION, we shadow the checks in bullet point 5 above to infer that the 
-   * {@link org.apache.avro.Schema.Field} is either at 
+   * RECORD or UNION, we shadow the checks in bullet point 5 above to infer that the
+   * {@link org.apache.avro.Schema.Field} is either at
    * position 0 OR it is NOT dirty. If one of these conditions is true then we DO NOT
-   * process this field. This is carried out in 
+   * process this field. This is carried out in
    * {@link org.apache.gora.cassandra.store.CassandraStore#getFieldValue(Schema, Type, Object)}</li>
-   * <li>We then insert the Key and Object into the {@link java.util.LinkedHashMap} buffer 
+   * <li>We then insert the Key and Object into the {@link java.util.LinkedHashMap} buffer
    * before being flushed. This performs a structural modification of the map.</li>
    * </ol>
    * ** We create a duplicate instance of the object to be persisted and insert processed
-   * objects into a synchronized {@link java.util.LinkedHashMap}. This allows 
+   * objects into a synchronized {@link java.util.LinkedHashMap}. This allows
    * us to keep all the objects in memory till flushing.
-   * @see org.apache.gora.store.DataStore#put(java.lang.Object, 
-   * org.apache.gora.persistency.Persistent).
-   * @param key for the Avro Record (object).
+   *
+   * @param key   for the Avro Record (object).
    * @param value Record object to be persisted in Cassandra
+   * @see org.apache.gora.store.DataStore#put(java.lang.Object,org.apache.gora.persistency.Persistent)
    */
   @Override
   public void put(K key, T value) {

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-cassandra/src/main/java/org/apache/gora/cassandra/store/HectorUtils.java
----------------------------------------------------------------------
diff --git a/gora-cassandra/src/main/java/org/apache/gora/cassandra/store/HectorUtils.java b/gora-cassandra/src/main/java/org/apache/gora/cassandra/store/HectorUtils.java
index 0c20cf7..3f33202 100644
--- a/gora-cassandra/src/main/java/org/apache/gora/cassandra/store/HectorUtils.java
+++ b/gora-cassandra/src/main/java/org/apache/gora/cassandra/store/HectorUtils.java
@@ -34,7 +34,7 @@ import org.apache.gora.persistency.Persistent;
 /**
  * This class it not thread safe.
  * According to Hector's JavaDoc a Mutator isn't thread safe, too.
- * Take a look at {@CassandraClient} for safe usage.
+ * @see CassandraClient for safe usage.
  */
 public class HectorUtils<K,T extends Persistent> {
 

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-compiler/src/main/java/org/apache/gora/compiler/GoraCompiler.java
----------------------------------------------------------------------
diff --git a/gora-compiler/src/main/java/org/apache/gora/compiler/GoraCompiler.java b/gora-compiler/src/main/java/org/apache/gora/compiler/GoraCompiler.java
index 2f0d02d..529f1ef 100644
--- a/gora-compiler/src/main/java/org/apache/gora/compiler/GoraCompiler.java
+++ b/gora-compiler/src/main/java/org/apache/gora/compiler/GoraCompiler.java
@@ -142,7 +142,12 @@ public class GoraCompiler extends SpecificCompiler {
     }
   }
 
-  /** Recognizes camel case */
+  /**
+   * Recognizes camel case
+   *
+   * @param s converts the given input string to camel case
+   * @return the converted camel case string
+   */
   public static String toUpperCase(String s) {
     StringBuilder builder = new StringBuilder();
 

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-core/src/main/java/org/apache/gora/avro/mapreduce/FsInput.java
----------------------------------------------------------------------
diff --git a/gora-core/src/main/java/org/apache/gora/avro/mapreduce/FsInput.java b/gora-core/src/main/java/org/apache/gora/avro/mapreduce/FsInput.java
index 9d5eabf..bdd1ddf 100644
--- a/gora-core/src/main/java/org/apache/gora/avro/mapreduce/FsInput.java
+++ b/gora-core/src/main/java/org/apache/gora/avro/mapreduce/FsInput.java
@@ -36,7 +36,13 @@ public class FsInput implements Closeable, SeekableInput {
   private final FSDataInputStream stream;
   private final long len;
 
-  /** Construct given a path and a configuration. */
+  /**
+   * Construct given a path and a configuration.
+   *
+   * @param path a path on HDFS to construct
+   * @param conf a Hadoop {@link org.apache.hadoop.conf.Configuration} object
+   * @throws IOException if there is an error opening path, or obtaining a file status from the file system
+   */
   public FsInput(Path path, Configuration conf) throws IOException {
     this.stream = path.getFileSystem(conf).open(path);
     this.len = path.getFileSystem(conf).getFileStatus(path).getLen();

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-core/src/main/java/org/apache/gora/filter/Filter.java
----------------------------------------------------------------------
diff --git a/gora-core/src/main/java/org/apache/gora/filter/Filter.java b/gora-core/src/main/java/org/apache/gora/filter/Filter.java
index 92ef924..badaa61 100644
--- a/gora-core/src/main/java/org/apache/gora/filter/Filter.java
+++ b/gora-core/src/main/java/org/apache/gora/filter/Filter.java
@@ -24,18 +24,18 @@ import org.apache.hadoop.io.Writable;
  * Defines filtering (possibly including modification) of rows. By default
  * all filtering is done client side. (In generic Gora classes). Datastore
  * implementations can decide if they install remote filters, when possible.
- *  
+ *
  * @param <K>
  * @param <T>
  */
 public interface Filter<K, T extends Persistent> extends Writable{
-  
+
   /**
    * Filter the key and persistent. Modification is possible.
-   * 
+   *
    * @param key
    * @param persistent
-   * @return <code>true</code> if the row is filtered out (excluded), 
+   * @return <code>true</code> if the row is filtered out (excluded),
    * <code>false</code> otherwise.
    */
   public boolean filter(K key, T persistent);

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-core/src/main/java/org/apache/gora/filter/FilterList.java
----------------------------------------------------------------------
diff --git a/gora-core/src/main/java/org/apache/gora/filter/FilterList.java b/gora-core/src/main/java/org/apache/gora/filter/FilterList.java
index d327920..63ef656 100644
--- a/gora-core/src/main/java/org/apache/gora/filter/FilterList.java
+++ b/gora-core/src/main/java/org/apache/gora/filter/FilterList.java
@@ -30,7 +30,7 @@ import java.util.List;
 
 /**
  * {@link FilterList} enables us to utilize conditional operands
- * for advanced filtering within the construction and 
+ * for advanced filtering within the construction and
  * execution of Gora queries.
  *
  * @param <K>

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-core/src/main/java/org/apache/gora/filter/MapFieldValueFilter.java
----------------------------------------------------------------------
diff --git a/gora-core/src/main/java/org/apache/gora/filter/MapFieldValueFilter.java b/gora-core/src/main/java/org/apache/gora/filter/MapFieldValueFilter.java
index 0fa70a4..610d9d7 100644
--- a/gora-core/src/main/java/org/apache/gora/filter/MapFieldValueFilter.java
+++ b/gora-core/src/main/java/org/apache/gora/filter/MapFieldValueFilter.java
@@ -33,7 +33,7 @@ import java.util.Map;
 
 /**
  * A filter that checks for a single field in the persistent.
- * 
+ *
  * @param <K>
  * @param <T>
  */

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-core/src/main/java/org/apache/gora/mapreduce/GoraInputFormat.java
----------------------------------------------------------------------
diff --git a/gora-core/src/main/java/org/apache/gora/mapreduce/GoraInputFormat.java b/gora-core/src/main/java/org/apache/gora/mapreduce/GoraInputFormat.java
index 9c1a3c2..a082da9 100644
--- a/gora-core/src/main/java/org/apache/gora/mapreduce/GoraInputFormat.java
+++ b/gora-core/src/main/java/org/apache/gora/mapreduce/GoraInputFormat.java
@@ -48,9 +48,9 @@ import org.apache.hadoop.mapreduce.lib.input.FileSplit;
  * <p> The {@link InputSplit}s are prepared from the {@link PartitionQuery}s
  * obtained by calling {@link DataStore#getPartitions(Query)}.
  * <p>
- * Hadoop jobs can be either configured through static 
+ * Hadoop jobs can be either configured through static
  * <code>setInput()</code> methods, or from {@link GoraMapper}.
- * 
+ *
  * @see GoraMapper
  */
 public class GoraInputFormat<K, T extends PersistentBase>
@@ -127,9 +127,12 @@ public class GoraInputFormat<K, T extends PersistentBase>
 
   /**
    * Sets the input parameters for the job
-   * @param job the job to set the properties for
-   * @param query the query to get the inputs from
+   *
+   * @param job          the job to set the properties for
+   * @param query        the query to get the inputs from
    * @param reuseObjects whether to reuse objects in serialization
+   * @param <K1>
+   * @param <V1>
    * @throws IOException
    */
   public static <K1, V1 extends Persistent> void setInput(Job job
@@ -143,14 +146,17 @@ public class GoraInputFormat<K, T extends PersistentBase>
     job.setInputFormatClass(GoraInputFormat.class);
     GoraInputFormat.setQuery(job, query);
   }
-  
+
   /**
    * Sets the input parameters for the job
-   * @param job the job to set the properties for
+   *
+   * @param job            the job to set the properties for
    * @param dataStoreClass the datastore class
-   * @param inKeyClass Map input key class
-   * @param inValueClass Map input value class
-   * @param reuseObjects whether to reuse objects in serialization
+   * @param inKeyClass     Map input key class
+   * @param inValueClass   Map input value class
+   * @param reuseObjects   whether to reuse objects in serialization
+   * @param <K1>
+   * @param <V1>
    * @throws IOException
    */
   public static <K1, V1 extends Persistent> void setInput(

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-core/src/main/java/org/apache/gora/mapreduce/GoraMapper.java
----------------------------------------------------------------------
diff --git a/gora-core/src/main/java/org/apache/gora/mapreduce/GoraMapper.java b/gora-core/src/main/java/org/apache/gora/mapreduce/GoraMapper.java
index 8c62110..1a49c69 100644
--- a/gora-core/src/main/java/org/apache/gora/mapreduce/GoraMapper.java
+++ b/gora-core/src/main/java/org/apache/gora/mapreduce/GoraMapper.java
@@ -32,19 +32,25 @@ import org.apache.hadoop.mapreduce.Partitioner;
 public class GoraMapper<K1, V1 extends Persistent, K2, V2> extends Mapper<K1, V1, K2, V2> {
 
   /**
-   * Initializes the Mapper, and sets input parameters for the job. All of 
-   * the records in the dataStore are used as the input. If you want to 
+   * Initializes the Mapper, and sets input parameters for the job. All of
+   * the records in the dataStore are used as the input. If you want to
    * include a specific subset, use one of the overloaded methods which takes
    * query parameter.
-   * @param job the job to set the properties for
-   * @param dataStoreClass the datastore class
-   * @param inKeyClass Map input key class
-   * @param inValueClass Map input value class
-   * @param outKeyClass Map output key class
-   * @param outValueClass Map output value class
-   * @param mapperClass the mapper class extending GoraMapper
+   *
+   * @param job              the job to set the properties for
+   * @param dataStoreClass   the datastore class
+   * @param inKeyClass       Map input key class
+   * @param inValueClass     Map input value class
+   * @param outKeyClass      Map output key class
+   * @param outValueClass    Map output value class
+   * @param mapperClass      the mapper class extending GoraMapper
    * @param partitionerClass optional partitioner class
-   * @param reuseObjects whether to reuse objects in serialization
+   * @param reuseObjects     whether to reuse objects in serialization
+   * @param <K1>
+   * @param <V1>
+   * @param <K2>
+   * @param <V2>
+   * @throws IOException
    */
   @SuppressWarnings("rawtypes")
   public static <K1, V1 extends Persistent, K2, V2> void initMapperJob(
@@ -69,21 +75,27 @@ public class GoraMapper<K1, V1 extends Persistent, K2, V2> extends Mapper<K1, V1
       job.setPartitionerClass(partitionerClass);
     }
   }
-  
+
   /**
-   * Initializes the Mapper, and sets input parameters for the job. All of 
-   * the records in the dataStore are used as the input. If you want to 
+   * Initializes the Mapper, and sets input parameters for the job. All of
+   * the records in the dataStore are used as the input. If you want to
    * include a specific subset, use one of the overloaded methods which takes
    * query parameter.
-   * @param job the job to set the properties for
+   *
+   * @param job            the job to set the properties for
    * @param dataStoreClass the datastore class
-   * @param inKeyClass Map input key class
-   * @param inValueClass Map input value class
-   * @param outKeyClass Map output key class
-   * @param outValueClass Map output value class
-   * @param mapperClass the mapper class extending GoraMapper
-   * @param reuseObjects whether to reuse objects in serialization
-   */  
+   * @param inKeyClass     Map input key class
+   * @param inValueClass   Map input value class
+   * @param outKeyClass    Map output key class
+   * @param outValueClass  Map output value class
+   * @param mapperClass    the mapper class extending GoraMapper
+   * @param reuseObjects   whether to reuse objects in serialization
+   * @param <K1>
+   * @param <V1>
+   * @param <K2>
+   * @param <V2>
+   * @throws IOException
+   */
   @SuppressWarnings("rawtypes")
   public static <K1, V1 extends Persistent, K2, V2> void initMapperJob(
       Job job,
@@ -97,16 +109,22 @@ public class GoraMapper<K1, V1 extends Persistent, K2, V2> extends Mapper<K1, V1
     initMapperJob(job, dataStoreClass, inKeyClass, inValueClass, outKeyClass,
         outValueClass, mapperClass, null, reuseObjects);
   }
-  
+
   /**
    * Initializes the Mapper, and sets input parameters for the job
-   * @param job the job to set the properties for
-   * @param query the query to get the inputs from
-   * @param outKeyClass Map output key class
-   * @param outValueClass Map output value class
-   * @param mapperClass the mapper class extending GoraMapper
+   *
+   * @param job              the job to set the properties for
+   * @param query            the query to get the inputs from
+   * @param outKeyClass      Map output key class
+   * @param outValueClass    Map output value class
+   * @param mapperClass      the mapper class extending GoraMapper
    * @param partitionerClass optional partitioner class
-   * @param reuseObjects whether to reuse objects in serialization
+   * @param reuseObjects     whether to reuse objects in serialization
+   * @param <K1>
+   * @param <V1>
+   * @param <K2>
+   * @param <V2>
+   * @throws IOException
    */
   @SuppressWarnings("rawtypes")
   public static <K1, V1 extends Persistent, K2, V2> void initMapperJob(
@@ -131,12 +149,18 @@ public class GoraMapper<K1, V1 extends Persistent, K2, V2> extends Mapper<K1, V1
 
   /**
    * Initializes the Mapper, and sets input parameters for the job
-   * @param job the job to set the properties for
-   * @param dataStore the datastore as the input
-   * @param outKeyClass Map output key class
+   *
+   * @param job           the job to set the properties for
+   * @param dataStore     the datastore as the input
+   * @param outKeyClass   Map output key class
    * @param outValueClass Map output value class
-   * @param mapperClass the mapper class extending GoraMapper
-   * @param reuseObjects whether to reuse objects in serialization
+   * @param mapperClass   the mapper class extending GoraMapper
+   * @param reuseObjects  whether to reuse objects in serialization
+   * @param <K1>
+   * @param <V1>
+   * @param <K2>
+   * @param <V2>
+   * @throws IOException
    */
   @SuppressWarnings({ "rawtypes" })
   public static <K1, V1 extends Persistent, K2, V2> void initMapperJob(
@@ -149,15 +173,21 @@ public class GoraMapper<K1, V1 extends Persistent, K2, V2> extends Mapper<K1, V1
     initMapperJob(job, dataStore.newQuery(),
         outKeyClass, outValueClass, mapperClass, reuseObjects);
   }
-  
+
   /**
    * Initializes the Mapper, and sets input parameters for the job
-   * @param job the job to set the properties for
-   * @param query the query to get the inputs from
-   * @param outKeyClass Map output key class
+   *
+   * @param job           the job to set the properties for
+   * @param query         the query to get the inputs from
+   * @param outKeyClass   Map output key class
    * @param outValueClass Map output value class
-   * @param mapperClass the mapper class extending GoraMapper
-   * @param reuseObjects whether to reuse objects in serialization
+   * @param mapperClass   the mapper class extending GoraMapper
+   * @param reuseObjects  whether to reuse objects in serialization
+   * @param <K1>
+   * @param <V1>
+   * @param <K2>
+   * @param <V2>
+   * @throws IOException
    */
   @SuppressWarnings({ "rawtypes" })
   public static <K1, V1 extends Persistent, K2, V2> void initMapperJob(

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-core/src/main/java/org/apache/gora/mapreduce/GoraOutputFormat.java
----------------------------------------------------------------------
diff --git a/gora-core/src/main/java/org/apache/gora/mapreduce/GoraOutputFormat.java b/gora-core/src/main/java/org/apache/gora/mapreduce/GoraOutputFormat.java
index 2cb536c..e4792e3 100644
--- a/gora-core/src/main/java/org/apache/gora/mapreduce/GoraOutputFormat.java
+++ b/gora-core/src/main/java/org/apache/gora/mapreduce/GoraOutputFormat.java
@@ -95,9 +95,12 @@ public class GoraOutputFormat<K, T extends Persistent>
 
   /**
    * Sets the output parameters for the job
-   * @param job the job to set the properties for
-   * @param dataStore the datastore as the output
+   *
+   * @param job          the job to set the properties for
+   * @param dataStore    the datastore as the output
    * @param reuseObjects whether to reuse objects in serialization
+   * @param <K>
+   * @param <V>
    */
   public static <K, V extends Persistent> void setOutput(Job job,
       DataStore<K,V> dataStore, boolean reuseObjects) {
@@ -106,12 +109,15 @@ public class GoraOutputFormat<K, T extends Persistent>
   }
 
   /**
-   * Sets the output parameters for the job 
-   * @param job the job to set the properties for
-   * @param dataStoreClass the datastore class
-   * @param keyClass output key class
+   * Sets the output parameters for the job
+   *
+   * @param job             the job to set the properties for
+   * @param dataStoreClass  the datastore class
+   * @param keyClass        output key class
    * @param persistentClass output value class
-   * @param reuseObjects whether to reuse objects in serialization
+   * @param reuseObjects    whether to reuse objects in serialization
+   * @param <K>
+   * @param <V>
    */
   @SuppressWarnings("rawtypes")
   public static <K, V extends Persistent> void setOutput(Job job,

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-core/src/main/java/org/apache/gora/mapreduce/GoraReducer.java
----------------------------------------------------------------------
diff --git a/gora-core/src/main/java/org/apache/gora/mapreduce/GoraReducer.java b/gora-core/src/main/java/org/apache/gora/mapreduce/GoraReducer.java
index 6f2f146..627f799 100644
--- a/gora-core/src/main/java/org/apache/gora/mapreduce/GoraReducer.java
+++ b/gora-core/src/main/java/org/apache/gora/mapreduce/GoraReducer.java
@@ -27,15 +27,20 @@ import org.apache.hadoop.mapreduce.Reducer;
  */
 public class GoraReducer<K1, V1, K2, V2 extends Persistent>
   extends Reducer<K1, V1, K2, V2> {
- 
+
   /**
-   * Initializes the Reducer, and sets output parameters for the job. 
-   * @param job the job to set the properties for
-   * @param dataStoreClass the datastore class
-   * @param keyClass output key class
+   * Initializes the Reducer, and sets output parameters for the job.
+   *
+   * @param job             the job to set the properties for
+   * @param dataStoreClass  the datastore class
+   * @param keyClass        output key class
    * @param persistentClass output value class
-   * @param reducerClass the reducer class extending GoraReducer
-   * @param reuseObjects whether to reuse objects in serialization
+   * @param reducerClass    the reducer class extending GoraReducer
+   * @param reuseObjects    whether to reuse objects in serialization
+   * @param <K1>
+   * @param <V1>
+   * @param <K2>
+   * @param <V2>
    */
   public static <K1, V1, K2, V2 extends Persistent>
   void initReducerJob(
@@ -50,12 +55,17 @@ public class GoraReducer<K1, V1, K2, V2 extends Persistent>
     
     job.setReducerClass(reducerClass);
   }
-  
+
   /**
-   * Initializes the Reducer, and sets output parameters for the job. 
-   * @param job the job to set the properties for
-   * @param dataStore the datastore as the output
-   * @param reducerClass the reducer class extending GoraReducer
+   * Initializes the Reducer, and sets output parameters for the job.
+   *
+   * @param job          the job to set the properties for
+   * @param dataStore    the datastore as the output
+   * @param reducerClass the reducer class extending GoraReducer* @param reducerClass
+   * @param <K1>
+   * @param <V1>
+   * @param <K2>
+   * @param <V2>
    */
   public static <K1, V1, K2, V2 extends Persistent>
   void initReducerJob(
@@ -67,11 +77,16 @@ public class GoraReducer<K1, V1, K2, V2 extends Persistent>
   }
 
   /**
-   * Initializes the Reducer, and sets output parameters for the job. 
-   * @param job the job to set the properties for
-   * @param dataStore the datastore as the output
+   * Initializes the Reducer, and sets output parameters for the job.
+   *
+   * @param job          the job to set the properties for
+   * @param dataStore    the datastore as the output
    * @param reducerClass the reducer class extending GoraReducer
    * @param reuseObjects whether to reuse objects in serialization
+   * @param <K1>
+   * @param <V1>
+   * @param <K2>
+   * @param <V2>
    */
   public static <K1, V1, K2, V2 extends Persistent>
   void initReducerJob(

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-core/src/main/java/org/apache/gora/mapreduce/PersistentSerializer.java
----------------------------------------------------------------------
diff --git a/gora-core/src/main/java/org/apache/gora/mapreduce/PersistentSerializer.java b/gora-core/src/main/java/org/apache/gora/mapreduce/PersistentSerializer.java
index b63de09..b75d1dd 100644
--- a/gora-core/src/main/java/org/apache/gora/mapreduce/PersistentSerializer.java
+++ b/gora-core/src/main/java/org/apache/gora/mapreduce/PersistentSerializer.java
@@ -55,7 +55,10 @@ public class PersistentSerializer implements Serializer<PersistentBase> {
   }
 
   /**
-   * Do the serialization of the {@link Persistent} object
+   * Do the serialization of the {@link PersistentBase} object
+   *
+   * @param persistent
+   * @throws IOException
    */
   @Override
   public void serialize(PersistentBase persistent) throws IOException {

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-core/src/main/java/org/apache/gora/persistency/BeanFactory.java
----------------------------------------------------------------------
diff --git a/gora-core/src/main/java/org/apache/gora/persistency/BeanFactory.java b/gora-core/src/main/java/org/apache/gora/persistency/BeanFactory.java
index 2e7da32..a2dff8c 100644
--- a/gora-core/src/main/java/org/apache/gora/persistency/BeanFactory.java
+++ b/gora-core/src/main/java/org/apache/gora/persistency/BeanFactory.java
@@ -19,48 +19,58 @@
 package org.apache.gora.persistency;
 
 /**
- * BeanFactory's enable contruction of keys and Persistent objects. 
+ * BeanFactory's enable contruction of keys and Persistent objects.
+ *
+ * @param <K>
+ * @param <T>
  */
 public interface BeanFactory<K, T>{
 
   /**
    * Constructs a new instance of the key class
+   *
    * @return a new instance of the key class
+   * @throws Exception
    */
   K newKey() throws Exception;
 
   /**
    * Constructs a new instance of the Persistent class
+   *
    * @return a new instance of the Persistent class
    */
   T newPersistent();
 
   /**
-   * Returns an instance of the key object to be 
-   * used to access static fields of the object. Returned object MUST  
-   * be treated as read-only. No fields other than the static fields 
-   * of the object should be assumed to be readable. 
+   * Returns an instance of the key object to be
+   * used to access static fields of the object. Returned object MUST
+   * be treated as read-only. No fields other than the static fields
+   * of the object should be assumed to be readable.
+   *
    * @return a cached instance of the key object
    */
   K getCachedKey();
-  
+
   /**
-   * Returns an instance of the {@link Persistent} object to be 
-   * used to access static fields of the object. Returned object MUST  
-   * be treated as read-only. No fields other than the static fields 
-   * of the object should be assumed to be readable. 
+   * Returns an instance of the {@link Persistent} object to be
+   * used to access static fields of the object. Returned object MUST
+   * be treated as read-only. No fields other than the static fields
+   * of the object should be assumed to be readable.
+   *
    * @return a cached instance of the Persistent object
    */
   T getCachedPersistent();
 
   /**
    * Returns the key class
+   *
    * @return the key class
    */
   Class<K> getKeyClass();
 
   /**
    * Returns the persistent class
+   *
    * @return the persistent class
    */
   Class<T> getPersistentClass();

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-core/src/main/java/org/apache/gora/persistency/impl/BeanFactoryImpl.java
----------------------------------------------------------------------
diff --git a/gora-core/src/main/java/org/apache/gora/persistency/impl/BeanFactoryImpl.java b/gora-core/src/main/java/org/apache/gora/persistency/impl/BeanFactoryImpl.java
index 9507cc7..445f58e 100644
--- a/gora-core/src/main/java/org/apache/gora/persistency/impl/BeanFactoryImpl.java
+++ b/gora-core/src/main/java/org/apache/gora/persistency/impl/BeanFactoryImpl.java
@@ -25,9 +25,11 @@ import org.apache.gora.persistency.Persistent;
 import org.apache.gora.util.ReflectionUtils;
 
 /**
- * A default implementation of the {@link BeanFactory} interface. Constructs 
- * the keys using by reflection, {@link Persistent} objects by calling 
- * {@link Persistent#newInstance(org.apache.gora.persistency.StateManager)}. 
+ * A default implementation of the {@link BeanFactory} interface. Constructs
+ * the keys using by reflection, {@link Persistent} objects by calling
+ *
+ * @param <K>
+ * @param <T>
  */
 public class BeanFactoryImpl<K, T extends Persistent> implements BeanFactory<K, T> {
 
@@ -48,10 +50,11 @@ public class BeanFactoryImpl<K, T extends Persistent> implements BeanFactory<K,
   
   /** Flag to be used to determine if a key is persistent or not */
   private boolean isKeyPersistent = false;
-  
+
   /**
    * Default constructor for this class.
-   * @param keyClass.
+   *
+   * @param keyClass
    * @param persistentClass
    */
   public BeanFactoryImpl(Class<K> keyClass, Class<T> persistentClass) {

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-core/src/main/java/org/apache/gora/persistency/ws/impl/BeanFactoryWSImpl.java
----------------------------------------------------------------------
diff --git a/gora-core/src/main/java/org/apache/gora/persistency/ws/impl/BeanFactoryWSImpl.java b/gora-core/src/main/java/org/apache/gora/persistency/ws/impl/BeanFactoryWSImpl.java
index ccb8971..c106829 100644
--- a/gora-core/src/main/java/org/apache/gora/persistency/ws/impl/BeanFactoryWSImpl.java
+++ b/gora-core/src/main/java/org/apache/gora/persistency/ws/impl/BeanFactoryWSImpl.java
@@ -29,8 +29,10 @@ import org.slf4j.LoggerFactory;
 
 /**
  * A default implementation of the {@link BeanFactory} interface. Constructs 
- * the keys using by reflection, {@link Persistent} objects by calling 
- * {@link Persistent#newInstance(org.apache.gora.persistency.StateManager)}. 
+ * the keys using by reflection, {@link Persistent} objects by calling
+ *
+ * @param <K>
+ * @param <T>
  */
 public class BeanFactoryWSImpl<K, T extends Persistent> implements BeanFactory<K, T> {
 
@@ -65,9 +67,10 @@ public class BeanFactoryWSImpl<K, T extends Persistent> implements BeanFactory<K
    * Flag to be used to determine if a key is persistent or not
    */
   private boolean isKeyPersistent = false;
-  
+
   /**
    * Constructor
+   *
    * @param keyClass
    * @param persistentClass
    */

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-core/src/main/java/org/apache/gora/query/Query.java
----------------------------------------------------------------------
diff --git a/gora-core/src/main/java/org/apache/gora/query/Query.java b/gora-core/src/main/java/org/apache/gora/query/Query.java
index d783840..4001f65 100644
--- a/gora-core/src/main/java/org/apache/gora/query/Query.java
+++ b/gora-core/src/main/java/org/apache/gora/query/Query.java
@@ -70,25 +70,26 @@ public interface Query<K, T extends Persistent> {
   void setFields(String... fieldNames);
 
   String[] getFields();
-  
+
   /**
-   * @param Set a filter on this query.
+   * @param filter Set a filter on this query.
    */
   public void setFilter(Filter<K, T> filter);
-  
+
   /**
    * @return The filter on this query, or <code>null</code> if none.
    */
   public Filter<K, T> getFilter();
-  
+
   /**
    * Set whether the local filter is enabled. This is usually called by
    * data store implementations that install the filter remotely
    * (for efficiency reasons) and therefore disable the local filter.
-   * @param enable
+   *
+   * @param enable true to enable local {@link org.apache.gora.filter.Filter}
    */
   void setLocalFilterEnabled(boolean enable);
-  
+
   /**
    * @return Whether the local filter is enabled.
    * See {@link #setLocalFilterEnabled(boolean)}.
@@ -99,26 +100,20 @@ public interface Query<K, T extends Persistent> {
   void setKey(K key);
 
   /**
-   * 
-   * @param startKey
-   *          an inclusive start key
+   * @param startKey an inclusive start key
    */
   void setStartKey(K startKey);
 
   /**
-   * 
-   * @param endKey
-   *          an inclusive end key
+   * @param endKey an inclusive end key
    */
   void setEndKey(K endKey);
 
   /**
    * Set the range of keys over which the query will execute.
-   * 
-   * @param startKey
-   *          an inclusive start key
-   * @param endKey
-   *          an inclusive end key
+   *
+   * @param startKey an inclusive start key
+   * @param endKey   an inclusive end key
    */
   void setKeyRange(K startKey, K endKey);
 
@@ -142,14 +137,17 @@ public interface Query<K, T extends Persistent> {
   long getStartTime();
 
   long getEndTime();
-  
+
   /**
    * Sets the maximum number of results to return.
+   *
+   * @param limit long value for the limit permitted for a given query
    */
   void setLimit(long limit);
 
   /**
    * Returns the maximum number of results
+   *
    * @return the limit if it is set, otherwise a negative number
    */
   long getLimit();

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-core/src/main/java/org/apache/gora/query/Result.java
----------------------------------------------------------------------
diff --git a/gora-core/src/main/java/org/apache/gora/query/Result.java b/gora-core/src/main/java/org/apache/gora/query/Result.java
index 946360a..3a7bffe 100644
--- a/gora-core/src/main/java/org/apache/gora/query/Result.java
+++ b/gora-core/src/main/java/org/apache/gora/query/Result.java
@@ -41,45 +41,56 @@ public interface Result<K, T extends Persistent> {
    * @return the Query object for this Result.
    */
   Query<K, T> getQuery();
-  
+
   /**
    * Advances to the next element and returns false if at end.
+   *
    * @return true if end is not reached yet
+   * @throws Exception if an error is encountered whilst advancing to next result
    */
   boolean next() throws Exception;
-  
+
   /**
    * Returns the current key.
+   *
    * @return current key
    */
   K getKey();
-  
+
   /**
    * Returns the current object.
+   *
    * @return current object
    */
   T get();
-  
+
   /**
    * Returns the class of the keys
+   *
    * @return class of the keys
    */
   Class<K> getKeyClass();
-    
+
   /**
    * Returns the class of the persistent objects
+   *
    * @return class of the persistent objects
    */
   Class<T> getPersistentClass();
-  
+
   /**
    * Returns the number of times next() is called with return value true.
+   *
    * @return the number of results so far
    */
   long getOffset();
-  
+
   /**
    * Returns how far along the result has iterated, a value between 0 and 1.
+   *
+   * @return a float value representing progress of the job
+   * @throws IOException          if there is an erro obtaining progress
+   * @throws InterruptedException if progress stalls or is interrupted
    */
   float getProgress() throws IOException, InterruptedException;
 

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-core/src/main/java/org/apache/gora/query/impl/ResultBase.java
----------------------------------------------------------------------
diff --git a/gora-core/src/main/java/org/apache/gora/query/impl/ResultBase.java b/gora-core/src/main/java/org/apache/gora/query/impl/ResultBase.java
index 548739c..56d7e84 100644
--- a/gora-core/src/main/java/org/apache/gora/query/impl/ResultBase.java
+++ b/gora-core/src/main/java/org/apache/gora/query/impl/ResultBase.java
@@ -30,65 +30,66 @@ import java.io.IOException;
  * Base class for {@link Result} implementations.
  */
 public abstract class ResultBase<K, T extends Persistent> 
-  implements Result<K, T> {
+implements Result<K, T> {
 
   protected final DataStore<K,T> dataStore;
-  
+
   protected final Query<K, T> query;
-  
+
   protected K key;
-  
+
   protected T persistent;
-  
+
   /** Query limit */
   protected long limit;
-  
+
   /** How far we have proceeded*/
   protected long offset = 0;
-  
+
   public ResultBase(DataStore<K,T> dataStore, Query<K,T> query) {
     this.dataStore = dataStore;
     this.query = query;
     this.limit = query.getLimit();
   }
-  
+
   @Override
   public DataStore<K, T> getDataStore() {
     return dataStore;
   }
-  
+
   @Override
   public Query<K, T> getQuery() {
     return query;
   }
-  
+
   @Override
   public T get() {
     return persistent;
   }
-  
+
   @Override
   public K getKey() {
     return key;
   }
-    
+
   @Override
   public Class<K> getKeyClass() {
     return getDataStore().getKeyClass();
   }
-  
+
   @Override
   public Class<T> getPersistentClass() {
     return getDataStore().getPersistentClass();
   }
-  
+
   /**
-   * Returns whether the limit for the query is reached. 
+   * Returns whether the limit for the query is reached.
+   * @return true if result limit is reached
    */
   protected boolean isLimitReached() {
     return limit > 0 && offset >= limit;
   }
-  
+
   protected void clear() {
     if(persistent != null) {
       persistent.clear();
@@ -97,13 +98,13 @@ public abstract class ResultBase<K, T extends Persistent>
       ((Persistent)key).clear();
     }
   }
-  
+
   @Override
   public final boolean next() throws Exception {
     if(isLimitReached()) {
       return false;
     }
-      
+
     boolean ret;
     do {
       clear();
@@ -115,42 +116,44 @@ public abstract class ResultBase<K, T extends Persistent>
       }
       //we keep looping until we get a row that is not filtered out
     } while (filter(key, persistent));
-    
+
     if(ret) ++offset;
     return ret;
   }
-  
+
   protected boolean filter(K key, T persistent) {
     if (!query.isLocalFilterEnabled()) {
       return false;
     }
-    
+
     Filter<K, T> filter = query.getFilter();
     if (filter == null) {
       return false;
     }
-    
+
     return filter.filter(key, persistent);
   }
-  
+
   @Override
   public long getOffset() {
     return offset;
   }
-  
+
   /**
    * {@link ResultBase#next()} calls this function to read the 
-   * actual results. 
+   * actual results.
+   * @return true if another result exists
+   * @throws IOException if for some reason we reach a result which does not exist
    */
   protected abstract boolean nextInner() throws IOException; 
-  
+
   protected T getOrCreatePersistent(T persistent) throws Exception {
-	  if(persistent != null) {
-			return persistent;
-		}
-		return dataStore.newPersistent();
+    if(persistent != null) {
+      return persistent;
+    }
+    return dataStore.newPersistent();
   }
-  
+
   @Override
   public void close() throws IOException{
   }

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-core/src/main/java/org/apache/gora/spark/GoraSparkEngine.java
----------------------------------------------------------------------
diff --git a/gora-core/src/main/java/org/apache/gora/spark/GoraSparkEngine.java b/gora-core/src/main/java/org/apache/gora/spark/GoraSparkEngine.java
index add4e14..48490b0 100644
--- a/gora-core/src/main/java/org/apache/gora/spark/GoraSparkEngine.java
+++ b/gora-core/src/main/java/org/apache/gora/spark/GoraSparkEngine.java
@@ -96,10 +96,15 @@ public class GoraSparkEngine<K, V extends Persistent> {
     return initialize(sparkContext, hadoopConf, dataStore);
   }
 
-    /**
-     * Creates a job and sets the output parameters for the conf that Spark will use
-     * @param dataStore the datastore as the output
-     */
+  /**
+   * Creates a job and sets the output parameters for the conf that Spark will use
+   *
+   * @param dataStore the datastore as the output
+   * @param <K>
+   * @param <V>
+   * @return
+   * @throws IOException
+   */
     public <K, V extends Persistent> Configuration generateOutputConf(DataStore<K, V> dataStore)
        throws IOException {
 
@@ -111,25 +116,32 @@ public class GoraSparkEngine<K, V extends Persistent> {
            dataStore.getPersistentClass());
     }
 
-    /**
-     * Sets the output parameters for the conf that Spark will use
-     * @param job the job to set the properties for
-     * @param dataStore the datastore as the output
-     */
+  /**
+   * Sets the output parameters for the conf that Spark will use
+   *
+   * @param job the job to set the properties for
+   * @param dataStore the datastore as the output
+   * @param <K>
+   * @param <V>
+   * @return
+   */
     public <K, V extends Persistent> Configuration generateOutputConf(Job job,
         DataStore<K, V> dataStore) {
       return generateOutputConf(job, dataStore.getClass(), dataStore.getKeyClass(),
               dataStore.getPersistentClass());
     }
 
-    /**
-     * Sets the output parameters for the conf that Spark will use
-     *
-     * @param job             the job to set the properties for
-     * @param dataStoreClass  the datastore class
-     * @param keyClass        output key class
-     * @param persistentClass output value class
-     */
+  /**
+   * Sets the output parameters for the conf that Spark will use
+   *
+   * @param job             the job to set the properties for
+   * @param dataStoreClass  the datastore class
+   * @param keyClass        output key class
+   * @param persistentClass output value class
+   * @param <K>
+   * @param <V>
+   * @return
+   */
     @SuppressWarnings("rawtypes")
     public <K, V extends Persistent> Configuration generateOutputConf(Job job,
         Class<? extends DataStore> dataStoreClass,

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-core/src/main/java/org/apache/gora/store/DataStore.java
----------------------------------------------------------------------
diff --git a/gora-core/src/main/java/org/apache/gora/store/DataStore.java b/gora-core/src/main/java/org/apache/gora/store/DataStore.java
index e3b5411..ace39b8 100644
--- a/gora-core/src/main/java/org/apache/gora/store/DataStore.java
+++ b/gora-core/src/main/java/org/apache/gora/store/DataStore.java
@@ -32,13 +32,15 @@ import org.apache.gora.query.Result;
  * fetched, queried or deleted by the DataStore methods. DataStores can be
  * constructed by an instance of {@link DataStoreFactory}.
  *
- * <p> DataStores implementations should be thread safe.
- * <p><a name="visibility"><b>Note:</b> Results of updates ({@link #put(Object, Persistent)},
+ * <p> DataStores implementations should be thread safe.</p>
+ * <p><a name="visibility"><b>Note:</b></a> Results of updates ({@link #put(Object, Persistent)},
  * {@link #delete(Object)} and {@link #deleteByQuery(Query)} operations) are
  * guaranteed to be visible to subsequent get / execute operations ONLY
  * after a subsequent call to {@link #flush()}. Additionally, exception
  * handling is largely DataStore specific and is not largely dealt
  * with from within this interface.
+ * </p>
+ *
  * @param <K> the class of keys in the datastore
  * @param <T> the class of persistent objects in the datastore
  */
@@ -144,6 +146,9 @@ public interface DataStore<K, T extends Persistent> {
    * object with the same key already exists it will silently
    * be replaced. See also the note on 
    * <a href="#visibility">visibility</a>.
+   *
+   * @param key
+   * @param obj
    */
   void put(K key, T obj);
 
@@ -181,6 +186,8 @@ public interface DataStore<K, T extends Persistent> {
    * @param query the base query to create the partitions for. If the query
    * is null, then the data store returns the partitions for the default query
    * (returning every object)
+   *
+   * @param query
    * @return a List of PartitionQuery's
    * @throws IOException 
    */

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-core/src/main/java/org/apache/gora/store/impl/DataStoreBase.java
----------------------------------------------------------------------
diff --git a/gora-core/src/main/java/org/apache/gora/store/impl/DataStoreBase.java b/gora-core/src/main/java/org/apache/gora/store/impl/DataStoreBase.java
index 3b18532..4fe339d 100644
--- a/gora-core/src/main/java/org/apache/gora/store/impl/DataStoreBase.java
+++ b/gora-core/src/main/java/org/apache/gora/store/impl/DataStoreBase.java
@@ -160,6 +160,9 @@ public abstract class DataStoreBase<K, T extends PersistentBase>
    * Checks whether the fields argument is null, and if so
    * returns all the fields of the Persistent object, else returns the
    * argument.
+   *
+   * @param fields
+   * @return String array
    */
   protected String[] getFieldsToQuery(String[] fields) {
     if(fields != null) {
@@ -253,8 +256,10 @@ public abstract class DataStoreBase<K, T extends PersistentBase>
    * the schema name in the defined properties is returned. If null then
    * the provided mappingSchemaName is returned. If this is null too,
    * the class name, without the package, of the persistent class is returned.
+   *
    * @param mappingSchemaName the name of the schema as read from the mapping file
    * @param persistentClass persistent class
+   * @return String
    */
   protected String getSchemaName(String mappingSchemaName, Class<?> persistentClass) {
     String confSchemaName = getOrCreateConf().get("preferred.schema.name");

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-core/src/main/java/org/apache/gora/store/impl/FileBackedDataStoreBase.java
----------------------------------------------------------------------
diff --git a/gora-core/src/main/java/org/apache/gora/store/impl/FileBackedDataStoreBase.java b/gora-core/src/main/java/org/apache/gora/store/impl/FileBackedDataStoreBase.java
index c559243..23ce9fa 100644
--- a/gora-core/src/main/java/org/apache/gora/store/impl/FileBackedDataStoreBase.java
+++ b/gora-core/src/main/java/org/apache/gora/store/impl/FileBackedDataStoreBase.java
@@ -116,7 +116,11 @@ public InputStream getInputStream() {
     return outputStream;
   }
 
-  /** Opens an InputStream for the input Hadoop path */
+  /** Opens an InputStream for the input Hadoop path
+   *
+   * @return
+   * @throws IOException
+   */
   protected InputStream createInputStream() throws IOException {
     //TODO: if input path is a directory, use smt like MultiInputStream to
     //read all the files recursively
@@ -126,7 +130,10 @@ public InputStream getInputStream() {
     return fs.open(path);
   }
 
-  /** Opens an OutputStream for the output Hadoop path */
+  /** Opens an OutputStream for the output Hadoop path
+   *
+   * @return
+   */
   protected OutputStream createOutputStream() {
     OutputStream conf = null;
     try{
@@ -192,12 +199,20 @@ public InputStream getInputStream() {
   /**
    * Executes a normal Query reading the whole data. #execute() calls this function
    * for non-PartitionQuery's.
+   *
+   * @param query
+   * @return
+   * @throws IOException
    */
   protected abstract Result<K,T> executeQuery(Query<K,T> query)
     throws IOException;
 
   /**
    * Executes a PartitialQuery, reading the data between start and end.
+   *
+   * @param query
+   * @return
+   * @throws IOException
    */
   protected abstract Result<K,T> executePartial(FileSplitPartitionQuery<K,T> query)
     throws IOException;

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-core/src/main/java/org/apache/gora/util/AvroUtils.java
----------------------------------------------------------------------
diff --git a/gora-core/src/main/java/org/apache/gora/util/AvroUtils.java b/gora-core/src/main/java/org/apache/gora/util/AvroUtils.java
index 36b076e..690cbd0 100644
--- a/gora-core/src/main/java/org/apache/gora/util/AvroUtils.java
+++ b/gora-core/src/main/java/org/apache/gora/util/AvroUtils.java
@@ -86,9 +86,8 @@ public class AvroUtils {
 
   /**
    * Return the field names from a schema object
-   * 
-   * @param persistent
-   *          the persistent object to get the fields names from
+   *
+   * @param schema the schema object to get the fields names from
    * @return the field names
    */
   public static String[] getSchemaFieldNames(Schema schema) {

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-core/src/main/java/org/apache/gora/util/ByteUtils.java
----------------------------------------------------------------------
diff --git a/gora-core/src/main/java/org/apache/gora/util/ByteUtils.java b/gora-core/src/main/java/org/apache/gora/util/ByteUtils.java
index 53aea95..933f33d 100644
--- a/gora-core/src/main/java/org/apache/gora/util/ByteUtils.java
+++ b/gora-core/src/main/java/org/apache/gora/util/ByteUtils.java
@@ -624,7 +624,7 @@ public class ByteUtils {
   /**
    * @param left
    * @param right
-   * @return 0 if equal, < 0 if left is less than right, etc.
+   * @return 0 if equal, {@literal <} 0 if left is less than right, etc.
    */
   public static int compareTo(final byte [] left, final byte [] right) {
     return compareTo(left, 0, left.length, right, 0, right.length);
@@ -637,7 +637,7 @@ public class ByteUtils {
    * @param s2 Where to start comparing in the right buffer
    * @param l1 How much to compare from the left buffer
    * @param l2 How much to compare from the right buffer
-   * @return 0 if equal, < 0 if left is less than right, etc.
+   * @return 0 if equal, {@literal <} 0 if left is less than right, etc.
    */
   public static int compareTo(byte[] b1, int s1, int l1,
       byte[] b2, int s2, int l2) {

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/compiler/GoraDynamoDBCompiler.java
----------------------------------------------------------------------
diff --git a/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/compiler/GoraDynamoDBCompiler.java b/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/compiler/GoraDynamoDBCompiler.java
index be38e36..6a0e51d 100644
--- a/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/compiler/GoraDynamoDBCompiler.java
+++ b/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/compiler/GoraDynamoDBCompiler.java
@@ -347,9 +347,8 @@ public class GoraDynamoDBCompiler {
 
   /**
    * Start point of the compiler program
-   * @param argsReceives 
-   *          the schema file to be compiled and where this should be written
-   * @throws Exception
+   *
+   * @param args the schema file to be compiled and where this should be written
    */
   public static void main(String[] args) {
     try {

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/query/DynamoDBQuery.java
----------------------------------------------------------------------
diff --git a/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/query/DynamoDBQuery.java b/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/query/DynamoDBQuery.java
index 699d051..1f49bd4 100644
--- a/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/query/DynamoDBQuery.java
+++ b/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/query/DynamoDBQuery.java
@@ -220,9 +220,6 @@ public class DynamoDBQuery<K, T extends Persistent> extends QueryWSBase<K, T> {
 
   /**
    * Builds scan query expression using a hash attribute value where to start
-   * 
-   * @param pHashAttrValueHash
-   *          attribute value where to start scanning
    */
   public void buildScanExpression() {
     K qKey = getKey();

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/store/DynamoDBAvroStore.java
----------------------------------------------------------------------
diff --git a/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/store/DynamoDBAvroStore.java b/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/store/DynamoDBAvroStore.java
index 98f64ae..bebd06c 100644
--- a/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/store/DynamoDBAvroStore.java
+++ b/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/store/DynamoDBAvroStore.java
@@ -47,9 +47,8 @@ DataStoreBase<K, T> implements IDynamoDB<K, T> {
 
   /**
    * Sets the handler to the main DynamoDB
-   * 
-   * @param DynamoDBStore
-   *          handler to main DynamoDB
+   *
+   * @param dynamoHandler handler to main DynamoDB
    */
   @Override
   public void setDynamoDBStoreHandler(DynamoDBStore<K, T> dynamoHandler) {

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/store/DynamoDBMapping.java
----------------------------------------------------------------------
diff --git a/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/store/DynamoDBMapping.java b/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/store/DynamoDBMapping.java
index 2db5fd8..67d9564 100644
--- a/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/store/DynamoDBMapping.java
+++ b/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/store/DynamoDBMapping.java
@@ -186,10 +186,10 @@ public class DynamoDBMapping {
 
     /**
      * Sets the hash key schema for the specified table
+     *
      * @param tableName
      * @param keyName
      * @param keyType
-     * @param keyType2
      */
     public void setKeySchema(String tableName, String keyName, String keyType) {
       ArrayList<KeySchemaElement> kSchema = tablesToKeySchemas.get(tableName);
@@ -245,11 +245,10 @@ public class DynamoDBMapping {
 
     /**
      * Adds an attribute to an specific item
-     * 
+     *
      * @param tableName
      * @param attributeName
      * @param attrType
-     * @param itemNumber
      */
     public void addAttribute(String tableName, String attributeName,
         String attrType) {

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/store/DynamoDBNativeStore.java
----------------------------------------------------------------------
diff --git a/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/store/DynamoDBNativeStore.java b/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/store/DynamoDBNativeStore.java
index 6fe1742..24beda5 100644
--- a/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/store/DynamoDBNativeStore.java
+++ b/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/store/DynamoDBNativeStore.java
@@ -59,8 +59,9 @@ public class DynamoDBNativeStore<K, T extends Persistent> extends
 
   /**
    * Deletes items using a specific query
-   * 
-   * @throws IOException
+   *
+   * @param query matching records to this query will be deleted
+   * @return
    */
   @Override
   @SuppressWarnings("unchecked")
@@ -181,8 +182,8 @@ public class DynamoDBNativeStore<K, T extends Persistent> extends
 
   /**
    * Returns a new instance of the key object.
-   * 
-   * @throws IOException
+   *
+   * @return
    */
   @Override
   public K newKey() {
@@ -192,8 +193,8 @@ public class DynamoDBNativeStore<K, T extends Persistent> extends
 
   /**
    * Returns a new persistent object
-   * 
-   * @throws IOException
+   *
+   * @return
    */
   @Override
   public T newPersistent() {
@@ -212,8 +213,9 @@ public class DynamoDBNativeStore<K, T extends Persistent> extends
 
   /**
    * Puts an object identified by a key
-   * 
-   * @throws IOException
+   *
+   * @param key
+   * @param obj
    */
   @Override
   public void put(K key, T obj) {
@@ -242,9 +244,9 @@ public class DynamoDBNativeStore<K, T extends Persistent> extends
 
   /**
    * Deletes the object using key
-   * 
+   *
+   * @param key the key of the object
    * @return true for a successful process
-   * @throws IOException
    */
   @Override
   public boolean delete(K key) {

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/store/DynamoDBStore.java
----------------------------------------------------------------------
diff --git a/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/store/DynamoDBStore.java b/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/store/DynamoDBStore.java
index 8fbf68c..1cb75ed 100644
--- a/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/store/DynamoDBStore.java
+++ b/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/store/DynamoDBStore.java
@@ -105,7 +105,6 @@ public class DynamoDBStore<K, T extends Persistent> implements DataStore<K, T> {
   /**
    * Creates the table within the data store for a preferred schema or for a
    * group of schemas defined within the mapping file
-   * @throws IOException
    */
   @Override
   public void createSchema() {
@@ -237,12 +236,10 @@ public class DynamoDBStore<K, T extends Persistent> implements DataStore<K, T> {
     dynamoDbStore.put(key, value);
   }
 
-
-
   /**
    * Verifies if the specified schemas exist
-   * 
-   * @throws IOException
+   *
+   * @return
    */
   @Override
   public boolean schemaExists() {
@@ -356,7 +353,7 @@ public class DynamoDBStore<K, T extends Persistent> implements DataStore<K, T> {
   /**
    * Executes a delete table request using the DynamoDB client
    * 
-   * @param tableName
+   * @param pTableName
    */
   public void executeDeleteTableRequest(String pTableName) {
     try {

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/store/DynamoDBUtils.java
----------------------------------------------------------------------
diff --git a/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/store/DynamoDBUtils.java b/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/store/DynamoDBUtils.java
index 4fdf5f9..d797678 100644
--- a/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/store/DynamoDBUtils.java
+++ b/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/store/DynamoDBUtils.java
@@ -122,11 +122,9 @@ public class DynamoDBUtils {
 
   /**
    * Creates the AWSCredentials object based on the properties file.
-   * 
-   * @param awsCredentialsProperties
-   * @throws FileNotFoundException
-   * @throws IllegalArgumentException
-   * @throws IOException
+   *
+   * @param clazz
+   * @return
    */
   public static PropertiesCredentials getCredentials(Class<?> clazz) {
     PropertiesCredentials awsCredentials = null;

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/store/IDynamoDB.java
----------------------------------------------------------------------
diff --git a/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/store/IDynamoDB.java b/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/store/IDynamoDB.java
index 7aaf02f..4407bc7 100644
--- a/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/store/IDynamoDB.java
+++ b/gora-dynamodb/src/main/java/org/apache/gora/dynamodb/store/IDynamoDB.java
@@ -24,7 +24,8 @@ public interface IDynamoDB<K, T extends Persistent> extends DataStore<K, T> {
 
   /**
    * Sets the handler to the main DynamoDB
-   * @param DynamoDBStore handler to main DynamoDB
+   *
+   * @param dynamoHandler handler to main DynamoDB
    */
   public abstract void setDynamoDBStoreHandler(DynamoDBStore<K, T> dynamoHandler);
 

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-goraci/src/main/java/org/apache/gora/goraci/generated/CINode.java
----------------------------------------------------------------------
diff --git a/gora-goraci/src/main/java/org/apache/gora/goraci/generated/CINode.java b/gora-goraci/src/main/java/org/apache/gora/goraci/generated/CINode.java
index 3773929..da02248 100644
--- a/gora-goraci/src/main/java/org/apache/gora/goraci/generated/CINode.java
+++ b/gora-goraci/src/main/java/org/apache/gora/goraci/generated/CINode.java
@@ -107,7 +107,6 @@ public class CINode extends org.apache.gora.persistency.impl.PersistentBase impl
   
   /**
    * Checks the dirty status of the 'prev' field. A field is dirty if it represents a change that has not yet been written to the database.
-   * @param value the value to set.
    */
   public boolean isPrevDirty() {
     return isDirty(0);
@@ -131,7 +130,6 @@ public class CINode extends org.apache.gora.persistency.impl.PersistentBase impl
   
   /**
    * Checks the dirty status of the 'client' field. A field is dirty if it represents a change that has not yet been written to the database.
-   * @param value the value to set.
    */
   public boolean isClientDirty() {
     return isDirty(1);
@@ -155,7 +153,6 @@ public class CINode extends org.apache.gora.persistency.impl.PersistentBase impl
   
   /**
    * Checks the dirty status of the 'count' field. A field is dirty if it represents a change that has not yet been written to the database.
-   * @param value the value to set.
    */
   public boolean isCountDirty() {
     return isDirty(2);
@@ -354,7 +351,6 @@ public class CINode extends org.apache.gora.persistency.impl.PersistentBase impl
 	  
 	  /**
 	   * Checks the dirty status of the 'prev' field. A field is dirty if it represents a change that has not yet been written to the database.
-		   * @param value the value to set.
 	   */
 	  public boolean isPrevDirty() {
 	    throw new java.lang.UnsupportedOperationException("IsDirty is not supported on tombstones");
@@ -377,7 +373,6 @@ public class CINode extends org.apache.gora.persistency.impl.PersistentBase impl
 	  
 	  /**
 	   * Checks the dirty status of the 'client' field. A field is dirty if it represents a change that has not yet been written to the database.
-		   * @param value the value to set.
 	   */
 	  public boolean isClientDirty() {
 	    throw new java.lang.UnsupportedOperationException("IsDirty is not supported on tombstones");
@@ -400,7 +395,6 @@ public class CINode extends org.apache.gora.persistency.impl.PersistentBase impl
 	  
 	  /**
 	   * Checks the dirty status of the 'count' field. A field is dirty if it represents a change that has not yet been written to the database.
-		   * @param value the value to set.
 	   */
 	  public boolean isCountDirty() {
 	    throw new java.lang.UnsupportedOperationException("IsDirty is not supported on tombstones");

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-goraci/src/main/java/org/apache/gora/goraci/generated/Flushed.java
----------------------------------------------------------------------
diff --git a/gora-goraci/src/main/java/org/apache/gora/goraci/generated/Flushed.java b/gora-goraci/src/main/java/org/apache/gora/goraci/generated/Flushed.java
index 7c3a85d..0fd140c 100644
--- a/gora-goraci/src/main/java/org/apache/gora/goraci/generated/Flushed.java
+++ b/gora-goraci/src/main/java/org/apache/gora/goraci/generated/Flushed.java
@@ -97,7 +97,6 @@ public class Flushed extends org.apache.gora.persistency.impl.PersistentBase imp
   
   /**
    * Checks the dirty status of the 'count' field. A field is dirty if it represents a change that has not yet been written to the database.
-   * @param value the value to set.
    */
   public boolean isCountDirty() {
     return isDirty(0);
@@ -235,7 +234,6 @@ public class Flushed extends org.apache.gora.persistency.impl.PersistentBase imp
 	  
 	  /**
 	   * Checks the dirty status of the 'count' field. A field is dirty if it represents a change that has not yet been written to the database.
-		   * @param value the value to set.
 	   */
 	  public boolean isCountDirty() {
 	    throw new java.lang.UnsupportedOperationException("IsDirty is not supported on tombstones");

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-hbase/src/main/java/org/apache/gora/hbase/store/HBaseStore.java
----------------------------------------------------------------------
diff --git a/gora-hbase/src/main/java/org/apache/gora/hbase/store/HBaseStore.java b/gora-hbase/src/main/java/org/apache/gora/hbase/store/HBaseStore.java
index bb83ff2..0d98250 100644
--- a/gora-hbase/src/main/java/org/apache/gora/hbase/store/HBaseStore.java
+++ b/gora-hbase/src/main/java/org/apache/gora/hbase/store/HBaseStore.java
@@ -832,7 +832,7 @@ implements Configurable {
    * 
    * @see Scan#setCaching(int)
    * 
-   * @param numRows the number of rows for caching >= 0
+   * @param numRows the number of rows for caching {@literal >=} 0
    * @return &lt;&lt;Fluent interface&gt;&gt;
    */
   public HBaseStore<K, T> setScannerCaching(int numRows) {

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-hbase/src/main/java/org/apache/gora/hbase/util/HBaseByteInterface.java
----------------------------------------------------------------------
diff --git a/gora-hbase/src/main/java/org/apache/gora/hbase/util/HBaseByteInterface.java b/gora-hbase/src/main/java/org/apache/gora/hbase/util/HBaseByteInterface.java
index c20383b..a31ed07 100644
--- a/gora-hbase/src/main/java/org/apache/gora/hbase/util/HBaseByteInterface.java
+++ b/gora-hbase/src/main/java/org/apache/gora/hbase/util/HBaseByteInterface.java
@@ -38,8 +38,7 @@ import org.apache.gora.util.AvroUtils;
 import org.apache.hadoop.hbase.util.Bytes;
 
 /**
- * Contains utility methods for byte[] <-> field
- * conversions.
+ * Contains utility methods for byte[] {@literal <->} field conversions.
  */
 public class HBaseByteInterface {
   /**

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-mongodb/src/main/java/org/apache/gora/mongodb/filters/BaseFactory.java
----------------------------------------------------------------------
diff --git a/gora-mongodb/src/main/java/org/apache/gora/mongodb/filters/BaseFactory.java b/gora-mongodb/src/main/java/org/apache/gora/mongodb/filters/BaseFactory.java
index 3dea131..77d7fe5 100644
--- a/gora-mongodb/src/main/java/org/apache/gora/mongodb/filters/BaseFactory.java
+++ b/gora-mongodb/src/main/java/org/apache/gora/mongodb/filters/BaseFactory.java
@@ -24,7 +24,7 @@ import org.apache.gora.persistency.impl.PersistentBase;
  * {@link org.apache.gora.mongodb.filters.FilterFactory} which just manage back
  * reference to {@link MongoFilterUtil}.
  * 
- * @author Damien Raude-Morvan <dr...@dictanova.com>
+ * @author Damien Raude-Morvan draudemorvan@dictanova.com
  */
 public abstract class BaseFactory<K, T extends PersistentBase> implements
     FilterFactory<K, T> {

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-mongodb/src/main/java/org/apache/gora/mongodb/filters/FilterFactory.java
----------------------------------------------------------------------
diff --git a/gora-mongodb/src/main/java/org/apache/gora/mongodb/filters/FilterFactory.java b/gora-mongodb/src/main/java/org/apache/gora/mongodb/filters/FilterFactory.java
index a2caabb..c68364f 100644
--- a/gora-mongodb/src/main/java/org/apache/gora/mongodb/filters/FilterFactory.java
+++ b/gora-mongodb/src/main/java/org/apache/gora/mongodb/filters/FilterFactory.java
@@ -28,7 +28,7 @@ import com.mongodb.DBObject;
 /**
  * Describe factory which create remote filter for MongoDB.
  * 
- * @author Damien Raude-Morvan <dr...@dictanova.com>
+ * @author Damien Raude-Morvan draudemorvan@dictanova.com
  */
 public interface FilterFactory<K, T extends PersistentBase> {
 

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-mongodb/src/main/java/org/apache/gora/mongodb/filters/MongoFilterUtil.java
----------------------------------------------------------------------
diff --git a/gora-mongodb/src/main/java/org/apache/gora/mongodb/filters/MongoFilterUtil.java b/gora-mongodb/src/main/java/org/apache/gora/mongodb/filters/MongoFilterUtil.java
index 96a4ef1..8779af4 100644
--- a/gora-mongodb/src/main/java/org/apache/gora/mongodb/filters/MongoFilterUtil.java
+++ b/gora-mongodb/src/main/java/org/apache/gora/mongodb/filters/MongoFilterUtil.java
@@ -39,7 +39,7 @@ import com.mongodb.DBObject;
  * change factories implementations used.
  * </p>
  * 
- * @author Damien Raude-Morvan <dr...@dictanova.com>
+ * @author Damien Raude-Morvan draudemorvan@dictanova.com
  * @see #setFilter(com.mongodb.DBObject, org.apache.gora.filter.Filter,
  *      org.apache.gora.mongodb.store.MongoStore)
  */

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-mongodb/src/main/java/org/apache/gora/mongodb/query/MongoDBQuery.java
----------------------------------------------------------------------
diff --git a/gora-mongodb/src/main/java/org/apache/gora/mongodb/query/MongoDBQuery.java b/gora-mongodb/src/main/java/org/apache/gora/mongodb/query/MongoDBQuery.java
index 002ff86..0c2f22f 100644
--- a/gora-mongodb/src/main/java/org/apache/gora/mongodb/query/MongoDBQuery.java
+++ b/gora-mongodb/src/main/java/org/apache/gora/mongodb/query/MongoDBQuery.java
@@ -29,7 +29,7 @@ import com.mongodb.DBObject;
 /**
  * MongoDB specific implementation of the {@link Query} interface.
  * 
- * @author Fabien Poulard <fp...@dictanova.com>
+ * @author Fabien Poulard fpoulard@dictanova.com
  */
 public class MongoDBQuery<K, T extends PersistentBase> extends QueryBase<K, T> {
 

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-mongodb/src/main/java/org/apache/gora/mongodb/query/MongoDBResult.java
----------------------------------------------------------------------
diff --git a/gora-mongodb/src/main/java/org/apache/gora/mongodb/query/MongoDBResult.java b/gora-mongodb/src/main/java/org/apache/gora/mongodb/query/MongoDBResult.java
index a032ec0..f20da31 100644
--- a/gora-mongodb/src/main/java/org/apache/gora/mongodb/query/MongoDBResult.java
+++ b/gora-mongodb/src/main/java/org/apache/gora/mongodb/query/MongoDBResult.java
@@ -32,8 +32,8 @@ import com.mongodb.DBObject;
  * MongoDB specific implementation of the {@link org.apache.gora.query.Result}
  * interface.
  *
- * @author Fabien Poulard <fp...@dictanova.com>
- * @author Damien Raude-Morvan <dr...@dictanova.com>
+ * @author Fabien Poulard fpoulard@dictanova.com
+ * @author Damien Raude-Morvan draudemorvan@dictanova.com
  */
 public class MongoDBResult<K, T extends PersistentBase> extends
         ResultBase<K, T> {

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-mongodb/src/main/java/org/apache/gora/mongodb/store/MongoMapping.java
----------------------------------------------------------------------
diff --git a/gora-mongodb/src/main/java/org/apache/gora/mongodb/store/MongoMapping.java b/gora-mongodb/src/main/java/org/apache/gora/mongodb/store/MongoMapping.java
index 0d7d79e..f8912c6 100644
--- a/gora-mongodb/src/main/java/org/apache/gora/mongodb/store/MongoMapping.java
+++ b/gora-mongodb/src/main/java/org/apache/gora/mongodb/store/MongoMapping.java
@@ -29,7 +29,7 @@ import org.slf4j.LoggerFactory;
 import com.google.common.collect.ImmutableList;
 
 /**
- * @author Fabien Poulard <fp...@dictanova.com>
+ * @author Fabien Poulard fpoulard@dictanova.com
  */
 public class MongoMapping {
 

http://git-wip-us.apache.org/repos/asf/gora/blob/f5a6d842/gora-mongodb/src/main/java/org/apache/gora/mongodb/store/MongoMappingBuilder.java
----------------------------------------------------------------------
diff --git a/gora-mongodb/src/main/java/org/apache/gora/mongodb/store/MongoMappingBuilder.java b/gora-mongodb/src/main/java/org/apache/gora/mongodb/store/MongoMappingBuilder.java
index 69b977f..1e2884e 100644
--- a/gora-mongodb/src/main/java/org/apache/gora/mongodb/store/MongoMappingBuilder.java
+++ b/gora-mongodb/src/main/java/org/apache/gora/mongodb/store/MongoMappingBuilder.java
@@ -84,8 +84,6 @@ public class MongoMappingBuilder<K, T extends PersistentBase> {
    * 
    * @param uri
    *          path to the file holding the mapping
-   * @return a {@link org.apache.gora.mongodb.store.MongoMapping} built from the
-   *         file
    * @throws java.io.IOException
    */
   protected void fromFile(String uri) throws IOException {
@@ -153,10 +151,10 @@ public class MongoMappingBuilder<K, T extends PersistentBase> {
     // docNameFromMapping could be null here
     if (!collName.equals(docNameFromMapping)) {
       MongoStore.LOG
-          .info("Keyclass and nameclass match but mismatching table names "
-              + " mappingfile schema is '" + docNameFromMapping
-              + "' vs actual schema '" + collName
-              + "' , assuming they are the same.");
+      .info("Keyclass and nameclass match but mismatching table names "
+          + " mappingfile schema is '" + docNameFromMapping
+          + "' vs actual schema '" + collName
+          + "' , assuming they are the same.");
       if (docNameFromMapping != null) {
         mapping.renameCollection(docNameFromMapping, collName);
       }
@@ -167,9 +165,9 @@ public class MongoMappingBuilder<K, T extends PersistentBase> {
     List<Element> fields = classElement.getChildren(TAG_FIELD);
     for (Element field : fields) {
       mapping
-          .addClassField(field.getAttributeValue(ATT_NAME),
-              field.getAttributeValue(ATT_FIELD),
-              field.getAttributeValue(ATT_TYPE));
+      .addClassField(field.getAttributeValue(ATT_NAME),
+          field.getAttributeValue(ATT_FIELD),
+          field.getAttributeValue(ATT_TYPE));
     }
   }