You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hive.apache.org by ai...@apache.org on 2016/10/14 16:04:06 UTC

hive git commit: HIVE-14839: Improve the stability of TestSessionManagerMetrics (Marta Kuczora, reviewed by Aihua Xu)

Repository: hive
Updated Branches:
  refs/heads/master aed21d0b7 -> f42c89ca4


HIVE-14839: Improve the stability of TestSessionManagerMetrics (Marta Kuczora, reviewed by Aihua Xu)


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

Branch: refs/heads/master
Commit: f42c89ca47298ed3f8ecd7a9c3154cfcb9468e7f
Parents: aed21d0
Author: Aihua Xu <ai...@apache.org>
Authored: Fri Oct 14 12:03:22 2016 -0400
Committer: Aihua Xu <ai...@apache.org>
Committed: Fri Oct 14 12:03:22 2016 -0400

----------------------------------------------------------------------
 .../cli/session/TestSessionManagerMetrics.java  | 83 ++++++++++++++------
 1 file changed, 60 insertions(+), 23 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/hive/blob/f42c89ca/service/src/test/org/apache/hive/service/cli/session/TestSessionManagerMetrics.java
----------------------------------------------------------------------
diff --git a/service/src/test/org/apache/hive/service/cli/session/TestSessionManagerMetrics.java b/service/src/test/org/apache/hive/service/cli/session/TestSessionManagerMetrics.java
index 5511c54..82126c0 100644
--- a/service/src/test/org/apache/hive/service/cli/session/TestSessionManagerMetrics.java
+++ b/service/src/test/org/apache/hive/service/cli/session/TestSessionManagerMetrics.java
@@ -18,6 +18,11 @@
 
 package org.apache.hive.service.cli.session;
 
+import java.util.concurrent.BrokenBarrierException;
+import java.util.concurrent.CyclicBarrier;
+import java.util.concurrent.TimeUnit;
+import java.util.concurrent.TimeoutException;
+
 import org.apache.hadoop.hive.common.metrics.MetricsTestUtils;
 import org.apache.hadoop.hive.common.metrics.common.MetricsConstant;
 import org.apache.hadoop.hive.common.metrics.common.MetricsFactory;
@@ -25,11 +30,10 @@ import org.apache.hadoop.hive.common.metrics.metrics2.CodahaleMetrics;
 import org.apache.hadoop.hive.common.metrics.metrics2.MetricsReporting;
 import org.apache.hadoop.hive.conf.HiveConf;
 import org.apache.hive.service.server.HiveServer2;
+import org.junit.Assert;
 import org.junit.BeforeClass;
 import org.junit.Test;
 
-import java.io.File;
-
 /**
  * Test metrics from SessionManager.
  */
@@ -37,6 +41,13 @@ public class TestSessionManagerMetrics {
 
   private static SessionManager sm;
   private static CodahaleMetrics metrics;
+  private static final int BARRIER_AWAIT_TIMEOUT = 30;
+  private static final String FAIL_TO_START_MSG = "The tasks could not be started within "
+      + BARRIER_AWAIT_TIMEOUT + " seconds before the %s metrics verification.";
+  private static final String FAIL_TO_COMPLETE_MSG = "The tasks could not be completed within "
+      + BARRIER_AWAIT_TIMEOUT + " seconds after the %s metrics verification.";
+  private final CyclicBarrier ready = new CyclicBarrier(3);
+  private final CyclicBarrier completed = new CyclicBarrier(3);
 
   @BeforeClass
   public static void setup() throws Exception {
@@ -45,7 +56,6 @@ public class TestSessionManagerMetrics {
     conf.setIntVar(HiveConf.ConfVars.HIVE_SERVER2_ASYNC_EXEC_WAIT_QUEUE_SIZE, 10);
     conf.setVar(HiveConf.ConfVars.HIVE_SERVER2_ASYNC_EXEC_KEEPALIVE_TIME, "1000000s");
 
-
     conf.setBoolVar(HiveConf.ConfVars.HIVE_SERVER2_METRICS_ENABLED, true);
     conf.setBoolVar(HiveConf.ConfVars.HIVE_SUPPORT_CONCURRENCY, false);
     conf.setVar(HiveConf.ConfVars.HIVE_METRICS_REPORTER, MetricsReporting.JSON_FILE.name() + "," + MetricsReporting.JMX.name());
@@ -59,42 +69,69 @@ public class TestSessionManagerMetrics {
     metrics = (CodahaleMetrics) MetricsFactory.getInstance();
   }
 
-  final Object barrier = new Object();
-
   class BarrierRunnable implements Runnable {
     @Override
     public void run() {
-      synchronized (barrier) {
-        try {
-          barrier.wait();
-        } catch (InterruptedException e) {
-          throw new RuntimeException(e);
-        }
+      try {
+        ready.await();
+        completed.await();
+      } catch (InterruptedException | BrokenBarrierException e) {
+        throw new RuntimeException(e);
       }
     }
   }
 
   /**
    * Tests metrics regarding async thread pool.
+   *
+   * The test does the following steps:
+   * - Submit four tasks
+   * - Wait with the metrics verification, until the first two tasks are running.
+   * If, for some reason, the tasks are not started within a timeout period, make the test fail.
+   * - Make the tasks wait until the metrics are checked.
+   * - Verify the metrics. Both the EXEC_ASYNC_POOL_SIZE and EXEC_ASYNC_QUEUE_SIZE should be 2.
+   * - Let the first two tasks complete, so the remaining two tasks can be removed from the queue and started.
+   * - Wait until the remaining tasks are running.
+   * Do the metrics check only if they are started to avoid the failures when the queue size was not 0.
+   * If, for some reason, the tasks are not started within a timeout period, make the test fail.
+   * - Verify the metrics.
+   * The EXEC_ASYNC_POOL_SIZE should be 2 and the EXEC_ASYNC_QUEUE_SIZE should be 0.
+   * - Let the remaining tasks complete.
    */
   @Test
   public void testThreadPoolMetrics() throws Exception {
 
-    sm.submitBackgroundOperation(new BarrierRunnable());
-    sm.submitBackgroundOperation(new BarrierRunnable());
-    sm.submitBackgroundOperation(new BarrierRunnable());
-    sm.submitBackgroundOperation(new BarrierRunnable());
+    String errorMessage = null;
+    try {
+      sm.submitBackgroundOperation(new BarrierRunnable());
+      sm.submitBackgroundOperation(new BarrierRunnable());
+      sm.submitBackgroundOperation(new BarrierRunnable());
+      sm.submitBackgroundOperation(new BarrierRunnable());
+
+      errorMessage = String.format(FAIL_TO_START_MSG, "first");
+      ready.await(BARRIER_AWAIT_TIMEOUT, TimeUnit.SECONDS);
+      ready.reset();
+
+      String json = metrics.dumpJson();
+      MetricsTestUtils.verifyMetricsJson(json, MetricsTestUtils.GAUGE, MetricsConstant.EXEC_ASYNC_POOL_SIZE, 2);
+      MetricsTestUtils.verifyMetricsJson(json, MetricsTestUtils.GAUGE, MetricsConstant.EXEC_ASYNC_QUEUE_SIZE, 2);
+
+      errorMessage = String.format(FAIL_TO_COMPLETE_MSG, "first");
+      completed.await(BARRIER_AWAIT_TIMEOUT, TimeUnit.SECONDS);
+      completed.reset();
+
+      errorMessage = String.format(FAIL_TO_START_MSG, "second");
+      ready.await(BARRIER_AWAIT_TIMEOUT, TimeUnit.SECONDS);
 
-    String json = metrics.dumpJson();
+      json = metrics.dumpJson();
+      MetricsTestUtils.verifyMetricsJson(json, MetricsTestUtils.GAUGE, MetricsConstant.EXEC_ASYNC_POOL_SIZE, 2);
+      MetricsTestUtils.verifyMetricsJson(json, MetricsTestUtils.GAUGE, MetricsConstant.EXEC_ASYNC_QUEUE_SIZE, 0);
 
-    MetricsTestUtils.verifyMetricsJson(json, MetricsTestUtils.GAUGE, MetricsConstant.EXEC_ASYNC_POOL_SIZE, 2);
-    MetricsTestUtils.verifyMetricsJson(json, MetricsTestUtils.GAUGE, MetricsConstant.EXEC_ASYNC_QUEUE_SIZE, 2);
+      errorMessage = String.format(FAIL_TO_COMPLETE_MSG, "second");
+      completed.await(BARRIER_AWAIT_TIMEOUT, TimeUnit.SECONDS);
 
-    synchronized (barrier) {
-      barrier.notifyAll();
+    } catch (TimeoutException e) {
+      Assert.fail(errorMessage);
     }
-    json = metrics.dumpJson();
-    MetricsTestUtils.verifyMetricsJson(json, MetricsTestUtils.GAUGE, MetricsConstant.EXEC_ASYNC_POOL_SIZE, 2);
-    MetricsTestUtils.verifyMetricsJson(json, MetricsTestUtils.GAUGE, MetricsConstant.EXEC_ASYNC_QUEUE_SIZE, 0);
   }
 }