This project has retired. For details please refer to its Attic page.
HttpSenderMetrics xref
View Javadoc

1   /*
2    * Licensed to the Apache Software Foundation (ASF) under one
3    * or more contributor license agreements.  See the NOTICE file
4    * distributed with this work for additional information
5    * regarding copyright ownership.  The ASF licenses this file
6    * to you under the Apache License, Version 2.0 (the
7    * "License"); you may not use this file except in compliance
8    * with the License.  You may obtain a copy of the License at
9    *
10   *     http://www.apache.org/licenses/LICENSE-2.0
11   *
12   * Unless required by applicable law or agreed to in writing, software
13   * distributed under the License is distributed on an "AS IS" BASIS,
14   * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
15   * See the License for the specific language governing permissions and
16   * limitations under the License.
17   */
18  package org.apache.hadoop.chukwa.datacollection.sender.metrics;
19  
20  import org.apache.hadoop.metrics.MetricsContext;
21  import org.apache.hadoop.metrics.MetricsRecord;
22  import org.apache.hadoop.metrics.MetricsUtil;
23  import org.apache.hadoop.metrics.Updater;
24  import org.apache.hadoop.metrics.util.MetricsBase;
25  import org.apache.hadoop.metrics.util.MetricsRegistry;
26  import org.apache.hadoop.metrics.util.MetricsTimeVaryingInt;
27  
28  public class HttpSenderMetrics implements Updater {
29  
30    public MetricsRegistry registry = new MetricsRegistry();
31    private MetricsRecord metricsRecord;
32    private HttpSenderActivityMBean mbean;
33    
34    
35    public MetricsTimeVaryingInt collectorRollover =
36      new MetricsTimeVaryingInt("collectorRollover", registry,"number of collector rollovert");
37    
38    public MetricsTimeVaryingInt httpPost =
39      new MetricsTimeVaryingInt("httpPost", registry,"number of HTTP post");
40    
41    public MetricsTimeVaryingInt httpException =
42      new MetricsTimeVaryingInt("httpException", registry,"number of HTTP Exception");
43  
44    public MetricsTimeVaryingInt httpThrowable =
45      new MetricsTimeVaryingInt("httpThrowable", registry,"number of HTTP Throwable exception");
46    
47    public MetricsTimeVaryingInt httpTimeOutException =
48      new MetricsTimeVaryingInt("httpTimeOutException", registry,"number of HTTP TimeOutException");
49    
50    /** Creates a new instance of HttpSenderMetrics 
51     * @param processName 
52     * @param recordName */
53    public HttpSenderMetrics(String processName, String recordName) {
54        MetricsContext context = MetricsUtil.getContext(processName);
55        metricsRecord = MetricsUtil.createRecord(context, recordName);
56        metricsRecord.setTag("process", processName);
57        mbean = new HttpSenderActivityMBean(registry, recordName);
58        context.registerUpdater(this);
59    }
60  
61  
62    /**
63     * Since this object is a registered updater, this method will be called
64     * periodically, e.g. every 5 seconds.
65     */
66    public void doUpdates(MetricsContext unused) {
67      synchronized (this) {
68        for (MetricsBase m : registry.getMetricsList()) {
69          m.pushMetric(metricsRecord);
70        }
71      }
72      metricsRecord.update();
73    }
74  
75    public void shutdown() {
76      if (mbean != null)
77        mbean.shutdown();
78    }
79  
80  }