You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hbase.apache.org by ja...@apache.org on 2019/08/11 21:15:56 UTC

[hbase] branch branch-1.4 updated: HBASE-22725 Remove all remaining Javadoc warnings

This is an automated email from the ASF dual-hosted git repository.

janh pushed a commit to branch branch-1.4
in repository https://gitbox.apache.org/repos/asf/hbase.git


The following commit(s) were added to refs/heads/branch-1.4 by this push:
     new f2c8990  HBASE-22725 Remove all remaining Javadoc warnings
f2c8990 is described below

commit f2c8990a90179376446696c010e62521aa969e82
Author: syedmurtazahassan <sy...@gmail.com>
AuthorDate: Sun Aug 11 21:48:08 2019 +0200

    HBASE-22725 Remove all remaining Javadoc warnings
    
    Signed-off-by: stack <st...@apache.org>
    Signed-off-by: Jan Hentschel <ja...@ultratendency.com>
---
 .../java/org/apache/hadoop/hbase/client/Table.java |  2 +-
 .../hadoop/hbase/client/coprocessor/Batch.java     |  5 +++--
 .../apache/hadoop/hbase/regionserver/HRegion.java  |  2 +-
 .../apache/hadoop/hbase/HBaseTestingUtility.java   | 23 +++++++++++-----------
 .../hadoop/hbase/master/MockRegionServer.java      | 15 +++++++-------
 5 files changed, 24 insertions(+), 23 deletions(-)

diff --git a/hbase-client/src/main/java/org/apache/hadoop/hbase/client/Table.java b/hbase-client/src/main/java/org/apache/hadoop/hbase/client/Table.java
index 5e1935d..1d30426 100644
--- a/hbase-client/src/main/java/org/apache/hadoop/hbase/client/Table.java
+++ b/hbase-client/src/main/java/org/apache/hadoop/hbase/client/Table.java
@@ -219,7 +219,7 @@ public interface Table extends Closeable {
 
   /**
    * Puts some data in the table.
-   * 
+   *
    * @param put The data to put.
    * @throws IOException if a remote or network exception occurs.
    * @since 0.20.0
diff --git a/hbase-client/src/main/java/org/apache/hadoop/hbase/client/coprocessor/Batch.java b/hbase-client/src/main/java/org/apache/hadoop/hbase/client/coprocessor/Batch.java
index 55343ac..c9261ef 100644
--- a/hbase-client/src/main/java/org/apache/hadoop/hbase/client/coprocessor/Batch.java
+++ b/hbase-client/src/main/java/org/apache/hadoop/hbase/client/coprocessor/Batch.java
@@ -40,9 +40,10 @@ public abstract class Batch {
    * the implementations {@link Batch.Call#call(Object)} method will be invoked
    * with a proxy to each region's coprocessor {@link com.google.protobuf.Service} implementation.
    * </p>
-   * @see org.apache.hadoop.hbase.client.coprocessor
+   * @see org.apache.hadoop.hbase.client.coprocessor.Batch
    * @see org.apache.hadoop.hbase.client.HTable#coprocessorService(byte[])
-   * @see org.apache.hadoop.hbase.client.HTable#coprocessorService(Class, byte[], byte[], org.apache.hadoop.hbase.client.coprocessor.Batch.Call)
+   * @see org.apache.hadoop.hbase.client.HTable#coprocessorService(Class, byte[], byte[],
+   * org.apache.hadoop.hbase.client.coprocessor.Batch.Call)
    * @param <T> the instance type to be passed to
    * {@link Batch.Call#call(Object)}
    * @param <R> the return type from {@link Batch.Call#call(Object)}
diff --git a/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/HRegion.java b/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/HRegion.java
index 6761810..d383ec8 100644
--- a/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/HRegion.java
+++ b/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/HRegion.java
@@ -3121,7 +3121,7 @@ public class HRegion implements HeapSize, PropagatingConfigurationObserver, Regi
    * @param batchOp contains the list of mutations
    * @return an array of OperationStatus which internally contains the
    *         OperationStatusCode and the exceptionMessage if any.
-   * @throws IOException
+   * @throws IOException if an IO problem is encountered
    */
   OperationStatus[] batchMutate(BatchOperationInProgress<?> batchOp) throws IOException {
     boolean initialized = false;
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/HBaseTestingUtility.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/HBaseTestingUtility.java
index 99bdea1..643ed21 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/HBaseTestingUtility.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/HBaseTestingUtility.java
@@ -2119,14 +2119,14 @@ public class HBaseTestingUtility extends HBaseCommonTestingUtility {
   }
 
   /**
-   * @param tableName
-   * @param startKey
-   * @param stopKey
-   * @param callingMethod
-   * @param conf
-   * @param isReadOnly
-   * @param families
-   * @throws IOException
+   * @param tableName the name of the table
+   * @param startKey the start key of the region
+   * @param stopKey the stop key of the region
+   * @param callingMethod the name of the calling method probably a test method
+   * @param conf the configuration to use
+   * @param isReadOnly {@code true} if the table is read only, {@code false} otherwise
+   * @param families the column families to use
+   * @throws IOException if an IO problem is encountered
    * @return A region on which you must call
    *         {@link HRegion#closeHRegion(HRegion)} when done.
    */
@@ -3278,10 +3278,9 @@ public class HBaseTestingUtility extends HBaseCommonTestingUtility {
    * Waits for a table to be 'enabled'.  Enabled means that table is set as 'enabled' and the
    * regions have been all assigned.  Will timeout after default period (30 seconds)
    * @see #waitTableAvailable(byte[])
-   * @param table Table to wait on.
-   * @param table
-   * @throws InterruptedException
-   * @throws IOException
+   * @param table the table to wait on.
+   * @throws InterruptedException if interrupted while waiting
+   * @throws IOException if an IO problem is encountered
    */
   public void waitTableEnabled(TableName table)
       throws InterruptedException, IOException {
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/master/MockRegionServer.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/master/MockRegionServer.java
index 42c04e4..0c673ce 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/master/MockRegionServer.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/master/MockRegionServer.java
@@ -132,8 +132,8 @@ ClientProtos.ClientService.BlockingInterface, RegionServerServices {
   private final Random random = new Random();
 
   /**
-   * Map of regions to map of rows and {@link Results}.  Used as data source when
-   * {@link MockRegionServer#get(byte[], Get)} is called. Because we have a byte
+   * Map of regions to map of rows and {@link Result}. Used as data source when
+   * {@link #get(RpcController, ClientProtos.GetRequest)} is called. Because we have a byte
    * key, need to use TreeMap and provide a Comparator.  Use
    * {@link #setGetResult(byte[], byte[], Result)} filling this map.
    */
@@ -187,10 +187,11 @@ ClientProtos.ClientService.BlockingInterface, RegionServerServices {
   }
 
   /**
-   * Use this method filling the backing data source used by {@link #get(byte[], Get)}
-   * @param regionName
-   * @param row
-   * @param r
+   * Use this method filling the backing data source used by
+   * {@link #get(RpcController, ClientProtos.GetRequest)}
+   * @param regionName the region name to assign
+   * @param row the row key
+   * @param r the single row result
    */
   void setGetResult(final byte [] regionName, final byte [] row, final Result r) {
     Map<byte [], Result> value = this.gets.get(regionName);
@@ -548,7 +549,7 @@ ClientProtos.ClientService.BlockingInterface, RegionServerServices {
     // TODO Auto-generated method stub
     return null;
   }
-  
+
   @Override
   public Set<TableName> getOnlineTables() {
     return null;