- CACHE_BLOOMS_ON_WRITE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- CACHE_DATA_ON_WRITE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- CACHE_INDEX_ON_WRITE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- CacheEvictionStats - Class in org.apache.hadoop.hbase
-
- calculateAutoBalancedSplits(List<InputSplit>, long) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Calculates the number of MapReduce input splits for the map tasks.
- call(S, RpcController, RpcCallback<R>) - Method in interface org.apache.hadoop.hbase.client.ServiceCaller
-
Represent the actual protobuf rpc call.
- CallCancelledException - Exception in org.apache.hadoop.hbase.ipc
-
Client side call cancelled.
- CallCancelledException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.CallCancelledException
-
- CallDroppedException - Exception in org.apache.hadoop.hbase
-
Returned to the clients when their request was discarded due to server being overloaded.
- CallDroppedException() - Constructor for exception org.apache.hadoop.hbase.CallDroppedException
-
- CallDroppedException(String) - Constructor for exception org.apache.hadoop.hbase.CallDroppedException
-
- CallerDisconnectedException - Exception in org.apache.hadoop.hbase.ipc
-
Exception indicating that the remote host making this IPC lost its IPC connection.
- CallerDisconnectedException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.CallerDisconnectedException
-
- CallQueueTooBigException - Exception in org.apache.hadoop.hbase
-
Returned to clients when their request was dropped because the call queue was too big to accept a
new call.
- CallQueueTooBigException() - Constructor for exception org.apache.hadoop.hbase.CallQueueTooBigException
-
- CallQueueTooBigException(String) - Constructor for exception org.apache.hadoop.hbase.CallQueueTooBigException
-
- CallTimeoutException - Exception in org.apache.hadoop.hbase.ipc
-
Client-side call timeout
- CallTimeoutException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.CallTimeoutException
-
- CallTimeoutException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.ipc.CallTimeoutException
-
CallTimeoutException with cause
- canTakeRow(HRegionLocation, Row) - Method in interface org.apache.hadoop.hbase.client.RequestController.Checker
-
Checks the data whether it is valid to submit.
- CATALOG_FAMILY - Static variable in class org.apache.hadoop.hbase.HConstants
-
The catalog family
- CATALOG_FAMILY_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The catalog family as a string
- catalogJanitorSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Enable/Disable the catalog janitor/
- catalogJanitorSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Turn the catalog janitor on/off.
- Cell - Interface in org.apache.hadoop.hbase
-
The unit of storage in HBase consisting of the following fields:
- CellBuilder - Interface in org.apache.hadoop.hbase
-
- CellBuilderFactory - Class in org.apache.hadoop.hbase
-
Create a CellBuilder instance.
- CellBuilderType - Enum in org.apache.hadoop.hbase
-
- CellComparator - Interface in org.apache.hadoop.hbase
-
Comparator for comparing cells and has some specialized methods that allows comparing individual
cell components like row, family, qualifier and timestamp
- CellCounter - Class in org.apache.hadoop.hbase.mapreduce
-
A job with a a map and reduce phase to count cells in a table.
- CellCounter() - Constructor for class org.apache.hadoop.hbase.mapreduce.CellCounter
-
- CellCreator - Class in org.apache.hadoop.hbase.mapreduce
-
Facade to create Cells for HFileOutputFormat.
- CellCreator(Configuration) - Constructor for class org.apache.hadoop.hbase.mapreduce.CellCreator
-
- CellScannable - Interface in org.apache.hadoop.hbase
-
Implementer can return a CellScanner over its Cell content.
- cellScanner() - Method in interface org.apache.hadoop.hbase.CellScannable
-
Returns A CellScanner over the contained
Cell
s
- CellScanner - Interface in org.apache.hadoop.hbase
-
An interface for iterating through a sequence of cells.
- cellScanner() - Method in class org.apache.hadoop.hbase.client.Mutation
-
- cellScanner() - Method in class org.apache.hadoop.hbase.client.Result
-
- CellScannerButNoCodecException - Exception in org.apache.hadoop.hbase.ipc
-
Thrown if a cellscanner but no codec to encode it with.
- CellScannerButNoCodecException() - Constructor for exception org.apache.hadoop.hbase.ipc.CellScannerButNoCodecException
-
- CellSerialization - Class in org.apache.hadoop.hbase.mapreduce
-
- CellSerialization() - Constructor for class org.apache.hadoop.hbase.mapreduce.CellSerialization
-
- CellSortReducer - Class in org.apache.hadoop.hbase.mapreduce
-
Emits sorted Cells.
- CellSortReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.CellSortReducer
-
- CellUtil - Class in org.apache.hadoop.hbase
-
Utility methods helpful for slinging
Cell
instances.
- cellVisibilityExpr - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
- CF_RENAME_PROP - Static variable in class org.apache.hadoop.hbase.mapreduce.Import
-
- chance - Variable in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
- CHAOS_AGENT_REGISTRATION_EPIMERAL_ZNODE - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
-
- CHAOS_AGENT_STATUS_PERSISTENT_ZNODE - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
-
- CHAOS_TEST_ROOT_ZNODE - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
-
- CHAOSAGENT_SHELL_USER - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
-
- ChaosConstants - Class in org.apache.hadoop.hbase.chaos
-
ChaosConstant holds a bunch of Choas-related Constants
- ChaosConstants() - Constructor for class org.apache.hadoop.hbase.chaos.ChaosConstants
-
- checkAndMutate(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
- checkAndMutate(byte[], Filter) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
- checkAndMutate(CheckAndMutate) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
checkAndMutate that atomically checks if a row matches the specified condition.
- checkAndMutate(List<CheckAndMutate>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Batch version of checkAndMutate.
- CheckAndMutate - Class in org.apache.hadoop.hbase.client
-
Used to perform CheckAndMutate operations.
- checkAndMutate(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Table
-
- checkAndMutate(byte[], Filter) - Method in interface org.apache.hadoop.hbase.client.Table
-
- checkAndMutate(CheckAndMutate) - Method in interface org.apache.hadoop.hbase.client.Table
-
checkAndMutate that atomically checks if a row matches the specified condition.
- checkAndMutate(List<CheckAndMutate>) - Method in interface org.apache.hadoop.hbase.client.Table
-
Batch version of checkAndMutate.
- CheckAndMutate.Builder - Class in org.apache.hadoop.hbase.client
-
A builder class for building a CheckAndMutate object.
- checkAndMutateAll(List<CheckAndMutate>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
A simple version of batch checkAndMutate.
- CheckAndMutateResult - Class in org.apache.hadoop.hbase.client
-
Represents a result of a CheckAndMutate operation
- CheckAndMutateResult(boolean, Result) - Constructor for class org.apache.hadoop.hbase.client.CheckAndMutateResult
-
- checkForAnd(byte[], int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Checks if the current index of filter string we are on is the beginning of the keyword 'AND'
- checkForOr(byte[], int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Checks if the current index of filter string we are on is the beginning of the keyword 'OR'
- checkForSkip(byte[], int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Checks if the current index of filter string we are on is the beginning of the keyword 'SKIP'
- checkForWhile(byte[], int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Checks if the current index of filter string we are on is the beginning of the keyword 'WHILE'
- checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat
-
- checkOutputSpecs(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
-
- checkOutputSpecs(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
Checks if the output table exists and is enabled.
- checkSizeAndGrow(int) - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
-
- CHECKSUM_TYPE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
The name of the configuration parameter that specifies the name of an algorithm that is used to
compute checksums for newly created blocks.
- checksumRows(Table) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Return an md5 digest of the entire contents of a table.
- CHORE_SERVICE_PREFIX - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
-
- Cipher - Class in org.apache.hadoop.hbase.io.crypto
-
A common interface for a cryptographic algorithm.
- Cipher(CipherProvider) - Constructor for class org.apache.hadoop.hbase.io.crypto.Cipher
-
- CIPHER_AES - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default cipher for encryption
- CipherProvider - Interface in org.apache.hadoop.hbase.io.crypto
-
An CipherProvider contributes support for various cryptographic Ciphers.
- classifyExs(List<Throwable>) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- CLASSNAME_KEY - Static variable in interface org.apache.hadoop.hbase.client.BufferedMutator
-
- cleanerChoreSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Enable/Disable the cleaner chore.
- cleanerChoreSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Turn the cleaner chore on/off.
- cleanRestoreDir(Job, String) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat
-
clean restore directory after snapshot scan job
- cleanupDataTestDirOnTestFS() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Cleans the test data directory on the test filesystem.
- cleanupDataTestDirOnTestFS(String) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Cleans a subdirectory under the test data directory on the test filesystem.
- cleanupJob(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- cleanupTestDir() - Method in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
Deprecated.
Returns True if we removed the test dirs
- cleanupTestDir(String) - Method in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
Deprecated.
- cleanupTestDir() - Method in class org.apache.hadoop.hbase.HBaseZKTestingUtility
-
Deprecated.
Returns True if we removed the test dirs
- clear() - Method in interface org.apache.hadoop.hbase.CellBuilder
-
Remove all internal elements from builder.
- clearBlockCache(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Clear all the blocks corresponding to this table from BlockCache.
- clearBlockCache(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Clear all the blocks corresponding to this table from BlockCache.
- clearCompactionQueues(ServerName, Set<String>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Clear compacting queues on a regionserver.
- clearCompactionQueues(ServerName, Set<String>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Clear compacting queues on a region server.
- clearDeadServers(List<ServerName>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Clear dead region servers from master.
- clearDeadServers(List<ServerName>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Clear dead region servers from master.
- clearRegionLocationCache() - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Clear all the entries in the region location cache, for all the tables.
- clearRegionLocationCache() - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Clear all the entries in the region location cache.
- clearRegionLocationCache() - Method in interface org.apache.hadoop.hbase.client.Connection
-
Clear all the entries in the region location cache, for all the tables.
- clearRegionLocationCache() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Clear all the entries in the region location cache.
- clearSlowLogResponses(Set<ServerName>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Clears online slow/large RPC logs from the provided list of RegionServers
- clearSlowLogResponses(Set<ServerName>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Clears online slow RPC logs from the provided list of RegionServers
- Client - Class in org.apache.hadoop.hbase.rest.client
-
A wrapper around HttpClient which provides some useful function and semantics for interacting
with the REST gateway.
- Client() - Constructor for class org.apache.hadoop.hbase.rest.client.Client
-
Default Constructor
- Client(Cluster) - Constructor for class org.apache.hadoop.hbase.rest.client.Client
-
Constructor
- Client(Cluster, boolean) - Constructor for class org.apache.hadoop.hbase.rest.client.Client
-
Constructor
- Client(Cluster, Configuration, boolean) - Constructor for class org.apache.hadoop.hbase.rest.client.Client
-
Constructor
- Client(Cluster, String, Optional<String>, Optional<String>) - Constructor for class org.apache.hadoop.hbase.rest.client.Client
-
Constructor, allowing to define custom trust store (only for SSL connections)
- Client(Cluster, Configuration, String, Optional<String>, Optional<String>) - Constructor for class org.apache.hadoop.hbase.rest.client.Client
-
Constructor, allowing to define custom trust store (only for SSL connections)
- CLIENT_CONNECTION_REGISTRY_IMPL_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Registry implementation to be used on the client side.
- CLIENT_PORT_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The ZK client port key in the ZK properties map.
- CLIENT_ZOOKEEPER_CLIENT_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Client port of ZooKeeper for client to locate meta
- CLIENT_ZOOKEEPER_OBSERVER_MODE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Indicate whether the client ZK are observer nodes of the server ZK
- CLIENT_ZOOKEEPER_QUORUM - Static variable in class org.apache.hadoop.hbase.HConstants
-
Name of ZooKeeper quorum configuration parameter for client to locate meta.
- ClientBackoffPolicy - Interface in org.apache.hadoop.hbase.client.backoff
-
Configurable policy for the amount of time a client should wait for a new request to the server
when given the server load statistics.
- ClockOutOfSyncException - Exception in org.apache.hadoop.hbase
-
This exception is thrown by the master when a region server clock skew is too high.
- ClockOutOfSyncException(String) - Constructor for exception org.apache.hadoop.hbase.ClockOutOfSyncException
-
- clone() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- cloneFamily(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- cloneIfNecessary(ArrayList<Cell>) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- cloneIfNecessary(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- cloneQualifier(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- cloneRow(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
get individual arrays for tests
- cloneSnapshot(String, TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create a new table by cloning the snapshot content.
- cloneSnapshot(String, TableName, boolean, String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create a new table by cloning the snapshot content.
- cloneSnapshot(String, TableName, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create a new table by cloning the snapshot content.
- cloneSnapshot(String, TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Create a new table by cloning the snapshot content.
- cloneSnapshot(String, TableName, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Create a new table by cloning the snapshot content.
- cloneSnapshot(String, TableName, boolean, String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Create a new table by cloning the snapshot content.
- cloneSnapshotAsync(String, TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create a new table by cloning the snapshot content, but does not block and wait for it to be
completely cloned.
- cloneSnapshotAsync(String, TableName, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create a new table by cloning the snapshot content.
- cloneSnapshotAsync(String, TableName, boolean, String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create a new table by cloning the snapshot content.
- cloneTableSchema(TableName, TableName, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create a new table by cloning the existent table schema.
- cloneTableSchema(TableName, TableName, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Create a new table by cloning the existent table schema.
- cloneValue(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- close() - Method in interface org.apache.hadoop.hbase.client.Admin
-
- close() - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutator
-
- close() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
- close() - Method in interface org.apache.hadoop.hbase.client.Connection
-
- close() - Method in interface org.apache.hadoop.hbase.client.ResultScanner
-
Closes the scanner and releases any resources it has allocated
- close() - Method in interface org.apache.hadoop.hbase.client.Table
-
Releases any resources held or pending changes in internal buffers.
- close() - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.
Closes all the resources held open for this cluster.
- close() - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
-
- close() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- close() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- close() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
Closes the split.
- close() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
Closes the split.
- close() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- close() - Method in class org.apache.hadoop.hbase.quotas.QuotaRetriever
-
- close() - Method in class org.apache.hadoop.hbase.util.RegionMover
-
- closeConnection() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- closeRegionAndWAL(Region) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Close both the region r
and it's underlying WAL.
- closeRegionAndWAL(HRegion) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Close both the HRegion r
and it's underlying WAL.
- closeTable() - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
- closeTable() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- Cluster - Class in org.apache.hadoop.hbase.rest.client
-
A list of 'host:port' addresses of HTTP servers operating as a single entity, for example
multiple redundant web service gateways.
- Cluster() - Constructor for class org.apache.hadoop.hbase.rest.client.Cluster
-
Constructor
- Cluster(List<String>) - Constructor for class org.apache.hadoop.hbase.rest.client.Cluster
-
Constructor
- CLUSTER_DISTRIBUTED - Static variable in class org.apache.hadoop.hbase.HConstants
-
Cluster is in distributed mode or not
- CLUSTER_ID_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default value for cluster ID
- CLUSTER_ID_FILE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
name of the file for unique cluster ID
- CLUSTER_IS_LOCAL - Static variable in class org.apache.hadoop.hbase.HConstants
-
Cluster is standalone or pseudo-distributed
- ClusterMetrics - Interface in org.apache.hadoop.hbase
-
Metrics information on the HBase cluster.
- clusterTestDir - Variable in class org.apache.hadoop.hbase.HBaseZKTestingUtility
-
Deprecated.
Directory (a subdirectory of dataTestDir) used by the dfs cluster if any
- cmp(int) - Method in enum org.apache.hadoop.hbase.util.Order
-
Returns the adjusted trichotomous value according to the ordering imposed by this
Order
.
- colFamTimeRangeMap - Variable in class org.apache.hadoop.hbase.client.Query
-
- COLON - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for colon (:)
- COLUMN_LIST - Static variable in class org.apache.hadoop.hbase.mapred.TableInputFormat
-
space delimited list of columns
- ColumnCountGetFilter - Class in org.apache.hadoop.hbase.filter
-
Simple filter that returns first N columns on row only.
- ColumnCountGetFilter(int) - Constructor for class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
- columnFamily - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- columnFamily - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- ColumnFamilyDescriptor - Interface in org.apache.hadoop.hbase.client
-
An ColumnFamilyDescriptor contains information about a column family such as the number of
versions, compression settings, etc.
- ColumnFamilyDescriptorBuilder - Class in org.apache.hadoop.hbase.client
-
- ColumnPaginationFilter - Class in org.apache.hadoop.hbase.filter
-
A filter, based on the ColumnCountGetFilter, takes two arguments: limit and offset.
- ColumnPaginationFilter(int, int) - Constructor for class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
Initializes filter with an integer offset and limit.
- ColumnPaginationFilter(int, byte[]) - Constructor for class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
Initializes filter with a string/bookmark based offset and limit.
- ColumnPrefixFilter - Class in org.apache.hadoop.hbase.filter
-
This filter is used for selecting only those keys with columns that matches a particular prefix.
- ColumnPrefixFilter(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
- columnQualifier - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- columnQualifier - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- ColumnRangeFilter - Class in org.apache.hadoop.hbase.filter
-
This filter is used for selecting only those keys with columns that are between minColumn to
maxColumn.
- ColumnRangeFilter(byte[], boolean, byte[], boolean) - Constructor for class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
Create a filter to select those keys with columns that are between minColumn and maxColumn.
- COLUMNS - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- columns - Variable in class org.apache.hadoop.hbase.mapred.GroupingTableMap
-
- columns - Variable in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
The grouping columns.
- COLUMNS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- ColumnValueFilter - Class in org.apache.hadoop.hbase.filter
-
- ColumnValueFilter(byte[], byte[], CompareOperator, byte[]) - Constructor for class org.apache.hadoop.hbase.filter.ColumnValueFilter
-
- ColumnValueFilter(byte[], byte[], CompareOperator, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.ColumnValueFilter
-
- combineTableNameSuffix(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
- COMMA - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for a comma
- commitTask(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- compact(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Compact a table.
- compact(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Compact a column family within a table.
- compact(TableName, CompactType) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Compact a table.
- compact(TableName, byte[], CompactType) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Compact a column family within a table.
- compact(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Compact a table.
- compact(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Compact a column family within a table.
- compact(TableName, CompactType) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Compact a table.
- compact(TableName, byte[], CompactType) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Compact a column family within a table.
- compact(boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Compact all regions in the mini hbase cluster
- compact(TableName, boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Compact all of a table's reagion in the mini hbase cluster
- compact(boolean) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
Call flushCache on all regions on all participating regionservers.
- compact(TableName, boolean) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
Call flushCache on all regions of the specified table.
- COMPACTION_ENABLED - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Used by HBase Shell interface to access this metadata attribute which denotes if the table is
compaction enabled.
- COMPACTION_KV_MAX - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for the maximum batch of KVs to be used in flushes and compactions
- COMPACTION_KV_MAX_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- COMPACTION_SCANNER_SIZE_MAX - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for the scanner size limit to be used in compactions
- COMPACTION_SCANNER_SIZE_MAX_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- CompactionState - Enum in org.apache.hadoop.hbase.client
-
POJO representing the compaction state
- compactionSwitch(boolean, List<String>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Turn the compaction on or off.
- compactionSwitch(boolean, List<String>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Turn the compaction on or off.
- compactRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Compact an individual region.
- compactRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Compact a column family within a region.
- compactRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Compact an individual region.
- compactRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Compact a column family within a region.
- compactRegionServer(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Compact all regions on the region server.
- compactRegionServer(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Compact all regions on the region server.
- CompactType - Enum in org.apache.hadoop.hbase.client
-
Currently, there are only two compact types: NORMAL
means do store files compaction;
MOB
means do mob files compaction.
- COMPARATOR - Static variable in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- COMPARATOR - Static variable in interface org.apache.hadoop.hbase.client.RegionInfo
-
- COMPARATOR - Static variable in interface org.apache.hadoop.hbase.client.Row
-
- COMPARATOR - Static variable in interface org.apache.hadoop.hbase.client.TableDescriptor
-
- comparator - Variable in class org.apache.hadoop.hbase.filter.CompareFilter
-
- comparator - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- Comparator() - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable.Comparator
-
- COMPARATOR_IGNORE_REPLICATION - Static variable in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- COMPARATOR_IGNORE_REPLICATION - Static variable in interface org.apache.hadoop.hbase.client.TableDescriptor
-
- compare(Cell, Cell) - Method in interface org.apache.hadoop.hbase.CellComparator
-
Lexographically compares two cells.
- compare(Cell, Cell, boolean) - Method in interface org.apache.hadoop.hbase.CellComparator
-
Compare cells.
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable.Comparator
-
- compare(long) - Method in class org.apache.hadoop.hbase.io.TimeRange
-
Compare the timestamp to timerange.
- compare(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.Bytes.ByteArrayComparator
-
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.Bytes.ByteArrayComparator
-
- compare(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.Bytes.RowEndKeyComparator
-
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.Bytes.RowEndKeyComparator
-
- compareColumns(Cell, byte[], int, int, int, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Compares the cell's column (family and qualifier) with the given byte[]
- compareFamilies(Cell, Cell) - Method in interface org.apache.hadoop.hbase.CellComparator
-
Lexicographically compares the families of the two cells
- compareFamilies(Cell, byte[], int, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Compares the cell's family with the given byte[]
- compareFamily(CompareOperator, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- CompareFilter - Class in org.apache.hadoop.hbase.filter
-
This is a generic filter to be used to filter by comparison.
- CompareFilter(CompareOperator, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.CompareFilter
-
Constructor.
- CompareOperator - Enum in org.apache.hadoop.hbase
-
Generic set of comparison operators.
- compareQualifier(CompareOperator, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- compareQualifiers(Cell, Cell) - Method in interface org.apache.hadoop.hbase.CellComparator
-
Lexicographically compares the qualifiers of the two cells
- compareQualifiers(Cell, byte[], int, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Compares the cell's qualifier with the given byte[]
- compareResults(Result, Result) - Static method in class org.apache.hadoop.hbase.client.Result
-
Does a deep comparison of two Results, down to the byte arrays.
- compareResults(Result, Result, boolean) - Static method in class org.apache.hadoop.hbase.client.Result
-
Does a deep comparison of two Results, down to the byte arrays.
- compareRow(CompareOperator, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- compareRows(Cell, Cell) - Method in interface org.apache.hadoop.hbase.CellComparator
-
Lexographically compares the rows of two cells.
- compareRows(Cell, byte[], int, int) - Method in interface org.apache.hadoop.hbase.CellComparator
-
Compares the row part of the cell with a simple plain byte[] like the stopRow in Scan.
- compareRows(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.CellComparator
-
Compares two row bytes
- compareRows(ByteBuffer, Cell) - Method in interface org.apache.hadoop.hbase.CellComparator
-
Lexicographically compare two rows
- compareTimestamps(Cell, Cell) - Method in interface org.apache.hadoop.hbase.CellComparator
-
Compares cell's timestamps in DESCENDING order.
- compareTimestamps(long, long) - Method in interface org.apache.hadoop.hbase.CellComparator
-
Compares cell's timestamps in DESCENDING order.
- compareTo(RegionInfo) - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.BigDecimalComparator
-
- compareTo(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.filter.BigDecimalComparator
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.BinaryComparator
-
- compareTo(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.filter.BinaryComparator
-
- compareTo(byte[]) - Method in class org.apache.hadoop.hbase.filter.BinaryComponentComparator
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.BinaryComponentComparator
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.BinaryPrefixComparator
-
- compareTo(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.filter.BinaryPrefixComparator
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.BitComparator
-
- compareTo(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.filter.BitComparator
-
- compareTo(byte[]) - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
-
Special compareTo method for subclasses, to avoid copying byte[] unnecessarily.
- compareTo(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
-
Special compareTo method for subclasses, to avoid copying bytes unnecessarily.
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.LongComparator
-
- compareTo(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.filter.LongComparator
-
- compareTo(byte[]) - Method in class org.apache.hadoop.hbase.filter.NullComparator
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.NullComparator
-
- compareTo(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.filter.NullComparator
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.SubstringComparator
-
- compareTo(HRegionLocation) - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- compareTo(ImmutableBytesWritable) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Define the sort order of the BytesWritable.
- compareTo(byte[]) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Compares the bytes in this object to the specified byte array
- compareTo(TableSplit) - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
- compareTo(TableSplit) - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Compares this split against the given one.
- compareTo(Address) - Method in class org.apache.hadoop.hbase.net.Address
-
- compareTo(ServerName) - Method in class org.apache.hadoop.hbase.ServerName
-
- compareTo(Size) - Method in class org.apache.hadoop.hbase.Size
-
- compareTo(TableName) - Method in class org.apache.hadoop.hbase.TableName
-
- compareTo(Bytes) - Method in class org.apache.hadoop.hbase.util.Bytes
-
Define the sort order of the Bytes.
- compareTo(byte[]) - Method in class org.apache.hadoop.hbase.util.Bytes
-
Compares the bytes in this object to the specified byte array
- compareTo(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Lexicographically compare two arrays.
- compareTo(byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Lexicographically compare two arrays.
- compareValue(CompareOperator, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- compareVersion(String, String) - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
- compareWithoutRow(Cell, Cell) - Method in interface org.apache.hadoop.hbase.CellComparator
-
Lexicographically compares the two cells excluding the row part.
- COMPRESS_TAGS - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- COMPRESSION - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- Compression.Algorithm - Enum in org.apache.hadoop.hbase.io.compress
-
Compression algorithms.
- COMPRESSION_ALGORITHMS - Static variable in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
Deprecated.
Compression algorithms to use in testing
- COMPRESSION_ALGORITHMS_PARAMETERIZED - Static variable in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
Deprecated.
Compression algorithms to use in parameterized JUnit 4 tests
- COMPRESSION_COMPACT - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- COMPRESSION_COMPACT_MAJOR - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- COMPRESSION_COMPACT_MINOR - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- COMPRESSION_OVERRIDE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
- computeCryptoKeyHash(Configuration, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Returns the hash of the supplied argument, using the hash algorithm specified in the given
config.
- computeDelta(TableDescriptor, TableDescriptor) - Static method in class org.apache.hadoop.hbase.client.TableDescriptorUtils
-
Compares two
TableDescriptor
and indicate which columns were added, deleted, or
modified from oldTD to newTD
- ConcurrentTableModificationException - Exception in org.apache.hadoop.hbase
-
Thrown when a table has been modified concurrently
- ConcurrentTableModificationException() - Constructor for exception org.apache.hadoop.hbase.ConcurrentTableModificationException
-
default constructor
- ConcurrentTableModificationException(String) - Constructor for exception org.apache.hadoop.hbase.ConcurrentTableModificationException
-
Constructor
- ConcurrentTableModificationException(byte[]) - Constructor for exception org.apache.hadoop.hbase.ConcurrentTableModificationException
-
- ConcurrentTableModificationException(TableName) - Constructor for exception org.apache.hadoop.hbase.ConcurrentTableModificationException
-
- conf - Variable in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.
- conf - Variable in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
Deprecated.
- conf - Variable in class org.apache.hadoop.hbase.ipc.PluggableBlockingQueue
-
- conf - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
- conf() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
-
- CONF_DEST_PREFIX - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
Configuration prefix for overrides for the destination filesystem
- CONF_SKIP_TMP - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- CONF_SOURCE_PREFIX - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
Configuration prefix for overrides for the source filesystem
- CONFIG - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
-
Denotes class names that appear in user facing configuration files.
- CONFIGURATION - Static variable in class org.apache.hadoop.hbase.HConstants
-
- ConfigurationUtil - Class in org.apache.hadoop.hbase.util
-
Utilities for storing more complex collection types in
Configuration
instances.
- configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
-
- configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.HRegionPartitioner
-
- configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormat
-
- configureCfRenaming(Configuration, Map<String, String>) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
-
Sets a configuration property with key
Import.CF_RENAME_PROP
in conf that tells the mapper
how to rename column families.
- configureIncrementalLoad(Job, Table, RegionLocator) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
Configure a MapReduce Job to perform an incremental load into the given table.
- configureIncrementalLoad(Job, TableDescriptor, RegionLocator) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
Configure a MapReduce Job to perform an incremental load into the given table.
- configureIncrementalLoad(Job, List<HFileOutputFormat2.TableInfo>) - Static method in class org.apache.hadoop.hbase.mapreduce.MultiTableHFileOutputFormat
-
- configureIncrementalLoadMap(Job, TableDescriptor) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
- configureRemoteCluster(Job, Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
Configure HBase cluster key for remote cluster to load region location for locality-sensitive
if it's enabled.
- configureSplitTable(Job, TableName) - Static method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Sets split table in map-reduce job.
- Connection - Interface in org.apache.hadoop.hbase.client
-
A cluster connection encapsulating lower level individual connections to actual servers and a
connection to zookeeper.
- ConnectionClosedException - Exception in org.apache.hadoop.hbase.exceptions
-
Thrown when the connection is closed
- ConnectionClosedException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.ConnectionClosedException
-
- ConnectionClosedException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.ConnectionClosedException
-
ConnectionClosedException with cause
- ConnectionClosingException - Exception in org.apache.hadoop.hbase.exceptions
-
Thrown when the client believes that we are trying to communicate to has been repeatedly
unresponsive for a while.
- ConnectionClosingException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.ConnectionClosingException
-
- ConnectionClosingException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.ConnectionClosingException
-
ConnectionClosingException with cause
- ConnectionFactory - Class in org.apache.hadoop.hbase.client
-
A non-instantiable class that manages creation of
Connection
s.
- ConnectionFactory() - Constructor for class org.apache.hadoop.hbase.client.ConnectionFactory
-
No public c.tors
- Consistency - Enum in org.apache.hadoop.hbase.client
-
Consistency defines the expected consistency level for an operation.
- consistency - Variable in class org.apache.hadoop.hbase.client.Query
-
- Constants - Interface in org.apache.hadoop.hbase.rest
-
Common constants for org.apache.hadoop.hbase.rest
- contains(byte[], byte) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Return true if target is present as an element anywhere in the given array.
- contains(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Return true if target is present as an element anywhere in the given array.
- containsColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Checks for existence of a value for the specified column (empty or not).
- containsColumn(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
-
Checks for existence of a value for the specified column (empty or not).
- containsEmptyColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Checks if the specified column contains an empty value (a zero-length byte array).
- containsEmptyColumn(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
-
Checks if the specified column contains an empty value (a zero-length byte array).
- containsNonEmptyColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Checks if the specified column contains a non-empty value (not a zero-length byte array).
- containsNonEmptyColumn(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
-
Checks if the specified column contains a non-empty value (not a zero-length byte array).
- containsRange(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns true if the given inclusive range of rows is fully contained by this region.
- containsRow(byte[]) - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns true if the given row falls in this region.
- containsServer(Address) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
Returns true if a server with hostPort is found
- containsTable(TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
- Context - Class in org.apache.hadoop.hbase.io.crypto
-
Crypto context.
- convertByteArrayToBoolean(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Converts a boolean expressed in a byte array to an actual boolean
- convertByteArrayToInt(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Converts an int expressed in a byte array to an actual int
- convertByteArrayToLong(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Converts a long expressed in a byte array to an actual long
- convertScanToString(Scan) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Writes the given scan into a Base64 encoded string.
- convertStringToScan(String) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Converts the given Base64 string back into a Scan instance.
- COPROC - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
-
- CoprocessorDescriptor - Interface in org.apache.hadoop.hbase.client
-
CoprocessorDescriptor contains the details about how to build a coprocessor.
- CoprocessorDescriptorBuilder - Class in org.apache.hadoop.hbase.client
-
- CoprocessorException - Exception in org.apache.hadoop.hbase.coprocessor
-
Thrown if a coprocessor encounters any exception.
- CoprocessorException() - Constructor for exception org.apache.hadoop.hbase.coprocessor.CoprocessorException
-
Default Constructor
- CoprocessorException(Class<?>, String) - Constructor for exception org.apache.hadoop.hbase.coprocessor.CoprocessorException
-
Constructor with a Class object and exception message.
- CoprocessorException(String) - Constructor for exception org.apache.hadoop.hbase.coprocessor.CoprocessorException
-
Constructs the exception and supplies a string as the message
- CoprocessorRpcChannel - Interface in org.apache.hadoop.hbase.ipc
-
- coprocessorService() - Method in interface org.apache.hadoop.hbase.client.Admin
-
- coprocessorService(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- coprocessorService(Function<RpcChannel, S>, ServiceCaller<S, R>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Execute the given coprocessor call on the master.
- coprocessorService(Function<RpcChannel, S>, ServiceCaller<S, R>, ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Execute the given coprocessor call on the given region server.
- coprocessorService(Function<RpcChannel, S>, ServiceCaller<S, R>, byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Execute the given coprocessor call on the region which contains the given row
.
- coprocessorService(Function<RpcChannel, S>, ServiceCaller<S, R>, AsyncTable.CoprocessorCallback<R>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Execute a coprocessor call on the regions which are covered by a range.
- coprocessorService(byte[]) - Method in interface org.apache.hadoop.hbase.client.Table
-
- coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>) - Method in interface org.apache.hadoop.hbase.client.Table
-
- coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>, Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.Table
-
- coprocessorServiceOnAllRegionServers(AsyncAdmin, Function<RpcChannel, S>, ServiceCaller<S, R>) - Static method in class org.apache.hadoop.hbase.client.AsyncAdminClientUtils
-
Execute the given coprocessor call on all region servers.
- copy(ColumnFamilyDescriptor) - Static method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- copy(TableDescriptor) - Static method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- copy(TableName, TableDescriptor) - Static method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- copy(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Copy the byte array given in parameter and return an instance of a new byte array with the same
length and the same content.
- copy(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Copy the byte array given in parameter and return an instance of a new byte array with the same
length and the same content.
- copyBytes() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Returns a copy of the bytes referred to by this writable
- copyBytes() - Method in class org.apache.hadoop.hbase.util.Bytes
-
Returns a copy of the bytes referred to by this writable
- copyFamilyTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Copies the family to the given byte[]
- copyFamilyTo(Cell, ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Copies the family to the given bytebuffer
- copyFrom(Result) - Method in class org.apache.hadoop.hbase.client.Result
-
Copy another Result into this one.
- copyQualifierTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Copies the qualifier to the given byte[]
- copyQualifierTo(Cell, ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Copies the qualifier to the given bytebuffer
- copyRow(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Copies the row to a new byte[]
- copyRowTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Copies the row to the given byte[]
- copyRowTo(Cell, ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Copies the row to the given bytebuffer
- CopyTable - Class in org.apache.hadoop.hbase.mapreduce
-
Tool used to copy a table to another one which can be on a different setup.
- CopyTable() - Constructor for class org.apache.hadoop.hbase.mapreduce.CopyTable
-
- copyToNewArrays(Collection<ByteRange>) - Static method in class org.apache.hadoop.hbase.util.ByteRangeUtils
-
- copyValueTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Copies the value to the given byte[]
- copyValueTo(Cell, ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Copies the value to the given bytebuffer
- CORRUPT_DIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
- CorruptedSnapshotException - Exception in org.apache.hadoop.hbase.snapshot
-
Exception thrown when the found snapshot info from the filesystem is not valid.
- CorruptedSnapshotException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.snapshot.CorruptedSnapshotException
-
Snapshot was corrupt for some reason.
- CorruptedSnapshotException(String, SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.CorruptedSnapshotException
-
Snapshot was corrupt for some reason.
- CorruptedSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.CorruptedSnapshotException
-
Snapshot was corrupt for some reason.
- countRows(Table) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Return the number of rows in the given table.
- countRows(Table, Scan) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- countRows(Table, byte[]...) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- countRows(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Return the number of rows in the given table.
- countRows(Region) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- countRows(Region, Scan) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- countRows(InternalScanner) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- countServedRegions() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
Counts the total numbers of regions being served by the currently online region servers by
asking each how many regions they have.
- CP_HTD_ATTR_INCLUSION_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
- create(CellBuilderType) - Static method in class org.apache.hadoop.hbase.CellBuilderFactory
-
Create a CellBuilder instance.
- create(Configuration) - Static method in class org.apache.hadoop.hbase.client.RequestControllerFactory
-
- create(List<Cell>) - Static method in class org.apache.hadoop.hbase.client.Result
-
Instantiate a Result with the specified List of KeyValues.
- create(List<Cell>, Boolean) - Static method in class org.apache.hadoop.hbase.client.Result
-
- create(List<Cell>, Boolean, boolean) - Static method in class org.apache.hadoop.hbase.client.Result
-
- create(List<Cell>, Boolean, boolean, boolean) - Static method in class org.apache.hadoop.hbase.client.Result
-
- create(Cell[]) - Static method in class org.apache.hadoop.hbase.client.Result
-
Instantiate a Result with the specified array of KeyValues.
- create(Cell[], Boolean, boolean) - Static method in class org.apache.hadoop.hbase.client.Result
-
- create(Cell[], Boolean, boolean, boolean) - Static method in class org.apache.hadoop.hbase.client.Result
-
- create() - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
Creates a Configuration with HBase resources
- create(Configuration) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
Creates a Configuration with HBase resources
- create(byte[], int, int, byte[], int, int, byte[], int, int, long, byte[], int, int) - Method in class org.apache.hadoop.hbase.mapreduce.CellCreator
-
- create(byte[], int, int, byte[], int, int, byte[], int, int, long, byte[], int, int, String) - Method in class org.apache.hadoop.hbase.mapreduce.CellCreator
-
- create(byte[], int, int, byte[], int, int, byte[], int, int, long, byte[], int, int, List<Tag>) - Method in class org.apache.hadoop.hbase.mapreduce.CellCreator
-
- create(String) - Static method in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- create(NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- create(UserGroupInformation) - Static method in class org.apache.hadoop.hbase.security.User
-
Wraps an underlying UserGroupInformation
instance.
- create(TestingHBaseClusterOption) - Static method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
- CREATE_TABLE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- createAsyncConnection() - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
- createAsyncConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
- createAsyncConnection(Configuration, User) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Create a new AsyncConnection instance using the passed conf
and user
.
- createAsyncConnection(Configuration, User, Map<String, byte[]>) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Create a new AsyncConnection instance using the passed conf
and user
.
- createCellScanner(List<? extends CellScannable>) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Returns CellScanner interface over cellIterables
- createCellScanner(Iterable<Cell>) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Returns CellScanner interface over cellIterable
- createCellScanner(Iterator<Cell>) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Returns CellScanner interface over cellIterable
or null if cells
is
null
- createCellScanner(Cell[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Returns CellScanner interface over cellArray
- createCellScanner(NavigableMap<byte[], List<Cell>>) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Flatten the map of cells out under the CellScanner
- createClusterConf(Configuration, String) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
Generates a Configuration
instance by applying the ZooKeeper cluster key to the base
Configuration.
- createClusterConf(Configuration, String, String) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
Generates a Configuration
instance by applying property overrides prefixed by a cluster
profile key to the base Configuration.
- createComparator(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Parses a comparator of the form comparatorType:comparatorValue form and returns a comparator
- createCompareOperator(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Takes a compareOperator symbol as a byte array and returns the corresponding CompareOperator
- createCompleteResult(Iterable<Result>) - Static method in class org.apache.hadoop.hbase.client.Result
-
Forms a single result from the partial results in the partialResults list.
- createCompositeKey(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.MultiTableHFileOutputFormat
-
Creates a composite key to use as a mapper output key when using
MultiTableHFileOutputFormat.configureIncrementaLoad to set up bulk ingest job
- createCompositeKey(byte[], ImmutableBytesWritable) - Static method in class org.apache.hadoop.hbase.mapreduce.MultiTableHFileOutputFormat
-
Alternate api which accepts an ImmutableBytesWritable for the suffix
- createCompositeKey(String, ImmutableBytesWritable) - Static method in class org.apache.hadoop.hbase.mapreduce.MultiTableHFileOutputFormat
-
Alternate api which accepts a String for the tableName and ImmutableBytesWritable for the
suffix
- createCompressionStream(OutputStream, Compressor, int) - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
- createConnection() - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Create a new Connection instance using default HBaseConfiguration.
- createConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Create a new Connection instance using the passed conf
instance.
- createConnection(Configuration, ExecutorService) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Create a new Connection instance using the passed conf
instance.
- createConnection(Configuration, User) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Create a new Connection instance using the passed conf
instance.
- createConnection(Configuration, ExecutorService, User) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Create a new Connection instance using the passed conf
instance.
- createConnection(Configuration, ExecutorService, User, Map<String, byte[]>) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Create a new Connection instance using the passed conf
instance.
- createCursorResult(Cursor) - Static method in class org.apache.hadoop.hbase.client.Result
-
- createDecompressionStream(InputStream, Decompressor, int) - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
- createDecryptionStream(InputStream, Context, byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Create a decrypting input stream given a context and IV
- createDecryptionStream(InputStream, Decryptor) - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Create a decrypting output stream given an initialized decryptor
- createDecryptionStream(InputStream) - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
-
Create a stream for decryption
- createEncryptionStream(OutputStream, Context, byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Create an encrypting output stream given a context and IV
- createEncryptionStream(OutputStream, Encryptor) - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Create an encrypting output stream given an initialized encryptor
- createEncryptionStream(OutputStream) - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
-
Create a stream for encryption
- createEventLoopPerClient(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.NettyRpcClientConfigHelper
-
The NettyRpcClient
will create its own NioEventLoopGroup
.
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
-
Creating this filter by reflection, it is used by
ParseFilter
,
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.FamilyFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.PageFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.PrefixFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.QualifierFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.RowFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ValueFilter
-
- createGroupKey(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
-
Create a key by concatenating multiple column values.
- createGroupKey(byte[][]) - Method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
Create a key by concatenating multiple column values.
- createKey() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- createKey() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- createLocalHRegion(TableDescriptor, byte[], byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create an HRegion that writes to the local tmp dirs
- createLocalHRegion(RegionInfo, TableDescriptor) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create an HRegion that writes to the local tmp dirs.
- createLocalHRegion(RegionInfo, Configuration, TableDescriptor, WAL) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create an HRegion that writes to the local tmp dirs with specified wal
- createLocalHRegion(TableName, byte[], byte[], Configuration, boolean, Durability, WAL, byte[]...) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- createLocalHRegionWithInMemoryFlags(TableName, byte[], byte[], Configuration, boolean, Durability, WAL, boolean[], byte[]...) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- createMaxByteArray(int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Create a max byte array with the specified max byte count
- createMobRegionInfo(TableName) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Creates a RegionInfo object for MOB data.
- createMockRegionServerService() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create a stubbed out RegionServerService, mainly for getting FS.
- createMockRegionServerService(RpcServerInterface) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create a stubbed out RegionServerService, mainly for getting FS.
- createMockRegionServerService(ServerName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create a stubbed out RegionServerService, mainly for getting FS.
- createModifyableTableDescriptor(String) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- createModifyableTableDescriptor(TableName, int, int, int, KeepDeletedCells) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- createMultiRegionsInMeta(Configuration, TableDescriptor, byte[][]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create rows in hbase:meta for regions of the specified table with the specified start keys.
- createMultiRegionTable(TableName, byte[], int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create a table with multiple regions.
- createMultiRegionTable(TableName, byte[][]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create a table with multiple regions.
- createMultiRegionTable(TableName, int, byte[][]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create a table with multiple regions.
- createMultiRegionTable(TableName, byte[][], int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create a table with multiple regions.
- createMultiRegionTable(TableName, byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create a table with multiple regions.
- createNamespace(NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create a new namespace.
- createNamespace(NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Create a new namespace.
- createNamespaceAsync(NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create a new namespace.
- createNInputSplitsUniform(InputSplit, int) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Create n splits for one InputSplit, For now only support uniform distribution
- createPlainCompressionStream(OutputStream, Compressor) - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
Creates a compression stream without any additional wrapping into buffering streams.
- createPreSplitLoadTestTable(Configuration, TableName, byte[], Compression.Algorithm, DataBlockEncoding) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Creates a pre-split table for load testing.
- createPreSplitLoadTestTable(Configuration, TableName, byte[], Compression.Algorithm, DataBlockEncoding, int, int, Durability) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Creates a pre-split table for load testing.
- createPreSplitLoadTestTable(Configuration, TableName, byte[][], Compression.Algorithm, DataBlockEncoding, int, int, Durability) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Creates a pre-split table for load testing.
- createPreSplitLoadTestTable(Configuration, TableDescriptor, ColumnFamilyDescriptor) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Creates a pre-split table for load testing.
- createPreSplitLoadTestTable(Configuration, TableDescriptor, ColumnFamilyDescriptor, int) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Creates a pre-split table for load testing.
- createPreSplitLoadTestTable(Configuration, TableDescriptor, ColumnFamilyDescriptor[], int) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Creates a pre-split table for load testing.
- createPreSplitLoadTestTable(Configuration, TableDescriptor, ColumnFamilyDescriptor[], RegionSplitter.SplitAlgorithm, int) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Creates a pre-split table for load testing.
- createRandomTable(TableName, Collection<String>, int, int, int, int, int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Creates a random table with the given parameters
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
-
Builds a TableRecordReader.
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat
-
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.WALInputFormat
-
- createRegionAndWAL(RegionInfo, Path, Configuration, TableDescriptor) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create a region with it's own WAL.
- createRegionAndWAL(RegionInfo, Path, Configuration, TableDescriptor, BlockCache) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create a region with it's own WAL.
- createRegionAndWAL(RegionInfo, Path, Configuration, TableDescriptor, MobFileCache) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create a region with it's own WAL.
- createRegionAndWAL(RegionInfo, Path, Configuration, TableDescriptor, boolean) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create a region with it's own WAL.
- createRegionName(TableName, byte[], long, boolean) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Make a region name of passed parameters.
- createRegionName(TableName, byte[], String, boolean) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Make a region name of passed parameters.
- createRegionName(TableName, byte[], long, int, boolean) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Make a region name of passed parameters.
- createRegionName(TableName, byte[], byte[], boolean) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Make a region name of passed parameters.
- createRegionName(TableName, byte[], byte[], int, boolean) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Make a region name of passed parameters.
- createRegionSizeCalculator(RegionLocator, Admin) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- createRootDir(boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Creates an hbase rootdir in user home directory.
- createRootDir() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- createScanFromConfiguration(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Sets up a
Scan
instance, applying settings from the configuration property constants
defined in
TableInputFormat
.
- createScanFromCursor(Cursor) - Static method in class org.apache.hadoop.hbase.client.Scan
-
Create a new Scan with a cursor.
- createSubDir(String, Path, String) - Method in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
Deprecated.
- createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.mapred.RowCounter
-
Returns the JobConf
- createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.CellCounter
-
Sets up the actual job.
- createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.CopyTable
-
Sets up the actual job.
- createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.Export
-
Sets up the actual job.
- createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
-
Sets up the actual job.
- createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
Sets up the actual job.
- createSubmittableJob(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.RowCounter
-
Sets up the actual job.
- createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.RowCounter
-
- createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.WALPlayer
-
Sets up the actual job.
- createTable(TableDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Creates a new table.
- createTable(TableDescriptor, byte[], byte[], int) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Creates a new table with the specified number of regions.
- createTable(TableDescriptor, byte[][]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Creates a new table with an initial set of empty regions defined by the specified split keys.
- createTable(TableDescriptor) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Creates a new table.
- createTable(TableDescriptor, byte[], byte[], int) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Creates a new table with the specified number of regions.
- createTable(TableDescriptor, byte[][]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Creates a new table with an initial set of empty regions defined by the specified split keys.
- createTable(TableName, String) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create a table.
- createTable(TableName, String[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create a table.
- createTable(TableName, byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create a table.
- createTable(TableName, byte[][]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create a table.
- createTable(TableName, byte[][], byte[][]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create a table.
- createTable(TableName, byte[][], byte[][], int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create a table.
- createTable(TableName, byte[][], int, byte[], byte[], int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- createTable(TableDescriptor, byte[][], Configuration) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create a table.
- createTable(TableDescriptor, byte[][], byte[][], Configuration) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create a table.
- createTable(TableDescriptor, byte[][], byte[][], BloomType, int, Configuration) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create a table.
- createTable(TableDescriptor, byte[][]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create a table.
- createTable(TableName, byte[][], byte[][], int, Configuration) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create a table.
- createTable(TableName, byte[], int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create a table.
- createTable(TableName, byte[][], int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create a table.
- createTable(TableName, byte[][], int, byte[][]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create a table.
- createTable(TableName, byte[][], int, int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create a table.
- createTable(TableName, byte[][], int, int, String) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- createTable(TableName, byte[][], int[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create a table.
- createTable(TableName, byte[], byte[][]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create a table.
- createTableAsync(TableDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Creates a new table but does not block and wait for it to come online.
- createTableAsync(TableDescriptor, byte[][]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Creates a new table but does not block and wait for it to come online.
- createTableDescriptor(TableName, int, int, int, KeepDeletedCells) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- createTableDescriptor(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create a table of name name
.
- createTableDescriptor(TableName, byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- createTableDescriptor(TableName, byte[][], int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- createTestRegion(String, ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- createTestRegion(String, ColumnFamilyDescriptor, BlockCache) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- createTreeSet() - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- createUnescapdArgument(byte[], int, int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Removes the single quote escaping a single quote - thus it returns an unescaped argument
- createUserForTesting(Configuration, String, String[]) - Static method in class org.apache.hadoop.hbase.security.User
-
Generates a new User
instance specifically for use in test code.
- createValue() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- createValue() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- createVisibilityExpTags(String) - Method in interface org.apache.hadoop.hbase.mapreduce.VisibilityExpressionResolver
-
Convert visibility expression into tags to be serialized.
- createWal(Configuration, Path, RegionInfo) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create an unmanaged WAL.
- createWALRootDir() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Creates a hbase walDir in the user's home directory.
- CREDENTIALS_LOCATION - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- CRLF - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- CRYPTO_ALTERNATE_KEY_ALGORITHM_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the name of the alternate cipher algorithm for the cluster, a string
- CRYPTO_CIPHERPROVIDER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the crypto algorithm provider, a class name
- CRYPTO_ENABLED_CONF_DEFAULT - Static variable in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Default value for globally enable / disable column family encryption (set to "true" for
backward compatibility)
- CRYPTO_ENABLED_CONF_KEY - Static variable in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Configuration key for globally enable / disable column family encryption
- CRYPTO_KEY_ALGORITHM_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the algorithm used for creating jks key, a string
- CRYPTO_KEY_FAIL_ON_ALGORITHM_MISMATCH_CONF_DEFAULT - Static variable in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Default behaviour is not to fail if the hash algorithm configured differs from the one used in
the HFile.
- CRYPTO_KEY_FAIL_ON_ALGORITHM_MISMATCH_CONF_KEY - Static variable in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Configuration key for specifying the behaviour if the configured hash algorithm differs from
the one used for generating key hash in encrypted HFiles currently being read.
- CRYPTO_KEY_HASH_ALGORITHM_CONF_DEFAULT - Static variable in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Default hash algorithm used for generating key hash in encrypted HFiles.
- CRYPTO_KEY_HASH_ALGORITHM_CONF_KEY - Static variable in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Configuration key for the hash algorithm used for generating key hash in encrypted HFiles.
- CRYPTO_KEYPROVIDER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the crypto key provider, a class name
- CRYPTO_KEYPROVIDER_PARAMETERS_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the crypto key provider parameters
- CRYPTO_MASTERKEY_ALTERNATE_NAME_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the name of the alternate master key for the cluster, a string
- CRYPTO_MASTERKEY_NAME_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the name of the master key for the cluster, a string
- CRYPTO_WAL_ALGORITHM_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the algorithm to use when encrypting the WAL, a string
- CRYPTO_WAL_KEY_NAME_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the name of the master WAL encryption key for the cluster, a string
- CryptoCipherProvider - Class in org.apache.hadoop.hbase.io.crypto
-
The default cipher provider.
- curBuf - Variable in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
-
- current() - Method in interface org.apache.hadoop.hbase.CellScanner
-
Returns the current Cell which may be mutable
- current() - Method in class org.apache.hadoop.hbase.client.Result
-
- cursor() - Method in interface org.apache.hadoop.hbase.client.AdvancedScanResultConsumer.ScanController
-
Get the scan cursor if available.
- Cursor - Class in org.apache.hadoop.hbase.client
-
- CUSTOM_FILTERS - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- D - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'D'
- DATA_BLOCK_ENCODING - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- DATA_FILE_UMASK_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
File permission umask to use when creating hbase data files
- DATABLOCK_ENCODING_OVERRIDE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
- DataBlockEncoding - Enum in org.apache.hadoop.hbase.io.encoding
-
Provide access to all data block encoding algorithms.
- DataType<T> - Interface in org.apache.hadoop.hbase.types
-
DataType
is the base class for all HBase data types.
- DAY_IN_SECONDS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Seconds in a day, hour and minute
- decode(PositionedByteRange) - Method in interface org.apache.hadoop.hbase.types.DataType
-
Read an instance of T
from the buffer src
.
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedBlob
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedBlobVar
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt16
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt32
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt64
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt8
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedString
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawByte
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawBytes
-
- decode(PositionedByteRange, int) - Method in class org.apache.hadoop.hbase.types.RawBytes
-
Read a byte[]
from the buffer src
.
- decode(PositionedByteRange, int) - Method in class org.apache.hadoop.hbase.types.RawBytesFixedLength
-
Read a byte[]
from the buffer src
.
- decode(PositionedByteRange, int) - Method in class org.apache.hadoop.hbase.types.RawBytesTerminated
-
Read a byte[]
from the buffer src
.
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawDouble
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawFloat
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawInteger
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawLong
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawShort
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawString
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Struct
-
- decode(PositionedByteRange, int) - Method in class org.apache.hadoop.hbase.types.Struct
-
Read the field at index
.
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
-
- decodeA(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Union2
-
Read an instance of the first type parameter from buffer src
.
- decodeB(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Union2
-
Read an instance of the second type parameter from buffer src
.
- decodeBlobCopy(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode a Blob value, byte-for-byte copy.
- decodeBlobVar(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode a blob value that was encoded using BlobVar encoding.
- decodeByte(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt8
-
Read a byte
value from the buffer src
.
- decodeByte(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawByte
-
Read a byte
value from the buffer buff
.
- decodeC(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Union3
-
Read an instance of the third type parameter from buffer src
.
- decodeD(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Union4
-
Read an instance of the fourth type parameter from buffer src
.
- decodeDouble(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
-
Read a double
value from the buffer src
.
- decodeDouble(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
-
Read a double
value from the buffer src
.
- decodeDouble(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawDouble
-
Read a double
value from the buffer buff
.
- decodeFloat(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
-
Read a float
value from the buffer dst
.
- decodeFloat(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawFloat
-
Read a float
value from the buffer buff
.
- decodeFloat32(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode a 32-bit floating point value using the fixed-length encoding.
- decodeFloat64(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode a 64-bit floating point value using the fixed-length encoding.
- decodeInt(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt32
-
Read an int
value from the buffer src
.
- decodeInt(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawInteger
-
Read an int
value from the buffer buff
.
- decodeInt16(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode an int16
value.
- decodeInt32(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode an int32
value.
- decodeInt64(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode an int64
value.
- decodeInt8(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode an int8
value.
- decodeLong(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt64
-
Read a long
value from the buffer src
.
- decodeLong(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
-
Read a long
value from the buffer src
.
- decodeLong(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawLong
-
Read a long
value from the buffer buff
.
- decodeNumericAsBigDecimal(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode a
BigDecimal
value from the variable-length encoding.
- decodeNumericAsDouble(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode a primitive double
value from the Numeric encoding.
- decodeNumericAsLong(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode a primitive long
value from the Numeric encoding.
- decodeShort(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt16
-
Read a short
value from the buffer src
.
- decodeShort(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawShort
-
Read a short
value from the buffer buff
.
- decodeString(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode a String value.
- decommissionRegionServers(List<ServerName>, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Mark region server(s) as decommissioned to prevent additional regions from getting assigned to
them.
- decommissionRegionServers(List<ServerName>, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Mark region server(s) as decommissioned to prevent additional regions from getting assigned to
them.
- decrypt(byte[], int, InputStream, int, Decryptor) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Decrypt a block of ciphertext read in from a stream with the given cipher and context
- decrypt(byte[], int, InputStream, int, Encryption.Context, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Decrypt a block of ciphertext from a stream given a context and IV
- decrypt(OutputStream, InputStream, int, Decryptor) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Decrypt a stream of ciphertext given a decryptor
- decrypt(OutputStream, InputStream, int, Encryption.Context, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Decrypt a stream of ciphertext given a context and IV
- Decryptor - Interface in org.apache.hadoop.hbase.io.crypto
-
Decryptors apply a cipher to an InputStream to recover plaintext.
- decryptWithSubjectKey(OutputStream, InputStream, int, String, Configuration, Cipher, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Decrypts a block of ciphertext with the symmetric key resolved for the given subject
- decTaskCounters(Collection<byte[]>, ServerName) - Method in interface org.apache.hadoop.hbase.client.RequestController
-
Decrement the counter if a task is accomplished.
- deepCopy() - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Create a new ByteRange
with new backing byte[] containing a copy of the content from
this
range's window.
- deepCopy() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- deepCopy() - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- deepCopy() - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
-
- deepCopy() - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- deepCopy() - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
- deepCopySubRangeTo(int, int, byte[], int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Wrapper for System.arraycopy.
- deepCopyTo(byte[], int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Wrapper for System.arraycopy.
- deepCopyToNewArray() - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Instantiate a new byte[] with exact length, which is at least 24 bytes + length.
- DEFAULT_BASE_TEST_DIRECTORY - Static variable in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
Deprecated.
Default base directory for test output.
- DEFAULT_BLOCKCACHE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default setting for whether to use a block cache or not.
- DEFAULT_BLOCKSIZE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default size of blocks in files stored to the filesytem (hfiles).
- DEFAULT_BLOCKSIZE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default block size for an HFile.
- DEFAULT_BLOOMFILTER - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default setting for whether or not to use bloomfilters.
- DEFAULT_CACHE_BLOOMS_ON_WRITE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default setting for whether to cache bloom filter blocks on write if block caching is enabled.
- DEFAULT_CACHE_DATA_ON_WRITE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default setting for whether to cache data blocks on write if block caching is enabled.
- DEFAULT_CACHE_INDEX_ON_WRITE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default setting for whether to cache index blocks on write if block caching is enabled.
- DEFAULT_CLIENT_ZOOKEEPER_OBSERVER_MODE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Assuming client zk not in observer mode and master need to synchronize information
- DEFAULT_CLUSTER_DISTRIBUTED - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default value for cluster distributed mode
- DEFAULT_CLUSTER_ID - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default cluster ID, cannot be used to identify a cluster so a key with this value means it
wasn't meant for replication.
- DEFAULT_COMPACTION_ENABLED - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Constant that denotes whether the table is compaction enabled by default
- DEFAULT_COMPRESS_TAGS - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default compress tags along with any type of DataBlockEncoding.
- DEFAULT_COMPRESSION - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default compression type.
- DEFAULT_DATA_BLOCK_ENCODING - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default data block encoding algorithm.
- DEFAULT_DFS_REPLICATION - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- DEFAULT_ENABLE_CLIENT_BACKPRESSURE - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_EVICT_BLOCKS_ON_CLOSE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default setting for whether to evict cached blocks from the blockcache on close.
- DEFAULT_EVICT_REMAIN_RATIO - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- DEFAULT_EXECUTOR_STATUS_COLLECT_ENABLED - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_GROUP - Static variable in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
- DEFAULT_HBASE_BALANCER_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default value for the balancer period
- DEFAULT_HBASE_CLIENT_MAX_PERREGION_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_CLIENT_MAX_PERSERVER_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_CLIENT_MAX_TOTAL_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_CLIENT_OPERATION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default HBase client operation timeout, which is tantamount to a blocking call
- DEFAULT_HBASE_CLIENT_PAUSE - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_CLIENT_PERSERVER_REQUESTS_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_CLIENT_RETRIES_NUMBER - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_CLIENT_SCANNER_ASYNC_PREFETCH - Static variable in class org.apache.hadoop.hbase.client.Scan
-
- DEFAULT_HBASE_CLIENT_SCANNER_CACHING - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_CLIENT_SCANNER_MAX_RESULT_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Maximum number of bytes returned when calling a scanner's next method.
- DEFAULT_HBASE_CLIENT_SCANNER_TIMEOUT_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_CLIENT_SERVERSIDE_RETRIES_MULTIPLIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_ENABLE_SEPARATE_CHILD_REGIONS - Static variable in class org.apache.hadoop.hbase.HConstants
-
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)
- DEFAULT_HBASE_MASTER_BALANCER_MAX_RIT_PERCENT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default value for the max percent of regions in transition
- DEFAULT_HBASE_META_BLOCK_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_META_SCANNER_CACHING - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_META_VERSIONS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_RPC_SHORTOPERATION_RETRY_PAUSE_TIME - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_RPC_SHORTOPERATION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_RPC_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_SERVER_PAUSE - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_SERVER_SCANNER_MAX_RESULT_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Maximum number of bytes returned when calling a scanner's next method.
- DEFAULT_HBASE_SPLIT_COORDINATED_BY_ZK - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_SPLIT_WAL_MAX_SPLITTER - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HEALTH_FAILURE_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HEALTH_SCRIPT_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HEAP_OCCUPANCY_HIGH_WATERMARK - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HEAP_OCCUPANCY_LOW_WATERMARK - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HOST - Static variable in class org.apache.hadoop.hbase.HConstants
-
default host address
- DEFAULT_HREGION_EDITS_REPLAY_SKIP_ERRORS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HREGION_MEMSTORE_BLOCK_MULTIPLIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default value for hbase.hregion.memstore.block.multiplier
- DEFAULT_HSTORE_OPEN_AND_CLOSE_THREADS_MAX - Static variable in class org.apache.hadoop.hbase.HConstants
-
The default number for the max number of threads used for opening and closing stores or store
files in parallel
- DEFAULT_IN_MEMORY - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default setting for whether to try and serve this column family from memory or not.
- DEFAULT_INDEX_BLOCK_ENCODING - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default index block encoding algorithm.
- DEFAULT_KEEP_DELETED - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default setting for preventing deleted from being collected immediately.
- DEFAULT_LISTEN_PORT - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- DEFAULT_LOSSY_COUNTING_ERROR_RATE - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_MAJOR_COMPACTION_JITTER - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_MAJOR_COMPACTION_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_MASTER_INFOPORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
default port for master web api
- DEFAULT_MASTER_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
default port that the master listens on
- DEFAULT_MASTER_TYPE_BACKUP - Static variable in class org.apache.hadoop.hbase.HConstants
-
by default every master is a possible primary master unless the conf explicitly overrides it
- DEFAULT_MATH_CONTEXT - Static variable in class org.apache.hadoop.hbase.util.OrderedBytes
-
- DEFAULT_MAX_AGE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- DEFAULT_MAX_BACKOFF - Static variable in class org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
-
- DEFAULT_MAX_FILE_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default maximum file size
- DEFAULT_MAX_VERSIONS - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default number of versions of a record to keep.
- DEFAULT_MEMSTORE_FLUSH_SIZE - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Constant that denotes the maximum default size of the memstore in bytes after which the
contents are flushed to the store files.
- DEFAULT_MERGE_ENABLED - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Constant that denotes whether the table is merge enabled by default
- DEFAULT_META_REPLICA_NUM - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_MIN_AGE_TO_ARCHIVE - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- DEFAULT_MIN_VERSIONS - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default is not to keep a minimum of versions.
- DEFAULT_MOB_CACHE_EVICT_PERIOD - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- DEFAULT_MOB_CLEANER_BATCH_SIZE_UPPER_BOUND - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- DEFAULT_MOB_CLEANER_PERIOD - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- DEFAULT_MOB_COMPACT_PARTITION_POLICY - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- DEFAULT_MOB_COMPACTION_BATCH_SIZE - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- DEFAULT_MOB_COMPACTION_CHORE_PERIOD - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- DEFAULT_MOB_COMPACTION_MAX_FILE_SIZE - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
Default maximum selection size = 1GB
- DEFAULT_MOB_COMPACTION_MERGEABLE_THRESHOLD - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- DEFAULT_MOB_COMPACTION_THREADS_MAX - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- DEFAULT_MOB_COMPACTION_TYPE - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- DEFAULT_MOB_DELFILE_MAX_COUNT - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- DEFAULT_MOB_DISCARD_MISS - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- DEFAULT_MOB_FILE_CACHE_SIZE - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- DEFAULT_MOB_MAJOR_COMPACTION_REGION_BATCH_SIZE - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
Default is 0 - means no limit - all regions of a MOB table will be compacted at once
- DEFAULT_MOB_THRESHOLD - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- DEFAULT_MOVE_RETRIES_MAX - Static variable in class org.apache.hadoop.hbase.util.RegionMover
-
- DEFAULT_MOVE_WAIT_MAX - Static variable in class org.apache.hadoop.hbase.util.RegionMover
-
- DEFAULT_NAMESPACE - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- DEFAULT_NAMESPACE_NAME - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
-
Default namespace name.
- DEFAULT_NAMESPACE_NAME_STR - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- DEFAULT_NEW_VERSION_BEHAVIOR - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- DEFAULT_ONLINE_LOG_PROVIDER_ENABLED - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_OVERALL_HREGION_FILES - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default overall region files
- DEFAULT_PREFETCH_BLOCKS_ON_OPEN - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- DEFAULT_READONLY - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Constant that denotes whether the table is READONLY by default and is false
- DEFAULT_REGION_MEMSTORE_REPLICATION - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- DEFAULT_REGION_REPLICATION - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- DEFAULT_REGION_SERVER_BULKLOAD_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_REGION_SERVER_HANDLER_ABORT_ON_ERROR_PERCENT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_REGION_SERVER_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_REGION_SERVER_HIGH_PRIORITY_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_REGION_SERVER_REPLICATION_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_REGIONS_PER_SERVER - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
The default number of regions per regionserver when creating a pre-split table.
- DEFAULT_REGIONS_RECOVERY_INTERVAL - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_REGIONSERVER_INFOPORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
default port for region server web api
- DEFAULT_REGIONSERVER_METRICS_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_REGIONSERVER_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default port region server listens on.
- DEFAULT_REPLICA_ID - Static variable in interface org.apache.hadoop.hbase.client.RegionInfo
-
- DEFAULT_REPLICATION_SCOPE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default scope.
- DEFAULT_REST_CLIENT_CONN_TIMEOUT - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- DEFAULT_REST_CLIENT_SOCKET_TIMEOUT - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- DEFAULT_RETRY_ATTEMPTS - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
-
- DEFAULT_RETRY_SLEEP_INTERVAL - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
-
- DEFAULT_SERVERSTART_WAIT_MAX - Static variable in class org.apache.hadoop.hbase.util.RegionMover
-
- DEFAULT_SHELL_TIMESTAMP_FORMAT_EPOCH - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_SHELL_USER - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
-
- DEFAULT_SLOW_LOG_RING_BUFFER_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_SLOW_LOG_SYS_TABLE_CHORE_DURATION - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_SLOW_LOG_SYS_TABLE_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_SNAPSHOT_RESTORE_FAILSAFE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_SNAPSHOT_RESTORE_TAKE_FAILSAFE_SNAPSHOT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_SNAPSHOT_TTL - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_SNAPSHOT_TTL_CONFIG_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_SPLIT_ENABLED - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Constant that denotes whether the table is split enabled by default
- DEFAULT_STATUS_MULTICAST_ADDRESS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_STATUS_MULTICAST_BIND_ADDRESS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_STATUS_MULTICAST_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_STATUS_MULTICAST_PUBLISHER_BIND_ADDRESS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_STORE_FILE_REF_COUNT_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_TEMPORARY_HDFS_DIRECTORY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Don't use it! This'll get you the wrong path in a secure cluster.
- DEFAULT_THREAD_WAKE_FREQUENCY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default value for thread wake frequency
- DEFAULT_TTL - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default time to live of cell contents.
- DEFAULT_USE_META_REPLICAS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_VERSION_FILE_WRITE_ATTEMPTS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for how often we should try to write a version file, before failing
- DEFAULT_WAL_STORAGE_POLICY - Static variable in class org.apache.hadoop.hbase.HConstants
-
By default we defer the WAL storage policy to HDFS
- DEFAULT_ZK_SESSION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default value for ZooKeeper session timeout
- DEFAULT_ZOOKEEPER_CLIENT_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default client port that the zookeeper listens on
- DEFAULT_ZOOKEEPER_MAX_CLIENT_CNXNS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default limit on concurrent client-side zookeeper connections
- DEFAULT_ZOOKEEPER_ZNODE_PARENT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DefaultCipherProvider - Class in org.apache.hadoop.hbase.io.crypto
-
The default cipher provider.
- defaultInstance() - Static method in class org.apache.hadoop.hbase.client.BalanceRequest
-
Get a BalanceRequest for a default run of the balancer.
- DEFER_TO_HDFS_STORAGE_POLICY - Static variable in class org.apache.hadoop.hbase.HConstants
-
"NONE" is not a valid storage policy and means we defer the policy to HDFS.
- delete(Delete) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Deletes the specified cells/row.
- delete(List<Delete>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Deletes the specified cells/rows in bulk.
- Delete - Class in org.apache.hadoop.hbase.client
-
Used to perform Delete operations on a single row.
- Delete(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Delete
-
Create a Delete operation for the specified row.
- Delete(byte[], long) - Constructor for class org.apache.hadoop.hbase.client.Delete
-
Create a Delete operation for the specified row and timestamp.
- Delete(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.client.Delete
-
Create a Delete operation for the specified row and timestamp.
- Delete(byte[], int, int, long) - Constructor for class org.apache.hadoop.hbase.client.Delete
-
Create a Delete operation for the specified row and timestamp.
- Delete(Delete) - Constructor for class org.apache.hadoop.hbase.client.Delete
-
Create a Delete operation using another Delete as template.
- Delete(byte[], long, NavigableMap<byte[], List<Cell>>) - Constructor for class org.apache.hadoop.hbase.client.Delete
-
Construct the Delete with user defined data.
- delete(Delete) - Method in interface org.apache.hadoop.hbase.client.Table
-
Deletes the specified cells/row.
- delete(List<Delete>) - Method in interface org.apache.hadoop.hbase.client.Table
-
Batch Deletes the specified cells/rows from the table.
- delete(String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a DELETE request
- delete(String, Header) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a DELETE request
- delete(Cluster, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a DELETE request
- delete(Cluster, String, Header) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a DELETE request
- deleteAll(List<Delete>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
A simple version of batch delete.
- deleteColumnFamily(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Delete a column family from a table.
- deleteColumnFamily(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Delete a column family from a table.
- deleteColumnFamilyAsync(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Delete a column family from a table.
- deleteNamespace(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Delete an existing namespace.
- deleteNamespace(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Delete an existing namespace.
- deleteNamespaceAsync(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Delete an existing namespace.
- deleteNumericRows(Table, byte[], int, int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- deleteSnapshot(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Delete an existing snapshot.
- deleteSnapshot(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Delete an existing snapshot.
- deleteSnapshots(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Delete existing snapshots whose names match the pattern passed.
- deleteSnapshots() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Delete all existing snapshots.
- deleteSnapshots(Pattern) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Delete existing snapshots whose names match the pattern passed.
- deleteTable(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Deletes a table.
- deleteTable(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Deletes a table.
- deleteTable(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Drop an existing table
- deleteTableAsync(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Deletes the table but does not block and wait for it to be completely removed.
- deleteTableData(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Provide an existing table name to truncate.
- deleteTableIfAny(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Drop an existing table
- deleteTableSnapshots(Pattern, Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Delete all existing snapshots matching the given table name regular expression and snapshot
name regular expression.
- deleteTableSnapshots(Pattern) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Delete all existing snapshots matching the given table name pattern.
- deleteTableSnapshots(Pattern, Pattern) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Delete all existing snapshots matching the given table name regular expression and snapshot
name regular expression.
- DELIMITER - Static variable in class org.apache.hadoop.hbase.HConstants
-
delimiter used between portions of a region name
- DependentColumnFilter - Class in org.apache.hadoop.hbase.filter
-
A filter for adding inter-column timestamp matching Only cells with a correspondingly timestamped
entry in the target column will be retained Not compatible with Scan.setBatch as operations need
full rows for correct filtering
- DependentColumnFilter(byte[], byte[], boolean, CompareOperator, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
Build a dependent column filter with value checking dependent column varies will be compared
using the supplied compareOp and comparator, for usage of which refer to
CompareFilter
- DependentColumnFilter(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
Constructor for DependentColumn filter.
- DependentColumnFilter(byte[], byte[], boolean) - Constructor for class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
Constructor for DependentColumn filter.
- DEPRECATED_MOB_CLEANER_PERIOD - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedBlob
-
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedBlobVar
-
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedFloat32
-
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedFloat64
-
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt16
-
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt32
-
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt64
-
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt8
-
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedNumeric
-
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedString
-
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.RawBytes
-
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.RawString
-
- deserialize(byte[]) - Static method in exception org.apache.hadoop.hbase.errorhandling.ForeignException
-
Takes a series of bytes and tries to generate an ForeignException instance for it.
- DFS_REPLICATION - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- disableReplicationPeer(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Stop the replication stream to the specified peer.
- disableReplicationPeer(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Stop the replication stream to the specified peer
- disableReplicationPeerAsync(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Disable a replication peer but does not block and wait for it.
- disableTable(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Disable table and wait on completion.
- disableTable(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Disable a table.
- disableTableAsync(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Disable the table but does not block and wait for it to be completely disabled.
- disableTableReplication(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Disable a table's replication switch.
- disableTableReplication(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Disable a table's replication switch.
- disableWriteBufferPeriodicFlush() - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
-
Disable the periodical flush, i.e, set the timeout to 0.
- disableWriteBufferPeriodicFlush() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
Disable periodic flushing of the write buffer.
- DISALLOWED_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.TableName
-
One globally disallowed name
- doLoadColumnFamiliesOnDemand() - Method in class org.apache.hadoop.hbase.client.Query
-
Get the logical value indicating whether on-demand CF loading should be allowed.
- DoNotRetryIOException - Exception in org.apache.hadoop.hbase
-
Subclass if exception is not meant to be retried: e.g.
- DoNotRetryIOException() - Constructor for exception org.apache.hadoop.hbase.DoNotRetryIOException
-
- DoNotRetryIOException(String) - Constructor for exception org.apache.hadoop.hbase.DoNotRetryIOException
-
- DoNotRetryIOException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.DoNotRetryIOException
-
- DoNotRetryIOException(Throwable) - Constructor for exception org.apache.hadoop.hbase.DoNotRetryIOException
-
- DoNotRetryRegionException - Exception in org.apache.hadoop.hbase.client
-
Similar to RegionException, but disables retries.
- DoNotRetryRegionException() - Constructor for exception org.apache.hadoop.hbase.client.DoNotRetryRegionException
-
- DoNotRetryRegionException(String) - Constructor for exception org.apache.hadoop.hbase.client.DoNotRetryRegionException
-
- DoNotRetryRegionException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.client.DoNotRetryRegionException
-
- DoNotRetryRegionException(Throwable) - Constructor for exception org.apache.hadoop.hbase.client.DoNotRetryRegionException
-
- doSetup(Reducer<ImmutableBytesWritable, Text, ImmutableBytesWritable, KeyValue>.Context, Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
-
Handles common parameter initialization that a subclass might want to leverage.
- doSetup(Mapper<LongWritable, Text, ImmutableBytesWritable, Put>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
Handles common parameter initialization that a subclass might want to leverage.
- doSetup(Mapper<LongWritable, Text, ImmutableBytesWritable, Text>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
-
Handles common parameter initialization that a subclass might want to leverage.
- doWork() - Method in class org.apache.hadoop.hbase.mapreduce.RowCounter
-
- doWork() - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
Execute the export snapshot by copying the snapshot metadata, hfiles and wals.
- doWork() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
- doWork() - Method in class org.apache.hadoop.hbase.util.RegionMover
-
- dropDependentColumn - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- dropDependentColumn() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
Returns true if we should drop the dependent column, false otherwise
- DroppedSnapshotException - Exception in org.apache.hadoop.hbase
-
Thrown during flush if the possibility snapshot content was not properly persisted into store
files.
- DroppedSnapshotException() - Constructor for exception org.apache.hadoop.hbase.DroppedSnapshotException
-
- DroppedSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.DroppedSnapshotException
-
- DroppedSnapshotException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.DroppedSnapshotException
-
DroppedSnapshotException with cause
- DRY_RUN_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- Durability - Enum in org.apache.hadoop.hbase.client
-
Enum describing the durability guarantees for tables and
Mutation
s Note that the items
must be sorted in order of increasing durability
- durability - Variable in class org.apache.hadoop.hbase.client.Mutation
-
- DURABILITY - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- GB_IN_BYTES - Static variable in class org.apache.hadoop.hbase.HConstants
-
- generateColumnDescriptors() - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create a set of column descriptors with the combination of compression, encoding, bloom codecs
available.
- generateColumnDescriptors(String) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create a set of column descriptors with the combination of compression, encoding, bloom codecs
available.
- generateSecretKey(Configuration, String, String...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Return a key derived from the concatenation of the supplied arguments using
PBKDF2WithHmacSHA384 key derivation algorithm at 10,000 iterations.
- generateSecretKey(Configuration, String, byte[]...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Return a key derived from the concatenation of the supplied arguments using
PBKDF2WithHmacSHA384 key derivation algorithm at 10,000 iterations.
- get(Get) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Extracts certain cells from a given row.
- get(List<Get>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Extracts certain cells from the given rows, in batch.
- Get - Class in org.apache.hadoop.hbase.client
-
Used to perform Get operations on a single row.
- Get(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Get
-
Create a Get operation for the specified row.
- Get(Get) - Constructor for class org.apache.hadoop.hbase.client.Get
-
Copy-constructor
- Get(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.client.Get
-
Create a Get operation for the specified row.
- Get(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.client.Get
-
Create a Get operation for the specified row.
- get(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Returns a list of all KeyValue objects with matching column family and qualifier.
- get(Get) - Method in interface org.apache.hadoop.hbase.client.Table
-
Extracts certain cells from a given row.
- get(List<Get>) - Method in interface org.apache.hadoop.hbase.client.Table
-
Extracts specified cells from the given rows, as a batch.
- get() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Get the data from the BytesWritable.
- get(String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a GET request
- get(Cluster, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a GET request
- get(String, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a GET request
- get(Cluster, String, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a GET request
- get(String, Header[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a GET request
- get(Cluster, String, Header[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a GET request
- get() - Method in class org.apache.hadoop.hbase.Size
-
get the value
- get(Size.Unit) - Method in class org.apache.hadoop.hbase.Size
-
get the value which is converted to specified unit.
- get(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Retrieve the byte at index
.
- get(int, byte[]) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Fill dst
with bytes from the range, starting from index
.
- get(int, byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Fill dst
with bytes from the range, starting from index
.
- get() - Method in class org.apache.hadoop.hbase.util.Bytes
-
Get the data from the Bytes.
- get() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Retrieve the next byte from this range.
- get(byte[]) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Fill dst
with bytes from the range, starting from position
.
- get(byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Fill dst
with bytes from the range, starting from the current position
.
- get(int, byte[]) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- get(int, byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- get(int, byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- get(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- get(int, byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
- get(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
- getACL() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Returns The serialized ACL for this operation, or null if none
- getACL() - Method in class org.apache.hadoop.hbase.client.Query
-
Returns The serialized ACL for this operation, or null if none
- getAction() - Method in class org.apache.hadoop.hbase.client.CheckAndMutate
-
Returns the action done if check succeeds
- getActiveMasterAddress() - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Get the address of active master if there is one.
- getAddress() - Method in class org.apache.hadoop.hbase.ServerName
-
- getAddress() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
Returns Address for this cluster instance.
- getAdmin() - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Retrieve an
AsyncAdmin
implementation to administer an HBase cluster.
- getAdmin(ExecutorService) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Retrieve an
AsyncAdmin
implementation to administer an HBase cluster.
- getAdmin() - Method in interface org.apache.hadoop.hbase.client.Connection
-
Retrieve an Admin implementation to administer an HBase cluster.
- getAdmin() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Returns an Admin instance which is shared between HBaseTestingUtility instance users.
- getAdmin() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Allows subclasses to get the
Admin
.
- getAdminBuilder() - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
- getAdminBuilder(ExecutorService) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
- getAgeOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSink
-
- getAgeOfLastShippedOp() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- getAliasPassword(String) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
-
- getAll(List<Get>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
A simple version for batch get.
- getAllFilters() - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Returns all known filters
- getAllOnlineRegions(MiniHBaseCluster) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- getAllowPartialResults() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns true when the constructor of this scan understands that the results they will see may
only represent a partial portion of a row.
- getAllRegionLocations() - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Retrieves all of the regions associated with this table.
- getAllRegionLocations() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Retrieves all of the regions associated with this table.
- getAsyncConnection() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Get a shared AsyncClusterConnection to the cluster.
- getAsyncConnection(User) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Get a assigned AsyncClusterConnection to the cluster.
- getAttribute(String) - Method in interface org.apache.hadoop.hbase.client.Attributes
-
Gets an attribute
- getAttribute(String) - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
- getAttributeSize() - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
- getAttributesMap() - Method in interface org.apache.hadoop.hbase.client.Attributes
-
Gets all attributes
- getAttributesMap() - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
- getAuthChore(Configuration) - Static method in class org.apache.hadoop.hbase.AuthUtil
-
- getAuthorizations() - Method in class org.apache.hadoop.hbase.client.Query
-
Returns The authorizations this Query is associated with.
- getAuthRenewalChore(UserGroupInformation, Configuration) - Static method in class org.apache.hadoop.hbase.AuthUtil
-
Deprecated.
Checks if security is enabled and if so, launches chore for refreshing kerberos ticket.
- getAverageLoad() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
Returns the average cluster load
- getBackoffTime(ServerName, byte[], ServerStatistics) - Method in interface org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicy
-
Returns the number of ms to wait on the client based on the
- getBackoffTime(ServerName, byte[], ServerStatistics) - Method in class org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
-
- getBackupMasterAddresses() - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Get all the backup master addresses.
- getBackupMasterNames() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
Returns the names of backup masters
- getBackupMasters() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get a list of current backup masters.
- getBackupMasters() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
- getBackupZooKeeperServerNum() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- getBadLineCount() - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
-
- getBadLineCount() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
- getBadLineCount() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
-
- getBalancerOn() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
- getBandwidth() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getBatch() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns maximum number of values to return for a single call to next()
- getBlockBytesScanned() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
Return the amount of block bytes scanned to retrieve the response cells.
- getBlocksize() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns The storefile/hfile blocksize for this column family.
- getBlockSize() - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
-
Get the cipher's internal block size
- getBlockSize() - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
-
Get the cipher's internal block size
- getBlocksLocalWeight() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the data at local weight of this region in the regionserver
- getBlocksLocalWithSsdWeight() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Different from blocksLocalWeight,this metric's numerator only include the data stored on ssd
- getBlocksTotalWeight() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the block total weight of this region
- getBloomFilterSize() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns The total size of all Bloom filter blocks, not just loaded into the block cache
- getBloomFilterType() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns bloom filter type used for new StoreFiles in ColumnFamily
- getBody() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
Returns the HTTP response body
- getBufferedMutator(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
- getBufferedMutator(TableName, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
- getBufferedMutator(TableName) - Method in interface org.apache.hadoop.hbase.client.Connection
-
- getBufferedMutator(BufferedMutatorParams) - Method in interface org.apache.hadoop.hbase.client.Connection
-
- getBufferedMutatorBuilder(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
- getBufferedMutatorBuilder(TableName, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
- getByteBuffer() - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
-
This flips the underlying BB so be sure to use it _last_!
- getBytes() - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
The underlying byte[].
- getBytes(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Returns a new byte array, copied from the given buf
, from the position (inclusive) to
the limit (exclusive).
- getCacheBlocks() - Method in class org.apache.hadoop.hbase.client.Get
-
Get whether blocks should be cached for this Get.
- getCacheBlocks() - Method in class org.apache.hadoop.hbase.client.Scan
-
Get whether blocks should be cached for this Scan.
- getCachedFilesList(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the list of cached files
- getCachedFilesList(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the list of cached files
- getCaching() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns caching the number of rows fetched when calling next on a scanner
- getCallDetails() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- getCause(int) - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getCauses() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getCellBuilder(CellBuilderType) - Method in class org.apache.hadoop.hbase.client.Append
-
- getCellBuilder(CellBuilderType) - Method in class org.apache.hadoop.hbase.client.Delete
-
- getCellBuilder(CellBuilderType) - Method in class org.apache.hadoop.hbase.client.Increment
-
- getCellBuilder(CellBuilderType) - Method in class org.apache.hadoop.hbase.client.Mutation
-
get a CellBuilder instance that already has relevant Type and Row set.
- getCellBuilder() - Method in class org.apache.hadoop.hbase.client.Mutation
-
get a CellBuilder instance that already has relevant Type and Row set.
- getCellBuilder(CellBuilderType, Cell.Type) - Method in class org.apache.hadoop.hbase.client.Mutation
-
get a CellBuilder instance that already has relevant Type and Row set.
- getCellBuilder(CellBuilderType) - Method in class org.apache.hadoop.hbase.client.Put
-
- getCellKeyAsString(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Returns The Key portion of the passed cell
as a String.
- getCellKeyAsString(Cell, Function<Cell, String>) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Return the Key portion of the passed cell
as a String.
- getCellVisibility() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Returns CellVisibility associated with cells in this Mutation.
- getChance() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
Returns The chance that a row gets included.
- getCipher(String) - Method in interface org.apache.hadoop.hbase.io.crypto.CipherProvider
-
Get an Cipher
- getCipher() - Method in class org.apache.hadoop.hbase.io.crypto.Context
-
- getCipher(String) - Method in class org.apache.hadoop.hbase.io.crypto.CryptoCipherProvider
-
- getCipher(String) - Method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
-
- getCipher(Configuration, String) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Get an cipher given a name
- getCipherProvider(Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
- getClassName() - Method in interface org.apache.hadoop.hbase.client.CoprocessorDescriptor
-
Returns the name of the class or interface represented by this object.
- getClientAddress() - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- getClientAddress() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- getClientMetrics() - Method in interface org.apache.hadoop.hbase.UserMetrics
-
Returns metrics per client(hostname)
- getClientPort() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- getClientPortList() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
Get the list of client ports.
- getClosestRowBefore(Region, byte[], byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- getCluster() - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Returns the cluster definition
- getClusterId() - Method in interface org.apache.hadoop.hbase.client.Connection
-
Returns the cluster ID unique to this HBase cluster.
- getClusterId() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
- getClusterIds() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Returns the set of clusterIds that have consumed the mutation
- getClusterKey() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- getClusterKey() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getClusterMetrics() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get whole cluster metrics, containing status about:
- getClusterMetrics(EnumSet<ClusterMetrics.Option>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get cluster status with a set of ClusterMetrics.Option
to get desired status.
- getClusterMetrics() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
- getClusterMetrics(EnumSet<ClusterMetrics.Option>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
- getClusterMetrics() - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.
Returns a ClusterMetrics for this HBase cluster.
- getClusterMetrics() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- getCode() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
Returns the HTTP response code
- getColumnCells(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Return the Cells for the specific column.
- getColumnFamilies() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
- getColumnFamily(byte[]) - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Returns the ColumnDescriptor for a specific column family with name as specified by the
parameter column.
- getColumnFamilyCount() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Returns the count of the column families of the table.
- getColumnFamilyMap() - Method in class org.apache.hadoop.hbase.client.replication.TableCFs
-
- getColumnFamilyNames() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Returns all the column family names of the current table.
- getColumnFamilyTimeRange() - Method in class org.apache.hadoop.hbase.client.Query
-
Returns A map of column families to time ranges
- getColumnLatestCell(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
The Cell for the most recent timestamp for a given column.
- getColumnLatestCell(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
-
The Cell for the most recent timestamp for a given column.
- getColumnOffset() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- getCompactedCellCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the number of already compacted kvs in current compaction
- getCompactingCellCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the total number of cells in current compaction
- getCompactionCompressionType() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns Compression type setting.
- getCompactionPressure() - Method in class org.apache.hadoop.hbase.client.RegionLoadStats
-
- getCompactionState(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the current compaction state of a table.
- getCompactionState(TableName, CompactType) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the current compaction state of a table.
- getCompactionState(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the current compaction state of a table.
- getCompactionState(TableName, CompactType) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the current compaction state of a table.
- getCompactionState() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the compaction state of this region
- getCompactionStateForRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the current compaction state of region.
- getCompactionStateForRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the current compaction state of region.
- getComparator(Comparator<ColumnFamilyDescriptor>) - Static method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
- getComparator() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
-
Returns the comparator
- getComparator() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
Returns the comparator
- getComparator() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Returns the comparator
- getCompareOp() - Method in class org.apache.hadoop.hbase.client.CheckAndMutate
-
Returns the comparison operator
- getCompareOperator() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
-
Returns operator
- getCompareOperator() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- getCompareOperator() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- getComparisonData() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
-
- getCompletedSequenceId() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
This does not really belong inside RegionLoad but its being done in the name of expediency.
- getCompletionTime() - Method in interface org.apache.hadoop.hbase.ServerTask
-
Get the task completion time.
- getCompressionType() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns Compression type setting.
- getCompressionType() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- getCompressor() - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
- getComputedSteps() - Method in class org.apache.hadoop.hbase.client.BalancerDecision
-
- getComputedTotalCost() - Method in class org.apache.hadoop.hbase.client.BalancerDecision
-
- getConf() - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.
- getConf() - Method in class org.apache.hadoop.hbase.io.crypto.Context
-
- getConf() - Method in class org.apache.hadoop.hbase.io.crypto.CryptoCipherProvider
-
- getConf() - Method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
-
- getConf() - Method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
Returns the current configuration.
- getConf() - Method in class org.apache.hadoop.hbase.mapreduce.HRegionPartitioner
-
Returns the current configuration.
- getConf() - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormat
-
Returns the current configuration.
- getConf() - Method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
- getConf() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Returns the current configuration.
- getConf() - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
- getConf() - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Get configuration of this cluster.
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Returns Configuration used by the instance.
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutator
-
Returns the Configuration
object used by this instance.
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Returns the Configuration
object used by this instance.
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Returns the Configuration
object used by this instance.
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
Returns the Configuration
object used by this instance.
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns an unmodifiable map.
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.Connection
-
Returns Configuration instance being used by this Connection instance.
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.Table
-
Returns the Configuration
object used by this instance.
- getConfiguration() - Method in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
Deprecated.
Returns this classes's instance of Configuration
.
- getConfiguration() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Returns this classes's instance of Configuration
.
- getConfiguration() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- getConfiguration() - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
- getConfigurationValue(String) - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns accessing the configuration value by key.
- getConfigurationValue(String) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
-
Getter for accessing the configuration value by key
- getConfiguredHashAlgorithm(Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Returns the Hash Algorithm defined in the crypto configuration.
- getConfiguredNamespacesAndTablesInRSGroup(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the namespaces and tables which have this RegionServer group in descriptor.
- getConfiguredNamespacesAndTablesInRSGroup(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the namespaces and tables which have this RegionServer group in descriptor.
- getConnection() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Returns Connection used by this object.
- getConnection() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Get a shared Connection to the cluster.
- getConnection(User) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Get a assigned Connection to the cluster.
- getConnectionAttributes() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- getConsistency() - Method in class org.apache.hadoop.hbase.client.Query
-
Returns the consistency level for this operation
- getCoprocessorDescriptors() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Return the list of attached co-processor represented
- getCoprocessorNames() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Return the RegionServer-level and Region-level coprocessors
- getCostFuncInfoList() - Method in class org.apache.hadoop.hbase.client.BalancerRejection
-
- getCpRequestCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the number of coprocessor service requests made to region
- getCreationTime() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
-
- getCurrent() - Static method in class org.apache.hadoop.hbase.security.User
-
Returns the User
instance within current execution context.
- getCurrentKey() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
Returns the current key.
- getCurrentKey() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
Returns the current key.
- getCurrentRegionCachedRatio() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns current prefetch ratio of this region on this server
- getCurrentSpaceQuotaSnapshot(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Returns the Master's view of a quota on the given namespace
or null if the Master has
no quota information on that namespace.
- getCurrentSpaceQuotaSnapshot(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Returns the Master's view of a quota on the given tableName
or null if the Master has
no quota information on that table.
- getCurrentSpaceQuotaSnapshot(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Returns the Master's view of a quota on the given namespace
or null if the Master has
no quota information on that namespace.
- getCurrentSpaceQuotaSnapshot(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Returns the Master's view of a quota on the given tableName
or null if the Master has
no quota information on that table.
- getCurrentValue() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
Returns the current value.
- getCurrentValue() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
Returns the current value.
- getCursor() - Method in class org.apache.hadoop.hbase.client.Result
-
Return the cursor if this Result is a cursor result.
- getDataBlockEncoderById(short) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Find and create data block encoder for given id;
- getDataBlockEncoding() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns the data block encoding algorithm used in block cache and optionally on disk
- getDataLocality() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the data locality of region in the regionserver.
- getDataLocalityForSsd() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Different from dataLocality,this metric's numerator only include the data stored on ssd
- getDataNodeHosts() - Method in class org.apache.hadoop.hbase.StartMiniClusterOption
-
Deprecated.
- getDataNodeHosts() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
-
- getDataTestDir() - Method in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
Deprecated.
- getDataTestDir(String) - Method in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
Deprecated.
- getDataTestDirOnTestFS() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- getDataTestDirOnTestFS(String) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- getDate() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
The date that hbase was compiled.
- getDeadServerNames() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
Returns the names of region servers on the dead list
- getDecommissionedServerNames() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
Returns the names of region servers on the decommissioned list
- getDecompressor() - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
- getDecryptor() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Return a decryptor for decrypting data.
- getDefaultRootDirPath(boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Returns the path to the default root dir the minicluster uses.
- getDefaultRootDirPath() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- getDefaultValues() - Static method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- getDesc(List<Throwable>, List<? extends Row>, List<String>) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getDesc(Map<String, Integer>) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getDescription() - Method in interface org.apache.hadoop.hbase.ServerTask
-
Get the task's description.
- getDescriptor(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get a table descriptor.
- getDescriptor(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Method for getting the tableDescriptor
- getDescriptor() - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
- getDescriptor() - Method in interface org.apache.hadoop.hbase.client.Table
-
- getDeserializer(Class<Cell>) - Method in class org.apache.hadoop.hbase.mapreduce.CellSerialization
-
- getDeserializer(Class<Mutation>) - Method in class org.apache.hadoop.hbase.mapreduce.MutationSerialization
-
- getDeserializer(Class<Result>) - Method in class org.apache.hadoop.hbase.mapreduce.ResultSerialization
-
- getDFSCluster() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- getDFSReplication() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns replication factor set for this CF
- getDifferentUser(Configuration, String) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
This method clones the passed c
configuration setting a new user into the clone.
- getDropDependentColumn() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- getDurability() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Get the current durability
- getDurability() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Returns the durability setting for the table.
- getEditsRead() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- getEncodedName() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns the encoded region name.
- getEncodedNameAsBytes() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns the encoded region name as an array of bytes.
- getEncodedRegionName() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the region's encoded name.
- getEncoder() - Method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Return new data block encoder for given algorithm type.
- getEncodingById(short) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
- getEncodingById(short) - Static method in enum org.apache.hadoop.hbase.io.encoding.IndexBlockEncoding
-
- getEncryptionKey() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns Return the raw crypto key attribute for the family, or null if not set
- getEncryptionType() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns Return the encryption algorithm in use by this family
- getEncryptor() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Get an encryptor for encrypting data.
- getEnd() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
-
- getEndKey() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns the endKey.
- getEndKeys() - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Gets the ending row key for every region in the currently open table.
- getEndKeys() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Gets the ending row key for every region in the currently open table.
- getEndRow() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
Returns end row key
- getEndRow() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the end row.
- getEvictedBlocks() - Method in class org.apache.hadoop.hbase.CacheEvictionStats
-
- getExceptionCount() - Method in class org.apache.hadoop.hbase.CacheEvictionStats
-
- getExceptions() - Method in class org.apache.hadoop.hbase.CacheEvictionStats
-
- getExcludeNamespaces() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getExcludeTableCFsMap() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getExhaustiveDescription() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getExists() - Method in class org.apache.hadoop.hbase.client.Result
-
- getExternalDfsUri() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
-
- getExternalZkConnectString() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
-
- getExtraHeader(String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Get an extra header value.
- getExtraHeaders() - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Get all extra headers (read-only).
- getFailureCount() - Method in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
-
Deprecated.
Returns failure count
- getFamilies() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns the keys of the familyMap
- getFamily() - Method in class org.apache.hadoop.hbase.client.CheckAndMutate
-
Returns the family to check
- getFamily() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
-
Returns the column family
- getFamily() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
Returns the column family
- getFamily() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Returns the family
- getFamilyArray() - Method in interface org.apache.hadoop.hbase.Cell
-
Contiguous bytes composed of legal HDFS filename characters which may start at any index in the
containing array.
- getFamilyCellMap() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Method for retrieving the put's familyMap
- getFamilyLength() - Method in interface org.apache.hadoop.hbase.Cell
-
Returns Number of family bytes.
- getFamilyMap() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the get's familyMap
- getFamilyMap(byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Map of qualifiers to values.
- getFamilyMap() - Method in class org.apache.hadoop.hbase.client.Scan
-
Getting the familyMap
- getFamilyMapOfLongs() - Method in class org.apache.hadoop.hbase.client.Increment
-
Before 0.95, when you called Increment#getFamilyMap(), you got back a map of families to a list
of Longs.
- getFamilyOffset() - Method in interface org.apache.hadoop.hbase.Cell
-
Returns Array index of first family byte
- getFilter() - Method in class org.apache.hadoop.hbase.client.CheckAndMutate
-
Returns the filter to check
- getFilter() - Method in class org.apache.hadoop.hbase.client.Query
-
- getFilter() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns RowFilter
- getFilter() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
-
- getFilter() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
-
- getFilterArguments(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Returns the arguments of the filter from the filter string
- getFilterByOperator() - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- getFilteredReadRequestCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the number of filtered read requests made to region
- getFilteredReadRequests() - Method in interface org.apache.hadoop.hbase.UserMetrics
-
Returns count of filtered read requests for a user
- getFilterIfMissing() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Get whether entire row should be filtered if column is not found.
- getFilterName(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Returns the filter name given a simple filter expression
- getFilters() - Method in class org.apache.hadoop.hbase.filter.FilterList
-
Get the filters.
- getFinalFunctionCosts() - Method in class org.apache.hadoop.hbase.client.BalancerDecision
-
- getFingerprint() - Method in class org.apache.hadoop.hbase.client.Get
-
Compile the table and column family (i.e.
- getFingerprint() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Compile the column family (i.e.
- getFingerprint() - Method in class org.apache.hadoop.hbase.client.Operation
-
Produces a Map containing a fingerprint which identifies the type and the static schema
components of a query (i.e.
- getFingerprint() - Method in class org.apache.hadoop.hbase.client.Scan
-
Compile the table and column family (i.e.
- getFirst() - Method in class org.apache.hadoop.hbase.util.Pair
-
Return the first element stored in the pair.
- getFirst() - Method in class org.apache.hadoop.hbase.util.PairOfSameType
-
Return the first element stored in the pair.
- getFirstFailureAt() - Method in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
-
Deprecated.
Returns time of the fist failure
- getFlushPolicyClassName() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
This gets the class associated with the flush policy which determines the stores need to be
flushed when flushing a region.
- getFromStoreFile(HStore, Get) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Do a small get/scan against one store.
- getFromStoreFile(HStore, byte[], NavigableSet<byte[]>) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Do a small get/scan against one store.
- getGroupName(String) - Static method in class org.apache.hadoop.hbase.AuthUtil
-
Deprecated.
Returns the actual name for a group principal (stripped of the group prefix).
- getGroupNames() - Method in class org.apache.hadoop.hbase.security.User
-
Returns the list of groups of which this user is a member.
- getHBaseCluster() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Get the Mini HBase cluster.
- getHBaseClusterInterface() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Returns the HBaseCluster instance.
- getHBaseVersion() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
Returns the HBase version string as reported by the HMaster
- getHbck() - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Retrieve an Hbck implementation to fix an HBase cluster.
- getHbck(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Retrieve an Hbck implementation to fix an HBase cluster.
- getHbck() - Method in interface org.apache.hadoop.hbase.client.Connection
-
Retrieve an Hbck implementation to fix an HBase cluster.
- getHbck(ServerName) - Method in interface org.apache.hadoop.hbase.client.Connection
-
Retrieve an Hbck implementation to fix an HBase cluster.
- getHbck() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Returns an Hbck
instance.
- getHeader(String) - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- getHeaders() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
Returns the HTTP response headers
- getHeapOccupancy() - Method in class org.apache.hadoop.hbase.client.RegionLoadStats
-
- getHostname() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- getHostname() - Method in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
-
Returns null if not set
- getHostName() - Method in class org.apache.hadoop.hbase.net.Address
-
- getHostname() - Method in class org.apache.hadoop.hbase.net.Address
-
- getHostname() - Method in class org.apache.hadoop.hbase.ServerName
-
- getHostnameLowerCase() - Method in class org.apache.hadoop.hbase.ServerName
-
- getHostnamePort(int) - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getHostnamePort() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
Returns String made of hostname and port formatted as per
Addressing.createHostAndPortStr(String, int)
- getHttpClient() - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Returns the wrapped HttpClient
- getId() - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
This method allows you to retrieve the identifier for the operation if one was set.
- getId() - Method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Returns The id of a data block encoder.
- getId() - Method in enum org.apache.hadoop.hbase.io.encoding.IndexBlockEncoding
-
Returns The id of a data block encoder.
- getImplementationClassName() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- getIndexBlockEncoding() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Return the index block encoding algorithm used in block cache and optionally on disk
- getInfoServerPort() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
- getInitialClusterMetrics() - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.
Returns a ClusterStatus for this HBase cluster as observed at the starting of the HBaseCluster
- getInitialFunctionCosts() - Method in class org.apache.hadoop.hbase.client.BalancerDecision
-
- getInitTotalCost() - Method in class org.apache.hadoop.hbase.client.BalancerDecision
-
- getInMemoryCompaction() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns in-memory compaction policy if set for the cf.
- getInstance() - Static method in interface org.apache.hadoop.hbase.CellComparator
-
A comparator for ordering cells in user-space tables.
- getInstance() - Static method in class org.apache.hadoop.hbase.io.crypto.CryptoCipherProvider
-
- getInstance() - Static method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
-
- getInt(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Retrieve the int value at index
- getInt() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Retrieve the next int value from this range.
- getIsolationLevel() - Method in class org.apache.hadoop.hbase.client.Query
-
Returns The isolation level of this query.
- getIv() - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
-
Get the initialization vector
- getIvLength() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Return the expected initialization vector length, in bytes, or 0 if not applicable
- getIvLength() - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
-
Get the expected length for the initialization vector
- getIvLength() - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
-
Get the expected length for the initialization vector
- getJarPath() - Method in interface org.apache.hadoop.hbase.client.CoprocessorDescriptor
-
Returns Path of the jar file.
- getKeepDeletedCells() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns return the KeepDeletedCells
- getKey() - Method in class org.apache.hadoop.hbase.io.crypto.Context
-
- getKey(String) - Method in interface org.apache.hadoop.hbase.io.crypto.KeyProvider
-
Retrieve the key for a given key aliase
- getKey(String) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
-
- getKeyBytes() - Method in class org.apache.hadoop.hbase.io.crypto.Context
-
- getKeyBytesHash() - Method in class org.apache.hadoop.hbase.io.crypto.Context
-
- getKeyFormat() - Method in class org.apache.hadoop.hbase.io.crypto.Context
-
- getKeyLength() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Return the key length required by this cipher, in bytes
- getKeyProvider(Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
- getKeys(String[]) - Method in interface org.apache.hadoop.hbase.io.crypto.KeyProvider
-
Retrieve keys for a given set of key aliases
- getKeys(String[]) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
-
- getKeyValues(Configuration, String) - Static method in class org.apache.hadoop.hbase.util.ConfigurationUtil
-
Retrieve a list of key value pairs from configuration, stored under the provided key
- getKeyValues(Configuration, String, char) - Static method in class org.apache.hadoop.hbase.util.ConfigurationUtil
-
Retrieve a list of key value pairs from configuration, stored under the provided key
- getLastAttemptAt() - Method in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
-
Deprecated.
Returns time of the latest attempt
- getLastMajorCompactionTimestamp(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the timestamp of the last major compaction for the passed table The timestamp of the oldest
HFile resulting from a major compaction of that table, or 0 if no such HFile could be found.
- getLastMajorCompactionTimestamp(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the timestamp of the last major compaction for the passed table.
- getLastMajorCompactionTimestamp(TableName) - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
- getLastMajorCompactionTimestamp(byte[]) - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
- getLastMajorCompactionTimestamp() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the timestamp of the oldest hfile for any store of this region.
- getLastMajorCompactionTimestampForRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the timestamp of the last major compaction for the passed region.
- getLastMajorCompactionTimestampForRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the timestamp of the last major compaction for the passed region.
- getLastReportTimestamp() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Returns the last timestamp (server side) of generating this metrics
- getLatestVersionOnly() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Get whether only the latest version of the column value should be compared.
- getLength() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Returns the number of valid bytes in the buffer
- getLength() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
- getLength() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the length of the split.
- getLength() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
-
Retrieve the maximum length (in bytes) of encoded values.
- getLength() - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
The length of the range.
- getLength() - Method in class org.apache.hadoop.hbase.util.Bytes
-
Returns the number of valid bytes in the buffer
- getLimit() - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- getLimit() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns the limit of rows for this scan
- getLimit() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
- getLimit() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- getLimit() - Method in interface org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView
-
Returns the limit, in bytes, of the target (e.g.
- getLimit() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Return the current limit
- getListener() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- getLiveMasterThreads() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
Returns List of live master threads (skips the aborted and the killed)
- getLiveRegionServerThreads() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
Returns List of live region server threads (skips the aborted and the killed)
- getLiveServerMetrics() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
Returns the names of region servers on the live list
- getLoadColumnFamiliesOnDemandValue() - Method in class org.apache.hadoop.hbase.client.Query
-
Get the raw loadColumnFamiliesOnDemand setting; if it's not set, can be null.
- getLocation() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
Returns the value of the Location header
- getLocations() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
- getLocations() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the region's location as an array.
- getLocks() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get locks.
- getLocks() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
List locks.
- getLogEntries(Set<ServerName>, String, ServerType, int, Map<String, Object>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Retrieve recent online records from HMaster / RegionServers.
- getLogEntries(Set<ServerName>, String, ServerType, int, Map<String, Object>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Retrieve recent online records from HMaster / RegionServers.
- getLong(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Retrieve the long value at index
- getLong() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Retrieve the next long value from this range.
- getLongValue() - Method in class org.apache.hadoop.hbase.Size
-
get the value
- getMajorCompactionCompressionType() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns Compression type setting for major compactions.
- getMajorVersion(String) - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
- getMap() - Method in class org.apache.hadoop.hbase.client.Result
-
Map of families to all versions of its qualifiers and values.
- getMaster() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the current active master.
- getMaster() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
- getMaster() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
Returns the current active master, if available.
- getMaster(int) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
Returns the master at the specified index, if available.
- getMasterClass() - Method in class org.apache.hadoop.hbase.StartMiniClusterOption
-
Deprecated.
- getMasterCoprocessorNames() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Helper that delegates to getClusterMetrics().getMasterCoprocessorNames().
- getMasterCoprocessorNames() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
- getMasterCoprocessorNames() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
- getMasterIndex(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- getMasterInfoPort() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the info port of the current master if one is available.
- getMasterInfoPort() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the info port of the current master if one is available.
- getMasterInfoPort() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
- getMasterName() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
Returns detailed information about the current master
ServerName
.
- getMasterTasks() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
Provide the list of master tasks
- getMasterThread() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
Returns the current active master thread, if available.
- getMasterThreads() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
Returns List of master threads.
- getMax() - Method in class org.apache.hadoop.hbase.io.TimeRange
-
Returns the biggest timestamp that should be considered
- getMaxAllowedOperationTime() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
-
- getMaxCacheSize() - Method in class org.apache.hadoop.hbase.CacheEvictionStats
-
- getMaxColumn() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
Returns the max column range for the filter
- getMaxColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
Returns true if max column is inclusive, false otherwise
- getMaxCompactedStoreFileRefCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the max reference count for any store file among all compacted stores files of this
region
- getMaxFileSize() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
-
- getMaxFileSize() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Returns the maximum size upto which a region can grow to after which a region split is
triggered.
- getMaxHeapSize() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Returns the maximum allowable size of the heap
- getMaxKeyValueSize() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- getMaxPriority() - Method in class org.apache.hadoop.hbase.client.RowMutations
-
- getMaxResultSize() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns the maximum result size in bytes.
- getMaxResultsPerColumnFamily() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the get's maximum number of values to return per Column Family
- getMaxResultsPerColumnFamily() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns maximum number of values to return per row per CF
- getMaxVersions() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns maximum number of versions
- getMaxVersions() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the get's maximum number of version
- getMaxVersions() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns the max number of versions to fetch
- getMD5AsHex(byte[]) - Static method in class org.apache.hadoop.hbase.util.MD5Hash
-
Given a byte array, returns in MD5 hash as a hex string.
- getMD5AsHex(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.MD5Hash
-
Given a byte array, returns its MD5 hash as a hex string.
- getMemStoreFlushSize() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Returns the size of the memstore after which a flush to filesystem is triggered.
- getMemStoreLoad() - Method in class org.apache.hadoop.hbase.client.RegionLoadStats
-
- getMemStoreSize() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the memstore size
- getMessage() - Method in exception org.apache.hadoop.hbase.quotas.SpaceLimitingException
-
- getMetaRSPort(Connection) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- getMetaTableRows() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Returns all rows from the hbase:meta table.
- getMetaTableRows(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Returns all rows from the hbase:meta table for a given user table
- getMethodName() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- getMin() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
Gets the minimum timestamp requested by filter.
- getMin() - Method in class org.apache.hadoop.hbase.io.TimeRange
-
Returns the smallest timestamp that should be considered
- getMinColumn() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
Returns the min column range for the filter
- getMinColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
Returns true if min column is inclusive, false otherwise
- getMiniHBaseCluster() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- getMinorCompactionCompressionType() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns Compression type setting for minor compactions.
- getMinVersions() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns The minimum number of versions to keep.
- getMobCompactPartitionPolicy() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Get the mob compact partition policy for this family
- getMobThreshold() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Gets the mob threshold of the family.
- getMovesCalculated() - Method in class org.apache.hadoop.hbase.client.BalanceResponse
-
- getMovesExecuted() - Method in class org.apache.hadoop.hbase.client.BalanceResponse
-
The number of moves actually executed by the balancer if it ran.
- getMultiGetsCount() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- getMultiMutationsCount() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- getMultiServiceCalls() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- getMutations() - Method in class org.apache.hadoop.hbase.client.RowMutations
-
Returns An unmodifiable list of the current mutations.
- getName() - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutator
-
Gets the fully qualified table name instance of the table that this
AsyncBufferedMutator
writes to.
- getName() - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Gets the fully qualified table name instance of this table.
- getName() - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Gets the fully qualified table name instance of the table whose region we want to locate.
- getName() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
Gets the fully qualified table name instance of the table that this BufferedMutator writes to.
- getName() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns a copy of Name of this column family
- getName() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Gets the fully qualified table name instance of this table.
- getName() - Method in enum org.apache.hadoop.hbase.client.security.SecurityCapability
-
- getName() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
-
- getName() - Method in interface org.apache.hadoop.hbase.client.Table
-
Gets the fully qualified table name instance of this table.
- getName() - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
- getName() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Return this Cipher's name
- getName() - Method in interface org.apache.hadoop.hbase.io.crypto.CipherProvider
-
Return the provider's name
- getName() - Method in class org.apache.hadoop.hbase.io.crypto.CryptoCipherProvider
-
- getName() - Method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
-
- getName() - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- getName() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
Get group name.
- getName() - Method in class org.apache.hadoop.hbase.security.User
-
Returns the full user name.
- getName() - Method in class org.apache.hadoop.hbase.TableName
-
- getNameAsString() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns Name of this column family
- getNameAsString() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- getNameAsString() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the region name as a string
- getNameAsString() - Method in class org.apache.hadoop.hbase.TableName
-
- getNameAsString() - Method in interface org.apache.hadoop.hbase.UserMetrics
-
Returns the user name as a string
- getNameFromId(short) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Find and return the name of data block encoder for the given id.
- getNameFromId(short) - Static method in enum org.apache.hadoop.hbase.io.encoding.IndexBlockEncoding
-
Find and return the name of data block encoder for the given id.
- getNameInBytes() - Method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Returns name converted to bytes.
- getNameInBytes() - Method in enum org.apache.hadoop.hbase.io.encoding.IndexBlockEncoding
-
Returns name converted to bytes.
- getNamespace() - Method in class org.apache.hadoop.hbase.client.NormalizeTableFilterParams
-
- getNamespace() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
-
- getNamespace() - Method in class org.apache.hadoop.hbase.TableName
-
- getNamespaceAsString() - Method in class org.apache.hadoop.hbase.TableName
-
- getNamespaceDescriptor(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get a namespace descriptor by name.
- getNamespaceDescriptor(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get a namespace descriptor by name
- getNamespaceFilter() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
Returns the Namespace filter regex
- getNamespaces() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getNameWithNamespaceInclAsString() - Method in class org.apache.hadoop.hbase.TableName
-
Ideally, getNameAsString should contain namespace within it, but if the namespace is default,
it just returns the name.
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.Filter
-
If the filter returns the match code SEEK_NEXT_USING_HINT, then it should also tell which is
the next key it must seek to.
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
Pick the next cell that the scanner should seek to.
- getNormalizerTargetRegionCount() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Check if there is the target region count.
- getNormalizerTargetRegionSize() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Check if there is the target region size.
- getNoVersionMap() - Method in class org.apache.hadoop.hbase.client.Result
-
Map of families to their most recent qualifiers and values.
- getNumAlwaysStandByMasters() - Method in class org.apache.hadoop.hbase.StartMiniClusterOption
-
Deprecated.
- getNumAlwaysStandByMasters() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
-
- getNumberOfTasksInProgress() - Method in interface org.apache.hadoop.hbase.client.RequestController
-
Returns The number of running task.
- getNumDataNodes() - Method in class org.apache.hadoop.hbase.StartMiniClusterOption
-
Deprecated.
- getNumDataNodes() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
-
- getNumExceptions() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getNumHFiles(TableName, byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- getNumHFilesForRS(HRegionServer, TableName, byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- getNumLiveRegionServers() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
Returns Number of live region servers in the cluster currently.
- getNumMasters() - Method in class org.apache.hadoop.hbase.StartMiniClusterOption
-
Deprecated.
- getNumMasters() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
-
- getNumRegionServers() - Method in class org.apache.hadoop.hbase.StartMiniClusterOption
-
Deprecated.
- getNumRegionServers() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
-
- getNumZkServers() - Method in class org.apache.hadoop.hbase.StartMiniClusterOption
-
Deprecated.
- getNumZkServers() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
-
- getOffset() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- getOffset() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Return the offset into the buffer.
- getOffset() - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
The offset, the index into the underlying byte[] at which this range begins.
- getOffset() - Method in class org.apache.hadoop.hbase.util.Bytes
-
Return the offset into the buffer.
- getOnlineRegionsInterface(ServerName) - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Get the server side OnlineRegions
interface for the specific region server.
- getOperationTimeout() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Return the operation timeout for a rpc call.
- getOperationTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Get timeout of each operation in Table instance.
- getOperationTimeout() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- getOperationTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.Table
-
Get timeout of each operation in Table instance.
- getOperator() - Method in class org.apache.hadoop.hbase.filter.BitComparator
-
Returns the bitwise operator
- getOperator() - Method in class org.apache.hadoop.hbase.filter.FilterList
-
Get the operator.
- getOPsShipped() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- getOrder() - Method in interface org.apache.hadoop.hbase.types.DataType
-
Retrieve the sort
Order
imposed by this data type, or null when natural ordering is not
preserved.
- getOrder() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.OrderedBytesBase
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawByte
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawBytes
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawDouble
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawFloat
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawInteger
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawLong
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawShort
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawString
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.Struct
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.Union2
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.Union3
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.Union4
-
- getOtherRegionServer(HRegionServer) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Find any other region server which is different from the one identified by parameter
- getOutputCommitter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
-
- getOutputCommitter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
Returns the output committer.
- getOwner() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
-
- getPageSize() - Method in class org.apache.hadoop.hbase.filter.PageFilter
-
- getParam() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- getPartition(ImmutableBytesWritable, V2, int) - Method in class org.apache.hadoop.hbase.mapred.HRegionPartitioner
-
- getPartition(ImmutableBytesWritable, VALUE, int) - Method in class org.apache.hadoop.hbase.mapreduce.HRegionPartitioner
-
Gets the partition number for a given key (hence record) given the total number of partitions
i.e.
- getPartition(ImmutableBytesWritable, VALUE, int) - Method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
- getPassword(Configuration, String, String) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
Get the password from the Configuration instance using the getPassword method if it exists.
- getPeerConfig() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerDescription
-
- getPeerData() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getPeerID() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- getPeerId() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerDescription
-
- getPeriodicalFlushTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutator
-
Returns the periodical flush interval, 0 means disabled.
- getPolicy() - Method in interface org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView.SpaceQuotaStatusView
-
Returns the violation policy, which may not be presented.
- getPool() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- getPort() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- getPort() - Method in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
-
Returns -1 if not set
- getPort() - Method in class org.apache.hadoop.hbase.net.Address
-
- getPort() - Method in class org.apache.hadoop.hbase.ServerName
-
- getPos() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- getPos() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- getPosition() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
The current position
marker.
- getPrefix() - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
- getPrefix() - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- getPrefix() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
-
- getPriority() - Method in interface org.apache.hadoop.hbase.client.CoprocessorDescriptor
-
Returns The order to execute this coprocessor
- getPriority() - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
- getPriority() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
- getProcedures() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get procedures.
- getProcedures() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
List procedures
- getProcessingTime() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- getProgress() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- getProgress() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- getProgress() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
The current progress of the record reader through its data.
- getProgress() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
The current progress of the record reader through its data.
- getProperties() - Method in interface org.apache.hadoop.hbase.client.CoprocessorDescriptor
-
Returns Arbitrary key-value parameter pairs passed into the coprocessor.
- getProtocol() - Method in exception org.apache.hadoop.hbase.exceptions.UnknownProtocolException
-
- getProvider() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Return the provider for this Cipher
- getQualifier() - Method in class org.apache.hadoop.hbase.client.CheckAndMutate
-
Returns the qualifier to check
- getQualifier() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
-
Returns the qualifier
- getQualifier() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
Returns the column qualifier
- getQualifier() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Returns the qualifier
- getQualifier() - Method in class org.apache.hadoop.hbase.TableName
-
- getQualifierArray() - Method in interface org.apache.hadoop.hbase.Cell
-
Contiguous raw bytes that may start at any index in the containing array.
- getQualifierAsString() - Method in class org.apache.hadoop.hbase.TableName
-
- getQualifierLength() - Method in interface org.apache.hadoop.hbase.Cell
-
Returns Number of qualifier bytes.
- getQualifierOffset() - Method in interface org.apache.hadoop.hbase.Cell
-
Returns Array index of first qualifier byte
- getQueueId() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- getQueueTime() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- getQuota(QuotaFilter) - Method in interface org.apache.hadoop.hbase.client.Admin
-
List the quotas based on the filter.
- getQuota(QuotaFilter) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
List the quotas based on the filter.
- getQuotaStatus() - Method in interface org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView
-
Returns the status of the quota.
- getQuotaType() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
-
- getRandomDir() - Method in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
Deprecated.
- getRandomKey() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Create a random symmetric key
- getRandomUUID() - Static method in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
Deprecated.
- getReadRequestCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the number of read requests made to region
- getReadRequestCount() - Method in interface org.apache.hadoop.hbase.UserMetrics
-
Returns the number of read requests made by user
- getReadRequestsCount() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Returns total Number of read requests from the start of the region server.
- getReadRpcTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Get timeout of each rpc read request in this Table instance.
- getReadRpcTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.Table
-
Get timeout of each rpc read request in this Table instance.
- getReadType() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns the read type for this scan
- getReason() - Method in class org.apache.hadoop.hbase.client.BalancerRejection
-
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hbase.mapred.MultiTableSnapshotInputFormat
-
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
Builds a TableRecordReader.
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat
-
- getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat
-
Creates a new record writer.
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
-
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
Creates a new record writer.
- getRegex() - Method in class org.apache.hadoop.hbase.client.NormalizeTableFilterParams
-
- getRegion() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
Returns regionInfo
- getRegion(RegionInfo) - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Get the server side Region
interface for the specific region.
- getRegionCachedInfo() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Returns the region cache information for the regions hosted on this server
- getRegionCount() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
Returns the number of regions deployed on the cluster
- getRegionId() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns the regionId.
- getRegionLocation(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Finds the region on which the given row is being served.
- getRegionLocation(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Finds the region on which the given row is being served.
- getRegionLocation(byte[], int) - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Finds the region with the given replicaId
on which the given row is being served.
- getRegionLocation(byte[], int, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Finds the region with the given replicaId
on which the given row is being served.
- getRegionLocation(byte[]) - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Finds the region on which the given row is being served.
- getRegionLocation(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Finds the region on which the given row is being served.
- getRegionLocation(byte[], int) - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Finds the region with the given replica id on which the given row is being served.
- getRegionLocation(byte[], int, boolean) - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Finds the region with the given replica id on which the given row is being served.
- getRegionLocation() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
Returns the region's hostname
- getRegionLocation() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the region location.
- getRegionLocations(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Find all the replicas for the region on which the given row is being served.
- getRegionLocations(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Find all the replicas for the region on which the given row is being served.
- getRegionLocations(byte[]) - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Find all the replicas for the region on which the given row is being served.
- getRegionLocations(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Find all the replicas for the region on which the given row is being served.
- getRegionLocator(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Retrieve a AsyncRegionLocator implementation to inspect region information on a table.
- getRegionLocator() - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
- getRegionLocator(TableName) - Method in interface org.apache.hadoop.hbase.client.Connection
-
Retrieve a RegionLocator implementation to inspect region information on a table.
- getRegionLocator() - Method in interface org.apache.hadoop.hbase.client.Table
-
- getRegionLocator() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- getRegionMetrics(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- getRegionMetrics(ServerName, TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get
RegionMetrics
of all regions hosted on a regionserver for a table.
- getRegionMetrics(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get a list of
RegionMetrics
of all regions hosted on a region server.
- getRegionMetrics(ServerName, TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get a list of
RegionMetrics
of all regions hosted on a region server for a table.
- getRegionMetrics() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Returns region load metrics
- getRegionName() - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- getRegionName() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- getRegionName() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns the regionName as an array of bytes.
- getRegionName() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the region name
- getRegionNameAsString() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns Region name as a String for use in logging, etc.
- getRegionNameAsString(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
- getRegionNameAsString(RegionInfo, byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
- getRegionPlans() - Method in class org.apache.hadoop.hbase.client.BalancerDecision
-
- getRegionReplication() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Returns Returns the configured replicas per region
- getRegions(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get all the online regions on a region server.
- getRegions(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the regions of a given table.
- getRegions(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get all the online regions on a region server.
- getRegions(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the regions of a given table.
- getRegions(byte[]) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- getRegions(TableName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- getRegionServer(int) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
Grab a numbered region server of your choice.
- getRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- getRegionServer() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
-
- getRegionServerAddresses() - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Get all the region server addresses.
- getRegionServerFilter() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
Returns the RegionServer filter regex
- getRegionServerGroup() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Get the region server group this table belongs to.
- getRegionServerIndex(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- getRegionServers() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the live server list.
- getRegionServers(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Retrieve all current live region servers including decommissioned if excludeDecommissionedRS is
false, else non-decommissioned ones only
- getRegionServers() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
- getRegionServers(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
- getRegionServerSpaceQuotaSnapshots(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- getRegionServerSpaceQuotaSnapshots(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
- getRegionServerThreads() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- getRegionSizeMB() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the total size of the hfiles in the region
- getRegionSplitPolicyClassName() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
This gets the class associated with the region split policy which determines when a region
split should occur.
- getRegionSplitStartKeys(byte[], byte[], int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Create region split keys between startkey and endKey
- getRegionStatesInTransition() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
- getRemaining() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
The number of bytes remaining between position and the end of the range.
- getRemoteWALDir() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getReplicaId() - Method in class org.apache.hadoop.hbase.client.Query
-
Returns region replica id where Query will fetch data from.
- getReplicaId() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns returns region replica id
- getReplicationEndpointImpl() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getReplicationLag() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- getReplicationLoadSink() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Call directly from client such as hbase shell
- getReplicationLoadSourceList() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Call directly from client such as hbase shell
- getReplicationLoadSourceMap() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Call directly from client such as hbase shell
- getReplicationPeerConfig(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Returns the configured ReplicationPeerConfig for the specified peer.
- getReplicationPeerConfig(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Returns the configured ReplicationPeerConfig for the specified peer
- getReplicationPeerSyncReplicationState(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the current cluster state in a synchronous replication peer.
- getReplicationPeerSyncReplicationState(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the current cluster state in a synchronous replication peer.
- getReportTimestamp() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Returns the timestamp (server side) of generating this metrics
- getRequestAttributes() - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Get the map of request attributes
- getRequestAttributes() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- getRequestAttributes() - Method in interface org.apache.hadoop.hbase.client.Table
-
Get the attributes to be submitted with requests
- getRequestCount() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
Returns the number of requests since last report
- getRequestCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the number of write requests and read requests and coprocessor service requests made to
region
- getRequestCount() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Returns total Number of requests from the start of the region server.
- getRequestCount() - Method in interface org.apache.hadoop.hbase.UserMetrics
-
Returns the number of write requests and read requests and coprocessor service requests made by
the user
- getRequestCountPerSecond() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Returns the number of requests per second.
- getResponseBody(HttpResponse) - Static method in class org.apache.hadoop.hbase.rest.client.Client
-
Returns the response body of the HTTPResponse, if any, as an array of bytes.
- getResponseSize() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- getResult() - Method in class org.apache.hadoop.hbase.client.CheckAndMutateResult
-
Returns It is used only for CheckAndMutate operations with Increment/Append.
- getRevision() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
Get the subversion revision number for the root directory
- getRow() - Method in class org.apache.hadoop.hbase.client.CheckAndMutate
-
Returns the row
- getRow() - Method in class org.apache.hadoop.hbase.client.Cursor
-
- getRow() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the get's row
- getRow() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Method for retrieving the delete's row
- getRow() - Method in class org.apache.hadoop.hbase.client.Result
-
Method for retrieving the row key that corresponds to the row from which this Result was
created.
- getRow(int) - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getRow() - Method in interface org.apache.hadoop.hbase.client.Row
-
Returns The row.
- getRow() - Method in class org.apache.hadoop.hbase.client.RowMutations
-
- getRowArray() - Method in interface org.apache.hadoop.hbase.Cell
-
Contiguous raw bytes that may start at any index in the containing array.
- getRowLength() - Method in interface org.apache.hadoop.hbase.Cell
-
Returns Number of row bytes.
- getRowOffset() - Method in interface org.apache.hadoop.hbase.Cell
-
Returns Array index of first row byte
- getRowOffsetPerColumnFamily() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the get's offset per row per column family (#kvs to be skipped)
- getRowOffsetPerColumnFamily() - Method in class org.apache.hadoop.hbase.client.Scan
-
Method for retrieving the scan's offset per row per column family (#kvs to be skipped)
- getRowRanges() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
-
- getRpcTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Get timeout of each rpc request in this Table instance.
- getRpcTimeout() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- getRpcTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.Table
-
Get timeout of each rpc request in this Table instance.
- getRsClass() - Method in class org.apache.hadoop.hbase.StartMiniClusterOption
-
Deprecated.
- getRSForFirstRegionInTable(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
Tool to get the reference to the region server object that holds the region of the specified
user table.
- getRSGroup(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get group info for the given group name
- getRSGroup(Address) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get group info for the given hostPort
- getRSGroup(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get group info for the given table
- getRSGroup(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get group info for the given group name
- getRSGroup(Address) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get group info for the given hostPort
- getRSGroup(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get group info for the given table
- getRsPorts() - Method in class org.apache.hadoop.hbase.StartMiniClusterOption
-
Deprecated.
- getRsPorts() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
-
- getScan() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- getScan() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Gets the scan defining the actual details like columns etc.
- getScan() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns a Scan object from the stored string representation.
- getScanAsString() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns a scan string
- getScanMetrics() - Method in interface org.apache.hadoop.hbase.client.ResultScanner
-
Returns the scan metrics, or null
if we do not enable metrics.
- getScanner(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Gets a scanner on the current table for the given family.
- getScanner(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Gets a scanner on the current table for the given family and qualifier.
- getScanner(Scan) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Returns a scanner on the current table as specified by the
Scan
object.
- getScanner(Scan) - Method in interface org.apache.hadoop.hbase.client.Table
-
Returns a scanner on the current table as specified by the
Scan
object.
- getScanner(byte[]) - Method in interface org.apache.hadoop.hbase.client.Table
-
Gets a scanner on the current table for the given family.
- getScanner(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Table
-
Gets a scanner on the current table for the given family and qualifier.
- getScans() - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
-
Allows subclasses to get the list of
Scan
objects.
- getScanTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Get the timeout of a single operation in a scan.
- getScope() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns the scope tag
- getSecond() - Method in class org.apache.hadoop.hbase.util.Pair
-
Return the second element stored in the pair.
- getSecond() - Method in class org.apache.hadoop.hbase.util.PairOfSameType
-
Return the second element stored in the pair.
- getSecretKeyForSubject(String, Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Resolves a key for the given subject
- getSecurityCapabilities() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Return the set of supported security capabilities.
- getSecurityCapabilities() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Returns the list of supported security capabilities.
- getSeqNum() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- getSequenceId() - Method in interface org.apache.hadoop.hbase.Cell
-
- getSerializedSize() - Method in interface org.apache.hadoop.hbase.Cell
-
Returns Serialized size (defaults to include tag length if has some tags).
- getSerializer(Class<Cell>) - Method in class org.apache.hadoop.hbase.mapreduce.CellSerialization
-
- getSerializer(Class<Mutation>) - Method in class org.apache.hadoop.hbase.mapreduce.MutationSerialization
-
- getSerializer(Class<Result>) - Method in class org.apache.hadoop.hbase.mapreduce.ResultSerialization
-
- getServerClass() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- getServerHoldingMeta() - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.
Get the ServerName of region server serving the first hbase:meta region
- getServerHoldingRegion(TableName, byte[]) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.
Get the ServerName of region server serving the specified region
- getServerHoldingRegion(TableName, byte[]) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- getServerName() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- getServerName() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
- getServerName() - Method in class org.apache.hadoop.hbase.ServerName
-
- getServers() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
Get list of servers.
- getServersName() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
- getServerWith(byte[]) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
Get the location of the specified region
- getServerWithMeta() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- getShort(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Retrieve the short value at index
- getShort() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Retrieve the next short value from this range.
- getShortName() - Method in class org.apache.hadoop.hbase.security.User
-
Returns the shortened version of the user name -- the portion that maps to an operating system
user name.
- getShortNameToLog() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns Return a short, printable name for this region (usually encoded name) for us logging.
- getShortNameToLog(RegionInfo...) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns a String of short, printable names for hris
(usually encoded name) for us
logging.
- getShortNameToLog(List<RegionInfo>) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns a String of short, printable names for hris
(usually encoded name) for us
logging.
- getSimpleComparator() - Method in interface org.apache.hadoop.hbase.CellComparator
-
Return a dumbed-down, fast comparator for hbase2 base-type, the ByteBufferKeyValue
.
- getSizeOfLogQueue() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- getSkipBadLines() - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
-
- getSkipBadLines() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
- getSkipBadLines() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
-
- getSlowLogResponses(Set<ServerName>, LogQueryFilter) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- getSlowLogResponses(Set<ServerName>, LogQueryFilter) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
- getSnapshotDescription() - Method in exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
-
Returns the description of the snapshot that is being failed