You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hive.apache.org by we...@apache.org on 2017/05/17 02:53:22 UTC

[44/50] [abbrv] hive git commit: HIVE-16619: Clean up javadoc from errors in module hive-serde (Janos Gub via Zoltan Haindrich)

HIVE-16619: Clean up javadoc from errors in module hive-serde (Janos Gub via Zoltan Haindrich)

Signed-off-by: Zoltan Haindrich <ki...@rxd.hu>


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

Branch: refs/heads/hive-14535
Commit: 23e703f96935ecd6c7daf6316329f305ccac6615
Parents: 202c513
Author: Janos Gub <gu...@gmail.com>
Authored: Tue May 16 08:30:58 2017 +0200
Committer: Zoltan Haindrich <ki...@rxd.hu>
Committed: Tue May 16 08:30:58 2017 +0200

----------------------------------------------------------------------
 .../hadoop/hive/serde2/AbstractSerDe.java       |  2 +-
 .../hive/serde2/ColumnProjectionUtils.java      |  8 ++++----
 .../apache/hadoop/hive/serde2/SerDeUtils.java   |  2 +-
 .../serde2/avro/AvroLazyObjectInspector.java    |  2 +-
 .../hive/serde2/avro/AvroSchemaRetriever.java   |  2 +-
 .../hive/serde2/columnar/ColumnarSerDe.java     |  4 ++--
 .../serde2/columnar/ColumnarStructBase.java     |  2 +-
 .../dynamic_type/DynamicSerDeStructBase.java    |  2 +-
 .../serde2/dynamic_type/ParseException.java     |  2 +-
 .../hive/serde2/fast/DeserializeRead.java       |  6 +++---
 .../hive/serde2/io/TimestampWritable.java       |  6 +++---
 .../hadoop/hive/serde2/lazy/LazyDate.java       |  2 +-
 .../hadoop/hive/serde2/lazy/LazyFactory.java    | 21 ++++++++------------
 .../hive/serde2/lazy/LazyHiveDecimal.java       |  2 +-
 .../hive/serde2/lazy/LazySimpleSerDe.java       | 12 +++++------
 .../hive/serde2/lazybinary/LazyBinaryArray.java |  2 +-
 .../hive/serde2/lazybinary/LazyBinaryMap.java   |  2 +-
 .../hive/serde2/lazybinary/LazyBinarySerDe.java |  6 +++---
 .../serde2/lazybinary/LazyBinaryString.java     |  2 +-
 .../serde2/lazybinary/LazyBinaryStruct.java     |  2 +-
 .../hive/serde2/lazybinary/LazyBinaryUnion.java |  2 +-
 .../hive/serde2/lazybinary/LazyBinaryUtils.java |  2 +-
 .../serde2/objectinspector/ObjectInspector.java |  2 +-
 .../objectinspector/ObjectInspectorUtils.java   |  4 ++--
 .../PrimitiveObjectInspectorFactory.java        |  6 +++---
 .../hive/serde2/typeinfo/TypeInfoUtils.java     |  4 ++--
 26 files changed, 52 insertions(+), 57 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/hive/blob/23e703f9/serde/src/java/org/apache/hadoop/hive/serde2/AbstractSerDe.java
----------------------------------------------------------------------
diff --git a/serde/src/java/org/apache/hadoop/hive/serde2/AbstractSerDe.java b/serde/src/java/org/apache/hadoop/hive/serde2/AbstractSerDe.java
index 049b35d..a2a85b3 100644
--- a/serde/src/java/org/apache/hadoop/hive/serde2/AbstractSerDe.java
+++ b/serde/src/java/org/apache/hadoop/hive/serde2/AbstractSerDe.java
@@ -118,7 +118,7 @@ public abstract class AbstractSerDe implements Deserializer, Serializer {
   }
 
   /**
-   * @rturn Whether the SerDe that can store schema both inside and outside of metastore
+   * @return Whether the SerDe that can store schema both inside and outside of metastore
    *        does, in fact, store it inside metastore, based on table parameters.
    */
   public boolean shouldStoreFieldsInMetastore(Map<String, String> tableParams) {

http://git-wip-us.apache.org/repos/asf/hive/blob/23e703f9/serde/src/java/org/apache/hadoop/hive/serde2/ColumnProjectionUtils.java
----------------------------------------------------------------------
diff --git a/serde/src/java/org/apache/hadoop/hive/serde2/ColumnProjectionUtils.java b/serde/src/java/org/apache/hadoop/hive/serde2/ColumnProjectionUtils.java
index 9844166..2009645 100644
--- a/serde/src/java/org/apache/hadoop/hive/serde2/ColumnProjectionUtils.java
+++ b/serde/src/java/org/apache/hadoop/hive/serde2/ColumnProjectionUtils.java
@@ -44,7 +44,7 @@ public final class ColumnProjectionUtils {
   /**
    * the nested column path is the string from the root to the leaf
    * e.g.
-   * c:struct<a:string,b:string>
+   * c:struct&lt;a:string,b:string&gt;
    * the column a's path is c.a and b's path is c.b
    */
   public static final String READ_NESTED_COLUMN_PATH_CONF_STR =
@@ -57,7 +57,7 @@ public final class ColumnProjectionUtils {
   private static final Joiner CSV_JOINER = Joiner.on(",").skipNulls();
 
   /**
-   * @deprecated for backwards compatibility with <= 0.12, use setReadAllColumns
+   * @deprecated for backwards compatibility with &lt;= 0.12, use setReadAllColumns
    */
   @Deprecated
   public static void setFullyReadColumns(Configuration conf) {
@@ -65,7 +65,7 @@ public final class ColumnProjectionUtils {
   }
 
   /**
-   * @deprecated for backwards compatibility with <= 0.12, use setReadAllColumns
+   * @deprecated for backwards compatibility with &lt;= 0.12, use setReadAllColumns
    * and appendReadColumns
    */
   @Deprecated
@@ -76,7 +76,7 @@ public final class ColumnProjectionUtils {
   }
 
   /**
-   * @deprecated for backwards compatibility with <= 0.12, use appendReadColumns
+   * @deprecated for backwards compatibility with &lt;= 0.12, use appendReadColumns
    */
   @Deprecated
   public static void appendReadColumnIDs(Configuration conf, List<Integer> ids) {

http://git-wip-us.apache.org/repos/asf/hive/blob/23e703f9/serde/src/java/org/apache/hadoop/hive/serde2/SerDeUtils.java
----------------------------------------------------------------------
diff --git a/serde/src/java/org/apache/hadoop/hive/serde2/SerDeUtils.java b/serde/src/java/org/apache/hadoop/hive/serde2/SerDeUtils.java
index 9ead0ed..b9d23dd 100644
--- a/serde/src/java/org/apache/hadoop/hive/serde2/SerDeUtils.java
+++ b/serde/src/java/org/apache/hadoop/hive/serde2/SerDeUtils.java
@@ -163,7 +163,7 @@ public final class SerDeUtils {
    * Convert a Object to a standard Java object in compliance with JDBC 3.0 (see JDBC 3.0
    * Specification, Table B-3: Mapping from JDBC Types to Java Object Types).
    *
-   * This method is kept consistent with {@link HiveResultSetMetaData#hiveTypeToSqlType}.
+   * This method is kept consistent with HiveResultSetMetaData#hiveTypeToSqlType .
    */
   public static Object toThriftPayload(Object val, ObjectInspector valOI, int version) {
     if (valOI.getCategory() == ObjectInspector.Category.PRIMITIVE) {

http://git-wip-us.apache.org/repos/asf/hive/blob/23e703f9/serde/src/java/org/apache/hadoop/hive/serde2/avro/AvroLazyObjectInspector.java
----------------------------------------------------------------------
diff --git a/serde/src/java/org/apache/hadoop/hive/serde2/avro/AvroLazyObjectInspector.java b/serde/src/java/org/apache/hadoop/hive/serde2/avro/AvroLazyObjectInspector.java
index de9f4a8..ff8ac36 100644
--- a/serde/src/java/org/apache/hadoop/hive/serde2/avro/AvroLazyObjectInspector.java
+++ b/serde/src/java/org/apache/hadoop/hive/serde2/avro/AvroLazyObjectInspector.java
@@ -110,7 +110,7 @@ public class AvroLazyObjectInspector extends LazySimpleStructObjectInspector {
   /**
    * Set the {@link AvroSchemaRetriever} for the {@link AvroLazyObjectInspector} to the given class
    *
-   * @param scheamRetrieverClass the schema retriever class to be set
+   * @param schemaRetriever the schema retriever class to be set
    * */
   public void setSchemaRetriever(AvroSchemaRetriever schemaRetriever) {
     this.schemaRetriever = schemaRetriever;

http://git-wip-us.apache.org/repos/asf/hive/blob/23e703f9/serde/src/java/org/apache/hadoop/hive/serde2/avro/AvroSchemaRetriever.java
----------------------------------------------------------------------
diff --git a/serde/src/java/org/apache/hadoop/hive/serde2/avro/AvroSchemaRetriever.java b/serde/src/java/org/apache/hadoop/hive/serde2/avro/AvroSchemaRetriever.java
index fcd2621..bed4de7 100644
--- a/serde/src/java/org/apache/hadoop/hive/serde2/avro/AvroSchemaRetriever.java
+++ b/serde/src/java/org/apache/hadoop/hive/serde2/avro/AvroSchemaRetriever.java
@@ -22,7 +22,7 @@ import org.apache.avro.Schema;
 /**
  * Retrieves the avro schema from the given source. "Source" is a little loose term here in the
  * sense it can range from being an HDFS url location pointing to the schema or it can be even as
- * simple as a {@link Properties properties} file with a simple key-value mapping to the schema. For
+ * simple as a {@link java.util.Properties properties} file with a simple key-value mapping to the schema. For
  * cases where the {@link Schema schema} is a part of the serialized data itself, "Source" would
  * refer to the data bytes from which the {@link Schema schema} has to retrieved.
  *

http://git-wip-us.apache.org/repos/asf/hive/blob/23e703f9/serde/src/java/org/apache/hadoop/hive/serde2/columnar/ColumnarSerDe.java
----------------------------------------------------------------------
diff --git a/serde/src/java/org/apache/hadoop/hive/serde2/columnar/ColumnarSerDe.java b/serde/src/java/org/apache/hadoop/hive/serde2/columnar/ColumnarSerDe.java
index 36beaee..d353fab 100644
--- a/serde/src/java/org/apache/hadoop/hive/serde2/columnar/ColumnarSerDe.java
+++ b/serde/src/java/org/apache/hadoop/hive/serde2/columnar/ColumnarSerDe.java
@@ -88,7 +88,7 @@ public class ColumnarSerDe extends ColumnarSerDeBase {
   /**
    * Initialize the SerDe given the parameters.
    *
-   * @see AbstractSerDe#initialize(Configuration, Properties)
+   * @see org.apache.hadoop.hive.serde2.AbstractSerDe#initialize(Configuration, Properties)
    */
   @Override
   public void initialize(Configuration conf, Properties tbl) throws SerDeException {
@@ -123,7 +123,7 @@ public class ColumnarSerDe extends ColumnarSerDeBase {
    * @param objInspector
    *          The ObjectInspector for the row object
    * @return The serialized Writable object
-   * @see AbstractSerDe#serialize(Object, ObjectInspector)
+   * @see org.apache.hadoop.hive.serde2.AbstractSerDe#serialize(Object, ObjectInspector)
    */
   @Override
   public Writable serialize(Object obj, ObjectInspector objInspector) throws SerDeException {

http://git-wip-us.apache.org/repos/asf/hive/blob/23e703f9/serde/src/java/org/apache/hadoop/hive/serde2/columnar/ColumnarStructBase.java
----------------------------------------------------------------------
diff --git a/serde/src/java/org/apache/hadoop/hive/serde2/columnar/ColumnarStructBase.java b/serde/src/java/org/apache/hadoop/hive/serde2/columnar/ColumnarStructBase.java
index fd06f58..33726d9 100644
--- a/serde/src/java/org/apache/hadoop/hive/serde2/columnar/ColumnarStructBase.java
+++ b/serde/src/java/org/apache/hadoop/hive/serde2/columnar/ColumnarStructBase.java
@@ -183,7 +183,7 @@ public abstract class ColumnarStructBase implements StructObject, SerDeStatsStru
    * @param length
    *          the length
    *
-   * @return -1 for null, >=0 for length
+   * @return -1 for null, &gt;=0 for length
    */
   protected abstract int getLength(ObjectInspector objectInspector,
       ByteArrayRef cachedByteArrayRef, int start, int length);

http://git-wip-us.apache.org/repos/asf/hive/blob/23e703f9/serde/src/java/org/apache/hadoop/hive/serde2/dynamic_type/DynamicSerDeStructBase.java
----------------------------------------------------------------------
diff --git a/serde/src/java/org/apache/hadoop/hive/serde2/dynamic_type/DynamicSerDeStructBase.java b/serde/src/java/org/apache/hadoop/hive/serde2/dynamic_type/DynamicSerDeStructBase.java
index a15c9e1..fa1f305 100644
--- a/serde/src/java/org/apache/hadoop/hive/serde2/dynamic_type/DynamicSerDeStructBase.java
+++ b/serde/src/java/org/apache/hadoop/hive/serde2/dynamic_type/DynamicSerDeStructBase.java
@@ -86,7 +86,7 @@ public abstract class DynamicSerDeStructBase extends DynamicSerDeTypeBase
    * @param o
    *          - this list should be in the order of the function's params for
    *          now. If we wanted to remove this requirement, we'd need to make it
-   *          a List<Pair<String, Object>> with the String being the field name.
+   *          a List&lt;Pair&lt;String, Object&gt;&gt; with the String being the field name.
    * 
    */
   @Override

http://git-wip-us.apache.org/repos/asf/hive/blob/23e703f9/serde/src/java/org/apache/hadoop/hive/serde2/dynamic_type/ParseException.java
----------------------------------------------------------------------
diff --git a/serde/src/java/org/apache/hadoop/hive/serde2/dynamic_type/ParseException.java b/serde/src/java/org/apache/hadoop/hive/serde2/dynamic_type/ParseException.java
index d7fde21..00424d3 100644
--- a/serde/src/java/org/apache/hadoop/hive/serde2/dynamic_type/ParseException.java
+++ b/serde/src/java/org/apache/hadoop/hive/serde2/dynamic_type/ParseException.java
@@ -19,7 +19,7 @@ public class ParseException extends Exception {
    * to indicate that this constructor was used to create this object. This
    * constructor calls its super class with the empty string to force the
    * "toString" method of parent class "Throwable" to print the error message in
-   * the form: ParseException: <result of getMessage>
+   * the form: ParseException: &lt;result of getMessage&gt;
    */
   public ParseException(Token currentTokenVal,
       int[][] expectedTokenSequencesVal, String[] tokenImageVal) {

http://git-wip-us.apache.org/repos/asf/hive/blob/23e703f9/serde/src/java/org/apache/hadoop/hive/serde2/fast/DeserializeRead.java
----------------------------------------------------------------------
diff --git a/serde/src/java/org/apache/hadoop/hive/serde2/fast/DeserializeRead.java b/serde/src/java/org/apache/hadoop/hive/serde2/fast/DeserializeRead.java
index ac931d6..cb775f7 100644
--- a/serde/src/java/org/apache/hadoop/hive/serde2/fast/DeserializeRead.java
+++ b/serde/src/java/org/apache/hadoop/hive/serde2/fast/DeserializeRead.java
@@ -60,11 +60,11 @@ public abstract class DeserializeRead {
    *
    * if (deserializeRead.readNextField()) {
    *   if (deserializeRead.currentExternalBufferNeeded) {
-   *     <Ensure external buffer is as least deserializeRead.currentExternalBufferNeededLen bytes>
+   *     &lt;Ensure external buffer is as least deserializeRead.currentExternalBufferNeededLen bytes&gt;
    *     deserializeRead.copyToExternalBuffer(externalBuffer, externalBufferStart);
    *   } else {
-   *     <Otherwise, field data is available in the currentBytes, currentBytesStart, and
-   *      currentBytesLength of deserializeRead>
+   *     &lt;Otherwise, field data is available in the currentBytes, currentBytesStart, and
+   *      currentBytesLength of deserializeRead&gt;
    *   }
    *
    * @param typeInfos

http://git-wip-us.apache.org/repos/asf/hive/blob/23e703f9/serde/src/java/org/apache/hadoop/hive/serde2/io/TimestampWritable.java
----------------------------------------------------------------------
diff --git a/serde/src/java/org/apache/hadoop/hive/serde2/io/TimestampWritable.java b/serde/src/java/org/apache/hadoop/hive/serde2/io/TimestampWritable.java
index bbccc7f..af00a30 100644
--- a/serde/src/java/org/apache/hadoop/hive/serde2/io/TimestampWritable.java
+++ b/serde/src/java/org/apache/hadoop/hive/serde2/io/TimestampWritable.java
@@ -47,9 +47,9 @@ import org.apache.hadoop.io.WritableUtils;
  * The fractional portion is reversed, and encoded as a VInt
  * so timestamps with less precision use fewer bytes.
  *
- *      0.1    -> 1
- *      0.01   -> 10
- *      0.001  -> 100
+ *      0.1    -&gt; 1
+ *      0.01   -&gt; 10
+ *      0.001  -&gt; 100
  *
  */
 public class TimestampWritable implements WritableComparable<TimestampWritable> {

http://git-wip-us.apache.org/repos/asf/hive/blob/23e703f9/serde/src/java/org/apache/hadoop/hive/serde2/lazy/LazyDate.java
----------------------------------------------------------------------
diff --git a/serde/src/java/org/apache/hadoop/hive/serde2/lazy/LazyDate.java b/serde/src/java/org/apache/hadoop/hive/serde2/lazy/LazyDate.java
index c00faac..ab20aaf 100644
--- a/serde/src/java/org/apache/hadoop/hive/serde2/lazy/LazyDate.java
+++ b/serde/src/java/org/apache/hadoop/hive/serde2/lazy/LazyDate.java
@@ -77,7 +77,7 @@ public class LazyDate extends LazyPrimitive<LazyDateObjectInspector, DateWritabl
    * Writes a Date in SQL date format to the output stream.
    * @param out
    *          The output stream
-   * @param i
+   * @param d
    *          The Date to write
    * @throws IOException
    */

http://git-wip-us.apache.org/repos/asf/hive/blob/23e703f9/serde/src/java/org/apache/hadoop/hive/serde2/lazy/LazyFactory.java
----------------------------------------------------------------------
diff --git a/serde/src/java/org/apache/hadoop/hive/serde2/lazy/LazyFactory.java b/serde/src/java/org/apache/hadoop/hive/serde2/lazy/LazyFactory.java
index 2b940fd..f87ac76 100644
--- a/serde/src/java/org/apache/hadoop/hive/serde2/lazy/LazyFactory.java
+++ b/serde/src/java/org/apache/hadoop/hive/serde2/lazy/LazyFactory.java
@@ -85,7 +85,7 @@ public final class LazyFactory {
    * @param poi PrimitiveObjectInspector
    * @param typeBinary a switch to return either a LazyPrimtive class or it's binary
    *        companion
-   * @return LazyPrimitive<? extends ObjectInspector, ? extends Writable>
+   * @return LazyPrimitive&lt;? extends ObjectInspector, ? extends Writable&gt;
    */
   public static LazyPrimitive<? extends ObjectInspector, ? extends Writable>
   createLazyPrimitiveClass(PrimitiveObjectInspector poi, boolean typeBinary) {
@@ -201,7 +201,7 @@ public final class LazyFactory {
    * @param oi ObjectInspector
    * @param typeBinary Boolean value used as switch to return variants of LazyPrimitive
    *                   objects which are initialized from a binary format for the data.
-   * @return LazyObject<? extends ObjectInspector>
+   * @return LazyObject&lt;? extends ObjectInspector&gt;
    */
   public static LazyObject<? extends ObjectInspector>
   createLazyObject(ObjectInspector oi, boolean typeBinary) {
@@ -219,7 +219,7 @@ public final class LazyFactory {
    *
    * @param typeInfo
    *          The type information for the LazyObject
-   * @param separator
+   * @param separators
    *          The array of separators for delimiting each level
    * @param separatorIndex
    *          The current level (for separators). List(array), struct uses 1
@@ -244,7 +244,7 @@ public final class LazyFactory {
    *
    * @param typeInfo
    *          The type information for the LazyObject
-   * @param separator
+   * @param separators
    *          The array of separators for delimiting each level
    * @param separatorIndex
    *          The current level (for separators). List(array), struct uses 1
@@ -267,13 +267,12 @@ public final class LazyFactory {
    * Create a hierarchical ObjectInspector for LazyObject with the given typeInfo.
    *
    * @param typeInfo The type information for the LazyObject
-   * @param separator The array of separators for delimiting each level
+   * @param separators The array of separators for delimiting each level
    * @param separatorIndex The current level (for separators). List(array), struct uses 1 level of
    *          separator, and map uses 2 levels: the first one for delimiting entries, the second one
    *          for delimiting key and values.
    * @param nullSequence The sequence of bytes representing NULL.
    * @param extendedBooleanLiteral whether extended boolean literal set is legal
-   * @param option the {@link ObjectInspectorOption}
    * @return The ObjectInspector
    * @throws SerDeException
    */
@@ -289,13 +288,13 @@ public final class LazyFactory {
    * Create a hierarchical ObjectInspector for LazyObject with the given typeInfo.
    *
    * @param typeInfo The type information for the LazyObject
-   * @param separator The array of separators for delimiting each level
+   * @param separators The array of separators for delimiting each level
    * @param separatorIndex The current level (for separators). List(array), struct uses 1 level of
    *          separator, and map uses 2 levels: the first one for delimiting entries, the second one
    *          for delimiting key and values.
    * @param nullSequence The sequence of bytes representing NULL.
    * @param extendedBooleanLiteral whether extended boolean literal set is legal
-   * @param option the {@link ObjectInspectorOption}
+   * @param option the {@link ObjectInspectorOptions}
    * @return The ObjectInspector
    * @throws SerDeException
    */
@@ -312,12 +311,11 @@ public final class LazyFactory {
    * Create a hierarchical ObjectInspector for LazyObject with the given typeInfo.
    *
    * @param typeInfo The type information for the LazyObject
-   * @param separator The array of separators for delimiting each level
    * @param separatorIndex The current level (for separators). List(array), struct uses 1 level of
    *          separator, and map uses 2 levels: the first one for delimiting entries, the second one
    *          for delimiting key and values.
    * @param lazyParams Params for lazy types
-   * @param option the {@link ObjectInspectorOption}
+   * @param option the {@link ObjectInspectorOptions}
    * @return The ObjectInspector
    * @throws SerDeException
    */
@@ -420,9 +418,6 @@ public final class LazyFactory {
    * Create a hierarchical ObjectInspector for LazyStruct with the given
    * columnNames and columnTypeInfos.
    *
-   * @param lastColumnTakesRest
-   *          whether the last column of the struct should take the rest of the
-   *          row if there are extra fields.
    * @param lazyParams  parameters for the lazy types
    * @throws SerDeException
    * @see LazyFactory#createLazyObjectInspector(TypeInfo, byte[], int, Text,

http://git-wip-us.apache.org/repos/asf/hive/blob/23e703f9/serde/src/java/org/apache/hadoop/hive/serde2/lazy/LazyHiveDecimal.java
----------------------------------------------------------------------
diff --git a/serde/src/java/org/apache/hadoop/hive/serde2/lazy/LazyHiveDecimal.java b/serde/src/java/org/apache/hadoop/hive/serde2/lazy/LazyHiveDecimal.java
index 4d2ff22..9378cd1 100644
--- a/serde/src/java/org/apache/hadoop/hive/serde2/lazy/LazyHiveDecimal.java
+++ b/serde/src/java/org/apache/hadoop/hive/serde2/lazy/LazyHiveDecimal.java
@@ -126,7 +126,7 @@ public class LazyHiveDecimal extends LazyPrimitive<LazyHiveDecimalObjectInspecto
   /**
    * Writes HiveDecimalWritable object to output stream as string
    * @param outputStream
-   * @param hiveDecimal
+   * @param hiveDecimalWritable
    * @throws IOException
    */
   public static void writeUTF8(

http://git-wip-us.apache.org/repos/asf/hive/blob/23e703f9/serde/src/java/org/apache/hadoop/hive/serde2/lazy/LazySimpleSerDe.java
----------------------------------------------------------------------
diff --git a/serde/src/java/org/apache/hadoop/hive/serde2/lazy/LazySimpleSerDe.java b/serde/src/java/org/apache/hadoop/hive/serde2/lazy/LazySimpleSerDe.java
index 17ecff1..c692c39 100644
--- a/serde/src/java/org/apache/hadoop/hive/serde2/lazy/LazySimpleSerDe.java
+++ b/serde/src/java/org/apache/hadoop/hive/serde2/lazy/LazySimpleSerDe.java
@@ -105,7 +105,7 @@ public class LazySimpleSerDe extends AbstractEncodingAwareSerDe {
    * ","-separated column names columns.types: ",", ":", or ";"-separated column
    * types
    *
-   * @see AbstractSerDe#initialize(Configuration, Properties)
+   * @see  org.apache.hadoop.hive.serde2.AbstractSerDe#initialize(Configuration, Properties)
    */
   @Override
   public void initialize(Configuration job, Properties tbl)
@@ -141,7 +141,7 @@ public class LazySimpleSerDe extends AbstractEncodingAwareSerDe {
    * @param field
    *          the Writable that contains the data
    * @return The deserialized row Object.
-   * @see AbstractSerDe#deserialize(Writable)
+   * @see  org.apache.hadoop.hive.serde2.AbstractSerDe#deserialize(Writable)
    */
   @Override
   public Object doDeserialize(Writable field) throws SerDeException {
@@ -167,7 +167,7 @@ public class LazySimpleSerDe extends AbstractEncodingAwareSerDe {
   /**
    * Returns the Writable Class after serialization.
    *
-   * @see AbstractSerDe#getSerializedClass()
+   * @see org.apache.hadoop.hive.serde2.AbstractSerDe#getSerializedClass()
    */
   @Override
   public Class<? extends Writable> getSerializedClass() {
@@ -185,8 +185,8 @@ public class LazySimpleSerDe extends AbstractEncodingAwareSerDe {
    * @param objInspector
    *          The ObjectInspector for the row object
    * @return The serialized Writable object
-   * @throws IOException
-   * @see AbstractSerDe#serialize(Object, ObjectInspector)
+   * @throws SerDeException
+   * @see org.apache.hadoop.hive.serde2.AbstractSerDe#serialize(Object, ObjectInspector)
    */
   @Override
   public Writable doSerialize(Object obj, ObjectInspector objInspector)
@@ -422,7 +422,7 @@ public class LazySimpleSerDe extends AbstractEncodingAwareSerDe {
 
   /**
    * This class is deprecated and is only used for backward compatibility. Replace by
-   * @see org.apache.hadoop.hive.serde2.lazy.LazySerDeParameters.
+   * @see org.apache.hadoop.hive.serde2.lazy.LazySerDeParameters .
    */
   @Deprecated
   public static class SerDeParameters extends org.apache.hadoop.hive.serde2.lazy.LazySerDeParameters {

http://git-wip-us.apache.org/repos/asf/hive/blob/23e703f9/serde/src/java/org/apache/hadoop/hive/serde2/lazybinary/LazyBinaryArray.java
----------------------------------------------------------------------
diff --git a/serde/src/java/org/apache/hadoop/hive/serde2/lazybinary/LazyBinaryArray.java b/serde/src/java/org/apache/hadoop/hive/serde2/lazybinary/LazyBinaryArray.java
index fee1472..6b1288c 100644
--- a/serde/src/java/org/apache/hadoop/hive/serde2/lazybinary/LazyBinaryArray.java
+++ b/serde/src/java/org/apache/hadoop/hive/serde2/lazybinary/LazyBinaryArray.java
@@ -30,7 +30,7 @@ import org.apache.hadoop.hive.serde2.objectinspector.ListObjectInspector;
 import org.apache.hadoop.hive.serde2.objectinspector.ObjectInspector;
 
 /**
- * LazyBinaryArray is serialized as follows: start A b b b b b b end bytes[] ->
+ * LazyBinaryArray is serialized as follows: start A b b b b b b end bytes[] -&gt;
  * |--------|---|---|---|---| ... |---|---|
  * 
  * Section A is the null-bytes. Suppose the list has N elements, then there are

http://git-wip-us.apache.org/repos/asf/hive/blob/23e703f9/serde/src/java/org/apache/hadoop/hive/serde2/lazybinary/LazyBinaryMap.java
----------------------------------------------------------------------
diff --git a/serde/src/java/org/apache/hadoop/hive/serde2/lazybinary/LazyBinaryMap.java b/serde/src/java/org/apache/hadoop/hive/serde2/lazybinary/LazyBinaryMap.java
index 1aa72ce..80e1e46 100644
--- a/serde/src/java/org/apache/hadoop/hive/serde2/lazybinary/LazyBinaryMap.java
+++ b/serde/src/java/org/apache/hadoop/hive/serde2/lazybinary/LazyBinaryMap.java
@@ -31,7 +31,7 @@ import org.apache.hadoop.hive.serde2.objectinspector.MapObjectInspector;
 import org.apache.hadoop.hive.serde2.objectinspector.PrimitiveObjectInspector;
 
 /**
- * LazyBinaryMap is serialized as follows: start A b c b c b c end bytes[] ->
+ * LazyBinaryMap is serialized as follows: start A b c b c b c end bytes[] -&gt;
  * |--------|---|---|---|---| ... |---|---|
  * 
  * Section A is the null-bytes. Suppose the map has N key-value pairs, then

http://git-wip-us.apache.org/repos/asf/hive/blob/23e703f9/serde/src/java/org/apache/hadoop/hive/serde2/lazybinary/LazyBinarySerDe.java
----------------------------------------------------------------------
diff --git a/serde/src/java/org/apache/hadoop/hive/serde2/lazybinary/LazyBinarySerDe.java b/serde/src/java/org/apache/hadoop/hive/serde2/lazybinary/LazyBinarySerDe.java
index 7cdedd6..268f374 100644
--- a/serde/src/java/org/apache/hadoop/hive/serde2/lazybinary/LazyBinarySerDe.java
+++ b/serde/src/java/org/apache/hadoop/hive/serde2/lazybinary/LazyBinarySerDe.java
@@ -353,7 +353,7 @@ public class LazyBinarySerDe extends AbstractSerDe {
    * @param byteStream
    * @param dec
    * @param scratchLongs
-   * @param buffer
+   * @param scratchBytes
    */
   public static void writeToByteStream(
       RandomAccessOutput byteStream,
@@ -379,9 +379,9 @@ public class LazyBinarySerDe extends AbstractSerDe {
   * And, allocate scratch buffer with HiveDecimal.SCRATCH_BUFFER_LEN_BIG_INTEGER_BYTES bytes.
   *
   * @param byteStream
-  * @param dec
+  * @param decWritable
   * @param scratchLongs
-  * @param buffer
+  * @param scratchBytes
   */
   public static void writeToByteStream(
       RandomAccessOutput byteStream,

http://git-wip-us.apache.org/repos/asf/hive/blob/23e703f9/serde/src/java/org/apache/hadoop/hive/serde2/lazybinary/LazyBinaryString.java
----------------------------------------------------------------------
diff --git a/serde/src/java/org/apache/hadoop/hive/serde2/lazybinary/LazyBinaryString.java b/serde/src/java/org/apache/hadoop/hive/serde2/lazybinary/LazyBinaryString.java
index 9f691d7..4f1ae56 100644
--- a/serde/src/java/org/apache/hadoop/hive/serde2/lazybinary/LazyBinaryString.java
+++ b/serde/src/java/org/apache/hadoop/hive/serde2/lazybinary/LazyBinaryString.java
@@ -22,7 +22,7 @@ import org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableStringObj
 import org.apache.hadoop.io.Text;
 
 /**
- * The serialization of LazyBinaryString is very simple: start A end bytes[] ->
+ * The serialization of LazyBinaryString is very simple: start A end bytes[] -&gt;
  * |---------------------------------|
  * 
  * Section A is just an array of bytes which are exactly the Text contained in

http://git-wip-us.apache.org/repos/asf/hive/blob/23e703f9/serde/src/java/org/apache/hadoop/hive/serde2/lazybinary/LazyBinaryStruct.java
----------------------------------------------------------------------
diff --git a/serde/src/java/org/apache/hadoop/hive/serde2/lazybinary/LazyBinaryStruct.java b/serde/src/java/org/apache/hadoop/hive/serde2/lazybinary/LazyBinaryStruct.java
index b4eb7bb..f594484 100644
--- a/serde/src/java/org/apache/hadoop/hive/serde2/lazybinary/LazyBinaryStruct.java
+++ b/serde/src/java/org/apache/hadoop/hive/serde2/lazybinary/LazyBinaryStruct.java
@@ -35,7 +35,7 @@ import org.apache.hadoop.hive.serde2.objectinspector.StructObjectInspector;
 import org.apache.hadoop.io.BinaryComparable;
 
 /**
- * LazyBinaryStruct is serialized as follows: start A B A B A B end bytes[] ->
+ * LazyBinaryStruct is serialized as follows: start A B A B A B end bytes[] -&gt;
  * |-----|---------|--- ... ---|-----|---------|
  *
  * Section A is one null-byte, corresponding to eight struct fields in Section

http://git-wip-us.apache.org/repos/asf/hive/blob/23e703f9/serde/src/java/org/apache/hadoop/hive/serde2/lazybinary/LazyBinaryUnion.java
----------------------------------------------------------------------
diff --git a/serde/src/java/org/apache/hadoop/hive/serde2/lazybinary/LazyBinaryUnion.java b/serde/src/java/org/apache/hadoop/hive/serde2/lazybinary/LazyBinaryUnion.java
index fbf05b6..819fbab 100644
--- a/serde/src/java/org/apache/hadoop/hive/serde2/lazybinary/LazyBinaryUnion.java
+++ b/serde/src/java/org/apache/hadoop/hive/serde2/lazybinary/LazyBinaryUnion.java
@@ -29,7 +29,7 @@
   import org.apache.hadoop.hive.serde2.objectinspector.*;
 
 /**
- * LazyBinaryUnion is serialized as follows: start TAG FIELD end bytes[] ->
+ * LazyBinaryUnion is serialized as follows: start TAG FIELD end bytes[] -&gt;
  * |-----|---------|--- ... ---|-----|---------|
  *
  * Section TAG is one byte, corresponding to tag of set union field

http://git-wip-us.apache.org/repos/asf/hive/blob/23e703f9/serde/src/java/org/apache/hadoop/hive/serde2/lazybinary/LazyBinaryUtils.java
----------------------------------------------------------------------
diff --git a/serde/src/java/org/apache/hadoop/hive/serde2/lazybinary/LazyBinaryUtils.java b/serde/src/java/org/apache/hadoop/hive/serde2/lazybinary/LazyBinaryUtils.java
index 5666516..4c67259 100644
--- a/serde/src/java/org/apache/hadoop/hive/serde2/lazybinary/LazyBinaryUtils.java
+++ b/serde/src/java/org/apache/hadoop/hive/serde2/lazybinary/LazyBinaryUtils.java
@@ -100,7 +100,7 @@ public final class LazyBinaryUtils {
   /**
    * Record is the unit that data is serialized in. A record includes two parts.
    * The first part stores the size of the element and the second part stores
-   * the real element. size element record -> |----|-------------------------|
+   * the real element. size element record -&gt; |----|-------------------------|
    *
    * A RecordInfo stores two information of a record, the size of the "size"
    * part which is the element offset and the size of the element part which is

http://git-wip-us.apache.org/repos/asf/hive/blob/23e703f9/serde/src/java/org/apache/hadoop/hive/serde2/objectinspector/ObjectInspector.java
----------------------------------------------------------------------
diff --git a/serde/src/java/org/apache/hadoop/hive/serde2/objectinspector/ObjectInspector.java b/serde/src/java/org/apache/hadoop/hive/serde2/objectinspector/ObjectInspector.java
index d90560b..7238fbc 100644
--- a/serde/src/java/org/apache/hadoop/hive/serde2/objectinspector/ObjectInspector.java
+++ b/serde/src/java/org/apache/hadoop/hive/serde2/objectinspector/ObjectInspector.java
@@ -50,7 +50,7 @@ public interface ObjectInspector extends Cloneable {
    * ObjectInspector. This is used to display the type information to the user.
    *
    * For primitive types, the type name is standardized. For other types, the
-   * type name can be something like "list<int>", "map<int,string>", java class
+   * type name can be something like "list&lt;int&gt;", "map&lt;int,string&gt;", java class
    * names, or user-defined type names similar to typedef.
    */
   String getTypeName();

http://git-wip-us.apache.org/repos/asf/hive/blob/23e703f9/serde/src/java/org/apache/hadoop/hive/serde2/objectinspector/ObjectInspectorUtils.java
----------------------------------------------------------------------
diff --git a/serde/src/java/org/apache/hadoop/hive/serde2/objectinspector/ObjectInspectorUtils.java b/serde/src/java/org/apache/hadoop/hive/serde2/objectinspector/ObjectInspectorUtils.java
index 697d22e..0d6fd4a 100644
--- a/serde/src/java/org/apache/hadoop/hive/serde2/objectinspector/ObjectInspectorUtils.java
+++ b/serde/src/java/org/apache/hadoop/hive/serde2/objectinspector/ObjectInspectorUtils.java
@@ -1385,8 +1385,8 @@ public final class ObjectInspectorUtils {
    *
    * @param oi - Input object inspector
    * @param oiSettableProperties - Lookup map to cache the result.(If no caching, pass null)
-   * @return - true if : (1) oi is an instance of settable<DataType>OI.
-   *                     (2) All the embedded object inspectors are instances of settable<DataType>OI.
+   * @return - true if : (1) oi is an instance of settable&lt;DataType&gt;OI.
+   *                     (2) All the embedded object inspectors are instances of settable&lt;DataType&gt;OI.
    *           If (1) or (2) is false, return false.
    */
   public static boolean hasAllFieldsSettable(ObjectInspector oi,

http://git-wip-us.apache.org/repos/asf/hive/blob/23e703f9/serde/src/java/org/apache/hadoop/hive/serde2/objectinspector/primitive/PrimitiveObjectInspectorFactory.java
----------------------------------------------------------------------
diff --git a/serde/src/java/org/apache/hadoop/hive/serde2/objectinspector/primitive/PrimitiveObjectInspectorFactory.java b/serde/src/java/org/apache/hadoop/hive/serde2/objectinspector/primitive/PrimitiveObjectInspectorFactory.java
index 9ea6609..2425c30 100644
--- a/serde/src/java/org/apache/hadoop/hive/serde2/objectinspector/primitive/PrimitiveObjectInspectorFactory.java
+++ b/serde/src/java/org/apache/hadoop/hive/serde2/objectinspector/primitive/PrimitiveObjectInspectorFactory.java
@@ -280,7 +280,7 @@ public final class PrimitiveObjectInspectorFactory {
 
   /**
    * Returns the PrimitiveWritableObjectInspector for the given type info
-   * @param PrimitiveTypeInfo    PrimitiveTypeInfo instance
+   * @param typeInfo PrimitiveTypeInfo instance
    * @return AbstractPrimitiveWritableObjectInspector instance
    */
   public static AbstractPrimitiveWritableObjectInspector getPrimitiveWritableObjectInspector(
@@ -316,7 +316,7 @@ public final class PrimitiveObjectInspectorFactory {
    * Returns a PrimitiveWritableObjectInspector which implements ConstantObjectInspector
    * for the PrimitiveCategory.
    *
-   * @param primitiveCategory
+   * @param typeInfo
    * @param value
    */
   public static ConstantObjectInspector getPrimitiveWritableConstantObjectInspector(
@@ -385,7 +385,7 @@ public final class PrimitiveObjectInspectorFactory {
 
   /**
    * Returns the PrimitiveJavaObjectInspector for the given PrimitiveTypeInfo instance,
-   * @param PrimitiveTypeInfo    PrimitiveTypeInfo instance
+   * @param typeInfo PrimitiveTypeInfo instance
    * @return AbstractPrimitiveJavaObjectInspector instance
    */
   public static AbstractPrimitiveJavaObjectInspector getPrimitiveJavaObjectInspector(

http://git-wip-us.apache.org/repos/asf/hive/blob/23e703f9/serde/src/java/org/apache/hadoop/hive/serde2/typeinfo/TypeInfoUtils.java
----------------------------------------------------------------------
diff --git a/serde/src/java/org/apache/hadoop/hive/serde2/typeinfo/TypeInfoUtils.java b/serde/src/java/org/apache/hadoop/hive/serde2/typeinfo/TypeInfoUtils.java
index 54964e4..9f083ec 100644
--- a/serde/src/java/org/apache/hadoop/hive/serde2/typeinfo/TypeInfoUtils.java
+++ b/serde/src/java/org/apache/hadoop/hive/serde2/typeinfo/TypeInfoUtils.java
@@ -158,7 +158,7 @@ public final class TypeInfoUtils {
 
   /**
    * Returns the array element type, if the Type is an array (Object[]), or
-   * GenericArrayType (Map<String,String>[]). Otherwise return null.
+   * GenericArrayType (Map&lt;String,String&gt;[]). Otherwise return null.
    */
   public static Type getArrayElementType(Type t) {
     if (t instanceof Class && ((Class<?>) t).isArray()) {
@@ -176,7 +176,7 @@ public final class TypeInfoUtils {
    *
    * @param size
    *          In case the last parameter of Method is an array, we will try to
-   *          return a List<TypeInfo> with the specified size by repeating the
+   *          return a List&lt;TypeInfo&gt; with the specified size by repeating the
    *          element of the array at the end. In case the size is smaller than
    *          the minimum possible number of arguments for the method, null will
    *          be returned.