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  
19  package org.apache.hadoop.hbase.regionserver;
20  
21  import org.apache.hadoop.hbase.metrics.BaseSource;
22  
23  /**
24   * Interface for classes that expose metrics about the regionserver.
25   */
26  public interface MetricsRegionServerSource extends BaseSource {
27  
28    /**
29     * The name of the metrics
30     */
31    String METRICS_NAME = "Server";
32  
33    /**
34     * The name of the metrics context that metrics will be under.
35     */
36    String METRICS_CONTEXT = "regionserver";
37  
38    /**
39     * Description
40     */
41    String METRICS_DESCRIPTION = "Metrics about HBase RegionServer";
42  
43    /**
44     * The name of the metrics context that metrics will be under in jmx
45     */
46    String METRICS_JMX_CONTEXT = "RegionServer,sub=" + METRICS_NAME;
47  
48    /**
49     * Update the Put time histogram
50     *
51     * @param t time it took
52     */
53    void updatePut(long t);
54  
55    /**
56     * Update the Delete time histogram
57     *
58     * @param t time it took
59     */
60    void updateDelete(long t);
61  
62    /**
63     * Update the Get time histogram .
64     *
65     * @param t time it took
66     */
67    void updateGet(long t);
68  
69    /**
70     * Update the Increment time histogram.
71     *
72     * @param t time it took
73     */
74    void updateIncrement(long t);
75  
76    /**
77     * Update the Append time histogram.
78     *
79     * @param t time it took
80     */
81    void updateAppend(long t);
82  
83    /**
84     * Update the Replay time histogram.
85     *
86     * @param t time it took
87     */
88    void updateReplay(long t);
89  
90    /**
91     * Update the scan size.
92     *
93     * @param scanSize size of the scan
94     */
95    void updateScannerNext(long scanSize);
96  
97    /**
98     * Increment the number of slow Puts that have happened.
99     */
100   void incrSlowPut();
101 
102   /**
103    * Increment the number of slow Deletes that have happened.
104    */
105   void incrSlowDelete();
106 
107   /**
108    * Increment the number of slow Gets that have happened.
109    */
110   void incrSlowGet();
111 
112   /**
113    * Increment the number of slow Increments that have happened.
114    */
115   void incrSlowIncrement();
116 
117   /**
118    * Increment the number of slow Appends that have happened.
119    */
120   void incrSlowAppend();
121 
122   /**
123    * Update the split transaction time histogram
124    * @param t time it took, in milliseconds
125    */
126   void updateSplitTime(long t);
127 
128   /**
129    * Increment number of a requested splits
130    */
131   void incrSplitRequest();
132 
133   /**
134    * Increment number of successful splits
135    */
136   void incrSplitSuccess();
137 
138   /**
139    * Update the flush time histogram
140    * @param t time it took, in milliseconds
141    */
142   void updateFlushTime(long t);
143 
144   // Strings used for exporting to metrics system.
145   String REGION_COUNT = "regionCount";
146   String REGION_COUNT_DESC = "Number of regions";
147   String STORE_COUNT = "storeCount";
148   String STORE_COUNT_DESC = "Number of Stores";
149   String WALFILE_COUNT = "hlogFileCount";
150   String WALFILE_COUNT_DESC = "Number of WAL Files";
151   String WALFILE_SIZE = "hlogFileSize";
152   String WALFILE_SIZE_DESC = "Size of all WAL Files";
153   String STOREFILE_COUNT = "storeFileCount";
154   String STOREFILE_COUNT_DESC = "Number of Store Files";
155   String MEMSTORE_SIZE = "memStoreSize";
156   String MEMSTORE_SIZE_DESC = "Size of the memstore";
157   String STOREFILE_SIZE = "storeFileSize";
158   String STOREFILE_SIZE_DESC = "Size of storefiles being served.";
159   String TOTAL_REQUEST_COUNT = "totalRequestCount";
160   String TOTAL_REQUEST_COUNT_DESC =
161       "Total number of requests this RegionServer has answered.";
162   String READ_REQUEST_COUNT = "readRequestCount";
163   String READ_REQUEST_COUNT_DESC =
164       "Number of read requests this region server has answered.";
165   String WRITE_REQUEST_COUNT = "writeRequestCount";
166   String WRITE_REQUEST_COUNT_DESC =
167       "Number of mutation requests this region server has answered.";
168   String CHECK_MUTATE_FAILED_COUNT = "checkMutateFailedCount";
169   String CHECK_MUTATE_FAILED_COUNT_DESC =
170       "Number of Check and Mutate calls that failed the checks.";
171   String CHECK_MUTATE_PASSED_COUNT = "checkMutatePassedCount";
172   String CHECK_MUTATE_PASSED_COUNT_DESC =
173       "Number of Check and Mutate calls that passed the checks.";
174   String STOREFILE_INDEX_SIZE = "storeFileIndexSize";
175   String STOREFILE_INDEX_SIZE_DESC = "Size of indexes in storefiles on disk.";
176   String STATIC_INDEX_SIZE = "staticIndexSize";
177   String STATIC_INDEX_SIZE_DESC = "Uncompressed size of the static indexes.";
178   String STATIC_BLOOM_SIZE = "staticBloomSize";
179   String STATIC_BLOOM_SIZE_DESC =
180       "Uncompressed size of the static bloom filters.";
181   String NUMBER_OF_MUTATIONS_WITHOUT_WAL = "mutationsWithoutWALCount";
182   String NUMBER_OF_MUTATIONS_WITHOUT_WAL_DESC =
183       "Number of mutations that have been sent by clients with the write ahead logging turned off.";
184   String DATA_SIZE_WITHOUT_WAL = "mutationsWithoutWALSize";
185   String DATA_SIZE_WITHOUT_WAL_DESC =
186       "Size of data that has been sent by clients with the write ahead logging turned off.";
187   String PERCENT_FILES_LOCAL = "percentFilesLocal";
188   String PERCENT_FILES_LOCAL_DESC =
189       "The percent of HFiles that are stored on the local hdfs data node.";
190   String PERCENT_FILES_LOCAL_SECONDARY_REGIONS = "percentFilesLocalSecondaryRegions";
191   String PERCENT_FILES_LOCAL_SECONDARY_REGIONS_DESC =
192     "The percent of HFiles used by secondary regions that are stored on the local hdfs data node.";
193   String SPLIT_QUEUE_LENGTH = "splitQueueLength";
194   String SPLIT_QUEUE_LENGTH_DESC = "Length of the queue for splits.";
195   String COMPACTION_QUEUE_LENGTH = "compactionQueueLength";
196   String LARGE_COMPACTION_QUEUE_LENGTH = "largeCompactionQueueLength";
197   String SMALL_COMPACTION_QUEUE_LENGTH = "smallCompactionQueueLength";
198   String COMPACTION_QUEUE_LENGTH_DESC = "Length of the queue for compactions.";
199   String FLUSH_QUEUE_LENGTH = "flushQueueLength";
200   String FLUSH_QUEUE_LENGTH_DESC = "Length of the queue for region flushes";
201   String BLOCK_CACHE_FREE_SIZE = "blockCacheFreeSize";
202   String BLOCK_CACHE_FREE_DESC =
203       "Size of the block cache that is not occupied.";
204   String BLOCK_CACHE_COUNT = "blockCacheCount";
205   String BLOCK_CACHE_COUNT_DESC = "Number of block in the block cache.";
206   String BLOCK_CACHE_SIZE = "blockCacheSize";
207   String BLOCK_CACHE_SIZE_DESC = "Size of the block cache.";
208   String BLOCK_CACHE_HIT_COUNT = "blockCacheHitCount";
209   String BLOCK_CACHE_HIT_COUNT_DESC = "Count of the hit on the block cache.";
210   String BLOCK_CACHE_MISS_COUNT = "blockCacheMissCount";
211   String BLOCK_COUNT_MISS_COUNT_DESC =
212       "Number of requests for a block that missed the block cache.";
213   String BLOCK_CACHE_EVICTION_COUNT = "blockCacheEvictionCount";
214   String BLOCK_CACHE_EVICTION_COUNT_DESC =
215       "Count of the number of blocks evicted from the block cache.";
216   String BLOCK_CACHE_HIT_PERCENT = "blockCacheCountHitPercent";
217   String BLOCK_CACHE_HIT_PERCENT_DESC =
218       "Percent of block cache requests that are hits";
219   String BLOCK_CACHE_EXPRESS_HIT_PERCENT = "blockCacheExpressHitPercent";
220   String BLOCK_CACHE_EXPRESS_HIT_PERCENT_DESC =
221       "The percent of the time that requests with the cache turned on hit the cache.";
222   String RS_START_TIME_NAME = "regionServerStartTime";
223   String ZOOKEEPER_QUORUM_NAME = "zookeeperQuorum";
224   String SERVER_NAME_NAME = "serverName";
225   String CLUSTER_ID_NAME = "clusterId";
226   String RS_START_TIME_DESC = "RegionServer Start Time";
227   String ZOOKEEPER_QUORUM_DESC = "Zookeeper Quorum";
228   String SERVER_NAME_DESC = "Server Name";
229   String CLUSTER_ID_DESC = "Cluster Id";
230   String UPDATES_BLOCKED_TIME = "updatesBlockedTime";
231   String UPDATES_BLOCKED_DESC =
232       "Number of MS updates have been blocked so that the memstore can be flushed.";
233   String DELETE_KEY = "delete";
234   String GET_KEY = "get";
235   String INCREMENT_KEY = "increment";
236   String MUTATE_KEY = "mutate";
237   String APPEND_KEY = "append";
238   String REPLAY_KEY = "replay";
239   String SCAN_NEXT_KEY = "scanNext";
240   String SLOW_MUTATE_KEY = "slowPutCount";
241   String SLOW_GET_KEY = "slowGetCount";
242   String SLOW_DELETE_KEY = "slowDeleteCount";
243   String SLOW_INCREMENT_KEY = "slowIncrementCount";
244   String SLOW_APPEND_KEY = "slowAppendCount";
245   String SLOW_MUTATE_DESC =
246       "The number of Multis that took over 1000ms to complete";
247   String SLOW_DELETE_DESC =
248       "The number of Deletes that took over 1000ms to complete";
249   String SLOW_GET_DESC = "The number of Gets that took over 1000ms to complete";
250   String SLOW_INCREMENT_DESC =
251       "The number of Increments that took over 1000ms to complete";
252   String SLOW_APPEND_DESC =
253       "The number of Appends that took over 1000ms to complete";
254 
255   String FLUSHED_CELLS = "flushedCellsCount";
256   String FLUSHED_CELLS_DESC = "The number of cells flushed to disk";
257   String FLUSHED_CELLS_SIZE = "flushedCellsSize";
258   String FLUSHED_CELLS_SIZE_DESC = "The total amount of data flushed to disk, in bytes";
259   String COMPACTED_CELLS = "compactedCellsCount";
260   String COMPACTED_CELLS_DESC = "The number of cells processed during minor compactions";
261   String COMPACTED_CELLS_SIZE = "compactedCellsSize";
262   String COMPACTED_CELLS_SIZE_DESC =
263       "The total amount of data processed during minor compactions, in bytes";
264   String MAJOR_COMPACTED_CELLS = "majorCompactedCellsCount";
265   String MAJOR_COMPACTED_CELLS_DESC =
266       "The number of cells processed during major compactions";
267   String MAJOR_COMPACTED_CELLS_SIZE = "majorCompactedCellsSize";
268   String MAJOR_COMPACTED_CELLS_SIZE_DESC =
269       "The total amount of data processed during major compactions, in bytes";
270 
271   String BLOCKED_REQUESTS_COUNT = "blockedRequestCount";
272   String BLOCKED_REQUESTS_COUNT_DESC = "The number of blocked requests because of memstore size is "
273       + "larger than blockingMemStoreSize";
274 
275   String SPLIT_KEY = "splitTime";
276   String SPLIT_REQUEST_KEY = "splitRequestCount";
277   String SPLIT_REQUEST_DESC = "Number of splits requested";
278   String SPLIT_SUCCESS_KEY = "splitSuccessCount";
279   String SPLIT_SUCCESS_DESC = "Number of successfully executed splits";
280   String FLUSH_KEY = "flushTime";
281 }