@InterfaceAudience.Public public final class HConstants extends Object
Modifier and Type | Class and Description |
---|---|
static class |
HConstants.OperationStatusCode
Status codes used for return values of bulk operations.
|
Modifier and Type | Field and Description |
---|---|
static int |
ADMIN_QOS |
static int |
ALL_VERSIONS
Define for 'return-all-versions'.
|
static String |
BASE_NAMESPACE_DIR |
static int |
BATCH_ROWS_THRESHOLD_DEFAULT
Default value of
BATCH_ROWS_THRESHOLD_NAME |
static String |
BATCH_ROWS_THRESHOLD_NAME
Number of rows in a batch operation above which a warning will be logged.
|
static String |
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.
|
static String |
BUCKET_CACHE_SIZE_KEY
When using bucket cache, it is the capacity in megabytes of the cache.
|
static String |
BULKLOAD_MAX_RETRIES_NUMBER
Maximum time to retry for a failed bulk load request
|
static String |
BULKLOAD_STAGING_DIR_NAME
Staging dir used by bulk load
|
static String |
BYTES_PER_CHECKSUM
The name of the configuration parameter that specifies the number of bytes in a newly created
checksum chunk.
|
static byte[] |
CATALOG_FAMILY
The catalog family
|
static String |
CATALOG_FAMILY_STR
The catalog family as a string
|
static String |
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.
|
static String |
CIPHER_AES
Default cipher for encryption
|
static String |
CLIENT_CONNECTION_REGISTRY_IMPL_CONF_KEY
Registry implementation to be used on the client side.
|
static String |
CLIENT_PORT_STR
The ZK client port key in the ZK properties map.
|
static String |
CLIENT_ZOOKEEPER_CLIENT_PORT
Client port of ZooKeeper for client to locate meta
|
static String |
CLIENT_ZOOKEEPER_OBSERVER_MODE
Indicate whether the client ZK are observer nodes of the server ZK
|
static String |
CLIENT_ZOOKEEPER_QUORUM
Name of ZooKeeper quorum configuration parameter for client to locate meta.
|
static String |
CLUSTER_DISTRIBUTED
Cluster is in distributed mode or not
|
static String |
CLUSTER_ID_DEFAULT
Default value for cluster ID
|
static String |
CLUSTER_ID_FILE_NAME
name of the file for unique cluster ID
|
static boolean |
CLUSTER_IS_DISTRIBUTED
Deprecated.
|
static boolean |
CLUSTER_IS_LOCAL
Cluster is standalone or pseudo-distributed
|
static String |
COMPACTION_KV_MAX
Parameter name for the maximum batch of KVs to be used in flushes and compactions
|
static int |
COMPACTION_KV_MAX_DEFAULT |
static String |
CONFIGURATION |
static String |
CORRUPT_DIR_NAME |
static String |
CP_HTD_ATTR_INCLUSION_KEY |
static Pattern |
CP_HTD_ATTR_KEY_PATTERN
Deprecated.
It is used internally. As of release 2.0.0, this will be removed in HBase 3.0.0.
|
static String |
CP_HTD_ATTR_VALUE_PARAM_KEY_PATTERN
Deprecated.
It is used internally. As of release 2.0.0, this will be removed in HBase 3.0.0.
|
static Pattern |
CP_HTD_ATTR_VALUE_PARAM_PATTERN
Deprecated.
It is used internally. As of release 2.0.0, this will be removed in HBase 3.0.0.
|
static String |
CP_HTD_ATTR_VALUE_PARAM_VALUE_PATTERN
Deprecated.
It is used internally. As of release 2.0.0, this will be removed in HBase 3.0.0.
|
static Pattern |
CP_HTD_ATTR_VALUE_PATTERN
Deprecated.
It is used internally. As of release 2.0.0, this will be removed in HBase 3.0.0.
|
static String |
CRYPTO_ALTERNATE_KEY_ALGORITHM_CONF_KEY
Configuration key for the name of the alternate cipher algorithm for the cluster, a string
|
static String |
CRYPTO_CIPHERPROVIDER_CONF_KEY
Configuration key for the crypto algorithm provider, a class name
|
static String |
CRYPTO_KEY_ALGORITHM_CONF_KEY
Configuration key for the algorithm used for creating jks key, a string
|
static String |
CRYPTO_KEYPROVIDER_CONF_KEY
Configuration key for the crypto key provider, a class name
|
static String |
CRYPTO_KEYPROVIDER_PARAMETERS_KEY
Configuration key for the crypto key provider parameters
|
static String |
CRYPTO_MASTERKEY_ALTERNATE_NAME_CONF_KEY
Configuration key for the name of the alternate master key for the cluster, a string
|
static String |
CRYPTO_MASTERKEY_NAME_CONF_KEY
Configuration key for the name of the master key for the cluster, a string
|
static String |
CRYPTO_WAL_ALGORITHM_CONF_KEY
Configuration key for the algorithm to use when encrypting the WAL, a string
|
static String |
CRYPTO_WAL_KEY_NAME_CONF_KEY
Configuration key for the name of the master WAL encryption key for the cluster, a string
|
static String |
DATA_FILE_UMASK_KEY
File permission umask to use when creating hbase data files
|
static int |
DAY_IN_SECONDS
Seconds in a day, hour and minute
|
static int |
DEFAULT_BLOCKSIZE
Default block size for an HFile.
|
static boolean |
DEFAULT_CLIENT_ZOOKEEPER_OBSERVER_MODE
Assuming client zk not in observer mode and master need to synchronize information
|
static boolean |
DEFAULT_CLUSTER_DISTRIBUTED
Default value for cluster distributed mode
|
static UUID |
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.
|
static boolean |
DEFAULT_ENABLE_CLIENT_BACKPRESSURE |
static int |
DEFAULT_HBASE_BALANCER_PERIOD
Default value for the balancer period
|
static int |
DEFAULT_HBASE_CLIENT_MAX_PERREGION_TASKS
Default value of
HBASE_CLIENT_MAX_PERREGION_TASKS . |
static int |
DEFAULT_HBASE_CLIENT_MAX_PERSERVER_TASKS
Default value of
HBASE_CLIENT_MAX_PERSERVER_TASKS . |
static int |
DEFAULT_HBASE_CLIENT_MAX_TOTAL_TASKS
Default value of
HBASE_CLIENT_MAX_TOTAL_TASKS . |
static int |
DEFAULT_HBASE_CLIENT_OPERATION_TIMEOUT
Default HBase client operation timeout, which is tantamount to a blocking call
|
static long |
DEFAULT_HBASE_CLIENT_PAUSE
Default value of
HBASE_CLIENT_PAUSE . |
static int |
DEFAULT_HBASE_CLIENT_PERSERVER_REQUESTS_THRESHOLD
Default value of
HBASE_CLIENT_PERSERVER_REQUESTS_THRESHOLD . |
static int |
DEFAULT_HBASE_CLIENT_RETRIES_NUMBER
Default value of
HBASE_CLIENT_RETRIES_NUMBER . |
static int |
DEFAULT_HBASE_CLIENT_SCANNER_CACHING
Default value for
HBASE_CLIENT_SCANNER_CACHING |
static long |
DEFAULT_HBASE_CLIENT_SCANNER_MAX_RESULT_SIZE
Maximum number of bytes returned when calling a scanner's next method.
|
static int |
DEFAULT_HBASE_CLIENT_SCANNER_TIMEOUT_PERIOD
Default value of
HBASE_CLIENT_SCANNER_TIMEOUT_PERIOD . |
static int |
DEFAULT_HBASE_CLIENT_SERVERSIDE_RETRIES_MULTIPLIER |
static boolean |
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)
|
static double |
DEFAULT_HBASE_MASTER_BALANCER_MAX_RIT_PERCENT
Default value for the max percent of regions in transition
|
static int |
DEFAULT_HBASE_META_BLOCK_SIZE
Default value of
HBASE_META_BLOCK_SIZE . |
static int |
DEFAULT_HBASE_META_SCANNER_CACHING
Default value of
HBASE_META_SCANNER_CACHING . |
static int |
DEFAULT_HBASE_META_VERSIONS
Default value of
HBASE_META_VERSIONS . |
static long |
DEFAULT_HBASE_RPC_SHORTOPERATION_RETRY_PAUSE_TIME
Default value of
HBASE_RPC_SHORTOPERATION_RETRY_PAUSE_TIME |
static int |
DEFAULT_HBASE_RPC_SHORTOPERATION_TIMEOUT
Default value of
HBASE_RPC_SHORTOPERATION_TIMEOUT_KEY |
static int |
DEFAULT_HBASE_RPC_TIMEOUT
Default value of
HBASE_RPC_TIMEOUT_KEY |
static int |
DEFAULT_HBASE_SERVER_PAUSE
Default value of
HBASE_SERVER_PAUSE . |
static long |
DEFAULT_HBASE_SERVER_SCANNER_MAX_RESULT_SIZE
Maximum number of bytes returned when calling a scanner's next method.
|
static boolean |
DEFAULT_HBASE_SPLIT_COORDINATED_BY_ZK
Deprecated.
since 2.4.0 and in 3.0.0, to be removed in 4.0.0.
|
static int |
DEFAULT_HBASE_SPLIT_WAL_MAX_SPLITTER |
static int |
DEFAULT_HEALTH_FAILURE_THRESHOLD |
static long |
DEFAULT_HEALTH_SCRIPT_TIMEOUT |
static float |
DEFAULT_HEAP_OCCUPANCY_HIGH_WATERMARK |
static float |
DEFAULT_HEAP_OCCUPANCY_LOW_WATERMARK |
static String |
DEFAULT_HOST
default host address
|
static boolean |
DEFAULT_HREGION_EDITS_REPLAY_SKIP_ERRORS |
static int |
DEFAULT_HREGION_MEMSTORE_BLOCK_MULTIPLIER
Default value for hbase.hregion.memstore.block.multiplier
|
static int |
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
|
static String |
DEFAULT_LOSSY_COUNTING_ERROR_RATE |
static float |
DEFAULT_MAJOR_COMPACTION_JITTER |
static long |
DEFAULT_MAJOR_COMPACTION_PERIOD |
static int |
DEFAULT_MASTER_HANLDER_COUNT
Deprecated.
|
static int |
DEFAULT_MASTER_INFOPORT
default port for master web api
|
static int |
DEFAULT_MASTER_PORT
default port that the master listens on
|
static boolean |
DEFAULT_MASTER_TYPE_BACKUP
by default every master is a possible primary master unless the conf explicitly overrides it
|
static long |
DEFAULT_MAX_FILE_SIZE
Default maximum file size
|
static int |
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.
|
static boolean |
DEFAULT_ONLINE_LOG_PROVIDER_ENABLED |
static boolean |
DEFAULT_OVERALL_HREGION_FILES
Default overall region files
|
static double |
DEFAULT_REGION_SERVER_HANDLER_ABORT_ON_ERROR_PERCENT |
static int |
DEFAULT_REGION_SERVER_HANDLER_COUNT |
static int |
DEFAULT_REGION_SERVER_HIGH_PRIORITY_HANDLER_COUNT |
static int |
DEFAULT_REGION_SERVER_REPLICATION_HANDLER_COUNT |
static int |
DEFAULT_REGIONS_RECOVERY_INTERVAL |
static int |
DEFAULT_REGIONSERVER_INFOPORT
default port for region server web api
|
static long |
DEFAULT_REGIONSERVER_METRICS_PERIOD |
static int |
DEFAULT_REGIONSERVER_PORT
Default port region server listens on.
|
static boolean |
DEFAULT_SHELL_TIMESTAMP_FORMAT_EPOCH |
static int |
DEFAULT_SLOW_LOG_RING_BUFFER_SIZE |
static boolean |
DEFAULT_SLOW_LOG_SYS_TABLE_ENABLED_KEY |
static String |
DEFAULT_SNAPSHOT_RESTORE_FAILSAFE_NAME |
static boolean |
DEFAULT_SNAPSHOT_RESTORE_TAKE_FAILSAFE_SNAPSHOT |
static long |
DEFAULT_SNAPSHOT_TTL |
static String |
DEFAULT_SNAPSHOT_TTL_CONFIG_KEY |
static String |
DEFAULT_STATUS_MULTICAST_ADDRESS |
static String |
DEFAULT_STATUS_MULTICAST_BIND_ADDRESS |
static int |
DEFAULT_STATUS_MULTICAST_PORT |
static String |
DEFAULT_STATUS_MULTICAST_PUBLISHER_BIND_ADDRESS |
static int |
DEFAULT_STORE_FILE_REF_COUNT_THRESHOLD |
static String |
DEFAULT_TEMPORARY_HDFS_DIRECTORY |
static int |
DEFAULT_THREAD_WAKE_FREQUENCY
Default value for thread wake frequency
|
static boolean |
DEFAULT_USE_META_REPLICAS |
static int |
DEFAULT_VERSION_FILE_WRITE_ATTEMPTS
Parameter name for how often we should try to write a version file, before failing
|
static String |
DEFAULT_WAL_STORAGE_POLICY
By default we defer the WAL storage policy to HDFS
|
static int |
DEFAULT_ZK_SESSION_TIMEOUT
Default value for ZooKeeper session timeout
|
static int |
DEFAULT_ZOOKEEPER_CLIENT_PORT
Default client port that the zookeeper listens on
|
static int |
DEFAULT_ZOOKEEPER_MAX_CLIENT_CNXNS
Default limit on concurrent client-side zookeeper connections
|
static String |
DEFAULT_ZOOKEEPER_ZNODE_PARENT |
static int |
DEFAULT_ZOOKEPER_CLIENT_PORT
Deprecated.
use
DEFAULT_ZOOKEEPER_CLIENT_PORT instead |
static int |
DEFAULT_ZOOKEPER_MAX_CLIENT_CNXNS
Deprecated.
use
DEFAULT_ZOOKEEPER_MAX_CLIENT_CNXNS instead |
static long |
DEFAULT_ZOOKEPER_RECOVERABLE_WAITIME
Deprecated.
|
static String |
DEFER_TO_HDFS_STORAGE_POLICY
"NONE" is not a valid storage policy and means we defer the policy to HDFS.
|
static int |
DELIMITER
delimiter used between portions of a region name
|
static byte[] |
EMPTY_BYTE_ARRAY
An empty byte array instance.
|
static ByteBuffer |
EMPTY_BYTE_BUFFER |
static byte[] |
EMPTY_END_ROW
Last row in a table.
|
static byte[] |
EMPTY_START_ROW
Used by scanners, etc when they want to start at the beginning of a region
|
static String |
EMPTY_STRING
An empty string instance.
|
static String |
ENABLE_CLIENT_BACKPRESSURE
Config key for if the server should send backpressure and if the client should listen to that
backpressure from the server
|
static String |
ENABLE_DATA_FILE_UMASK
Enable file permission modification from standard hbase
|
static String |
ENABLE_WAL_COMPRESSION
Configuration name of WAL Compression
|
static String |
ENABLE_WAL_ENCRYPTION
Configuration key for enabling WAL encryption, a boolean
|
static TableName |
ENSEMBLE_TABLE_NAME
The name of the ensemble table
|
static String |
FAMILY_KEY_STR
The family str as a key in map
|
static String |
FILE_SYSTEM_VERSION
Current version of file system.
|
static int |
FOREVER
Unlimited time-to-live.
|
static long |
GB_IN_BYTES |
static String |
HBASE_BALANCER_MAX_BALANCING
Config for the max balancing time
|
static String |
HBASE_BALANCER_PERIOD
Config for the balancer period
|
static String |
HBASE_CANARY_READ_ALL_CF |
static String |
HBASE_CANARY_READ_RAW_SCAN_KEY |
static String |
HBASE_CANARY_WRITE_DATA_TTL_KEY
Canary config keys
|
static String |
HBASE_CANARY_WRITE_PERSERVER_REGIONS_LOWERLIMIT_KEY |
static String |
HBASE_CANARY_WRITE_PERSERVER_REGIONS_UPPERLIMIT_KEY |
static String |
HBASE_CANARY_WRITE_TABLE_CHECK_PERIOD_KEY |
static String |
HBASE_CANARY_WRITE_VALUE_SIZE_KEY |
static String |
HBASE_CHECKSUM_VERIFICATION
If this parameter is set to true, then hbase will read data and then verify checksums.
|
static boolean |
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.
|
static String |
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.
|
static long |
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.
|
static long |
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.
|
static String |
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.
|
static String |
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.
|
static String |
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.
|
static String |
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.
|
static long |
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.
|
static String |
HBASE_CLIENT_INSTANCE_ID
Parameter name for unique identifier for this
Configuration
instance. |
static String |
HBASE_CLIENT_IPC_POOL_SIZE
Parameter name for HBase client IPC pool size
|
static String |
HBASE_CLIENT_IPC_POOL_TYPE
Parameter name for HBase client IPC pool type
|
static String |
HBASE_CLIENT_MAX_PERREGION_TASKS
The maximum number of concurrent connections the client will maintain to a single Region.
|
static String |
HBASE_CLIENT_MAX_PERSERVER_TASKS
The maximum number of concurrent connections the client will maintain to a single RegionServer.
|
static String |
HBASE_CLIENT_MAX_TOTAL_TASKS
The maximum number of concurrent connections the client will maintain.
|
static String |
HBASE_CLIENT_META_OPERATION_TIMEOUT
Parameter name for HBase client meta operation timeout.
|
static String |
HBASE_CLIENT_META_REPLICA_SCAN_TIMEOUT
Parameter name for HBase client meta replica scan call timeout.
|
static int |
HBASE_CLIENT_META_REPLICA_SCAN_TIMEOUT_DEFAULT
Default HBase client meta replica scan call timeout, 1 second
|
static String |
HBASE_CLIENT_OPERATION_TIMEOUT
Parameter name for HBase client operation timeout.
|
static String |
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.
|
static String |
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.
|
static String |
HBASE_CLIENT_PERSERVER_REQUESTS_THRESHOLD
The maximum number of concurrent pending RPC requests for one server in process level.
|
static String |
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.
|
static String |
HBASE_CLIENT_SCANNER_CACHING
Parameter name to set the default scanner caching for all clients.
|
static String |
HBASE_CLIENT_SCANNER_MAX_RESULT_SIZE_KEY
Parameter name for maximum number of bytes returned when calling a scanner's next method.
|
static long |
HBASE_CLIENT_SCANNER_ONHEAP_BLOCK_CACHE_FIXED_SIZE_DEFAULT |
static String |
HBASE_CLIENT_SCANNER_TIMEOUT_PERIOD
The client scanner timeout period in milliseconds.
|
static String |
HBASE_CLIENT_SERVERSIDE_RETRIES_MULTIPLIER |
static float |
HBASE_CLUSTER_MINIMUM_MEMORY_THRESHOLD |
static String |
HBASE_DIR
Parameter name for HBase instance root directory
|
static String |
HBASE_ENABLE_SEPARATE_CHILD_REGIONS
Config key for enable/disable automatically separate child regions to different region servers
in the procedure of split regions.
|
static String |
HBASE_MASTER_BALANCER_MAX_RIT_PERCENT
Config for the max percent of regions in transition
|
static String |
HBASE_MASTER_LOADBALANCE_BYTABLE
Config for balancing the cluster by table
|
static String |
HBASE_MASTER_LOADBALANCER_CLASS
Config for pluggable load balancers
|
static String |
HBASE_MASTER_LOGCLEANER_PLUGINS |
static String |
HBASE_MASTER_NORMALIZER_CLASS
Config for pluggable region normalizer
|
static String |
HBASE_META_BLOCK_SIZE
Parameter name for number of versions, kept by meta table.
|
static String |
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.
|
static String |
HBASE_META_VERSIONS
Parameter name for number of versions, kept by meta table.
|
static List<String> |
HBASE_NON_TABLE_DIRS
Directories that are not HBase table directories
|
static List<String> |
HBASE_NON_USER_TABLE_DIRS
Deprecated.
Since hbase-2.3.0; no replacement as not used any more (internally at least)
|
static String |
HBASE_REGION_SPLIT_POLICY_KEY |
static String |
HBASE_REGIONSERVER_LEASE_PERIOD_KEY
Deprecated.
This config option is deprecated. Will be removed at later releases after 0.96.
|
static String |
HBASE_RPC_READ_TIMEOUT_KEY
timeout for each read RPC
|
static String |
HBASE_RPC_SHORTOPERATION_RETRY_PAUSE_TIME
Retry pause time for short operation RPC
|
static String |
HBASE_RPC_SHORTOPERATION_TIMEOUT_KEY
timeout for short operation RPC
|
static String |
HBASE_RPC_TIMEOUT_KEY
timeout for each RPC
|
static String |
HBASE_RPC_WRITE_TIMEOUT_KEY
timeout for each write RPC
|
static String |
HBASE_RS_NONCES_ENABLED
Whether nonces are enabled; default is true.
|
static String |
HBASE_SERVER_PAUSE
Parameter name for server pause value, used mostly as value to wait before running a retry of a
failed operation.
|
static String |
HBASE_SERVER_SCANNER_MAX_RESULT_SIZE_KEY
Parameter name for maximum number of bytes returned when calling a scanner's next method.
|
static String |
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.
|
static String |
HBASE_SPLIT_WAL_MAX_SPLITTER |
static String |
HBASE_SPLITLOG_MANAGER_TIMEOUT
Configuration key for SplitLog manager timeout
|
static String |
HBASE_TEMP_DIRECTORY
Temporary directory used for table creation and deletion
|
static String |
HBASECLIENT_IMPL
Deprecated.
|
static String |
HBCK_CODE_NAME
Deprecated.
|
static String |
HBCK_SIDELINEDIR_NAME
Used by HBCK to sideline backup data
|
static String |
HEALTH_CHORE_WAKE_FREQ |
static String |
HEALTH_FAILURE_THRESHOLD
The maximum number of health check failures a server can encounter consecutively.
|
static String |
HEALTH_SCRIPT_LOC
Health script related settings.
|
static String |
HEALTH_SCRIPT_TIMEOUT |
static String |
HEAP_OCCUPANCY_HIGH_WATERMARK_KEY |
static String |
HEAP_OCCUPANCY_LOW_WATERMARK_KEY |
static String |
HFILE_ARCHIVE_DIRECTORY
Directory under /hbase where archived hfiles are stored
|
static float |
HFILE_BLOCK_CACHE_SIZE_DEFAULT |
static String |
HFILE_BLOCK_CACHE_SIZE_KEY
Configuration key for the size of the block cache
|
static long |
HFILE_ONHEAP_BLOCK_CACHE_FIXED_SIZE_DEFAULT |
static String |
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.
|
static boolean |
HFILE_PREAD_ALL_BYTES_ENABLED_DEFAULT |
static String |
HFILE_PREAD_ALL_BYTES_ENABLED_KEY
Configuration key for setting pread must read both necessaryLen and extraLen, default is
disabled.
|
static byte[] |
HFILEBLOCK_DUMMY_HEADER
Just an array of bytes of the right size.
|
static int |
HFILEBLOCK_HEADER_SIZE
The size of a version 2 HFile block header, minor version 1.
|
static int |
HFILEBLOCK_HEADER_SIZE_NO_CHECKSUM
The size data structures with minor version is 0
|
static int |
HIGH_QOS |
static int |
HOUR_IN_SECONDS |
static String |
HREGION_COMPACTIONDIR_NAME
Used to construct the name of the compaction directory during compaction
|
static String |
HREGION_EDITS_REPLAY_SKIP_ERRORS |
static String |
HREGION_LOGDIR_NAME
Used to construct the name of the log directory for a region server
|
static String |
HREGION_MAX_FILESIZE
Conf key for the max file size after which we split the region
|
static String |
HREGION_MEMSTORE_BLOCK_MULTIPLIER
Block updates if memstore has hbase.hregion.memstore.block.multiplier times
hbase.hregion.memstore.flush.size bytes.
|
static String |
HREGION_MEMSTORE_FLUSH_SIZE
Conf key for the memstore size at which we flush the memstore
|
static String |
HREGION_OLDLOGDIR_NAME
Like the previous, but for old logs that are about to be deleted
|
static String |
HSTORE_OPEN_AND_CLOSE_THREADS_MAX
The max number of threads used for opening and closing stores or store files in parallel
|
static String |
IN_MEMORY |
static int |
INDEX_KEY_MAGIC
Used as a magic return value while optimized index key feature enabled(HBASE-7845)
|
static long |
KB_IN_BYTES
KB, MB, GB, TB equivalent to how many bytes
|
static String |
KEEP_SEQID_PERIOD
Parameter name for # days to keep MVCC values during a major compaction
|
static String |
KEY_FOR_HOSTNAME_SEEN_BY_MASTER |
static byte[] |
LAST_ROW
Used by scanners and others when they're trying to detect the end of a table
|
static long |
LATEST_TIMESTAMP
Timestamp to use when we want to refer to the latest cell.
|
static byte[] |
LATEST_TIMESTAMP_BYTES
LATEST_TIMESTAMP in bytes form
|
static String |
LIB_DIR
Deprecated.
|
static String |
LOAD_BALANCER_SLOP_KEY |
static String |
LOCALHOST
Host name of the local machine
|
static String |
LOCALHOST_IP |
static String |
LOG_REPLAY_WAIT_REGION_TIMEOUT
Deprecated.
|
static String |
MAJOR_COMPACTION_JITTER
Parameter name and default value for major compaction jitter.
|
static String |
MAJOR_COMPACTION_PERIOD
Parameter name and default value for how often a region should perform a major compaction
|
static int |
MASTER__META_TRANSITION_HANDLER_COUNT_DEFAULT |
static String |
MASTER_ADDRS_KEY
Configuration key for the list of master host:ports
|
static String |
MASTER_CLOSE_REGION_THREADS |
static int |
MASTER_CLOSE_REGION_THREADS_DEFAULT |
static String |
MASTER_HANDLER_COUNT
Deprecated.
|
static String |
MASTER_IMPL
Parameter name for what master implementation to use.
|
static String |
MASTER_INFO_PORT
Configuration key for master web API port
|
static String |
MASTER_LOG_REPLAY_OPS_THREADS |
static int |
MASTER_LOG_REPLAY_OPS_THREADS_DEFAULT |
static String |
MASTER_MERGE_DISPATCH_THREADS
Number of threads used to dispatch merge operations to the regionservers.
|
static int |
MASTER_MERGE_DISPATCH_THREADS_DEFAULT |
static String |
MASTER_META_SERVER_OPERATIONS_THREADS |
static int |
MASTER_META_SERVER_OPERATIONS_THREADS_DEFAULT |
static String |
MASTER_META_TRANSITION_HANDLER_COUNT |
static String |
MASTER_OPEN_REGION_THREADS
Configurations for master executor services.
|
static int |
MASTER_OPEN_REGION_THREADS_DEFAULT |
static String |
MASTER_PORT
Parameter name for port master listens on.
|
static String |
MASTER_SERVER_OPERATIONS_THREADS |
static int |
MASTER_SERVER_OPERATIONS_THREADS_DEFAULT |
static String |
MASTER_TYPE_BACKUP
Parameter name for the master type being backup (waits for primary to go inactive).
|
static int |
MAX_ROW_LENGTH
Max length a row can have because of the limitation in TFile.
|
static int |
MAXIMUM_VALUE_LENGTH
Maximum value length, enforced on KeyValue construction
|
static long |
MB_IN_BYTES |
static byte[] |
MERGE_QUALIFIER_PREFIX |
static String |
MERGE_QUALIFIER_PREFIX_STR
Merge qualifier prefix.
|
static byte[] |
MERGEA_QUALIFIER
Deprecated.
Since 2.3.0 and 2.2.1. Not used anymore. Instead we look for the
MERGE_QUALIFIER_PREFIX_STR prefix. |
static byte[] |
MERGEB_QUALIFIER
Deprecated.
Since 2.3.0 and 2.2.1. Not used anymore. Instead we look for the
MERGE_QUALIFIER_PREFIX_STR prefix. |
static int |
META_QOS
Deprecated.
the name "META_QOS" is a bit ambiguous, actually only meta region transition can
use this priority, and you should not use this directly. Will be removed in 3.0.0.
|
static String |
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.
|
static int |
META_ROW_DELIMITER
delimiter used between portions of a region name
|
static short |
META_VERSION
The current version of the meta table.
|
static byte[] |
META_VERSION_QUALIFIER
The meta table version column qualifier.
|
static String |
METADATA |
static String |
METRICS_RIT_STUCK_WARNING_THRESHOLD
Region in Transition metrics threshold time
|
static String |
MIGRATION_NAME
Any artifacts left from migration can be moved here
|
static int |
MIN_KEEP_SEQID_PERIOD
At least to keep MVCC values in hfiles for 5 days
|
static int |
MINUTE_IN_SECONDS |
static String |
NAME |
static String |
NINES |
static long |
NO_NONCE |
static long |
NO_SEQNUM
Value indicating the server name was saved with no sequence number.
|
static int |
NORMAL_QOS |
static String |
NOT_IMPLEMENTED |
static String |
OLD_SNAPSHOT_DIR_NAME |
static long |
OLDEST_TIMESTAMP
Deprecated.
Should not be public since hbase-1.3.0. For internal use only. Move internal to
Scanners flagged as special timestamp value never to be returned as timestamp on a
Cell.
|
static String |
OVERALL_HREGION_FILES
Conf key for if we should sum overall region files size when check to split
|
static int |
PRIORITY_UNSET
QOS attributes: these attributes are used to demarcate RPC call processing by different set of
handlers.
|
static int |
QOS_THRESHOLD |
static String |
RECOVERED_EDITS_DIR |
static String |
RECOVERED_HFILES_DIR |
static String |
REGION_IMPL |
static String |
REGION_SERVER_HANDLER_ABORT_ON_ERROR_PERCENT |
static String |
REGION_SERVER_HANDLER_COUNT |
static String |
REGION_SERVER_HIGH_PRIORITY_HANDLER_COUNT |
static String |
REGION_SERVER_IMPL
Parameter name for what region server implementation to use.
|
static String |
REGION_SERVER_REPLICATION_HANDLER_COUNT |
static String |
REGION_SPLIT_THREADS_MAX
The max number of threads used for splitting storefiles in parallel during the region split
process.
|
static byte[] |
REGIONINFO_QUALIFIER
The regioninfo column qualifier
|
static String |
REGIONINFO_QUALIFIER_STR
The RegionInfo qualifier as a string
|
static String |
REGIONS_RECOVERY_INTERVAL |
static String |
REGIONSERVER_INFO_PORT
A configuration key for regionserver info port
|
static String |
REGIONSERVER_INFO_PORT_AUTO
A flag that enables automatic selection of regionserver info port
|
static String |
REGIONSERVER_METRICS_PERIOD
The period (in milliseconds) between computing region server point in time metrics
|
static String |
REGIONSERVER_PORT
Parameter name for port region server listens on.
|
static int |
REPLAY_QOS |
static byte[] |
REPLICATION_BARRIER_FAMILY
The replication barrier family
|
static String |
REPLICATION_BARRIER_FAMILY_STR
The replication barrier family as a string
|
static boolean |
REPLICATION_BULKLOAD_ENABLE_DEFAULT |
static String |
REPLICATION_BULKLOAD_ENABLE_KEY |
static String |
REPLICATION_CLUSTER_ID
Replication cluster id of source cluster which uniquely identifies itself with peer cluster
|
static String |
REPLICATION_CODEC_CONF_KEY
Configuration key for setting replication codec class name
|
static String |
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
|
static String |
REPLICATION_DROP_ON_DELETED_TABLE_KEY
Deprecated.
moved it into HBaseInterClusterReplicationEndpoint
|
static int |
REPLICATION_QOS |
static int |
REPLICATION_SCOPE_GLOBAL
Scope tag for globally scoped data.
|
static int |
REPLICATION_SCOPE_LOCAL
Scope tag for locally scoped data.
|
static String |
REPLICATION_SERVICE_CLASSNAME_DEFAULT |
static String |
REPLICATION_SINK_SERVICE_CLASSNAME |
static int |
REPLICATION_SOURCE_MAXTHREADS_DEFAULT
Maximum number of threads used by the replication source for shipping edits to the sinks
|
static String |
REPLICATION_SOURCE_MAXTHREADS_KEY
Maximum number of threads used by the replication source for shipping edits to the sinks
|
static String |
REPLICATION_SOURCE_SERVICE_CLASSNAME |
static String |
REPLICATION_SOURCE_SHIPEDITS_TIMEOUT
Configuration key for ReplicationSource shipeEdits timeout
|
static int |
REPLICATION_SOURCE_SHIPEDITS_TIMEOUT_DFAULT |
static int |
REPLICATION_SOURCE_TOTAL_BUFFER_DFAULT |
static String |
REPLICATION_SOURCE_TOTAL_BUFFER_KEY
Max total size of buffered entries in all replication peers.
|
static int[] |
RETRY_BACKOFF
Retrying we multiply hbase.client.pause setting by what we have in this array until we run out
of array items.
|
static String |
RPC_CODEC_CONF_KEY
Configuration key for setting RPC codec class name
|
static byte |
RPC_CURRENT_VERSION |
static byte[] |
RPC_HEADER
The first four bytes of Hadoop RPC connections
|
static byte[] |
SEQNUM_QUALIFIER
The open seqnum column qualifier
|
static String |
SEQNUM_QUALIFIER_STR
The open seqnum column qualifier
|
static byte[] |
SERVER_QUALIFIER
The server column qualifier
|
static String |
SERVER_QUALIFIER_STR
The server column qualifier
|
static byte[] |
SERVERNAME_QUALIFIER |
static String |
SERVERNAME_QUALIFIER_STR
The serverName column qualifier.
|
static String |
SHELL_TIMESTAMP_FORMAT_EPOCH_KEY |
static String |
SLOW_LOG_BUFFER_ENABLED_KEY |
static String |
SLOW_LOG_SYS_TABLE_ENABLED_KEY |
static byte[] |
SLOWLOG_INFO_FAMILY
The slowlog info family
|
private static String |
SLOWLOG_INFO_FAMILY_STR
The slowlog info family as a string
|
static String |
SNAPSHOT_DIR_NAME
Name of the directory to store all snapshots.
|
static String |
SNAPSHOT_RESTORE_FAILSAFE_NAME |
static String |
SNAPSHOT_RESTORE_TAKE_FAILSAFE_SNAPSHOT |
static int |
SOCKET_RETRY_WAIT_MS
The delay when re-trying a socket operation in a loop (HBASE-4712)
|
static String |
SPLIT_LOGDIR_NAME
Used to construct the name of the splitlog directory for a region server
|
static byte[] |
SPLITA_QUALIFIER
The lower-half split region column qualifier
|
static String |
SPLITA_QUALIFIER_STR
The lower-half split region column qualifier string.
|
static byte[] |
SPLITB_QUALIFIER
The upper-half split region column qualifier
|
static String |
SPLITB_QUALIFIER_STR
The upper-half split region column qualifier String.
|
static byte[] |
STARTCODE_QUALIFIER
The startcode column qualifier
|
static String |
STARTCODE_QUALIFIER_STR
The startcode column qualifier
|
static byte[] |
STATE_QUALIFIER |
static String |
STATE_QUALIFIER_STR
The state column qualifier
|
static String |
STATUS_MULTICAST_ADDRESS
IP to use for the multicast status messages between the master and the clients.
|
static String |
STATUS_MULTICAST_BIND_ADDRESS
The address to use for binding the local socket for receiving multicast.
|
static String |
STATUS_MULTICAST_NI_NAME
The network interface name to use for the multicast messages.
|
static String |
STATUS_MULTICAST_PORT
The port to use for the multicast messages.
|
static String |
STATUS_MULTICAST_PUBLISHER_BIND_ADDRESS
The address to use for binding the local socket for sending multicast.
|
static String |
STATUS_PUBLISHED
Setting to activate, or not, the publication of the status by the master.
|
static boolean |
STATUS_PUBLISHED_DEFAULT |
static String |
STORAGE_POLICY_PREFIX
Date Tiered Compaction tmp dir prefix name if use storage policy
|
static String |
STORE_FILE_REF_COUNT_THRESHOLD |
static int |
SYSTEMTABLE_QOS |
static byte[] |
TABLE_FAMILY
The catalog family
|
static String |
TABLE_FAMILY_STR
The catalog family as a string
|
static long |
TABLE_MAX_ROWSIZE_DEFAULT
Default max row size (1 Gb).
|
static String |
TABLE_MAX_ROWSIZE_KEY
Max size of single row for Get's or Scan's without in-row scanning flag set.
|
static byte[] |
TABLE_STATE_QUALIFIER
The serialized table state qualifier
|
static long |
TB_IN_BYTES |
static String |
TEMPORARY_FS_DIRECTORY_KEY
Config key for hbase temporary directory in hdfs
|
static String |
THREAD_WAKE_FREQUENCY
Parameter name for how often threads should wake up
|
static String |
USE_META_REPLICAS
Conf key for enabling meta replication
|
static Charset |
UTF8_CHARSET
When we encode strings, we always specify UTF8 encoding
|
static String |
UTF8_ENCODING
When we encode strings, we always specify UTF8 encoding
|
static String |
VERSION_FILE_NAME
name of version file
|
static String |
VERSION_FILE_WRITE_ATTEMPTS
Parameter name for how often we should try to write a version file, before failing
|
static String |
VERSIONS |
static String |
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
|
static int |
WEEK_IN_SECONDS
Deprecated.
|
static Long |
ZERO_L
long constant for zero
|
static String |
ZEROES |
static String |
ZK_CFG_PROPERTY_PREFIX
Common prefix of ZooKeeper configuration properties
|
static int |
ZK_CFG_PROPERTY_PREFIX_LEN |
static String |
ZK_CLIENT_KERBEROS_PRINCIPAL |
static String |
ZK_CLIENT_KEYTAB_FILE
Configuration keys for programmatic JAAS configuration for secured ZK interaction
|
static String |
ZK_CONNECTION_REGISTRY_CLASS
Full class name of the Zookeeper based connection registry implementation
|
static String |
ZK_SERVER_KERBEROS_PRINCIPAL |
static String |
ZK_SERVER_KEYTAB_FILE |
static String |
ZK_SESSION_TIMEOUT
Configuration key for ZooKeeper session timeout
|
static long |
ZK_SYNC_BLOCKING_TIMEOUT_DEFAULT_MS |
static String |
ZK_SYNC_BLOCKING_TIMEOUT_MS
Timeout for the ZK sync() call
|
static String |
ZOOKEEPER_CLIENT_PORT
Parameter name for the client port that the zookeeper listens on
|
static String |
ZOOKEEPER_DATA_DIR
Parameter name for the ZK data directory
|
static String |
ZOOKEEPER_MAX_CLIENT_CNXNS
Parameter name for the limit on concurrent client-side zookeeper connections
|
static String |
ZOOKEEPER_QUORUM
Name of ZooKeeper quorum configuration parameter.
|
static String |
ZOOKEEPER_RECOVERABLE_WAITTIME
Deprecated.
|
static String |
ZOOKEEPER_TICK_TIME
Parameter name for the ZK tick time
|
static String |
ZOOKEEPER_ZNODE_PARENT
Parameter name for the root dir in ZK for this cluster
|
Modifier | Constructor and Description |
---|---|
private |
HConstants() |
public static final String UTF8_ENCODING
public static final Charset UTF8_CHARSET
public static final int DEFAULT_BLOCKSIZE
public static final int INDEX_KEY_MAGIC
public static final String RECOVERED_EDITS_DIR
public static final String RECOVERED_HFILES_DIR
public static final String STORAGE_POLICY_PREFIX
public static final byte[] RPC_HEADER
public static final byte RPC_CURRENT_VERSION
public static final int HFILEBLOCK_HEADER_SIZE_NO_CHECKSUM
public static final int HFILEBLOCK_HEADER_SIZE
public static final byte[] HFILEBLOCK_DUMMY_HEADER
public static final String NINES
public static final String ZEROES
public static final String VERSION_FILE_NAME
public static final String FILE_SYSTEM_VERSION
public static final String CLUSTER_DISTRIBUTED
public static final String HBASE_MASTER_LOADBALANCER_CLASS
public static final String HBASE_MASTER_LOADBALANCE_BYTABLE
public static final String HBASE_MASTER_BALANCER_MAX_RIT_PERCENT
public static final double DEFAULT_HBASE_MASTER_BALANCER_MAX_RIT_PERCENT
public static final String HBASE_BALANCER_MAX_BALANCING
public static final String HBASE_BALANCER_PERIOD
public static final int DEFAULT_HBASE_BALANCER_PERIOD
public static final String HBASE_ENABLE_SEPARATE_CHILD_REGIONS
public static final boolean DEFAULT_HBASE_ENABLE_SEPARATE_CHILD_REGIONS
public static final TableName ENSEMBLE_TABLE_NAME
public static final String HBASE_MASTER_NORMALIZER_CLASS
public static final boolean CLUSTER_IS_LOCAL
@Deprecated public static final boolean CLUSTER_IS_DISTRIBUTED
public static final boolean DEFAULT_CLUSTER_DISTRIBUTED
public static final String DEFAULT_HOST
public static final String MASTER_PORT
public static final int DEFAULT_MASTER_PORT
public static final int DEFAULT_MASTER_INFOPORT
public static final String MASTER_INFO_PORT
public static final String MASTER_ADDRS_KEY
public static final String ZK_CONNECTION_REGISTRY_CLASS
public static final String MASTER_TYPE_BACKUP
public static final boolean DEFAULT_MASTER_TYPE_BACKUP
public static final String ZOOKEEPER_QUORUM
public static final String CLIENT_ZOOKEEPER_QUORUM
public static final String CLIENT_ZOOKEEPER_CLIENT_PORT
public static final String CLIENT_ZOOKEEPER_OBSERVER_MODE
public static final boolean DEFAULT_CLIENT_ZOOKEEPER_OBSERVER_MODE
public static final String ZK_CFG_PROPERTY_PREFIX
public static final int ZK_CFG_PROPERTY_PREFIX_LEN
public static final String CLIENT_PORT_STR
public static final String ZOOKEEPER_CLIENT_PORT
@Deprecated public static final int DEFAULT_ZOOKEPER_CLIENT_PORT
DEFAULT_ZOOKEEPER_CLIENT_PORT
insteadpublic static final int DEFAULT_ZOOKEEPER_CLIENT_PORT
@Deprecated public static final String ZOOKEEPER_RECOVERABLE_WAITTIME
@Deprecated public static final long DEFAULT_ZOOKEPER_RECOVERABLE_WAITIME
public static final String ZOOKEEPER_ZNODE_PARENT
public static final String DEFAULT_ZOOKEEPER_ZNODE_PARENT
public static final String ZOOKEEPER_MAX_CLIENT_CNXNS
public static final String ZOOKEEPER_DATA_DIR
public static final String ZOOKEEPER_TICK_TIME
@Deprecated public static final int DEFAULT_ZOOKEPER_MAX_CLIENT_CNXNS
DEFAULT_ZOOKEEPER_MAX_CLIENT_CNXNS
insteadpublic static final int DEFAULT_ZOOKEEPER_MAX_CLIENT_CNXNS
public static final String ZK_SESSION_TIMEOUT
public static final String ZK_SYNC_BLOCKING_TIMEOUT_MS
public static final long ZK_SYNC_BLOCKING_TIMEOUT_DEFAULT_MS
public static final int DEFAULT_ZK_SESSION_TIMEOUT
public static final String REGIONSERVER_PORT
public static final int DEFAULT_REGIONSERVER_PORT
public static final int DEFAULT_REGIONSERVER_INFOPORT
public static final String REGIONSERVER_INFO_PORT
public static final String REGIONSERVER_INFO_PORT_AUTO
public static final String REGION_SERVER_IMPL
public static final String MASTER_IMPL
@Deprecated public static final String HBASECLIENT_IMPL
public static final String THREAD_WAKE_FREQUENCY
public static final int DEFAULT_THREAD_WAKE_FREQUENCY
public static final String VERSION_FILE_WRITE_ATTEMPTS
public static final int DEFAULT_VERSION_FILE_WRITE_ATTEMPTS
public static final String MAJOR_COMPACTION_PERIOD
public static final long DEFAULT_MAJOR_COMPACTION_PERIOD
public static final String MAJOR_COMPACTION_JITTER
MAJOR_COMPACTION_PERIOD
to cause compaction to occur a given amount of time
either side of MAJOR_COMPACTION_PERIOD
. Default to 0.5 so jitter has us fall
evenly either side of when the compaction should run.public static final float DEFAULT_MAJOR_COMPACTION_JITTER
public static final String COMPACTION_KV_MAX
public static final int COMPACTION_KV_MAX_DEFAULT
public static final String HBASE_DIR
public static final String HBASE_CLIENT_IPC_POOL_TYPE
public static final String HBASE_CLIENT_IPC_POOL_SIZE
public static final String HBASE_CLIENT_OPERATION_TIMEOUT
public static final String HBASE_CLIENT_META_OPERATION_TIMEOUT
public static final int DEFAULT_HBASE_CLIENT_OPERATION_TIMEOUT
public static final String HBASE_CLIENT_META_REPLICA_SCAN_TIMEOUT
public static final int HBASE_CLIENT_META_REPLICA_SCAN_TIMEOUT_DEFAULT
public static final String HREGION_LOGDIR_NAME
public static final String SPLIT_LOGDIR_NAME
public static final String HREGION_OLDLOGDIR_NAME
public static final String BULKLOAD_STAGING_DIR_NAME
public static final String CORRUPT_DIR_NAME
public static final String HBCK_SIDELINEDIR_NAME
public static final String MIGRATION_NAME
@Deprecated public static final String LIB_DIR
public static final String HREGION_COMPACTIONDIR_NAME
public static final String HREGION_MAX_FILESIZE
public static final long DEFAULT_MAX_FILE_SIZE
public static final String OVERALL_HREGION_FILES
public static final boolean DEFAULT_OVERALL_HREGION_FILES
public static final String TABLE_MAX_ROWSIZE_KEY
public static final long TABLE_MAX_ROWSIZE_DEFAULT
public static final String HSTORE_OPEN_AND_CLOSE_THREADS_MAX
public static final int DEFAULT_HSTORE_OPEN_AND_CLOSE_THREADS_MAX
public static final String HREGION_MEMSTORE_BLOCK_MULTIPLIER
public static final int DEFAULT_HREGION_MEMSTORE_BLOCK_MULTIPLIER
public static final String HREGION_MEMSTORE_FLUSH_SIZE
public static final String HREGION_EDITS_REPLAY_SKIP_ERRORS
public static final boolean DEFAULT_HREGION_EDITS_REPLAY_SKIP_ERRORS
public static final int MAXIMUM_VALUE_LENGTH
public static final String CLUSTER_ID_FILE_NAME
public static final String CLUSTER_ID_DEFAULT
public static final String KEEP_SEQID_PERIOD
public static final int MIN_KEEP_SEQID_PERIOD
public static final String BASE_NAMESPACE_DIR
public static final int META_ROW_DELIMITER
public static final String CATALOG_FAMILY_STR
public static final byte[] CATALOG_FAMILY
public static final String REGIONINFO_QUALIFIER_STR
public static final byte[] REGIONINFO_QUALIFIER
public static final String SERVER_QUALIFIER_STR
public static final byte[] SERVER_QUALIFIER
public static final String STARTCODE_QUALIFIER_STR
public static final byte[] STARTCODE_QUALIFIER
public static final String SEQNUM_QUALIFIER_STR
public static final byte[] SEQNUM_QUALIFIER
public static final String STATE_QUALIFIER_STR
public static final byte[] STATE_QUALIFIER
public static final String SERVERNAME_QUALIFIER_STR
public static final byte[] SERVERNAME_QUALIFIER
public static final String SPLITA_QUALIFIER_STR
public static final byte[] SPLITA_QUALIFIER
public static final String SPLITB_QUALIFIER_STR
public static final byte[] SPLITB_QUALIFIER
public static final String MERGE_QUALIFIER_PREFIX_STR
public static final byte[] MERGE_QUALIFIER_PREFIX
@Deprecated public static final byte[] MERGEA_QUALIFIER
MERGE_QUALIFIER_PREFIX_STR
prefix.@Deprecated public static final byte[] MERGEB_QUALIFIER
MERGE_QUALIFIER_PREFIX_STR
prefix.public static final String TABLE_FAMILY_STR
public static final byte[] TABLE_FAMILY
public static final byte[] TABLE_STATE_QUALIFIER
public static final String REPLICATION_BARRIER_FAMILY_STR
public static final byte[] REPLICATION_BARRIER_FAMILY
public static final byte[] META_VERSION_QUALIFIER
-ROOT-
table: i.e. in the 'info:v' column.public static final String FAMILY_KEY_STR
public static final short META_VERSION
public static final byte[] EMPTY_BYTE_ARRAY
public static final String EMPTY_STRING
public static final ByteBuffer EMPTY_BYTE_BUFFER
public static final byte[] EMPTY_START_ROW
public static final byte[] EMPTY_END_ROW
public static final byte[] LAST_ROW
public static final int MAX_ROW_LENGTH
public static final long LATEST_TIMESTAMP
@Deprecated public static final long OLDEST_TIMESTAMP
public static final byte[] LATEST_TIMESTAMP_BYTES
public static final int ALL_VERSIONS
public static final int FOREVER
@Deprecated public static final int WEEK_IN_SECONDS
public static final int DAY_IN_SECONDS
public static final int HOUR_IN_SECONDS
public static final int MINUTE_IN_SECONDS
public static final long KB_IN_BYTES
public static final long MB_IN_BYTES
public static final long GB_IN_BYTES
public static final long TB_IN_BYTES
public static final String NAME
public static final String VERSIONS
public static final String IN_MEMORY
public static final String METADATA
public static final String CONFIGURATION
public static final int[] RETRY_BACKOFF
public static final String REGION_IMPL
public static final int REPLICATION_SCOPE_LOCAL
public static final int REPLICATION_SCOPE_GLOBAL
public static final UUID DEFAULT_CLUSTER_ID
public static final String HBASE_CLIENT_SCANNER_MAX_RESULT_SIZE_KEY
public static final String HBASE_SERVER_SCANNER_MAX_RESULT_SIZE_KEY
public static final long DEFAULT_HBASE_CLIENT_SCANNER_MAX_RESULT_SIZE
public static final long DEFAULT_HBASE_SERVER_SCANNER_MAX_RESULT_SIZE
public static final String HBASE_CLIENT_PAUSE
public static final long DEFAULT_HBASE_CLIENT_PAUSE
HBASE_CLIENT_PAUSE
.@Deprecated public static final String HBASE_CLIENT_PAUSE_FOR_CQTBE
public static final String HBASE_CLIENT_MAX_TOTAL_TASKS
public static final int DEFAULT_HBASE_CLIENT_MAX_TOTAL_TASKS
HBASE_CLIENT_MAX_TOTAL_TASKS
.public static final String HBASE_CLIENT_MAX_PERSERVER_TASKS
public static final int DEFAULT_HBASE_CLIENT_MAX_PERSERVER_TASKS
HBASE_CLIENT_MAX_PERSERVER_TASKS
.public static final String HBASE_CLIENT_MAX_PERREGION_TASKS
public static final int DEFAULT_HBASE_CLIENT_MAX_PERREGION_TASKS
HBASE_CLIENT_MAX_PERREGION_TASKS
.public static final String HBASE_CLIENT_PERSERVER_REQUESTS_THRESHOLD
public static final int DEFAULT_HBASE_CLIENT_PERSERVER_REQUESTS_THRESHOLD
HBASE_CLIENT_PERSERVER_REQUESTS_THRESHOLD
.public static final String HBASE_SERVER_PAUSE
public static final int DEFAULT_HBASE_SERVER_PAUSE
HBASE_SERVER_PAUSE
.public static final String HBASE_CLIENT_RETRIES_NUMBER
public static final int DEFAULT_HBASE_CLIENT_RETRIES_NUMBER
HBASE_CLIENT_RETRIES_NUMBER
.public static final String HBASE_CLIENT_SERVERSIDE_RETRIES_MULTIPLIER
public static final int DEFAULT_HBASE_CLIENT_SERVERSIDE_RETRIES_MULTIPLIER
public static final String HBASE_CLIENT_SCANNER_CACHING
public static final int DEFAULT_HBASE_CLIENT_SCANNER_CACHING
HBASE_CLIENT_SCANNER_CACHING
public static final String HBASE_META_SCANNER_CACHING
public static final int DEFAULT_HBASE_META_SCANNER_CACHING
HBASE_META_SCANNER_CACHING
.public static final String HBASE_META_VERSIONS
public static final int DEFAULT_HBASE_META_VERSIONS
HBASE_META_VERSIONS
.public static final String HBASE_META_BLOCK_SIZE
public static final int DEFAULT_HBASE_META_BLOCK_SIZE
HBASE_META_BLOCK_SIZE
.public static final String HBASE_CLIENT_INSTANCE_ID
Configuration
instance. If there are two or more Configuration
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.public static final String HBASE_CLIENT_SCANNER_TIMEOUT_PERIOD
@Deprecated public static final String HBASE_REGIONSERVER_LEASE_PERIOD_KEY
HBASE_CLIENT_SCANNER_TIMEOUT_PERIOD
instead.public static final int DEFAULT_HBASE_CLIENT_SCANNER_TIMEOUT_PERIOD
HBASE_CLIENT_SCANNER_TIMEOUT_PERIOD
.public static final String HBASE_RPC_TIMEOUT_KEY
public static final String HBASE_RPC_READ_TIMEOUT_KEY
public static final String HBASE_RPC_WRITE_TIMEOUT_KEY
public static final int DEFAULT_HBASE_RPC_TIMEOUT
HBASE_RPC_TIMEOUT_KEY
public static final String HBASE_RPC_SHORTOPERATION_TIMEOUT_KEY
public static final int DEFAULT_HBASE_RPC_SHORTOPERATION_TIMEOUT
HBASE_RPC_SHORTOPERATION_TIMEOUT_KEY
public static final String HBASE_RPC_SHORTOPERATION_RETRY_PAUSE_TIME
public static final long DEFAULT_HBASE_RPC_SHORTOPERATION_RETRY_PAUSE_TIME
HBASE_RPC_SHORTOPERATION_RETRY_PAUSE_TIME
public static final long NO_SEQNUM
public static final String CLIENT_CONNECTION_REGISTRY_IMPL_CONF_KEY
public static final String REPLICATION_SOURCE_SERVICE_CLASSNAME
public static final String REPLICATION_SINK_SERVICE_CLASSNAME
public static final String REPLICATION_SERVICE_CLASSNAME_DEFAULT
public static final String REPLICATION_BULKLOAD_ENABLE_KEY
public static final boolean REPLICATION_BULKLOAD_ENABLE_DEFAULT
public static final String REPLICATION_CLUSTER_ID
public static final String REPLICATION_SOURCE_TOTAL_BUFFER_KEY
public static final int REPLICATION_SOURCE_TOTAL_BUFFER_DFAULT
public static final String REPLICATION_SOURCE_SHIPEDITS_TIMEOUT
public static final int REPLICATION_SOURCE_SHIPEDITS_TIMEOUT_DFAULT
public static final String REPLICATION_CONF_DIR
public static final String BULKLOAD_MAX_RETRIES_NUMBER
@Deprecated public static final String HBCK_CODE_NAME
public static final String KEY_FOR_HOSTNAME_SEEN_BY_MASTER
public static final String HBASE_MASTER_LOGCLEANER_PLUGINS
public static final String HBASE_REGION_SPLIT_POLICY_KEY
public static final String HBASE_RS_NONCES_ENABLED
public static final String HFILE_BLOCK_CACHE_SIZE_KEY
public static final float HFILE_BLOCK_CACHE_SIZE_DEFAULT
public static final String HFILE_ONHEAP_BLOCK_CACHE_FIXED_SIZE_KEY
public static final long HFILE_ONHEAP_BLOCK_CACHE_FIXED_SIZE_DEFAULT
public static final long HBASE_CLIENT_SCANNER_ONHEAP_BLOCK_CACHE_FIXED_SIZE_DEFAULT
public static final String HFILE_PREAD_ALL_BYTES_ENABLED_KEY
public static final boolean HFILE_PREAD_ALL_BYTES_ENABLED_DEFAULT
public static final float HBASE_CLUSTER_MINIMUM_MEMORY_THRESHOLD
@Deprecated public static final Pattern CP_HTD_ATTR_KEY_PATTERN
@Deprecated public static final Pattern CP_HTD_ATTR_VALUE_PATTERN
Pattern that matches a coprocessor specification. Form is:<coprocessor jar file location> '|' <class name> ['|' <priority> ['|' <arguments>]]
where arguments are<KEY> '=' <VALUE> [,...]
For example:hdfs:///foo.jar|com.foo.FooRegionObserver|1001|arg1=1,arg2=2
@Deprecated public static final String CP_HTD_ATTR_VALUE_PARAM_KEY_PATTERN
@Deprecated public static final String CP_HTD_ATTR_VALUE_PARAM_VALUE_PATTERN
@Deprecated public static final Pattern CP_HTD_ATTR_VALUE_PARAM_PATTERN
public static final String CP_HTD_ATTR_INCLUSION_KEY
public static final int SOCKET_RETRY_WAIT_MS
public static final String LOCALHOST
public static final String HBASE_CHECKSUM_VERIFICATION
public static final String LOCALHOST_IP
public static final String REGION_SERVER_HANDLER_COUNT
public static final int DEFAULT_REGION_SERVER_HANDLER_COUNT
public static final String REGION_SERVER_HANDLER_ABORT_ON_ERROR_PERCENT
public static final double DEFAULT_REGION_SERVER_HANDLER_ABORT_ON_ERROR_PERCENT
public static final String REGION_SERVER_HIGH_PRIORITY_HANDLER_COUNT
public static final int DEFAULT_REGION_SERVER_HIGH_PRIORITY_HANDLER_COUNT
public static final String REGION_SERVER_REPLICATION_HANDLER_COUNT
public static final int DEFAULT_REGION_SERVER_REPLICATION_HANDLER_COUNT
public static final String MASTER_META_TRANSITION_HANDLER_COUNT
public static final int MASTER__META_TRANSITION_HANDLER_COUNT_DEFAULT
@Deprecated public static final String MASTER_HANDLER_COUNT
@Deprecated public static final int DEFAULT_MASTER_HANLDER_COUNT
@Deprecated public static final String LOG_REPLAY_WAIT_REGION_TIMEOUT
public static final String USE_META_REPLICAS
public static final boolean DEFAULT_USE_META_REPLICAS
@Deprecated public static final String META_REPLICAS_NUM
@Deprecated public static final int DEFAULT_META_REPLICA_NUM
public static final String BYTES_PER_CHECKSUM
public static final String CHECKSUM_TYPE_NAME
public static final String ENABLE_DATA_FILE_UMASK
public static final String DATA_FILE_UMASK_KEY
public static final String ENABLE_WAL_COMPRESSION
public static final String WAL_STORAGE_POLICY
public static final String DEFER_TO_HDFS_STORAGE_POLICY
public static final String DEFAULT_WAL_STORAGE_POLICY
public static final String METRICS_RIT_STUCK_WARNING_THRESHOLD
public static final String LOAD_BALANCER_SLOP_KEY
public static final int DELIMITER
public static final int PRIORITY_UNSET
public static final int NORMAL_QOS
public static final int REPLICATION_QOS
public static final int REPLAY_QOS
public static final int QOS_THRESHOLD
public static final int ADMIN_QOS
public static final int HIGH_QOS
public static final int SYSTEMTABLE_QOS
@Deprecated public static final int META_QOS
public static final String HFILE_ARCHIVE_DIRECTORY
public static final String SNAPSHOT_DIR_NAME
public static final String OLD_SNAPSHOT_DIR_NAME
public static final String HBASE_TEMP_DIRECTORY
public static final String REGIONSERVER_METRICS_PERIOD
public static final long DEFAULT_REGIONSERVER_METRICS_PERIOD
public static final List<String> HBASE_NON_TABLE_DIRS
@Deprecated public static final List<String> HBASE_NON_USER_TABLE_DIRS
public static final String HEALTH_SCRIPT_LOC
public static final String HEALTH_SCRIPT_TIMEOUT
public static final String HEALTH_CHORE_WAKE_FREQ
public static final long DEFAULT_HEALTH_SCRIPT_TIMEOUT
public static final String HEALTH_FAILURE_THRESHOLD
public static final int DEFAULT_HEALTH_FAILURE_THRESHOLD
public static final String STATUS_PUBLISHED
public static final boolean STATUS_PUBLISHED_DEFAULT
public static final String STATUS_MULTICAST_ADDRESS
public static final String DEFAULT_STATUS_MULTICAST_ADDRESS
public static final String STATUS_MULTICAST_BIND_ADDRESS
public static final String DEFAULT_STATUS_MULTICAST_BIND_ADDRESS
public static final String STATUS_MULTICAST_PORT
public static final int DEFAULT_STATUS_MULTICAST_PORT
public static final String STATUS_MULTICAST_NI_NAME
public static final String STATUS_MULTICAST_PUBLISHER_BIND_ADDRESS
public static final String DEFAULT_STATUS_MULTICAST_PUBLISHER_BIND_ADDRESS
public static final long NO_NONCE
public static final String CIPHER_AES
public static final String CRYPTO_CIPHERPROVIDER_CONF_KEY
public static final String CRYPTO_KEYPROVIDER_CONF_KEY
public static final String CRYPTO_KEYPROVIDER_PARAMETERS_KEY
public static final String CRYPTO_MASTERKEY_NAME_CONF_KEY
public static final String CRYPTO_MASTERKEY_ALTERNATE_NAME_CONF_KEY
public static final String CRYPTO_WAL_ALGORITHM_CONF_KEY
public static final String CRYPTO_WAL_KEY_NAME_CONF_KEY
public static final String CRYPTO_KEY_ALGORITHM_CONF_KEY
public static final String CRYPTO_ALTERNATE_KEY_ALGORITHM_CONF_KEY
public static final String ENABLE_WAL_ENCRYPTION
public static final String RPC_CODEC_CONF_KEY
public static final String REPLICATION_CODEC_CONF_KEY
public static final String REPLICATION_SOURCE_MAXTHREADS_KEY
@Deprecated public static final String REPLICATION_DROP_ON_DELETED_TABLE_KEY
public static final int REPLICATION_SOURCE_MAXTHREADS_DEFAULT
public static final String HBASE_SPLITLOG_MANAGER_TIMEOUT
public static final String BUCKET_CACHE_IOENGINE_KEY
Set this option and a non-zero BUCKET_CACHE_SIZE_KEY
to enable bucket cache.
public static final String BUCKET_CACHE_SIZE_KEY
@Deprecated public static final String HBASE_CLIENT_FAST_FAIL_MODE_ENABLED
@Deprecated public static final boolean HBASE_CLIENT_ENABLE_FAST_FAIL_MODE_DEFAULT
@Deprecated public static final String HBASE_CLIENT_FAST_FAIL_THREASHOLD_MS
@Deprecated public static final long HBASE_CLIENT_FAST_FAIL_THREASHOLD_MS_DEFAULT
@Deprecated public static final String HBASE_CLIENT_FAILURE_MAP_CLEANUP_INTERVAL_MS
@Deprecated public static final long HBASE_CLIENT_FAILURE_MAP_CLEANUP_INTERVAL_MS_DEFAULT
@Deprecated public static final String HBASE_CLIENT_FAST_FAIL_CLEANUP_MS_DURATION_MS
@Deprecated public static final long HBASE_CLIENT_FAST_FAIL_CLEANUP_DURATION_MS_DEFAULT
@Deprecated public static final String HBASE_CLIENT_FAST_FAIL_INTERCEPTOR_IMPL
@Deprecated public static final String HBASE_SPLIT_WAL_COORDINATED_BY_ZK
@Deprecated public static final boolean DEFAULT_HBASE_SPLIT_COORDINATED_BY_ZK
public static final String HBASE_SPLIT_WAL_MAX_SPLITTER
public static final int DEFAULT_HBASE_SPLIT_WAL_MAX_SPLITTER
public static final String ENABLE_CLIENT_BACKPRESSURE
public static final boolean DEFAULT_ENABLE_CLIENT_BACKPRESSURE
public static final String HEAP_OCCUPANCY_LOW_WATERMARK_KEY
public static final float DEFAULT_HEAP_OCCUPANCY_LOW_WATERMARK
public static final String HEAP_OCCUPANCY_HIGH_WATERMARK_KEY
public static final float DEFAULT_HEAP_OCCUPANCY_HIGH_WATERMARK
public static final String REGION_SPLIT_THREADS_MAX
public static final String HBASE_CANARY_WRITE_DATA_TTL_KEY
public static final String HBASE_CANARY_WRITE_PERSERVER_REGIONS_LOWERLIMIT_KEY
public static final String HBASE_CANARY_WRITE_PERSERVER_REGIONS_UPPERLIMIT_KEY
public static final String HBASE_CANARY_WRITE_VALUE_SIZE_KEY
public static final String HBASE_CANARY_WRITE_TABLE_CHECK_PERIOD_KEY
public static final String HBASE_CANARY_READ_RAW_SCAN_KEY
public static final String HBASE_CANARY_READ_ALL_CF
public static final String ZK_CLIENT_KEYTAB_FILE
public static final String ZK_CLIENT_KERBEROS_PRINCIPAL
public static final String ZK_SERVER_KEYTAB_FILE
public static final String ZK_SERVER_KERBEROS_PRINCIPAL
public static final String TEMPORARY_FS_DIRECTORY_KEY
public static final String DEFAULT_TEMPORARY_HDFS_DIRECTORY
public static final String SNAPSHOT_RESTORE_TAKE_FAILSAFE_SNAPSHOT
public static final boolean DEFAULT_SNAPSHOT_RESTORE_TAKE_FAILSAFE_SNAPSHOT
public static final String SNAPSHOT_RESTORE_FAILSAFE_NAME
public static final String DEFAULT_SNAPSHOT_RESTORE_FAILSAFE_NAME
public static final String DEFAULT_LOSSY_COUNTING_ERROR_RATE
public static final String NOT_IMPLEMENTED
public static final long DEFAULT_SNAPSHOT_TTL
public static final String DEFAULT_SNAPSHOT_TTL_CONFIG_KEY
public static final String STORE_FILE_REF_COUNT_THRESHOLD
public static final int DEFAULT_STORE_FILE_REF_COUNT_THRESHOLD
public static final String REGIONS_RECOVERY_INTERVAL
public static final int DEFAULT_REGIONS_RECOVERY_INTERVAL
public static final String MASTER_OPEN_REGION_THREADS
public static final int MASTER_OPEN_REGION_THREADS_DEFAULT
public static final String MASTER_CLOSE_REGION_THREADS
public static final int MASTER_CLOSE_REGION_THREADS_DEFAULT
public static final String MASTER_SERVER_OPERATIONS_THREADS
public static final int MASTER_SERVER_OPERATIONS_THREADS_DEFAULT
public static final String MASTER_MERGE_DISPATCH_THREADS
public static final int MASTER_MERGE_DISPATCH_THREADS_DEFAULT
public static final String MASTER_META_SERVER_OPERATIONS_THREADS
public static final int MASTER_META_SERVER_OPERATIONS_THREADS_DEFAULT
public static final String MASTER_LOG_REPLAY_OPS_THREADS
public static final int MASTER_LOG_REPLAY_OPS_THREADS_DEFAULT
public static final int DEFAULT_SLOW_LOG_RING_BUFFER_SIZE
public static final String SLOW_LOG_BUFFER_ENABLED_KEY
public static final boolean DEFAULT_ONLINE_LOG_PROVIDER_ENABLED
private static final String SLOWLOG_INFO_FAMILY_STR
public static final byte[] SLOWLOG_INFO_FAMILY
public static final String SLOW_LOG_SYS_TABLE_ENABLED_KEY
public static final boolean DEFAULT_SLOW_LOG_SYS_TABLE_ENABLED_KEY
public static final String SHELL_TIMESTAMP_FORMAT_EPOCH_KEY
public static final boolean DEFAULT_SHELL_TIMESTAMP_FORMAT_EPOCH
public static final String BATCH_ROWS_THRESHOLD_NAME
public static final int BATCH_ROWS_THRESHOLD_DEFAULT
BATCH_ROWS_THRESHOLD_NAME
private HConstants()
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.