001/*
002 * Licensed to the Apache Software Foundation (ASF) under one
003 * or more contributor license agreements.  See the NOTICE file
004 * distributed with this work for additional information
005 * regarding copyright ownership.  The ASF licenses this file
006 * to you under the Apache License, Version 2.0 (the
007 * "License"); you may not use this file except in compliance
008 * with the License.  You may obtain a copy of the License at
009 *
010 *     http://www.apache.org/licenses/LICENSE-2.0
011 *
012 * Unless required by applicable law or agreed to in writing, software
013 * distributed under the License is distributed on an "AS IS" BASIS,
014 * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
015 * See the License for the specific language governing permissions and
016 * limitations under the License.
017 */
018package org.apache.hadoop.hbase;
019
020import static org.apache.hadoop.hbase.io.hfile.BlockType.MAGIC_LENGTH;
021
022import java.nio.ByteBuffer;
023import java.nio.charset.Charset;
024import java.util.Arrays;
025import java.util.Collections;
026import java.util.List;
027import java.util.UUID;
028import org.apache.commons.lang3.ArrayUtils;
029import org.apache.hadoop.hbase.conf.ConfigKey;
030import org.apache.hadoop.hbase.util.Bytes;
031import org.apache.yetus.audience.InterfaceAudience;
032
033/**
034 * HConstants holds a bunch of HBase-related constants
035 */
036@InterfaceAudience.Public
037public final class HConstants {
038  // NOTICE!!!! Please do not add a constants here, unless they are referenced by a lot of classes.
039
040  // Bytes.UTF8_ENCODING should be updated if this changed
041  /** When we encode strings, we always specify UTF8 encoding */
042  public static final String UTF8_ENCODING = "UTF-8";
043
044  // Bytes.UTF8_CHARSET should be updated if this changed
045  /** When we encode strings, we always specify UTF8 encoding */
046  public static final Charset UTF8_CHARSET = Charset.forName(UTF8_ENCODING);
047  /**
048   * Default block size for an HFile.
049   */
050  public final static int DEFAULT_BLOCKSIZE = 64 * 1024;
051
052  /** Used as a magic return value while optimized index key feature enabled(HBASE-7845) */
053  public final static int INDEX_KEY_MAGIC = -2;
054
055  /*
056   * Name of directory that holds recovered edits written by the wal log splitting code, one per
057   * region
058   */
059  public static final String RECOVERED_EDITS_DIR = "recovered.edits";
060
061  /*
062   * Name of directory that holds recovered hfiles written by the wal log splitting code, one per
063   * region
064   */
065  public static final String RECOVERED_HFILES_DIR = "recovered.hfiles";
066
067  /**
068   * Date Tiered Compaction tmp dir prefix name if use storage policy
069   */
070  public static final String STORAGE_POLICY_PREFIX = "storage_policy_";
071
072  /**
073   * The first four bytes of Hadoop RPC connections
074   */
075  public static final byte[] RPC_HEADER = new byte[] { 'H', 'B', 'a', 's' };
076  public static final byte RPC_CURRENT_VERSION = 0;
077
078  // HFileBlock constants. TODO!!!! THESE DEFINES BELONG IN HFILEBLOCK, NOT UP HERE.
079  // Needed down in hbase-common though by encoders but these encoders should not be dealing
080  // in the internals of hfileblocks. Fix encapsulation.
081
082  /** The size data structures with minor version is 0 */
083  public static final int HFILEBLOCK_HEADER_SIZE_NO_CHECKSUM =
084    MAGIC_LENGTH + 2 * Bytes.SIZEOF_INT + Bytes.SIZEOF_LONG;
085  /**
086   * The size of a version 2 HFile block header, minor version 1. There is a 1 byte checksum type,
087   * followed by a 4 byte bytesPerChecksum followed by another 4 byte value to store
088   * sizeofDataOnDisk.
089   */
090  public static final int HFILEBLOCK_HEADER_SIZE =
091    HFILEBLOCK_HEADER_SIZE_NO_CHECKSUM + Bytes.SIZEOF_BYTE + 2 * Bytes.SIZEOF_INT;
092  /** Just an array of bytes of the right size. */
093  public static final byte[] HFILEBLOCK_DUMMY_HEADER = new byte[HFILEBLOCK_HEADER_SIZE];
094
095  // End HFileBlockConstants.
096
097  /**
098   * Status codes used for return values of bulk operations.
099   */
100  @InterfaceAudience.LimitedPrivate(HBaseInterfaceAudience.COPROC)
101  public enum OperationStatusCode {
102    NOT_RUN,
103    SUCCESS,
104    BAD_FAMILY,
105    STORE_TOO_BUSY,
106    SANITY_CHECK_FAILURE,
107    FAILURE
108  }
109
110  /** long constant for zero */
111  public static final Long ZERO_L = Long.valueOf(0L);
112  public static final String NINES = "99999999999999";
113  public static final String ZEROES = "00000000000000";
114
115  // For migration
116
117  /** name of version file */
118  public static final String VERSION_FILE_NAME = "hbase.version";
119
120  /**
121   * Current version of file system. Version 4 supports only one kind of bloom filter. Version 5
122   * changes versions in catalog table regions. Version 6 enables blockcaching on catalog tables.
123   * Version 7 introduces hfile -- hbase 0.19 to 0.20.. Version 8 introduces namespace
124   */
125  // public static final String FILE_SYSTEM_VERSION = "6";
126  public static final String FILE_SYSTEM_VERSION = "8";
127
128  // Configuration parameters
129
130  // TODO: Is having HBase homed on port 60k OK?
131
132  /** Cluster is in distributed mode or not */
133  public static final String CLUSTER_DISTRIBUTED = "hbase.cluster.distributed";
134
135  /** Config for pluggable load balancers */
136  public static final String HBASE_MASTER_LOADBALANCER_CLASS = "hbase.master.loadbalancer.class";
137
138  /** Config for balancing the cluster by table */
139  public static final String HBASE_MASTER_LOADBALANCE_BYTABLE = "hbase.master.loadbalance.bytable";
140
141  /** Config for the max percent of regions in transition */
142  public static final String HBASE_MASTER_BALANCER_MAX_RIT_PERCENT =
143    "hbase.master.balancer.maxRitPercent";
144
145  /** Default value for the max percent of regions in transition */
146  public static final double DEFAULT_HBASE_MASTER_BALANCER_MAX_RIT_PERCENT = 1.0;
147
148  /** Config for the max balancing time */
149  public static final String HBASE_BALANCER_MAX_BALANCING = "hbase.balancer.max.balancing";
150
151  /** Config for the balancer period */
152  public static final String HBASE_BALANCER_PERIOD = "hbase.balancer.period";
153
154  /** Default value for the balancer period */
155  public static final int DEFAULT_HBASE_BALANCER_PERIOD = 300000;
156
157  /** Config for the oldWALs directory size updater period */
158  public static final String HBASE_OLDWAL_DIR_SIZE_UPDATER_PERIOD =
159    "hbase.master.oldwals.dir.updater.period";
160
161  /** Default value for the oldWALs directory size updater period */
162  public static final int DEFAULT_HBASE_OLDWAL_DIR_SIZE_UPDATER_PERIOD = 300000;
163
164  /**
165   * Config key for enable/disable automatically separate child regions to different region servers
166   * in the procedure of split regions. One child will be kept to the server where parent region is
167   * on, and the other child will be assigned to a random server. See HBASE-25518.
168   */
169  public static final String HBASE_ENABLE_SEPARATE_CHILD_REGIONS =
170    "hbase.master.auto.separate.child.regions.after.split.enabled";
171
172  /**
173   * Default value for automatically separate child regions to different region servers (set to
174   * "false" to keep all child regions to the server where parent region is on)
175   */
176  public static final boolean DEFAULT_HBASE_ENABLE_SEPARATE_CHILD_REGIONS = false;
177
178  /** The name of the ensemble table */
179  public static final TableName ENSEMBLE_TABLE_NAME = TableName.valueOf("hbase:ensemble");
180
181  /** Config for pluggable region normalizer */
182  public static final String HBASE_MASTER_NORMALIZER_CLASS = "hbase.master.normalizer.class";
183
184  /** Cluster is standalone or pseudo-distributed */
185  public static final boolean CLUSTER_IS_LOCAL = false;
186
187  /** Default value for cluster distributed mode */
188  public static final boolean DEFAULT_CLUSTER_DISTRIBUTED = CLUSTER_IS_LOCAL;
189
190  /** default host address */
191  public static final String DEFAULT_HOST = "0.0.0.0";
192
193  /** Parameter name for port master listens on. */
194  public static final String MASTER_PORT = "hbase.master.port";
195
196  /** default port that the master listens on */
197  public static final int DEFAULT_MASTER_PORT = 16000;
198
199  /** default port for master web api */
200  public static final int DEFAULT_MASTER_INFOPORT = 16010;
201
202  /** Configuration key for master web API port */
203  public static final String MASTER_INFO_PORT = "hbase.master.info.port";
204
205  /** Configuration key for the list of master host:ports **/
206  public static final String MASTER_ADDRS_KEY = "hbase.masters";
207
208  /** Full class name of the Zookeeper based connection registry implementation */
209  public static final String ZK_CONNECTION_REGISTRY_CLASS =
210    "org.apache.hadoop.hbase.client.ZKConnectionRegistry";
211
212  /** Parameter name for the master type being backup (waits for primary to go inactive). */
213  public static final String MASTER_TYPE_BACKUP = "hbase.master.backup";
214
215  /**
216   * by default every master is a possible primary master unless the conf explicitly overrides it
217   */
218  public static final boolean DEFAULT_MASTER_TYPE_BACKUP = false;
219
220  /** Name of ZooKeeper quorum configuration parameter. */
221  public static final String ZOOKEEPER_QUORUM = "hbase.zookeeper.quorum";
222
223  /** Name of ZooKeeper quorum configuration parameter for client to locate meta. */
224  public static final String CLIENT_ZOOKEEPER_QUORUM = "hbase.client.zookeeper.quorum";
225
226  /** Client port of ZooKeeper for client to locate meta */
227  public static final String CLIENT_ZOOKEEPER_CLIENT_PORT =
228    "hbase.client.zookeeper.property.clientPort";
229
230  /** Indicate whether the client ZK are observer nodes of the server ZK */
231  public static final String CLIENT_ZOOKEEPER_OBSERVER_MODE =
232    "hbase.client.zookeeper.observer.mode";
233  /** Assuming client zk not in observer mode and master need to synchronize information */
234  public static final boolean DEFAULT_CLIENT_ZOOKEEPER_OBSERVER_MODE = false;
235
236  /** Common prefix of ZooKeeper configuration properties */
237  public static final String ZK_CFG_PROPERTY_PREFIX = "hbase.zookeeper.property.";
238
239  public static final int ZK_CFG_PROPERTY_PREFIX_LEN = ZK_CFG_PROPERTY_PREFIX.length();
240
241  /**
242   * The ZK client port key in the ZK properties map. The name reflects the fact that this is not an
243   * HBase configuration key.
244   */
245  public static final String CLIENT_PORT_STR = "clientPort";
246
247  /** Parameter name for the client port that the zookeeper listens on */
248  public static final String ZOOKEEPER_CLIENT_PORT = ZK_CFG_PROPERTY_PREFIX + CLIENT_PORT_STR;
249
250  /** Default client port that the zookeeper listens on */
251  public static final int DEFAULT_ZOOKEEPER_CLIENT_PORT = 2181;
252
253  /** Parameter name for the root dir in ZK for this cluster */
254  public static final String ZOOKEEPER_ZNODE_PARENT = "zookeeper.znode.parent";
255
256  public static final String DEFAULT_ZOOKEEPER_ZNODE_PARENT = "/hbase";
257
258  /**
259   * Parameter name for the limit on concurrent client-side zookeeper connections
260   */
261  public static final String ZOOKEEPER_MAX_CLIENT_CNXNS = ZK_CFG_PROPERTY_PREFIX + "maxClientCnxns";
262
263  /** Parameter name for the ZK data directory */
264  public static final String ZOOKEEPER_DATA_DIR = ZK_CFG_PROPERTY_PREFIX + "dataDir";
265
266  /** Parameter name for the ZK tick time */
267  public static final String ZOOKEEPER_TICK_TIME = ZK_CFG_PROPERTY_PREFIX + "tickTime";
268
269  /** Default limit on concurrent client-side zookeeper connections */
270  public static final int DEFAULT_ZOOKEEPER_MAX_CLIENT_CNXNS = 300;
271
272  /** Configuration key for ZooKeeper session timeout */
273  public static final String ZK_SESSION_TIMEOUT = "zookeeper.session.timeout";
274
275  /** Timeout for the ZK sync() call */
276  public static final String ZK_SYNC_BLOCKING_TIMEOUT_MS = "hbase.zookeeper.sync.timeout.millis";
277  // Choice of the default value is based on the following ZK recommendation (from docs). Keeping it
278  // lower lets the callers fail fast in case of any issues.
279  // "The clients view of the system is guaranteed to be up-to-date within a certain time bound.
280  // (On the order of tens of seconds.) Either system changes will be seen by a client within this
281  // bound, or the client will detect a service outage."
282  public static final long ZK_SYNC_BLOCKING_TIMEOUT_DEFAULT_MS = 30 * 1000;
283
284  /** Default value for ZooKeeper session timeout */
285  public static final int DEFAULT_ZK_SESSION_TIMEOUT = 90 * 1000;
286
287  /** Parameter name for port region server listens on. */
288  public static final String REGIONSERVER_PORT = "hbase.regionserver.port";
289
290  /** Default port region server listens on. */
291  public static final int DEFAULT_REGIONSERVER_PORT = 16020;
292
293  /** default port for region server web api */
294  public static final int DEFAULT_REGIONSERVER_INFOPORT = 16030;
295
296  /** A configuration key for regionserver info port */
297  public static final String REGIONSERVER_INFO_PORT = "hbase.regionserver.info.port";
298
299  /** A flag that enables automatic selection of regionserver info port */
300  public static final String REGIONSERVER_INFO_PORT_AUTO = REGIONSERVER_INFO_PORT + ".auto";
301
302  /** Parameter name for what region server implementation to use. */
303  public static final String REGION_SERVER_IMPL = "hbase.regionserver.impl";
304
305  /** Parameter name for what master implementation to use. */
306  public static final String MASTER_IMPL = "hbase.master.impl";
307
308  /** Parameter name for how often threads should wake up */
309  public static final String THREAD_WAKE_FREQUENCY = "hbase.server.thread.wakefrequency";
310
311  /** Default value for thread wake frequency */
312  public static final int DEFAULT_THREAD_WAKE_FREQUENCY = 10 * 1000;
313
314  /** Parameter name for how often we should try to write a version file, before failing */
315  public static final String VERSION_FILE_WRITE_ATTEMPTS = "hbase.server.versionfile.writeattempts";
316
317  /** Parameter name for how often we should try to write a version file, before failing */
318  public static final int DEFAULT_VERSION_FILE_WRITE_ATTEMPTS = 3;
319
320  /** Parameter name and default value for how often a region should perform a major compaction */
321  public static final String MAJOR_COMPACTION_PERIOD =
322    ConfigKey.LONG("hbase.hregion.majorcompaction");
323  public static final long DEFAULT_MAJOR_COMPACTION_PERIOD = 1000 * 60 * 60 * 24 * 7; // 7 days
324
325  /**
326   * Parameter name and default value for major compaction jitter. Used as a multiplier applied to
327   * {@link HConstants#MAJOR_COMPACTION_PERIOD} to cause compaction to occur a given amount of time
328   * either side of {@link HConstants#MAJOR_COMPACTION_PERIOD}. Default to 0.5 so jitter has us fall
329   * evenly either side of when the compaction should run.
330   */
331  public static final String MAJOR_COMPACTION_JITTER =
332    ConfigKey.FLOAT("hbase.hregion.majorcompaction.jitter");
333  public static final float DEFAULT_MAJOR_COMPACTION_JITTER = 0.50F;
334
335  /** Parameter name for the maximum batch of KVs to be used in flushes and compactions */
336  public static final String COMPACTION_KV_MAX = ConfigKey.INT("hbase.hstore.compaction.kv.max");
337  public static final int COMPACTION_KV_MAX_DEFAULT = 10;
338
339  /** Parameter name for the scanner size limit to be used in compactions */
340  public static final String COMPACTION_SCANNER_SIZE_MAX =
341    ConfigKey.LONG("hbase.hstore.compaction.scanner.size.limit");
342  public static final long COMPACTION_SCANNER_SIZE_MAX_DEFAULT = 10 * 1024 * 1024L; // 10MB
343
344  /** Parameter name for HBase instance root directory */
345  public static final String HBASE_DIR = "hbase.rootdir";
346
347  /** Parameter name for HBase client IPC pool type */
348  public static final String HBASE_CLIENT_IPC_POOL_TYPE = "hbase.client.ipc.pool.type";
349
350  /** Parameter name for HBase client IPC pool size */
351  public static final String HBASE_CLIENT_IPC_POOL_SIZE = "hbase.client.ipc.pool.size";
352
353  /** Parameter name for HBase client operation timeout. */
354  public static final String HBASE_CLIENT_OPERATION_TIMEOUT = "hbase.client.operation.timeout";
355
356  /** Parameter name for HBase client meta operation timeout. */
357  public static final String HBASE_CLIENT_META_OPERATION_TIMEOUT =
358    "hbase.client.meta.operation.timeout";
359
360  /** Default HBase client operation timeout, which is tantamount to a blocking call */
361  public static final int DEFAULT_HBASE_CLIENT_OPERATION_TIMEOUT = 1200000;
362
363  /** Parameter name for HBase client meta replica scan call timeout. */
364  public static final String HBASE_CLIENT_META_REPLICA_SCAN_TIMEOUT =
365    "hbase.client.meta.replica.scan.timeout";
366
367  /** Default HBase client meta replica scan call timeout, 1 second */
368  public static final int HBASE_CLIENT_META_REPLICA_SCAN_TIMEOUT_DEFAULT = 1000000;
369
370  /** Used to construct the name of the log directory for a region server */
371  public static final String HREGION_LOGDIR_NAME = "WALs";
372
373  /** Used to construct the name of the splitlog directory for a region server */
374  public static final String SPLIT_LOGDIR_NAME = "splitWAL";
375
376  /** Like the previous, but for old logs that are about to be deleted */
377  public static final String HREGION_OLDLOGDIR_NAME = "oldWALs";
378
379  /** Staging dir used by bulk load */
380  public static final String BULKLOAD_STAGING_DIR_NAME = "staging";
381
382  public static final String CORRUPT_DIR_NAME = "corrupt";
383
384  /** Used by HBCK to sideline backup data */
385  public static final String HBCK_SIDELINEDIR_NAME = ".hbck";
386
387  /** Any artifacts left from migration can be moved here */
388  public static final String MIGRATION_NAME = ".migration";
389
390  /** Used to construct the name of the compaction directory during compaction */
391  public static final String HREGION_COMPACTIONDIR_NAME = "compaction.dir";
392
393  /** Conf key for the max file size after which we split the region */
394  public static final String HREGION_MAX_FILESIZE = ConfigKey.LONG("hbase.hregion.max.filesize");
395
396  /** Default maximum file size */
397  public static final long DEFAULT_MAX_FILE_SIZE = 10 * 1024 * 1024 * 1024L;
398
399  /** Conf key for if we should sum overall region files size when check to split */
400  public static final String OVERALL_HREGION_FILES = "hbase.hregion.split.overallfiles";
401
402  /** Default overall region files */
403  public static final boolean DEFAULT_OVERALL_HREGION_FILES = true;
404
405  /**
406   * Max size of single row for Get's or Scan's without in-row scanning flag set.
407   */
408  public static final String TABLE_MAX_ROWSIZE_KEY = "hbase.table.max.rowsize";
409
410  /**
411   * Default max row size (1 Gb).
412   */
413  public static final long TABLE_MAX_ROWSIZE_DEFAULT = 1024 * 1024 * 1024L;
414
415  /**
416   * The max number of threads used for opening and closing stores or store files in parallel
417   */
418  public static final String HSTORE_OPEN_AND_CLOSE_THREADS_MAX =
419    ConfigKey.INT("hbase.hstore.open.and.close.threads.max");
420
421  /**
422   * The default number for the max number of threads used for opening and closing stores or store
423   * files in parallel
424   */
425  public static final int DEFAULT_HSTORE_OPEN_AND_CLOSE_THREADS_MAX = 1;
426
427  /**
428   * Block updates if memstore has hbase.hregion.memstore.block.multiplier times
429   * hbase.hregion.memstore.flush.size bytes. Useful preventing runaway memstore during spikes in
430   * update traffic.
431   */
432  public static final String HREGION_MEMSTORE_BLOCK_MULTIPLIER =
433    ConfigKey.INT("hbase.hregion.memstore.block.multiplier", v -> v > 0);
434
435  /**
436   * Default value for hbase.hregion.memstore.block.multiplier
437   */
438  public static final int DEFAULT_HREGION_MEMSTORE_BLOCK_MULTIPLIER = 4;
439
440  /** Conf key for the memstore size at which we flush the memstore */
441  public static final String HREGION_MEMSTORE_FLUSH_SIZE =
442    ConfigKey.LONG("hbase.hregion.memstore.flush.size", v -> v > 0);
443
444  public static final String HREGION_EDITS_REPLAY_SKIP_ERRORS =
445    "hbase.hregion.edits.replay.skip.errors";
446
447  public static final boolean DEFAULT_HREGION_EDITS_REPLAY_SKIP_ERRORS = false;
448
449  /** Maximum value length, enforced on KeyValue construction */
450  public static final int MAXIMUM_VALUE_LENGTH = Integer.MAX_VALUE - 1;
451
452  /** name of the file for unique cluster ID */
453  public static final String CLUSTER_ID_FILE_NAME = "hbase.id";
454
455  /** Default value for cluster ID */
456  public static final String CLUSTER_ID_DEFAULT = "default-cluster";
457
458  /** Parameter name for # days to keep MVCC values during a major compaction */
459  public static final String KEEP_SEQID_PERIOD =
460    ConfigKey.INT("hbase.hstore.compaction.keep.seqId.period");
461  /** At least to keep MVCC values in hfiles for 5 days */
462  public static final int MIN_KEEP_SEQID_PERIOD = 5;
463
464  // Always store the location of the root table's HRegion.
465  // This HRegion is never split.
466
467  // region name = table + startkey + regionid. This is the row key.
468  // each row in the root and meta tables describes exactly 1 region
469  // Do we ever need to know all the information that we are storing?
470
471  // Note that the name of the root table starts with "-" and the name of the
472  // meta table starts with "." Why? it's a trick. It turns out that when we
473  // store region names in memory, we use a SortedMap. Since "-" sorts before
474  // "." (and since no other table name can start with either of these
475  // characters, the root region will always be the first entry in such a Map,
476  // followed by all the meta regions (which will be ordered by their starting
477  // row key as well), followed by all user tables. So when the Master is
478  // choosing regions to assign, it will always choose the root region first,
479  // followed by the meta regions, followed by user regions. Since the root
480  // and meta regions always need to be on-line, this ensures that they will
481  // be the first to be reassigned if the server(s) they are being served by
482  // should go down.
483
484  public static final String BASE_NAMESPACE_DIR = "data";
485
486  /** delimiter used between portions of a region name */
487  public static final int META_ROW_DELIMITER = ',';
488
489  /** The catalog family as a string */
490  public static final String CATALOG_FAMILY_STR = "info";
491
492  /** The catalog family */
493  public static final byte[] CATALOG_FAMILY = Bytes.toBytes(CATALOG_FAMILY_STR);
494
495  /** The RegionInfo qualifier as a string */
496  public static final String REGIONINFO_QUALIFIER_STR = "regioninfo";
497
498  /** The regioninfo column qualifier */
499  public static final byte[] REGIONINFO_QUALIFIER = Bytes.toBytes(REGIONINFO_QUALIFIER_STR);
500
501  /** The server column qualifier */
502  public static final String SERVER_QUALIFIER_STR = "server";
503  /** The server column qualifier */
504  public static final byte[] SERVER_QUALIFIER = Bytes.toBytes(SERVER_QUALIFIER_STR);
505
506  /** The startcode column qualifier */
507  public static final String STARTCODE_QUALIFIER_STR = "serverstartcode";
508  /** The startcode column qualifier */
509  public static final byte[] STARTCODE_QUALIFIER = Bytes.toBytes(STARTCODE_QUALIFIER_STR);
510
511  /** The open seqnum column qualifier */
512  public static final String SEQNUM_QUALIFIER_STR = "seqnumDuringOpen";
513  /** The open seqnum column qualifier */
514  public static final byte[] SEQNUM_QUALIFIER = Bytes.toBytes(SEQNUM_QUALIFIER_STR);
515
516  /** The state column qualifier */
517  public static final String STATE_QUALIFIER_STR = "state";
518
519  public static final byte[] STATE_QUALIFIER = Bytes.toBytes(STATE_QUALIFIER_STR);
520
521  /**
522   * The serverName column qualifier. Its the server where the region is transitioning on, while
523   * column server is the server where the region is opened on. They are the same when the region is
524   * in state OPEN.
525   */
526  public static final String SERVERNAME_QUALIFIER_STR = "sn";
527
528  public static final byte[] SERVERNAME_QUALIFIER = Bytes.toBytes(SERVERNAME_QUALIFIER_STR);
529
530  /** The lower-half split region column qualifier string. */
531  public static final String SPLITA_QUALIFIER_STR = "splitA";
532  /** The lower-half split region column qualifier */
533  public static final byte[] SPLITA_QUALIFIER = Bytes.toBytes(SPLITA_QUALIFIER_STR);
534
535  /** The upper-half split region column qualifier String. */
536  public static final String SPLITB_QUALIFIER_STR = "splitB";
537  /** The upper-half split region column qualifier */
538  public static final byte[] SPLITB_QUALIFIER = Bytes.toBytes(SPLITB_QUALIFIER_STR);
539
540  /**
541   * Merge qualifier prefix. We used to only allow two regions merge; mergeA and mergeB. Now we
542   * allow many to merge. Each region to merge will be referenced in a column whose qualifier starts
543   * with this define.
544   */
545  public static final String MERGE_QUALIFIER_PREFIX_STR = "merge";
546  public static final byte[] MERGE_QUALIFIER_PREFIX = Bytes.toBytes(MERGE_QUALIFIER_PREFIX_STR);
547
548  /**
549   * The lower-half merge region column qualifier
550   * @deprecated Since 2.3.0 and 2.2.1. Not used anymore. Instead we look for the
551   *             {@link #MERGE_QUALIFIER_PREFIX_STR} prefix.
552   */
553  @Deprecated
554  public static final byte[] MERGEA_QUALIFIER = Bytes.toBytes(MERGE_QUALIFIER_PREFIX_STR + "A");
555
556  /**
557   * The upper-half merge region column qualifier
558   * @deprecated Since 2.3.0 and 2.2.1. Not used anymore. Instead we look for the
559   *             {@link #MERGE_QUALIFIER_PREFIX_STR} prefix.
560   */
561  @Deprecated
562  public static final byte[] MERGEB_QUALIFIER = Bytes.toBytes(MERGE_QUALIFIER_PREFIX_STR + "B");
563
564  /** The catalog family as a string */
565  public static final String TABLE_FAMILY_STR = "table";
566
567  /** The catalog family */
568  public static final byte[] TABLE_FAMILY = Bytes.toBytes(TABLE_FAMILY_STR);
569
570  /** The serialized table state qualifier */
571  public static final byte[] TABLE_STATE_QUALIFIER = Bytes.toBytes("state");
572
573  /** The replication barrier family as a string */
574  public static final String REPLICATION_BARRIER_FAMILY_STR = "rep_barrier";
575
576  /** The replication barrier family */
577  public static final byte[] REPLICATION_BARRIER_FAMILY =
578    Bytes.toBytes(REPLICATION_BARRIER_FAMILY_STR);
579
580  /** The namespace family as a string */
581  public static final String NAMESPACE_FAMILY_STR = "ns";
582
583  /** The namespace family */
584  public static final byte[] NAMESPACE_FAMILY = Bytes.toBytes(NAMESPACE_FAMILY_STR);
585
586  public static final byte[] NAMESPACE_COL_DESC_QUALIFIER = Bytes.toBytes("d");
587  /**
588   * The meta table version column qualifier. We keep current version of the meta table in this
589   * column in <code>-ROOT-</code> table: i.e. in the 'info:v' column.
590   */
591  public static final byte[] META_VERSION_QUALIFIER = Bytes.toBytes("v");
592
593  /** The family str as a key in map */
594  public static final String FAMILY_KEY_STR = "family";
595
596  /**
597   * The current version of the meta table. - pre-hbase 0.92. There is no META_VERSION column in the
598   * root table in this case. The meta has HTableDescriptor serialized into the HRegionInfo; -
599   * version 0 is 0.92 and 0.94. Meta data has serialized HRegionInfo's using Writable
600   * serialization, and HRegionInfo's does not contain HTableDescriptors. - version 1 for 0.96+
601   * keeps HRegionInfo data structures, but changes the byte[] serialization from Writables to
602   * Protobuf. See HRegionInfo.VERSION
603   */
604  public static final short META_VERSION = 1;
605
606  // Other constants
607
608  /**
609   * An empty byte array instance.
610   */
611  public static final byte[] EMPTY_BYTE_ARRAY = new byte[0];
612
613  /**
614   * An empty string instance.
615   */
616  public static final String EMPTY_STRING = "";
617
618  public static final ByteBuffer EMPTY_BYTE_BUFFER = ByteBuffer.wrap(EMPTY_BYTE_ARRAY);
619
620  /**
621   * Used by scanners, etc when they want to start at the beginning of a region
622   */
623  public static final byte[] EMPTY_START_ROW = EMPTY_BYTE_ARRAY;
624
625  /**
626   * Last row in a table.
627   */
628  public static final byte[] EMPTY_END_ROW = EMPTY_BYTE_ARRAY;
629
630  /**
631   * Used by scanners and others when they're trying to detect the end of a table
632   */
633  public static final byte[] LAST_ROW = EMPTY_BYTE_ARRAY;
634
635  /**
636   * Max length a row can have because of the limitation in TFile.
637   */
638  public static final int MAX_ROW_LENGTH = Short.MAX_VALUE;
639
640  /**
641   * Timestamp to use when we want to refer to the latest cell. On client side, this is the
642   * timestamp set by default when no timestamp is specified, to refer to the latest. On server
643   * side, this acts as a notation. (1) For a cell of Put, which has this notation, its timestamp
644   * will be replaced with server's current time. (2) For a cell of Delete, which has this notation,
645   * A. If the cell is of {@link KeyValue.Type#Delete}, HBase issues a Get operation firstly. a.
646   * When the count of cell it gets is less than the count of cell to delete, the timestamp of
647   * Delete cell will be replaced with server's current time. b. When the count of cell it gets is
648   * equal to the count of cell to delete, the timestamp of Delete cell will be replaced with the
649   * latest timestamp of cell it gets. (c. It is invalid and an exception will be thrown, if the
650   * count of cell it gets is greater than the count of cell to delete, as the max version of Get is
651   * set to the count of cell to delete.) B. If the cell is of other Delete types, like
652   * {@link KeyValue.Type#DeleteFamilyVersion}, {@link KeyValue.Type#DeleteColumn}, or
653   * {@link KeyValue.Type#DeleteFamily}, the timestamp of Delete cell will be replaced with server's
654   * current time. So that is why it is named as "latest" but assigned as the max value of Long.
655   */
656  public static final long LATEST_TIMESTAMP = Long.MAX_VALUE;
657
658  /**
659   * LATEST_TIMESTAMP in bytes form
660   */
661  public static final byte[] LATEST_TIMESTAMP_BYTES = {
662    // big-endian
663    (byte) (LATEST_TIMESTAMP >>> 56), (byte) (LATEST_TIMESTAMP >>> 48),
664    (byte) (LATEST_TIMESTAMP >>> 40), (byte) (LATEST_TIMESTAMP >>> 32),
665    (byte) (LATEST_TIMESTAMP >>> 24), (byte) (LATEST_TIMESTAMP >>> 16),
666    (byte) (LATEST_TIMESTAMP >>> 8), (byte) LATEST_TIMESTAMP, };
667
668  /**
669   * Define for 'return-all-versions'.
670   */
671  public static final int ALL_VERSIONS = Integer.MAX_VALUE;
672
673  /**
674   * Unlimited time-to-live.
675   */
676  // public static final int FOREVER = -1;
677  public static final int FOREVER = Integer.MAX_VALUE;
678
679  /**
680   * Seconds in a day, hour and minute
681   */
682  public static final int DAY_IN_SECONDS = 24 * 60 * 60;
683  public static final int HOUR_IN_SECONDS = 60 * 60;
684  public static final int MINUTE_IN_SECONDS = 60;
685
686  /**
687   * KB, MB, GB, TB equivalent to how many bytes
688   */
689  public static final long KB_IN_BYTES = 1024;
690  public static final long MB_IN_BYTES = 1024 * KB_IN_BYTES;
691  public static final long GB_IN_BYTES = 1024 * MB_IN_BYTES;
692  public static final long TB_IN_BYTES = 1024 * GB_IN_BYTES;
693
694  // TODO: although the following are referenced widely to format strings for
695  // the shell. They really aren't a part of the public API. It would be
696  // nice if we could put them somewhere where they did not need to be
697  // public. They could have package visibility
698  public static final String NAME = "NAME";
699  public static final String VERSIONS = "VERSIONS";
700  public static final String IN_MEMORY = "IN_MEMORY";
701  public static final String METADATA = "METADATA";
702  public static final String CONFIGURATION = "CONFIGURATION";
703
704  /**
705   * Retrying we multiply hbase.client.pause setting by what we have in this array until we run out
706   * of array items. Retries beyond this use the last number in the array. So, for example, if
707   * hbase.client.pause is 1 second, and maximum retries count hbase.client.retries.number is 10, we
708   * will retry at the following intervals: 1, 2, 3, 5, 10, 20, 40, 100, 100, 100. With 100ms, a
709   * back-off of 200 means 20s
710   */
711  public static final int[] RETRY_BACKOFF =
712    { 1, 2, 3, 5, 10, 20, 40, 100, 100, 100, 100, 200, 200 };
713
714  public static final String REGION_IMPL = "hbase.hregion.impl";
715
716  /**
717   * Scope tag for locally scoped data. This data will not be replicated.
718   */
719  public static final int REPLICATION_SCOPE_LOCAL = 0;
720
721  /**
722   * Scope tag for globally scoped data. This data will be replicated to all peers.
723   */
724  public static final int REPLICATION_SCOPE_GLOBAL = 1;
725
726  /**
727   * Default cluster ID, cannot be used to identify a cluster so a key with this value means it
728   * wasn't meant for replication.
729   */
730  public static final UUID DEFAULT_CLUSTER_ID = new UUID(0L, 0L);
731
732  /**
733   * Parameter name for maximum number of bytes returned when calling a scanner's next method.
734   * Controlled by the client.
735   */
736  public static final String HBASE_CLIENT_SCANNER_MAX_RESULT_SIZE_KEY =
737    "hbase.client.scanner.max.result.size";
738
739  /**
740   * Parameter name for maximum number of bytes returned when calling a scanner's next method.
741   * Controlled by the server.
742   */
743  public static final String HBASE_SERVER_SCANNER_MAX_RESULT_SIZE_KEY =
744    "hbase.server.scanner.max.result.size";
745
746  /**
747   * Maximum number of bytes returned when calling a scanner's next method. Note that when a single
748   * row is larger than this limit the row is still returned completely. The default value is 2MB.
749   */
750  public static final long DEFAULT_HBASE_CLIENT_SCANNER_MAX_RESULT_SIZE = 2 * 1024 * 1024;
751
752  /**
753   * Maximum number of bytes returned when calling a scanner's next method. Note that when a single
754   * row is larger than this limit the row is still returned completely. Safety setting to protect
755   * the region server. The default value is 100MB. (a client would rarely request larger chunks on
756   * purpose)
757   */
758  public static final long DEFAULT_HBASE_SERVER_SCANNER_MAX_RESULT_SIZE = 100 * 1024 * 1024;
759
760  /**
761   * Parameter name for client pause value, used mostly as value to wait before running a retry of a
762   * failed get, region lookup, etc.
763   */
764  public static final String HBASE_CLIENT_PAUSE = "hbase.client.pause";
765
766  /**
767   * Default value of {@link #HBASE_CLIENT_PAUSE}.
768   */
769  public static final long DEFAULT_HBASE_CLIENT_PAUSE = 100;
770
771  /**
772   * Parameter name for client pause value for special case such as call queue too big, etc.
773   * @deprecated Since 2.5.0, will be removed in 4.0.0. Please use
774   *             hbase.client.pause.server.overloaded instead.
775   */
776  @Deprecated
777  public static final String HBASE_CLIENT_PAUSE_FOR_CQTBE = "hbase.client.pause.cqtbe";
778
779  /**
780   * The maximum number of concurrent connections the client will maintain.
781   */
782  public static final String HBASE_CLIENT_MAX_TOTAL_TASKS = "hbase.client.max.total.tasks";
783
784  /**
785   * Default value of {@link #HBASE_CLIENT_MAX_TOTAL_TASKS}.
786   */
787  public static final int DEFAULT_HBASE_CLIENT_MAX_TOTAL_TASKS = 100;
788
789  /**
790   * The maximum number of concurrent connections the client will maintain to a single RegionServer.
791   */
792  public static final String HBASE_CLIENT_MAX_PERSERVER_TASKS = "hbase.client.max.perserver.tasks";
793
794  /**
795   * Default value of {@link #HBASE_CLIENT_MAX_PERSERVER_TASKS}.
796   */
797  public static final int DEFAULT_HBASE_CLIENT_MAX_PERSERVER_TASKS = 2;
798
799  /**
800   * The maximum number of concurrent connections the client will maintain to a single Region.
801   */
802  public static final String HBASE_CLIENT_MAX_PERREGION_TASKS = "hbase.client.max.perregion.tasks";
803
804  /**
805   * Default value of {@link #HBASE_CLIENT_MAX_PERREGION_TASKS}.
806   */
807  public static final int DEFAULT_HBASE_CLIENT_MAX_PERREGION_TASKS = 1;
808
809  /**
810   * The maximum number of concurrent pending RPC requests for one server in process level.
811   */
812  public static final String HBASE_CLIENT_PERSERVER_REQUESTS_THRESHOLD =
813    "hbase.client.perserver.requests.threshold";
814
815  /**
816   * Default value of {@link #HBASE_CLIENT_PERSERVER_REQUESTS_THRESHOLD}.
817   */
818  public static final int DEFAULT_HBASE_CLIENT_PERSERVER_REQUESTS_THRESHOLD = Integer.MAX_VALUE;
819
820  /**
821   * Parameter name for server pause value, used mostly as value to wait before running a retry of a
822   * failed operation.
823   */
824  public static final String HBASE_SERVER_PAUSE = "hbase.server.pause";
825
826  /**
827   * Default value of {@link #HBASE_SERVER_PAUSE}.
828   */
829  public static final int DEFAULT_HBASE_SERVER_PAUSE = 1000;
830
831  /**
832   * Parameter name for maximum retries, used as maximum for all retryable operations such as
833   * fetching of the root region from root region server, getting a cell's value, starting a row
834   * update, etc.
835   */
836  public static final String HBASE_CLIENT_RETRIES_NUMBER = "hbase.client.retries.number";
837
838  /**
839   * Default value of {@link #HBASE_CLIENT_RETRIES_NUMBER}.
840   */
841  public static final int DEFAULT_HBASE_CLIENT_RETRIES_NUMBER = 15;
842
843  public static final String HBASE_CLIENT_SERVERSIDE_RETRIES_MULTIPLIER =
844    "hbase.client.serverside.retries.multiplier";
845
846  public static final int DEFAULT_HBASE_CLIENT_SERVERSIDE_RETRIES_MULTIPLIER = 3;
847
848  /**
849   * Parameter name to set the default scanner caching for all clients.
850   */
851  public static final String HBASE_CLIENT_SCANNER_CACHING = "hbase.client.scanner.caching";
852
853  /**
854   * Default value for {@link #HBASE_CLIENT_SCANNER_CACHING}
855   */
856  public static final int DEFAULT_HBASE_CLIENT_SCANNER_CACHING = Integer.MAX_VALUE;
857
858  /**
859   * Parameter name for number of rows that will be fetched when calling next on a scanner if it is
860   * not served from memory. Higher caching values will enable faster scanners but will eat up more
861   * memory and some calls of next may take longer and longer times when the cache is empty.
862   */
863  public static final String HBASE_META_SCANNER_CACHING = "hbase.meta.scanner.caching";
864
865  /**
866   * Default value of {@link #HBASE_META_SCANNER_CACHING}.
867   */
868  public static final int DEFAULT_HBASE_META_SCANNER_CACHING = 100;
869
870  /**
871   * Parameter name for number of versions, kept by meta table.
872   */
873  public static final String HBASE_META_VERSIONS = "hbase.meta.versions";
874
875  /**
876   * Default value of {@link #HBASE_META_VERSIONS}.
877   */
878  public static final int DEFAULT_HBASE_META_VERSIONS = 3;
879
880  /**
881   * Parameter name for number of versions, kept by meta table.
882   */
883  public static final String HBASE_META_BLOCK_SIZE = "hbase.meta.blocksize";
884
885  /**
886   * Default value of {@link #HBASE_META_BLOCK_SIZE}.
887   */
888  public static final int DEFAULT_HBASE_META_BLOCK_SIZE = 8 * 1024;
889
890  /**
891   * Parameter name for unique identifier for this {@link org.apache.hadoop.conf.Configuration}
892   * instance. If there are two or more {@link org.apache.hadoop.conf.Configuration} instances that,
893   * for all intents and purposes, are the same except for their instance ids, then they will not be
894   * able to share the same org.apache.hadoop.hbase.client.HConnection instance. On the other hand,
895   * even if the instance ids are the same, it could result in non-shared
896   * org.apache.hadoop.hbase.client.HConnection instances if some of the other connection parameters
897   * differ.
898   */
899  public static final String HBASE_CLIENT_INSTANCE_ID = "hbase.client.instance.id";
900
901  /**
902   * The client scanner timeout period in milliseconds.
903   */
904  public static final String HBASE_CLIENT_SCANNER_TIMEOUT_PERIOD =
905    "hbase.client.scanner.timeout.period";
906
907  /**
908   * Default value of {@link #HBASE_CLIENT_SCANNER_TIMEOUT_PERIOD}.
909   */
910  public static final int DEFAULT_HBASE_CLIENT_SCANNER_TIMEOUT_PERIOD = 60000;
911
912  /**
913   * timeout for each RPC
914   */
915  public static final String HBASE_RPC_TIMEOUT_KEY = "hbase.rpc.timeout";
916
917  /**
918   * timeout for each read RPC
919   */
920  public static final String HBASE_RPC_READ_TIMEOUT_KEY = "hbase.rpc.read.timeout";
921
922  /**
923   * timeout for each write RPC
924   */
925  public static final String HBASE_RPC_WRITE_TIMEOUT_KEY = "hbase.rpc.write.timeout";
926
927  /**
928   * Default value of {@link #HBASE_RPC_TIMEOUT_KEY}
929   */
930  public static final int DEFAULT_HBASE_RPC_TIMEOUT = 60000;
931
932  /**
933   * timeout for short operation RPC
934   */
935  public static final String HBASE_RPC_SHORTOPERATION_TIMEOUT_KEY =
936    "hbase.rpc.shortoperation.timeout";
937
938  /**
939   * Default value of {@link #HBASE_RPC_SHORTOPERATION_TIMEOUT_KEY}
940   */
941  public static final int DEFAULT_HBASE_RPC_SHORTOPERATION_TIMEOUT = 10000;
942
943  /**
944   * Retry pause time for short operation RPC
945   */
946  public static final String HBASE_RPC_SHORTOPERATION_RETRY_PAUSE_TIME =
947    "hbase.rpc.shortoperation.retry.pause.time";
948
949  /**
950   * Default value of {@link #HBASE_RPC_SHORTOPERATION_RETRY_PAUSE_TIME}
951   */
952  public static final long DEFAULT_HBASE_RPC_SHORTOPERATION_RETRY_PAUSE_TIME = 1000;
953
954  /**
955   * Value indicating the server name was saved with no sequence number.
956   */
957  public static final long NO_SEQNUM = -1;
958
959  /**
960   * Registry implementation to be used on the client side.
961   */
962  public static final String CLIENT_CONNECTION_REGISTRY_IMPL_CONF_KEY =
963    "hbase.client.registry.impl";
964
965  /*
966   * cluster replication constants.
967   */
968  public static final String REPLICATION_SOURCE_SERVICE_CLASSNAME =
969    "hbase.replication.source.service";
970  public static final String REPLICATION_SERVICE_CLASSNAME_DEFAULT =
971    "org.apache.hadoop.hbase.replication.regionserver.Replication";
972  public static final String REPLICATION_SINK_SERVICE_CLASSNAME = "hbase.replication.sink.service";
973  public static final String REPLICATION_SINK_SERVICE_CLASSNAME_DEFAULT =
974    "org.apache.hadoop.hbase.replication.ReplicationSinkServiceImpl";
975  public static final String REPLICATION_BULKLOAD_ENABLE_KEY = "hbase.replication.bulkload.enabled";
976  public static final boolean REPLICATION_BULKLOAD_ENABLE_DEFAULT = false;
977  /** Replication cluster id of source cluster which uniquely identifies itself with peer cluster */
978  public static final String REPLICATION_CLUSTER_ID = "hbase.replication.cluster.id";
979  /**
980   * Max total size of buffered entries in all replication peers. It will prevent server getting OOM
981   * if there are many peers. Default value is 256MB which is four times to default
982   * replication.source.size.capacity.
983   */
984  public static final String REPLICATION_SOURCE_TOTAL_BUFFER_KEY = "replication.total.buffer.quota";
985
986  public static final int REPLICATION_SOURCE_TOTAL_BUFFER_DFAULT = 256 * 1024 * 1024;
987
988  /** Configuration key for ReplicationSource shipeEdits timeout */
989  public static final String REPLICATION_SOURCE_SHIPEDITS_TIMEOUT =
990    "replication.source.shipedits.timeout";
991  public static final int REPLICATION_SOURCE_SHIPEDITS_TIMEOUT_DFAULT = 60000;
992
993  /**
994   * Directory where the source cluster file system client configuration are placed which is used by
995   * sink cluster to copy HFiles from source cluster file system
996   */
997  public static final String REPLICATION_CONF_DIR = "hbase.replication.conf.dir";
998
999  /** Maximum time to retry for a failed bulk load request */
1000  public static final String BULKLOAD_MAX_RETRIES_NUMBER = "hbase.bulkload.retries.number";
1001
1002  public static final String KEY_FOR_HOSTNAME_SEEN_BY_MASTER =
1003    "hbase.regionserver.hostname.seen.by.master";
1004
1005  public static final String HBASE_MASTER_LOGCLEANER_PLUGINS = "hbase.master.logcleaner.plugins";
1006
1007  public static final String HBASE_REGION_SPLIT_POLICY_KEY =
1008    "hbase.regionserver.region.split.policy";
1009
1010  /** Whether nonces are enabled; default is true. */
1011  public static final String HBASE_RS_NONCES_ENABLED = "hbase.regionserver.nonces.enabled";
1012
1013  /**
1014   * Configuration key for the size of the block cache
1015   */
1016  public static final String HFILE_BLOCK_CACHE_SIZE_KEY = "hfile.block.cache.size";
1017
1018  public static final float HFILE_BLOCK_CACHE_SIZE_DEFAULT = 0.4f;
1019
1020  /**
1021   * Configuration key for the memory size of the block cache
1022   */
1023  public static final String HFILE_BLOCK_CACHE_MEMORY_SIZE_KEY = "hfile.block.cache.memory.size";
1024
1025  /**
1026   * Configuration key for setting the fix size of the block size, default do nothing and it should
1027   * be explicitly set by user or only used within ClientSideRegionScanner. if it's set less than
1028   * current max on heap size, it overrides the max size of block cache
1029   */
1030  public static final String HFILE_ONHEAP_BLOCK_CACHE_FIXED_SIZE_KEY =
1031    "hfile.onheap.block.cache.fixed.size";
1032  public static final long HFILE_ONHEAP_BLOCK_CACHE_FIXED_SIZE_DEFAULT = 0L;
1033  public static final long HBASE_CLIENT_SCANNER_ONHEAP_BLOCK_CACHE_FIXED_SIZE_DEFAULT =
1034    32 * 1024 * 1024L;
1035
1036  /**
1037   * Configuration key for setting pread must read both necessaryLen and extraLen, default is
1038   * disabled. This is an optimized flag for reading HFile from blob storage.
1039   */
1040  public static final String HFILE_PREAD_ALL_BYTES_ENABLED_KEY = "hfile.pread.all.bytes.enabled";
1041  public static final boolean HFILE_PREAD_ALL_BYTES_ENABLED_DEFAULT = false;
1042
1043  /*
1044   * Minimum percentage of free heap necessary for a successful cluster startup.
1045   */
1046  public static final float HBASE_CLUSTER_MINIMUM_MEMORY_THRESHOLD = 0.2f;
1047
1048  public static final String CP_HTD_ATTR_INCLUSION_KEY =
1049    "hbase.coprocessor.classloader.included.classes";
1050
1051  /** The delay when re-trying a socket operation in a loop (HBASE-4712) */
1052  public static final int SOCKET_RETRY_WAIT_MS = 200;
1053
1054  /** Host name of the local machine */
1055  public static final String LOCALHOST = "localhost";
1056
1057  /**
1058   * If this parameter is set to true, then hbase will read data and then verify checksums. Checksum
1059   * verification inside hdfs will be switched off. However, if the hbase-checksum verification
1060   * fails, then it will switch back to using hdfs checksums for verifiying data that is being read
1061   * from storage. If this parameter is set to false, then hbase will not verify any checksums,
1062   * instead it will depend on checksum verification being done in the hdfs client.
1063   */
1064  public static final String HBASE_CHECKSUM_VERIFICATION = "hbase.regionserver.checksum.verify";
1065
1066  public static final String LOCALHOST_IP = "127.0.0.1";
1067
1068  public static final String REGION_SERVER_HANDLER_COUNT = "hbase.regionserver.handler.count";
1069  public static final int DEFAULT_REGION_SERVER_HANDLER_COUNT = 30;
1070
1071  /*
1072   * REGION_SERVER_HANDLER_ABORT_ON_ERROR_PERCENT: -1 => Disable aborting 0 => Abort if even a
1073   * single handler has died 0.x => Abort only when this percent of handlers have died 1 => Abort
1074   * only all of the handers have died
1075   */
1076  public static final String REGION_SERVER_HANDLER_ABORT_ON_ERROR_PERCENT =
1077    "hbase.regionserver.handler.abort.on.error.percent";
1078  public static final double DEFAULT_REGION_SERVER_HANDLER_ABORT_ON_ERROR_PERCENT = 0.5;
1079
1080  // High priority handlers to deal with admin requests and system table operation requests
1081  public static final String REGION_SERVER_HIGH_PRIORITY_HANDLER_COUNT =
1082    "hbase.regionserver.metahandler.count";
1083  public static final int DEFAULT_REGION_SERVER_HIGH_PRIORITY_HANDLER_COUNT = 20;
1084
1085  public static final String REGION_SERVER_REPLICATION_HANDLER_COUNT =
1086    "hbase.regionserver.replication.handler.count";
1087  public static final int DEFAULT_REGION_SERVER_REPLICATION_HANDLER_COUNT = 3;
1088  public static final String REGION_SERVER_BULKLOAD_HANDLER_COUNT =
1089    "hbase.regionserver.bulkload.handler.count";
1090  public static final int DEFAULT_REGION_SERVER_BULKLOAD_HANDLER_COUNT = 0;
1091  // Meta Transition handlers to deal with meta ReportRegionStateTransitionRequest. Meta transition
1092  // should be dealt with in a separate handler in case blocking other region's transition.
1093  public static final String MASTER_META_TRANSITION_HANDLER_COUNT =
1094    "hbase.master.meta.transition.handler.count";
1095  public static final int MASTER__META_TRANSITION_HANDLER_COUNT_DEFAULT = 1;
1096
1097  /** Conf key for enabling meta replication */
1098  public static final String USE_META_REPLICAS = "hbase.meta.replicas.use";
1099  public static final boolean DEFAULT_USE_META_REPLICAS = false;
1100
1101  /**
1102   * @deprecated Since 2.4.0, will be removed in 4.0.0. Please change the meta replicas number by
1103   *             altering meta table, i.e, set a new 'region replication' number and call
1104   *             modifyTable.
1105   */
1106  @Deprecated
1107  public static final String META_REPLICAS_NUM = "hbase.meta.replica.count";
1108  /**
1109   * @deprecated Since 2.4.0, will be removed in 4.0.0. Please change the meta replicas number by
1110   *             altering meta table, i.e, set a new 'region replication' number and call
1111   *             modifyTable.
1112   */
1113  @Deprecated
1114  public static final int DEFAULT_META_REPLICA_NUM = 1;
1115
1116  /**
1117   * The name of the configuration parameter that specifies the number of bytes in a newly created
1118   * checksum chunk.
1119   */
1120  public static final String BYTES_PER_CHECKSUM = "hbase.hstore.bytes.per.checksum";
1121
1122  /**
1123   * The name of the configuration parameter that specifies the name of an algorithm that is used to
1124   * compute checksums for newly created blocks.
1125   */
1126  public static final String CHECKSUM_TYPE_NAME = "hbase.hstore.checksum.algorithm";
1127
1128  /** Enable file permission modification from standard hbase */
1129  public static final String ENABLE_DATA_FILE_UMASK = "hbase.data.umask.enable";
1130  /** File permission umask to use when creating hbase data files */
1131  public static final String DATA_FILE_UMASK_KEY = "hbase.data.umask";
1132
1133  /** Configuration name of WAL Compression */
1134  public static final String ENABLE_WAL_COMPRESSION = "hbase.regionserver.wal.enablecompression";
1135
1136  /**
1137   * Configuration name of WAL storage policy Valid values are: HOT, COLD, WARM, ALL_SSD, ONE_SSD,
1138   * LAZY_PERSIST See
1139   * http://hadoop.apache.org/docs/r2.7.3/hadoop-project-dist/hadoop-hdfs/ArchivalStorage.html
1140   */
1141  public static final String WAL_STORAGE_POLICY = "hbase.wal.storage.policy";
1142  /**
1143   * "NONE" is not a valid storage policy and means we defer the policy to HDFS. @see
1144   * <a href="https://issues.apache.org/jira/browse/HBASE-20691">HBASE-20691</a>
1145   */
1146  public static final String DEFER_TO_HDFS_STORAGE_POLICY = "NONE";
1147  /** By default we defer the WAL storage policy to HDFS */
1148  public static final String DEFAULT_WAL_STORAGE_POLICY = DEFER_TO_HDFS_STORAGE_POLICY;
1149
1150  /** Region in Transition metrics threshold time */
1151  public static final String METRICS_RIT_STUCK_WARNING_THRESHOLD =
1152    "hbase.metrics.rit.stuck.warning.threshold";
1153
1154  public static final String LOAD_BALANCER_SLOP_KEY = "hbase.regions.slop";
1155
1156  /** delimiter used between portions of a region name */
1157  public static final int DELIMITER = ',';
1158
1159  /**
1160   * QOS attributes: these attributes are used to demarcate RPC call processing by different set of
1161   * handlers. For example, HIGH_QOS tagged methods are handled by high priority handlers.
1162   */
1163  // normal_QOS < replication_QOS < replay_QOS < QOS_threshold < admin_QOS < high_QOS < meta_QOS
1164  public static final int PRIORITY_UNSET = -1;
1165  public static final int NORMAL_QOS = 0;
1166  public static final int REPLICATION_QOS = 5;
1167  public static final int BULKLOAD_QOS = 4;
1168  /**
1169   * @deprecated since 3.0.0, will be removed in 4.0.0. DLR has been purged for a long time and
1170   *             region replication has its own 'replay' method.
1171   */
1172  @Deprecated
1173  public static final int REPLAY_QOS = 6;
1174  public static final int REGION_REPLICATION_QOS = REPLAY_QOS;
1175  public static final int QOS_THRESHOLD = 10;
1176  public static final int ADMIN_QOS = 100;
1177  public static final int HIGH_QOS = 200;
1178  public static final int SYSTEMTABLE_QOS = HIGH_QOS;
1179
1180  /** Directory under /hbase where archived hfiles are stored */
1181  public static final String HFILE_ARCHIVE_DIRECTORY = "archive";
1182
1183  /**
1184   * Name of the directory to store all snapshots. See SnapshotDescriptionUtils for remaining
1185   * snapshot constants; this is here to keep HConstants dependencies at a minimum and
1186   * uni-directional.
1187   */
1188  public static final String SNAPSHOT_DIR_NAME = ".hbase-snapshot";
1189
1190  /* Name of old snapshot directory. See HBASE-8352 for details on why it needs to be renamed */
1191  public static final String OLD_SNAPSHOT_DIR_NAME = ".snapshot";
1192
1193  /** Temporary directory used for table creation and deletion */
1194  public static final String HBASE_TEMP_DIRECTORY = ".tmp";
1195  /**
1196   * The period (in milliseconds) between computing region server point in time metrics
1197   */
1198  public static final String REGIONSERVER_METRICS_PERIOD = "hbase.regionserver.metrics.period";
1199  public static final long DEFAULT_REGIONSERVER_METRICS_PERIOD = 5000;
1200  /** Directories that are not HBase table directories */
1201  public static final List<String> HBASE_NON_TABLE_DIRS = Collections.unmodifiableList(
1202    Arrays.asList(new String[] { HBCK_SIDELINEDIR_NAME, HBASE_TEMP_DIRECTORY, MIGRATION_NAME }));
1203
1204  /**
1205   * Directories that are not HBase user table directories.
1206   * @deprecated Since hbase-2.3.0; no replacement as not used any more (internally at least)
1207   */
1208  @Deprecated
1209  public static final List<String> HBASE_NON_USER_TABLE_DIRS =
1210    Collections.unmodifiableList(Arrays.asList(
1211      (String[]) ArrayUtils.addAll(new String[] { TableName.META_TABLE_NAME.getNameAsString() },
1212        HBASE_NON_TABLE_DIRS.toArray())));
1213
1214  /** Health script related settings. */
1215  public static final String HEALTH_SCRIPT_LOC = "hbase.node.health.script.location";
1216  public static final String HEALTH_SCRIPT_TIMEOUT = "hbase.node.health.script.timeout";
1217  public static final String HEALTH_CHORE_WAKE_FREQ = "hbase.node.health.script.frequency";
1218  public static final long DEFAULT_HEALTH_SCRIPT_TIMEOUT = 60000;
1219  /**
1220   * The maximum number of health check failures a server can encounter consecutively.
1221   */
1222  public static final String HEALTH_FAILURE_THRESHOLD = "hbase.node.health.failure.threshold";
1223  public static final int DEFAULT_HEALTH_FAILURE_THRESHOLD = 3;
1224
1225  public static final String EXECUTOR_STATUS_COLLECT_ENABLED =
1226    "hbase.executors.status.collect.enabled";
1227  public static final boolean DEFAULT_EXECUTOR_STATUS_COLLECT_ENABLED = true;
1228
1229  /**
1230   * Setting to activate, or not, the publication of the status by the master. Default notification
1231   * is by a multicast message.
1232   */
1233  public static final String STATUS_PUBLISHED = "hbase.status.published";
1234  public static final boolean STATUS_PUBLISHED_DEFAULT = false;
1235
1236  /**
1237   * IP to use for the multicast status messages between the master and the clients. The default
1238   * address is chosen as one among others within the ones suitable for multicast messages.
1239   */
1240  public static final String STATUS_MULTICAST_ADDRESS = "hbase.status.multicast.address.ip";
1241  public static final String DEFAULT_STATUS_MULTICAST_ADDRESS = "226.1.1.3";
1242
1243  /**
1244   * The address to use for binding the local socket for receiving multicast. Defaults to 0.0.0.0.
1245   * @see <a href="https://issues.apache.org/jira/browse/HBASE-9961">HBASE-9961</a>
1246   */
1247  public static final String STATUS_MULTICAST_BIND_ADDRESS =
1248    "hbase.status.multicast.bind.address.ip";
1249  public static final String DEFAULT_STATUS_MULTICAST_BIND_ADDRESS = "0.0.0.0";
1250
1251  /**
1252   * The port to use for the multicast messages.
1253   */
1254  public static final String STATUS_MULTICAST_PORT = "hbase.status.multicast.address.port";
1255  public static final int DEFAULT_STATUS_MULTICAST_PORT = 16100;
1256
1257  /**
1258   * The network interface name to use for the multicast messages.
1259   */
1260  public static final String STATUS_MULTICAST_NI_NAME = "hbase.status.multicast.ni.name";
1261
1262  /**
1263   * The address to use for binding the local socket for sending multicast. Defaults to 0.0.0.0.
1264   */
1265  public static final String STATUS_MULTICAST_PUBLISHER_BIND_ADDRESS =
1266    "hbase.status.multicast.publisher.bind.address.ip";
1267  public static final String DEFAULT_STATUS_MULTICAST_PUBLISHER_BIND_ADDRESS = "0.0.0.0";
1268
1269  public static final long NO_NONCE = 0;
1270
1271  /** Default cipher for encryption */
1272  public static final String CIPHER_AES = "AES";
1273
1274  /** Configuration key for the crypto algorithm provider, a class name */
1275  public static final String CRYPTO_CIPHERPROVIDER_CONF_KEY = "hbase.crypto.cipherprovider";
1276
1277  /** Configuration key for the crypto key provider, a class name */
1278  public static final String CRYPTO_KEYPROVIDER_CONF_KEY = "hbase.crypto.keyprovider";
1279
1280  /** Configuration key for the crypto key provider parameters */
1281  public static final String CRYPTO_KEYPROVIDER_PARAMETERS_KEY =
1282    "hbase.crypto.keyprovider.parameters";
1283
1284  /** Configuration key for the name of the master key for the cluster, a string */
1285  public static final String CRYPTO_MASTERKEY_NAME_CONF_KEY = "hbase.crypto.master.key.name";
1286
1287  /** Configuration key for the name of the alternate master key for the cluster, a string */
1288  public static final String CRYPTO_MASTERKEY_ALTERNATE_NAME_CONF_KEY =
1289    "hbase.crypto.master.alternate.key.name";
1290
1291  /** Configuration key for the algorithm to use when encrypting the WAL, a string */
1292  public static final String CRYPTO_WAL_ALGORITHM_CONF_KEY = "hbase.crypto.wal.algorithm";
1293
1294  /** Configuration key for the name of the master WAL encryption key for the cluster, a string */
1295  public static final String CRYPTO_WAL_KEY_NAME_CONF_KEY = "hbase.crypto.wal.key.name";
1296
1297  /** Configuration key for the algorithm used for creating jks key, a string */
1298  public static final String CRYPTO_KEY_ALGORITHM_CONF_KEY = "hbase.crypto.key.algorithm";
1299
1300  /** Configuration key for the name of the alternate cipher algorithm for the cluster, a string */
1301  public static final String CRYPTO_ALTERNATE_KEY_ALGORITHM_CONF_KEY =
1302    "hbase.crypto.alternate.key.algorithm";
1303
1304  /** Configuration key for enabling WAL encryption, a boolean */
1305  public static final String ENABLE_WAL_ENCRYPTION = "hbase.regionserver.wal.encryption";
1306
1307  /** Configuration key for setting RPC codec class name */
1308  public static final String RPC_CODEC_CONF_KEY = "hbase.client.rpc.codec";
1309
1310  /** Configuration key for setting replication codec class name */
1311  public static final String REPLICATION_CODEC_CONF_KEY = "hbase.replication.rpc.codec";
1312
1313  /** Maximum number of threads used by the replication source for shipping edits to the sinks */
1314  public static final String REPLICATION_SOURCE_MAXTHREADS_KEY =
1315    "hbase.replication.source.maxthreads";
1316
1317  /**
1318   * Drop edits for tables that been deleted from the replication source and target
1319   * @deprecated since 3.0.0. Will be removed in 4.0.0. Moved it into
1320   *             HBaseInterClusterReplicationEndpoint.
1321   * @see <a href="https://issues.apache.org/jira/browse/HBASE-24359">HBASE-24359</a>
1322   */
1323  @Deprecated
1324  public static final String REPLICATION_DROP_ON_DELETED_TABLE_KEY =
1325    "hbase.replication.drop.on.deleted.table";
1326
1327  /** Maximum number of threads used by the replication source for shipping edits to the sinks */
1328  public static final int REPLICATION_SOURCE_MAXTHREADS_DEFAULT = 10;
1329
1330  /** Configuration key for SplitLog manager timeout */
1331  public static final String HBASE_SPLITLOG_MANAGER_TIMEOUT = "hbase.splitlog.manager.timeout";
1332
1333  /**
1334   * Configuration keys for Bucket cache
1335   */
1336  // TODO moving these bucket cache implementation specific configs to this level is violation of
1337  // encapsulation. But as these has to be referred from hbase-common and bucket cache
1338  // sits in hbase-server, there were no other go! Can we move the cache implementation to
1339  // hbase-common?
1340
1341  /**
1342   * Current ioengine options in include: heap, offheap and file:PATH (where PATH is the path to the
1343   * file that will host the file-based cache. See BucketCache#getIOEngineFromName() for list of
1344   * supported ioengine options.
1345   * <p>
1346   * Set this option and a non-zero {@link #BUCKET_CACHE_SIZE_KEY} to enable bucket cache.
1347   */
1348  public static final String BUCKET_CACHE_IOENGINE_KEY = "hbase.bucketcache.ioengine";
1349
1350  /**
1351   * When using bucket cache, it is the capacity in megabytes of the cache.
1352   */
1353  public static final String BUCKET_CACHE_SIZE_KEY = "hbase.bucketcache.size";
1354
1355  /**
1356   * If the chosen ioengine can persist its state across restarts, the path to the file to persist
1357   * to. This file is NOT the data file. It is a file into which we will serialize the map of what
1358   * is in the data file. For example, if you pass the following argument as
1359   * BUCKET_CACHE_IOENGINE_KEY ("hbase.bucketcache.ioengine"),
1360   * <code>file:/tmp/bucketcache.data </code>, then we will write the bucketcache data to the file
1361   * <code>/tmp/bucketcache.data</code> but the metadata on where the data is in the supplied file
1362   * is an in-memory map that needs to be persisted across restarts. Where to store this in-memory
1363   * state is what you supply here: e.g. <code>/tmp/bucketcache.map</code>.
1364   */
1365  public static final String BUCKET_CACHE_PERSISTENT_PATH_KEY = "hbase.bucketcache.persistent.path";
1366
1367  /**
1368   * HConstants for fast fail on the client side follow
1369   */
1370  /**
1371   * Config for enabling/disabling the fast fail mode.
1372   * @deprecated since 2.3.0, and in 3.0.0 the actually implementation will be removed so config
1373   *             this value will have no effect. The constants itself will be removed in 4.0.0.
1374   */
1375  @Deprecated
1376  public static final String HBASE_CLIENT_FAST_FAIL_MODE_ENABLED =
1377    "hbase.client.fast.fail.mode.enabled";
1378
1379  /**
1380   * @deprecated since 2.3.0, and in 3.0.0 the actually implementation will be removed so config
1381   *             this value will have no effect. The constants itself will be removed in 4.0.0.
1382   */
1383  @Deprecated
1384  public static final boolean HBASE_CLIENT_ENABLE_FAST_FAIL_MODE_DEFAULT = false;
1385
1386  /**
1387   * @deprecated since 2.3.0, and in 3.0.0 the actually implementation will be removed so config
1388   *             this value will have no effect. The constants itself will be removed in 4.0.0.
1389   */
1390  @Deprecated
1391  public static final String HBASE_CLIENT_FAST_FAIL_THREASHOLD_MS =
1392    "hbase.client.fastfail.threshold";
1393
1394  /**
1395   * @deprecated since 2.3.0, and in 3.0.0 the actually implementation will be removed so config
1396   *             this value will have no effect. The constants itself will be removed in 4.0.0.
1397   */
1398  @Deprecated
1399  public static final long HBASE_CLIENT_FAST_FAIL_THREASHOLD_MS_DEFAULT = 60000;
1400
1401  /**
1402   * @deprecated since 2.3.0, and in 3.0.0 the actually implementation will be removed so config
1403   *             this value will have no effect. The constants itself will be removed in 4.0.0.
1404   */
1405  @Deprecated
1406  public static final String HBASE_CLIENT_FAILURE_MAP_CLEANUP_INTERVAL_MS =
1407    "hbase.client.failure.map.cleanup.interval";
1408
1409  /**
1410   * @deprecated since 2.3.0, and in 3.0.0 the actually implementation will be removed so config
1411   *             this value will have no effect. The constants itself will be removed in 4.0.0.
1412   */
1413  @Deprecated
1414  public static final long HBASE_CLIENT_FAILURE_MAP_CLEANUP_INTERVAL_MS_DEFAULT = 600000;
1415
1416  /**
1417   * @deprecated since 2.3.0, and in 3.0.0 the actually implementation will be removed so config
1418   *             this value will have no effect. The constants itself will be removed in 4.0.0.
1419   */
1420  @Deprecated
1421  public static final String HBASE_CLIENT_FAST_FAIL_CLEANUP_MS_DURATION_MS =
1422    "hbase.client.fast.fail.cleanup.duration";
1423
1424  /**
1425   * @deprecated since 2.3.0, and in 3.0.0 the actually implementation will be removed so config
1426   *             this value will have no effect. The constants itself will be removed in 4.0.0.
1427   */
1428  @Deprecated
1429  public static final long HBASE_CLIENT_FAST_FAIL_CLEANUP_DURATION_MS_DEFAULT = 600000;
1430
1431  /**
1432   * @deprecated since 2.3.0, and in 3.0.0 the actually implementation will be removed so config
1433   *             this value will have no effect. The constants itself will be removed in 4.0.0.
1434   */
1435  @Deprecated
1436  public static final String HBASE_CLIENT_FAST_FAIL_INTERCEPTOR_IMPL =
1437    "hbase.client.fast.fail.interceptor.impl";
1438
1439  /**
1440   * @deprecated since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based
1441   *             distributed WAL splitter; see SplitWALManager.
1442   */
1443  @Deprecated
1444  public static final String HBASE_SPLIT_WAL_COORDINATED_BY_ZK = "hbase.split.wal.zk.coordinated";
1445
1446  /**
1447   * @deprecated since 2.4.0 and in 3.0.0, to be removed in 4.0.0.
1448   */
1449  @Deprecated
1450  public static final boolean DEFAULT_HBASE_SPLIT_COORDINATED_BY_ZK = false;
1451
1452  public static final String HBASE_SPLIT_WAL_MAX_SPLITTER = "hbase.regionserver.wal.max.splitters";
1453
1454  public static final int DEFAULT_HBASE_SPLIT_WAL_MAX_SPLITTER = 2;
1455
1456  /**
1457   * Config key for if the server should send backpressure and if the client should listen to that
1458   * backpressure from the server
1459   */
1460  public static final String ENABLE_CLIENT_BACKPRESSURE = "hbase.client.backpressure.enabled";
1461  public static final boolean DEFAULT_ENABLE_CLIENT_BACKPRESSURE = false;
1462
1463  public static final String HEAP_OCCUPANCY_LOW_WATERMARK_KEY =
1464    "hbase.heap.occupancy.low_water_mark";
1465  public static final float DEFAULT_HEAP_OCCUPANCY_LOW_WATERMARK = 0.95f;
1466  public static final String HEAP_OCCUPANCY_HIGH_WATERMARK_KEY =
1467    "hbase.heap.occupancy.high_water_mark";
1468  public static final float DEFAULT_HEAP_OCCUPANCY_HIGH_WATERMARK = 0.98f;
1469
1470  /**
1471   * The max number of threads used for splitting storefiles in parallel during the region split
1472   * process.
1473   */
1474  public static final String REGION_SPLIT_THREADS_MAX =
1475    "hbase.regionserver.region.split.threads.max";
1476
1477  /** Canary config keys */
1478  // TODO: Move these defines to Canary Class
1479  public static final String HBASE_CANARY_WRITE_DATA_TTL_KEY = "hbase.canary.write.data.ttl";
1480
1481  public static final String HBASE_CANARY_WRITE_PERSERVER_REGIONS_LOWERLIMIT_KEY =
1482    "hbase.canary.write.perserver.regions.lowerLimit";
1483
1484  public static final String HBASE_CANARY_WRITE_PERSERVER_REGIONS_UPPERLIMIT_KEY =
1485    "hbase.canary.write.perserver.regions.upperLimit";
1486
1487  public static final String HBASE_CANARY_WRITE_VALUE_SIZE_KEY = "hbase.canary.write.value.size";
1488
1489  public static final String HBASE_CANARY_WRITE_TABLE_CHECK_PERIOD_KEY =
1490    "hbase.canary.write.table.check.period";
1491
1492  public static final String HBASE_CANARY_READ_RAW_SCAN_KEY = "hbase.canary.read.raw.enabled";
1493
1494  public static final String HBASE_CANARY_READ_ALL_CF = "hbase.canary.read.all.column.famliy";
1495  /**
1496   * Configuration keys for programmatic JAAS configuration for secured ZK interaction
1497   */
1498  public static final String ZK_CLIENT_KEYTAB_FILE = "hbase.zookeeper.client.keytab.file";
1499  public static final String ZK_CLIENT_KERBEROS_PRINCIPAL =
1500    "hbase.zookeeper.client.kerberos.principal";
1501  public static final String ZK_SERVER_KEYTAB_FILE = "hbase.zookeeper.server.keytab.file";
1502  public static final String ZK_SERVER_KERBEROS_PRINCIPAL =
1503    "hbase.zookeeper.server.kerberos.principal";
1504
1505  /** Config key for hbase temporary directory in hdfs */
1506  public static final String TEMPORARY_FS_DIRECTORY_KEY = "hbase.fs.tmp.dir";
1507
1508  /**
1509   * Don't use it! This'll get you the wrong path in a secure cluster. Use
1510   * FileSystem.getHomeDirectory() or "/user/" +
1511   * UserGroupInformation.getCurrentUser().getShortUserName()
1512   */
1513  public static final String DEFAULT_TEMPORARY_HDFS_DIRECTORY =
1514    "/user/" + System.getProperty("user.name") + "/hbase-staging";
1515
1516  public static final String SNAPSHOT_RESTORE_TAKE_FAILSAFE_SNAPSHOT =
1517    "hbase.snapshot.restore.take.failsafe.snapshot";
1518  public static final boolean DEFAULT_SNAPSHOT_RESTORE_TAKE_FAILSAFE_SNAPSHOT = true;
1519
1520  public static final String SNAPSHOT_RESTORE_FAILSAFE_NAME =
1521    "hbase.snapshot.restore.failsafe.name";
1522  public static final String DEFAULT_SNAPSHOT_RESTORE_FAILSAFE_NAME =
1523    "hbase-failsafe-{snapshot.name}-{restore.timestamp}";
1524
1525  public static final String DEFAULT_LOSSY_COUNTING_ERROR_RATE =
1526    "hbase.util.default.lossycounting.errorrate";
1527  public static final String NOT_IMPLEMENTED = "Not implemented";
1528
1529  // Default TTL - FOREVER
1530  public static final long DEFAULT_SNAPSHOT_TTL = 0;
1531
1532  // User defined Default TTL config key
1533  public static final String DEFAULT_SNAPSHOT_TTL_CONFIG_KEY = "hbase.master.snapshot.ttl";
1534
1535  // Regions Recovery based on high storeFileRefCount threshold value
1536  public static final String STORE_FILE_REF_COUNT_THRESHOLD =
1537    "hbase.regions.recovery.store.file.ref.count";
1538
1539  // default -1 indicates there is no threshold on high storeRefCount
1540  public static final int DEFAULT_STORE_FILE_REF_COUNT_THRESHOLD = -1;
1541
1542  public static final String REGIONS_RECOVERY_INTERVAL =
1543    "hbase.master.regions.recovery.check.interval";
1544
1545  public static final int DEFAULT_REGIONS_RECOVERY_INTERVAL = 1200 * 1000; // Default 20 min
1546
1547  /**
1548   * Configurations for master executor services.
1549   */
1550  public static final String MASTER_OPEN_REGION_THREADS =
1551    "hbase.master.executor.openregion.threads";
1552  public static final int MASTER_OPEN_REGION_THREADS_DEFAULT = 5;
1553
1554  public static final String MASTER_CLOSE_REGION_THREADS =
1555    "hbase.master.executor.closeregion.threads";
1556  public static final int MASTER_CLOSE_REGION_THREADS_DEFAULT = 5;
1557
1558  public static final String MASTER_SERVER_OPERATIONS_THREADS =
1559    "hbase.master.executor.serverops.threads";
1560  public static final int MASTER_SERVER_OPERATIONS_THREADS_DEFAULT = 5;
1561
1562  /**
1563   * Number of threads used to dispatch merge operations to the regionservers.
1564   */
1565  public static final String MASTER_MERGE_DISPATCH_THREADS =
1566    "hbase.master.executor.merge.dispatch.threads";
1567  public static final int MASTER_MERGE_DISPATCH_THREADS_DEFAULT = 2;
1568
1569  public static final String MASTER_META_SERVER_OPERATIONS_THREADS =
1570    "hbase.master.executor.meta.serverops.threads";
1571  public static final int MASTER_META_SERVER_OPERATIONS_THREADS_DEFAULT = 5;
1572
1573  public static final String MASTER_LOG_REPLAY_OPS_THREADS =
1574    "hbase.master.executor.logreplayops.threads";
1575  public static final int MASTER_LOG_REPLAY_OPS_THREADS_DEFAULT = 10;
1576
1577  public static final int DEFAULT_SLOW_LOG_RING_BUFFER_SIZE = 256;
1578
1579  public static final String SLOW_LOG_BUFFER_ENABLED_KEY =
1580    "hbase.regionserver.slowlog.buffer.enabled";
1581  public static final boolean DEFAULT_ONLINE_LOG_PROVIDER_ENABLED = false;
1582
1583  /** The slowlog info family as a string */
1584  private static final String SLOWLOG_INFO_FAMILY_STR = "info";
1585
1586  /** The slowlog info family */
1587  public static final byte[] SLOWLOG_INFO_FAMILY = Bytes.toBytes(SLOWLOG_INFO_FAMILY_STR);
1588
1589  public static final String SLOW_LOG_SYS_TABLE_ENABLED_KEY =
1590    "hbase.regionserver.slowlog.systable.enabled";
1591  public static final boolean DEFAULT_SLOW_LOG_SYS_TABLE_ENABLED_KEY = false;
1592
1593  @Deprecated
1594  // since <need to know the version number> and will be removed in <version number>
1595  // Instead use hbase.regionserver.named.queue.chore.duration config property
1596  public static final String SLOW_LOG_SYS_TABLE_CHORE_DURATION_KEY =
1597    "hbase.slowlog.systable.chore.duration";
1598  // Default 10 mins.
1599  public static final int DEFAULT_SLOW_LOG_SYS_TABLE_CHORE_DURATION = 10 * 60 * 1000;
1600
1601  public static final String SLOW_LOG_SCAN_PAYLOAD_ENABLED = "hbase.slowlog.scan.payload.enabled";
1602  public static final boolean SLOW_LOG_SCAN_PAYLOAD_ENABLED_DEFAULT = false;
1603
1604  public static final String SHELL_TIMESTAMP_FORMAT_EPOCH_KEY =
1605    "hbase.shell.timestamp.format.epoch";
1606
1607  public static final boolean DEFAULT_SHELL_TIMESTAMP_FORMAT_EPOCH = false;
1608
1609  /**
1610   * Number of rows in a batch operation above which a warning will be logged.
1611   */
1612  public static final String BATCH_ROWS_THRESHOLD_NAME = "hbase.rpc.rows.warning.threshold";
1613
1614  /**
1615   * Default value of {@link #BATCH_ROWS_THRESHOLD_NAME}
1616   */
1617  public static final int BATCH_ROWS_THRESHOLD_DEFAULT = 5000;
1618
1619  /**
1620   * In some scenarios, such as the elastic scaling scenario on the cloud, the HBase client may not
1621   * be able to resolve the hostname of the newly added node. If the network is interconnected, the
1622   * client can actually access the HBase cluster nodes through ip. However, since the HBase client
1623   * obtains the Master/RS address info from or the ZK or the meta table, so the Master/RS of the
1624   * HBase cluster needs to expose the service with ip instead of the hostname. Therefore, We can
1625   * use hostname by default, but at the same time, we can also provide a config to support whether
1626   * to use ip for Master/RS service. See HBASE-27304 for details.
1627   */
1628  public final static String HBASE_SERVER_USEIP_ENABLED_KEY = "hbase.server.useip.enabled";
1629
1630  /**
1631   * Default value of {@link #HBASE_SERVER_USEIP_ENABLED_KEY}
1632   */
1633  public final static boolean HBASE_SERVER_USEIP_ENABLED_DEFAULT = false;
1634
1635  /**
1636   * Should the HMaster reject hosts of decommissioned RegionServers, bypass matching their port and
1637   * startcode parts of their ServerName or not? When True, the HMaster will reject a RegionServer's
1638   * request to `reportForDuty` if it's hostname exists in the list of decommissioned RegionServers
1639   * it maintains internally. Added in HBASE-28342.
1640   */
1641  public final static String REJECT_DECOMMISSIONED_HOSTS_KEY =
1642    "hbase.master.reject.decommissioned.hosts";
1643
1644  /**
1645   * Default value of {@link #REJECT_DECOMMISSIONED_HOSTS_KEY}
1646   */
1647  public final static boolean REJECT_DECOMMISSIONED_HOSTS_DEFAULT = false;
1648
1649  private HConstants() {
1650    // Can't be instantiated with this ctor.
1651  }
1652}