You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hbase.apache.org by sy...@apache.org on 2016/02/13 21:10:30 UTC

[19/22] hbase git commit: HBASE-15219 Revert pending verification of test result

HBASE-15219 Revert pending verification of test result


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

Branch: refs/heads/hbase-12439
Commit: 454e45f50df0038e2c67368c47f9395ebee7cf69
Parents: 85e1d9a
Author: tedyu <yu...@gmail.com>
Authored: Fri Feb 12 12:06:48 2016 -0800
Committer: tedyu <yu...@gmail.com>
Committed: Fri Feb 12 12:06:48 2016 -0800

----------------------------------------------------------------------
 .../org/apache/hadoop/hbase/tool/Canary.java    | 55 ++++----------------
 src/main/asciidoc/_chapters/ops_mgt.adoc        | 11 ----
 2 files changed, 9 insertions(+), 57 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/hbase/blob/454e45f5/hbase-server/src/main/java/org/apache/hadoop/hbase/tool/Canary.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/main/java/org/apache/hadoop/hbase/tool/Canary.java b/hbase-server/src/main/java/org/apache/hadoop/hbase/tool/Canary.java
index 9248c71..3c7ae64 100644
--- a/hbase-server/src/main/java/org/apache/hadoop/hbase/tool/Canary.java
+++ b/hbase-server/src/main/java/org/apache/hadoop/hbase/tool/Canary.java
@@ -94,11 +94,9 @@ import org.apache.hadoop.util.ToolRunner;
 public final class Canary implements Tool {
   // Sink interface used by the canary to outputs information
   public interface Sink {
-    public long getReadFailureCount();
     public void publishReadFailure(HRegionInfo region, Exception e);
     public void publishReadFailure(HRegionInfo region, HColumnDescriptor column, Exception e);
     public void publishReadTiming(HRegionInfo region, HColumnDescriptor column, long msTime);
-    public long getWriteFailureCount();
     public void publishWriteFailure(HRegionInfo region, Exception e);
     public void publishWriteFailure(HRegionInfo region, HColumnDescriptor column, Exception e);
     public void publishWriteTiming(HRegionInfo region, HColumnDescriptor column, long msTime);
@@ -113,23 +111,13 @@ public final class Canary implements Tool {
   // Simple implementation of canary sink that allows to plot on
   // file or standard output timings or failures.
   public static class StdOutSink implements Sink {
-    protected AtomicLong readFailureCount = new AtomicLong(0),
-        writeFailureCount = new AtomicLong(0);
-
-    @Override
-    public long getReadFailureCount() {
-      return readFailureCount.get();
-    }
-
     @Override
     public void publishReadFailure(HRegionInfo region, Exception e) {
-      readFailureCount.incrementAndGet();
       LOG.error(String.format("read from region %s failed", region.getRegionNameAsString()), e);
     }
 
     @Override
     public void publishReadFailure(HRegionInfo region, HColumnDescriptor column, Exception e) {
-      readFailureCount.incrementAndGet();
       LOG.error(String.format("read from region %s column family %s failed",
                 region.getRegionNameAsString(), column.getNameAsString()), e);
     }
@@ -141,19 +129,12 @@ public final class Canary implements Tool {
     }
 
     @Override
-    public long getWriteFailureCount() {
-      return writeFailureCount.get();
-    }
-
-    @Override
     public void publishWriteFailure(HRegionInfo region, Exception e) {
-      writeFailureCount.incrementAndGet();
       LOG.error(String.format("write to region %s failed", region.getRegionNameAsString()), e);
     }
 
     @Override
     public void publishWriteFailure(HRegionInfo region, HColumnDescriptor column, Exception e) {
-      writeFailureCount.incrementAndGet();
       LOG.error(String.format("write to region %s column family %s failed",
         region.getRegionNameAsString(), column.getNameAsString()), e);
     }
@@ -169,7 +150,6 @@ public final class Canary implements Tool {
 
     @Override
     public void publishReadFailure(String table, String server) {
-      readFailureCount.incrementAndGet();
       LOG.error(String.format("Read from table:%s on region server:%s", table, server));
     }
 
@@ -455,7 +435,6 @@ public final class Canary implements Tool {
   private boolean regionServerMode = false;
   private boolean regionServerAllRegions = false;
   private boolean writeSniffing = false;
-  private boolean treatFailureAsError = false;
   private TableName writeTableName = DEFAULT_WRITE_TABLE_NAME;
 
   private ExecutorService executor; // threads to retrieve data from regionservers
@@ -519,8 +498,6 @@ public final class Canary implements Tool {
           this.regionServerAllRegions = true;
         } else if(cmd.equals("-writeSniffing")) {
           this.writeSniffing = true;
-        } else if(cmd.equals("-treatFailureAsError")) {
-          this.treatFailureAsError = true;
         } else if (cmd.equals("-e")) {
           this.useRegExp = true;
         } else if (cmd.equals("-t")) {
@@ -625,7 +602,7 @@ public final class Canary implements Tool {
             }
           }
 
-          if (this.failOnError && monitor.finalCheckForErrors()) {
+          if (this.failOnError && monitor.hasError()) {
             monitorThread.interrupt();
             return monitor.errorCode;
           }
@@ -661,7 +638,6 @@ public final class Canary implements Tool {
         " default is true");
     System.err.println("   -t <N>         timeout for a check, default is 600000 (milisecs)");
     System.err.println("   -writeSniffing enable the write sniffing in canary");
-    System.err.println("   -treatFailureAsError treats read / write failure as error");
     System.err.println("   -writeTable    The table used for write sniffing."
         + " Default is hbase:canary");
     System.err
@@ -689,12 +665,11 @@ public final class Canary implements Tool {
     if (this.regionServerMode) {
       monitor =
           new RegionServerMonitor(connection, monitorTargets, this.useRegExp,
-              (ExtendedSink) this.sink, this.executor, this.regionServerAllRegions,
-              this.treatFailureAsError);
+              (ExtendedSink) this.sink, this.executor, this.regionServerAllRegions);
     } else {
       monitor =
           new RegionMonitor(connection, monitorTargets, this.useRegExp, this.sink, this.executor,
-              this.writeSniffing, this.writeTableName, this.treatFailureAsError);
+              this.writeSniffing, this.writeTableName);
     }
     return monitor;
   }
@@ -706,7 +681,6 @@ public final class Canary implements Tool {
     protected Admin admin;
     protected String[] targets;
     protected boolean useRegExp;
-    protected boolean treatFailureAsError;
     protected boolean initialized = false;
 
     protected boolean done = false;
@@ -722,27 +696,18 @@ public final class Canary implements Tool {
       return errorCode != 0;
     }
 
-    public boolean finalCheckForErrors() {
-      if (errorCode != 0) {
-        return true;
-      }
-      return treatFailureAsError &&
-          (sink.getReadFailureCount() > 0 || sink.getWriteFailureCount() > 0);
-    }
-
     @Override
     public void close() throws IOException {
       if (this.admin != null) this.admin.close();
     }
 
     protected Monitor(Connection connection, String[] monitorTargets, boolean useRegExp, Sink sink,
-        ExecutorService executor, boolean treatFailureAsError) {
+        ExecutorService executor) {
       if (null == connection) throw new IllegalArgumentException("connection shall not be null");
 
       this.connection = connection;
       this.targets = monitorTargets;
       this.useRegExp = useRegExp;
-      this.treatFailureAsError = treatFailureAsError;
       this.sink = sink;
       this.executor = executor;
     }
@@ -782,9 +747,8 @@ public final class Canary implements Tool {
     private int checkPeriod;
 
     public RegionMonitor(Connection connection, String[] monitorTargets, boolean useRegExp,
-        Sink sink, ExecutorService executor, boolean writeSniffing, TableName writeTableName,
-        boolean treatFailureAsError) {
-      super(connection, monitorTargets, useRegExp, sink, executor, treatFailureAsError);
+        Sink sink, ExecutorService executor, boolean writeSniffing, TableName writeTableName) {
+      super(connection, monitorTargets, useRegExp, sink, executor);
       Configuration conf = connection.getConfiguration();
       this.writeSniffing = writeSniffing;
       this.writeTableName = writeTableName;
@@ -1028,9 +992,8 @@ public final class Canary implements Tool {
     private boolean allRegions;
 
     public RegionServerMonitor(Connection connection, String[] monitorTargets, boolean useRegExp,
-        ExtendedSink sink, ExecutorService executor, boolean allRegions,
-        boolean treatFailureAsError) {
-      super(connection, monitorTargets, useRegExp, sink, executor, treatFailureAsError);
+        ExtendedSink sink, ExecutorService executor, boolean allRegions) {
+      super(connection, monitorTargets, useRegExp, sink, executor);
       this.allRegions = allRegions;
     }
 
@@ -1125,7 +1088,7 @@ public final class Canary implements Tool {
         }
       } catch (InterruptedException e) {
         this.errorCode = ERROR_EXIT_CODE;
-        LOG.error("Sniff regionserver interrupted!", e);
+        LOG.error("Sniff regionserver failed!", e);
       }
     }
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/454e45f5/src/main/asciidoc/_chapters/ops_mgt.adoc
----------------------------------------------------------------------
diff --git a/src/main/asciidoc/_chapters/ops_mgt.adoc b/src/main/asciidoc/_chapters/ops_mgt.adoc
index 578d66f..0f93785 100644
--- a/src/main/asciidoc/_chapters/ops_mgt.adoc
+++ b/src/main/asciidoc/_chapters/ops_mgt.adoc
@@ -93,7 +93,6 @@ Usage: bin/hbase org.apache.hadoop.hbase.tool.Canary [opts] [table1 [table2]...]
    -f <B>         stop whole program if first error occurs, default is true
    -t <N>         timeout for a check, default is 600000 (milliseconds)
    -writeSniffing enable the write sniffing in canary
-   -treatFailureAsError treats read / write failure as error
    -writeTable    The table used for write sniffing. Default is hbase:canary
    -D<configProperty>=<value> assigning or override the configuration params
 ----
@@ -216,16 +215,6 @@ $ ${HBASE_HOME}/bin/hbase canary -writeSniffing -writeTable ns:canary
 The default value size of each put is 10 bytes and you can set it by the config key:
 `hbase.canary.write.value.size`.
 
-==== Treat read / write failure as error
-
-By default, the canary tool only logs read failure, due to e.g. RetriesExhaustedException,
-while returning normal exit code. To treat read / write failure as error, you can run canary
-with the `-treatFailureAsError` option. When enabled, read / write failure would result in error
-exit code.
-----
-$ ${HBASE_HOME}/bin/hbase canary --treatFailureAsError
-----
-
 ==== Running Canary in a Kerberos-enabled Cluster
 
 To run Canary in a Kerberos-enabled cluster, configure the following two properties in _hbase-site.xml_: