You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@accumulo.apache.org by el...@apache.org on 2014/12/02 23:08:47 UTC

[1/2] accumulo git commit: Switch from TabletServer to Accumulo for the prefix.

Repository: accumulo
Updated Branches:
  refs/heads/metrics2 bb67cda91 -> 1aacbf0fb


Switch from TabletServer to Accumulo for the prefix.


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

Branch: refs/heads/metrics2
Commit: ad6bb3e4f2ffbe012b3537c76d8eb6675e2705b8
Parents: bb67cda
Author: Josh Elser <el...@apache.org>
Authored: Tue Dec 2 17:07:30 2014 -0500
Committer: Josh Elser <el...@apache.org>
Committed: Tue Dec 2 17:07:30 2014 -0500

----------------------------------------------------------------------
 .../org/apache/accumulo/tserver/TabletServer.java     | 14 +++++++-------
 1 file changed, 7 insertions(+), 7 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/ad6bb3e4/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServer.java
----------------------------------------------------------------------
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServer.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServer.java
index 2fd753d..c94bf82 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServer.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServer.java
@@ -16,6 +16,9 @@
  */
 package org.apache.accumulo.tserver;
 
+import static java.nio.charset.StandardCharsets.UTF_8;
+import static org.apache.accumulo.server.problems.ProblemType.TABLET_LOAD;
+
 import java.io.FileNotFoundException;
 import java.io.IOException;
 import java.lang.management.ManagementFactory;
@@ -49,8 +52,6 @@ import java.util.concurrent.atomic.AtomicInteger;
 import java.util.concurrent.atomic.AtomicLong;
 import java.util.concurrent.locks.ReentrantLock;
 
-import com.google.common.net.HostAndPort;
-
 import org.apache.accumulo.core.Constants;
 import org.apache.accumulo.core.client.AccumuloException;
 import org.apache.accumulo.core.client.AccumuloSecurityException;
@@ -238,8 +239,7 @@ import org.apache.thrift.server.TServer;
 import org.apache.zookeeper.KeeperException;
 import org.apache.zookeeper.KeeperException.NoNodeException;
 
-import static java.nio.charset.StandardCharsets.UTF_8;
-import static org.apache.accumulo.server.problems.ProblemType.TABLET_LOAD;
+import com.google.common.net.HostAndPort;
 
 public class TabletServer extends AccumuloServerContext implements Runnable {
   private static final Logger log = Logger.getLogger(TabletServer.class);
@@ -342,7 +342,7 @@ public class TabletServer extends AccumuloServerContext implements Runnable {
     this.resourceManager = new TabletServerResourceManager(this, fs);
     this.security = AuditedSecurityOperation.getInstance(this);
 
-    metricsSystem = DefaultMetricsSystem.initialize("TabletServer");
+    metricsSystem = DefaultMetricsSystem.initialize("Accumulo");
     mincMetrics = new TabletServerMinCMetrics(metricsSystem);
     updateMetrics = new TabletServerUpdateMetrics(metricsSystem);
     scanMetrics = new TabletServerScanMetrics(metricsSystem);
@@ -360,7 +360,7 @@ public class TabletServer extends AccumuloServerContext implements Runnable {
 
   private final AtomicLong totalQueuedMutationSize = new AtomicLong(0);
   private final ReentrantLock recoveryLock = new ReentrantLock(true);
-  
+
   private class ThriftClientHandler extends ClientServiceHandler implements TabletClientService.Iface {
 
     ThriftClientHandler() {
@@ -2216,7 +2216,7 @@ public class TabletServer extends AccumuloServerContext implements Runnable {
       recoveryLock.unlock();
     }
   }
-  
+
   public void addLoggersToMetadata(List<DfsLogger> logs, KeyExtent extent, int id) {
     if (!this.onlineTablets.containsKey(extent)) {
       log.info("Not adding " + logs.size() + " logs for extent " + extent + " as alias " + id + " tablet is offline");


[2/2] accumulo git commit: General example to get tserver sink configured.

Posted by el...@apache.org.
General example to get tserver sink configured.


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

Branch: refs/heads/metrics2
Commit: 1aacbf0fb7819da587e0f740bb8413640dd721f5
Parents: ad6bb3e
Author: Josh Elser <el...@apache.org>
Authored: Tue Dec 2 17:08:24 2014 -0500
Committer: Josh Elser <el...@apache.org>
Committed: Tue Dec 2 17:08:24 2014 -0500

----------------------------------------------------------------------
 .../hadoop-metrics2-accumulo.properties.example | 22 ++++++++++++++++++++
 1 file changed, 22 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/1aacbf0f/assemble/conf/templates/hadoop-metrics2-accumulo.properties.example
----------------------------------------------------------------------
diff --git a/assemble/conf/templates/hadoop-metrics2-accumulo.properties.example b/assemble/conf/templates/hadoop-metrics2-accumulo.properties.example
new file mode 100644
index 0000000..8e5bc5f
--- /dev/null
+++ b/assemble/conf/templates/hadoop-metrics2-accumulo.properties.example
@@ -0,0 +1,22 @@
+# Licensed to the Apache Software Foundation (ASF) under one or more
+# contributor license agreements.  See the NOTICE file distributed with
+# this work for additional information regarding copyright ownership.
+# The ASF licenses this file to You under the Apache License, Version 2.0
+# (the "License"); you may not use this file except in compliance with
+# the License.  You may obtain a copy of the License at
+#
+#     http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing, software
+# distributed under the License is distributed on an "AS IS" BASIS,
+# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+# See the License for the specific language governing permissions and
+# limitations under the License.
+
+# Write metrics to a file
+*.sink.file.class=org.apache.hadoop.metrics2.sink.FileSink
+
+# Poll collectors every ten seconds
+*.period=10
+
+accumulo.sink.file-all.filename=all.metrics