Package org.apache.hadoop.hbase
Class HConstants
java.lang.Object
org.apache.hadoop.hbase.HConstants
HConstants holds a bunch of HBase-related constants
-
Nested Class Summary
Modifier and TypeClassDescriptionstatic enum
Status codes used for return values of bulk operations. -
Field Summary
Modifier and TypeFieldDescriptionstatic final int
static final int
Define for 'return-all-versions'.static final String
static final int
Default value ofBATCH_ROWS_THRESHOLD_NAME
static final String
Number of rows in a batch operation above which a warning will be logged.static final String
Current ioengine options in include: heap, offheap and file:PATH (where PATH is the path to the file that will host the file-based cache.static final String
If the chosen ioengine can persist its state across restarts, the path to the file to persist to.static final String
When using bucket cache, it is the capacity in megabytes of the cache.static final String
Maximum time to retry for a failed bulk load requeststatic final int
static final String
Staging dir used by bulk loadstatic final String
The name of the configuration parameter that specifies the number of bytes in a newly created checksum chunk.static final byte[]
The catalog familystatic final String
The catalog family as a stringstatic final String
The name of the configuration parameter that specifies the name of an algorithm that is used to compute checksums for newly created blocks.static final String
Default cipher for encryptionstatic final String
Registry implementation to be used on the client side.static final String
The ZK client port key in the ZK properties map.static final String
Client port of ZooKeeper for client to locate metastatic final String
Indicate whether the client ZK are observer nodes of the server ZKstatic final String
Name of ZooKeeper quorum configuration parameter for client to locate meta.static final String
Cluster is in distributed mode or notstatic final String
Default value for cluster IDstatic final String
name of the file for unique cluster IDstatic final boolean
Cluster is standalone or pseudo-distributedstatic final String
Parameter name for the maximum batch of KVs to be used in flushes and compactionsstatic final int
static final String
Parameter name for the scanner size limit to be used in compactionsstatic final long
static final String
static final String
static final String
static final String
Configuration key for the name of the alternate cipher algorithm for the cluster, a stringstatic final String
Configuration key for the crypto algorithm provider, a class namestatic final String
Configuration key for the algorithm used for creating jks key, a stringstatic final String
Configuration key for the crypto key provider, a class namestatic final String
Configuration key for the crypto key provider parametersstatic final String
Configuration key for the name of the alternate master key for the cluster, a stringstatic final String
Configuration key for the name of the master key for the cluster, a stringstatic final String
Configuration key for the algorithm to use when encrypting the WAL, a stringstatic final String
Configuration key for the name of the master WAL encryption key for the cluster, a stringstatic final String
File permission umask to use when creating hbase data filesstatic final int
Seconds in a day, hour and minutestatic final int
Default block size for an HFile.static final boolean
Assuming client zk not in observer mode and master need to synchronize informationstatic final boolean
Default value for cluster distributed modestatic final UUID
Default cluster ID, cannot be used to identify a cluster so a key with this value means it wasn't meant for replication.static final boolean
static final boolean
static final int
Default value for the balancer periodstatic final int
Default value ofHBASE_CLIENT_MAX_PERREGION_TASKS
.static final int
Default value ofHBASE_CLIENT_MAX_PERSERVER_TASKS
.static final int
Default value ofHBASE_CLIENT_MAX_TOTAL_TASKS
.static final int
Default HBase client operation timeout, which is tantamount to a blocking callstatic final long
Default value ofHBASE_CLIENT_PAUSE
.static final int
Default value ofHBASE_CLIENT_PERSERVER_REQUESTS_THRESHOLD
.static final int
Default value ofHBASE_CLIENT_RETRIES_NUMBER
.static final int
Default value forHBASE_CLIENT_SCANNER_CACHING
static final long
Maximum number of bytes returned when calling a scanner's next method.static final int
Default value ofHBASE_CLIENT_SCANNER_TIMEOUT_PERIOD
.static final int
static final boolean
Default value for automatically separate child regions to different region servers (set to "false" to keep all child regions to the server where parent region is on)static final double
Default value for the max percent of regions in transitionstatic final int
Default value ofHBASE_META_BLOCK_SIZE
.static final int
Default value ofHBASE_META_SCANNER_CACHING
.static final int
Default value ofHBASE_META_VERSIONS
.static final int
Default value for the oldWALs directory size updater periodstatic final long
Default value ofHBASE_RPC_SHORTOPERATION_RETRY_PAUSE_TIME
static final int
Default value ofHBASE_RPC_SHORTOPERATION_TIMEOUT_KEY
static final int
Default value ofHBASE_RPC_TIMEOUT_KEY
static final int
Default value ofHBASE_SERVER_PAUSE
.static final long
Maximum number of bytes returned when calling a scanner's next method.static final boolean
Deprecated.since 2.4.0 and in 3.0.0, to be removed in 4.0.0.static final int
static final int
static final long
static final float
static final float
static final String
default host addressstatic final boolean
static final int
Default value for hbase.hregion.memstore.block.multiplierstatic final int
The default number for the max number of threads used for opening and closing stores or store files in parallelstatic final String
static final float
static final long
static final int
default port for master web apistatic final int
default port that the master listens onstatic final boolean
by default every master is a possible primary master unless the conf explicitly overrides itstatic final long
Default maximum file sizestatic final int
Deprecated.Since 2.4.0, will be removed in 4.0.0.static final boolean
static final boolean
Default overall region filesstatic final int
static final double
static final int
static final int
static final int
static final int
static final int
default port for region server web apistatic final long
static final int
Default port region server listens on.static final boolean
static final int
static final int
static final boolean
static final String
static final boolean
static final long
static final String
static final String
static final String
static final int
static final String
static final int
static final String
Don't use it! This'll get you the wrong path in a secure cluster.static final int
Default value for thread wake frequencystatic final boolean
static final int
Parameter name for how often we should try to write a version file, before failingstatic final String
By default we defer the WAL storage policy to HDFSstatic final int
Default value for ZooKeeper session timeoutstatic final int
Default client port that the zookeeper listens onstatic final int
Default limit on concurrent client-side zookeeper connectionsstatic final String
static final String
"NONE" is not a valid storage policy and means we defer the policy to HDFS.static final int
delimiter used between portions of a region namestatic final byte[]
An empty byte array instance.static final ByteBuffer
static final byte[]
Last row in a table.static final byte[]
Used by scanners, etc when they want to start at the beginning of a regionstatic final String
An empty string instance.static final String
Config key for if the server should send backpressure and if the client should listen to that backpressure from the serverstatic final String
Enable file permission modification from standard hbasestatic final String
Configuration name of WAL Compressionstatic final String
Configuration key for enabling WAL encryption, a booleanstatic final TableName
The name of the ensemble tablestatic final String
static final String
The family str as a key in mapstatic final String
Current version of file system.static final int
Unlimited time-to-live.static final long
static final String
Config for the max balancing timestatic final String
Config for the balancer periodstatic final String
static final String
static final String
Canary config keysstatic final String
static final String
static final String
static final String
static final String
If this parameter is set to true, then hbase will read data and then verify checksums.static final boolean
Deprecated.since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect.static final String
Deprecated.since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect.static final long
Deprecated.since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect.static final long
Deprecated.since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect.static final String
Deprecated.since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect.static final String
Deprecated.since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect.static final String
Deprecated.since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect.static final String
Deprecated.since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect.static final long
Deprecated.since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect.static final String
Parameter name for unique identifier for thisConfiguration
instance.static final String
Parameter name for HBase client IPC pool sizestatic final String
Parameter name for HBase client IPC pool typestatic final String
The maximum number of concurrent connections the client will maintain to a single Region.static final String
The maximum number of concurrent connections the client will maintain to a single RegionServer.static final String
The maximum number of concurrent connections the client will maintain.static final String
Parameter name for HBase client meta operation timeout.static final String
Parameter name for HBase client meta replica scan call timeout.static final int
Default HBase client meta replica scan call timeout, 1 secondstatic final String
Parameter name for HBase client operation timeout.static final String
Parameter name for client pause value, used mostly as value to wait before running a retry of a failed get, region lookup, etc.static final String
Deprecated.Since 2.5.0, will be removed in 4.0.0.static final String
The maximum number of concurrent pending RPC requests for one server in process level.static final String
Parameter name for maximum retries, used as maximum for all retryable operations such as fetching of the root region from root region server, getting a cell's value, starting a row update, etc.static final String
Parameter name to set the default scanner caching for all clients.static final String
Parameter name for maximum number of bytes returned when calling a scanner's next method.static final long
static final String
The client scanner timeout period in milliseconds.static final String
static final float
static final String
Parameter name for HBase instance root directorystatic final String
Config key for enable/disable automatically separate child regions to different region servers in the procedure of split regions.static final String
Config for the max percent of regions in transitionstatic final String
Config for balancing the cluster by tablestatic final String
Config for pluggable load balancersstatic final String
static final String
Config for pluggable region normalizerstatic final String
Parameter name for number of versions, kept by meta table.static final String
Parameter name for number of rows that will be fetched when calling next on a scanner if it is not served from memory.static final String
Parameter name for number of versions, kept by meta table.Directories that are not HBase table directoriesDeprecated.Since hbase-2.3.0; no replacement as not used any more (internally at least)static final String
Config for the oldWALs directory size updater periodstatic final String
static final String
timeout for each read RPCstatic final String
Retry pause time for short operation RPCstatic final String
timeout for short operation RPCstatic final String
timeout for each RPCstatic final String
timeout for each write RPCstatic final String
Whether nonces are enabled; default is true.static final String
Parameter name for server pause value, used mostly as value to wait before running a retry of a failed operation.static final String
Parameter name for maximum number of bytes returned when calling a scanner's next method.static final boolean
Default value ofHBASE_SERVER_USEIP_ENABLED_KEY
static final String
In some scenarios, such as the elastic scaling scenario on the cloud, the HBase client may not be able to resolve the hostname of the newly added node.static final String
Deprecated.since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based distributed WAL splitter; see SplitWALManager.static final String
static final String
Configuration key for SplitLog manager timeoutstatic final String
Temporary directory used for table creation and deletionstatic final String
Used by HBCK to sideline backup datastatic final String
static final String
The maximum number of health check failures a server can encounter consecutively.static final String
Health script related settings.static final String
static final String
static final String
static final String
Directory under /hbase where archived hfiles are storedstatic final float
static final String
Configuration key for the size of the block cachestatic final long
static final String
Configuration key for setting the fix size of the block size, default do nothing and it should be explicitly set by user or only used within ClientSideRegionScanner.static final boolean
static final String
Configuration key for setting pread must read both necessaryLen and extraLen, default is disabled.static final byte[]
Just an array of bytes of the right size.static final int
The size of a version 2 HFile block header, minor version 1.static final int
The size data structures with minor version is 0static final int
static final int
static final String
Used to construct the name of the compaction directory during compactionstatic final String
static final String
Used to construct the name of the log directory for a region serverstatic final String
Conf key for the max file size after which we split the regionstatic final String
Block updates if memstore has hbase.hregion.memstore.block.multiplier times hbase.hregion.memstore.flush.size bytes.static final String
Conf key for the memstore size at which we flush the memstorestatic final String
Like the previous, but for old logs that are about to be deletedstatic final String
The max number of threads used for opening and closing stores or store files in parallelstatic final String
static final int
Used as a magic return value while optimized index key feature enabled(HBASE-7845)static final long
KB, MB, GB, TB equivalent to how many bytesstatic final String
Parameter name for # days to keep MVCC values during a major compactionstatic final String
static final byte[]
Used by scanners and others when they're trying to detect the end of a tablestatic final long
Timestamp to use when we want to refer to the latest cell.static final byte[]
LATEST_TIMESTAMP in bytes formstatic final String
static final String
Host name of the local machinestatic final String
static final String
Parameter name and default value for major compaction jitter.static final String
Parameter name and default value for how often a region should perform a major compactionstatic final int
static final String
Configuration key for the list of master host:portsstatic final String
static final int
static final String
Parameter name for what master implementation to use.static final String
Configuration key for master web API portstatic final String
static final int
static final String
Number of threads used to dispatch merge operations to the regionservers.static final int
static final String
static final int
static final String
static final String
Configurations for master executor services.static final int
static final String
Parameter name for port master listens on.static final String
static final int
static final String
Parameter name for the master type being backup (waits for primary to go inactive).static final int
Max length a row can have because of the limitation in TFile.static final int
Maximum value length, enforced on KeyValue constructionstatic final long
static final byte[]
static final String
Merge qualifier prefix.static final byte[]
Deprecated.Since 2.3.0 and 2.2.1.static final byte[]
Deprecated.Since 2.3.0 and 2.2.1.static final String
Deprecated.Since 2.4.0, will be removed in 4.0.0.static final int
delimiter used between portions of a region namestatic final short
The current version of the meta table.static final byte[]
The meta table version column qualifier.static final String
static final String
Region in Transition metrics threshold timestatic final String
Any artifacts left from migration can be moved herestatic final int
At least to keep MVCC values in hfiles for 5 daysstatic final int
static final String
static final byte[]
static final byte[]
The namespace familystatic final String
The namespace family as a stringstatic final String
static final long
static final long
Value indicating the server name was saved with no sequence number.static final int
static final String
static final String
static final String
Conf key for if we should sum overall region files size when check to splitstatic final int
QOS attributes: these attributes are used to demarcate RPC call processing by different set of handlers.static final int
static final String
static final String
static final String
static final int
static final String
static final String
static final String
static final String
static final String
Parameter name for what region server implementation to use.static final String
static final String
The max number of threads used for splitting storefiles in parallel during the region split process.static final byte[]
The regioninfo column qualifierstatic final String
The RegionInfo qualifier as a stringstatic final String
static final String
A configuration key for regionserver info portstatic final String
A flag that enables automatic selection of regionserver info portstatic final String
The period (in milliseconds) between computing region server point in time metricsstatic final String
Parameter name for port region server listens on.static final boolean
Default value ofREJECT_DECOMMISSIONED_HOSTS_KEY
static final String
Should the HMaster reject hosts of decommissioned RegionServers, bypass matching their port and startcode parts of their ServerName or not? When True, the HMaster will reject a RegionServer's request to `reportForDuty` if it's hostname exists in the list of decommissioned RegionServers it maintains internally.static final int
Deprecated.since 3.0.0, will be removed in 4.0.0.static final byte[]
The replication barrier familystatic final String
The replication barrier family as a stringstatic final boolean
static final String
static final String
Replication cluster id of source cluster which uniquely identifies itself with peer clusterstatic final String
Configuration key for setting replication codec class namestatic final String
Directory where the source cluster file system client configuration are placed which is used by sink cluster to copy HFiles from source cluster file systemstatic final String
Deprecated.since 3.0.0.static final int
static final int
Scope tag for globally scoped data.static final int
Scope tag for locally scoped data.static final String
static final String
static final String
static final int
Maximum number of threads used by the replication source for shipping edits to the sinksstatic final String
Maximum number of threads used by the replication source for shipping edits to the sinksstatic final String
static final String
Configuration key for ReplicationSource shipeEdits timeoutstatic final int
static final int
static final String
Max total size of buffered entries in all replication peers.static final int[]
Retrying we multiply hbase.client.pause setting by what we have in this array until we run out of array items.static final String
Configuration key for setting RPC codec class namestatic final byte
static final byte[]
The first four bytes of Hadoop RPC connectionsstatic final byte[]
The open seqnum column qualifierstatic final String
The open seqnum column qualifierstatic final byte[]
The server column qualifierstatic final String
The server column qualifierstatic final byte[]
static final String
The serverName column qualifier.static final String
static final String
static final String
static final boolean
static final String
Deprecated.static final String
static final byte[]
The slowlog info familyprivate static final String
The slowlog info family as a stringstatic final String
Name of the directory to store all snapshots.static final String
static final String
static final int
The delay when re-trying a socket operation in a loop (HBASE-4712)static final String
Used to construct the name of the splitlog directory for a region serverstatic final byte[]
The lower-half split region column qualifierstatic final String
The lower-half split region column qualifier string.static final byte[]
The upper-half split region column qualifierstatic final String
The upper-half split region column qualifier String.static final byte[]
The startcode column qualifierstatic final String
The startcode column qualifierstatic final byte[]
static final String
The state column qualifierstatic final String
IP to use for the multicast status messages between the master and the clients.static final String
The address to use for binding the local socket for receiving multicast.static final String
The network interface name to use for the multicast messages.static final String
The port to use for the multicast messages.static final String
The address to use for binding the local socket for sending multicast.static final String
Setting to activate, or not, the publication of the status by the master.static final boolean
static final String
Date Tiered Compaction tmp dir prefix name if use storage policystatic final String
static final int
static final byte[]
The catalog familystatic final String
The catalog family as a stringstatic final long
Default max row size (1 Gb).static final String
Max size of single row for Get's or Scan's without in-row scanning flag set.static final byte[]
The serialized table state qualifierstatic final long
static final String
Config key for hbase temporary directory in hdfsstatic final String
Parameter name for how often threads should wake upstatic final String
Conf key for enabling meta replicationstatic final Charset
When we encode strings, we always specify UTF8 encodingstatic final String
When we encode strings, we always specify UTF8 encodingstatic final String
name of version filestatic final String
Parameter name for how often we should try to write a version file, before failingstatic final String
static final String
Configuration name of WAL storage policy Valid values are: HOT, COLD, WARM, ALL_SSD, ONE_SSD, LAZY_PERSIST See http://hadoop.apache.org/docs/r2.7.3/hadoop-project-dist/hadoop-hdfs/ArchivalStorage.htmlstatic final Long
long constant for zerostatic final String
static final String
Common prefix of ZooKeeper configuration propertiesstatic final int
static final String
static final String
Configuration keys for programmatic JAAS configuration for secured ZK interactionstatic final String
Full class name of the Zookeeper based connection registry implementationstatic final String
static final String
static final String
Configuration key for ZooKeeper session timeoutstatic final long
static final String
Timeout for the ZK sync() callstatic final String
Parameter name for the client port that the zookeeper listens onstatic final String
Parameter name for the ZK data directorystatic final String
Parameter name for the limit on concurrent client-side zookeeper connectionsstatic final String
Name of ZooKeeper quorum configuration parameter.static final String
Parameter name for the ZK tick timestatic final String
Parameter name for the root dir in ZK for this cluster -
Constructor Summary
-
Method Summary
-
Field Details
-
UTF8_ENCODING
When we encode strings, we always specify UTF8 encoding- See Also:
-
UTF8_CHARSET
When we encode strings, we always specify UTF8 encoding -
DEFAULT_BLOCKSIZE
Default block size for an HFile.- See Also:
-
INDEX_KEY_MAGIC
Used as a magic return value while optimized index key feature enabled(HBASE-7845)- See Also:
-
RECOVERED_EDITS_DIR
- See Also:
-
RECOVERED_HFILES_DIR
- See Also:
-
STORAGE_POLICY_PREFIX
Date Tiered Compaction tmp dir prefix name if use storage policy- See Also:
-
RPC_HEADER
The first four bytes of Hadoop RPC connections -
RPC_CURRENT_VERSION
- See Also:
-
HFILEBLOCK_HEADER_SIZE_NO_CHECKSUM
The size data structures with minor version is 0- See Also:
-
HFILEBLOCK_HEADER_SIZE
The size of a version 2 HFile block header, minor version 1. There is a 1 byte checksum type, followed by a 4 byte bytesPerChecksum followed by another 4 byte value to store sizeofDataOnDisk.- See Also:
-
HFILEBLOCK_DUMMY_HEADER
Just an array of bytes of the right size. -
ZERO_L
long constant for zero -
NINES
- See Also:
-
ZEROES
- See Also:
-
VERSION_FILE_NAME
name of version file- See Also:
-
FILE_SYSTEM_VERSION
Current version of file system. Version 4 supports only one kind of bloom filter. Version 5 changes versions in catalog table regions. Version 6 enables blockcaching on catalog tables. Version 7 introduces hfile -- hbase 0.19 to 0.20.. Version 8 introduces namespace- See Also:
-
CLUSTER_DISTRIBUTED
Cluster is in distributed mode or not- See Also:
-
HBASE_MASTER_LOADBALANCER_CLASS
Config for pluggable load balancers- See Also:
-
HBASE_MASTER_LOADBALANCE_BYTABLE
Config for balancing the cluster by table- See Also:
-
HBASE_MASTER_BALANCER_MAX_RIT_PERCENT
Config for the max percent of regions in transition- See Also:
-
DEFAULT_HBASE_MASTER_BALANCER_MAX_RIT_PERCENT
Default value for the max percent of regions in transition- See Also:
-
HBASE_BALANCER_MAX_BALANCING
Config for the max balancing time- See Also:
-
HBASE_BALANCER_PERIOD
Config for the balancer period- See Also:
-
DEFAULT_HBASE_BALANCER_PERIOD
Default value for the balancer period- See Also:
-
HBASE_OLDWAL_DIR_SIZE_UPDATER_PERIOD
Config for the oldWALs directory size updater period- See Also:
-
DEFAULT_HBASE_OLDWAL_DIR_SIZE_UPDATER_PERIOD
Default value for the oldWALs directory size updater period- See Also:
-
HBASE_ENABLE_SEPARATE_CHILD_REGIONS
Config key for enable/disable automatically separate child regions to different region servers in the procedure of split regions. One child will be kept to the server where parent region is on, and the other child will be assigned to a random server. See HBASE-25518.- See Also:
-
DEFAULT_HBASE_ENABLE_SEPARATE_CHILD_REGIONS
Default value for automatically separate child regions to different region servers (set to "false" to keep all child regions to the server where parent region is on)- See Also:
-
ENSEMBLE_TABLE_NAME
The name of the ensemble table -
HBASE_MASTER_NORMALIZER_CLASS
Config for pluggable region normalizer- See Also:
-
CLUSTER_IS_LOCAL
Cluster is standalone or pseudo-distributed- See Also:
-
DEFAULT_CLUSTER_DISTRIBUTED
Default value for cluster distributed mode- See Also:
-
DEFAULT_HOST
default host address- See Also:
-
MASTER_PORT
Parameter name for port master listens on.- See Also:
-
DEFAULT_MASTER_PORT
default port that the master listens on- See Also:
-
DEFAULT_MASTER_INFOPORT
default port for master web api- See Also:
-
MASTER_INFO_PORT
Configuration key for master web API port- See Also:
-
MASTER_ADDRS_KEY
Configuration key for the list of master host:ports- See Also:
-
ZK_CONNECTION_REGISTRY_CLASS
Full class name of the Zookeeper based connection registry implementation- See Also:
-
MASTER_TYPE_BACKUP
Parameter name for the master type being backup (waits for primary to go inactive).- See Also:
-
DEFAULT_MASTER_TYPE_BACKUP
by default every master is a possible primary master unless the conf explicitly overrides it- See Also:
-
ZOOKEEPER_QUORUM
Name of ZooKeeper quorum configuration parameter.- See Also:
-
CLIENT_ZOOKEEPER_QUORUM
Name of ZooKeeper quorum configuration parameter for client to locate meta.- See Also:
-
CLIENT_ZOOKEEPER_CLIENT_PORT
Client port of ZooKeeper for client to locate meta- See Also:
-
CLIENT_ZOOKEEPER_OBSERVER_MODE
Indicate whether the client ZK are observer nodes of the server ZK- See Also:
-
DEFAULT_CLIENT_ZOOKEEPER_OBSERVER_MODE
Assuming client zk not in observer mode and master need to synchronize information- See Also:
-
ZK_CFG_PROPERTY_PREFIX
Common prefix of ZooKeeper configuration properties- See Also:
-
ZK_CFG_PROPERTY_PREFIX_LEN
-
CLIENT_PORT_STR
The ZK client port key in the ZK properties map. The name reflects the fact that this is not an HBase configuration key.- See Also:
-
ZOOKEEPER_CLIENT_PORT
Parameter name for the client port that the zookeeper listens on- See Also:
-
DEFAULT_ZOOKEEPER_CLIENT_PORT
Default client port that the zookeeper listens on- See Also:
-
ZOOKEEPER_ZNODE_PARENT
Parameter name for the root dir in ZK for this cluster- See Also:
-
DEFAULT_ZOOKEEPER_ZNODE_PARENT
- See Also:
-
ZOOKEEPER_MAX_CLIENT_CNXNS
Parameter name for the limit on concurrent client-side zookeeper connections- See Also:
-
ZOOKEEPER_DATA_DIR
Parameter name for the ZK data directory- See Also:
-
ZOOKEEPER_TICK_TIME
Parameter name for the ZK tick time- See Also:
-
DEFAULT_ZOOKEEPER_MAX_CLIENT_CNXNS
Default limit on concurrent client-side zookeeper connections- See Also:
-
ZK_SESSION_TIMEOUT
Configuration key for ZooKeeper session timeout- See Also:
-
ZK_SYNC_BLOCKING_TIMEOUT_MS
Timeout for the ZK sync() call- See Also:
-
ZK_SYNC_BLOCKING_TIMEOUT_DEFAULT_MS
- See Also:
-
DEFAULT_ZK_SESSION_TIMEOUT
Default value for ZooKeeper session timeout- See Also:
-
REGIONSERVER_PORT
Parameter name for port region server listens on.- See Also:
-
DEFAULT_REGIONSERVER_PORT
Default port region server listens on.- See Also:
-
DEFAULT_REGIONSERVER_INFOPORT
default port for region server web api- See Also:
-
REGIONSERVER_INFO_PORT
A configuration key for regionserver info port- See Also:
-
REGIONSERVER_INFO_PORT_AUTO
A flag that enables automatic selection of regionserver info port- See Also:
-
REGION_SERVER_IMPL
Parameter name for what region server implementation to use.- See Also:
-
MASTER_IMPL
Parameter name for what master implementation to use.- See Also:
-
THREAD_WAKE_FREQUENCY
Parameter name for how often threads should wake up- See Also:
-
DEFAULT_THREAD_WAKE_FREQUENCY
Default value for thread wake frequency- See Also:
-
VERSION_FILE_WRITE_ATTEMPTS
Parameter name for how often we should try to write a version file, before failing- See Also:
-
DEFAULT_VERSION_FILE_WRITE_ATTEMPTS
Parameter name for how often we should try to write a version file, before failing- See Also:
-
MAJOR_COMPACTION_PERIOD
Parameter name and default value for how often a region should perform a major compaction- See Also:
-
DEFAULT_MAJOR_COMPACTION_PERIOD
- See Also:
-
MAJOR_COMPACTION_JITTER
Parameter name and default value for major compaction jitter. Used as a multiplier applied toMAJOR_COMPACTION_PERIOD
to cause compaction to occur a given amount of time either side ofMAJOR_COMPACTION_PERIOD
. Default to 0.5 so jitter has us fall evenly either side of when the compaction should run.- See Also:
-
DEFAULT_MAJOR_COMPACTION_JITTER
- See Also:
-
COMPACTION_KV_MAX
Parameter name for the maximum batch of KVs to be used in flushes and compactions- See Also:
-
COMPACTION_KV_MAX_DEFAULT
- See Also:
-
COMPACTION_SCANNER_SIZE_MAX
Parameter name for the scanner size limit to be used in compactions- See Also:
-
COMPACTION_SCANNER_SIZE_MAX_DEFAULT
- See Also:
-
HBASE_DIR
Parameter name for HBase instance root directory- See Also:
-
HBASE_CLIENT_IPC_POOL_TYPE
Parameter name for HBase client IPC pool type- See Also:
-
HBASE_CLIENT_IPC_POOL_SIZE
Parameter name for HBase client IPC pool size- See Also:
-
HBASE_CLIENT_OPERATION_TIMEOUT
Parameter name for HBase client operation timeout.- See Also:
-
HBASE_CLIENT_META_OPERATION_TIMEOUT
Parameter name for HBase client meta operation timeout.- See Also:
-
DEFAULT_HBASE_CLIENT_OPERATION_TIMEOUT
Default HBase client operation timeout, which is tantamount to a blocking call- See Also:
-
HBASE_CLIENT_META_REPLICA_SCAN_TIMEOUT
Parameter name for HBase client meta replica scan call timeout.- See Also:
-
HBASE_CLIENT_META_REPLICA_SCAN_TIMEOUT_DEFAULT
Default HBase client meta replica scan call timeout, 1 second- See Also:
-
HREGION_LOGDIR_NAME
Used to construct the name of the log directory for a region server- See Also:
-
SPLIT_LOGDIR_NAME
Used to construct the name of the splitlog directory for a region server- See Also:
-
HREGION_OLDLOGDIR_NAME
Like the previous, but for old logs that are about to be deleted- See Also:
-
BULKLOAD_STAGING_DIR_NAME
Staging dir used by bulk load- See Also:
-
CORRUPT_DIR_NAME
- See Also:
-
HBCK_SIDELINEDIR_NAME
Used by HBCK to sideline backup data- See Also:
-
MIGRATION_NAME
Any artifacts left from migration can be moved here- See Also:
-
HREGION_COMPACTIONDIR_NAME
Used to construct the name of the compaction directory during compaction- See Also:
-
HREGION_MAX_FILESIZE
Conf key for the max file size after which we split the region- See Also:
-
DEFAULT_MAX_FILE_SIZE
Default maximum file size- See Also:
-
OVERALL_HREGION_FILES
Conf key for if we should sum overall region files size when check to split- See Also:
-
DEFAULT_OVERALL_HREGION_FILES
Default overall region files- See Also:
-
TABLE_MAX_ROWSIZE_KEY
Max size of single row for Get's or Scan's without in-row scanning flag set.- See Also:
-
TABLE_MAX_ROWSIZE_DEFAULT
Default max row size (1 Gb).- See Also:
-
HSTORE_OPEN_AND_CLOSE_THREADS_MAX
The max number of threads used for opening and closing stores or store files in parallel- See Also:
-
DEFAULT_HSTORE_OPEN_AND_CLOSE_THREADS_MAX
The default number for the max number of threads used for opening and closing stores or store files in parallel- See Also:
-
HREGION_MEMSTORE_BLOCK_MULTIPLIER
Block updates if memstore has hbase.hregion.memstore.block.multiplier times hbase.hregion.memstore.flush.size bytes. Useful preventing runaway memstore during spikes in update traffic.- See Also:
-
DEFAULT_HREGION_MEMSTORE_BLOCK_MULTIPLIER
Default value for hbase.hregion.memstore.block.multiplier- See Also:
-
HREGION_MEMSTORE_FLUSH_SIZE
Conf key for the memstore size at which we flush the memstore- See Also:
-
HREGION_EDITS_REPLAY_SKIP_ERRORS
- See Also:
-
DEFAULT_HREGION_EDITS_REPLAY_SKIP_ERRORS
- See Also:
-
MAXIMUM_VALUE_LENGTH
Maximum value length, enforced on KeyValue construction- See Also:
-
CLUSTER_ID_FILE_NAME
name of the file for unique cluster ID- See Also:
-
CLUSTER_ID_DEFAULT
Default value for cluster ID- See Also:
-
KEEP_SEQID_PERIOD
Parameter name for # days to keep MVCC values during a major compaction- See Also:
-
MIN_KEEP_SEQID_PERIOD
At least to keep MVCC values in hfiles for 5 days- See Also:
-
BASE_NAMESPACE_DIR
- See Also:
-
META_ROW_DELIMITER
delimiter used between portions of a region name- See Also:
-
CATALOG_FAMILY_STR
The catalog family as a string- See Also:
-
CATALOG_FAMILY
The catalog family -
REGIONINFO_QUALIFIER_STR
The RegionInfo qualifier as a string- See Also:
-
REGIONINFO_QUALIFIER
The regioninfo column qualifier -
SERVER_QUALIFIER_STR
The server column qualifier- See Also:
-
SERVER_QUALIFIER
The server column qualifier -
STARTCODE_QUALIFIER_STR
The startcode column qualifier- See Also:
-
STARTCODE_QUALIFIER
The startcode column qualifier -
SEQNUM_QUALIFIER_STR
The open seqnum column qualifier- See Also:
-
SEQNUM_QUALIFIER
The open seqnum column qualifier -
STATE_QUALIFIER_STR
The state column qualifier- See Also:
-
STATE_QUALIFIER
-
SERVERNAME_QUALIFIER_STR
The serverName column qualifier. Its the server where the region is transitioning on, while column server is the server where the region is opened on. They are the same when the region is in state OPEN.- See Also:
-
SERVERNAME_QUALIFIER
-
SPLITA_QUALIFIER_STR
The lower-half split region column qualifier string.- See Also:
-
SPLITA_QUALIFIER
The lower-half split region column qualifier -
SPLITB_QUALIFIER_STR
The upper-half split region column qualifier String.- See Also:
-
SPLITB_QUALIFIER
The upper-half split region column qualifier -
MERGE_QUALIFIER_PREFIX_STR
Merge qualifier prefix. We used to only allow two regions merge; mergeA and mergeB. Now we allow many to merge. Each region to merge will be referenced in a column whose qualifier starts with this define.- See Also:
-
MERGE_QUALIFIER_PREFIX
-
MERGEA_QUALIFIER
Deprecated.Since 2.3.0 and 2.2.1. Not used anymore. Instead we look for theMERGE_QUALIFIER_PREFIX_STR
prefix.The lower-half merge region column qualifier -
MERGEB_QUALIFIER
Deprecated.Since 2.3.0 and 2.2.1. Not used anymore. Instead we look for theMERGE_QUALIFIER_PREFIX_STR
prefix.The upper-half merge region column qualifier -
TABLE_FAMILY_STR
The catalog family as a string- See Also:
-
TABLE_FAMILY
The catalog family -
TABLE_STATE_QUALIFIER
The serialized table state qualifier -
REPLICATION_BARRIER_FAMILY_STR
The replication barrier family as a string- See Also:
-
REPLICATION_BARRIER_FAMILY
The replication barrier family -
NAMESPACE_FAMILY_STR
The namespace family as a string- See Also:
-
NAMESPACE_FAMILY
The namespace family -
NAMESPACE_COL_DESC_QUALIFIER
-
META_VERSION_QUALIFIER
The meta table version column qualifier. We keep current version of the meta table in this column in-ROOT-
table: i.e. in the 'info:v' column. -
FAMILY_KEY_STR
The family str as a key in map- See Also:
-
META_VERSION
The current version of the meta table. - pre-hbase 0.92. There is no META_VERSION column in the root table in this case. The meta has HTableDescriptor serialized into the HRegionInfo; - version 0 is 0.92 and 0.94. Meta data has serialized HRegionInfo's using Writable serialization, and HRegionInfo's does not contain HTableDescriptors. - version 1 for 0.96+ keeps HRegionInfo data structures, but changes the byte[] serialization from Writables to Protobuf. See HRegionInfo.VERSION- See Also:
-
EMPTY_BYTE_ARRAY
An empty byte array instance. -
EMPTY_STRING
An empty string instance.- See Also:
-
EMPTY_BYTE_BUFFER
-
EMPTY_START_ROW
Used by scanners, etc when they want to start at the beginning of a region -
EMPTY_END_ROW
Last row in a table. -
LAST_ROW
Used by scanners and others when they're trying to detect the end of a table -
MAX_ROW_LENGTH
Max length a row can have because of the limitation in TFile.- See Also:
-
LATEST_TIMESTAMP
Timestamp to use when we want to refer to the latest cell. On client side, this is the timestamp set by default when no timestamp is specified, to refer to the latest. On server side, this acts as a notation. (1) For a cell of Put, which has this notation, its timestamp will be replaced with server's current time. (2) For a cell of Delete, which has this notation, A. If the cell is ofKeyValue.Type.Delete
, HBase issues a Get operation firstly. a. When the count of cell it gets is less than the count of cell to delete, the timestamp of Delete cell will be replaced with server's current time. b. When the count of cell it gets is equal to the count of cell to delete, the timestamp of Delete cell will be replaced with the latest timestamp of cell it gets. (c. It is invalid and an exception will be thrown, if the count of cell it gets is greater than the count of cell to delete, as the max version of Get is set to the count of cell to delete.) B. If the cell is of other Delete types, likeKeyValue.Type.DeleteFamilyVersion
,KeyValue.Type.DeleteColumn
, orKeyValue.Type.DeleteFamily
, the timestamp of Delete cell will be replaced with server's current time. So that is why it is named as "latest" but assigned as the max value of Long.- See Also:
-
LATEST_TIMESTAMP_BYTES
LATEST_TIMESTAMP in bytes form -
ALL_VERSIONS
Define for 'return-all-versions'.- See Also:
-
FOREVER
Unlimited time-to-live.- See Also:
-
DAY_IN_SECONDS
Seconds in a day, hour and minute- See Also:
-
HOUR_IN_SECONDS
- See Also:
-
MINUTE_IN_SECONDS
- See Also:
-
KB_IN_BYTES
KB, MB, GB, TB equivalent to how many bytes- See Also:
-
MB_IN_BYTES
- See Also:
-
GB_IN_BYTES
- See Also:
-
TB_IN_BYTES
- See Also:
-
NAME
- See Also:
-
VERSIONS
- See Also:
-
IN_MEMORY
- See Also:
-
METADATA
- See Also:
-
CONFIGURATION
- See Also:
-
RETRY_BACKOFF
Retrying we multiply hbase.client.pause setting by what we have in this array until we run out of array items. Retries beyond this use the last number in the array. So, for example, if hbase.client.pause is 1 second, and maximum retries count hbase.client.retries.number is 10, we will retry at the following intervals: 1, 2, 3, 5, 10, 20, 40, 100, 100, 100. With 100ms, a back-off of 200 means 20s -
REGION_IMPL
- See Also:
-
REPLICATION_SCOPE_LOCAL
Scope tag for locally scoped data. This data will not be replicated.- See Also:
-
REPLICATION_SCOPE_GLOBAL
Scope tag for globally scoped data. This data will be replicated to all peers.- See Also:
-
DEFAULT_CLUSTER_ID
Default cluster ID, cannot be used to identify a cluster so a key with this value means it wasn't meant for replication. -
HBASE_CLIENT_SCANNER_MAX_RESULT_SIZE_KEY
Parameter name for maximum number of bytes returned when calling a scanner's next method. Controlled by the client.- See Also:
-
HBASE_SERVER_SCANNER_MAX_RESULT_SIZE_KEY
Parameter name for maximum number of bytes returned when calling a scanner's next method. Controlled by the server.- See Also:
-
DEFAULT_HBASE_CLIENT_SCANNER_MAX_RESULT_SIZE
Maximum number of bytes returned when calling a scanner's next method. Note that when a single row is larger than this limit the row is still returned completely. The default value is 2MB.- See Also:
-
DEFAULT_HBASE_SERVER_SCANNER_MAX_RESULT_SIZE
Maximum number of bytes returned when calling a scanner's next method. Note that when a single row is larger than this limit the row is still returned completely. Safety setting to protect the region server. The default value is 100MB. (a client would rarely request larger chunks on purpose)- See Also:
-
HBASE_CLIENT_PAUSE
Parameter name for client pause value, used mostly as value to wait before running a retry of a failed get, region lookup, etc.- See Also:
-
DEFAULT_HBASE_CLIENT_PAUSE
Default value ofHBASE_CLIENT_PAUSE
.- See Also:
-
HBASE_CLIENT_PAUSE_FOR_CQTBE
Deprecated.Since 2.5.0, will be removed in 4.0.0. Please use hbase.client.pause.server.overloaded instead.Parameter name for client pause value for special case such as call queue too big, etc.- See Also:
-
HBASE_CLIENT_MAX_TOTAL_TASKS
The maximum number of concurrent connections the client will maintain.- See Also:
-
DEFAULT_HBASE_CLIENT_MAX_TOTAL_TASKS
Default value ofHBASE_CLIENT_MAX_TOTAL_TASKS
.- See Also:
-
HBASE_CLIENT_MAX_PERSERVER_TASKS
The maximum number of concurrent connections the client will maintain to a single RegionServer.- See Also:
-
DEFAULT_HBASE_CLIENT_MAX_PERSERVER_TASKS
Default value ofHBASE_CLIENT_MAX_PERSERVER_TASKS
.- See Also:
-
HBASE_CLIENT_MAX_PERREGION_TASKS
The maximum number of concurrent connections the client will maintain to a single Region.- See Also:
-
DEFAULT_HBASE_CLIENT_MAX_PERREGION_TASKS
Default value ofHBASE_CLIENT_MAX_PERREGION_TASKS
.- See Also:
-
HBASE_CLIENT_PERSERVER_REQUESTS_THRESHOLD
The maximum number of concurrent pending RPC requests for one server in process level.- See Also:
-
DEFAULT_HBASE_CLIENT_PERSERVER_REQUESTS_THRESHOLD
Default value ofHBASE_CLIENT_PERSERVER_REQUESTS_THRESHOLD
.- See Also:
-
HBASE_SERVER_PAUSE
Parameter name for server pause value, used mostly as value to wait before running a retry of a failed operation.- See Also:
-
DEFAULT_HBASE_SERVER_PAUSE
Default value ofHBASE_SERVER_PAUSE
.- See Also:
-
HBASE_CLIENT_RETRIES_NUMBER
Parameter name for maximum retries, used as maximum for all retryable operations such as fetching of the root region from root region server, getting a cell's value, starting a row update, etc.- See Also:
-
DEFAULT_HBASE_CLIENT_RETRIES_NUMBER
Default value ofHBASE_CLIENT_RETRIES_NUMBER
.- See Also:
-
HBASE_CLIENT_SERVERSIDE_RETRIES_MULTIPLIER
- See Also:
-
DEFAULT_HBASE_CLIENT_SERVERSIDE_RETRIES_MULTIPLIER
- See Also:
-
HBASE_CLIENT_SCANNER_CACHING
Parameter name to set the default scanner caching for all clients.- See Also:
-
DEFAULT_HBASE_CLIENT_SCANNER_CACHING
Default value forHBASE_CLIENT_SCANNER_CACHING
- See Also:
-
HBASE_META_SCANNER_CACHING
Parameter name for number of rows that will be fetched when calling next on a scanner if it is not served from memory. Higher caching values will enable faster scanners but will eat up more memory and some calls of next may take longer and longer times when the cache is empty.- See Also:
-
DEFAULT_HBASE_META_SCANNER_CACHING
Default value ofHBASE_META_SCANNER_CACHING
.- See Also:
-
HBASE_META_VERSIONS
Parameter name for number of versions, kept by meta table.- See Also:
-
DEFAULT_HBASE_META_VERSIONS
Default value ofHBASE_META_VERSIONS
.- See Also:
-
HBASE_META_BLOCK_SIZE
Parameter name for number of versions, kept by meta table.- See Also:
-
DEFAULT_HBASE_META_BLOCK_SIZE
Default value ofHBASE_META_BLOCK_SIZE
.- See Also:
-
HBASE_CLIENT_INSTANCE_ID
Parameter name for unique identifier for thisConfiguration
instance. If there are two or moreConfiguration
instances that, for all intents and purposes, are the same except for their instance ids, then they will not be able to share the same org.apache.hadoop.hbase.client.HConnection instance. On the other hand, even if the instance ids are the same, it could result in non-shared org.apache.hadoop.hbase.client.HConnection instances if some of the other connection parameters differ.- See Also:
-
HBASE_CLIENT_SCANNER_TIMEOUT_PERIOD
The client scanner timeout period in milliseconds.- See Also:
-
DEFAULT_HBASE_CLIENT_SCANNER_TIMEOUT_PERIOD
Default value ofHBASE_CLIENT_SCANNER_TIMEOUT_PERIOD
.- See Also:
-
HBASE_RPC_TIMEOUT_KEY
timeout for each RPC- See Also:
-
HBASE_RPC_READ_TIMEOUT_KEY
timeout for each read RPC- See Also:
-
HBASE_RPC_WRITE_TIMEOUT_KEY
timeout for each write RPC- See Also:
-
DEFAULT_HBASE_RPC_TIMEOUT
Default value ofHBASE_RPC_TIMEOUT_KEY
- See Also:
-
HBASE_RPC_SHORTOPERATION_TIMEOUT_KEY
timeout for short operation RPC- See Also:
-
DEFAULT_HBASE_RPC_SHORTOPERATION_TIMEOUT
Default value ofHBASE_RPC_SHORTOPERATION_TIMEOUT_KEY
- See Also:
-
HBASE_RPC_SHORTOPERATION_RETRY_PAUSE_TIME
Retry pause time for short operation RPC- See Also:
-
DEFAULT_HBASE_RPC_SHORTOPERATION_RETRY_PAUSE_TIME
Default value ofHBASE_RPC_SHORTOPERATION_RETRY_PAUSE_TIME
- See Also:
-
NO_SEQNUM
Value indicating the server name was saved with no sequence number.- See Also:
-
CLIENT_CONNECTION_REGISTRY_IMPL_CONF_KEY
Registry implementation to be used on the client side.- See Also:
-
REPLICATION_SOURCE_SERVICE_CLASSNAME
- See Also:
-
REPLICATION_SERVICE_CLASSNAME_DEFAULT
- See Also:
-
REPLICATION_SINK_SERVICE_CLASSNAME
- See Also:
-
REPLICATION_SINK_SERVICE_CLASSNAME_DEFAULT
- See Also:
-
REPLICATION_BULKLOAD_ENABLE_KEY
- See Also:
-
REPLICATION_BULKLOAD_ENABLE_DEFAULT
- See Also:
-
REPLICATION_CLUSTER_ID
Replication cluster id of source cluster which uniquely identifies itself with peer cluster- See Also:
-
REPLICATION_SOURCE_TOTAL_BUFFER_KEY
Max total size of buffered entries in all replication peers. It will prevent server getting OOM if there are many peers. Default value is 256MB which is four times to default replication.source.size.capacity.- See Also:
-
REPLICATION_SOURCE_TOTAL_BUFFER_DFAULT
- See Also:
-
REPLICATION_SOURCE_SHIPEDITS_TIMEOUT
Configuration key for ReplicationSource shipeEdits timeout- See Also:
-
REPLICATION_SOURCE_SHIPEDITS_TIMEOUT_DFAULT
- See Also:
-
REPLICATION_CONF_DIR
Directory where the source cluster file system client configuration are placed which is used by sink cluster to copy HFiles from source cluster file system- See Also:
-
BULKLOAD_MAX_RETRIES_NUMBER
Maximum time to retry for a failed bulk load request- See Also:
-
KEY_FOR_HOSTNAME_SEEN_BY_MASTER
- See Also:
-
HBASE_MASTER_LOGCLEANER_PLUGINS
- See Also:
-
HBASE_REGION_SPLIT_POLICY_KEY
- See Also:
-
HBASE_RS_NONCES_ENABLED
Whether nonces are enabled; default is true.- See Also:
-
HFILE_BLOCK_CACHE_SIZE_KEY
Configuration key for the size of the block cache- See Also:
-
HFILE_BLOCK_CACHE_SIZE_DEFAULT
- See Also:
-
HFILE_ONHEAP_BLOCK_CACHE_FIXED_SIZE_KEY
Configuration key for setting the fix size of the block size, default do nothing and it should be explicitly set by user or only used within ClientSideRegionScanner. if it's set less than current max on heap size, it overrides the max size of block cache- See Also:
-
HFILE_ONHEAP_BLOCK_CACHE_FIXED_SIZE_DEFAULT
- See Also:
-
HBASE_CLIENT_SCANNER_ONHEAP_BLOCK_CACHE_FIXED_SIZE_DEFAULT
- See Also:
-
HFILE_PREAD_ALL_BYTES_ENABLED_KEY
Configuration key for setting pread must read both necessaryLen and extraLen, default is disabled. This is an optimized flag for reading HFile from blob storage.- See Also:
-
HFILE_PREAD_ALL_BYTES_ENABLED_DEFAULT
- See Also:
-
HBASE_CLUSTER_MINIMUM_MEMORY_THRESHOLD
- See Also:
-
CP_HTD_ATTR_INCLUSION_KEY
- See Also:
-
SOCKET_RETRY_WAIT_MS
The delay when re-trying a socket operation in a loop (HBASE-4712)- See Also:
-
LOCALHOST
Host name of the local machine- See Also:
-
HBASE_CHECKSUM_VERIFICATION
If this parameter is set to true, then hbase will read data and then verify checksums. Checksum verification inside hdfs will be switched off. However, if the hbase-checksum verification fails, then it will switch back to using hdfs checksums for verifiying data that is being read from storage. If this parameter is set to false, then hbase will not verify any checksums, instead it will depend on checksum verification being done in the hdfs client.- See Also:
-
LOCALHOST_IP
- See Also:
-
REGION_SERVER_HANDLER_COUNT
- See Also:
-
DEFAULT_REGION_SERVER_HANDLER_COUNT
- See Also:
-
REGION_SERVER_HANDLER_ABORT_ON_ERROR_PERCENT
- See Also:
-
DEFAULT_REGION_SERVER_HANDLER_ABORT_ON_ERROR_PERCENT
- See Also:
-
REGION_SERVER_HIGH_PRIORITY_HANDLER_COUNT
- See Also:
-
DEFAULT_REGION_SERVER_HIGH_PRIORITY_HANDLER_COUNT
- See Also:
-
REGION_SERVER_REPLICATION_HANDLER_COUNT
- See Also:
-
DEFAULT_REGION_SERVER_REPLICATION_HANDLER_COUNT
- See Also:
-
REGION_SERVER_BULKLOAD_HANDLER_COUNT
- See Also:
-
DEFAULT_REGION_SERVER_BULKLOAD_HANDLER_COUNT
- See Also:
-
MASTER_META_TRANSITION_HANDLER_COUNT
- See Also:
-
MASTER__META_TRANSITION_HANDLER_COUNT_DEFAULT
- See Also:
-
USE_META_REPLICAS
Conf key for enabling meta replication- See Also:
-
DEFAULT_USE_META_REPLICAS
- See Also:
-
META_REPLICAS_NUM
Deprecated.Since 2.4.0, will be removed in 4.0.0. Please change the meta replicas number by altering meta table, i.e, set a new 'region replication' number and call modifyTable.- See Also:
-
DEFAULT_META_REPLICA_NUM
Deprecated.Since 2.4.0, will be removed in 4.0.0. Please change the meta replicas number by altering meta table, i.e, set a new 'region replication' number and call modifyTable.- See Also:
-
BYTES_PER_CHECKSUM
The name of the configuration parameter that specifies the number of bytes in a newly created checksum chunk.- See Also:
-
CHECKSUM_TYPE_NAME
The name of the configuration parameter that specifies the name of an algorithm that is used to compute checksums for newly created blocks.- See Also:
-
ENABLE_DATA_FILE_UMASK
Enable file permission modification from standard hbase- See Also:
-
DATA_FILE_UMASK_KEY
File permission umask to use when creating hbase data files- See Also:
-
ENABLE_WAL_COMPRESSION
Configuration name of WAL Compression- See Also:
-
WAL_STORAGE_POLICY
Configuration name of WAL storage policy Valid values are: HOT, COLD, WARM, ALL_SSD, ONE_SSD, LAZY_PERSIST See http://hadoop.apache.org/docs/r2.7.3/hadoop-project-dist/hadoop-hdfs/ArchivalStorage.html- See Also:
-
DEFER_TO_HDFS_STORAGE_POLICY
"NONE" is not a valid storage policy and means we defer the policy to HDFS. @see HBASE-20691- See Also:
-
DEFAULT_WAL_STORAGE_POLICY
By default we defer the WAL storage policy to HDFS- See Also:
-
METRICS_RIT_STUCK_WARNING_THRESHOLD
Region in Transition metrics threshold time- See Also:
-
LOAD_BALANCER_SLOP_KEY
- See Also:
-
DELIMITER
delimiter used between portions of a region name- See Also:
-
PRIORITY_UNSET
QOS attributes: these attributes are used to demarcate RPC call processing by different set of handlers. For example, HIGH_QOS tagged methods are handled by high priority handlers.- See Also:
-
NORMAL_QOS
- See Also:
-
REPLICATION_QOS
- See Also:
-
BULKLOAD_QOS
- See Also:
-
REPLAY_QOS
Deprecated.since 3.0.0, will be removed in 4.0.0. DLR has been purged for a long time and region replication has its own 'replay' method.- See Also:
-
REGION_REPLICATION_QOS
- See Also:
-
QOS_THRESHOLD
- See Also:
-
ADMIN_QOS
- See Also:
-
HIGH_QOS
- See Also:
-
SYSTEMTABLE_QOS
- See Also:
-
HFILE_ARCHIVE_DIRECTORY
Directory under /hbase where archived hfiles are stored- See Also:
-
SNAPSHOT_DIR_NAME
Name of the directory to store all snapshots. See SnapshotDescriptionUtils for remaining snapshot constants; this is here to keep HConstants dependencies at a minimum and uni-directional.- See Also:
-
OLD_SNAPSHOT_DIR_NAME
- See Also:
-
HBASE_TEMP_DIRECTORY
Temporary directory used for table creation and deletion- See Also:
-
REGIONSERVER_METRICS_PERIOD
The period (in milliseconds) between computing region server point in time metrics- See Also:
-
DEFAULT_REGIONSERVER_METRICS_PERIOD
- See Also:
-
HBASE_NON_TABLE_DIRS
Directories that are not HBase table directories -
HBASE_NON_USER_TABLE_DIRS
Deprecated.Since hbase-2.3.0; no replacement as not used any more (internally at least)Directories that are not HBase user table directories. -
HEALTH_SCRIPT_LOC
Health script related settings.- See Also:
-
HEALTH_SCRIPT_TIMEOUT
- See Also:
-
HEALTH_CHORE_WAKE_FREQ
- See Also:
-
DEFAULT_HEALTH_SCRIPT_TIMEOUT
- See Also:
-
HEALTH_FAILURE_THRESHOLD
The maximum number of health check failures a server can encounter consecutively.- See Also:
-
DEFAULT_HEALTH_FAILURE_THRESHOLD
- See Also:
-
EXECUTOR_STATUS_COLLECT_ENABLED
- See Also:
-
DEFAULT_EXECUTOR_STATUS_COLLECT_ENABLED
- See Also:
-
STATUS_PUBLISHED
Setting to activate, or not, the publication of the status by the master. Default notification is by a multicast message.- See Also:
-
STATUS_PUBLISHED_DEFAULT
- See Also:
-
STATUS_MULTICAST_ADDRESS
IP to use for the multicast status messages between the master and the clients. The default address is chosen as one among others within the ones suitable for multicast messages.- See Also:
-
DEFAULT_STATUS_MULTICAST_ADDRESS
- See Also:
-
STATUS_MULTICAST_BIND_ADDRESS
The address to use for binding the local socket for receiving multicast. Defaults to 0.0.0.0.- See Also:
-
DEFAULT_STATUS_MULTICAST_BIND_ADDRESS
- See Also:
-
STATUS_MULTICAST_PORT
The port to use for the multicast messages.- See Also:
-
DEFAULT_STATUS_MULTICAST_PORT
- See Also:
-
STATUS_MULTICAST_NI_NAME
The network interface name to use for the multicast messages.- See Also:
-
STATUS_MULTICAST_PUBLISHER_BIND_ADDRESS
The address to use for binding the local socket for sending multicast. Defaults to 0.0.0.0.- See Also:
-
DEFAULT_STATUS_MULTICAST_PUBLISHER_BIND_ADDRESS
- See Also:
-
NO_NONCE
- See Also:
-
CIPHER_AES
Default cipher for encryption- See Also:
-
CRYPTO_CIPHERPROVIDER_CONF_KEY
Configuration key for the crypto algorithm provider, a class name- See Also:
-
CRYPTO_KEYPROVIDER_CONF_KEY
Configuration key for the crypto key provider, a class name- See Also:
-
CRYPTO_KEYPROVIDER_PARAMETERS_KEY
Configuration key for the crypto key provider parameters- See Also:
-
CRYPTO_MASTERKEY_NAME_CONF_KEY
Configuration key for the name of the master key for the cluster, a string- See Also:
-
CRYPTO_MASTERKEY_ALTERNATE_NAME_CONF_KEY
Configuration key for the name of the alternate master key for the cluster, a string- See Also:
-
CRYPTO_WAL_ALGORITHM_CONF_KEY
Configuration key for the algorithm to use when encrypting the WAL, a string- See Also:
-
CRYPTO_WAL_KEY_NAME_CONF_KEY
Configuration key for the name of the master WAL encryption key for the cluster, a string- See Also:
-
CRYPTO_KEY_ALGORITHM_CONF_KEY
Configuration key for the algorithm used for creating jks key, a string- See Also:
-
CRYPTO_ALTERNATE_KEY_ALGORITHM_CONF_KEY
Configuration key for the name of the alternate cipher algorithm for the cluster, a string- See Also:
-
ENABLE_WAL_ENCRYPTION
Configuration key for enabling WAL encryption, a boolean- See Also:
-
RPC_CODEC_CONF_KEY
Configuration key for setting RPC codec class name- See Also:
-
REPLICATION_CODEC_CONF_KEY
Configuration key for setting replication codec class name- See Also:
-
REPLICATION_SOURCE_MAXTHREADS_KEY
Maximum number of threads used by the replication source for shipping edits to the sinks- See Also:
-
REPLICATION_DROP_ON_DELETED_TABLE_KEY
Deprecated.since 3.0.0. Will be removed in 4.0.0. Moved it into HBaseInterClusterReplicationEndpoint.Drop edits for tables that been deleted from the replication source and target- See Also:
-
REPLICATION_SOURCE_MAXTHREADS_DEFAULT
Maximum number of threads used by the replication source for shipping edits to the sinks- See Also:
-
HBASE_SPLITLOG_MANAGER_TIMEOUT
Configuration key for SplitLog manager timeout- See Also:
-
BUCKET_CACHE_IOENGINE_KEY
Current ioengine options in include: heap, offheap and file:PATH (where PATH is the path to the file that will host the file-based cache. See BucketCache#getIOEngineFromName() for list of supported ioengine options.Set this option and a non-zero
BUCKET_CACHE_SIZE_KEY
to enable bucket cache.- See Also:
-
BUCKET_CACHE_SIZE_KEY
When using bucket cache, it is the capacity in megabytes of the cache.- See Also:
-
BUCKET_CACHE_PERSISTENT_PATH_KEY
If the chosen ioengine can persist its state across restarts, the path to the file to persist to. This file is NOT the data file. It is a file into which we will serialize the map of what is in the data file. For example, if you pass the following argument as BUCKET_CACHE_IOENGINE_KEY ("hbase.bucketcache.ioengine"),file:/tmp/bucketcache.data
, then we will write the bucketcache data to the file/tmp/bucketcache.data
but the metadata on where the data is in the supplied file is an in-memory map that needs to be persisted across restarts. Where to store this in-memory state is what you supply here: e.g./tmp/bucketcache.map
.- See Also:
-
HBASE_CLIENT_FAST_FAIL_MODE_ENABLED
Deprecated.since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect. The constants itself will be removed in 4.0.0.Config for enabling/disabling the fast fail mode.- See Also:
-
HBASE_CLIENT_ENABLE_FAST_FAIL_MODE_DEFAULT
Deprecated.since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect. The constants itself will be removed in 4.0.0.- See Also:
-
HBASE_CLIENT_FAST_FAIL_THREASHOLD_MS
Deprecated.since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect. The constants itself will be removed in 4.0.0.- See Also:
-
HBASE_CLIENT_FAST_FAIL_THREASHOLD_MS_DEFAULT
Deprecated.since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect. The constants itself will be removed in 4.0.0.- See Also:
-
HBASE_CLIENT_FAILURE_MAP_CLEANUP_INTERVAL_MS
Deprecated.since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect. The constants itself will be removed in 4.0.0.- See Also:
-
HBASE_CLIENT_FAILURE_MAP_CLEANUP_INTERVAL_MS_DEFAULT
Deprecated.since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect. The constants itself will be removed in 4.0.0.- See Also:
-
HBASE_CLIENT_FAST_FAIL_CLEANUP_MS_DURATION_MS
Deprecated.since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect. The constants itself will be removed in 4.0.0.- See Also:
-
HBASE_CLIENT_FAST_FAIL_CLEANUP_DURATION_MS_DEFAULT
Deprecated.since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect. The constants itself will be removed in 4.0.0.- See Also:
-
HBASE_CLIENT_FAST_FAIL_INTERCEPTOR_IMPL
Deprecated.since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect. The constants itself will be removed in 4.0.0.- See Also:
-
HBASE_SPLIT_WAL_COORDINATED_BY_ZK
Deprecated.since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based distributed WAL splitter; see SplitWALManager.- See Also:
-
DEFAULT_HBASE_SPLIT_COORDINATED_BY_ZK
Deprecated.since 2.4.0 and in 3.0.0, to be removed in 4.0.0.- See Also:
-
HBASE_SPLIT_WAL_MAX_SPLITTER
- See Also:
-
DEFAULT_HBASE_SPLIT_WAL_MAX_SPLITTER
- See Also:
-
ENABLE_CLIENT_BACKPRESSURE
Config key for if the server should send backpressure and if the client should listen to that backpressure from the server- See Also:
-
DEFAULT_ENABLE_CLIENT_BACKPRESSURE
- See Also:
-
HEAP_OCCUPANCY_LOW_WATERMARK_KEY
- See Also:
-
DEFAULT_HEAP_OCCUPANCY_LOW_WATERMARK
- See Also:
-
HEAP_OCCUPANCY_HIGH_WATERMARK_KEY
- See Also:
-
DEFAULT_HEAP_OCCUPANCY_HIGH_WATERMARK
- See Also:
-
REGION_SPLIT_THREADS_MAX
The max number of threads used for splitting storefiles in parallel during the region split process.- See Also:
-
HBASE_CANARY_WRITE_DATA_TTL_KEY
Canary config keys- See Also:
-
HBASE_CANARY_WRITE_PERSERVER_REGIONS_LOWERLIMIT_KEY
- See Also:
-
HBASE_CANARY_WRITE_PERSERVER_REGIONS_UPPERLIMIT_KEY
- See Also:
-
HBASE_CANARY_WRITE_VALUE_SIZE_KEY
- See Also:
-
HBASE_CANARY_WRITE_TABLE_CHECK_PERIOD_KEY
- See Also:
-
HBASE_CANARY_READ_RAW_SCAN_KEY
- See Also:
-
HBASE_CANARY_READ_ALL_CF
- See Also:
-
ZK_CLIENT_KEYTAB_FILE
Configuration keys for programmatic JAAS configuration for secured ZK interaction- See Also:
-
ZK_CLIENT_KERBEROS_PRINCIPAL
- See Also:
-
ZK_SERVER_KEYTAB_FILE
- See Also:
-
ZK_SERVER_KERBEROS_PRINCIPAL
- See Also:
-
TEMPORARY_FS_DIRECTORY_KEY
Config key for hbase temporary directory in hdfs- See Also:
-
DEFAULT_TEMPORARY_HDFS_DIRECTORY
Don't use it! This'll get you the wrong path in a secure cluster. Use FileSystem.getHomeDirectory() or "/user/" + UserGroupInformation.getCurrentUser().getShortUserName() -
SNAPSHOT_RESTORE_TAKE_FAILSAFE_SNAPSHOT
- See Also:
-
DEFAULT_SNAPSHOT_RESTORE_TAKE_FAILSAFE_SNAPSHOT
- See Also:
-
SNAPSHOT_RESTORE_FAILSAFE_NAME
- See Also:
-
DEFAULT_SNAPSHOT_RESTORE_FAILSAFE_NAME
- See Also:
-
DEFAULT_LOSSY_COUNTING_ERROR_RATE
- See Also:
-
NOT_IMPLEMENTED
- See Also:
-
DEFAULT_SNAPSHOT_TTL
- See Also:
-
DEFAULT_SNAPSHOT_TTL_CONFIG_KEY
- See Also:
-
STORE_FILE_REF_COUNT_THRESHOLD
- See Also:
-
DEFAULT_STORE_FILE_REF_COUNT_THRESHOLD
- See Also:
-
REGIONS_RECOVERY_INTERVAL
- See Also:
-
DEFAULT_REGIONS_RECOVERY_INTERVAL
- See Also:
-
MASTER_OPEN_REGION_THREADS
Configurations for master executor services.- See Also:
-
MASTER_OPEN_REGION_THREADS_DEFAULT
- See Also:
-
MASTER_CLOSE_REGION_THREADS
- See Also:
-
MASTER_CLOSE_REGION_THREADS_DEFAULT
- See Also:
-
MASTER_SERVER_OPERATIONS_THREADS
- See Also:
-
MASTER_SERVER_OPERATIONS_THREADS_DEFAULT
- See Also:
-
MASTER_MERGE_DISPATCH_THREADS
Number of threads used to dispatch merge operations to the regionservers.- See Also:
-
MASTER_MERGE_DISPATCH_THREADS_DEFAULT
- See Also:
-
MASTER_META_SERVER_OPERATIONS_THREADS
- See Also:
-
MASTER_META_SERVER_OPERATIONS_THREADS_DEFAULT
- See Also:
-
MASTER_LOG_REPLAY_OPS_THREADS
- See Also:
-
MASTER_LOG_REPLAY_OPS_THREADS_DEFAULT
- See Also:
-
DEFAULT_SLOW_LOG_RING_BUFFER_SIZE
- See Also:
-
SLOW_LOG_BUFFER_ENABLED_KEY
- See Also:
-
DEFAULT_ONLINE_LOG_PROVIDER_ENABLED
- See Also:
-
SLOWLOG_INFO_FAMILY_STR
The slowlog info family as a string- See Also:
-
SLOWLOG_INFO_FAMILY
The slowlog info family -
SLOW_LOG_SYS_TABLE_ENABLED_KEY
- See Also:
-
DEFAULT_SLOW_LOG_SYS_TABLE_ENABLED_KEY
- See Also:
-
SLOW_LOG_SYS_TABLE_CHORE_DURATION_KEY
Deprecated.- See Also:
-
DEFAULT_SLOW_LOG_SYS_TABLE_CHORE_DURATION
- See Also:
-
SLOW_LOG_SCAN_PAYLOAD_ENABLED
- See Also:
-
SLOW_LOG_SCAN_PAYLOAD_ENABLED_DEFAULT
- See Also:
-
SHELL_TIMESTAMP_FORMAT_EPOCH_KEY
- See Also:
-
DEFAULT_SHELL_TIMESTAMP_FORMAT_EPOCH
- See Also:
-
BATCH_ROWS_THRESHOLD_NAME
Number of rows in a batch operation above which a warning will be logged.- See Also:
-
BATCH_ROWS_THRESHOLD_DEFAULT
Default value ofBATCH_ROWS_THRESHOLD_NAME
- See Also:
-
HBASE_SERVER_USEIP_ENABLED_KEY
In some scenarios, such as the elastic scaling scenario on the cloud, the HBase client may not be able to resolve the hostname of the newly added node. If the network is interconnected, the client can actually access the HBase cluster nodes through ip. However, since the HBase client obtains the Master/RS address info from or the ZK or the meta table, so the Master/RS of the HBase cluster needs to expose the service with ip instead of the hostname. Therefore, We can use hostname by default, but at the same time, we can also provide a config to support whether to use ip for Master/RS service. See HBASE-27304 for details.- See Also:
-
HBASE_SERVER_USEIP_ENABLED_DEFAULT
Default value ofHBASE_SERVER_USEIP_ENABLED_KEY
- See Also:
-
REJECT_DECOMMISSIONED_HOSTS_KEY
Should the HMaster reject hosts of decommissioned RegionServers, bypass matching their port and startcode parts of their ServerName or not? When True, the HMaster will reject a RegionServer's request to `reportForDuty` if it's hostname exists in the list of decommissioned RegionServers it maintains internally. Added in HBASE-28342.- See Also:
-
REJECT_DECOMMISSIONED_HOSTS_DEFAULT
Default value ofREJECT_DECOMMISSIONED_HOSTS_KEY
- See Also:
-
-
Constructor Details
-
HConstants
private HConstants()
-