org.apache.hadoop.hbase
Class HConstants

java.lang.Object
  extended by org.apache.hadoop.hbase.HConstants

@InterfaceAudience.Public
@InterfaceStability.Stable
public final class HConstants
extends Object

HConstants holds a bunch of HBase-related constants


Nested Class Summary
static class HConstants.Modify
          modifyTable op for replacing the table descriptor
static class HConstants.OperationStatusCode
          Status codes used for return values of bulk operations.
 
Field Summary
static int ALL_VERSIONS
          Define for 'return-all-versions'.
static String BASE_NAMESPACE_DIR
           
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_PORT_STR
          The ZK client port key in the ZK properties map.
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
          Cluster is fully-distributed
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 Pattern CP_HTD_ATTR_KEY_PATTERN
           
static String CP_HTD_ATTR_VALUE_PARAM_KEY_PATTERN
           
static Pattern CP_HTD_ATTR_VALUE_PARAM_PATTERN
           
static String CP_HTD_ATTR_VALUE_PARAM_VALUE_PATTERN
           
static Pattern CP_HTD_ATTR_VALUE_PATTERN
           
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_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_DISALLOW_WRITES_IN_RECOVERING_CONFIG
           
static boolean DEFAULT_DISTRIBUTED_LOG_REPLAY_CONFIG
           
static boolean DEFAULT_ENABLE_CLIENT_BACKPRESSURE
           
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 boolean DEFAULT_HBASE_CLIENT_PREFETCH
          Default value of HBASE_CLIENT_PREFETCH.
static int DEFAULT_HBASE_CLIENT_PREFETCH_LIMIT
          Default value of HBASE_CLIENT_PREFETCH_LIMIT.
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 boolean DEFAULT_HBASE_CONFIG_READ_ZOOKEEPER_CONFIG
           
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 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 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_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 int DEFAULT_MASTER_HANLDER_COUNT
           
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 float DEFAULT_REGION_SERVER_HANDLER_ABORT_ON_ERROR_PERCENT
           
static int DEFAULT_REGION_SERVER_HANDLER_COUNT
           
static int DEFAULT_REGION_SERVER_META_HANDLER_COUNT
           
static int DEFAULT_REGION_SERVER_REPLICATION_HANDLER_COUNT
           
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 String DEFAULT_STATUS_MULTICAST_ADDRESS
           
static String DEFAULT_STATUS_MULTICAST_BIND_ADDRESS
           
static int DEFAULT_STATUS_MULTICAST_PORT
           
static int DEFAULT_THREAD_WAKE_FREQUENCY
          Default value for thread wake frequency
static int DEFAULT_VERSION_FILE_WRITE_ATTEMPTS
          Parameter name for how often we should try to write a version file, before failing
static int DEFAULT_ZK_SESSION_TIMEOUT
          Default value for ZooKeeper session timeout
static String DEFAULT_ZOOKEEPER_ZNODE_PARENT
           
static int DEFAULT_ZOOKEPER_CLIENT_PORT
          Default client port that the zookeeper listens on
static int DEFAULT_ZOOKEPER_MAX_CLIENT_CNXNS
          Default limit on concurrent client-side zookeeper connections
static long DEFAULT_ZOOKEPER_RECOVERABLE_WAITIME
          Default wait time for the recoverable zookeeper
static int DELIMITER
          delimiter used between portions of a region name
static String DISALLOW_WRITES_IN_RECOVERING
           
static String DISTRIBUTED_LOG_REPLAY_KEY
          Conf key that enables unflushed WAL edits directly being replayed to region servers
static byte[] EMPTY_BYTE_ARRAY
          An empty instance.
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 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 HLog Compression
static String ENABLE_WAL_ENCRYPTION
          Configuration key for enabling WAL encryption, a boolean
static String FILE_SYSTEM_VERSION
          Current version of file system.
static int FOREVER
          Unlimited time-to-live.
static String HBASE_CHECKSUM_VERIFICATION
          If this parameter is set to true, then hbase will read data and then verify checksums.
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 operation timeout, which overrides RPC timeout
static String HBASE_CLIENT_OPERATION_TIMEOUT
          Parameter name for HBase client operation timeout, which overrides RPC 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_PREFETCH
          Parameter name for client region location prefetch toggle.
static String HBASE_CLIENT_PREFETCH_LIMIT
          Parameter name for client prefetch limit, used as the maximum number of regions info that will be prefetched.
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 String HBASE_CLIENT_SCANNER_TIMEOUT_PERIOD
          The client scanner timeout period in milliseconds.
static float HBASE_CLUSTER_MINIMUM_MEMORY_THRESHOLD
           
static String HBASE_CONFIG_READ_ZOOKEEPER_CONFIG
           
static String HBASE_DIR
          Parameter name for HBase instance root directory
static String HBASE_MASTER_LOADBALANCER_CLASS
          Config for pluggable load balancers
static String HBASE_MASTER_LOGCLEANER_PLUGINS
           
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
          Directories that are not HBase user table directories
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_SHORTOPERATION_TIMEOUT_KEY
          timeout for short operation RPC
static String HBASE_RPC_TIMEOUT_KEY
          timeout for each 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_TEMP_DIRECTORY
          Temporary directory used for table creation and deletion
static String HBASECLIENT_IMPL
          Parameter name for what hbase client implementation to use.
static String HBCK_CODE_NAME
          HBCK special code name used as server name when manipulating ZK nodes
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 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_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 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
          The directory from which co-processor/custom filter jars can be loaded dynamically by the region servers.
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
          Conf key that specifies timeout value to wait for a region ready
static String MAJOR_COMPACTION_PERIOD
          Parameter name for how often a region should should perform a major compaction
static String MASTER_HANDLER_COUNT
           
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_PORT
          Parameter name for port master listens on.
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 byte[] MERGEA_QUALIFIER
          The lower-half merge region column qualifier
static byte[] MERGEB_QUALIFIER
          The upper-half merge region column qualifier
static int META_ROW_DELIMITER
          delimiter used between portions of a region name
static byte[] META_TABLE_NAME
          Deprecated. 
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 MINUTE_IN_SECONDS
           
static String NAME
           
static String NINES
           
static byte[] NO_NEXT_INDEXED_KEY
          The byte array represents for NO_NEXT_INDEXED_KEY; The actual value is irrelevant because this is always compared by reference.
static long NO_NONCE
           
static long NO_SEQNUM
          Value indicating the server name was saved with no sequence number.
static int NORMAL_QOS
          QOS attributes: these attributes are used to demarcate RPC call processing by different set of handlers.
static String OLD_SNAPSHOT_DIR_NAME
           
static long OLDEST_TIMESTAMP
          Timestamp to use when we want to refer to the oldest cell.
static int QOS_THRESHOLD
           
static String RECOVERED_EDITS_DIR
           
static String REGION_IMPL
           
static String REGION_SERVER_HANDLER_ABORT_ON_ERROR_PERCENT
           
static String REGION_SERVER_HANDLER_COUNT
           
static String REGION_SERVER_IMPL
          Parameter name for what region server implementation to use.
static String REGION_SERVER_META_HANDLER_COUNT
           
static String REGION_SERVER_REPLICATION_HANDLER_COUNT
           
static byte[] REGIONINFO_QUALIFIER
          The regioninfo column qualifier
static String REGIONINFO_QUALIFIER_STR
          The RegionInfo qualifier as a string
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 String REPLICATION_CODEC_CONF_KEY
          Configuration key for setting replication codec class name
static boolean REPLICATION_ENABLE_DEFAULT
           
static String REPLICATION_ENABLE_KEY
           
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 String REPLICATION_SOURCE_SERVICE_CLASSNAME
           
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 ByteBuffer RPC_HEADER
          The first four bytes of Hadoop RPC connections
static byte[] SEQNUM_QUALIFIER
          The open seqnum column qualifier
static byte[] SERVER_QUALIFIER
          The server column qualifier
static byte[] SERVERNAME_QUALIFIER
          The serverName column qualifier.
static String SNAPSHOT_DIR_NAME
          Name of the directory to store all snapshots.
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 byte[] SPLITB_QUALIFIER
          The upper-half split region column qualifier
static byte[] STARTCODE_QUALIFIER
          The startcode column qualifier
static byte[] STATE_QUALIFIER
          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_PORT
          The port to use for the multicast messages.
static String STATUS_PUBLISHED
          Setting to activate, or not, the publication of the status by the master.
static boolean STATUS_PUBLISHED_DEFAULT
           
static String THREAD_WAKE_FREQUENCY
          Parameter name for how often threads should wake up
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 int WEEK_IN_SECONDS
          Seconds in a week
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_SESSION_TIMEOUT
          Configuration key for ZooKeeper session timeout
static String ZOOKEEPER_CLIENT_PORT
          Parameter name for the client port that the zookeeper listens on
static String ZOOKEEPER_CONFIG_NAME
          Name of ZooKeeper config file in conf/ directory.
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
          Parameter name for the wait time for the recoverable zookeeper
static String ZOOKEEPER_TICK_TIME
          Parameter name for the ZK tick time
static String ZOOKEEPER_USEMULTI
          Configuration key for whether to use ZK.multi
static String ZOOKEEPER_ZNODE_PARENT
          Parameter name for the root dir in ZK for this cluster
 
Method Summary
 
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
 

Field Detail

UTF8_ENCODING

public static final String UTF8_ENCODING
When we encode strings, we always specify UTF8 encoding

See Also:
Constant Field Values

UTF8_CHARSET

public static final Charset UTF8_CHARSET
When we encode strings, we always specify UTF8 encoding


DEFAULT_BLOCKSIZE

public static final int DEFAULT_BLOCKSIZE
Default block size for an HFile.

See Also:
Constant Field Values

INDEX_KEY_MAGIC

public static final int INDEX_KEY_MAGIC
Used as a magic return value while optimized index key feature enabled(HBASE-7845)

See Also:
Constant Field Values

RECOVERED_EDITS_DIR

public static final String RECOVERED_EDITS_DIR
See Also:
Constant Field Values

RPC_HEADER

public static final ByteBuffer RPC_HEADER
The first four bytes of Hadoop RPC connections


RPC_CURRENT_VERSION

public static final byte RPC_CURRENT_VERSION
See Also:
Constant Field Values

HFILEBLOCK_HEADER_SIZE_NO_CHECKSUM

public static final int HFILEBLOCK_HEADER_SIZE_NO_CHECKSUM
The size data structures with minor version is 0

See Also:
Constant Field Values

HFILEBLOCK_HEADER_SIZE

public static final int 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:
Constant Field Values

HFILEBLOCK_DUMMY_HEADER

public static final byte[] HFILEBLOCK_DUMMY_HEADER
Just an array of bytes of the right size.


ZERO_L

public static final Long ZERO_L
long constant for zero


NINES

public static final String NINES
See Also:
Constant Field Values

ZEROES

public static final String ZEROES
See Also:
Constant Field Values

VERSION_FILE_NAME

public static final String VERSION_FILE_NAME
name of version file

See Also:
Constant Field Values

FILE_SYSTEM_VERSION

public static final String 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:
Constant Field Values

CLUSTER_DISTRIBUTED

public static final String CLUSTER_DISTRIBUTED
Cluster is in distributed mode or not

See Also:
Constant Field Values

HBASE_MASTER_LOADBALANCER_CLASS

public static final String HBASE_MASTER_LOADBALANCER_CLASS
Config for pluggable load balancers

See Also:
Constant Field Values

CLUSTER_IS_LOCAL

public static final boolean CLUSTER_IS_LOCAL
Cluster is standalone or pseudo-distributed

See Also:
Constant Field Values

CLUSTER_IS_DISTRIBUTED

public static final boolean CLUSTER_IS_DISTRIBUTED
Cluster is fully-distributed

See Also:
Constant Field Values

DEFAULT_CLUSTER_DISTRIBUTED

public static final boolean DEFAULT_CLUSTER_DISTRIBUTED
Default value for cluster distributed mode

See Also:
Constant Field Values

DEFAULT_HOST

public static final String DEFAULT_HOST
default host address

See Also:
Constant Field Values

MASTER_PORT

public static final String MASTER_PORT
Parameter name for port master listens on.

See Also:
Constant Field Values

DEFAULT_MASTER_PORT

public static final int DEFAULT_MASTER_PORT
default port that the master listens on

See Also:
Constant Field Values

DEFAULT_MASTER_INFOPORT

public static final int DEFAULT_MASTER_INFOPORT
default port for master web api

See Also:
Constant Field Values

MASTER_INFO_PORT

public static final String MASTER_INFO_PORT
Configuration key for master web API port

See Also:
Constant Field Values

MASTER_TYPE_BACKUP

public static final String MASTER_TYPE_BACKUP
Parameter name for the master type being backup (waits for primary to go inactive).

See Also:
Constant Field Values

DEFAULT_MASTER_TYPE_BACKUP

public static final boolean DEFAULT_MASTER_TYPE_BACKUP
by default every master is a possible primary master unless the conf explicitly overrides it

See Also:
Constant Field Values

ZOOKEEPER_QUORUM

public static final String ZOOKEEPER_QUORUM
Name of ZooKeeper quorum configuration parameter.

See Also:
Constant Field Values

ZOOKEEPER_CONFIG_NAME

public static final String ZOOKEEPER_CONFIG_NAME
Name of ZooKeeper config file in conf/ directory.

See Also:
Constant Field Values

ZK_CFG_PROPERTY_PREFIX

public static final String ZK_CFG_PROPERTY_PREFIX
Common prefix of ZooKeeper configuration properties

See Also:
Constant Field Values

ZK_CFG_PROPERTY_PREFIX_LEN

public static final int ZK_CFG_PROPERTY_PREFIX_LEN

CLIENT_PORT_STR

public static final String 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:
Constant Field Values

ZOOKEEPER_CLIENT_PORT

public static final String ZOOKEEPER_CLIENT_PORT
Parameter name for the client port that the zookeeper listens on

See Also:
Constant Field Values

DEFAULT_ZOOKEPER_CLIENT_PORT

public static final int DEFAULT_ZOOKEPER_CLIENT_PORT
Default client port that the zookeeper listens on

See Also:
Constant Field Values

ZOOKEEPER_RECOVERABLE_WAITTIME

public static final String ZOOKEEPER_RECOVERABLE_WAITTIME
Parameter name for the wait time for the recoverable zookeeper

See Also:
Constant Field Values

DEFAULT_ZOOKEPER_RECOVERABLE_WAITIME

public static final long DEFAULT_ZOOKEPER_RECOVERABLE_WAITIME
Default wait time for the recoverable zookeeper

See Also:
Constant Field Values

ZOOKEEPER_ZNODE_PARENT

public static final String ZOOKEEPER_ZNODE_PARENT
Parameter name for the root dir in ZK for this cluster

See Also:
Constant Field Values

DEFAULT_ZOOKEEPER_ZNODE_PARENT

public static final String DEFAULT_ZOOKEEPER_ZNODE_PARENT
See Also:
Constant Field Values

ZOOKEEPER_MAX_CLIENT_CNXNS

public static final String ZOOKEEPER_MAX_CLIENT_CNXNS
Parameter name for the limit on concurrent client-side zookeeper connections

See Also:
Constant Field Values

ZOOKEEPER_DATA_DIR

public static final String ZOOKEEPER_DATA_DIR
Parameter name for the ZK data directory

See Also:
Constant Field Values

ZOOKEEPER_TICK_TIME

public static final String ZOOKEEPER_TICK_TIME
Parameter name for the ZK tick time

See Also:
Constant Field Values

DEFAULT_ZOOKEPER_MAX_CLIENT_CNXNS

public static final int DEFAULT_ZOOKEPER_MAX_CLIENT_CNXNS
Default limit on concurrent client-side zookeeper connections

See Also:
Constant Field Values

ZK_SESSION_TIMEOUT

public static final String ZK_SESSION_TIMEOUT
Configuration key for ZooKeeper session timeout

See Also:
Constant Field Values

DEFAULT_ZK_SESSION_TIMEOUT

public static final int DEFAULT_ZK_SESSION_TIMEOUT
Default value for ZooKeeper session timeout

See Also:
Constant Field Values

ZOOKEEPER_USEMULTI

public static final String ZOOKEEPER_USEMULTI
Configuration key for whether to use ZK.multi

See Also:
Constant Field Values

REGIONSERVER_PORT

public static final String REGIONSERVER_PORT
Parameter name for port region server listens on.

See Also:
Constant Field Values

DEFAULT_REGIONSERVER_PORT

public static final int DEFAULT_REGIONSERVER_PORT
Default port region server listens on.

See Also:
Constant Field Values

DEFAULT_REGIONSERVER_INFOPORT

public static final int DEFAULT_REGIONSERVER_INFOPORT
default port for region server web api

See Also:
Constant Field Values

REGIONSERVER_INFO_PORT

public static final String REGIONSERVER_INFO_PORT
A configuration key for regionserver info port

See Also:
Constant Field Values

REGIONSERVER_INFO_PORT_AUTO

public static final String REGIONSERVER_INFO_PORT_AUTO
A flag that enables automatic selection of regionserver info port

See Also:
Constant Field Values

REGION_SERVER_IMPL

public static final String REGION_SERVER_IMPL
Parameter name for what region server implementation to use.

See Also:
Constant Field Values

MASTER_IMPL

public static final String MASTER_IMPL
Parameter name for what master implementation to use.

See Also:
Constant Field Values

HBASECLIENT_IMPL

public static final String HBASECLIENT_IMPL
Parameter name for what hbase client implementation to use.

See Also:
Constant Field Values

THREAD_WAKE_FREQUENCY

public static final String THREAD_WAKE_FREQUENCY
Parameter name for how often threads should wake up

See Also:
Constant Field Values

DEFAULT_THREAD_WAKE_FREQUENCY

public static final int DEFAULT_THREAD_WAKE_FREQUENCY
Default value for thread wake frequency

See Also:
Constant Field Values

VERSION_FILE_WRITE_ATTEMPTS

public static final String VERSION_FILE_WRITE_ATTEMPTS
Parameter name for how often we should try to write a version file, before failing

See Also:
Constant Field Values

DEFAULT_VERSION_FILE_WRITE_ATTEMPTS

public static final int DEFAULT_VERSION_FILE_WRITE_ATTEMPTS
Parameter name for how often we should try to write a version file, before failing

See Also:
Constant Field Values

MAJOR_COMPACTION_PERIOD

public static final String MAJOR_COMPACTION_PERIOD
Parameter name for how often a region should should perform a major compaction

See Also:
Constant Field Values

COMPACTION_KV_MAX

public static final String COMPACTION_KV_MAX
Parameter name for the maximum batch of KVs to be used in flushes and compactions

See Also:
Constant Field Values

COMPACTION_KV_MAX_DEFAULT

public static final int COMPACTION_KV_MAX_DEFAULT
See Also:
Constant Field Values

HBASE_DIR

public static final String HBASE_DIR
Parameter name for HBase instance root directory

See Also:
Constant Field Values

HBASE_CLIENT_IPC_POOL_TYPE

public static final String HBASE_CLIENT_IPC_POOL_TYPE
Parameter name for HBase client IPC pool type

See Also:
Constant Field Values

HBASE_CLIENT_IPC_POOL_SIZE

public static final String HBASE_CLIENT_IPC_POOL_SIZE
Parameter name for HBase client IPC pool size

See Also:
Constant Field Values

HBASE_CLIENT_OPERATION_TIMEOUT

public static final String HBASE_CLIENT_OPERATION_TIMEOUT
Parameter name for HBase client operation timeout, which overrides RPC timeout

See Also:
Constant Field Values

HBASE_CLIENT_META_OPERATION_TIMEOUT

public static final String HBASE_CLIENT_META_OPERATION_TIMEOUT
Parameter name for HBase client operation timeout, which overrides RPC timeout

See Also:
Constant Field Values

DEFAULT_HBASE_CLIENT_OPERATION_TIMEOUT

public static final int DEFAULT_HBASE_CLIENT_OPERATION_TIMEOUT
Default HBase client operation timeout, which is tantamount to a blocking call

See Also:
Constant Field Values

HREGION_LOGDIR_NAME

public static final String HREGION_LOGDIR_NAME
Used to construct the name of the log directory for a region server

See Also:
Constant Field Values

SPLIT_LOGDIR_NAME

public static final String SPLIT_LOGDIR_NAME
Used to construct the name of the splitlog directory for a region server

See Also:
Constant Field Values

HREGION_OLDLOGDIR_NAME

public static final String HREGION_OLDLOGDIR_NAME
Like the previous, but for old logs that are about to be deleted

See Also:
Constant Field Values

CORRUPT_DIR_NAME

public static final String CORRUPT_DIR_NAME
See Also:
Constant Field Values

HBCK_SIDELINEDIR_NAME

public static final String HBCK_SIDELINEDIR_NAME
Used by HBCK to sideline backup data

See Also:
Constant Field Values

MIGRATION_NAME

public static final String MIGRATION_NAME
Any artifacts left from migration can be moved here

See Also:
Constant Field Values

LIB_DIR

public static final String LIB_DIR
The directory from which co-processor/custom filter jars can be loaded dynamically by the region servers. This value can be overridden by the hbase.dynamic.jars.dir config.

See Also:
Constant Field Values

HREGION_COMPACTIONDIR_NAME

public static final String HREGION_COMPACTIONDIR_NAME
Used to construct the name of the compaction directory during compaction

See Also:
Constant Field Values

HREGION_MAX_FILESIZE

public static final String HREGION_MAX_FILESIZE
Conf key for the max file size after which we split the region

See Also:
Constant Field Values

DEFAULT_MAX_FILE_SIZE

public static final long DEFAULT_MAX_FILE_SIZE
Default maximum file size

See Also:
Constant Field Values

HSTORE_OPEN_AND_CLOSE_THREADS_MAX

public static final String HSTORE_OPEN_AND_CLOSE_THREADS_MAX
The max number of threads used for opening and closing stores or store files in parallel

See Also:
Constant Field Values

DEFAULT_HSTORE_OPEN_AND_CLOSE_THREADS_MAX

public static final 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

See Also:
Constant Field Values

HREGION_MEMSTORE_FLUSH_SIZE

public static final String HREGION_MEMSTORE_FLUSH_SIZE
Conf key for the memstore size at which we flush the memstore

See Also:
Constant Field Values

HREGION_EDITS_REPLAY_SKIP_ERRORS

public static final String HREGION_EDITS_REPLAY_SKIP_ERRORS
See Also:
Constant Field Values

DEFAULT_HREGION_EDITS_REPLAY_SKIP_ERRORS

public static final boolean DEFAULT_HREGION_EDITS_REPLAY_SKIP_ERRORS
See Also:
Constant Field Values

MAXIMUM_VALUE_LENGTH

public static final int MAXIMUM_VALUE_LENGTH
Maximum value length, enforced on KeyValue construction

See Also:
Constant Field Values

CLUSTER_ID_FILE_NAME

public static final String CLUSTER_ID_FILE_NAME
name of the file for unique cluster ID

See Also:
Constant Field Values

CLUSTER_ID_DEFAULT

public static final String CLUSTER_ID_DEFAULT
Default value for cluster ID

See Also:
Constant Field Values

META_TABLE_NAME

@Deprecated
public static final byte[] META_TABLE_NAME
Deprecated. 
The hbase:meta table's name.


BASE_NAMESPACE_DIR

public static final String BASE_NAMESPACE_DIR
See Also:
Constant Field Values

META_ROW_DELIMITER

public static final int META_ROW_DELIMITER
delimiter used between portions of a region name

See Also:
Constant Field Values

CATALOG_FAMILY_STR

public static final String CATALOG_FAMILY_STR
The catalog family as a string

See Also:
Constant Field Values

CATALOG_FAMILY

public static final byte[] CATALOG_FAMILY
The catalog family


REGIONINFO_QUALIFIER_STR

public static final String REGIONINFO_QUALIFIER_STR
The RegionInfo qualifier as a string

See Also:
Constant Field Values

REGIONINFO_QUALIFIER

public static final byte[] REGIONINFO_QUALIFIER
The regioninfo column qualifier


SERVER_QUALIFIER

public static final byte[] SERVER_QUALIFIER
The server column qualifier


STARTCODE_QUALIFIER

public static final byte[] STARTCODE_QUALIFIER
The startcode column qualifier


SEQNUM_QUALIFIER

public static final byte[] SEQNUM_QUALIFIER
The open seqnum column qualifier


STATE_QUALIFIER

public static final byte[] STATE_QUALIFIER
The state column qualifier


SERVERNAME_QUALIFIER

public static final byte[] SERVERNAME_QUALIFIER
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.


SPLITA_QUALIFIER

public static final byte[] SPLITA_QUALIFIER
The lower-half split region column qualifier


SPLITB_QUALIFIER

public static final byte[] SPLITB_QUALIFIER
The upper-half split region column qualifier


MERGEA_QUALIFIER

public static final byte[] MERGEA_QUALIFIER
The lower-half merge region column qualifier


MERGEB_QUALIFIER

public static final byte[] MERGEB_QUALIFIER
The upper-half merge region column qualifier


META_VERSION_QUALIFIER

public static final byte[] 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.


META_VERSION

public static final short 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:
Constant Field Values

EMPTY_BYTE_ARRAY

public static final byte[] EMPTY_BYTE_ARRAY
An empty instance.


EMPTY_START_ROW

public static final byte[] EMPTY_START_ROW
Used by scanners, etc when they want to start at the beginning of a region


EMPTY_END_ROW

public static final byte[] EMPTY_END_ROW
Last row in a table.


LAST_ROW

public static final byte[] LAST_ROW
Used by scanners and others when they're trying to detect the end of a table


MAX_ROW_LENGTH

public static final int MAX_ROW_LENGTH
Max length a row can have because of the limitation in TFile.

See Also:
Constant Field Values

LATEST_TIMESTAMP

public static final long LATEST_TIMESTAMP
Timestamp to use when we want to refer to the latest cell. This is the timestamp sent by clients when no timestamp is specified on commit.

See Also:
Constant Field Values

OLDEST_TIMESTAMP

public static final long OLDEST_TIMESTAMP
Timestamp to use when we want to refer to the oldest cell.

See Also:
Constant Field Values

LATEST_TIMESTAMP_BYTES

public static final byte[] LATEST_TIMESTAMP_BYTES
LATEST_TIMESTAMP in bytes form


ALL_VERSIONS

public static final int ALL_VERSIONS
Define for 'return-all-versions'.

See Also:
Constant Field Values

FOREVER

public static final int FOREVER
Unlimited time-to-live.

See Also:
Constant Field Values

WEEK_IN_SECONDS

public static final int WEEK_IN_SECONDS
Seconds in a week

See Also:
Constant Field Values

DAY_IN_SECONDS

public static final int DAY_IN_SECONDS
Seconds in a day, hour and minute

See Also:
Constant Field Values

HOUR_IN_SECONDS

public static final int HOUR_IN_SECONDS
See Also:
Constant Field Values

MINUTE_IN_SECONDS

public static final int MINUTE_IN_SECONDS
See Also:
Constant Field Values

NAME

public static final String NAME
See Also:
Constant Field Values

VERSIONS

public static final String VERSIONS
See Also:
Constant Field Values

IN_MEMORY

public static final String IN_MEMORY
See Also:
Constant Field Values

METADATA

public static final String METADATA
See Also:
Constant Field Values

CONFIGURATION

public static final String CONFIGURATION
See Also:
Constant Field Values

RETRY_BACKOFF

public static final int[] 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

public static final String REGION_IMPL
See Also:
Constant Field Values

REPLICATION_SCOPE_LOCAL

public static final int REPLICATION_SCOPE_LOCAL
Scope tag for locally scoped data. This data will not be replicated.

See Also:
Constant Field Values

REPLICATION_SCOPE_GLOBAL

public static final int REPLICATION_SCOPE_GLOBAL
Scope tag for globally scoped data. This data will be replicated to all peers.

See Also:
Constant Field Values

DEFAULT_CLUSTER_ID

public static final 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.


HBASE_CLIENT_SCANNER_MAX_RESULT_SIZE_KEY

public static final String HBASE_CLIENT_SCANNER_MAX_RESULT_SIZE_KEY
Parameter name for maximum number of bytes returned when calling a scanner's next method.

See Also:
Constant Field Values

HBASE_SERVER_SCANNER_MAX_RESULT_SIZE_KEY

public static final String 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:
Constant Field Values

DEFAULT_HBASE_CLIENT_SCANNER_MAX_RESULT_SIZE

public static final long 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:
Constant Field Values

DEFAULT_HBASE_SERVER_SCANNER_MAX_RESULT_SIZE

public static final long 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 unlimited for backwards compatibility

See Also:
Constant Field Values

HBASE_CLIENT_PAUSE

public static final 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.

See Also:
Constant Field Values

DEFAULT_HBASE_CLIENT_PAUSE

public static final long DEFAULT_HBASE_CLIENT_PAUSE
Default value of HBASE_CLIENT_PAUSE.

See Also:
Constant Field Values

HBASE_CLIENT_MAX_TOTAL_TASKS

public static final String HBASE_CLIENT_MAX_TOTAL_TASKS
The maximum number of concurrent connections the client will maintain.

See Also:
Constant Field Values

DEFAULT_HBASE_CLIENT_MAX_TOTAL_TASKS

public static final int DEFAULT_HBASE_CLIENT_MAX_TOTAL_TASKS
Default value of HBASE_CLIENT_MAX_TOTAL_TASKS.

See Also:
Constant Field Values

HBASE_CLIENT_MAX_PERSERVER_TASKS

public static final String HBASE_CLIENT_MAX_PERSERVER_TASKS
The maximum number of concurrent connections the client will maintain to a single RegionServer.

See Also:
Constant Field Values

DEFAULT_HBASE_CLIENT_MAX_PERSERVER_TASKS

public static final int DEFAULT_HBASE_CLIENT_MAX_PERSERVER_TASKS
Default value of HBASE_CLIENT_MAX_PERSERVER_TASKS.

See Also:
Constant Field Values

HBASE_CLIENT_MAX_PERREGION_TASKS

public static final String HBASE_CLIENT_MAX_PERREGION_TASKS
The maximum number of concurrent connections the client will maintain to a single Region.

See Also:
Constant Field Values

DEFAULT_HBASE_CLIENT_MAX_PERREGION_TASKS

public static final int DEFAULT_HBASE_CLIENT_MAX_PERREGION_TASKS
Default value of HBASE_CLIENT_MAX_PERREGION_TASKS.

See Also:
Constant Field Values

HBASE_SERVER_PAUSE

public static final String 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:
Constant Field Values

DEFAULT_HBASE_SERVER_PAUSE

public static final int DEFAULT_HBASE_SERVER_PAUSE
Default value of HBASE_SERVER_PAUSE.

See Also:
Constant Field Values

HBASE_CLIENT_RETRIES_NUMBER

public static final 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.

See Also:
Constant Field Values

DEFAULT_HBASE_CLIENT_RETRIES_NUMBER

public static final int DEFAULT_HBASE_CLIENT_RETRIES_NUMBER
Default value of HBASE_CLIENT_RETRIES_NUMBER.

See Also:
Constant Field Values

HBASE_CLIENT_PREFETCH

public static String HBASE_CLIENT_PREFETCH
Parameter name for client region location prefetch toggle.


DEFAULT_HBASE_CLIENT_PREFETCH

public static boolean DEFAULT_HBASE_CLIENT_PREFETCH
Default value of HBASE_CLIENT_PREFETCH.


HBASE_CLIENT_PREFETCH_LIMIT

public static String HBASE_CLIENT_PREFETCH_LIMIT
Parameter name for client prefetch limit, used as the maximum number of regions info that will be prefetched.


DEFAULT_HBASE_CLIENT_PREFETCH_LIMIT

public static int DEFAULT_HBASE_CLIENT_PREFETCH_LIMIT
Default value of HBASE_CLIENT_PREFETCH_LIMIT.


HBASE_CLIENT_SCANNER_CACHING

public static final String HBASE_CLIENT_SCANNER_CACHING
Parameter name to set the default scanner caching for all clients.

See Also:
Constant Field Values

DEFAULT_HBASE_CLIENT_SCANNER_CACHING

public static final int DEFAULT_HBASE_CLIENT_SCANNER_CACHING
Default value for HBASE_CLIENT_SCANNER_CACHING

See Also:
Constant Field Values

HBASE_META_VERSIONS

public static String HBASE_META_VERSIONS
Parameter name for number of versions, kept by meta table.


DEFAULT_HBASE_META_VERSIONS

public static int DEFAULT_HBASE_META_VERSIONS
Default value of HBASE_META_VERSIONS.


HBASE_META_BLOCK_SIZE

public static String HBASE_META_BLOCK_SIZE
Parameter name for number of versions, kept by meta table.


DEFAULT_HBASE_META_BLOCK_SIZE

public static int DEFAULT_HBASE_META_BLOCK_SIZE
Default value of HBASE_META_BLOCK_SIZE.


HBASE_META_SCANNER_CACHING

public static final 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. 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:
Constant Field Values

DEFAULT_HBASE_META_SCANNER_CACHING

public static final int DEFAULT_HBASE_META_SCANNER_CACHING
Default value of HBASE_META_SCANNER_CACHING.

See Also:
Constant Field Values

HBASE_CLIENT_INSTANCE_ID

public static final String HBASE_CLIENT_INSTANCE_ID
Parameter name for unique identifier for this 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.

See Also:
Constant Field Values

HBASE_CLIENT_SCANNER_TIMEOUT_PERIOD

public static final String HBASE_CLIENT_SCANNER_TIMEOUT_PERIOD
The client scanner timeout period in milliseconds.

See Also:
Constant Field Values

HBASE_REGIONSERVER_LEASE_PERIOD_KEY

@Deprecated
public static final String HBASE_REGIONSERVER_LEASE_PERIOD_KEY
Deprecated. This config option is deprecated. Will be removed at later releases after 0.96.
Use HBASE_CLIENT_SCANNER_TIMEOUT_PERIOD instead.

See Also:
Constant Field Values

DEFAULT_HBASE_CLIENT_SCANNER_TIMEOUT_PERIOD

public static final int DEFAULT_HBASE_CLIENT_SCANNER_TIMEOUT_PERIOD
Default value of HBASE_CLIENT_SCANNER_TIMEOUT_PERIOD.

See Also:
Constant Field Values

HBASE_RPC_TIMEOUT_KEY

public static final String HBASE_RPC_TIMEOUT_KEY
timeout for each RPC

See Also:
Constant Field Values

DEFAULT_HBASE_RPC_TIMEOUT

public static final int DEFAULT_HBASE_RPC_TIMEOUT
Default value of HBASE_RPC_TIMEOUT_KEY

See Also:
Constant Field Values

HBASE_RPC_SHORTOPERATION_TIMEOUT_KEY

public static final String HBASE_RPC_SHORTOPERATION_TIMEOUT_KEY
timeout for short operation RPC

See Also:
Constant Field Values

DEFAULT_HBASE_RPC_SHORTOPERATION_TIMEOUT

public static final int DEFAULT_HBASE_RPC_SHORTOPERATION_TIMEOUT
Default value of HBASE_RPC_SHORTOPERATION_TIMEOUT_KEY

See Also:
Constant Field Values

NO_SEQNUM

public static final long NO_SEQNUM
Value indicating the server name was saved with no sequence number.

See Also:
Constant Field Values

REPLICATION_ENABLE_KEY

public static final String REPLICATION_ENABLE_KEY
See Also:
Constant Field Values

REPLICATION_ENABLE_DEFAULT

public static final boolean REPLICATION_ENABLE_DEFAULT
See Also:
Constant Field Values

REPLICATION_SOURCE_SERVICE_CLASSNAME

public static final String REPLICATION_SOURCE_SERVICE_CLASSNAME
See Also:
Constant Field Values

REPLICATION_SINK_SERVICE_CLASSNAME

public static final String REPLICATION_SINK_SERVICE_CLASSNAME
See Also:
Constant Field Values

REPLICATION_SERVICE_CLASSNAME_DEFAULT

public static final String REPLICATION_SERVICE_CLASSNAME_DEFAULT
See Also:
Constant Field Values

HBCK_CODE_NAME

public static final String HBCK_CODE_NAME
HBCK special code name used as server name when manipulating ZK nodes

See Also:
Constant Field Values

KEY_FOR_HOSTNAME_SEEN_BY_MASTER

public static final String KEY_FOR_HOSTNAME_SEEN_BY_MASTER
See Also:
Constant Field Values

HBASE_MASTER_LOGCLEANER_PLUGINS

public static final String HBASE_MASTER_LOGCLEANER_PLUGINS
See Also:
Constant Field Values

HBASE_REGION_SPLIT_POLICY_KEY

public static final String HBASE_REGION_SPLIT_POLICY_KEY
See Also:
Constant Field Values

HBASE_RS_NONCES_ENABLED

public static final String HBASE_RS_NONCES_ENABLED
Whether nonces are enabled; default is true.

See Also:
Constant Field Values

HFILE_BLOCK_CACHE_SIZE_KEY

public static final String HFILE_BLOCK_CACHE_SIZE_KEY
Configuration key for the size of the block cache

See Also:
Constant Field Values

HFILE_BLOCK_CACHE_SIZE_DEFAULT

public static final float HFILE_BLOCK_CACHE_SIZE_DEFAULT
See Also:
Constant Field Values

HBASE_CLUSTER_MINIMUM_MEMORY_THRESHOLD

public static final float HBASE_CLUSTER_MINIMUM_MEMORY_THRESHOLD
See Also:
Constant Field Values

CP_HTD_ATTR_KEY_PATTERN

public static final Pattern CP_HTD_ATTR_KEY_PATTERN

CP_HTD_ATTR_VALUE_PATTERN

public static final Pattern CP_HTD_ATTR_VALUE_PATTERN

CP_HTD_ATTR_VALUE_PARAM_KEY_PATTERN

public static final String CP_HTD_ATTR_VALUE_PARAM_KEY_PATTERN
See Also:
Constant Field Values

CP_HTD_ATTR_VALUE_PARAM_VALUE_PATTERN

public static final String CP_HTD_ATTR_VALUE_PARAM_VALUE_PATTERN
See Also:
Constant Field Values

CP_HTD_ATTR_VALUE_PARAM_PATTERN

public static final Pattern CP_HTD_ATTR_VALUE_PARAM_PATTERN

SOCKET_RETRY_WAIT_MS

public static final int SOCKET_RETRY_WAIT_MS
The delay when re-trying a socket operation in a loop (HBASE-4712)

See Also:
Constant Field Values

LOCALHOST

public static final String LOCALHOST
Host name of the local machine

See Also:
Constant Field Values

HBASE_CHECKSUM_VERIFICATION

public static final String 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:
Constant Field Values

LOCALHOST_IP

public static final String LOCALHOST_IP
See Also:
Constant Field Values

DISTRIBUTED_LOG_REPLAY_KEY

public static final String DISTRIBUTED_LOG_REPLAY_KEY
Conf key that enables unflushed WAL edits directly being replayed to region servers

See Also:
Constant Field Values

DEFAULT_DISTRIBUTED_LOG_REPLAY_CONFIG

public static final boolean DEFAULT_DISTRIBUTED_LOG_REPLAY_CONFIG
See Also:
Constant Field Values

DISALLOW_WRITES_IN_RECOVERING

public static final String DISALLOW_WRITES_IN_RECOVERING
See Also:
Constant Field Values

DEFAULT_DISALLOW_WRITES_IN_RECOVERING_CONFIG

public static final boolean DEFAULT_DISALLOW_WRITES_IN_RECOVERING_CONFIG
See Also:
Constant Field Values

REGION_SERVER_HANDLER_COUNT

public static final String REGION_SERVER_HANDLER_COUNT
See Also:
Constant Field Values

DEFAULT_REGION_SERVER_HANDLER_COUNT

public static final int DEFAULT_REGION_SERVER_HANDLER_COUNT
See Also:
Constant Field Values

REGION_SERVER_HANDLER_ABORT_ON_ERROR_PERCENT

public static final String REGION_SERVER_HANDLER_ABORT_ON_ERROR_PERCENT
See Also:
Constant Field Values

DEFAULT_REGION_SERVER_HANDLER_ABORT_ON_ERROR_PERCENT

public static final float DEFAULT_REGION_SERVER_HANDLER_ABORT_ON_ERROR_PERCENT
See Also:
Constant Field Values

REGION_SERVER_META_HANDLER_COUNT

public static final String REGION_SERVER_META_HANDLER_COUNT
See Also:
Constant Field Values

DEFAULT_REGION_SERVER_META_HANDLER_COUNT

public static final int DEFAULT_REGION_SERVER_META_HANDLER_COUNT
See Also:
Constant Field Values

REGION_SERVER_REPLICATION_HANDLER_COUNT

public static final String REGION_SERVER_REPLICATION_HANDLER_COUNT
See Also:
Constant Field Values

DEFAULT_REGION_SERVER_REPLICATION_HANDLER_COUNT

public static final int DEFAULT_REGION_SERVER_REPLICATION_HANDLER_COUNT
See Also:
Constant Field Values

MASTER_HANDLER_COUNT

public static final String MASTER_HANDLER_COUNT
See Also:
Constant Field Values

DEFAULT_MASTER_HANLDER_COUNT

public static final int DEFAULT_MASTER_HANLDER_COUNT
See Also:
Constant Field Values

LOG_REPLAY_WAIT_REGION_TIMEOUT

public static final String LOG_REPLAY_WAIT_REGION_TIMEOUT
Conf key that specifies timeout value to wait for a region ready

See Also:
Constant Field Values

BYTES_PER_CHECKSUM

public static final String BYTES_PER_CHECKSUM
The name of the configuration parameter that specifies the number of bytes in a newly created checksum chunk.

See Also:
Constant Field Values

CHECKSUM_TYPE_NAME

public static final 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.

See Also:
Constant Field Values

ENABLE_DATA_FILE_UMASK

public static final String ENABLE_DATA_FILE_UMASK
Enable file permission modification from standard hbase

See Also:
Constant Field Values

DATA_FILE_UMASK_KEY

public static final String DATA_FILE_UMASK_KEY
File permission umask to use when creating hbase data files

See Also:
Constant Field Values

ENABLE_WAL_COMPRESSION

public static final String ENABLE_WAL_COMPRESSION
Configuration name of HLog Compression

See Also:
Constant Field Values

METRICS_RIT_STUCK_WARNING_THRESHOLD

public static final String METRICS_RIT_STUCK_WARNING_THRESHOLD
Region in Transition metrics threshold time

See Also:
Constant Field Values

LOAD_BALANCER_SLOP_KEY

public static final String LOAD_BALANCER_SLOP_KEY
See Also:
Constant Field Values

NO_NEXT_INDEXED_KEY

public static final byte[] NO_NEXT_INDEXED_KEY
The byte array represents for NO_NEXT_INDEXED_KEY; The actual value is irrelevant because this is always compared by reference.


DELIMITER

public static final int DELIMITER
delimiter used between portions of a region name

See Also:
Constant Field Values

HBASE_CONFIG_READ_ZOOKEEPER_CONFIG

public static final String HBASE_CONFIG_READ_ZOOKEEPER_CONFIG
See Also:
Constant Field Values

DEFAULT_HBASE_CONFIG_READ_ZOOKEEPER_CONFIG

public static final boolean DEFAULT_HBASE_CONFIG_READ_ZOOKEEPER_CONFIG
See Also:
Constant Field Values

NORMAL_QOS

public static final int NORMAL_QOS
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:
Constant Field Values

QOS_THRESHOLD

public static final int QOS_THRESHOLD
See Also:
Constant Field Values

HIGH_QOS

public static final int HIGH_QOS
See Also:
Constant Field Values

REPLICATION_QOS

public static final int REPLICATION_QOS
See Also:
Constant Field Values

REPLAY_QOS

public static final int REPLAY_QOS
See Also:
Constant Field Values

HFILE_ARCHIVE_DIRECTORY

public static final String HFILE_ARCHIVE_DIRECTORY
Directory under /hbase where archived hfiles are stored

See Also:
Constant Field Values

SNAPSHOT_DIR_NAME

public static final String 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:
Constant Field Values

OLD_SNAPSHOT_DIR_NAME

public static final String OLD_SNAPSHOT_DIR_NAME
See Also:
Constant Field Values

HBASE_TEMP_DIRECTORY

public static final String HBASE_TEMP_DIRECTORY
Temporary directory used for table creation and deletion

See Also:
Constant Field Values

REGIONSERVER_METRICS_PERIOD

public static final String REGIONSERVER_METRICS_PERIOD
The period (in milliseconds) between computing region server point in time metrics

See Also:
Constant Field Values

DEFAULT_REGIONSERVER_METRICS_PERIOD

public static final long DEFAULT_REGIONSERVER_METRICS_PERIOD
See Also:
Constant Field Values

HBASE_NON_TABLE_DIRS

public static final List<String> HBASE_NON_TABLE_DIRS
Directories that are not HBase table directories


HBASE_NON_USER_TABLE_DIRS

public static final List<String> HBASE_NON_USER_TABLE_DIRS
Directories that are not HBase user table directories


HEALTH_SCRIPT_LOC

public static final String HEALTH_SCRIPT_LOC
Health script related settings.

See Also:
Constant Field Values

HEALTH_SCRIPT_TIMEOUT

public static final String HEALTH_SCRIPT_TIMEOUT
See Also:
Constant Field Values

HEALTH_CHORE_WAKE_FREQ

public static final String HEALTH_CHORE_WAKE_FREQ
See Also:
Constant Field Values

DEFAULT_HEALTH_SCRIPT_TIMEOUT

public static final long DEFAULT_HEALTH_SCRIPT_TIMEOUT
See Also:
Constant Field Values

HEALTH_FAILURE_THRESHOLD

public static final String HEALTH_FAILURE_THRESHOLD
The maximum number of health check failures a server can encounter consecutively.

See Also:
Constant Field Values

DEFAULT_HEALTH_FAILURE_THRESHOLD

public static final int DEFAULT_HEALTH_FAILURE_THRESHOLD
See Also:
Constant Field Values

STATUS_PUBLISHED

public static final String STATUS_PUBLISHED
Setting to activate, or not, the publication of the status by the master. Default notification is by a multicast message.

See Also:
Constant Field Values

STATUS_PUBLISHED_DEFAULT

public static final boolean STATUS_PUBLISHED_DEFAULT
See Also:
Constant Field Values

STATUS_MULTICAST_ADDRESS

public static final String 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:
Constant Field Values

DEFAULT_STATUS_MULTICAST_ADDRESS

public static final String DEFAULT_STATUS_MULTICAST_ADDRESS
See Also:
Constant Field Values

STATUS_MULTICAST_BIND_ADDRESS

public static final String STATUS_MULTICAST_BIND_ADDRESS
The address to use for binding the local socket for receiving multicast. Defaults to 0.0.0.0.

See Also:
HBASE-9961, Constant Field Values

DEFAULT_STATUS_MULTICAST_BIND_ADDRESS

public static final String DEFAULT_STATUS_MULTICAST_BIND_ADDRESS
See Also:
Constant Field Values

STATUS_MULTICAST_PORT

public static final String STATUS_MULTICAST_PORT
The port to use for the multicast messages.

See Also:
Constant Field Values

DEFAULT_STATUS_MULTICAST_PORT

public static final int DEFAULT_STATUS_MULTICAST_PORT
See Also:
Constant Field Values

NO_NONCE

public static final long NO_NONCE
See Also:
Constant Field Values

CIPHER_AES

public static final String CIPHER_AES
Default cipher for encryption

See Also:
Constant Field Values

CRYPTO_CIPHERPROVIDER_CONF_KEY

@InterfaceStability.Unstable
public static final String CRYPTO_CIPHERPROVIDER_CONF_KEY
Configuration key for the crypto algorithm provider, a class name

See Also:
Constant Field Values

CRYPTO_KEYPROVIDER_CONF_KEY

@InterfaceStability.Unstable
public static final String CRYPTO_KEYPROVIDER_CONF_KEY
Configuration key for the crypto key provider, a class name

See Also:
Constant Field Values

CRYPTO_KEYPROVIDER_PARAMETERS_KEY

@InterfaceStability.Unstable
public static final String CRYPTO_KEYPROVIDER_PARAMETERS_KEY
Configuration key for the crypto key provider parameters

See Also:
Constant Field Values

CRYPTO_MASTERKEY_NAME_CONF_KEY

@InterfaceStability.Unstable
public static final String CRYPTO_MASTERKEY_NAME_CONF_KEY
Configuration key for the name of the master key for the cluster, a string

See Also:
Constant Field Values

CRYPTO_MASTERKEY_ALTERNATE_NAME_CONF_KEY

@InterfaceStability.Unstable
public static final String CRYPTO_MASTERKEY_ALTERNATE_NAME_CONF_KEY
Configuration key for the name of the alternate master key for the cluster, a string

See Also:
Constant Field Values

CRYPTO_WAL_ALGORITHM_CONF_KEY

@InterfaceStability.Unstable
public static final String CRYPTO_WAL_ALGORITHM_CONF_KEY
Configuration key for the algorithm to use when encrypting the WAL, a string

See Also:
Constant Field Values

CRYPTO_WAL_KEY_NAME_CONF_KEY

@InterfaceStability.Unstable
public static final String CRYPTO_WAL_KEY_NAME_CONF_KEY
Configuration key for the name of the master WAL encryption key for the cluster, a string

See Also:
Constant Field Values

CRYPTO_KEY_ALGORITHM_CONF_KEY

public static final String CRYPTO_KEY_ALGORITHM_CONF_KEY
Configuration key for the algorithm used for creating jks key, a string

See Also:
Constant Field Values

CRYPTO_ALTERNATE_KEY_ALGORITHM_CONF_KEY

public static final String CRYPTO_ALTERNATE_KEY_ALGORITHM_CONF_KEY
Configuration key for the name of the alternate cipher algorithm for the cluster, a string

See Also:
Constant Field Values

ENABLE_WAL_ENCRYPTION

public static final String ENABLE_WAL_ENCRYPTION
Configuration key for enabling WAL encryption, a boolean

See Also:
Constant Field Values

RPC_CODEC_CONF_KEY

public static final String RPC_CODEC_CONF_KEY
Configuration key for setting RPC codec class name

See Also:
Constant Field Values

REPLICATION_CODEC_CONF_KEY

public static final String REPLICATION_CODEC_CONF_KEY
Configuration key for setting replication codec class name

See Also:
Constant Field Values

ENABLE_CLIENT_BACKPRESSURE

public static final 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

See Also:
Constant Field Values

DEFAULT_ENABLE_CLIENT_BACKPRESSURE

public static final boolean DEFAULT_ENABLE_CLIENT_BACKPRESSURE
See Also:
Constant Field Values

HEAP_OCCUPANCY_LOW_WATERMARK_KEY

public static final String HEAP_OCCUPANCY_LOW_WATERMARK_KEY
See Also:
Constant Field Values

DEFAULT_HEAP_OCCUPANCY_LOW_WATERMARK

public static final float DEFAULT_HEAP_OCCUPANCY_LOW_WATERMARK
See Also:
Constant Field Values

HEAP_OCCUPANCY_HIGH_WATERMARK_KEY

public static final String HEAP_OCCUPANCY_HIGH_WATERMARK_KEY
See Also:
Constant Field Values

DEFAULT_HEAP_OCCUPANCY_HIGH_WATERMARK

public static final float DEFAULT_HEAP_OCCUPANCY_HIGH_WATERMARK
See Also:
Constant Field Values


Copyright © 2015 The Apache Software Foundation. All Rights Reserved.