Skip navigation links
A B C D E F G H I J K L M N O P Q R S T U V W Z 

A

A - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'A'
abort(String, Throwable) - Method in interface org.apache.hadoop.hbase.client.Admin
 
abortMaster(int) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
Cause a master to exit without shutting down entire cluster.
abortProcedure(long, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.1.1 and will be removed in 4.0.0.
abortProcedure(long, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Deprecated.
since 2.1.1 and will be removed in 4.0.0.
abortProcedureAsync(long, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.1.1 and will be removed in 4.0.0.
abortRegionServer(int) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
Cause a region server to exit doing basic clean up only on its way out.
abortTask(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
 
accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.CellSerialization
 
accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.MutationSerialization
 
accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.ResultSerialization
 
AccessDeniedException - Exception in org.apache.hadoop.hbase.security
Exception thrown by access-related methods.
AccessDeniedException() - Constructor for exception org.apache.hadoop.hbase.security.AccessDeniedException
 
AccessDeniedException(Class<?>, String) - Constructor for exception org.apache.hadoop.hbase.security.AccessDeniedException
 
AccessDeniedException(String) - Constructor for exception org.apache.hadoop.hbase.security.AccessDeniedException
 
AccessDeniedException(Throwable) - Constructor for exception org.apache.hadoop.hbase.security.AccessDeniedException
 
add(Cell) - Method in class org.apache.hadoop.hbase.client.Append
Add column and value to this Append operation.
add(Cell) - Method in class org.apache.hadoop.hbase.client.Delete
Add an existing delete marker to this Delete object.
add(Cell) - Method in class org.apache.hadoop.hbase.client.Increment
Add the specified KeyValue to this operation.
add(Cell) - Method in class org.apache.hadoop.hbase.client.Put
Add the specified KeyValue to this Put operation.
add(Mutation) - Method in class org.apache.hadoop.hbase.client.RowMutations
Add a mutation
add(List<? extends Mutation>) - Method in class org.apache.hadoop.hbase.client.RowMutations
Add a list of mutations
add(String) - Method in class org.apache.hadoop.hbase.rest.client.Cluster
Add a node to the cluster
add(String, int) - Method in class org.apache.hadoop.hbase.rest.client.Cluster
Add a node to the cluster
add(DataType<?>) - Method in class org.apache.hadoop.hbase.types.StructBuilder
Append field to the sequence of accumulated fields.
add(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Concatenate byte arrays.
add(byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Concatenate byte arrays.
add(byte[][]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Concatenate byte arrays.
addAllServers(Collection<Address>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
Adds the given servers to the group.
addAllTables(Collection<TableName>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
Deprecated.
Since 3.0.0, will be removed in 4.0.0. The rsgroup information will be stored in the configuration of a table so this will be removed.
addClientPort(int) - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
Add a client port to the list.
addColumn(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Append
Add the specified column and value to this Append operation.
addColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
Delete the latest version of the specified column.
addColumn(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
Delete the specified version of the specified column.
addColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Get
Get the column from the specific family with the specified qualifier.
addColumn(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Increment
Increment the column from the specific family with the specified qualifier by the specified amount.
addColumn(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
Add the specified column and value to this Put operation.
addColumn(byte[], byte[], long, byte[]) - Method in class org.apache.hadoop.hbase.client.Put
Add the specified column and value, with the specified timestamp as its version to this Put operation.
addColumn(byte[], ByteBuffer, long, ByteBuffer) - Method in class org.apache.hadoop.hbase.client.Put
Add the specified column and value, with the specified timestamp as its version to this Put operation.
addColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
Get the column from the specified family with the specified qualifier.
addColumnFamily(TableName, ColumnFamilyDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Add a column family to an existing table.
addColumnFamily(TableName, ColumnFamilyDescriptor) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Add a column family to an existing table.
addColumnFamilyAsync(TableName, ColumnFamilyDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Add a column family to an existing table.
addColumns(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
Delete all versions of the specified column.
addColumns(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
Delete all versions of the specified column with a timestamp less than or equal to the specified timestamp.
addColumns(Scan, byte[][]) - Static method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Adds an array of columns specified using old format, family:qualifier.
addConfiguration(Map<String, String>) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor.Builder
 
addConfiguration(String, String) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor.Builder
 
addDependencyJars(JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
 
addDependencyJars(Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Add the HBase dependency jars as well as jars for any of the configured job classes to the job configuration, so that JobClient will ship them to the cluster and add them to the DistributedCache.
addDependencyJars(Configuration, Class<?>...) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Deprecated.
since 1.3.0 and will be removed in 3.0.0. Use TableMapReduceUtil.addDependencyJars(Job) instead.
addDependencyJarsForClasses(Configuration, Class<?>...) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Add the jars containing the given classes to the job's configuration such that JobClient will ship them to the cluster and add them to the DistributedCache.
addExtraHeader(String, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Add extra headers.
addFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
Delete all versions of all columns of the specified family.
addFamily(byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
Delete all columns of the specified family with a timestamp less than or equal to the specified timestamp.
addFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.Get
Get all columns from the specified family.
addFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
Get all columns from the specified family.
addFamilyVersion(byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
Delete all columns of the specified family with a timestamp equal to the specified timestamp.
addFilter(List<Filter>) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
addFilter(Filter) - Method in class org.apache.hadoop.hbase.filter.FilterList
Add a filter.
addFilterAndArguments(Configuration, Class<? extends Filter>, List<String>) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
Add a Filter to be instantiated on import
addHBaseDependencyJars(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Add HBase and its dependencies (only) to the job configuration.
addHbaseResources(Configuration) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
 
addOptions() - Method in class org.apache.hadoop.hbase.mapreduce.RowCounter
 
addOptions() - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
 
addOptions() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
 
addOptions() - Method in class org.apache.hadoop.hbase.util.RegionMover
 
addReplicationPeer(String, ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.client.Admin
Add a new replication peer for replicating data to slave cluster.
addReplicationPeer(String, ReplicationPeerConfig, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Add a new replication peer for replicating data to slave cluster.
addReplicationPeer(String, ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Add a new replication peer for replicating data to slave cluster
addReplicationPeer(String, ReplicationPeerConfig, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Add a new replication peer for replicating data to slave cluster
addReplicationPeerAsync(String, ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.client.Admin
Add a new replication peer but does not block and wait for it.
addReplicationPeerAsync(String, ReplicationPeerConfig, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Add a new replication peer but does not block and wait for it.
Address - Class in org.apache.hadoop.hbase.net
An immutable type to hold a hostname and port combo, like an Endpoint or java.net.InetSocketAddress (but without danger of our calling resolve -- we do NOT want a resolve happening every time we want to hold a hostname and port combo).
addRSGroup(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Creates a new RegionServer group with the given name
addRSGroup(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Creates a new RegionServer group with the given name
addServer(Address) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
Adds the given server to the group.
addTable(TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
Deprecated.
Since 3.0.0, will be removed in 4.0.0. The rsgroup information will be stored in the configuration of a table so this will be removed.
addToken(Token<? extends TokenIdentifier>) - Method in class org.apache.hadoop.hbase.security.User
Adds the given Token to the user's credentials.
addTypeFilter(QuotaType) - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
Add a type to the filter list
Admin - Interface in org.apache.hadoop.hbase.client
The administrative API for HBase.
ADMIN_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
 
advance() - Method in interface org.apache.hadoop.hbase.CellScanner
Advance the scanner 1 cell.
advance() - Method in class org.apache.hadoop.hbase.client.Result
 
AdvancedScanResultConsumer - Interface in org.apache.hadoop.hbase.client
This is the low level API for asynchronous scan.
AdvancedScanResultConsumer.ScanController - Interface in org.apache.hadoop.hbase.client
Used to suspend or stop a scan, or get a scan cursor if available.
AdvancedScanResultConsumer.ScanResumer - Interface in org.apache.hadoop.hbase.client
Used to resume a scan.
ALL_VERSIONS - Static variable in class org.apache.hadoop.hbase.HConstants
Define for 'return-all-versions'.
allTime() - Static method in class org.apache.hadoop.hbase.io.TimeRange
 
AND - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
AND Byte Array
AND_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
AND Array
AND_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
 
Append - Class in org.apache.hadoop.hbase.client
Performs Append operations on a single row.
Append(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Append
Create a Append operation for the specified row.
Append(Append) - Constructor for class org.apache.hadoop.hbase.client.Append
Copy constructor
Append(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.client.Append
Create a Append operation for the specified row.
Append(byte[], long, NavigableMap<byte[], List<Cell>>) - Constructor for class org.apache.hadoop.hbase.client.Append
Construct the Append with user defined data.
append(Append) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
Appends values to one or more columns within a single row.
append(Append) - Method in interface org.apache.hadoop.hbase.client.Table
Appends values to one or more columns within a single row.
appendReplicationPeerTableCFs(String, Map<TableName, List<String>>) - Method in interface org.apache.hadoop.hbase.client.Admin
Append the replicable table column family config from the specified peer.
appendReplicationPeerTableCFs(String, Map<TableName, List<String>>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Append the replicable table-cf config of the specified peer
apply(byte) - Method in enum org.apache.hadoop.hbase.util.Order
Apply order to the byte val.
apply(byte[]) - Method in enum org.apache.hadoop.hbase.util.Order
Apply order to the byte array val.
apply(byte[], int, int) - Method in enum org.apache.hadoop.hbase.util.Order
Apply order to a range within the byte array val.
areAdjacent(RegionInfo, RegionInfo) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
Check whether two regions are adjacent; i.e.
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedBlob
Deprecated.
since 3.0.0 and will be removed in 4.0.0
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedBlobVar
Deprecated.
since 3.0.0 and will be removed in 4.0.0
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedFloat32
Deprecated.
since 3.0.0 and will be removed in 4.0.0
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedFloat64
Deprecated.
since 3.0.0 and will be removed in 4.0.0
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt16
Deprecated.
since 3.0.0 and will be removed in 4.0.0
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt32
Deprecated.
since 3.0.0 and will be removed in 4.0.0
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt64
Deprecated.
since 3.0.0 and will be removed in 4.0.0
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt8
Deprecated.
since 3.0.0 and will be removed in 4.0.0
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedNumeric
Deprecated.
since 3.0.0 and will be removed in 4.0.0
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedString
Deprecated.
since 3.0.0 and will be removed in 4.0.0
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.RawBytes
Deprecated.
since 3.0.0 and will be removed in 4.0.0
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.RawString
Deprecated.
since 3.0.0 and will be removed in 4.0.0
assertKVListsEqual(String, List<? extends Cell>, List<? extends Cell>) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
assertRegionOnlyOnServer(RegionInfo, ServerName, long) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Check to make sure the region is open on the specified region server, but not on any other one.
assertRegionOnServer(RegionInfo, ServerName, long) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Due to async racing issue, a region may not be in the online region list of a region server yet, after the assignment znode is deleted and the new assignment is recorded in master.
assign(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Assign a Region.
assign(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Assign an individual region.
assignRegion(RegionInfo) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Uses directly the assignment manager to assign the region.
AsyncAdmin - Interface in org.apache.hadoop.hbase.client
The asynchronous administrative API for HBase.
AsyncAdminBuilder - Interface in org.apache.hadoop.hbase.client
For creating AsyncAdmin.
AsyncAdminClientUtils - Class in org.apache.hadoop.hbase.client
Additional Asynchronous Admin capabilities for clients.
AsyncBufferedMutator - Interface in org.apache.hadoop.hbase.client
Used to communicate with a single HBase table in batches.
AsyncBufferedMutatorBuilder - Interface in org.apache.hadoop.hbase.client
For creating AsyncBufferedMutator.
AsyncConnection - Interface in org.apache.hadoop.hbase.client
The asynchronous version of Connection.
AsyncTable<C extends ScanResultConsumerBase> - Interface in org.apache.hadoop.hbase.client
The interface for asynchronous version of Table.
AsyncTable.CoprocessorCallback<R> - Interface in org.apache.hadoop.hbase.client
The callback when we want to execute a coprocessor call on a range of regions.
AsyncTableBuilder<C extends ScanResultConsumerBase> - Interface in org.apache.hadoop.hbase.client
For creating AsyncTable.
AsyncTableRegionLocator - Interface in org.apache.hadoop.hbase.client
The asynchronous version of RegionLocator.
at(long) - Static method in class org.apache.hadoop.hbase.io.TimeRange
 
ATTRIBUTE_SEPERATOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
Attributes - Interface in org.apache.hadoop.hbase.client
 
AUTHENTICATION - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
Denotes classes that can be used to build custom authentication solutions.
AuthUtil - Class in org.apache.hadoop.hbase
Deprecated.
since 2.2.0, to be marked as InterfaceAudience.Private in 4.0.0.
available(int) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Checks to see if a specific port is available.
await(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.locking.EntityLock
 
await() - Method in class org.apache.hadoop.hbase.client.locking.EntityLock
 
await(long, BooleanSupplier) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Await the successful return of condition, sleeping sleepMillis between invocations.

B

BACKOFF_POLICY_CLASS - Static variable in interface org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicy
 
BACKSLASH - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for Backslash
BadAuthException - Exception in org.apache.hadoop.hbase.ipc
 
BadAuthException() - Constructor for exception org.apache.hadoop.hbase.ipc.BadAuthException
 
BadAuthException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.BadAuthException
 
BadAuthException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.ipc.BadAuthException
 
balance() - Method in interface org.apache.hadoop.hbase.client.Admin
Invoke the balancer.
balance(BalanceRequest) - Method in interface org.apache.hadoop.hbase.client.Admin
Invoke the balancer with the given balance request.
balance(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
Since 2.5.0. Will be removed in 4.0.0. Use Admin.balance(BalanceRequest) instead.
balance() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Invoke the balancer.
balance(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Deprecated.
Since 2.5.0. Will be removed in 4.0.0. Use AsyncAdmin.balance(BalanceRequest) instead.
balance(BalanceRequest) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Invoke the balancer with the given balance request.
BalancerDecision - Class in org.apache.hadoop.hbase.client
History of balancer decisions taken for region movements.
BalanceRequest - Class in org.apache.hadoop.hbase.client
Encapsulates options for executing a run of the Balancer.
BalanceRequest.Builder - Class in org.apache.hadoop.hbase.client
Builder for constructing a BalanceRequest
BalanceResponse - Class in org.apache.hadoop.hbase.client
Response returned from a balancer invocation
BalancerRejection - Class in org.apache.hadoop.hbase.client
History of detail information that balancer movements was rejected
balanceRSGroup(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Balance regions in the given RegionServer group
balanceRSGroup(String, BalanceRequest) - Method in interface org.apache.hadoop.hbase.client.Admin
Balance regions in the given RegionServer group, running based on the given BalanceRequest.
balanceRSGroup(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Balance regions in the given RegionServer group
balanceRSGroup(String, BalanceRequest) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Balance regions in the given RegionServer group
balancerSwitch(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Turn the load balancer on or off.
balancerSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Turn the load balancer on or off.
balancerSwitch(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Turn the load balancer on or off.
base - Variable in class org.apache.hadoop.hbase.types.FixedLengthWrapper
 
BASE_NAMESPACE_DIR - Static variable in class org.apache.hadoop.hbase.HConstants
 
BASE_TEST_DIRECTORY_KEY - Static variable in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
Deprecated.
System property key to get base test directory value
batch(List<? extends Row>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
Method that does a batch call on Deletes, Gets, Puts, Increments, Appends and RowMutations.
batch(List<? extends Row>, Object[]) - Method in interface org.apache.hadoop.hbase.client.Table
Method that does a batch call on Deletes, Gets, Puts, Increments, Appends, RowMutations.
BATCH_ROWS_THRESHOLD_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
BATCH_ROWS_THRESHOLD_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
Number of rows in a batch operation above which a warning will be logged.
batchAll(List<? extends Row>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
A simple version of batch.
batchCallback(List<? extends Row>, Object[], Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
since 3.0.0, will removed in 4.0.0. Please use the batch related methods in AsyncTable directly if you want to use callback. We reuse the callback for coprocessor here, and the problem is that for batch operation, the AsyncTable does not tell us the region, so in this method we need an extra locating after we get the result, which is not good.
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
since 3.0.0, will removed in 4.0.0. The batch call here references the blocking interface for of a protobuf stub, so it is not possible to do it in an asynchronous way, even if now we are building the Table implementation based on the AsyncTable, which is not good. Use the coprocessorService methods in AsyncTable directly instead.
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R, Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
since 3.0.0, will removed in 4.0.0. The batch call here references the blocking interface for of a protobuf stub, so it is not possible to do it in an asynchronous way, even if now we are building the Table implementation based on the AsyncTable, which is not good. Use the coprocessorService methods in AsyncTable directly instead.
between(long, long) - Static method in class org.apache.hadoop.hbase.io.TimeRange
Represents the time interval [minStamp, maxStamp)
BigDecimalComparator - Class in org.apache.hadoop.hbase.filter
A BigDecimal comparator which numerical compares against the specified byte array
BigDecimalComparator(BigDecimal) - Constructor for class org.apache.hadoop.hbase.filter.BigDecimalComparator
 
BinaryComparator - Class in org.apache.hadoop.hbase.filter
A binary comparator which lexicographically compares against the specified byte array using Bytes.compareTo(byte[], byte[]).
BinaryComparator(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.BinaryComparator
Constructor
BinaryComponentComparator - Class in org.apache.hadoop.hbase.filter
A comparator which compares against a specified byte array, but only compares specific portion of the byte array.
BinaryComponentComparator(byte[], int) - Constructor for class org.apache.hadoop.hbase.filter.BinaryComponentComparator
Constructor
BinaryPrefixComparator - Class in org.apache.hadoop.hbase.filter
A comparator which compares against a specified byte array, but only compares up to the length of this byte array.
BinaryPrefixComparator(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.BinaryPrefixComparator
Constructor
binaryPrefixType - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
BinaryPrefixType byte array
binarySearch(Cell[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
 
binarySearch(Cell[], byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
Searches for the latest value for the specified column.
binarySearch(byte[][], byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Binary search for keys in indexes using Bytes.BYTES_RAWCOMPARATOR.
binarySearch(Cell[], Cell, CellComparator) - Static method in class org.apache.hadoop.hbase.util.Bytes
Binary search for keys in indexes.
binaryType - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
BinaryType byte array
BitComparator - Class in org.apache.hadoop.hbase.filter
A bit comparator which performs the specified bitwise operation on each of the bytes with the specified byte array.
BitComparator(byte[], BitComparator.BitwiseOp) - Constructor for class org.apache.hadoop.hbase.filter.BitComparator
Constructor
BitComparator.BitwiseOp - Enum in org.apache.hadoop.hbase.filter
Bit operators.
bitOperator - Variable in class org.apache.hadoop.hbase.filter.BitComparator
 
blobVarEncodedLength(int) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Calculate the expected BlobVar encoded length based on unencoded length.
BLOCK_SIZE - Static variable in class org.apache.hadoop.hbase.io.crypto.Cipher
 
BLOCKCACHE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Key for the BLOCKCACHE attribute.
BLOCKSIZE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Size of storefile/hfile 'blocks'.
BLOOM_AND_COMPRESSION_COMBINATIONS - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
BLOOMFILTER - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
BloomType - Enum in org.apache.hadoop.hbase.regionserver
 
BOOLEAN_PARAMETERIZED - Static variable in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
Deprecated.
This is for unit tests parameterized with a two booleans.
BUCKET_CACHE_IOENGINE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Current ioengine options in include: heap, offheap and file:PATH (where PATH is the path to the file that will host the file-based cache.
BUCKET_CACHE_PERSISTENT_PATH_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
If the chosen ioengine can persist its state across restarts, the path to the file to persist to.
BUCKET_CACHE_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
When using bucket cache, it is the capacity in megabytes of the cache.
BufferedMutator - Interface in org.apache.hadoop.hbase.client
Used to communicate with a single HBase table similar to Table but meant for batched, asynchronous puts.
BufferedMutator.ExceptionListener - Interface in org.apache.hadoop.hbase.client
Listens for asynchronous exceptions on a BufferedMutator.
BufferedMutatorParams - Class in org.apache.hadoop.hbase.client
Parameters for instantiating a BufferedMutator.
BufferedMutatorParams(TableName) - Constructor for class org.apache.hadoop.hbase.client.BufferedMutatorParams
 
build() - Method in interface org.apache.hadoop.hbase.CellBuilder
 
build() - Method in interface org.apache.hadoop.hbase.client.AsyncAdminBuilder
Create a AsyncAdmin instance.
build() - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
Create the AsyncBufferedMutator instance.
build() - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
Create the AsyncTable instance.
build() - Method in class org.apache.hadoop.hbase.client.BalanceRequest.Builder
Build the BalanceRequest
build(Put) - Method in class org.apache.hadoop.hbase.client.CheckAndMutate.Builder
Build the CheckAndMutate object
build(Delete) - Method in class org.apache.hadoop.hbase.client.CheckAndMutate.Builder
Build the CheckAndMutate object
build(Increment) - Method in class org.apache.hadoop.hbase.client.CheckAndMutate.Builder
Build the CheckAndMutate object with an Increment to commit if the check succeeds.
build(Append) - Method in class org.apache.hadoop.hbase.client.CheckAndMutate.Builder
Build the CheckAndMutate object with an Append to commit if the check succeeds.
build(RowMutations) - Method in class org.apache.hadoop.hbase.client.CheckAndMutate.Builder
Build the CheckAndMutate object with a RowMutations to commit if the check succeeds.
build() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
build() - Method in class org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder
 
build() - Method in interface org.apache.hadoop.hbase.client.TableBuilder
Create the Table instance.
build() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
build() - Method in class org.apache.hadoop.hbase.NamespaceDescriptor.Builder
 
build() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
Builds the configuration object from the current state of this.
buildDependencyClasspath(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Returns a classpath string built from the content of the "tmpjars" value in conf.
builder() - Static method in class org.apache.hadoop.hbase.CacheEvictionStats
 
builder() - Static method in class org.apache.hadoop.hbase.StartMiniClusterOption
Deprecated.
Returns a new builder.
builder() - Static method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
Returns a new builder.
buildFromProto(MasterProtos.SetQuotaRequest) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettings
Converts the protocol buffer request into a QuotaSetting POJO.
buildSetQuotaRequestProto(QuotaSettings) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettings
Convert a QuotaSettings to a protocol buffer SetQuotaRequest.
BULK_OUTPUT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.Import
 
BULK_OUTPUT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
BULK_OUTPUT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.WALPlayer
 
BULKLOAD_DIR_NAME - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
Old configuration parameters (obsolete)
BULKLOAD_MAX_RETRIES_NUMBER - Static variable in class org.apache.hadoop.hbase.HConstants
Maximum time to retry for a failed bulk load request
BULKLOAD_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
 
BULKLOAD_STAGING_DIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
Staging dir used by bulk load
bypassGlobals(String, boolean) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Set the "bypass global settings" for the specified user
ByteArrayComparable - Class in org.apache.hadoop.hbase.filter
Base class for byte array comparators
ByteArrayComparable(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.ByteArrayComparable
Constructor.
ByteArrayComparator() - Constructor for class org.apache.hadoop.hbase.util.Bytes.ByteArrayComparator
 
ByteBufferOutputStream - Class in org.apache.hadoop.hbase.io
Not thread safe!
ByteBufferOutputStream(int) - Constructor for class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
ByteBufferOutputStream(int, boolean) - Constructor for class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
ByteBufferOutputStream(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
ByteRange - Interface in org.apache.hadoop.hbase.util
Lightweight, reusable class for specifying ranges of byte[]'s.
ByteRangeUtils - Class in org.apache.hadoop.hbase.util
Utility methods for working with ByteRange.
ByteRangeUtils() - Constructor for class org.apache.hadoop.hbase.util.ByteRangeUtils
 
Bytes - Class in org.apache.hadoop.hbase.util
Utility class that handles byte arrays, conversions to/from other types, comparisons, hash code generation, manufacturing keys for HashMaps or HashSets, and can be used as key in maps or trees.
Bytes() - Constructor for class org.apache.hadoop.hbase.util.Bytes
Create a zero-size sequence.
Bytes(byte[]) - Constructor for class org.apache.hadoop.hbase.util.Bytes
Create a Bytes using the byte array as the initial value.
Bytes(Bytes) - Constructor for class org.apache.hadoop.hbase.util.Bytes
Set the new Bytes to the contents of the passed ibw.
Bytes(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.util.Bytes
Set the value to a given byte range
Bytes.ByteArrayComparator - Class in org.apache.hadoop.hbase.util
Byte array comparator class.
Bytes.RowEndKeyComparator - Class in org.apache.hadoop.hbase.util
A Bytes.ByteArrayComparator that treats the empty array as the largest value.
BYTES_COMPARATOR - Static variable in class org.apache.hadoop.hbase.util.Bytes
Pass this to TreeMaps where byte [] are keys.
BYTES_PER_CHECKSUM - Static variable in class org.apache.hadoop.hbase.HConstants
The name of the configuration parameter that specifies the number of bytes in a newly created checksum chunk.
BYTES_RAWCOMPARATOR - Static variable in class org.apache.hadoop.hbase.util.Bytes
Use comparing byte arrays, byte-by-byte
bytesToVint(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Reads a zero-compressed encoded long from input buffer and returns it.

C

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
Use CellBuilderFactory to get CellBuilder instance.
CellBuilderFactory - Class in org.apache.hadoop.hbase
Create a CellBuilder instance.
CellBuilderType - Enum in org.apache.hadoop.hbase
Used by CellBuilderFactory and ExtendedCellBuilderFactory.
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 Cells
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
Deprecated.
Since 3.0.0, will be removed in 4.0.0. For internal test use only, do not use it any more.
checkAndMutate(byte[], Filter) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
Deprecated.
Since 3.0.0, will be removed in 4.0.0. For internal test use only, do not use it any more.
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
Deprecated.
Since 3.0.0, will be removed in 4.0.0. For internal test use only, do not use it any more.
checkAndMutate(byte[], Filter) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
Since 3.0.0, will be removed in 4.0.0. For internal test use only, do not use it any more.
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
Deprecated.
Since 3.0.0, will be removed in 4.0.0. For internal test use only, do not use it any more.
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
Performs a AsyncBufferedMutator.flush() and releases any resources held.
close() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
Performs a BufferedMutator.flush() and releases any resources held.
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
Close the Table and related objects that were initialized via TableInputFormatBase.initializeTable(Connection, TableName).
closeTable() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Close the Table and related objects that were initialized via TableInputFormatBase.initializeTable(Connection, TableName).
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
Different from SingleColumnValueFilter which returns an entire row when specified condition is matched, ColumnValueFilter return the matched cell only.
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
Analogous to HFileOutputFormat2.configureIncrementalLoad(Job, TableDescriptor, RegionLocator), this function will configure the requisite number of reducers to write HFiles for multple tables simultaneously
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 Connections.
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
Deprecated.
Since 3.0.0, will be removed in 4.0.0. The rsgroup information will be stored in the configuration of a table so this will be removed.
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
Used to build the CoprocessorDescriptor
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
Deprecated.
Please stop using this class again, as it is too low level, which is part of the rpc framework for HBase. Will be deleted in 4.0.0.
coprocessorService() - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 3.0.0, will removed in 4.0.0. This is too low level, please stop using it any more. Use the coprocessorService methods in AsyncAdmin instead.
coprocessorService(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 3.0.0, will removed in 4.0.0. This is too low level, please stop using it any more. Use the coprocessorService methods in AsyncAdmin instead.
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
Deprecated.
since 3.0.0, will removed in 4.0.0. This is too low level, please stop using it any more. Use the coprocessorService methods in AsyncTable instead.
coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
since 3.0.0, will removed in 4.0.0. The batch call here references the blocking interface for of a protobuf stub, so it is not possible to do it in an asynchronous way, even if now we are building the Table implementation based on the AsyncTable, which is not good. Use the coprocessorService methods in AsyncTable directly instead.
coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>, Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
since 3.0.0, will removed in 4.0.0. The batch call here references the blocking interface for of a protobuf stub, so it is not possible to do it in an asynchronous way, even if now we are building the Table implementation based on the AsyncTable, which is not good. Use the coprocessorService methods in AsyncTable directly instead.
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
Constructs a RequestController.
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
Deprecated.
since 0.98.9
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
Call ConnectionFactory.createAsyncConnection(Configuration) using default HBaseConfiguration.
createAsyncConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
Call ConnectionFactory.createAsyncConnection(Configuration, User) using the given conf and a User object created by UserProvider.
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.
Return a region on which you must call HBaseTestingUtility.closeRegionAndWAL(HRegion) when done.
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.
Same as HBaseTestingUtility.createRootDir(boolean create) except that create flag is false.
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
Deprecated.
as of release 2.3.0. Will be removed on 4.0.0. Please use main method instead.
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
Scan cursor to tell client where server is scanning Scan.setNeedCursorResult(boolean) Result.isCursor() Result.getCursor()
CUSTOM_FILTERS - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 

D

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.
DecommissionedHostRejectedException - Exception in org.apache.hadoop.hbase.ipc
 
DecommissionedHostRejectedException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.DecommissionedHostRejectedException
 
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_OLDWAL_DIR_SIZE_UPDATER_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
Default value for the oldWALs directory size updater period
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
Deprecated.
since 2.4.0 and in 3.0.0, to be removed in 4.0.0.
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
The context used to normalize BigDecimal values.
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
Deprecated.
Since 2.4.0, will be removed in 4.0.0. Please change the meta replicas number by altering meta table, i.e, set a new 'region replication' number and call modifyTable.
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_REST_SCANNERCACHE_EXPIRE_TIME_MS - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
DEFAULT_REST_SCANNERCACHE_SIZE - 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
Deprecated.
since 3.0.0 and will b removed in 4.0.0
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedBlobVar
Deprecated.
since 3.0.0 and will be removed in 4.0.0
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedFloat32
Deprecated.
since 3.0.0 and will be removed in 4.0.0
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedFloat64
Deprecated.
since 3.0.0 and will be removed in 4.0.0
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt16
Deprecated.
since 3.0.0 and will be removed in 4.0.0
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt32
Deprecated.
since 3.0.0 and will be removed in 4.0.0
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt64
Deprecated.
since 3.0.0 and will be removed in 4.0.0
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt8
Deprecated.
since 3.0.0 and will be removed in 4.0.0
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedNumeric
Deprecated.
since 3.0.0 and will be removed in 4.0.0
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedString
Deprecated.
since 3.0.0 and will be removed in 4.0.0
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.RawBytes
Deprecated.
since 3.0.0 and will be removed in 4.0.0
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.RawString
Deprecated.
since 3.0.0 and will be removed in 4.0.0
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 Mutations 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
Durability setting for the table.

E

E - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'E'
EMPTY_BYTE_ARRAY - Static variable in class org.apache.hadoop.hbase.HConstants
An empty byte array instance.
EMPTY_BYTE_BUFFER - Static variable in class org.apache.hadoop.hbase.HConstants
 
EMPTY_END_ROW - Static variable in class org.apache.hadoop.hbase.HConstants
Last row in a table.
EMPTY_HEADER_ARRAY - Static variable in class org.apache.hadoop.hbase.rest.client.Client
 
EMPTY_RESULT - Static variable in class org.apache.hadoop.hbase.client.Result
 
EMPTY_SERVER_LIST - Static variable in class org.apache.hadoop.hbase.ServerName
 
EMPTY_START_ROW - Static variable in class org.apache.hadoop.hbase.HConstants
Used by scanners, etc when they want to start at the beginning of a region
EMPTY_STRING - Static variable in class org.apache.hadoop.hbase.HConstants
An empty string instance.
EMPTY_STRING - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
EMPTY_VALUE_ON_MOBCELL_MISS - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
ENABLE_CLIENT_BACKPRESSURE - Static variable in class org.apache.hadoop.hbase.HConstants
Config key for if the server should send backpressure and if the client should listen to that backpressure from the server
ENABLE_DATA_FILE_UMASK - Static variable in class org.apache.hadoop.hbase.HConstants
Enable file permission modification from standard hbase
ENABLE_WAL_COMPRESSION - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration name of WAL Compression
ENABLE_WAL_ENCRYPTION - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for enabling WAL encryption, a boolean
enableDebug(Class<?>) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
In 2.3.0, will be removed in 4.0.0. Only support changing log level on log4j now as HBase only uses log4j. You should do this by your own as it you know which log framework you are using then set the log level to debug is very easy.
enableReplicationPeer(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Restart the replication stream to the specified peer.
enableReplicationPeer(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Restart the replication stream to the specified peer
enableReplicationPeerAsync(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Enable a replication peer but does not block and wait for it.
enableTable(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Enable a table.
enableTable(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Enable a table.
enableTableAsync(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Enable the table but does not block and wait for it to be completely enabled.
enableTableReplication(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Enable a table's replication switch.
enableTableReplication(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Enable a table's replication switch.
ENC_SEPARATOR - Static variable in interface org.apache.hadoop.hbase.client.RegionInfo
Separator used to demarcate the encodedName in a region name in the new format.
encode(PositionedByteRange, T) - Method in interface org.apache.hadoop.hbase.types.DataType
Write instance val into buffer dst.
encode(PositionedByteRange, T) - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
 
encode(PositionedByteRange, byte[]) - Method in class org.apache.hadoop.hbase.types.OrderedBlob
 
encode(PositionedByteRange, byte[], int, int) - Method in class org.apache.hadoop.hbase.types.OrderedBlob
Write a subset of val to dst.
encode(PositionedByteRange, byte[]) - Method in class org.apache.hadoop.hbase.types.OrderedBlobVar
 
encode(PositionedByteRange, byte[], int, int) - Method in class org.apache.hadoop.hbase.types.OrderedBlobVar
Write a subset of val to dst.
encode(PositionedByteRange, Float) - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
 
encode(PositionedByteRange, Double) - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
 
encode(PositionedByteRange, Short) - Method in class org.apache.hadoop.hbase.types.OrderedInt16
 
encode(PositionedByteRange, Integer) - Method in class org.apache.hadoop.hbase.types.OrderedInt32
 
encode(PositionedByteRange, Long) - Method in class org.apache.hadoop.hbase.types.OrderedInt64
 
encode(PositionedByteRange, Byte) - Method in class org.apache.hadoop.hbase.types.OrderedInt8
 
encode(PositionedByteRange, Number) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
 
encode(PositionedByteRange, String) - Method in class org.apache.hadoop.hbase.types.OrderedString
 
encode(PositionedByteRange, Byte) - Method in class org.apache.hadoop.hbase.types.RawByte
 
encode(PositionedByteRange, byte[]) - Method in class org.apache.hadoop.hbase.types.RawBytes
 
encode(PositionedByteRange, byte[], int, int) - Method in class org.apache.hadoop.hbase.types.RawBytes
Write val into dst, respecting voff and vlen.
encode(PositionedByteRange, byte[], int, int) - Method in class org.apache.hadoop.hbase.types.RawBytesFixedLength
Write val into buff, respecting offset and length.
encode(PositionedByteRange, byte[], int, int) - Method in class org.apache.hadoop.hbase.types.RawBytesTerminated
Write val into dst, respecting offset and length.
encode(PositionedByteRange, Double) - Method in class org.apache.hadoop.hbase.types.RawDouble
 
encode(PositionedByteRange, Float) - Method in class org.apache.hadoop.hbase.types.RawFloat
 
encode(PositionedByteRange, Integer) - Method in class org.apache.hadoop.hbase.types.RawInteger
 
encode(PositionedByteRange, Long) - Method in class org.apache.hadoop.hbase.types.RawLong
 
encode(PositionedByteRange, Short) - Method in class org.apache.hadoop.hbase.types.RawShort
 
encode(PositionedByteRange, String) - Method in class org.apache.hadoop.hbase.types.RawString
 
encode(PositionedByteRange, Object[]) - Method in class org.apache.hadoop.hbase.types.Struct
 
encode(PositionedByteRange, T) - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
Write instance val into buffer dst.
encodeBlobCopy(PositionedByteRange, byte[], int, int, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a Blob value as a byte-for-byte copy.
encodeBlobCopy(PositionedByteRange, byte[], Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a Blob value as a byte-for-byte copy.
encodeBlobVar(PositionedByteRange, byte[], int, int, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a Blob value using a modified varint encoding scheme.
encodeBlobVar(PositionedByteRange, byte[], Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a blob value using a modified varint encoding scheme.
encodeByte(PositionedByteRange, byte) - Method in class org.apache.hadoop.hbase.types.OrderedInt8
Write instance val into buffer dst.
encodeByte(byte[], int, byte) - Method in class org.apache.hadoop.hbase.types.RawByte
Write instance val into buffer buff.
encodedClass() - Method in interface org.apache.hadoop.hbase.types.DataType
Inform consumers over what type this DataType operates.
encodedClass() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedBlob
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedBlobVar
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedInt16
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedInt32
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedInt64
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedInt8
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedString
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.RawByte
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.RawBytes
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.RawDouble
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.RawFloat
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.RawInteger
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.RawLong
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.RawShort
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.RawString
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.Struct
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.Union2
 
encodedLength(T) - Method in interface org.apache.hadoop.hbase.types.DataType
Inform consumers how long the encoded byte[] will be.
encodedLength(T) - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
 
encodedLength(byte[]) - Method in class org.apache.hadoop.hbase.types.OrderedBlob
 
encodedLength(byte[]) - Method in class org.apache.hadoop.hbase.types.OrderedBlobVar
 
encodedLength(Float) - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
 
encodedLength(Double) - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
 
encodedLength(Short) - Method in class org.apache.hadoop.hbase.types.OrderedInt16
 
encodedLength(Integer) - Method in class org.apache.hadoop.hbase.types.OrderedInt32
 
encodedLength(Long) - Method in class org.apache.hadoop.hbase.types.OrderedInt64
 
encodedLength(Byte) - Method in class org.apache.hadoop.hbase.types.OrderedInt8
 
encodedLength(Number) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
 
encodedLength(String) - Method in class org.apache.hadoop.hbase.types.OrderedString
 
encodedLength(Byte) - Method in class org.apache.hadoop.hbase.types.RawByte
 
encodedLength(byte[]) - Method in class org.apache.hadoop.hbase.types.RawBytes
 
encodedLength(Double) - Method in class org.apache.hadoop.hbase.types.RawDouble
 
encodedLength(Float) - Method in class org.apache.hadoop.hbase.types.RawFloat
 
encodedLength(Integer) - Method in class org.apache.hadoop.hbase.types.RawInteger
 
encodedLength(Long) - Method in class org.apache.hadoop.hbase.types.RawLong
 
encodedLength(Short) - Method in class org.apache.hadoop.hbase.types.RawShort
 
encodedLength(String) - Method in class org.apache.hadoop.hbase.types.RawString
 
encodedLength(Object[]) - Method in class org.apache.hadoop.hbase.types.Struct
 
encodedLength(T) - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
 
encodeDouble(PositionedByteRange, double) - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
Write instance val into buffer dst.
encodeDouble(PositionedByteRange, double) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
Write instance val into buffer dst.
encodeDouble(byte[], int, double) - Method in class org.apache.hadoop.hbase.types.RawDouble
Write instance val into buffer buff.
encodeFloat(PositionedByteRange, float) - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
Write instance val into buffer buff.
encodeFloat(byte[], int, float) - Method in class org.apache.hadoop.hbase.types.RawFloat
Write instance val into buffer buff.
encodeFloat32(PositionedByteRange, float, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a 32-bit floating point value using the fixed-length encoding.
encodeFloat64(PositionedByteRange, double, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a 64-bit floating point value using the fixed-length encoding.
encodeInt(PositionedByteRange, int) - Method in class org.apache.hadoop.hbase.types.OrderedInt32
Write instance val into buffer dst.
encodeInt(byte[], int, int) - Method in class org.apache.hadoop.hbase.types.RawInteger
Write instance val into buffer buff.
encodeInt16(PositionedByteRange, short, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode an int16 value using the fixed-length encoding.
encodeInt32(PositionedByteRange, int, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode an int32 value using the fixed-length encoding.
encodeInt64(PositionedByteRange, long, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode an int64 value using the fixed-length encoding.
encodeInt8(PositionedByteRange, byte, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode an int8 value using the fixed-length encoding.
encodeLong(PositionedByteRange, long) - Method in class org.apache.hadoop.hbase.types.OrderedInt64
Write instance val into buffer dst.
encodeLong(PositionedByteRange, long) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
Write instance val into buffer dst.
encodeLong(byte[], int, long) - Method in class org.apache.hadoop.hbase.types.RawLong
Write instance val into buffer buff.
encodeNull(PositionedByteRange, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a null value.
encodeNumeric(PositionedByteRange, long, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a numerical value using the variable-length encoding.
encodeNumeric(PositionedByteRange, double, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a numerical value using the variable-length encoding.
encodeNumeric(PositionedByteRange, BigDecimal, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a numerical value using the variable-length encoding.
encodeRegionName(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
Returns the encodedName
encodeShort(PositionedByteRange, short) - Method in class org.apache.hadoop.hbase.types.OrderedInt16
Write instance val into buffer dst.
encodeShort(byte[], int, short) - Method in class org.apache.hadoop.hbase.types.RawShort
Write instance val into buffer buff.
encodeString(PositionedByteRange, String, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a String value.
encrypt(OutputStream, byte[], int, int, Encryptor) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Encrypt a block of plaintext
encrypt(OutputStream, byte[], int, int, Encryption.Context, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Encrypt a block of plaintext
encrypt(OutputStream, InputStream, Encryptor) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Encrypt a stream of plaintext given an encryptor
encrypt(OutputStream, InputStream, Encryption.Context, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Encrypt a stream of plaintext given a context and IV
ENCRYPTION - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
Encryption - Class in org.apache.hadoop.hbase.io.crypto
A facade for encryption algorithms and related support.
Encryption.Context - Class in org.apache.hadoop.hbase.io.crypto
Crypto context
ENCRYPTION_KEY - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
Encryptor - Interface in org.apache.hadoop.hbase.io.crypto
Encryptors apply a cipher to an OutputStream to produce ciphertext.
encryptWithSubjectKey(OutputStream, InputStream, String, Configuration, Cipher, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Encrypts a block of plaintext with the symmetric key resolved for the given subject
END - Static variable in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
Deprecated.
since 0.90.0
END_TIME_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.WALInputFormat
 
ENSEMBLE_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
The name of the ensemble table
ensureSomeNonStoppedRegionServersAvailable(int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Make sure that at least the specified number of region servers are running.
ensureSomeRegionServersAvailable(int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Make sure that at least the specified number of region servers are running
EntityLock - Class in org.apache.hadoop.hbase.client.locking
Lock for HBase Entity either a Table, a Namespace, or Regions.
EQUAL_TO - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for equal to (=)
EQUAL_TO_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
EQUAL_TO Array
EQUAL_TO_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
 
equals(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
equals
equals(Object) - Method in class org.apache.hadoop.hbase.client.Get
 
equals(Object) - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
Deprecated.
 
equals(Object) - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.BigDecimalComparator
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.BinaryComponentComparator
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.FamilyFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.NullComparator
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.QualifierFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.RowFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.ValueFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.HRegionLocation
 
equals(Object) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
equals(Object) - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
equals(Object) - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
 
equals(Object) - Method in class org.apache.hadoop.hbase.net.Address
 
equals(Object) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
 
equals(Object) - Method in class org.apache.hadoop.hbase.security.User
 
equals(Object) - Method in class org.apache.hadoop.hbase.ServerName
 
equals(Object) - Method in class org.apache.hadoop.hbase.Size
 
equals(Object) - Method in class org.apache.hadoop.hbase.TableName
 
equals(Object) - Method in class org.apache.hadoop.hbase.util.Bytes
 
equals(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Lexicographically determine the equality of two arrays.
equals(byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Lexicographically determine the equality of two arrays.
equals(byte[], ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.Bytes
Lexicographically determine the equality of two byte[], one as ByteBuffer.
equals(List<byte[]>, List<byte[]>) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
equals(Object) - Method in class org.apache.hadoop.hbase.util.Pair
 
equals(Object) - Method in class org.apache.hadoop.hbase.util.PairOfSameType
 
equals(Object) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
 
equals(Object) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
 
ERASURE_CODING_POLICY - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
If non-null, the HDFS erasure coding policy to set on the data dir of the table
ESTIMATED_HEAP_TAX - Static variable in class org.apache.hadoop.hbase.util.Bytes
Estimate of size cost to pay beyond payload in jvm for instance of byte [].
EVENT_LOOP_CONFIG - Static variable in class org.apache.hadoop.hbase.ipc.NettyRpcClientConfigHelper
 
EVICT_BLOCKS_ON_CLOSE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
exceedThrottleQuotaSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Switch the exceed throttle quota.
exceedThrottleQuotaSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Switch the exceed throttle quota.
execProcedure(String, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.client.Admin
Execute a distributed procedure on a cluster.
execProcedure(String, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Execute a distributed procedure on a cluster.
execProcedureWithReturn(String, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.client.Admin
Execute a distributed procedure on a cluster.
execProcedureWithReturn(String, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Execute a distributed procedure on a cluster.
execute(Cluster, HttpUriRequest, Header[], String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Execute a transaction method.
executePathOnly(Cluster, HttpUriRequest, Header[], String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Execute a transaction method given only the path.
executeURI(HttpUriRequest, Header[], String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Execute a transaction method given a complete URI.
EXECUTOR_STATUS_COLLECT_ENABLED - Static variable in class org.apache.hadoop.hbase.HConstants
 
exists(Get) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
Test for the existence of columns in the table, as specified by the Get.
exists(List<Get>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
Test for the existence of columns in the table, as specified by the Gets.
exists(Get) - Method in interface org.apache.hadoop.hbase.client.Table
Test for the existence of columns in the table, as specified by the Get.
exists(List<Get>) - Method in interface org.apache.hadoop.hbase.client.Table
Test for the existence of columns in the table, as specified by the Gets.
existsAll(List<Get>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
A simple version for batch exists.
expireMasterSession() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Expire the Master's session
expireRegionServerSession(int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Expire a region server's session
expireSession(ZKWatcher) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
expireSession(ZKWatcher, boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Expire a ZooKeeper session as recommended in ZooKeeper documentation http://hbase.apache.org/book.html#trouble.zookeeper There are issues when doing this: [1] http://www.mail-archive.com/dev@zookeeper.apache.org/msg01942.html [2] https://issues.apache.org/jira/browse/ZOOKEEPER-1105
explainTableAvailability(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
explainTableState(TableName, TableState.State) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
ExponentialClientBackoffPolicy - Class in org.apache.hadoop.hbase.client.backoff
Simple exponential backoff policy on for the client that uses a percent^4 times the max backoff to generate the backoff time.
ExponentialClientBackoffPolicy(Configuration) - Constructor for class org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
 
Export - Class in org.apache.hadoop.hbase.mapreduce
Export an HBase table.
Export() - Constructor for class org.apache.hadoop.hbase.mapreduce.Export
 
ExportSnapshot - Class in org.apache.hadoop.hbase.snapshot
Export the specified snapshot to a given FileSystem.
ExportSnapshot() - Constructor for class org.apache.hadoop.hbase.snapshot.ExportSnapshot
 
ExportSnapshotException - Exception in org.apache.hadoop.hbase.snapshot
Thrown when a snapshot could not be exported due to an error during the operation.
ExportSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.ExportSnapshotException
 
ExportSnapshotException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.snapshot.ExportSnapshotException
 
EXTENDED_CELL_SERIALIZATION_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
ExtendedCell and ExtendedCellSerialization are InterfaceAudience.Private.
extractArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.CompareFilter
Returns an array of heterogeneous objects
extractFilterSimpleExpression(byte[], int) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
Extracts a simple filter expression from the filter string given by the user
extractKeyValues(Result) - Method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
Extract columns values from the current record.
extractKeyValues(Result) - Method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
Extract columns values from the current record.
extraHeapSize() - Method in class org.apache.hadoop.hbase.client.Append
 
extraHeapSize() - Method in class org.apache.hadoop.hbase.client.Increment
 
extraHeapSize() - Method in class org.apache.hadoop.hbase.client.Mutation
Subclasses should override this method to add the heap size of their own fields.

F

FailedLogCloseException - Exception in org.apache.hadoop.hbase.regionserver.wal
Thrown when we fail close of the write-ahead-log file.
FailedLogCloseException() - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.FailedLogCloseException
 
FailedLogCloseException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.FailedLogCloseException
 
FailedLogCloseException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.FailedLogCloseException
 
FailedLogCloseException(Throwable) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.FailedLogCloseException
 
FailedSanityCheckException - Exception in org.apache.hadoop.hbase.exceptions
Exception thrown if a mutation fails sanity checks.
FailedSanityCheckException() - Constructor for exception org.apache.hadoop.hbase.exceptions.FailedSanityCheckException
default constructor
FailedSanityCheckException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.FailedSanityCheckException
 
FailedSanityCheckException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.FailedSanityCheckException
 
FailedServerException - Exception in org.apache.hadoop.hbase.ipc
Indicates that we're trying to connect to a already known as dead server.
FailedServerException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.FailedServerException
 
FailedSyncBeforeLogCloseException - Exception in org.apache.hadoop.hbase.regionserver.wal
Thrown when we fail close of the write-ahead-log file.
FailedSyncBeforeLogCloseException() - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.FailedSyncBeforeLogCloseException
 
FailedSyncBeforeLogCloseException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.FailedSyncBeforeLogCloseException
 
FailedSyncBeforeLogCloseException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.FailedSyncBeforeLogCloseException
 
FailedSyncBeforeLogCloseException(Throwable) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.FailedSyncBeforeLogCloseException
 
failOnHashAlgorithmMismatch(Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Returns the Hash Algorithm mismatch behaviour defined in the crypto configuration.
FallbackDisallowedException - Exception in org.apache.hadoop.hbase.ipc
Indicate that the rpc server tells client to fallback to simple auth but client is disabled to do so.
FallbackDisallowedException() - Constructor for exception org.apache.hadoop.hbase.ipc.FallbackDisallowedException
 
fam1 - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
fam2 - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
fam3 - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
FAMILY_KEY_STR - Static variable in class org.apache.hadoop.hbase.HConstants
The family str as a key in map
FamilyFilter - Class in org.apache.hadoop.hbase.filter
This filter is used to filter based on the column family.
FamilyFilter(CompareOperator, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.FamilyFilter
Constructor.
familyMap - Variable in class org.apache.hadoop.hbase.client.Mutation
 
familySet() - Method in class org.apache.hadoop.hbase.client.Get
Method for retrieving the keys in the familyMap
FatalConnectionException - Exception in org.apache.hadoop.hbase.ipc
Thrown when server finds fatal issue w/ connection setup: e.g.
FatalConnectionException() - Constructor for exception org.apache.hadoop.hbase.ipc.FatalConnectionException
 
FatalConnectionException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.FatalConnectionException
 
FatalConnectionException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.ipc.FatalConnectionException
 
fields - Variable in class org.apache.hadoop.hbase.types.Struct
 
fields - Variable in class org.apache.hadoop.hbase.types.StructBuilder
 
FILE_SYSTEM_VERSION - Static variable in class org.apache.hadoop.hbase.HConstants
Current version of file system.
FileSystemVersionException - Exception in org.apache.hadoop.hbase.util
Thrown when the file system needs to be upgraded
FileSystemVersionException() - Constructor for exception org.apache.hadoop.hbase.util.FileSystemVersionException
default constructor
FileSystemVersionException(String) - Constructor for exception org.apache.hadoop.hbase.util.FileSystemVersionException
 
filter - Variable in class org.apache.hadoop.hbase.client.Query
 
Filter - Class in org.apache.hadoop.hbase.filter
Interface for row and column filters directly applied within the regionserver.
Filter() - Constructor for class org.apache.hadoop.hbase.filter.Filter
 
FILTER - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
Filter.ReturnCode - Enum in org.apache.hadoop.hbase.filter
Return codes for filterValue().
FILTER_ARGS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.Import
 
FILTER_B64 - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
FILTER_CLASS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.Import
 
FILTER_CLASSES - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
FILTER_PACKAGE - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
Package containing filters
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.Filter
If this returns true, the scan will terminate.
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.FilterList
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
 
filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.FamilyFilter
 
filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.Filter
A way to filter based on the column family, column qualifier and/or the column value.
filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
 
filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.QualifierFilter
 
filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.RowFilter
 
filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
 
filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.ValueFilter
 
filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
filterColumn(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
filterColumn(Cell) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
filterIfMissing - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
filterKv(Filter, Cell) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
Attempt to filter out the keyvalue
FilterList - Class in org.apache.hadoop.hbase.filter
Implementation of Filter that represents an ordered List of Filters which will be evaluated with a specified boolean operator FilterList.Operator.MUST_PASS_ALL (AND) or FilterList.Operator.MUST_PASS_ONE (OR).
FilterList(FilterList.Operator, List<Filter>) - Constructor for class org.apache.hadoop.hbase.filter.FilterList
Constructor that takes a set of Filters and an operator.
FilterList(List<Filter>) - Constructor for class org.apache.hadoop.hbase.filter.FilterList
Constructor that takes a set of Filters.
FilterList(Filter...) - Constructor for class org.apache.hadoop.hbase.filter.FilterList
Constructor that takes a var arg number of Filters.
FilterList(FilterList.Operator) - Constructor for class org.apache.hadoop.hbase.filter.FilterList
Constructor that takes an operator.
FilterList(FilterList.Operator, Filter...) - Constructor for class org.apache.hadoop.hbase.filter.FilterList
Constructor that takes a var arg number of Filters and an operator.
FilterList.Operator - Enum in org.apache.hadoop.hbase.filter
set operator
filterOutRow - Variable in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.Filter
Last chance to veto row based on previous Filter.filterCell(Cell) calls.
filterRow() - Method in class org.apache.hadoop.hbase.filter.FilterList
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
filterRow - Variable in class org.apache.hadoop.hbase.filter.PrefixFilter
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.RowFilter
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
filterRowCells(List<Cell>) - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
filterRowCells(List<Cell>) - Method in class org.apache.hadoop.hbase.filter.Filter
Chance to alter the list of Cells to be submitted.
filterRowCells(List<Cell>) - Method in class org.apache.hadoop.hbase.filter.FilterList
Filters that never filter by modifying the returned List of Cells can inherit this implementation that does nothing.
filterRowCells(List<Cell>) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
 
filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
 
filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.Filter
Filters a row based on the row key.
filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.RowFilter
 
filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
 
filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
findCommonPrefix(byte[], byte[], int, int, int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
findLastTableState(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
findRegionsForTable(TableName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
 
first - Variable in class org.apache.hadoop.hbase.util.Pair
 
FIRST_CHAR - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
FirstKeyOnlyFilter - Class in org.apache.hadoop.hbase.filter
A filter that will only return the first KV from each row.
FirstKeyOnlyFilter() - Constructor for class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
FirstKeyValueMatchingQualifiersFilter - Class in org.apache.hadoop.hbase.filter
Deprecated.
Deprecated in 2.0.0 and will be removed in 3.0.0.
FirstKeyValueMatchingQualifiersFilter() - Constructor for class org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
Deprecated.
 
FixedLengthWrapper<T> - Class in org.apache.hadoop.hbase.types
Wraps an existing DataType implementation as a fixed-length version of itself.
FixedLengthWrapper(DataType<T>, int) - Constructor for class org.apache.hadoop.hbase.types.FixedLengthWrapper
Create a fixed-length version of the wrapped.
flush(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Flush a table.
flush(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Flush the specified column family stores on all regions of the passed table.
flush(TableName, List<byte[]>) - Method in interface org.apache.hadoop.hbase.client.Admin
Flush the specified column family stores on all regions of the passed table.
flush(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Flush a table.
flush(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Flush the specified column family stores on all regions of the passed table.
flush(TableName, List<byte[]>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Flush the specified column family stores on all regions of the passed table.
flush() - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutator
Executes all the buffered, asynchronous operations.
flush() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
Executes all the buffered, asynchronous Mutation operations and waits until they are done.
flush() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Flushes all caches in the mini hbase cluster
flush(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Flushes all caches in the mini hbase cluster
flush() - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
FLUSH_POLICY - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
flushcache() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
Call flushCache on all regions on all participating regionservers.
flushcache(TableName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
Call flushCache on all regions of the specified table.
flushMasterStore() - Method in interface org.apache.hadoop.hbase.client.Admin
Flush master local region
flushMasterStore() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Flush master local region
flushRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Flush an individual region.
flushRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Flush a column family within a region.
flushRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Flush an individual region.
flushRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Flush a column family within a region.
flushRegionServer(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
Flush all regions on the region server.
flushRegionServer(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Flush all region on the region server.
flushRegionsIfNecessary(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
If the durability is set to Durability.SKIP_WAL and the data is imported to hbase, we need to flush all the regions of the table as the data is held in memory and is also not present in the Write Ahead Log to replay in scenarios of a crash.
ForeignException - Exception in org.apache.hadoop.hbase.errorhandling
A ForeignException is an exception from another thread or process.
ForeignException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.errorhandling.ForeignException
Create a new ForeignException that can be serialized.
ForeignException(String, String) - Constructor for exception org.apache.hadoop.hbase.errorhandling.ForeignException
Create a new ForeignException that can be serialized.
FOREVER - Static variable in class org.apache.hadoop.hbase.HConstants
Unlimited time-to-live.
foundColumn - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
from(long) - Static method in class org.apache.hadoop.hbase.io.TimeRange
Represents the time interval [minStamp, Long.MAX_VALUE)
fromArrays(Collection<byte[]>) - Static method in class org.apache.hadoop.hbase.util.ByteRangeUtils
 
fromByte(byte) - Static method in enum org.apache.hadoop.hbase.client.IsolationLevel
 
fromBytes(byte[]) - Static method in enum org.apache.hadoop.hbase.client.IsolationLevel
 
fromHex(String) - Static method in class org.apache.hadoop.hbase.util.Bytes
Create a byte array from a string of hash digits.
fromJson(String, Class<T>) - Static method in class org.apache.hadoop.hbase.util.JsonMapper
 
fromParts(String, int) - Static method in class org.apache.hadoop.hbase.net.Address
 
fromSocketAddress(InetSocketAddress) - Static method in class org.apache.hadoop.hbase.net.Address
 
fromString(String) - Static method in class org.apache.hadoop.hbase.net.Address
 
fromTableThrottles(TableName, QuotaProtos.Throttle) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
 
fromThrottle(String, TableName, String, String, QuotaProtos.Throttle) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
 
FULL_MOB_COMPACTION_TYPE - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
FuzzyRowFilter - Class in org.apache.hadoop.hbase.filter
This is optimized version of a standard FuzzyRowFilter Filters data based on fuzzy row key.
FuzzyRowFilter(List<Pair<byte[], byte[]>>) - Constructor for class org.apache.hadoop.hbase.filter.FuzzyRowFilter
 

G

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
Returns an AsyncAdminBuilder for creating AsyncAdmin.
getAdminBuilder(ExecutorService) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
Returns an AsyncAdminBuilder for creating AsyncAdmin.
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
Deprecated.
Deprecated since 2.2.0, this method will be InterfaceAudience.Private use only after 4.0.0.
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
Returns current backup master list wrapped by CompletableFuture
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
Retrieve an AsyncBufferedMutator for performing client-side buffering of writes.
getBufferedMutator(TableName, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
Retrieve an AsyncBufferedMutator for performing client-side buffering of writes.
getBufferedMutator(TableName) - Method in interface org.apache.hadoop.hbase.client.Connection
Retrieve a BufferedMutator for performing client-side buffering of writes.
getBufferedMutator(BufferedMutatorParams) - Method in interface org.apache.hadoop.hbase.client.Connection
Retrieve a BufferedMutator for performing client-side buffering of writes.
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
Returns cluster status wrapped by CompletableFuture
getClusterMetrics(EnumSet<ClusterMetrics.Option>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Returns cluster status wrapped by CompletableFuture
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
Returns an unmodifiable collection of all the ColumnFamilyDescriptor of all the column families of the table.
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
Getter for fetching an unmodifiable NamespaceDescriptor.configuration map.
getConfiguration() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
getConfiguration() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
Getter for fetching an unmodifiable RSGroupInfo.configuration map.
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.
Returns a Path in the test filesystem, obtained from HBaseTestingUtility.getTestFileSystem() to write temporary test data.
getDataTestDirOnTestFS(String) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Returns a Path in the test filesystem, obtained from HBaseTestingUtility.getTestFileSystem() to write temporary test data.
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.
Same as {HBaseTestingUtility.getDefaultRootDirPath(boolean create) except that create flag is false.
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
Gets the TableDescriptor for this table.
getDescriptor() - Method in interface org.apache.hadoop.hbase.client.Table
Gets the table descriptor for this 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.
getEndKey() - Method in class org.apache.hadoop.hbase.HbckRegionDetails
 
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.
getErasureCodingPolicy() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
The HDFS erasure coding policy for a table.
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.
getFsReadTime() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
 
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.HbckServerName
 
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
Deprecated.
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)
getHostPort() - Method in class org.apache.hadoop.hbase.HbckServerName
 
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
Deprecated.
Since 3.0.0, will be removed in 4.0.0. You can not set it any more as the implementation has to use too many internal stuffs in HBase.
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
 
getListOfServers() - Method in class org.apache.hadoop.hbase.HbckInconsistentRegions
 
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
Returns current master server name wrapped by CompletableFuture
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
Returns a list of master coprocessors wrapped by CompletableFuture
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
The number of moves calculated by the balancer if BalanceResponse.isBalancerRan() is true.
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
Deprecated.
Since 3.0.0-alpha-2, will be removed in 4.0.0. You can not set it anymore. BufferedMutator will use Connection's ExecutorService.
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.
getRegion1Info() - Method in class org.apache.hadoop.hbase.HbckOverlapRegions
 
getRegion1Info() - Method in class org.apache.hadoop.hbase.HbckRegionHoles
 
getRegion2Info() - Method in class org.apache.hadoop.hbase.HbckOverlapRegions
 
getRegion2Info() - Method in class org.apache.hadoop.hbase.HbckRegionHoles
 
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
getRegionHdfsPath() - Method in class org.apache.hadoop.hbase.HbckOrphanRegionsOnFS
 
getRegionId() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
Returns the regionId.
getRegionId() - Method in class org.apache.hadoop.hbase.HbckInconsistentRegions
 
getRegionId() - Method in class org.apache.hadoop.hbase.HbckOrphanRegionsOnFS
 
getRegionId() - Method in class org.apache.hadoop.hbase.HbckOrphanRegionsOnRS
 
getRegionId() - Method in class org.apache.hadoop.hbase.HbckRegionDetails
 
getRegionInfo() - Method in class org.apache.hadoop.hbase.HbckEmptyRegionInfo
 
getRegionInfo() - Method in class org.apache.hadoop.hbase.HbckUnknownServers
 
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
Gets the AsyncTableRegionLocator for this table.
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
Gets the RegionLocator for this table.
getRegionLocator() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Allows subclasses to get the RegionLocator.
getRegionMetrics(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
Get RegionMetrics of all regions hosted on a regionserver.
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
Returns current live region servers list wrapped by CompletableFuture
getRegionServers(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
 
getRegionServerSpaceQuotaSnapshots(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
Fetches the observed SpaceQuotaSnapshotViews observed by a RegionServer.
getRegionServerSpaceQuotaSnapshots(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Fetches the observed SpaceQuotaSnapshotViews observed by a RegionServer.
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
getRsName() - Method in class org.apache.hadoop.hbase.HbckOrphanRegionsOnRS
 
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
If "hbase.slowlog.scan.payload.enabled" is enabled then this value may be present and should represent the Scan that produced the given 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
Deprecated.
As of HBase-2.0. Will be removed in HBase-3.0.
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.HbckUnknownServers
 
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
 
getServerNameInMeta() - Method in class org.apache.hadoop.hbase.HbckInconsistentRegions
 
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
Deprecated.
since 2.4.0 and will be removed in 4.0.0. Use Admin.getLogEntries(Set, String, ServerType, int, Map) instead.
getSlowLogResponses(Set<ServerName>, LogQueryFilter) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Deprecated.
since 2.4.0 and will be removed in 4.0.0. Use AsyncAdmin.getLogEntries(Set, String, ServerType, int, Map) instead.
getSnapshotDescription() - Method in exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
Returns the description of the snapshot that is being failed
getSnapshotList(Configuration) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
Returns the list of available snapshots in the specified location
getSnapshotsFilesMap(Configuration, AtomicLong, AtomicLong, AtomicLong) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
Returns the map of store files based on path for all snapshots
getSnapshotStats(Configuration, SnapshotDescription) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
Returns the snapshot stats
getSnapshotStats(Configuration, SnapshotProtos.SnapshotDescription, Map<Path, Integer>) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
Returns the snapshot stats
getSource() - Method in exception org.apache.hadoop.hbase.errorhandling.ForeignException
 
getSourceName() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
 
getSpaceQuotaTableSizes() - Method in interface org.apache.hadoop.hbase.client.Admin
Fetches the table sizes on the filesystem as tracked by the HBase Master.
getSpaceQuotaTableSizes() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Fetches the table sizes on the filesystem as tracked by the HBase Master.
getSplits(JobConf, int) - Method in class org.apache.hadoop.hbase.mapred.MultiTableSnapshotInputFormat
 
getSplits(JobConf, int) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Calculates the splits that will serve as input for the map tasks.
getSplits(JobConf, int) - Method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat
 
getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
Calculates the splits that will serve as input for the map tasks.
getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormat
 
getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.RoundRobinTableInputFormat
 
getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Calculates the splits that will serve as input for the map tasks.
getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Calculates the splits that will serve as input for the map tasks.
getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat
 
getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.WALInputFormat
 
getSplittableRegion(TableName, int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Retrieves a splittable region randomly from tableName
getSrcChecksum() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
Get the checksum of the source files from which Hadoop was compiled.
getStart() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
 
getStartCode() - Method in class org.apache.hadoop.hbase.HbckServerName
 
getStartcode() - Method in class org.apache.hadoop.hbase.ServerName
Deprecated.
Since 2.5.0, will be removed in 4.0.0. Use ServerName.getStartCode() instead.
getStartCode() - Method in class org.apache.hadoop.hbase.ServerName
Return the start code.
getStartEndKeys() - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
Gets the starting and ending row keys for every region in the currently open table.
getStartEndKeys() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
Gets the starting and ending row keys for every region in the currently open table.
getStartEndKeys() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
 
getStartEndKeys() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
 
getStartKey() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
Returns the startKey.
getStartKey(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
Gets the start key from the specified region name.
getStartKey() - Method in class org.apache.hadoop.hbase.HbckRegionDetails
 
getStartKeys() - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
Gets the starting row key for every region in the currently open table.
getStartKeys() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
Gets the starting row key for every region in the currently open table.
getStartRow() - Method in class org.apache.hadoop.hbase.client.Scan
Returns the startrow
getStartRow() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
Returns starting row key
getStartRow() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Returns the start row.
getStartTime() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
 
getStartTime() - Method in interface org.apache.hadoop.hbase.ServerTask
Get the task start time.
getState() - Method in interface org.apache.hadoop.hbase.ServerTask
Get the current state of the task.
getStats() - Method in class org.apache.hadoop.hbase.client.Result
Returns the associated statistics about the region from which this was returned.
getStatus() - Method in interface org.apache.hadoop.hbase.ServerTask
Get the current status of the task.
getStopRow() - Method in class org.apache.hadoop.hbase.client.Scan
Returns the stoprow
getStopRowKey() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
getStoragePolicy() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
Not using enum here because HDFS is not using enum for storage policy, see org.apache.hadoop.hdfs.server.blockmanagement.BlockStoragePolicySuite for more details.
getStoreCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
Returns the number of stores
getStoreFileCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
Returns the number of storefiles
getStoreFileIndexSize() - Method in interface org.apache.hadoop.hbase.RegionMetrics
TODO: why we pass the same value to different counters? Currently, the value from getStoreFileIndexSize() is same with getStoreFileRootLevelIndexSize() see HRegionServer#createRegionLoad.
getStoreFileRootLevelIndexSize() - Method in interface org.apache.hadoop.hbase.RegionMetrics
Returns The current total size of root-level indexes for the region
getStoreFileSize() - Method in interface org.apache.hadoop.hbase.RegionMetrics
Returns the total size of the storefiles
getStoreFileUncompressedDataIndexSize() - Method in interface org.apache.hadoop.hbase.RegionMetrics
Returns The total size of all index blocks, not just the root level
getStoreRefCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
Returns the reference count for the stores of this region
getStoreSequenceId() - Method in interface org.apache.hadoop.hbase.RegionMetrics
Returns completed sequence id per store.
getStream() - Method in class org.apache.hadoop.hbase.rest.client.Response
Gets the input stream instance.
getSuffix(byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.MultiTableHFileOutputFormat
 
getSupportedCiphers() - Method in interface org.apache.hadoop.hbase.io.crypto.CipherProvider
Return the set of Ciphers supported by this provider
getSupportedCiphers() - Method in class org.apache.hadoop.hbase.io.crypto.CryptoCipherProvider
 
getSupportedCiphers() - Method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
 
getSupportedCiphers() - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Get names of supported encryption algorithms
getSupportedCiphers(Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Get names of supported encryption algorithms
getSupportedCompressionAlgorithms() - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Get supported compression algorithms.
getSupportedFilters() - Method in class org.apache.hadoop.hbase.filter.ParseFilter
Return a Set of filters supported by the Filter Language
getSyncReplicationState() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerDescription
 
getSyncWaitTimeout() - Method in interface org.apache.hadoop.hbase.client.Admin
Return the blocking wait time for an asynchronous operation.
getTable(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
Retrieve an AsyncTable implementation for accessing a table.
getTable(TableName, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
Retrieve an AsyncTable implementation for accessing a table.
getTable(TableName) - Method in interface org.apache.hadoop.hbase.client.Connection
Retrieve a Table implementation for accessing a table.
getTable(TableName, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.Connection
Retrieve a Table implementation for accessing a table.
getTable() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
Returns current table name of the region
getTable(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
Gets the table name from the specified region name.
getTable() - Method in class org.apache.hadoop.hbase.client.replication.TableCFs
 
getTable() - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Allows subclasses to get the Table.
getTable() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
Returns table name
getTable() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Allows subclasses to get the Table.
getTable() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Returns the table name.
getTableBuilder(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
Returns an AsyncTableBuilder for creating AsyncTable.
getTableBuilder(TableName, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
Returns an AsyncTableBuilder for creating AsyncTable.
getTableBuilder(TableName, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.Connection
Returns an TableBuilder for creating Table.
getTableCFsMap() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
getTableFilter() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
Returns the Table filter regex
getTableName() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
 
getTableName() - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
Deprecated.
 
getTableName() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
 
getTableName() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
Get the name of the table
getTableName() - Method in class org.apache.hadoop.hbase.HbckRegionDetails
 
getTableName() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
Returns table name
getTableName(byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.MultiTableHFileOutputFormat
 
getTableName() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Returns the table name converted to a byte array.
getTableName() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
 
getTableNameAsString() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
 
getTableNames() - Method in class org.apache.hadoop.hbase.client.NormalizeTableFilterParams
 
getTableNameSuffixedWithFamily(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
 
getTableRegionStatesCount() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
Provide region states count for given table.
getTables() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
Deprecated.
Since 3.0.0, will be removed in 4.0.0. The rsgroup information will be stored in the configuration of a table so this will be removed.
getTagsArray() - Method in interface org.apache.hadoop.hbase.Cell
Deprecated.
As of HBase-2.0. Will be removed in HBase-3.0. Tags are are now internal.
getTagsLength() - Method in interface org.apache.hadoop.hbase.Cell
Deprecated.
As of HBase-2.0. Will be removed in HBase-3.0. Tags are are now internal.
getTagsOffset() - Method in interface org.apache.hadoop.hbase.Cell
Deprecated.
As of HBase-2.0. Will be removed in HBase-3.0. Tags are are now internal.
getTasks() - Method in interface org.apache.hadoop.hbase.ServerMetrics
Called directly from clients such as the hbase shell
getTestFileSystem() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
getTimeRange() - Method in class org.apache.hadoop.hbase.client.Append
Gets the TimeRange used for this append.
getTimeRange() - Method in class org.apache.hadoop.hbase.client.CheckAndMutate
Returns the time range to check
getTimeRange() - Method in class org.apache.hadoop.hbase.client.Get
Method for retrieving the get's TimeRange
getTimeRange() - Method in class org.apache.hadoop.hbase.client.Increment
Gets the TimeRange used for this increment.
getTimeRange() - Method in class org.apache.hadoop.hbase.client.Scan
Returns TimeRange
getTimestamp() - Method in interface org.apache.hadoop.hbase.Cell
Return a long value representing time at which this cell was "Put" into the row.
getTimestamp() - Method in class org.apache.hadoop.hbase.client.Mutation
Method for retrieving the timestamp.
getTimestampOfLastShippedOp() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
 
getTimeStampOfNextToReplicate() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
 
getTimestamps() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
Returns the list of timestamps
getTimestampsOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSink
 
getTimestampStarted() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSink
 
getTimeToLive() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
Returns Time-to-live of cell contents, in seconds.
getToken(String, String) - Method in class org.apache.hadoop.hbase.security.User
Returns the Token of the specified kind associated with this user, or null if the Token is not present.
getTokens() - Method in class org.apache.hadoop.hbase.security.User
Returns all the tokens stored in the user's credentials.
getTotalOpsProcessed() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSink
 
getTotalSizeOfCells(Result) - Static method in class org.apache.hadoop.hbase.client.Result
Get total size of raw cells
getTs() - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
 
getTs() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
 
getTTL() - Method in class org.apache.hadoop.hbase.client.Mutation
Return the TTL requested for the result of the mutation, in milliseconds.
getTtl() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
 
getType() - Method in interface org.apache.hadoop.hbase.Cell
Returns the type of cell in a human readable format using Cell.Type.
getType() - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
Deprecated.
 
getType() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
 
getType() - Method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
 
getTypeByte() - Method in interface org.apache.hadoop.hbase.Cell
Deprecated.
As of HBase-2.0. Will be removed in HBase-3.0. Use Cell.getType().
getTypeFilters() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
Returns the QuotaType types that we want to filter one
getUGI() - Method in class org.apache.hadoop.hbase.security.User
 
getUncompressedStoreFileSize() - Method in interface org.apache.hadoop.hbase.RegionMetrics
Returns the uncompressed size of the storefiles
getUnit(String) - Static method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
getUnit(String) - Static method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
getUnit() - Method in class org.apache.hadoop.hbase.Size
Returns size unit
getUnknownServerNames() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
Returns the names of region servers on the unknown list
getUrl() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
Get the subversion URL for the root hbase directory.
getUsage() - Method in interface org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView
Returns the current usage, in bytes, of the target (e.g.
getUsedHeapSize() - Method in interface org.apache.hadoop.hbase.ServerMetrics
Returns the amount of used heap
getUser() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
The user that compiled hbase.
getUserFilter() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
Returns the User filter regex
getUserMetrics() - Method in interface org.apache.hadoop.hbase.ServerMetrics
Returns metrics per user
getUserName() - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
Deprecated.
 
getUserName() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
 
getUserName() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
 
getUserName() - Method in interface org.apache.hadoop.hbase.UserMetrics
Returns the user name
getUserPermissions(GetUserPermissionsRequest) - Method in interface org.apache.hadoop.hbase.client.Admin
Get the global/namespace/table permissions for user
getUserPermissions(GetUserPermissionsRequest) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Get the global/namespace/table permissions for user
getUtf8ByteArrays(List<String>) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
getValue() - Method in class org.apache.hadoop.hbase.client.CheckAndMutate
Returns the expected value
getValue(Bytes) - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
Get a configuration value.
getValue(String) - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
Get a configuration value.
getValue(byte[]) - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
Get a configuration value.
getValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
Get the latest version of the specified column.
getValue() - Method in enum org.apache.hadoop.hbase.client.security.SecurityCapability
 
getValue(Bytes) - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
Getter for accessing the metadata associated with the key.
getValue(byte[]) - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
Getter for accessing the metadata associated with the key.
getValue(String) - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
Getter for accessing the metadata associated with the key.
getValue(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
getValue() - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
 
getValue() - Method in class org.apache.hadoop.hbase.filter.SubstringComparator
 
getValue(String) - Static method in enum org.apache.hadoop.hbase.KeepDeletedCells
 
getValueArray() - Method in interface org.apache.hadoop.hbase.Cell
Contiguous raw bytes that may start at any index in the containing array.
getValueAsByteBuffer(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
Returns the value wrapped in a new ByteBuffer.
getValueAsByteBuffer(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
Returns the value wrapped in a new ByteBuffer.
getValueLength() - Method in interface org.apache.hadoop.hbase.Cell
Returns Number of value bytes.
getValueOffset() - Method in interface org.apache.hadoop.hbase.Cell
Returns Array index of first value byte
getValues() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
Get all configuration values.
getValues() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
Returns Getter for fetching an unmodifiable map.
getVersion() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
 
getVersion() - Method in interface org.apache.hadoop.hbase.ServerMetrics
Returns the string type version of a regionserver.
getVersion() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
Get the hbase version.
getVersionedBytes() - Method in class org.apache.hadoop.hbase.ServerName
Return ServerName.getServerName() as bytes with a short-sized prefix with the ServerName.VERSION of this class.
getVersionNumber() - Method in interface org.apache.hadoop.hbase.ServerMetrics
Returns the version number of a regionserver.
getViolationPolicy() - Method in exception org.apache.hadoop.hbase.quotas.SpaceLimitingException
Returns the violation policy in effect.
getVisibilityExpressionResolver() - Method in class org.apache.hadoop.hbase.mapreduce.CellCreator
Returns Visibility expression resolver
getVLong(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Retrieve the long value at index which is stored as VLong
getVLong() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Retrieve the next long value, which is stored as VLong, from this range
getWaitInterval() - Method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
 
getWriteBufferPeriodicFlushTimeoutMs() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
Returns the current periodic flush timeout value in milliseconds.
getWriteBufferPeriodicFlushTimeoutMs() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
 
getWriteBufferPeriodicFlushTimerTickMs() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
Returns the current periodic flush timertick interval in milliseconds.
getWriteBufferPeriodicFlushTimerTickMs() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
Deprecated.
Since 3.0.0, will be removed in 4.0.0. We use a common timer in the whole client implementation so you can not set it any more.
getWriteBufferSize() - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutator
Returns the maximum size in bytes of the write buffer.
getWriteBufferSize() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
Returns the maximum size in bytes of the write buffer for this HTable.
getWriteBufferSize() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
 
getWriteRequestCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
Returns the number of write requests made to region
getWriteRequestCount() - Method in interface org.apache.hadoop.hbase.UserMetrics
Returns the number of write requests made by user
getWriteRequestsCount() - Method in interface org.apache.hadoop.hbase.ServerMetrics
Returns total Number of write requests from the start of the region server.
getWriteRpcTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
Get timeout of each rpc write request in this Table instance.
getWriteRpcTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.Table
Get timeout of each rpc write request in this Table instance.
getZkCluster() - Method in class org.apache.hadoop.hbase.HBaseZKTestingUtility
Deprecated.
 
getZooKeeperServerNum() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
 
getZooKeeperWatcher() - Method in class org.apache.hadoop.hbase.HBaseZKTestingUtility
Deprecated.
Returns a ZKWatcher instance.
getZooKeeperWatcher(HBaseZKTestingUtility) - Static method in class org.apache.hadoop.hbase.HBaseZKTestingUtility
Deprecated.
Gets a ZKWatcher.
grant(UserPermission, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Grants user specific permissions
grant(UserPermission, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Grants user specific permissions
GREATER_THAN_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
GREATER_THAN Array
GREATER_THAN_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
 
GREATER_THAN_OR_EQUAL_TO_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
GREATER_THAN_OR_EQUAL_TO Array
GREATER_THAN_OR_EQUAL_TO_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
 
GROUP_COLUMNS - Static variable in class org.apache.hadoop.hbase.mapred.GroupingTableMap
JobConf parameter to specify the columns used to produce the key passed to collect from the map phase
GROUP_COLUMNS - Static variable in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
JobConf parameter to specify the columns used to produce the key passed to collect from the map phase.
GroupingTableMap - Class in org.apache.hadoop.hbase.mapred
Extract grouping columns from input record
GroupingTableMap() - Constructor for class org.apache.hadoop.hbase.mapred.GroupingTableMap
 
GroupingTableMapper - Class in org.apache.hadoop.hbase.mapreduce
Extract grouping columns from input record.
GroupingTableMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
 

H

H - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'H'
has(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Mutation
A convenience method to determine if this object's familyMap contains a value assigned to the given family & qualifier.
has(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Mutation
A convenience method to determine if this object's familyMap contains a value assigned to the given family, qualifier and timestamp.
has(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Mutation
A convenience method to determine if this object's familyMap contains a value assigned to the given family, qualifier and timestamp.
has(byte[], byte[], long, byte[]) - Method in class org.apache.hadoop.hbase.client.Mutation
A convenience method to determine if this object's familyMap contains the given value assigned to the given family, qualifier and timestamp.
has(byte[], byte[], long, byte[], boolean, boolean) - Method in class org.apache.hadoop.hbase.client.Mutation
Private method to determine if this object's familyMap contains the given value assigned to the given family, qualifier and timestamp, respecting the 2 boolean arguments.
HAS_LARGE_RESULT - Static variable in class org.apache.hadoop.hbase.mapreduce.Import
 
hasBody() - Method in class org.apache.hadoop.hbase.rest.client.Response
Returns true if a response body was sent
hasColumnFamily(byte[]) - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
Checks to see if this table contains the given column family
hasCoprocessor(String) - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
Check if the table has an attached co-processor represented by the name className
hasCoprocessor(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
hasEditsSinceRestart() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
 
hasEncodedName(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
Does region name contain its encoded name?
hasFamilies() - Method in class org.apache.hadoop.hbase.client.Get
Method for checking if any families have been inserted into this Get
hasFamilies() - Method in class org.apache.hadoop.hbase.client.Increment
Method for checking if any families have been inserted into this Increment
hasFamilies() - Method in class org.apache.hadoop.hbase.client.Scan
Returns true if familyMap is non empty, false otherwise
hasFilter() - Method in class org.apache.hadoop.hbase.client.CheckAndMutate
Returns whether this has a filter or not
hasFilter() - Method in class org.apache.hadoop.hbase.client.Scan
Returns true is a filter has been specified, false if not
hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.Filter
Primarily used to check for conflicts with scans(such as scans that do not read a full row at a time).
hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.FilterList
 
hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
 
hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
hasFoundKV() - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
Returns true if first KV has been found.
hasGlobalReplicationScope() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
Check if any of the table's cfs' replication scope are set to HConstants.REPLICATION_SCOPE_GLOBAL.
hash128(String...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Return the MD5 digest of the concatenation of the supplied arguments.
hash128(byte[]...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Return the MD5 digest of the concatenation of the supplied arguments.
hash256(String...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Return the SHA-256 digest of the concatenation of the supplied arguments.
hash256(byte[]...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Return the SHA-256 digest of the concatenation of the supplied arguments.
hashCode() - Method in class org.apache.hadoop.hbase.client.Get
 
hashCode() - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
Deprecated.
 
hashCode() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.BigDecimalComparator
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.BinaryComponentComparator
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.FamilyFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.FilterList
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.NullComparator
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.QualifierFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.RowFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.ValueFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.HRegionLocation
 
hashCode() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
hashCode() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
hashCode() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
 
hashCode() - Method in class org.apache.hadoop.hbase.net.Address
 
hashCode() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
 
hashCode() - Method in class org.apache.hadoop.hbase.security.User
 
hashCode() - Method in class org.apache.hadoop.hbase.ServerName
 
hashCode() - Method in class org.apache.hadoop.hbase.Size
 
hashCode() - Method in class org.apache.hadoop.hbase.TableName
 
hashCode() - Method in class org.apache.hadoop.hbase.util.Bytes
 
hashCode(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Calculate a hash code from a given byte array.
hashCode(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Calculate a hash code from a given byte array.
hashCode(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Calculate the hash code for a given range of bytes.
hashCode() - Method in class org.apache.hadoop.hbase.util.Pair
 
hashCode() - Method in class org.apache.hadoop.hbase.util.PairOfSameType
 
hasHigherPriority(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
Returns which operator has higher precedence
hashWithAlg(String, byte[]...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Return the hash of the concatenation of the supplied arguments, using the hash algorithm provided.
hasNext() - Method in class org.apache.hadoop.hbase.types.StructIterator
 
hasRegionMemStoreReplication() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
Returns true if the read-replicas memstore replication is enabled.
hasUserPermissions(String, List<Permission>) - Method in interface org.apache.hadoop.hbase.client.Admin
Check if the user has specific permissions
hasUserPermissions(List<Permission>) - Method in interface org.apache.hadoop.hbase.client.Admin
Check if call user has specific permissions
hasUserPermissions(String, List<Permission>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Check if the user has specific permissions
hasUserPermissions(List<Permission>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Check if call user has specific permissions
HBASE_BALANCER_MAX_BALANCING - Static variable in class org.apache.hadoop.hbase.HConstants
Config for the max balancing time
HBASE_BALANCER_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
Config for the balancer period
HBASE_CANARY_READ_ALL_CF - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CANARY_READ_RAW_SCAN_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CANARY_WRITE_DATA_TTL_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Canary config keys
HBASE_CANARY_WRITE_PERSERVER_REGIONS_LOWERLIMIT_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CANARY_WRITE_PERSERVER_REGIONS_UPPERLIMIT_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CANARY_WRITE_TABLE_CHECK_PERIOD_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CANARY_WRITE_VALUE_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CHECKSUM_VERIFICATION - Static variable in class org.apache.hadoop.hbase.HConstants
If this parameter is set to true, then hbase will read data and then verify checksums.
HBASE_CLIENT_ASYNC_CONNECTION_IMPL - Static variable in class org.apache.hadoop.hbase.client.ConnectionFactory
 
HBASE_CLIENT_AUTOMATIC_KEYTAB_RENEWAL_DEFAULT - Static variable in class org.apache.hadoop.hbase.AuthUtil
Deprecated.
 
HBASE_CLIENT_AUTOMATIC_KEYTAB_RENEWAL_KEY - Static variable in class org.apache.hadoop.hbase.AuthUtil
Deprecated.
Configuration to automatically try to renew keytab-based logins
HBASE_CLIENT_ENABLE_FAST_FAIL_MODE_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
Deprecated.
since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect. The constants itself will be removed in 4.0.0.
HBASE_CLIENT_FAILURE_MAP_CLEANUP_INTERVAL_MS - Static variable in class org.apache.hadoop.hbase.HConstants
Deprecated.
since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect. The constants itself will be removed in 4.0.0.
HBASE_CLIENT_FAILURE_MAP_CLEANUP_INTERVAL_MS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
Deprecated.
since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect. The constants itself will be removed in 4.0.0.
HBASE_CLIENT_FAST_FAIL_CLEANUP_DURATION_MS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
Deprecated.
since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect. The constants itself will be removed in 4.0.0.
HBASE_CLIENT_FAST_FAIL_CLEANUP_MS_DURATION_MS - Static variable in class org.apache.hadoop.hbase.HConstants
Deprecated.
since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect. The constants itself will be removed in 4.0.0.
HBASE_CLIENT_FAST_FAIL_INTERCEPTOR_IMPL - Static variable in class org.apache.hadoop.hbase.HConstants
Deprecated.
since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect. The constants itself will be removed in 4.0.0.
HBASE_CLIENT_FAST_FAIL_MODE_ENABLED - Static variable in class org.apache.hadoop.hbase.HConstants
Deprecated.
since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect. The constants itself will be removed in 4.0.0.
HBASE_CLIENT_FAST_FAIL_THREASHOLD_MS - Static variable in class org.apache.hadoop.hbase.HConstants
Deprecated.
since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect. The constants itself will be removed in 4.0.0.
HBASE_CLIENT_FAST_FAIL_THREASHOLD_MS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
Deprecated.
since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect. The constants itself will be removed in 4.0.0.
HBASE_CLIENT_INSTANCE_ID - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for unique identifier for this Configuration instance.
HBASE_CLIENT_IPC_POOL_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for HBase client IPC pool size
HBASE_CLIENT_IPC_POOL_TYPE - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for HBase client IPC pool type
HBASE_CLIENT_KERBEROS_PRINCIPAL - Static variable in class org.apache.hadoop.hbase.AuthUtil
Deprecated.
Client principal
HBASE_CLIENT_KEYTAB_FILE - Static variable in class org.apache.hadoop.hbase.AuthUtil
Deprecated.
Client keytab file
HBASE_CLIENT_MAX_PERREGION_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
The maximum number of concurrent connections the client will maintain to a single Region.
HBASE_CLIENT_MAX_PERSERVER_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
The maximum number of concurrent connections the client will maintain to a single RegionServer.
HBASE_CLIENT_MAX_TOTAL_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
The maximum number of concurrent connections the client will maintain.
HBASE_CLIENT_META_OPERATION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for HBase client meta operation timeout.
HBASE_CLIENT_META_REPLICA_SCAN_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for HBase client meta replica scan call timeout.
HBASE_CLIENT_META_REPLICA_SCAN_TIMEOUT_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
Default HBase client meta replica scan call timeout, 1 second
HBASE_CLIENT_OPERATION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for HBase client operation timeout.
HBASE_CLIENT_PAUSE - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for client pause value, used mostly as value to wait before running a retry of a failed get, region lookup, etc.
HBASE_CLIENT_PAUSE_FOR_CQTBE - Static variable in class org.apache.hadoop.hbase.HConstants
Deprecated.
Since 2.5.0, will be removed in 4.0.0. Please use hbase.client.pause.server.overloaded instead.
HBASE_CLIENT_PERSERVER_REQUESTS_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
The maximum number of concurrent pending RPC requests for one server in process level.
HBASE_CLIENT_RETRIES_NUMBER - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for maximum retries, used as maximum for all retryable operations such as fetching of the root region from root region server, getting a cell's value, starting a row update, etc.
HBASE_CLIENT_SCANNER_ASYNC_PREFETCH - Static variable in class org.apache.hadoop.hbase.client.Scan
Parameter name for client scanner sync/async prefetch toggle.
HBASE_CLIENT_SCANNER_CACHING - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name to set the default scanner caching for all clients.
HBASE_CLIENT_SCANNER_MAX_RESULT_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for maximum number of bytes returned when calling a scanner's next method.
HBASE_CLIENT_SCANNER_ONHEAP_BLOCK_CACHE_FIXED_SIZE_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CLIENT_SCANNER_TIMEOUT_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
The client scanner timeout period in milliseconds.
HBASE_CLIENT_SERVERSIDE_RETRIES_MULTIPLIER - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CLUSTER_MINIMUM_MEMORY_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_DIR - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for HBase instance root directory
HBASE_ENABLE_SEPARATE_CHILD_REGIONS - Static variable in class org.apache.hadoop.hbase.HConstants
Config key for enable/disable automatically separate child regions to different region servers in the procedure of split regions.
HBASE_MASTER_BALANCER_MAX_RIT_PERCENT - Static variable in class org.apache.hadoop.hbase.HConstants
Config for the max percent of regions in transition
HBASE_MASTER_LOADBALANCE_BYTABLE - Static variable in class org.apache.hadoop.hbase.HConstants
Config for balancing the cluster by table
HBASE_MASTER_LOADBALANCER_CLASS - Static variable in class org.apache.hadoop.hbase.HConstants
Config for pluggable load balancers
HBASE_MASTER_LOGCLEANER_PLUGINS - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_MASTER_NORMALIZER_CLASS - Static variable in class org.apache.hadoop.hbase.HConstants
Config for pluggable region normalizer
HBASE_META_BLOCK_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for number of versions, kept by meta table.
HBASE_META_SCANNER_CACHING - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for number of rows that will be fetched when calling next on a scanner if it is not served from memory.
HBASE_META_VERSIONS - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for number of versions, kept by meta table.
HBASE_NETTY_EVENTLOOP_RPCCLIENT_THREADCOUNT_KEY - Static variable in class org.apache.hadoop.hbase.ipc.NettyRpcClientConfigHelper
Name of property to change netty rpc client eventloop thread count.
HBASE_NON_TABLE_DIRS - Static variable in class org.apache.hadoop.hbase.HConstants
Directories that are not HBase table directories
HBASE_NON_USER_TABLE_DIRS - Static variable in class org.apache.hadoop.hbase.HConstants
Deprecated.
Since hbase-2.3.0; no replacement as not used any more (internally at least)
HBASE_OLDWAL_DIR_SIZE_UPDATER_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
Config for the oldWALs directory size updater period
HBASE_REGION_SPLIT_POLICY_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_RPC_READ_TIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
timeout for each read RPC
HBASE_RPC_SHORTOPERATION_RETRY_PAUSE_TIME - Static variable in class org.apache.hadoop.hbase.HConstants
Retry pause time for short operation RPC
HBASE_RPC_SHORTOPERATION_TIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
timeout for short operation RPC
HBASE_RPC_TIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
timeout for each RPC
HBASE_RPC_WRITE_TIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
timeout for each write RPC
HBASE_RS_NONCES_ENABLED - Static variable in class org.apache.hadoop.hbase.HConstants
Whether nonces are enabled; default is true.
HBASE_SECURITY_AUTHORIZATION_CONF_KEY - Static variable in class org.apache.hadoop.hbase.security.User
 
HBASE_SECURITY_CONF_KEY - Static variable in class org.apache.hadoop.hbase.security.User
 
HBASE_SERVER_PAUSE - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for server pause value, used mostly as value to wait before running a retry of a failed operation.
HBASE_SERVER_SCANNER_MAX_RESULT_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for maximum number of bytes returned when calling a scanner's next method.
HBASE_SERVER_USEIP_ENABLED_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
HBASE_SERVER_USEIP_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
In some scenarios, such as the elastic scaling scenario on the cloud, the HBase client may not be able to resolve the hostname of the newly added node.
HBASE_SPLIT_WAL_COORDINATED_BY_ZK - Static variable in class org.apache.hadoop.hbase.HConstants
Deprecated.
since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based distributed WAL splitter; see SplitWALManager.
HBASE_SPLIT_WAL_MAX_SPLITTER - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_SPLITLOG_MANAGER_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for SplitLog manager timeout
HBASE_TEMP_DIRECTORY - Static variable in class org.apache.hadoop.hbase.HConstants
Temporary directory used for table creation and deletion
HBaseCluster - Class in org.apache.hadoop.hbase
Deprecated.
since 3.0.0, will be removed in 4.0.0. Use TestingHBaseCluster instead.
HBaseCluster(Configuration) - Constructor for class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
Construct an HBaseCluster
hbaseCluster - Variable in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
 
HBaseCommonTestingUtility - Class in org.apache.hadoop.hbase
Deprecated.
since 3.0.0, will be removed in 4.0.0. Use TestingHBaseCluster instead.
HBaseCommonTestingUtility() - Constructor for class org.apache.hadoop.hbase.HBaseCommonTestingUtility
Deprecated.
 
HBaseCommonTestingUtility(Configuration) - Constructor for class org.apache.hadoop.hbase.HBaseCommonTestingUtility
Deprecated.
 
HBaseConfiguration - Class in org.apache.hadoop.hbase
Adds HBase configuration files to a Configuration
HBaseConfiguration() - Constructor for class org.apache.hadoop.hbase.HBaseConfiguration
 
HBaseInterfaceAudience - Class in org.apache.hadoop.hbase
This class defines constants for different classes of hbase limited private apis
HBaseIOException - Exception in org.apache.hadoop.hbase
All hbase specific IOExceptions should be subclasses of HBaseIOException
HBaseIOException() - Constructor for exception org.apache.hadoop.hbase.HBaseIOException
 
HBaseIOException(String) - Constructor for exception org.apache.hadoop.hbase.HBaseIOException
 
HBaseIOException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.HBaseIOException
 
HBaseIOException(Throwable) - Constructor for exception org.apache.hadoop.hbase.HBaseIOException
 
HBaseServerException - Exception in org.apache.hadoop.hbase
Base class for exceptions thrown by an HBase server.
HBaseServerException() - Constructor for exception org.apache.hadoop.hbase.HBaseServerException
 
HBaseServerException(String) - Constructor for exception org.apache.hadoop.hbase.HBaseServerException
 
HBaseServerException(boolean) - Constructor for exception org.apache.hadoop.hbase.HBaseServerException
 
HBaseServerException(boolean, String) - Constructor for exception org.apache.hadoop.hbase.HBaseServerException
 
HBaseSnapshotException - Exception in org.apache.hadoop.hbase.snapshot
General exception base class for when a snapshot fails.
HBaseSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
Some exception happened for a snapshot and don't even know the snapshot that it was about.
HBaseSnapshotException(String, SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
Exception for the given snapshot that has no previous root cause.
HBaseSnapshotException(String, Throwable, SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
Exception for the given snapshot due to another exception.
HBaseSnapshotException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
Exception when the description of the snapshot cannot be determined, due to some root other root cause.
HBaseTestingUtility - Class in org.apache.hadoop.hbase
Deprecated.
since 3.0.0, will be removed in 4.0.0. Use TestingHBaseCluster instead.
HBaseTestingUtility() - Constructor for class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Create an HBaseTestingUtility using a default configuration.
HBaseTestingUtility(Configuration) - Constructor for class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Create an HBaseTestingUtility using a given configuration.
HBaseZKTestingUtility - Class in org.apache.hadoop.hbase
Deprecated.
since 3.0.0, will be removed in 4.0.0. Use TestingHBaseCluster instead.
HBaseZKTestingUtility() - Constructor for class org.apache.hadoop.hbase.HBaseZKTestingUtility
Deprecated.
 
HBaseZKTestingUtility(Configuration) - Constructor for class org.apache.hadoop.hbase.HBaseZKTestingUtility
Deprecated.
 
HBCK - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
Denotes classes used by hbck tool for fixing inconsistent state of HBase.
HBCK_SIDELINEDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
Used by HBCK to sideline backup data
HbckEmptyRegionInfo - Class in org.apache.hadoop.hbase
POJO to present Empty Region Info from Catalog Janitor Inconsistencies Report via REST API.
HbckEmptyRegionInfo(String) - Constructor for class org.apache.hadoop.hbase.HbckEmptyRegionInfo
 
HbckInconsistentRegions - Class in org.apache.hadoop.hbase
POJO to present HBCK Inconsistent Regions from HBCK Inconsistencies Report via REST API.
HbckInconsistentRegions(String, HbckServerName, List<HbckServerName>) - Constructor for class org.apache.hadoop.hbase.HbckInconsistentRegions
 
HbckOrphanRegionsOnFS - Class in org.apache.hadoop.hbase
POJO to present Orphan Region on FS from HBCK Inconsistencies Report via REST API.
HbckOrphanRegionsOnFS(String, String) - Constructor for class org.apache.hadoop.hbase.HbckOrphanRegionsOnFS
 
HbckOrphanRegionsOnRS - Class in org.apache.hadoop.hbase
POJO to present Orphan Region on RS from HBCK Inconsistencies Report via REST API.
HbckOrphanRegionsOnRS(String, HbckServerName) - Constructor for class org.apache.hadoop.hbase.HbckOrphanRegionsOnRS
 
HbckOverlapRegions - Class in org.apache.hadoop.hbase
POJO to present Region Overlap from Catalog Janitor Inconsistencies Report via REST API.
HbckOverlapRegions(HbckRegionDetails, HbckRegionDetails) - Constructor for class org.apache.hadoop.hbase.HbckOverlapRegions
 
HbckRegionDetails - Class in org.apache.hadoop.hbase
POJO class for HBCK RegionInfo in HBCK Inconsistencies report.
HbckRegionDetails(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.HbckRegionDetails
 
HbckRegionHoles - Class in org.apache.hadoop.hbase
POJO to present Region Holes from Catalog Janitor Inconsistencies Report via REST API.
HbckRegionHoles(HbckRegionDetails, HbckRegionDetails) - Constructor for class org.apache.hadoop.hbase.HbckRegionHoles
 
HbckServerName - Class in org.apache.hadoop.hbase
POJO class for ServerName in HBCK Inconsistencies report.
HbckServerName(String, int, long) - Constructor for class org.apache.hadoop.hbase.HbckServerName
 
HbckUnknownServers - Class in org.apache.hadoop.hbase
POJO to present Unknown Regions from Catalog Janitor Inconsistencies Report via REST API.
HbckUnknownServers(HbckRegionDetails, HbckServerName) - Constructor for class org.apache.hadoop.hbase.HbckUnknownServers
 
HConstants - Class in org.apache.hadoop.hbase
HConstants holds a bunch of HBase-related constants
head(String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a HEAD request
head(Cluster, String, Header[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a HEAD request
head(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Make a new byte array from a subset of bytes at the head of another.
HEALTH_CHORE_WAKE_FREQ - Static variable in class org.apache.hadoop.hbase.HConstants
 
HEALTH_FAILURE_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
The maximum number of health check failures a server can encounter consecutively.
HEALTH_SCRIPT_LOC - Static variable in class org.apache.hadoop.hbase.HConstants
Health script related settings.
HEALTH_SCRIPT_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
 
HEAP_OCCUPANCY_HIGH_WATERMARK_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
HEAP_OCCUPANCY_LOW_WATERMARK_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
heapSize() - Method in class org.apache.hadoop.hbase.client.Mutation
Returns Calculate what Mutation adds to class heap size.
HEARTBEAT_TIME_BUFFER - Static variable in class org.apache.hadoop.hbase.client.locking.EntityLock
 
HFILE_ARCHIVE_DIRECTORY - Static variable in class org.apache.hadoop.hbase.HConstants
Directory under /hbase where archived hfiles are stored
HFILE_BLOCK_CACHE_SIZE_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
HFILE_BLOCK_CACHE_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for the size of the block cache
HFILE_ONHEAP_BLOCK_CACHE_FIXED_SIZE_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
HFILE_ONHEAP_BLOCK_CACHE_FIXED_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for setting the fix size of the block size, default do nothing and it should be explicitly set by user or only used within ClientSideRegionScanner.
HFILE_PREAD_ALL_BYTES_ENABLED_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
HFILE_PREAD_ALL_BYTES_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for setting pread must read both necessaryLen and extraLen, default is disabled.
HFILEBLOCK_DUMMY_HEADER - Static variable in class org.apache.hadoop.hbase.HConstants
Just an array of bytes of the right size.
HFILEBLOCK_HEADER_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
The size of a version 2 HFile block header, minor version 1.
HFILEBLOCK_HEADER_SIZE_NO_CHECKSUM - Static variable in class org.apache.hadoop.hbase.HConstants
The size data structures with minor version is 0
HFileOutputFormat2 - Class in org.apache.hadoop.hbase.mapreduce
Writes HFiles.
HFileOutputFormat2() - Constructor for class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
 
HIGH_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
 
hint - Variable in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
HOST - Static variable in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
 
HOUR_IN_SECONDS - Static variable in class org.apache.hadoop.hbase.HConstants
 
HREGION_COMPACTIONDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
Used to construct the name of the compaction directory during compaction
HREGION_EDITS_REPLAY_SKIP_ERRORS - Static variable in class org.apache.hadoop.hbase.HConstants
 
HREGION_LOGDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
Used to construct the name of the log directory for a region server
HREGION_MAX_FILESIZE - Static variable in class org.apache.hadoop.hbase.HConstants
Conf key for the max file size after which we split the region
HREGION_MEMSTORE_BLOCK_MULTIPLIER - Static variable in class org.apache.hadoop.hbase.HConstants
Block updates if memstore has hbase.hregion.memstore.block.multiplier times hbase.hregion.memstore.flush.size bytes.
HREGION_MEMSTORE_FLUSH_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
Conf key for the memstore size at which we flush the memstore
HREGION_OLDLOGDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
Like the previous, but for old logs that are about to be deleted
HRegionLocation - Class in org.apache.hadoop.hbase
Data structure to hold RegionInfo and the address for the hosting HRegionServer.
HRegionLocation(RegionInfo, ServerName) - Constructor for class org.apache.hadoop.hbase.HRegionLocation
 
HRegionLocation(RegionInfo, ServerName, long) - Constructor for class org.apache.hadoop.hbase.HRegionLocation
 
HRegionPartitioner<K2,V2> - Class in org.apache.hadoop.hbase.mapred
This is used to partition the output keys into groups of keys.
HRegionPartitioner() - Constructor for class org.apache.hadoop.hbase.mapred.HRegionPartitioner
 
HRegionPartitioner<KEY,VALUE> - Class in org.apache.hadoop.hbase.mapreduce
This is used to partition the output keys into groups of keys.
HRegionPartitioner() - Constructor for class org.apache.hadoop.hbase.mapreduce.HRegionPartitioner
 
HSTORE_OPEN_AND_CLOSE_THREADS_MAX - Static variable in class org.apache.hadoop.hbase.HConstants
The max number of threads used for opening and closing stores or store files in parallel

I

I - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'I'
ID_ATRIBUTE - Static variable in class org.apache.hadoop.hbase.client.OperationWithAttributes
 
ID_SIZE - Static variable in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
 
ID_SIZE - Static variable in enum org.apache.hadoop.hbase.io.encoding.IndexBlockEncoding
 
IdentityTableMap - Class in org.apache.hadoop.hbase.mapred
Pass the given key and record as-is to reduce
IdentityTableMap() - Constructor for class org.apache.hadoop.hbase.mapred.IdentityTableMap
constructor
IdentityTableMapper - Class in org.apache.hadoop.hbase.mapreduce
Pass the given key and record as-is to the reduce phase.
IdentityTableMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.IdentityTableMapper
 
IdentityTableReduce - Class in org.apache.hadoop.hbase.mapred
Write to table each key, record pair
IdentityTableReduce() - Constructor for class org.apache.hadoop.hbase.mapred.IdentityTableReduce
 
IdentityTableReducer - Class in org.apache.hadoop.hbase.mapreduce
Convenience class that simply writes all values (which must be Put or Delete instances) passed to it out to the configured HBase table.
IdentityTableReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.IdentityTableReducer
 
idx - Variable in class org.apache.hadoop.hbase.types.StructIterator
 
ifEquals(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.CheckAndMutate.Builder
Check for equality
ifMatches(byte[], byte[], CompareOperator, byte[]) - Method in class org.apache.hadoop.hbase.client.CheckAndMutate.Builder
Check for match
ifMatches(Filter) - Method in class org.apache.hadoop.hbase.client.CheckAndMutate.Builder
Check for match
ifNotExists(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.CheckAndMutate.Builder
Check for lack of column
IGNORE_MISSING_FILES - Static variable in class org.apache.hadoop.hbase.mapreduce.WALPlayer
 
ImmutableBytesWritable - Class in org.apache.hadoop.hbase.io
A byte sequence that is usable as a key or value.
ImmutableBytesWritable() - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable
Create a zero-size sequence.
ImmutableBytesWritable(byte[]) - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable
Create a ImmutableBytesWritable using the byte array as the initial value.
ImmutableBytesWritable(ImmutableBytesWritable) - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable
Set the new ImmutableBytesWritable to the contents of the passed ibw.
ImmutableBytesWritable(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable
Set the value to a given byte range
ImmutableBytesWritable.Comparator - Class in org.apache.hadoop.hbase.io
A Comparator optimized for ImmutableBytesWritable.
implementationClassName(String) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
Deprecated.
Since 3.0.0, will be removed in 4.0.0. You can not set it any more as the implementation has to use too many internal stuffs in HBase.
Import - Class in org.apache.hadoop.hbase.mapreduce
Import data written by Export.
Import() - Constructor for class org.apache.hadoop.hbase.mapreduce.Import
 
IMPORT_FORMAT_VER - Static variable in class org.apache.hadoop.hbase.mapreduce.ResultSerialization
 
ImportTsv - Class in org.apache.hadoop.hbase.mapreduce
Tool to import data from a TSV file.
ImportTsv() - Constructor for class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
IN_MEMORY - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
IN_MEMORY - Static variable in class org.apache.hadoop.hbase.HConstants
 
IN_MEMORY_COMPACTION - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
includeRegionInSplit(byte[], byte[]) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
Test if the given region is to be included in the InputSplit while splitting the regions of a table.
includeRegionInSplit(byte[], byte[]) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Test if the given region is to be included in the InputSplit while splitting the regions of a table.
includeStartRow() - Method in class org.apache.hadoop.hbase.client.Scan
Returns if we should include start row when scan
includesTimeRange(TimeRange) - Method in class org.apache.hadoop.hbase.io.TimeRange
Check if the range has any overlap with TimeRange
includeStopRow() - Method in class org.apache.hadoop.hbase.client.Scan
Returns if we should include stop row when scan
InclusiveStopFilter - Class in org.apache.hadoop.hbase.filter
A Filter that stops after the given row.
InclusiveStopFilter(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
IncompatibleFilterException - Exception in org.apache.hadoop.hbase.filter
Used to indicate a filter incompatibility
IncompatibleFilterException() - Constructor for exception org.apache.hadoop.hbase.filter.IncompatibleFilterException
constructor
IncompatibleFilterException(String) - Constructor for exception org.apache.hadoop.hbase.filter.IncompatibleFilterException
constructor
increment(Increment) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
Increments one or more columns within a single row.
Increment - Class in org.apache.hadoop.hbase.client
Used to perform Increment operations on a single row.
Increment(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Increment
Create a Increment operation for the specified row.
Increment(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.client.Increment
Create a Increment operation for the specified row.
Increment(Increment) - Constructor for class org.apache.hadoop.hbase.client.Increment
Copy constructor
Increment(byte[], long, NavigableMap<byte[], List<Cell>>) - Constructor for class org.apache.hadoop.hbase.client.Increment
Construct the Increment with user defined data.
increment(Increment) - Method in interface org.apache.hadoop.hbase.client.Table
Increments one or more columns within a single row.
incrementBadLineCount(int) - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
 
incrementBadLineCount(int) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
 
incrementBadLineCount(int) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
 
incrementBytes(byte[], long) - Static method in class org.apache.hadoop.hbase.util.Bytes
Bytewise binary increment/deincrement of long contained in byte array on given amount.
incrementColumnValue(byte[], byte[], byte[], long) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
incrementColumnValue(byte[], byte[], byte[], long, Durability) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
Atomically increments a column value.
incrementColumnValue(byte[], byte[], byte[], long) - Method in interface org.apache.hadoop.hbase.client.Table
incrementColumnValue(byte[], byte[], byte[], long, Durability) - Method in interface org.apache.hadoop.hbase.client.Table
Atomically increments a column value.
incrementIv(byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
 
incrementIv(byte[], int) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
 
incTaskCounters(Collection<byte[]>, ServerName) - Method in interface org.apache.hadoop.hbase.client.RequestController
Increment the counter if we build a valid task.
INDEX_BLOCK_ENCODING - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
INDEX_KEY_MAGIC - Static variable in class org.apache.hadoop.hbase.HConstants
Used as a magic return value while optimized index key feature enabled(HBASE-7845)
IndexBlockEncoding - Enum in org.apache.hadoop.hbase.io.encoding
Provide access to all index block encoding algorithms.
indexOf(byte[], byte) - Static method in class org.apache.hadoop.hbase.util.Bytes
Returns the index of the first appearance of the value target in array.
indexOf(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Returns the start position of the first occurrence of the specified target within array, or -1 if there is no such occurrence.
init(String) - Method in interface org.apache.hadoop.hbase.io.crypto.KeyProvider
Initialize the key provider
init(String) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
 
init() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
Build the scanner.
init() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
Build the scanner.
init() - Method in interface org.apache.hadoop.hbase.mapreduce.VisibilityExpressionResolver
Giving a chance for the initialization.
initCredentials(JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
 
initCredentials(Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
 
initCredentialsForCluster(Job, String) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Deprecated.
Since 1.2.0 and will be removed in 3.0.0. Use TableMapReduceUtil.initCredentialsForCluster(Job, Configuration) instead.
initCredentialsForCluster(Job, Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Obtain an authentication token, for the specified cluster, on behalf of the current user and add it to the credentials for the given map reduce job.
INITIAL_MAX_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.io.TimeRange
 
INITIAL_MIN_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.io.TimeRange
 
initialClusterStatus - Variable in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
the status of the cluster before we begin
initialize(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormat
 
initialize(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Handle subclass specific set up.
initialize(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
 
initialize(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Handle subclass specific set up.
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
Initializes the reader.
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
Build the scanner.
initializeTable(Connection, TableName) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Allows subclasses to initialize the table information.
initializeTable(Connection, TableName) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Allows subclasses to initialize the table information.
initJob(String, String, String, Class<? extends TableMap>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
Use this before submitting a TableMap job.
initJob(String, String, Class<? extends TableMap>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.IdentityTableMap
Use this before submitting a TableMap job.
initJob(String, Scan, String, Class<? extends TableMapper>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
Use this before submitting a TableMap job.
initJob(String, Scan, Class<? extends TableMapper>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.IdentityTableMapper
Use this before submitting a TableMap job.
initMultiTableSnapshotMapperJob(Map<String, Collection<Scan>>, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean, Path) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Sets up the job for reading from one or more multiple table snapshots, with one or more scans per snapshot.
initMultiTableSnapshotMapperJob(Map<String, Collection<Scan>>, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Path) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Sets up the job for reading from one or more table snapshots, with one or more scans per snapshot.
initTableMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
 
initTableMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(TableName, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(byte[], Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, boolean, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(byte[], Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(byte[], Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(List<Scan>, Class<? extends TableMapper>, Class<?>, Class<?>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a Multi TableMap job.
initTableMapperJob(List<Scan>, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a Multi TableMap job.
initTableMapperJob(List<Scan>, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a Multi TableMap job.
initTableReduceJob(String, Class<? extends TableReduce>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Use this before submitting a TableReduce job.
initTableReduceJob(String, Class<? extends TableReduce>, JobConf, Class) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Use this before submitting a TableReduce job.
initTableReduceJob(String, Class<? extends TableReduce>, JobConf, Class, boolean) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Use this before submitting a TableReduce job.
initTableReducerJob(String, Class<? extends TableReducer>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableReduce job.
initTableReducerJob(String, Class<? extends TableReducer>, Job, Class) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableReduce job.
initTableReducerJob(String, Class<? extends TableReducer>, Job, Class, String, String, String) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableReduce job.
initTableReducerJob(String, Class<? extends TableReducer>, Job, Class, String, String, String, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableReduce job.
initTableSnapshotMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean, Path) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Sets up the job for reading from a table snapshot.
initTableSnapshotMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean, Path, RegionSplitter.SplitAlgorithm, int) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Sets up the job for reading from a table snapshot.
initTableSnapshotMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Path) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Sets up the job for reading from a table snapshot.
initTableSnapshotMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Path, RegionSplitter.SplitAlgorithm, int) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Sets up the job for reading from a table snapshot.
INPUT_FILES_SEPARATOR_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.WALPlayer
 
INPUT_TABLE - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Job parameter that specifies the input table.
instantiateFilter(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
Create a Filter to apply to all incoming keys (KeyValues) to optionally not include in the job output
INVALID_REGION_NAME_FORMAT_MESSAGE - Static variable in interface org.apache.hadoop.hbase.client.RegionInfo
 
invalidateConnection() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Resets the connections so that the next time getConnection() is called, a new connection is created.
InvalidFamilyOperationException - Exception in org.apache.hadoop.hbase
Thrown if a request is table schema modification is requested but made for an invalid family name.
InvalidFamilyOperationException() - Constructor for exception org.apache.hadoop.hbase.InvalidFamilyOperationException
default constructor
InvalidFamilyOperationException(String) - Constructor for exception org.apache.hadoop.hbase.InvalidFamilyOperationException
Constructor
InvalidFamilyOperationException(Exception) - Constructor for exception org.apache.hadoop.hbase.InvalidFamilyOperationException
Constructor taking another exception.
InvalidMutationDurabilityException - Exception in org.apache.hadoop.hbase.regionserver
Thrown if Mutation's Durability is skip wal but table need replication.
InvalidMutationDurabilityException() - Constructor for exception org.apache.hadoop.hbase.regionserver.InvalidMutationDurabilityException
default constructor
InvalidMutationDurabilityException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.InvalidMutationDurabilityException
 
InvalidRowFilterException - Exception in org.apache.hadoop.hbase.filter
Used to indicate an invalid RowFilter.
InvalidRowFilterException() - Constructor for exception org.apache.hadoop.hbase.filter.InvalidRowFilterException
constructor
InvalidRowFilterException(String) - Constructor for exception org.apache.hadoop.hbase.filter.InvalidRowFilterException
constructor
IS_META - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Used by rest interface to access this metadata attribute which denotes if it is a catalog table, either hbase:meta .
IS_MOB - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
isAborted() - Method in interface org.apache.hadoop.hbase.client.Admin
 
isAdjacent(RegionInfo) - Method in interface org.apache.hadoop.hbase.client.RegionInfo
Returns True if region is adjacent, either just before or just after this one.
isAllTime() - Method in class org.apache.hadoop.hbase.io.TimeRange
Check if it is for all time
isAscendingOrder() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
 
isAsyncPrefetch() - Method in class org.apache.hadoop.hbase.client.Scan
 
isBalancerEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
Query the current state of the balancer.
isBalancerEnabled() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Query the current state of the balancer.
isBalancerRan() - Method in class org.apache.hadoop.hbase.client.BalanceResponse
Returns true if the balancer ran, otherwise false.
isBlobCopy(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses BlobCopy encoding, false otherwise.
isBlobVar(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses BlobVar encoding, false otherwise.
isBlockCacheEnabled() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
Returns True if hfile DATA type blocks should be cached (You cannot disable caching of INDEX and BLOOM type blocks).
isCacheBloomsOnWrite() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
Returns true if we should cache bloomfilter blocks on write
isCacheDataOnWrite() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
Returns true if we should cache data blocks on write
isCacheIndexesOnWrite() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
Returns true if we should cache index blocks on write
isCatalogJanitorEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
Query on the catalog janitor state (Enabled/Disabled?).
isCatalogJanitorEnabled() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Query on the catalog janitor state.
isCheckExistenceOnly() - Method in class org.apache.hadoop.hbase.client.Get
 
isCleanerChoreEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
Query on the cleaner chore state (Enabled/Disabled?).
isCleanerChoreEnabled() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Query the current state of the cleaner chore.
isClosed() - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
Returns whether the connection is closed or not.
isClosed() - Method in interface org.apache.hadoop.hbase.client.Connection
Returns whether the connection is closed or not.
isClusterRunning() - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
Return whether the cluster is running.
isCompactionEnabled() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
Check if the compaction enable flag of the table is true.
isCompressTags() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
Returns Whether KV tags should be compressed along with DataBlockEncoding.
isCorrectEncoder(DataBlockEncoder, short) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
Check if given encoder has this id.
isCreateRootDir() - Method in class org.apache.hadoop.hbase.StartMiniClusterOption
Deprecated.
 
isCreateRootDir() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
 
isCreateWALDir() - Method in class org.apache.hadoop.hbase.StartMiniClusterOption
Deprecated.
 
isCreateWALDir() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
 
isCursor() - Method in class org.apache.hadoop.hbase.client.Result
Return true if this Result is a cursor to tell users where the server has scanned.
isDegenerate() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
Returns True if RegionInfo is degenerate...
isDelete(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
Return true if a delete type, a KeyValue.Type.Delete or a {KeyValue.Type#DeleteFamily} or a KeyValue.Type.DeleteColumn KeyValue type.
isDistributedCluster() - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
 
isDoNotRetry() - Method in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
Returns True if origin exception was a do not retry type.
isDryRun() - Method in class org.apache.hadoop.hbase.client.BalanceRequest
Returns true if the balancer should run in dry run mode, otherwise false.
isEmpty() - Method in class org.apache.hadoop.hbase.client.Mutation
Method to check if the familyMap is empty
isEmpty() - Method in class org.apache.hadoop.hbase.client.Result
Check if the underlying Cell [] is empty or not
isEmpty() - Method in class org.apache.hadoop.hbase.rest.client.Cluster
Returns true if no locations have been added, false otherwise
isEmpty() - Method in interface org.apache.hadoop.hbase.util.ByteRange
Returns true when this range is of zero length, false otherwise.
isEnabled() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerDescription
 
isEncodedRegionName(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
Figure if the passed bytes represent an encoded region name or not.
isEncodedValue(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Returns true when src appears to be positioned an encoded value, false otherwise.
isEncryptionEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Returns true if the column family encryption feature is enabled globally.
isEvictBlocksOnClose() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
Returns true if we should evict cached blocks from the blockcache on close
isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
 
isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.Filter
Check that given column family is essential for filter to check row.
isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
The only CF this filter needs is given column family.
isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
isFirst() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
Returns True if this is first Region in Table
isFixedFloat32(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses fixed-width Float32 encoding, false otherwise.
isFixedFloat64(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses fixed-width Float64 encoding, false otherwise.
isFixedInt16(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses fixed-width Int16 encoding, false otherwise.
isFixedInt32(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses fixed-width Int32 encoding, false otherwise.
isFixedInt64(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses fixed-width Int64 encoding, false otherwise.
isFixedInt8(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses fixed-width Int8 encoding, false otherwise.
isFullServerName(String) - Static method in class org.apache.hadoop.hbase.ServerName
Returns true if the String follows the pattern of ServerName.toString(), false otherwise.
isGetScan() - Method in class org.apache.hadoop.hbase.client.Scan
 
isGroupPrincipal(String) - Static method in class org.apache.hadoop.hbase.AuthUtil
Deprecated.
Returns whether or not the given name should be interpreted as a group principal.
isGuaranteedClientSideOnly() - Method in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
Deprecated.
Returns true if we know no mutation made it to the server, false otherwise.
isHBaseClusterRunning() - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
Return whether the hbase cluster is running.
isHBaseSecurityEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.security.User
Returns whether or not secure authentication is enabled for HBase.
isIgnoreRegionsInTransition() - Method in class org.apache.hadoop.hbase.client.BalanceRequest
Returns true if the balancer should execute even if regions are in transition, otherwise false.
isInMemory() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
Returns True if we are to favor keeping all values for this column family in the HRegionServer cache.
isInViolation() - Method in interface org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView.SpaceQuotaStatusView
Returns true if the quota is being violated, false otherwise.
isKilledRS(ServerName) - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
Keeping track of killed servers and being able to check if a particular server was killed makes it possible to do fault tolerance testing for dead servers in a deterministic way.
isKilledRS(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
 
isLast() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
Returns True if this is last Region in Table
isLegalColumnFamilyName(byte[]) - Static method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Check if the column family name is legal.
isLegalFullyQualifiedTableName(byte[]) - Static method in class org.apache.hadoop.hbase.TableName
Check passed byte array, "tableName", is legal user-space table name.
isLegalNamespaceName(byte[]) - Static method in class org.apache.hadoop.hbase.TableName
 
isLegalNamespaceName(byte[], int, int) - Static method in class org.apache.hadoop.hbase.TableName
Valid namespace characters are alphabetic characters, numbers, and underscores.
isLegalTableQualifierName(byte[]) - Static method in class org.apache.hadoop.hbase.TableName
 
isLegalTableQualifierName(byte[], boolean) - Static method in class org.apache.hadoop.hbase.TableName
 
isLegalTableQualifierName(byte[], int, int) - Static method in class org.apache.hadoop.hbase.TableName
Qualifier names can only contain 'word' characters [\p{IsAlphabetic}\p{Digit}] or '_', '.' or '-'.
isLegalTableQualifierName(byte[], int, int, boolean) - Static method in class org.apache.hadoop.hbase.TableName
 
isLocked() - Method in class org.apache.hadoop.hbase.client.locking.EntityLock
 
isLoginFromKeytab() - Method in class org.apache.hadoop.hbase.security.User
Returns true if user credentials are obtained from keytab.
isMasterInMaintenanceMode() - Method in interface org.apache.hadoop.hbase.client.Admin
Check whether Master is in maintenance mode.
isMasterInMaintenanceMode() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Check whether master is in maintenance mode
isMaxColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
Returns if max column range is inclusive.
isMergeEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
Query the current state of the merge switch.
isMergeEnabled() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Query the current state of the Merge switch.
isMergeEnabled() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
Check if the merge enable flag of the table is true.
isMetaRegion() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
Returns true if this region is a meta region.
isMetaRegion() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
Checks if this table is hbase:meta region.
isMetaTable() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
Checks if the table is a hbase:meta table
isMetaTableName(TableName) - Static method in class org.apache.hadoop.hbase.TableName
Returns True if tn is the hbase:meta table name.
isMinColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
Returns if min column range is inclusive.
isMobEnabled() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
Gets whether the mob is enabled for the family.
isNeedCursorResult() - Method in class org.apache.hadoop.hbase.client.Scan
 
isNewVersionBehavior() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
By default, HBase only consider timestamp in versions.
isNewVersionBehaviorEnabled() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Check whether the tests should assume NEW_VERSION_BEHAVIOR when creating new column families.
isNext(RegionInfo) - Method in interface org.apache.hadoop.hbase.client.RegionInfo
Returns True if region is next, adjacent but 'after' this one.
isNormalizationEnabled() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
Check if normalization enable flag of the table is true.
isNormalizerEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
Query the current state of the region normalizer.
isNormalizerEnabled() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Query the current state of the region normalizer
isNull() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
Returns true if the filter is empty
isNull(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src is null, false otherwise.
isNullable() - Method in interface org.apache.hadoop.hbase.types.DataType
Indicates whether this instance supports encoding null values.
isNullable() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
 
isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedBytesBase
 
isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
 
isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
 
isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedInt16
 
isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedInt32
 
isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedInt64
 
isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedInt8
 
isNullable() - Method in class org.apache.hadoop.hbase.types.RawByte
 
isNullable() - Method in class org.apache.hadoop.hbase.types.RawBytes
 
isNullable() - Method in class org.apache.hadoop.hbase.types.RawDouble
 
isNullable() - Method in class org.apache.hadoop.hbase.types.RawFloat
 
isNullable() - Method in class org.apache.hadoop.hbase.types.RawInteger
 
isNullable() - Method in class org.apache.hadoop.hbase.types.RawLong
 
isNullable() - Method in class org.apache.hadoop.hbase.types.RawShort
 
isNullable() - Method in class org.apache.hadoop.hbase.types.RawString
 
isNullable() - Method in class org.apache.hadoop.hbase.types.Struct
 
isNullable() - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
 
isNullable() - Method in class org.apache.hadoop.hbase.types.Union2
 
isNullable() - Method in class org.apache.hadoop.hbase.types.Union3
 
isNullable() - Method in class org.apache.hadoop.hbase.types.Union4
 
isNumeric(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses Numeric encoding, false otherwise.
isNumericInfinite(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses Numeric encoding and is Infinite, false otherwise.
isNumericNaN(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses Numeric encoding and is NaN, false otherwise.
isNumericZero(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses Numeric encoding and is 0, false otherwise.
isOffline() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
Deprecated.
since 3.0.0 and will be removed in 4.0.0
isolateRegions() - Method in class org.apache.hadoop.hbase.util.RegionMover
Isolated regions specified in RegionMover.isolateRegionIdArray on RegionMover.hostname in ack Mode and Unload regions from given RegionMover.hostname using ack/noAck mode and RegionMover.maxthreads.
IsolationLevel - Enum in org.apache.hadoop.hbase.client
Specify Isolation levels in Scan operations.
isOrderPreserving() - Method in interface org.apache.hadoop.hbase.types.DataType
Indicates whether this instance writes encoded byte[]'s which preserve the natural sort order of the unencoded value.
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.OrderedBytesBase
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawByte
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawBytes
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawDouble
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawFloat
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawInteger
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawLong
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawShort
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawString
 
isOrderPreserving - Variable in class org.apache.hadoop.hbase.types.Struct
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.Struct
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.Union2
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.Union3
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.Union4
 
isOverlap(RegionInfo) - Method in interface org.apache.hadoop.hbase.client.RegionInfo
Returns True if an overlap in region range.
isPrefetchBlocksOnOpen() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
Returns true if we should prefetch blocks into the blockcache on open
isProcedureFinished(String, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.client.Admin
Check the current state of the specified procedure.
isProcedureFinished(String, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Check the current state of the specified procedure.
isPut(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
Returns True if this cell is a Put.
isQuoteUnescaped(byte[], int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Returns a boolean indicating whether the quote was escaped or not
isRaw() - Method in class org.apache.hadoop.hbase.client.Scan
Returns True if this Scan is in "raw" mode.
isReadOnly() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
Check if the readOnly flag of the table is set.
isReadShortCircuitOn() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Get the HBase setting for dfs.client.read.shortcircuit from the conf or a system property.
isRecovered() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
 
isRecoverySupported() - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
 
isRemote() - Method in exception org.apache.hadoop.hbase.errorhandling.ForeignException
The cause of a ForeignException can be an exception that was generated on a local in process thread, or a thread from a 'remote' separate process.
isReplicationPeerEnabled(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Check if a replication peer is enabled.
isReplicationPeerEnabled(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Check if a replication peer is enabled.
isReplicationPeerModificationEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
Check whether replication peer modification is enabled.
isReplicationPeerModificationEnabled() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Check whether replication peer modification is enabled.
isReturnResults() - Method in class org.apache.hadoop.hbase.client.Append
Returns current setting for returnResults
isReturnResults() - Method in class org.apache.hadoop.hbase.client.Increment
Returns current setting for returnResults
isReturnResults() - Method in class org.apache.hadoop.hbase.client.Mutation
Returns current value for returnResults
isReversed() - Method in class org.apache.hadoop.hbase.client.Scan
Get whether this scan is a reversed one.
isReversed() - Method in class org.apache.hadoop.hbase.filter.Filter
 
isReversed() - Method in class org.apache.hadoop.hbase.filter.FilterList
 
isRpcThrottleEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
Get if the rpc throttle is enabled.
isRpcThrottleEnabled() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Get if the rpc throttle is enabled.
isRunning() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
 
isSameAddress(ServerName, ServerName) - Static method in class org.apache.hadoop.hbase.ServerName
Compare two addresses
isScanMetricsEnabled() - Method in class org.apache.hadoop.hbase.client.Scan
Returns True if collection of scan metrics is enabled.
isSearchRowInclusive() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
 
isSecurityEnabled() - Static method in class org.apache.hadoop.hbase.security.User
Returns whether or not Kerberos authentication is configured for Hadoop.
isSerial() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
isServerOverloaded(Throwable) - Static method in exception org.apache.hadoop.hbase.HBaseServerException
Returns True if the server was considered overloaded when the exception was thrown
isServerOverloaded() - Method in exception org.apache.hadoop.hbase.HBaseServerException
Returns True if server was considered overloaded when exception was thrown
isServerOverloaded() - Method in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
Returns True if the server was considered overloaded when the exception was thrown.
isShowConfInServlet() - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
Returns whether to show HBase Configuration in servlet
isSkippable() - Method in interface org.apache.hadoop.hbase.types.DataType
Indicates whether this instance is able to skip over it's encoded value.
isSkippable() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
 
isSkippable() - Method in class org.apache.hadoop.hbase.types.OrderedBlob
 
isSkippable() - Method in class org.apache.hadoop.hbase.types.OrderedBytesBase
 
isSkippable() - Method in class org.apache.hadoop.hbase.types.RawByte
 
isSkippable() - Method in class org.apache.hadoop.hbase.types.RawBytes
 
isSkippable() - Method in class org.apache.hadoop.hbase.types.RawDouble
 
isSkippable() - Method in class org.apache.hadoop.hbase.types.RawFloat
 
isSkippable() - Method in class org.apache.hadoop.hbase.types.RawInteger
 
isSkippable() - Method in class org.apache.hadoop.hbase.types.RawLong
 
isSkippable() - Method in class org.apache.hadoop.hbase.types.RawShort
 
isSkippable() - Method in class org.apache.hadoop.hbase.types.RawString
 
isSkippable - Variable in class org.apache.hadoop.hbase.types.Struct
 
isSkippable() - Method in class org.apache.hadoop.hbase.types.Struct
 
isSkippable() - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
 
isSkippable() - Method in class org.apache.hadoop.hbase.types.Union2
 
isSkippable() - Method in class org.apache.hadoop.hbase.types.Union3
 
isSkippable() - Method in class org.apache.hadoop.hbase.types.Union4
 
isSnapshotCleanupEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
Query the current state of the auto snapshot cleanup based on TTL.
isSnapshotCleanupEnabled() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Query the current state of the auto snapshot cleanup based on TTL.
isSnapshotFinished(SnapshotDescription) - Method in interface org.apache.hadoop.hbase.client.Admin
Check the current state of the passed snapshot.
isSnapshotFinished(SnapshotDescription) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Check the current state of the passed snapshot.
isSorted(Collection<byte[]>) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
isSplit() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
Returns True if has been split and has daughters.
isSplitEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
Query the current state of the split switch.
isSplitEnabled() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Query the current state of the Split switch.
isSplitEnabled() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
Check if the split enable flag of the table is true.
isSplitParent() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
Deprecated.
since 3.0.0 and will be removed in 4.0.0, Use RegionInfo.isSplit() instead.
isStale() - Method in class org.apache.hadoop.hbase.client.Result
Whether or not the results are coming from possibly stale data.
isSticky() - Method in class org.apache.hadoop.hbase.rest.client.Client
The default behaviour is load balancing by sending each request to a random host.
isStopped() - Method in interface org.apache.hadoop.hbase.Stoppable
Returns True if Stoppable.stop(String) has been closed.
isSuccess() - Method in class org.apache.hadoop.hbase.client.CheckAndMutateResult
Returns Whether the CheckAndMutate operation is successful or not
isSyncReplication() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
Use remote wal dir to decide whether a peer is sync replication peer
isSystemTable() - Method in class org.apache.hadoop.hbase.TableName
 
isTableAvailable(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Check if a table is available.
isTableAvailable(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Check if a table is available.
isTableDisabled(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Check if a table is disabled.
isTableDisabled(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Check if a table is disabled.
isTableEnabled(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Check if a table is enabled.
isTableEnabled(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Check if a table is enabled.
isText(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses Text encoding, false otherwise.
iterateOnSplits(byte[], byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Iterate over keys within the passed range, splitting at an [a,b) boundary.
iterateOnSplits(byte[], byte[], boolean, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Iterate over keys within the passed range.
iterator() - Method in interface org.apache.hadoop.hbase.client.ResultScanner
 
iterator() - Method in class org.apache.hadoop.hbase.quotas.QuotaRetriever
 
iterator(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Struct
Retrieve an Iterator over the values encoded in src.
iterator() - Method in class org.apache.hadoop.hbase.util.PairOfSameType
 
IV_LENGTH - Static variable in class org.apache.hadoop.hbase.io.crypto.Cipher
 

J

JOB_NAME_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
join() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
Wait for Mini HBase Cluster to shut down.
JsonMapper - Class in org.apache.hadoop.hbase.util
Utility class for converting objects to JSON

K

K - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'K'
KB_IN_BYTES - Static variable in class org.apache.hadoop.hbase.HConstants
KB, MB, GB, TB equivalent to how many bytes
KEEP_DELETED_CELLS - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Retain all cells across flushes and compactions even if they fall behind a delete tombstone.
KEEP_SEQID_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for # days to keep MVCC values during a major compaction
KeepDeletedCells - Enum in org.apache.hadoop.hbase
Ways to keep cells marked for delete around.
KEY_ENCODING_QUERY_PARAM_NAME - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
KEY_FOR_HOSTNAME_SEEN_BY_MASTER - Static variable in class org.apache.hadoop.hbase.HConstants
 
KEY_LENGTH - Static variable in class org.apache.hadoop.hbase.io.crypto.Cipher
 
KEY_LENGTH_BITS - Static variable in class org.apache.hadoop.hbase.io.crypto.Cipher
 
KeyOnlyFilter - Class in org.apache.hadoop.hbase.filter
A filter that will only return the key component of each KV (the value will be rewritten as empty).
KeyOnlyFilter() - Constructor for class org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
KeyOnlyFilter(boolean) - Constructor for class org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
KeyProvider - Interface in org.apache.hadoop.hbase.io.crypto
KeyProvider is a interface to abstract the different methods of retrieving key material from key storage such as Java key store.
KEYS - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
KEYS_FOR_HBA_CREATE_TABLE - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
KeyStoreKeyProvider - Class in org.apache.hadoop.hbase.io.crypto
A basic KeyProvider that can resolve keys from a protected KeyStore file on the local filesystem.
KeyStoreKeyProvider() - Constructor for class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
 
killAll() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
Do a simulated kill all masters and regionservers.
killCurrentActiveZooKeeperServer() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
 
killDataNode(ServerName) - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
Kills the datanode process if this is a distributed cluster, otherwise, this causes master to exit doing basic clean up only.
killDataNode(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
 
killMaster(ServerName) - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
Kills the master process if this is a distributed cluster, otherwise, this causes master to exit doing basic clean up only.
killMaster(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
 
killMiniHBaseCluster() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Abruptly Shutdown HBase mini cluster.
killNameNode(ServerName) - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
Kills the namenode process if this is a distributed cluster, otherwise, this causes master to exit doing basic clean up only.
killNameNode(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
 
killOneBackupZooKeeperServer() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
Kill one back up ZK servers.
killRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
Kills the region server process if this is a distributed cluster, otherwise this causes the region server to exit doing basic clean up only.
killRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
 
killZkNode(ServerName) - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
Kills the zookeeper node process if this is a distributed cluster, otherwise, this causes master to exit doing basic clean up only.
killZkNode(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
 
kvCreator - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
 
KVP_DELIMITER - Static variable in class org.apache.hadoop.hbase.util.ConfigurationUtil
 

L

L - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'L'
LAST_CHAR - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
LAST_ROW - Static variable in class org.apache.hadoop.hbase.HConstants
Used by scanners and others when they're trying to detect the end of a table
lastHost - Variable in class org.apache.hadoop.hbase.rest.client.Cluster
 
LATEST_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.HConstants
Timestamp to use when we want to refer to the latest cell.
LATEST_TIMESTAMP_BYTES - Static variable in class org.apache.hadoop.hbase.HConstants
LATEST_TIMESTAMP in bytes form
latestVersionOnly - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
LeaseException - Exception in org.apache.hadoop.hbase.regionserver
Reports a problem with a lease
LeaseException() - Constructor for exception org.apache.hadoop.hbase.regionserver.LeaseException
default constructor
LeaseException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.LeaseException
 
LeaseNotRecoveredException - Exception in org.apache.hadoop.hbase.util
Thrown when the lease was expected to be recovered, but the file can't be opened.
LeaseNotRecoveredException() - Constructor for exception org.apache.hadoop.hbase.util.LeaseNotRecoveredException
 
LeaseNotRecoveredException(String) - Constructor for exception org.apache.hadoop.hbase.util.LeaseNotRecoveredException
 
LeaseNotRecoveredException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.util.LeaseNotRecoveredException
 
LeaseNotRecoveredException(Throwable) - Constructor for exception org.apache.hadoop.hbase.util.LeaseNotRecoveredException
 
len(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Returns length of the byte array, returning 0 if the array is null.
length - Variable in class org.apache.hadoop.hbase.types.FixedLengthWrapper
 
length(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return the number of encoded entries remaining in buff.
LESS_THAN_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
LESS_THAN Array
LESS_THAN_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
 
LESS_THAN_OR_EQUAL_TO_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
LESS_THAN_OR_EQUAL_TO Array
LESS_THAN_OR_EQUAL_TO_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
 
limitNamespaceSpace(String, long, SpaceViolationPolicy) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Creates a QuotaSettings object to limit the FileSystem space usage for the given namespace to the given size in bytes.
limitNumMapTasks(String, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Ensures that the given number of map tasks for the given job configuration does not exceed the number of regions for the given table.
limitNumReduceTasks(String, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Ensures that the given number of reduce tasks for the given job configuration does not exceed the number of regions for the given table.
limitNumReduceTasks(String, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Ensures that the given number of reduce tasks for the given job configuration does not exceed the number of regions for the given table.
limitTableSpace(TableName, long, SpaceViolationPolicy) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Creates a QuotaSettings object to limit the FileSystem space usage for the given table to the given size in bytes.
listCells() - Method in class org.apache.hadoop.hbase.client.Result
Create a sorted list of the Cell's in this result.
listDeadServers() - Method in interface org.apache.hadoop.hbase.client.Admin
List dead region servers.
listDeadServers() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
List all the dead region servers.
listDecommissionedRegionServers() - Method in interface org.apache.hadoop.hbase.client.Admin
List region servers marked as decommissioned, which can not be assigned regions.
listDecommissionedRegionServers() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
List region servers marked as decommissioned, which can not be assigned regions.
listener(BufferedMutator.ExceptionListener) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
Override the default error handler.
listNamespaceDescriptors() - Method in interface org.apache.hadoop.hbase.client.Admin
List available namespace descriptors
listNamespaceDescriptors() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
List available namespace descriptors
listNamespaces() - Method in interface org.apache.hadoop.hbase.client.Admin
List available namespaces
listNamespaces() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
List available namespaces
listReplicatedTableCFs() - Method in interface org.apache.hadoop.hbase.client.Admin
Find all table and column families that are replicated from this cluster
listReplicatedTableCFs() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Find all table and column families that are replicated from this cluster
listReplicationPeers() - Method in interface org.apache.hadoop.hbase.client.Admin
Return a list of replication peers.
listReplicationPeers(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
Return a list of replication peers.
listReplicationPeers() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Return a list of replication peers.
listReplicationPeers(Pattern) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Return a list of replication peers.
listRSGroups() - Method in interface org.apache.hadoop.hbase.client.Admin
Lists current set of RegionServer groups
listRSGroups() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Lists current set of RegionServer groups
listSnapshots() - Method in interface org.apache.hadoop.hbase.client.Admin
List completed snapshots.
listSnapshots(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
List all the completed snapshots matching the given pattern.
listSnapshots() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
List completed snapshots.
listSnapshots(Pattern) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
List all the completed snapshots matching the given pattern.
listTableDescriptors() - Method in interface org.apache.hadoop.hbase.client.Admin
List all the userspace tables.
listTableDescriptors(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
List all userspace tables and whether or not include system tables.
listTableDescriptors(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
List all the userspace tables that match the given pattern.
listTableDescriptors(Pattern, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
List all the tables matching the given pattern.
listTableDescriptors(List<TableName>) - Method in interface org.apache.hadoop.hbase.client.Admin
Get tableDescriptors.
listTableDescriptors() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
List all the userspace tables.
listTableDescriptors(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
List all the tables.
listTableDescriptors(Pattern, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
List all the tables matching the given pattern.
listTableDescriptors(List<TableName>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
List specific tables including system tables.
listTableDescriptorsByNamespace(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Get list of table descriptors by namespace.
listTableDescriptorsByNamespace(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Get list of table descriptors by namespace.
listTableDescriptorsByState(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
List all enabled or disabled tables
listTableDescriptorsByState(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
List all enabled or disabled table descriptors
listTableNames() - Method in interface org.apache.hadoop.hbase.client.Admin
List all of the names of userspace tables.
listTableNames(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
List all of the names of userspace tables.
listTableNames(Pattern, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
List all of the names of userspace tables.
listTableNames() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
List all of the names of userspace tables.
listTableNames(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
List all of the names of tables.
listTableNames(Pattern, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
List all of the names of userspace tables.
listTableNamesByNamespace(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Get list of table names by namespace.
listTableNamesByNamespace(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Get list of table names by namespace.
listTableNamesByState(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
List all enabled or disabled table names
listTableNamesByState(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
List all enabled or disabled table names
listTablesInRSGroup(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Get all tables in this RegionServer group.
listTablesInRSGroup(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Get all tables in this RegionServer group.
listTableSnapshots(Pattern, Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
List all the completed snapshots matching the given table name regular expression and snapshot name regular expression.
listTableSnapshots(Pattern) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
List all the completed snapshots matching the given table name pattern.
listTableSnapshots(Pattern, Pattern) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
List all the completed snapshots matching the given table name regular expression and snapshot name regular expression.
listUnknownServers() - Method in interface org.apache.hadoop.hbase.client.Admin
List unknown region servers.
listUnknownServers() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
List all the unknown region servers.
load(URI) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
 
load() - Method in class org.apache.hadoop.hbase.util.RegionMover
Loads the specified RegionMover.hostname with regions listed in the RegionMover.filename RegionMover Object has to be created using RegionMover(RegionMoverBuilder)
LOAD_BALANCER_SLOP_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
loadColumnFamiliesOnDemand - Variable in class org.apache.hadoop.hbase.client.Query
 
loadNumericRows(Table, byte[], int, int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
loadRandomRows(Table, byte[], int, int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
loadRegion(HRegion, byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
loadRegion(Region, byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
loadRegion(HRegion, byte[], boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Load region with rows from 'aaa' to 'zzz'.
loadTable(Table, byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Load table with rows from 'aaa' to 'zzz'.
loadTable(Table, byte[], boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Load table with rows from 'aaa' to 'zzz'.
loadTable(Table, byte[][]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Load table of multiple column families with rows from 'aaa' to 'zzz'.
loadTable(Table, byte[][], byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Load table of multiple column families with rows from 'aaa' to 'zzz'.
loadTable(Table, byte[][], byte[], boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Load table of multiple column families with rows from 'aaa' to 'zzz'.
loadValue(byte[], byte[], ByteBuffer) - Method in class org.apache.hadoop.hbase.client.Result
Loads the latest version of the specified column into the provided ByteBuffer.
loadValue(byte[], int, int, byte[], int, int, ByteBuffer) - Method in class org.apache.hadoop.hbase.client.Result
Loads the latest version of the specified column into the provided ByteBuffer.
LOCALHOST - Static variable in class org.apache.hadoop.hbase.HConstants
Host name of the local machine
LOCALHOST_IP - Static variable in class org.apache.hadoop.hbase.HConstants
 
LOCALITY_SENSITIVE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
Keep locality while generating HFiles for bulkload.
LOCATOR_META_REPLICAS_MODE - Static variable in interface org.apache.hadoop.hbase.client.RegionLocator
Configuration for Region Locator's mode when meta replica is configured.
LOCATOR_META_REPLICAS_MODE_LOADBALANCE_SELECTOR - Static variable in interface org.apache.hadoop.hbase.client.RegionLocator
Configuration for meta replica selector when Region Locator's LoadBalance mode is configured.
LOG - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
LOG - Static variable in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
Deprecated.
 
LOG - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
LOG - Static variable in class org.apache.hadoop.hbase.mapreduce.TableSplit
Deprecated.
LOG variable would be made private. fix in hbase 3.0
LOG_BAD_LINES_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
LOG_PER_ROW_COUNT - Static variable in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
 
LogEntry - Class in org.apache.hadoop.hbase.client
Abstract response class representing online logs response from ring-buffer use-cases e.g slow/large RPC logs, balancer decision logs
LogEntry() - Constructor for class org.apache.hadoop.hbase.client.LogEntry
 
login(Configuration, String, String, String) - Static method in class org.apache.hadoop.hbase.security.User
Log in the current process using the given configuration keys for the credential file and login principal.
login(String, String) - Static method in class org.apache.hadoop.hbase.security.User
Login with the given keytab and principal.
loginClient(Configuration) - Static method in class org.apache.hadoop.hbase.AuthUtil
Deprecated.
For kerberized cluster, return login user (from kinit or from keytab if specified).
LogQueryFilter - Class in org.apache.hadoop.hbase.client
Deprecated.
as of 2.4.0. Will be removed in 4.0.0.
LogQueryFilter() - Constructor for class org.apache.hadoop.hbase.client.LogQueryFilter
Deprecated.
 
logVersion() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
 
LongComparator - Class in org.apache.hadoop.hbase.filter
A long comparator which numerical compares against the specified byte array
LongComparator(long) - Constructor for class org.apache.hadoop.hbase.filter.LongComparator
 
LOOPBACK_HOST - Static variable in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
 
LPAREN - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for LPAREN
LPAREN_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
LPAREN Array
LPAREN_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
 

M

main(String[]) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
For debugging.
main(String[]) - Static method in class org.apache.hadoop.hbase.mapred.RowCounter
 
main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.CellCounter
Main entry point.
main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.CopyTable
Main entry point.
main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.Export
Main entry point.
main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
Main entry point.
main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.RoundRobinTableInputFormat
Pass table name as argument.
main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.RowCounter
Main entry point.
main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.WALPlayer
Main entry point.
main(String[]) - Static method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
 
main(String[]) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
 
main(String[]) - Static method in class org.apache.hadoop.hbase.util.RegionMover
 
main(String[]) - Static method in class org.apache.hadoop.hbase.util.VersionInfo
 
MAJOR_COMPACTION_JITTER - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name and default value for major compaction jitter.
MAJOR_COMPACTION_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name and default value for how often a region should perform a major compaction
MAJOR_VERSION - Static variable in exception org.apache.hadoop.hbase.exceptions.RequestTooBigException
 
majorCompact(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Major compact a table.
majorCompact(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Major compact a column family within a table.
majorCompact(TableName, CompactType) - Method in interface org.apache.hadoop.hbase.client.Admin
Major compact a table.
majorCompact(TableName, byte[], CompactType) - Method in interface org.apache.hadoop.hbase.client.Admin
Major compact a column family within a table.
majorCompact(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Major compact a table.
majorCompact(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Major compact a column family within a table.
majorCompact(TableName, CompactType) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Major compact a table.
majorCompact(TableName, byte[], CompactType) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Major compact a column family within a table.
majorCompactRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Major compact a table or an individual region.
majorCompactRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Major compact a column family within region.
majorCompactRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Major compact a region.
majorCompactRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Major compact a column family within region.
majorCompactRegionServer(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
Major compact all regions on the region server.
majorCompactRegionServer(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Compact all regions on the region server.
makeColumn(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
Makes a column in family:qualifier form from separate byte arrays.
map(ImmutableBytesWritable, Result, OutputCollector<ImmutableBytesWritable, Result>, Reporter) - Method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
Extract the grouping columns from value to construct a new key.
map(ImmutableBytesWritable, Result, OutputCollector<ImmutableBytesWritable, Result>, Reporter) - Method in class org.apache.hadoop.hbase.mapred.IdentityTableMap
Pass the key, value to reduce
map(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Result>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
Extract the grouping columns from value to construct a new key.
map(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Result>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.IdentityTableMapper
Pass the key, value to reduce.
map(LongWritable, Text, Mapper<LongWritable, Text, ImmutableBytesWritable, Put>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
Convert a line of TSV text into an HBase table row.
map(LongWritable, Text, Mapper<LongWritable, Text, ImmutableBytesWritable, Text>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
Convert a line of TSV text into an HBase table row.
mapKey(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Calculate a hash code from a given byte array suitable for use as a key in maps.
mapKey(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Calculate a hash code from a given byte array suitable for use as a key in maps.
MAPPER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
MAPREDUCE_INPUT_AUTOBALANCE - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Specify if we enable auto-balance to set number of mappers in M/R jobs.
MASK_FOR_LOWER_INT_IN_LONG - Static variable in class org.apache.hadoop.hbase.util.Bytes
Mask to apply to a long to reveal the lower int only.
MASTER__META_TRANSITION_HANDLER_COUNT_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
MASTER_ADDRS_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for the list of master host:ports
MASTER_CLOSE_REGION_THREADS - Static variable in class org.apache.hadoop.hbase.HConstants
 
MASTER_CLOSE_REGION_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
MASTER_IMPL - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for what master implementation to use.
MASTER_INFO_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for master web API port
MASTER_LOG_REPLAY_OPS_THREADS - Static variable in class org.apache.hadoop.hbase.HConstants
 
MASTER_LOG_REPLAY_OPS_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
MASTER_MERGE_DISPATCH_THREADS - Static variable in class org.apache.hadoop.hbase.HConstants
Number of threads used to dispatch merge operations to the regionservers.
MASTER_MERGE_DISPATCH_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
MASTER_META_SERVER_OPERATIONS_THREADS - Static variable in class org.apache.hadoop.hbase.HConstants
 
MASTER_META_SERVER_OPERATIONS_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
MASTER_META_TRANSITION_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
 
MASTER_OPEN_REGION_THREADS - Static variable in class org.apache.hadoop.hbase.HConstants
Configurations for master executor services.
MASTER_OPEN_REGION_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
MASTER_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for port master listens on.
MASTER_SERVER_OPERATIONS_THREADS - Static variable in class org.apache.hadoop.hbase.HConstants
 
MASTER_SERVER_OPERATIONS_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
MASTER_TYPE_BACKUP - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for the master type being backup (waits for primary to go inactive).
MasterNotRunningException - Exception in org.apache.hadoop.hbase
Thrown if the master is not running
MasterNotRunningException() - Constructor for exception org.apache.hadoop.hbase.MasterNotRunningException
default constructor
MasterNotRunningException(String) - Constructor for exception org.apache.hadoop.hbase.MasterNotRunningException
Constructor
MasterNotRunningException(Exception) - Constructor for exception org.apache.hadoop.hbase.MasterNotRunningException
Constructor taking another exception.
MasterNotRunningException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.MasterNotRunningException
 
MasterSwitchType - Enum in org.apache.hadoop.hbase.client
Represents the master switch type
matchedColumn - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
matchingColumn(Cell, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
 
matchingColumn(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
matchingColumnFamilyAndQualifierPrefix(Cell, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
Returns True if matching column family and the qualifier starts with qual
matchingFamily(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
matchingFamily(Cell, byte, Cell, byte) - Static method in class org.apache.hadoop.hbase.CellUtil
 
matchingFamily(Cell, byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
 
matchingQualifier(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
matchingQualifier(Cell, byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
Finds if the qualifier part of the cell and the KV serialized byte[] are equal.
matchingRow(Cell, byte[], int, int) - Static method in class org.apache.hadoop.hbase.CellUtil
 
matchingRowColumn(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
Compares the row and column of two keyvalues for equality
matchingRowColumnBytes(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
Compares the row and column of two keyvalues for equality
matchingRows(Cell, byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
 
matchingRows(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
Compares the row of two keyvalues for equality
matchingRows(Cell, short, Cell, short) - Static method in class org.apache.hadoop.hbase.CellUtil
Compares the row of two keyvalues for equality
matchingTags(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
matchingTimestamp(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
matchingValue(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
matchingValue(Cell, Cell, int, int) - Static method in class org.apache.hadoop.hbase.CellUtil
 
matchingValue(Cell, byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
 
matchReplicationScope(boolean) - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
Check if the table's cfs' replication scope matched with the replication state
MAX_AVERAGE_REGION_SIZE - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
In auto-balance, we split input by ave region size, if calculated region size is too big, we can set it.
MAX_BACKOFF_KEY - Static variable in class org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
 
MAX_FILESIZE - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Used by HBase Shell interface to access this metadata attribute which denotes the maximum size of the store file after which a region split occurs.
MAX_PRECISION - Static variable in class org.apache.hadoop.hbase.util.OrderedBytes
Max precision guaranteed to fit into a long.
MAX_ROW_LENGTH - Static variable in class org.apache.hadoop.hbase.HConstants
Max length a row can have because of the limitation in TFile.
MAX_VERSIONS - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
maxColumn - Variable in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
maxColumnInclusive - Variable in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
MAXIMUM_VALUE_LENGTH - Static variable in class org.apache.hadoop.hbase.HConstants
Maximum value length, enforced on KeyValue construction
maxKeyValueSize(int) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
Override the maximum key-value size specified by the provided Connection's Configuration instance, via the configuration key hbase.client.keyvalue.maxsize.
maxQueueLength - Variable in class org.apache.hadoop.hbase.ipc.PluggableBlockingQueue
 
mayHaveClusterIssues() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
mayHaveMoreCellsInRow() - Method in class org.apache.hadoop.hbase.client.Result
For scanning large rows, the RS may choose to return the cells chunk by chunk to prevent OOM or timeout.
MB_IN_BYTES - Static variable in class org.apache.hadoop.hbase.HConstants
 
MD5_HEX_LENGTH - Static variable in interface org.apache.hadoop.hbase.client.RegionInfo
 
MD5Hash - Class in org.apache.hadoop.hbase.util
Utility class for MD5 MD5 hash produces a 128-bit digest.
MD5Hash() - Constructor for class org.apache.hadoop.hbase.util.MD5Hash
 
MemoryCompactionPolicy - Enum in org.apache.hadoop.hbase
Enum describing all possible memory compaction policies
MEMSTORE_FLUSHSIZE - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Used by HBase Shell interface to access this metadata attribute which represents the maximum size of the memstore after which its contents are flushed onto the disk.
MEMSTORETS_TAGS_PARAMETRIZED - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
This is for unit tests parameterized with a single boolean.
memStoreTSTagsAndOffheapCombination() - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
merge(Configuration, Configuration) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
Merge two configurations.
MERGE_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 merge enabled.
MERGE_QUALIFIER_PREFIX - Static variable in class org.apache.hadoop.hbase.HConstants
 
MERGE_QUALIFIER_PREFIX_STR - Static variable in class org.apache.hadoop.hbase.HConstants
Merge qualifier prefix.
MERGEA_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
Deprecated.
Since 2.3.0 and 2.2.1. Not used anymore. Instead we look for the HConstants.MERGE_QUALIFIER_PREFIX_STR prefix.
MERGEB_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
Deprecated.
Since 2.3.0 and 2.2.1. Not used anymore. Instead we look for the HConstants.MERGE_QUALIFIER_PREFIX_STR prefix.
MergeRegionException - Exception in org.apache.hadoop.hbase.exceptions
Thrown when something is wrong in trying to merge two regions.
MergeRegionException() - Constructor for exception org.apache.hadoop.hbase.exceptions.MergeRegionException
default constructor
MergeRegionException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.MergeRegionException
Constructor
MergeRegionException(Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.MergeRegionException
 
mergeRegions(byte[], byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Deprecated.
since 2.3.0 and will be removed in 4.0.0.Use AsyncAdmin.mergeRegions(List, boolean) instead.
mergeRegions(List<byte[]>, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Merge multiple regions (>=2).
mergeRegionsAsync(byte[], byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.3.0 and will be removed in 4.0.0. Multi-region merge feature is now supported. Use Admin.mergeRegionsAsync(byte[][], boolean) instead.
mergeRegionsAsync(byte[][], boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Merge multiple regions (>=2).
mergeSwitch(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Turn the merge switch on or off.
mergeSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Turn the Merge switch on or off.
mergeSwitch(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Turn the Merge switch on or off.
META_REPLICAS_NUM - Static variable in class org.apache.hadoop.hbase.HConstants
Deprecated.
Since 2.4.0, will be removed in 4.0.0. Please change the meta replicas number by altering meta table, i.e, set a new 'region replication' number and call modifyTable.
META_ROW_DELIMITER - Static variable in class org.apache.hadoop.hbase.HConstants
delimiter used between portions of a region name
META_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.TableName
The hbase:meta table's name.
META_VERSION - Static variable in class org.apache.hadoop.hbase.HConstants
The current version of the meta table.
META_VERSION_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
The meta table version column qualifier.
METADATA - Static variable in class org.apache.hadoop.hbase.HConstants
 
METRICS_RIT_STUCK_WARNING_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
Region in Transition metrics threshold time
MIGRATION_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
Any artifacts left from migration can be moved here
MIMETYPE_BINARY - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
MIMETYPE_HTML - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
MIMETYPE_JSON - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
MIMETYPE_PROTOBUF - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
MIMETYPE_PROTOBUF_IETF - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
MIMETYPE_TEXT - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
MIMETYPE_XML - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
MIN_AGE_TO_ARCHIVE_KEY - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
Minimum MOB file age to archive, default (3600000 - 1h)
MIN_KEEP_SEQID_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
At least to keep MVCC values in hfiles for 5 days
MIN_VERSIONS - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
MIN_WRITE_BUFFER_PERIODIC_FLUSH_TIMERTICK_MS - Static variable in interface org.apache.hadoop.hbase.client.BufferedMutator
Having the timer tick run more often that once every 100ms is needless and will probably cause too many timer events firing having a negative impact on performance.
minColumn - Variable in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
minColumnInclusive - Variable in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
MiniHBaseCluster - Class in org.apache.hadoop.hbase
Deprecated.
since 3.0.0, will be removed in 4.0.0. Use TestingHBaseCluster instead.
MiniHBaseCluster(Configuration, int) - Constructor for class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
Start a MiniHBaseCluster.
MiniHBaseCluster(Configuration, int, int) - Constructor for class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
Start a MiniHBaseCluster.
MiniHBaseCluster(Configuration, int, int, Class<? extends HMaster>, Class<? extends MiniHBaseCluster.MiniHBaseClusterRegionServer>) - Constructor for class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
Start a MiniHBaseCluster.
MiniHBaseCluster(Configuration, int, int, int, List<Integer>, Class<? extends HMaster>, Class<? extends MiniHBaseCluster.MiniHBaseClusterRegionServer>) - Constructor for class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
 
MiniZooKeeperCluster - Class in org.apache.hadoop.hbase.zookeeper
TODO: Most of the code in this class is ripped from ZooKeeper tests.
MiniZooKeeperCluster() - Constructor for class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
 
MiniZooKeeperCluster(Configuration) - Constructor for class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
 
MINOR_VERSION - Static variable in exception org.apache.hadoop.hbase.exceptions.RequestTooBigException
 
MINUS_SIGN - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII for Minus Sign
MINUTE_IN_SECONDS - Static variable in class org.apache.hadoop.hbase.HConstants
 
MOB_CACHE_BLOCKS - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
MOB_CACHE_EVICT_PERIOD - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
MOB_CACHE_EVICT_REMAIN_RATIO - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
MOB_CLEANER_BATCH_SIZE_UPPER_BOUND - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
MOB_CLEANER_PERIOD - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
MOB_COMPACT_PARTITION_POLICY - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
MOB_COMPACTION_BATCH_SIZE - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
The max number of the mob files that is allowed in a batch of the mob compaction.
MOB_COMPACTION_CHORE_PERIOD - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
The period that MobCompactionChore runs.
MOB_COMPACTION_MAX_FILE_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
Maximum size of a MOB compaction selection
MOB_COMPACTION_MERGEABLE_THRESHOLD - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
If the size of a mob file is less than this value, it's regarded as a small file and needs to be merged in mob compaction.
MOB_COMPACTION_THREADS_MAX - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
MOB_COMPACTION_TYPE_KEY - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
MOB_COMPACTOR_CLASS_KEY - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
MOB_DELFILE_MAX_COUNT - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
MOB_DIR_NAME - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
MOB_FILE_CACHE_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
MOB_MAJOR_COMPACTION_REGION_BATCH_SIZE - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
The max number of a MOB table regions that is allowed in a batch of the mob compaction.
MOB_REF_TAG - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
MOB_REGION_NAME - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
MOB_REGION_NAME_BYTES - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
MOB_SCAN_RAW - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
MOB_SCAN_REF_ONLY - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
MOB_TABLE_LOCK_SUFFIX - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
MOB_THRESHOLD - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
MOB_UNSAFE_DISCARD_MISS_KEY - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
Use this configuration option with caution, only during upgrade procedure to handle missing MOB cells during compaction.
MobCompactPartitionPolicy - Enum in org.apache.hadoop.hbase.client
Enum describing the mob compact partition policy types.
MobConstants - Class in org.apache.hadoop.hbase.mob
The constants used in mob.
modifyColumnFamily(TableName, ColumnFamilyDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Modify an existing column family on a table.
modifyColumnFamily(TableName, ColumnFamilyDescriptor) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Modify an existing column family on a table.
modifyColumnFamily(ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
modifyColumnFamilyAsync(TableName, ColumnFamilyDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Modify an existing column family on a table.
modifyColumnFamilyStoreFileTracker(TableName, byte[], String) - Method in interface org.apache.hadoop.hbase.client.Admin
Change the store file tracker of the given table's given family.
modifyColumnFamilyStoreFileTracker(TableName, byte[], String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Change the store file tracker of the given table's given family.
modifyColumnFamilyStoreFileTrackerAsync(TableName, byte[], String) - Method in interface org.apache.hadoop.hbase.client.Admin
Change the store file tracker of the given table's given family.
modifyNamespace(NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Modify an existing namespace.
modifyNamespace(NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Modify an existing namespace.
modifyNamespaceAsync(NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Modify an existing namespace.
modifyTable(TableDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Modify an existing table, more IRB friendly version.
modifyTable(TableDescriptor) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Modify an existing table, more IRB friendly version.
modifyTable(TableDescriptor, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Modify an existing table, more IRB friendly version.
modifyTableAsync(TableDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Modify an existing table, more IRB (ruby) friendly version.
modifyTableAsync(TableDescriptor, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
The same as Admin.modifyTableAsync(TableDescriptor td), except for the reopenRegions parameter, which controls whether the process of modifying the table should reopen all regions.
modifyTableStoreFileTracker(TableName, String) - Method in interface org.apache.hadoop.hbase.client.Admin
Change the store file tracker of the given table.
modifyTableStoreFileTracker(TableName, String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Change the store file tracker of the given table.
modifyTableStoreFileTrackerAsync(TableName, String) - Method in interface org.apache.hadoop.hbase.client.Admin
Change the store file tracker of the given table.
modifyTableSync(Admin, TableDescriptor) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
since 3.0.0 and will be removed in 4.0.0. Just use Admin.modifyTable(TableDescriptor) directly as it is synchronous now.
move(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Move the region encodedRegionName to a random server.
move(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.2.0 and will be removed in 4.0.0. Use Admin.move(byte[], ServerName) instead. And if you want to move the region to a random server, please use Admin.move(byte[]).
move(byte[], ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
Move the region encodedRegionName to destServerName.
move(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Move the region r to a random server.
move(byte[], ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Move the region r to dest.
MOVE_RETRIES_MAX_KEY - Static variable in class org.apache.hadoop.hbase.util.RegionMover
 
MOVE_WAIT_MAX_KEY - Static variable in class org.apache.hadoop.hbase.util.RegionMover
 
moveRegionAndWait(RegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Move region to destination server and wait till region is completely moved and online
moveServersToRSGroup(Set<Address>, String) - Method in interface org.apache.hadoop.hbase.client.Admin
Move given set of servers to the specified target RegionServer group
moveServersToRSGroup(Set<Address>, String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Move given set of servers to the specified target RegionServer group
MULTI_TABLES_SUPPORT - Static variable in class org.apache.hadoop.hbase.mapreduce.WALPlayer
 
MultiActionResultTooLarge - Exception in org.apache.hadoop.hbase
Exception thrown when the result needs to be chunked on the server side.
MultiActionResultTooLarge(String) - Constructor for exception org.apache.hadoop.hbase.MultiActionResultTooLarge
 
multiple(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Create a byte array which is multiple given bytes
MultipleColumnPrefixFilter - Class in org.apache.hadoop.hbase.filter
This filter is used for selecting only those keys with columns that matches a particular prefix.
MultipleColumnPrefixFilter(byte[][]) - Constructor for class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
MultiRowRangeFilter - Class in org.apache.hadoop.hbase.filter
Filter to support scan multiple row key ranges.
MultiRowRangeFilter(List<MultiRowRangeFilter.RowRange>) - Constructor for class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
MultiRowRangeFilter(byte[][]) - Constructor for class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
Constructor for creating a MultiRowRangeFilter from multiple rowkey prefixes.
MultiRowRangeFilter.RowRange - Class in org.apache.hadoop.hbase.filter
 
MultiTableHFileOutputFormat - Class in org.apache.hadoop.hbase.mapreduce
Create 3 level tree directory, first level is using table name as parent directory and then use family name as child directory, and all related HFiles for one family are under child directory -tableName1 -columnFamilyName1 -columnFamilyName2 -HFiles -tableName2 -columnFamilyName1 -HFiles -columnFamilyName2
MultiTableHFileOutputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.MultiTableHFileOutputFormat
 
MultiTableInputFormat - Class in org.apache.hadoop.hbase.mapreduce
Convert HBase tabular data from multiple scanners into a format that is consumable by Map/Reduce.
MultiTableInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormat
 
MultiTableInputFormatBase - Class in org.apache.hadoop.hbase.mapreduce
MultiTableInputFormatBase() - Constructor for class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
 
MultiTableOutputFormat - Class in org.apache.hadoop.hbase.mapreduce
Hadoop output format that writes to one or more HBase tables.
MultiTableOutputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
 
MultiTableSnapshotInputFormat - Class in org.apache.hadoop.hbase.mapred
MultiTableSnapshotInputFormat generalizes TableSnapshotInputFormat allowing a MapReduce job to run over one or more table snapshots, with one or more scans configured for each.
MultiTableSnapshotInputFormat() - Constructor for class org.apache.hadoop.hbase.mapred.MultiTableSnapshotInputFormat
 
MultiTableSnapshotInputFormat - Class in org.apache.hadoop.hbase.mapreduce
MultiTableSnapshotInputFormat generalizes TableSnapshotInputFormat allowing a MapReduce job to run over one or more table snapshots, with one or more scans configured for each.
MultiTableSnapshotInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormat
 
mutate(Mutation) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutator
Sends a Mutation to the table.
mutate(List<? extends Mutation>) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutator
Send some Mutations to the table.
mutate(Mutation) - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
Sends a Mutation to the table.
mutate(List<? extends Mutation>) - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
Send some Mutations to the table.
mutateRow(RowMutations) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
Performs multiple mutations atomically on a single row.
mutateRow(RowMutations) - Method in interface org.apache.hadoop.hbase.client.Table
Performs multiple mutations atomically on a single row.
Mutation - Class in org.apache.hadoop.hbase.client
 
Mutation() - Constructor for class org.apache.hadoop.hbase.client.Mutation
empty construction.
Mutation(Mutation) - Constructor for class org.apache.hadoop.hbase.client.Mutation
 
Mutation(byte[], long, NavigableMap<byte[], List<Cell>>) - Constructor for class org.apache.hadoop.hbase.client.Mutation
Construct the mutation with user defined data.
MUTATION_OVERHEAD - Static variable in class org.apache.hadoop.hbase.client.Mutation
 
MutationSerialization - Class in org.apache.hadoop.hbase.mapreduce
 
MutationSerialization() - Constructor for class org.apache.hadoop.hbase.mapreduce.MutationSerialization
 

N

N - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'N'
NAME - Static variable in class org.apache.hadoop.hbase.HConstants
 
NAME - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
 
NAMESPACE_COL_DESC_BYTES - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Deprecated.
namespace table has been folded into the ns family in meta table, do not use this any more.
NAMESPACE_COL_DESC_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
 
NAMESPACE_DELIM - Static variable in class org.apache.hadoop.hbase.TableName
Namespace delimiter
NAMESPACE_DESC_PROP_GROUP - Static variable in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
 
NAMESPACE_DESCRIPTOR_COMPARATOR - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
 
NAMESPACE_FAMILY - Static variable in class org.apache.hadoop.hbase.HConstants
The namespace family
NAMESPACE_FAMILY_INFO - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Deprecated.
namespace table has been folded into the ns family in meta table, do not use this any more.
NAMESPACE_FAMILY_INFO_BYTES - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Deprecated.
namespace table has been folded into the ns family in meta table, do not use this any more.
NAMESPACE_FAMILY_STR - Static variable in class org.apache.hadoop.hbase.HConstants
The namespace family as a string
NAMESPACE_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.TableName
Deprecated.
since 3.0.0 and will be removed in 4.0.0. We have folded the data in namespace table into meta table, so do not use it any more.
NAMESPACE_TABLEDESC - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Deprecated.
since 3.0.0 and will be removed in 4.0.0. We have folded the data in namespace table into meta table, so do not use it any more.
NamespaceDescriptor - Class in org.apache.hadoop.hbase
Namespace POJO class.
NamespaceDescriptor.Builder - Class in org.apache.hadoop.hbase
 
NamespaceExistException - Exception in org.apache.hadoop.hbase
Thrown when a namespace exists but should not
NamespaceExistException() - Constructor for exception org.apache.hadoop.hbase.NamespaceExistException
 
NamespaceExistException(String) - Constructor for exception org.apache.hadoop.hbase.NamespaceExistException
 
NamespaceNotFoundException - Exception in org.apache.hadoop.hbase
Thrown when a namespace can not be located
NamespaceNotFoundException() - Constructor for exception org.apache.hadoop.hbase.NamespaceNotFoundException
 
NamespaceNotFoundException(String) - Constructor for exception org.apache.hadoop.hbase.NamespaceNotFoundException
 
needsTaskCommit(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
 
needToReplicate(TableName) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
Decide whether the table need replicate to the peer cluster
needToReplicate(TableName, byte[]) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
Decide whether the passed family of the table need replicate to the peer cluster according to this peer config.
NettyRpcClientConfigHelper - Class in org.apache.hadoop.hbase.ipc
Helper class for passing config to NettyRpcClient.
NEW_VERSION_BEHAVIOR - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
newBuilder() - Static method in class org.apache.hadoop.hbase.client.BalanceRequest
Create a builder to construct a custom BalanceRequest.
newBuilder() - Static method in class org.apache.hadoop.hbase.client.BalanceResponse
Creates a new BalanceResponse.Builder
newBuilder(byte[]) - Static method in class org.apache.hadoop.hbase.client.CheckAndMutate
returns a builder object to build a CheckAndMutate object
newBuilder(byte[]) - Static method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
newBuilder(ColumnFamilyDescriptor) - Static method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
newBuilder(String) - Static method in class org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder
 
newBuilder(TableName) - Static method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
newBuilder(TableDescriptor) - Static method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Copy all values, families, and name from the input.
newBuilder() - Static method in class org.apache.hadoop.hbase.replication.ReplicationLoadSink
 
newBuilder() - Static method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
 
newBuilder() - Static method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
newBuilder(ReplicationPeerConfig) - Static method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
newChecker() - Method in interface org.apache.hadoop.hbase.client.RequestController
Returns A new checker for evaluating a batch rows.
newContext() - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
 
newContext(Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
 
newPair(T1, T2) - Static method in class org.apache.hadoop.hbase.util.Pair
Constructs a new pair, inferring the type via the passed arguments
newParser() - Method in class org.apache.hadoop.hbase.mapreduce.RowCounter
 
newParser() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
 
next() - Method in interface org.apache.hadoop.hbase.client.ResultScanner
Grab the next row's worth of values.
next(int) - Method in interface org.apache.hadoop.hbase.client.ResultScanner
Get nbRows rows.
next(ImmutableBytesWritable, Result) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
 
next(ImmutableBytesWritable, Result) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
 
next() - Method in class org.apache.hadoop.hbase.quotas.QuotaRetriever
 
next() - Method in class org.apache.hadoop.hbase.types.StructIterator
 
nextKeyValue() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
Positions the record reader to the next record.
nextKeyValue() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
Positions the record reader to the next record.
NINE - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code foe Nine
NINES - Static variable in class org.apache.hadoop.hbase.HConstants
 
NO_NONCE - Static variable in class org.apache.hadoop.hbase.HConstants
 
NO_SEQNUM - Static variable in class org.apache.hadoop.hbase.HConstants
Value indicating the server name was saved with no sequence number.
NO_STRICT_COL_FAMILY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
NOCACHE_PARAM_NAME - Static variable in interface org.apache.hadoop.hbase.rest.Constants
If this query parameter is present when processing row or scanner resources, it disables server side block caching
nodes - Variable in class org.apache.hadoop.hbase.rest.client.Cluster
 
NON_STARTCODE - Static variable in class org.apache.hadoop.hbase.ServerName
What to use if no startcode supplied.
NONE - Static variable in class org.apache.hadoop.hbase.io.crypto.Encryption.Context
The null crypto context
NORMAL_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
 
NORMALIZATION_ENABLED - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Used by shell/rest interface to access this metadata attribute which denotes if the table should be treated by region normalizer.
normalize() - Method in interface org.apache.hadoop.hbase.client.Admin
Invoke region normalizer.
normalize(NormalizeTableFilterParams) - Method in interface org.apache.hadoop.hbase.client.Admin
Invoke region normalizer.
normalize() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Invoke region normalizer.
normalize(NormalizeTableFilterParams) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Invoke region normalizer.
NORMALIZER_TARGET_REGION_COUNT - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
NORMALIZER_TARGET_REGION_SIZE - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Deprecated.
NORMALIZER_TARGET_REGION_SIZE_MB - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
normalizerSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Turn region normalizer on or off.
normalizerSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Set region normalizer on/off.
NormalizeTableFilterParams - Class in org.apache.hadoop.hbase.client
A collection of criteria used for table selection.
NoServerForRegionException - Exception in org.apache.hadoop.hbase.client
Thrown when no region server can be found for a region
NoServerForRegionException() - Constructor for exception org.apache.hadoop.hbase.client.NoServerForRegionException
default constructor
NoServerForRegionException(String) - Constructor for exception org.apache.hadoop.hbase.client.NoServerForRegionException
Constructor
NoSuchColumnFamilyException - Exception in org.apache.hadoop.hbase.regionserver
Thrown if request for nonexistent column family.
NoSuchColumnFamilyException() - Constructor for exception org.apache.hadoop.hbase.regionserver.NoSuchColumnFamilyException
default constructor
NoSuchColumnFamilyException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.NoSuchColumnFamilyException
 
NOT_EQUAL_TO_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
NOT_EQUAL_TO Array
NOT_EQUAL_TO_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
 
NOT_IMPLEMENTED - Static variable in class org.apache.hadoop.hbase.HConstants
 
NotAllMetaRegionsOnlineException - Exception in org.apache.hadoop.hbase
Thrown when an operation requires the root and all meta regions to be online
NotAllMetaRegionsOnlineException() - Constructor for exception org.apache.hadoop.hbase.NotAllMetaRegionsOnlineException
default constructor
NotAllMetaRegionsOnlineException(String) - Constructor for exception org.apache.hadoop.hbase.NotAllMetaRegionsOnlineException
 
NotServingRegionException - Exception in org.apache.hadoop.hbase
Thrown by a region server if it is sent a request for a region it is not serving.
NotServingRegionException() - Constructor for exception org.apache.hadoop.hbase.NotServingRegionException
 
NotServingRegionException(String) - Constructor for exception org.apache.hadoop.hbase.NotServingRegionException
 
NotServingRegionException(byte[]) - Constructor for exception org.apache.hadoop.hbase.NotServingRegionException
 
NullComparator - Class in org.apache.hadoop.hbase.filter
A binary comparator which lexicographically compares against the specified byte array using Bytes.compareTo(byte[], byte[]).
NullComparator() - Constructor for class org.apache.hadoop.hbase.filter.NullComparator
 
NUM_MAPPERS_PER_REGION - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Set the number of Mappers for each region, all regions have same number of Mappers
numEqualPrefixBytes(ByteRange, ByteRange, int) - Static method in class org.apache.hadoop.hbase.util.ByteRangeUtils
 
numFamilies() - Method in class org.apache.hadoop.hbase.client.Get
Method for retrieving the number of families to get from
numFamilies() - Method in class org.apache.hadoop.hbase.client.Increment
Method for retrieving the number of families to increment from
numFamilies() - Method in class org.apache.hadoop.hbase.client.Mutation
Returns the number of different families
numFamilies() - Method in class org.apache.hadoop.hbase.client.Scan
Returns the number of families in familyMap

O

O - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'O'
of(String) - Static method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
of(byte[]) - Static method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
of(String) - Static method in class org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder
 
of(List<? extends Mutation>) - Static method in class org.apache.hadoop.hbase.client.RowMutations
Create a RowMutations with the specified mutations.
offline(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Offline specified region from master's in-memory state.
offline(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Offline specified region from master's in-memory state.
OLD_META_STR - Static variable in class org.apache.hadoop.hbase.TableName
 
OLD_META_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.TableName
TableName for old .META.
OLD_ROOT_STR - Static variable in class org.apache.hadoop.hbase.TableName
 
OLD_ROOT_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.TableName
TableName for old -ROOT- table.
OLD_SNAPSHOT_DIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
 
onComplete() - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CoprocessorCallback
onComplete() - Method in interface org.apache.hadoop.hbase.client.ScanResultConsumerBase
Indicate that the scan operation is completed normally.
onError(Throwable) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CoprocessorCallback
Indicate that we got an error which does not belong to any regions.
onError(Throwable) - Method in interface org.apache.hadoop.hbase.client.ScanResultConsumerBase
Indicate that we hit an unrecoverable error and the scan operation is terminated.
onException(RetriesExhaustedWithDetailsException, BufferedMutator) - Method in interface org.apache.hadoop.hbase.client.BufferedMutator.ExceptionListener
 
onHeartbeat(AdvancedScanResultConsumer.ScanController) - Method in interface org.apache.hadoop.hbase.client.AdvancedScanResultConsumer
Indicate that there is a heartbeat message but we have not cumulated enough cells to call AdvancedScanResultConsumer.onNext(Result[], ScanController).
OnlineLogRecord - Class in org.apache.hadoop.hbase.client
Slow/Large Log payload for hbase-client, to be used by Admin API get_slow_responses and get_large_responses
onNext(Result[], AdvancedScanResultConsumer.ScanController) - Method in interface org.apache.hadoop.hbase.client.AdvancedScanResultConsumer
Indicate that we have receive some data.
onNext(Result) - Method in interface org.apache.hadoop.hbase.client.ScanResultConsumer
Return false if you want to terminate the scan process.
onRegionComplete(RegionInfo, R) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CoprocessorCallback
Indicate that the respose of a region is available
onRegionError(RegionInfo, Throwable) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CoprocessorCallback
Indicate that the error for a region is available
onScanMetricsCreated(ScanMetrics) - Method in interface org.apache.hadoop.hbase.client.ScanResultConsumerBase
If scan.isScanMetricsEnabled() returns true, then this method will be called prior to all other methods in this interface to give you the ScanMetrics instance for this scan operation.
op - Variable in class org.apache.hadoop.hbase.filter.CompareFilter
 
op - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
open(Configuration) - Static method in class org.apache.hadoop.hbase.quotas.QuotaRetriever
Open a QuotaRetriever with no filter, all the quota settings will be returned.
open(Configuration, QuotaFilter) - Static method in class org.apache.hadoop.hbase.quotas.QuotaRetriever
Open a QuotaRetriever with the specified filter.
Operation - Class in org.apache.hadoop.hbase.client
Superclass for any type that maps to a potentially application-level query.
Operation() - Constructor for class org.apache.hadoop.hbase.client.Operation
 
operationTimeout(int) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
 
OperationWithAttributes - Class in org.apache.hadoop.hbase.client
 
OperationWithAttributes() - Constructor for class org.apache.hadoop.hbase.client.OperationWithAttributes
empty construction.
OperationWithAttributes(OperationWithAttributes) - Constructor for class org.apache.hadoop.hbase.client.OperationWithAttributes
 
opertationTimeout(int) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
Deprecated.
Since 2.3.0, will be removed in 4.0.0. Use BufferedMutatorParams.operationTimeout(int)
OPTIMIZED_MOB_COMPACTION_TYPE - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
Mob compaction type: "full", "optimized" "full" - run full major compaction (during migration) "optimized" - optimized version for use case with infrequent updates/deletes
OR - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
OR Byte Array
OR_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
OR Array
OR_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
 
order - Variable in class org.apache.hadoop.hbase.types.OrderedBytesBase
 
order - Variable in class org.apache.hadoop.hbase.types.RawBytes
 
order - Variable in class org.apache.hadoop.hbase.types.RawString
 
Order - Enum in org.apache.hadoop.hbase.util
Used to describe or modify the lexicographical sort order of a byte[].
OrderedBlob - Class in org.apache.hadoop.hbase.types
A byte[] of variable-length.
OrderedBlob(Order) - Constructor for class org.apache.hadoop.hbase.types.OrderedBlob
Creates a new byte[] with variable length.
OrderedBlobVar - Class in org.apache.hadoop.hbase.types
An alternative to OrderedBlob for use by Struct fields that do not terminate the fields list.
OrderedBlobVar(Order) - Constructor for class org.apache.hadoop.hbase.types.OrderedBlobVar
 
OrderedBytes - Class in org.apache.hadoop.hbase.util
Utility class that handles ordered byte arrays.
OrderedBytes() - Constructor for class org.apache.hadoop.hbase.util.OrderedBytes
 
OrderedBytesBase<T> - Class in org.apache.hadoop.hbase.types
Base class for data types backed by the OrderedBytes encoding implementations.
OrderedBytesBase(Order) - Constructor for class org.apache.hadoop.hbase.types.OrderedBytesBase
 
OrderedFloat32 - Class in org.apache.hadoop.hbase.types
A float of 32-bits using a fixed-length encoding.
OrderedFloat32(Order) - Constructor for class org.apache.hadoop.hbase.types.OrderedFloat32
Creates a new 32-bit float with a fixed-length encoding.
OrderedFloat64 - Class in org.apache.hadoop.hbase.types
A double of 64-bits using a fixed-length encoding.
OrderedFloat64(Order) - Constructor for class org.apache.hadoop.hbase.types.OrderedFloat64
Creates a new 64-bite double with a fixed-length encoding.
OrderedInt16 - Class in org.apache.hadoop.hbase.types
A short of 16-bits using a fixed-length encoding.
OrderedInt16(Order) - Constructor for class org.apache.hadoop.hbase.types.OrderedInt16
Creates a new 16-bit short with a fixed-length encoding.
OrderedInt32 - Class in org.apache.hadoop.hbase.types
An int of 32-bits using a fixed-length encoding.
OrderedInt32(Order) - Constructor for class org.apache.hadoop.hbase.types.OrderedInt32
Creates a new 32-bit int with a fixed-length encoding.
OrderedInt64 - Class in org.apache.hadoop.hbase.types
A long of 64-bits using a fixed-length encoding.
OrderedInt64(Order) - Constructor for class org.apache.hadoop.hbase.types.OrderedInt64
Creates a new 64-bit long with a fixed-length encoding.
OrderedInt8 - Class in org.apache.hadoop.hbase.types
A byte of 8-bits using a fixed-length encoding.
OrderedInt8(Order) - Constructor for class org.apache.hadoop.hbase.types.OrderedInt8
Creates a new 8-bit byte with a fixed-length encoding.
OrderedNumeric - Class in org.apache.hadoop.hbase.types
An Number of arbitrary precision and variable-length encoding.
OrderedNumeric(Order) - Constructor for class org.apache.hadoop.hbase.types.OrderedNumeric
Creates a new Number of arbitrary precision and variable-length encoding.
OrderedString - Class in org.apache.hadoop.hbase.types
A String of variable-length.
OrderedString(Order) - Constructor for class org.apache.hadoop.hbase.types.OrderedString
Creates a new variable-length String.
org.apache.hadoop.hbase - package org.apache.hadoop.hbase
 
org.apache.hadoop.hbase.backup - package org.apache.hadoop.hbase.backup
 
org.apache.hadoop.hbase.chaos - package org.apache.hadoop.hbase.chaos
 
org.apache.hadoop.hbase.client - package org.apache.hadoop.hbase.client
Provides HBase Client
org.apache.hadoop.hbase.client.backoff - package org.apache.hadoop.hbase.client.backoff
 
org.apache.hadoop.hbase.client.example - package org.apache.hadoop.hbase.client.example
 
org.apache.hadoop.hbase.client.locking - package org.apache.hadoop.hbase.client.locking
 
org.apache.hadoop.hbase.client.replication - package org.apache.hadoop.hbase.client.replication
 
org.apache.hadoop.hbase.client.security - package org.apache.hadoop.hbase.client.security
 
org.apache.hadoop.hbase.client.trace - package org.apache.hadoop.hbase.client.trace
 
org.apache.hadoop.hbase.codec - package org.apache.hadoop.hbase.codec
 
org.apache.hadoop.hbase.conf - package org.apache.hadoop.hbase.conf
 
org.apache.hadoop.hbase.coordination - package org.apache.hadoop.hbase.coordination
 
org.apache.hadoop.hbase.coprocessor - package org.apache.hadoop.hbase.coprocessor
Table of Contents
org.apache.hadoop.hbase.errorhandling - package org.apache.hadoop.hbase.errorhandling
 
org.apache.hadoop.hbase.exceptions - package org.apache.hadoop.hbase.exceptions
 
org.apache.hadoop.hbase.favored - package org.apache.hadoop.hbase.favored
 
org.apache.hadoop.hbase.filter - package org.apache.hadoop.hbase.filter
Provides row-level filters applied to HRegion scan results during calls to ResultScanner.next().
org.apache.hadoop.hbase.hbtop - package org.apache.hadoop.hbase.hbtop
 
org.apache.hadoop.hbase.hbtop.field - package org.apache.hadoop.hbase.hbtop.field
 
org.apache.hadoop.hbase.hbtop.mode - package org.apache.hadoop.hbase.hbtop.mode
 
org.apache.hadoop.hbase.hbtop.screen - package org.apache.hadoop.hbase.hbtop.screen
 
org.apache.hadoop.hbase.hbtop.screen.field - package org.apache.hadoop.hbase.hbtop.screen.field
 
org.apache.hadoop.hbase.hbtop.screen.help - package org.apache.hadoop.hbase.hbtop.screen.help
 
org.apache.hadoop.hbase.hbtop.screen.mode - package org.apache.hadoop.hbase.hbtop.screen.mode
 
org.apache.hadoop.hbase.hbtop.screen.top - package org.apache.hadoop.hbase.hbtop.screen.top
 
org.apache.hadoop.hbase.hbtop.terminal - package org.apache.hadoop.hbase.hbtop.terminal
 
org.apache.hadoop.hbase.hbtop.terminal.impl - package org.apache.hadoop.hbase.hbtop.terminal.impl
 
org.apache.hadoop.hbase.hbtop.terminal.impl.batch - package org.apache.hadoop.hbase.hbtop.terminal.impl.batch
 
org.apache.hadoop.hbase.http - package org.apache.hadoop.hbase.http
Copied from hadoop source code.
See https://issues.apache.org/jira/browse/HADOOP-10232 to know why.
org.apache.hadoop.hbase.http.conf - package org.apache.hadoop.hbase.http.conf
 
org.apache.hadoop.hbase.http.gson - package org.apache.hadoop.hbase.http.gson
 
org.apache.hadoop.hbase.http.jersey - package org.apache.hadoop.hbase.http.jersey
 
org.apache.hadoop.hbase.http.jmx - package org.apache.hadoop.hbase.http.jmx
This package provides access to JMX primarily through the JMXJsonServlet class.
org.apache.hadoop.hbase.http.log - package org.apache.hadoop.hbase.http.log
 
org.apache.hadoop.hbase.http.prometheus - package org.apache.hadoop.hbase.http.prometheus
 
org.apache.hadoop.hbase.io - package org.apache.hadoop.hbase.io
 
org.apache.hadoop.hbase.io.asyncfs - package org.apache.hadoop.hbase.io.asyncfs
 
org.apache.hadoop.hbase.io.asyncfs.monitor - package org.apache.hadoop.hbase.io.asyncfs.monitor
 
org.apache.hadoop.hbase.io.compress - package org.apache.hadoop.hbase.io.compress
 
org.apache.hadoop.hbase.io.crypto - package org.apache.hadoop.hbase.io.crypto
 
org.apache.hadoop.hbase.io.crypto.aes - package org.apache.hadoop.hbase.io.crypto.aes
 
org.apache.hadoop.hbase.io.crypto.tls - package org.apache.hadoop.hbase.io.crypto.tls
 
org.apache.hadoop.hbase.io.encoding - package org.apache.hadoop.hbase.io.encoding
 
org.apache.hadoop.hbase.io.hadoopbackport - package org.apache.hadoop.hbase.io.hadoopbackport
 
org.apache.hadoop.hbase.io.hfile - package org.apache.hadoop.hbase.io.hfile
Provides implementations of HFile and HFile BlockCache.
org.apache.hadoop.hbase.io.util - package org.apache.hadoop.hbase.io.util
 
org.apache.hadoop.hbase.ipc - package org.apache.hadoop.hbase.ipc
Tools to help define network clients and servers.
org.apache.hadoop.hbase.log - package org.apache.hadoop.hbase.log
 
org.apache.hadoop.hbase.logging - package org.apache.hadoop.hbase.logging
 
org.apache.hadoop.hbase.mapred - package org.apache.hadoop.hbase.mapred
Provides HBase MapReduce Input/OutputFormats, a table indexing MapReduce job, and utility methods.
org.apache.hadoop.hbase.mapreduce - package org.apache.hadoop.hbase.mapreduce
Provides HBase MapReduce Input/OutputFormats, a table indexing MapReduce job, and utility methods.
org.apache.hadoop.hbase.master - package org.apache.hadoop.hbase.master
 
org.apache.hadoop.hbase.metrics - package org.apache.hadoop.hbase.metrics
Metrics API for HBase.
org.apache.hadoop.hbase.mob - package org.apache.hadoop.hbase.mob
 
org.apache.hadoop.hbase.mob.mapreduce - package org.apache.hadoop.hbase.mob.mapreduce
 
org.apache.hadoop.hbase.namequeues - package org.apache.hadoop.hbase.namequeues
 
org.apache.hadoop.hbase.namequeues.impl - package org.apache.hadoop.hbase.namequeues.impl
 
org.apache.hadoop.hbase.namequeues.request - package org.apache.hadoop.hbase.namequeues.request
 
org.apache.hadoop.hbase.namequeues.response - package org.apache.hadoop.hbase.namequeues.response
 
org.apache.hadoop.hbase.namespace - package org.apache.hadoop.hbase.namespace
 
org.apache.hadoop.hbase.net - package org.apache.hadoop.hbase.net
 
org.apache.hadoop.hbase.nio - package org.apache.hadoop.hbase.nio
 
org.apache.hadoop.hbase.quotas - package org.apache.hadoop.hbase.quotas
 
org.apache.hadoop.hbase.quotas.policies - package org.apache.hadoop.hbase.quotas.policies
 
org.apache.hadoop.hbase.regionserver - package org.apache.hadoop.hbase.regionserver
 
org.apache.hadoop.hbase.regionserver.http - package org.apache.hadoop.hbase.regionserver.http
 
org.apache.hadoop.hbase.regionserver.metrics - package org.apache.hadoop.hbase.regionserver.metrics
 
org.apache.hadoop.hbase.regionserver.querymatcher - package org.apache.hadoop.hbase.regionserver.querymatcher
 
org.apache.hadoop.hbase.regionserver.regionreplication - package org.apache.hadoop.hbase.regionserver.regionreplication
 
org.apache.hadoop.hbase.regionserver.storefiletracker - package org.apache.hadoop.hbase.regionserver.storefiletracker
 
org.apache.hadoop.hbase.regionserver.throttle - package org.apache.hadoop.hbase.regionserver.throttle
 
org.apache.hadoop.hbase.regionserver.wal - package org.apache.hadoop.hbase.regionserver.wal
 
org.apache.hadoop.hbase.replication - package org.apache.hadoop.hbase.replication
Multi Cluster Replication
org.apache.hadoop.hbase.rest - package org.apache.hadoop.hbase.rest
HBase REST
org.apache.hadoop.hbase.rest.client - package org.apache.hadoop.hbase.rest.client
 
org.apache.hadoop.hbase.rsgroup - package org.apache.hadoop.hbase.rsgroup
 
org.apache.hadoop.hbase.security - package org.apache.hadoop.hbase.security
 
org.apache.hadoop.hbase.server.trace - package org.apache.hadoop.hbase.server.trace
 
org.apache.hadoop.hbase.shaded.protobuf - package org.apache.hadoop.hbase.shaded.protobuf
 
org.apache.hadoop.hbase.slowlog - package org.apache.hadoop.hbase.slowlog
 
org.apache.hadoop.hbase.snapshot - package org.apache.hadoop.hbase.snapshot
 
org.apache.hadoop.hbase.testing - package org.apache.hadoop.hbase.testing
 
org.apache.hadoop.hbase.thrift - package org.apache.hadoop.hbase.thrift
Provides an HBase Thrift service.
org.apache.hadoop.hbase.tool.coprocessor - package org.apache.hadoop.hbase.tool.coprocessor
 
org.apache.hadoop.hbase.types - package org.apache.hadoop.hbase.types
This package provides the definition and implementation of HBase's extensible data type API.
org.apache.hadoop.hbase.util - package org.apache.hadoop.hbase.util
 
org.apache.hadoop.hbase.util.compaction - package org.apache.hadoop.hbase.util.compaction
 
org.apache.hadoop.hbase.util.hbck - package org.apache.hadoop.hbase.util.hbck
 
org.apache.hadoop.hbase.wal - package org.apache.hadoop.hbase.wal
 
org.apache.hadoop.hbase.zookeeper - package org.apache.hadoop.hbase.zookeeper
 
org.apache.hadoop.metrics2 - package org.apache.hadoop.metrics2
 
org.apache.hbase.archetypes.exemplars.client - package org.apache.hbase.archetypes.exemplars.client
This package provides fully-functional exemplar Java code demonstrating simple usage of the hbase-client API, for incorporation into a Maven archetype with hbase-client dependency.
org.apache.hbase.archetypes.exemplars.shaded_client - package org.apache.hbase.archetypes.exemplars.shaded_client
This package provides fully-functional exemplar Java code demonstrating simple usage of the hbase-client API, for incorporation into a Maven archetype with hbase-shaded-client dependency.
OUTPUT_CONF_PREFIX - Static variable in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
Prefix for configuration property overrides to apply in TableOutputFormat.setConf(Configuration).
OUTPUT_TABLE - Static variable in class org.apache.hadoop.hbase.mapred.TableOutputFormat
JobConf parameter that specifies the output table
OUTPUT_TABLE - Static variable in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
Job parameter that specifies the output table.
OVERALL_HREGION_FILES - Static variable in class org.apache.hadoop.hbase.HConstants
Conf key for if we should sum overall region files size when check to split
ownerToString() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
 

P

P - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'P'
padHead(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Make a new byte array from a subset of bytes at the head of another, zero padded as desired.
padTail(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Make a new byte array from a subset of bytes at the tail of another, zero padded as desired.
PageFilter - Class in org.apache.hadoop.hbase.filter
Implementation of Filter interface that limits results to a specific page size.
PageFilter(long) - Constructor for class org.apache.hadoop.hbase.filter.PageFilter
Constructor that takes a maximum page size.
Pair<T1,T2> - Class in org.apache.hadoop.hbase.util
A generic class for pairs.
Pair() - Constructor for class org.apache.hadoop.hbase.util.Pair
Default constructor.
Pair(T1, T2) - Constructor for class org.apache.hadoop.hbase.util.Pair
Constructor
PairOfSameType<T> - Class in org.apache.hadoop.hbase.util
A generic, immutable class for pairs of objects both of type T.
PairOfSameType(T, T) - Constructor for class org.apache.hadoop.hbase.util.PairOfSameType
Constructor
parseColumn(byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
Splits a column in family:qualifier form into separate byte arrays.
parseComparator(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Splits a column in comparatorType:comparatorValue form into separate byte arrays
ParseConstants - Class in org.apache.hadoop.hbase.filter
ParseConstants holds a bunch of constants related to parsing Filter Strings Used by ParseFilter
ParseConstants() - Constructor for class org.apache.hadoop.hbase.filter.ParseConstants
 
parseDelimitedFrom(byte[], int, int) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
Parses all the RegionInfo instances from the passed in stream until EOF.
ParseFilter - Class in org.apache.hadoop.hbase.filter
This class allows a user to specify a filter via a string The string is parsed using the methods of this class and a filter object is constructed.
ParseFilter() - Constructor for class org.apache.hadoop.hbase.filter.ParseFilter
 
parseFilterString(String) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
Parses the filterString and constructs a filter using it
parseFilterString(byte[]) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
Parses the filterString and constructs a filter using it
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
parseFrom(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
Returns A deserialized RegionInfo
parseFrom(byte[], int, int) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
Parse a serialized representation of RegionInfo
parseFrom(DataInputStream) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
Parses an RegionInfo instance from the passed in stream.
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.BigDecimalComparator
Parse a serialized representation of BigDecimalComparator
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.BinaryComparator
Parse a serialized representation of BinaryComparator
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.BinaryComponentComparator
Parse a serialized representation of BinaryComponentComparator
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.BinaryPrefixComparator
Parse a serialized representation of BinaryPrefixComparator
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.BitComparator
Parse a serialized representation of BitComparator
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
Parse a serialized representation of ByteArrayComparable
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
Parse a serialized representation of ColumnCountGetFilter
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
Parse a serialized representation of ColumnPaginationFilter
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
Parses a serialized representation of the ColumnPrefixFilter
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
Parse a serialized representation of ColumnRangeFilter
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
Parse a serialized representation of ColumnValueFilter
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
Parse a seralized representation of DependentColumnFilter
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.FamilyFilter
Parse the serialized representation of FamilyFilter
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.Filter
Concrete implementers can signal a failure condition in their code by throwing an IOException.
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.FilterList
Parse a seralized representation of FilterList
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
Parse a serialized representation of FirstKeyOnlyFilter
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
Deprecated.
Parses a serialized representation of FirstKeyValueMatchingQualifiersFilter
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
Parse a serialized representation of FuzzyRowFilter
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
Parse a serialized representation of InclusiveStopFilter
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
Parse a serialized representation of KeyOnlyFilter
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.LongComparator
Parses a serialized representation of LongComparator
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
Parse a serialized representation of MultipleColumnPrefixFilter
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
Parse a serialized representation of MultiRowRangeFilter
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.NullComparator
Parse the serialized representation of NullComparator
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.PageFilter
Parse a serialized representation of PageFilter
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.PrefixFilter
Parse a serialized representation of PrefixFilter
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.QualifierFilter
Parse a serialized representation of QualifierFilter
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.RandomRowFilter
Parse a serialized representation of RandomRowFilter
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.RegexStringComparator
Parse a serialized representation of RegexStringComparator
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.RowFilter
Parse a serialized representation of RowFilter
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
Parse a serialized representation of SingleColumnValueExcludeFilter
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Parse a serialized representation of SingleColumnValueFilter
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.SkipFilter
Parse a serialized representation of SkipFilter
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.SubstringComparator
Parse a serialized representation of SubstringComparator
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.TimestampsFilter
Parse a serialized representation of TimestampsFilter
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ValueFilter
Parse a serialized representation of ValueFilter
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
Parse a serialized representation of WhileMatchFilter
parseFrom(byte[]) - Static method in enum org.apache.hadoop.hbase.replication.SyncReplicationState
 
parseFromOrNull(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
Returns A deserialized RegionInfo or null if we failed deserialize or passed bytes null
parseFromOrNull(byte[], int, int) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
Returns A deserialized RegionInfo or null if we failed deserialize or passed bytes null
parser - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
 
parseRegionName(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
Separate elements of a regionName.
parseRegionNameOrReturnNull(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
Separate elements of a regionName.
parseServerName(String) - Static method in class org.apache.hadoop.hbase.ServerName
Parse a ServerName from a string
parseSimpleFilterExpression(byte[]) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
Constructs a filter object given a simple filter expression
parseStateAndNewStateFrom(byte[]) - Static method in enum org.apache.hadoop.hbase.replication.SyncReplicationState
 
parseVersionedServerName(byte[]) - Static method in class org.apache.hadoop.hbase.ServerName
Use this method instantiating a ServerName from bytes gotten from a call to ServerName.getVersionedBytes().
passedPrefix - Variable in class org.apache.hadoop.hbase.filter.PrefixFilter
 
PASSWORD - Static variable in interface org.apache.hadoop.hbase.io.crypto.KeyProvider
 
password - Variable in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
 
PASSWORDFILE - Static variable in interface org.apache.hadoop.hbase.io.crypto.KeyProvider
 
passwordFile - Variable in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
 
pbkdf128(String...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Return a 128 bit key derived from the concatenation of the supplied arguments using PBKDF2WithHmacSHA1 at 10,000 iterations.
pbkdf128(byte[]...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Return a 128 bit key derived from the concatenation of the supplied arguments using PBKDF2WithHmacSHA1 at 10,000 iterations.
peek() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Retrieve the next byte from this range without incrementing position.
PHOENIX - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
 
PleaseHoldException - Exception in org.apache.hadoop.hbase
This exception is thrown by the master when a region server was shut down and restarted so fast that the master still hasn't processed the server shutdown of the first instance, or when master is initializing and client call admin operations, or when an operation is performed on a region server that is still starting.
PleaseHoldException(String) - Constructor for exception org.apache.hadoop.hbase.PleaseHoldException
 
PleaseHoldException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.PleaseHoldException
 
PleaseHoldException(Throwable) - Constructor for exception org.apache.hadoop.hbase.PleaseHoldException
 
PleaseRestartMasterException - Exception in org.apache.hadoop.hbase
Thrown if the master requires restart.
PleaseRestartMasterException(String) - Constructor for exception org.apache.hadoop.hbase.PleaseRestartMasterException
 
PluggableBlockingQueue - Class in org.apache.hadoop.hbase.ipc
Abstract class template for defining a pluggable blocking queue implementation to be used by the 'pluggable' call queue type in the RpcExecutor.
PluggableBlockingQueue(int, PriorityFunction, Configuration) - Constructor for class org.apache.hadoop.hbase.ipc.PluggableBlockingQueue
 
pluralize(Collection<?>) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
pluralize(int) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
pool(ExecutorService) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
Deprecated.
Since 3.0.0-alpha-2, will be removed in 4.0.0. You can not set it anymore. BufferedMutator will use Connection's ExecutorService.
popArguments(Stack<ByteBuffer>, Stack<Filter>) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Pops an argument from the operator stack and the number of arguments required by the operator from the filterStack and evaluates them
populatePut(byte[], ImportTsv.TsvParser.ParsedLine, Put, int) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
 
PositionedByteRange - Interface in org.apache.hadoop.hbase.util
Extends ByteRange with additional methods to support tracking a consumers position within the viewport.
post(String, String, byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a POST request
post(String, String, byte[], Header) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a POST request
post(Cluster, String, String, byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a POST request
post(Cluster, String, String, byte[], Header) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a POST request
post(String, Header[], byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a POST request
post(Cluster, String, Header[], byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a POST request
predicateNoRegionsInTransition() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Returns a Predicate for checking that there are no regions in transition in master
predicateTableAvailable(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Returns a Predicate for checking that table is enabled
predicateTableDisabled(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Returns a Predicate for checking that table is enabled
predicateTableEnabled(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Returns a Predicate for checking that table is enabled
PreemptiveFastFailException - Exception in org.apache.hadoop.hbase.exceptions
Deprecated.
since 2.3.0, and will be removed in 4.0.0.
PreemptiveFastFailException(long, long, long, ServerName) - Constructor for exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
Deprecated.
 
PreemptiveFastFailException(long, long, long, ServerName, boolean) - Constructor for exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
Deprecated.
 
PREFETCH_BLOCKS_ON_OPEN - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Key for the PREFETCH_BLOCKS_ON_OPEN attribute.
prefix - Variable in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
prefix - Variable in class org.apache.hadoop.hbase.filter.PrefixFilter
 
PrefixFilter - Class in org.apache.hadoop.hbase.filter
Pass results that have same row prefix.
PrefixFilter(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.PrefixFilter
 
PRESPLIT_TEST_TABLE - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
PRESPLIT_TEST_TABLE_KEY - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
prettyPrint(String) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
Use logging.
printUsage() - Method in class org.apache.hadoop.hbase.mapreduce.RowCounter
 
printUsage(String, String, String) - Method in class org.apache.hadoop.hbase.mapreduce.RowCounter
 
printUsage() - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
 
printUsage() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
 
PRIORITY - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
priority - Variable in class org.apache.hadoop.hbase.ipc.PluggableBlockingQueue
 
PRIORITY_UNSET - Static variable in class org.apache.hadoop.hbase.HConstants
QOS attributes: these attributes are used to demarcate RPC call processing by different set of handlers.
processOldArgs(List<String>) - Method in class org.apache.hadoop.hbase.mapreduce.RowCounter
 
processOptions(CommandLine) - Method in class org.apache.hadoop.hbase.mapreduce.RowCounter
 
processOptions(CommandLine) - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
 
processOptions(CommandLine) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
 
processOptions(CommandLine) - Method in class org.apache.hadoop.hbase.util.RegionMover
 
processParameter(String, String) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
 
processParameters(URI) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
 
put(Put) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
Puts some data to the table.
put(List<Put>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
Puts some data in the table, in batch.
Put - Class in org.apache.hadoop.hbase.client
Used to perform Put operations for a single row.
Put(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Put
Create a Put operation for the specified row.
Put(byte[], long) - Constructor for class org.apache.hadoop.hbase.client.Put
Create a Put operation for the specified row, using a given timestamp.
Put(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.client.Put
We make a copy of the passed in row key to keep local.
Put(ByteBuffer, long) - Constructor for class org.apache.hadoop.hbase.client.Put
 
Put(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.client.Put
 
Put(byte[], int, int, long) - Constructor for class org.apache.hadoop.hbase.client.Put
We make a copy of the passed in row key to keep local.
Put(byte[], boolean) - Constructor for class org.apache.hadoop.hbase.client.Put
Create a Put operation for an immutable row key.
Put(byte[], long, boolean) - Constructor for class org.apache.hadoop.hbase.client.Put
Create a Put operation for an immutable row key, using a given timestamp.
Put(Put) - Constructor for class org.apache.hadoop.hbase.client.Put
Copy constructor.
Put(byte[], long, NavigableMap<byte[], List<Cell>>) - Constructor for class org.apache.hadoop.hbase.client.Put
Construct the Put with user defined data.
put(Put) - Method in interface org.apache.hadoop.hbase.client.Table
Puts some data in the table.
put(List<Put>) - Method in interface org.apache.hadoop.hbase.client.Table
Batch puts the specified data into the table.
put(String, String, byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a PUT request
put(String, String, byte[], Header) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a PUT request
put(Cluster, String, String, byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a PUT request
put(Cluster, String, String, byte[], Header) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a PUT request
put(String, Header[], byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a PUT request
put(Cluster, String, Header[], byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a PUT request
put(int, byte) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Store val at index.
put(int, byte[]) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Store val at index.
put(int, byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Store length bytes from val into this range, starting at index.
put(byte) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Store val at the next position in this range.
put(byte[]) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Store the content of val in this range, starting at the next position.
put(byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Store length bytes from val into this range.
put(int, byte) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
 
put(int, byte[]) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
 
put(int, byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
 
put(int, byte) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
 
put(int, byte[]) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
 
put(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
 
put(int, byte) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
 
put(int, byte[]) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
 
put(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
 
put(byte) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
put(byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
put(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
put(int, byte) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
put(int, byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
put(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
put(byte) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
put(byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
put(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
put(int, byte) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
put(int, byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
put(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
putAll(List<Put>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
A simple version of batch put.
putAllConfiguration(Map<String, String>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
Adds all of the provided "raw" configuration entries to this.
putAllPeerData(Map<byte[], byte[]>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
Sets all of the provided serialized peer configuration data.
putAsShort(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Put an int value as short out to the specified byte array position.
putBigDecimal(byte[], int, BigDecimal) - Static method in class org.apache.hadoop.hbase.util.Bytes
Put a BigDecimal value out to the specified byte array position.
putByte(byte[], int, byte) - Static method in class org.apache.hadoop.hbase.util.Bytes
Write a single byte out to the specified byte array position.
putByteBuffer(byte[], int, ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.Bytes
Add the whole content of the ByteBuffer to the bytes arrays.
putBytes(byte[], int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Put bytes at the specified byte array position.
PutCombiner<K> - Class in org.apache.hadoop.hbase.mapreduce
Combine Puts.
PutCombiner() - Constructor for class org.apache.hadoop.hbase.mapreduce.PutCombiner
 
putConfiguration(String, String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
Sets a "raw" configuration property for this replication peer.
putDouble(byte[], int, double) - Static method in class org.apache.hadoop.hbase.util.Bytes
Put a double value out to the specified byte array position as the IEEE 754 double format.
putFloat(byte[], int, float) - Static method in class org.apache.hadoop.hbase.util.Bytes
Put a float value out to the specified byte array position.
putInt(int, int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Store the int value at index
putInt(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Put an int value out to the specified byte array position.
putInt(int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Store int val at the next position in this range.
putInt(int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
 
putInt(int, int) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
 
putInt(int, int) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
 
putInt(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
putInt(int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
putInt(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
putInt(int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
putLong(int, long) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Store the long value at index
putLong(byte[], int, long) - Static method in class org.apache.hadoop.hbase.util.Bytes
Put a long value out to the specified byte array position.
putLong(long) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Store long val at the next position in this range.
putLong(int, long) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
 
putLong(int, long) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
 
putLong(int, long) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
 
putLong(long) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
putLong(int, long) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
putLong(long) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
putLong(int, long) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
putPeerData(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
Sets the serialized peer configuration data
putShort(int, short) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Store the short value at index
putShort(byte[], int, short) - Static method in class org.apache.hadoop.hbase.util.Bytes
Put a short value out to the specified byte array position.
putShort(short) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Store short val at the next position in this range.
putShort(int, short) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
 
putShort(int, short) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
 
putShort(int, short) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
 
putShort(short) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
putShort(int, short) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
putShort(short) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
putShort(int, short) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
PutSortReducer - Class in org.apache.hadoop.hbase.mapreduce
Emits sorted Puts.
PutSortReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.PutSortReducer
 
putVLong(int, long) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Store the long value at index as a VLong
putVLong(long) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Store the long val at the next position as a VLong
putVLong(int, long) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
 
putVLong(int, long) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
 
putVLong(long) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
putVLong(int, long) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
putVLong(long) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
putVLong(int, long) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 

Q

QOS_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
 
QualifierFilter - Class in org.apache.hadoop.hbase.filter
This filter is used to filter based on the column qualifier.
QualifierFilter(CompareOperator, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.QualifierFilter
Constructor.
Query - Class in org.apache.hadoop.hbase.client
Base class for HBase read operations; e.g.
Query() - Constructor for class org.apache.hadoop.hbase.client.Query
 
QUORUM_ADDRESS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
Optional job parameter to specify a peer cluster.
QUORUM_PORT - Static variable in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
Optional job parameter to specify peer cluster's ZK client port
QuotaExceededException - Exception in org.apache.hadoop.hbase.quotas
Generic quota exceeded exception
QuotaExceededException(String) - Constructor for exception org.apache.hadoop.hbase.quotas.QuotaExceededException
 
QuotaExceededException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.quotas.QuotaExceededException
 
QuotaFilter - Class in org.apache.hadoop.hbase.quotas
Filter to use to filter the QuotaRetriever results.
QuotaFilter() - Constructor for class org.apache.hadoop.hbase.quotas.QuotaFilter
 
QuotaRetriever - Class in org.apache.hadoop.hbase.quotas
Scanner to iterate over the quota settings.
QuotaScope - Enum in org.apache.hadoop.hbase.quotas
Describe the Scope of the quota rules.
QuotaSettings - Class in org.apache.hadoop.hbase.quotas
 
QuotaSettings(String, TableName, String, String) - Constructor for class org.apache.hadoop.hbase.quotas.QuotaSettings
 
QuotaSettingsFactory - Class in org.apache.hadoop.hbase.quotas
 
QuotaSettingsFactory() - Constructor for class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
 
QuotaType - Enum in org.apache.hadoop.hbase.quotas
Describe the Quota Type.

R

R - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'R'
random(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Fill given array with random bytes.
random(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Fill given array with random bytes at the specified position.
randomFreePort() - Static method in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
Deprecated.
 
randomFreePort() - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
randomMultiCastAddress() - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
RandomRowFilter - Class in org.apache.hadoop.hbase.filter
A filter that includes rows based on a chance.
RandomRowFilter(float) - Constructor for class org.apache.hadoop.hbase.filter.RandomRowFilter
Create a new filter with a specified chance for a row to be included.
RawByte - Class in org.apache.hadoop.hbase.types
An DataType for interacting with values encoded using Bytes.putByte(byte[], int, byte).
RawByte() - Constructor for class org.apache.hadoop.hbase.types.RawByte
 
RawBytes - Class in org.apache.hadoop.hbase.types
An DataType for interacting with variable-length values encoded using Bytes.putBytes(byte[], int, byte[], int, int).
RawBytes() - Constructor for class org.apache.hadoop.hbase.types.RawBytes
Deprecated.
since 3.0.0 and will be removed in 4.0.0
RawBytes(Order) - Constructor for class org.apache.hadoop.hbase.types.RawBytes
Creates a new DataType with variable-length values.
RawBytesFixedLength - Class in org.apache.hadoop.hbase.types
An DataType that encodes fixed-length values encoded using Bytes.putBytes( byte[], int, byte[], int, int).
RawBytesFixedLength(Order, int) - Constructor for class org.apache.hadoop.hbase.types.RawBytesFixedLength
Create a RawBytesFixedLength using the specified order and length.
RawBytesFixedLength(int) - Constructor for class org.apache.hadoop.hbase.types.RawBytesFixedLength
Create a RawBytesFixedLength of the specified length.
RawBytesTerminated - Class in org.apache.hadoop.hbase.types
An DataType that encodes variable-length values encoded using Bytes.putBytes(byte[], int, byte[], int, int).
RawBytesTerminated(Order, byte[]) - Constructor for class org.apache.hadoop.hbase.types.RawBytesTerminated
Create a RawBytesTerminated using the specified terminator and order.
RawBytesTerminated(Order, String) - Constructor for class org.apache.hadoop.hbase.types.RawBytesTerminated
Create a RawBytesTerminated using the specified terminator and order.
RawBytesTerminated(byte[]) - Constructor for class org.apache.hadoop.hbase.types.RawBytesTerminated
Create a RawBytesTerminated using the specified terminator.
RawBytesTerminated(String) - Constructor for class org.apache.hadoop.hbase.types.RawBytesTerminated
Create a RawBytesTerminated using the specified terminator.
rawCells() - Method in class org.apache.hadoop.hbase.client.Result
Return the array of Cells backing this Result instance.
RawDouble - Class in org.apache.hadoop.hbase.types
An DataType for interacting with values encoded using Bytes.putDouble(byte[], int, double).
RawDouble() - Constructor for class org.apache.hadoop.hbase.types.RawDouble
 
RawFloat - Class in org.apache.hadoop.hbase.types
An DataType for interacting with values encoded using Bytes.putFloat(byte[], int, float).
RawFloat() - Constructor for class org.apache.hadoop.hbase.types.RawFloat
 
RawInteger - Class in org.apache.hadoop.hbase.types
An DataType for interacting with values encoded using Bytes.putInt(byte[], int, int).
RawInteger() - Constructor for class org.apache.hadoop.hbase.types.RawInteger
 
RawLong - Class in org.apache.hadoop.hbase.types
An DataType for interacting with values encoded using Bytes.putLong(byte[], int, long).
RawLong() - Constructor for class org.apache.hadoop.hbase.types.RawLong
 
RawShort - Class in org.apache.hadoop.hbase.types
An DataType for interacting with values encoded using Bytes.putShort(byte[], int, short).
RawShort() - Constructor for class org.apache.hadoop.hbase.types.RawShort
 
RawString - Class in org.apache.hadoop.hbase.types
An DataType for interacting with values encoded using Bytes.toBytes(String).
RawString() - Constructor for class org.apache.hadoop.hbase.types.RawString
Deprecated.
since 3.0.0 and will be removed in 4.0.0
RawString(Order) - Constructor for class org.apache.hadoop.hbase.types.RawString
Creates a new DataType for interacting with values encoded using Bytes.toBytes(String).
RawStringFixedLength - Class in org.apache.hadoop.hbase.types
An DataType that encodes fixed-length values encoded using Bytes.toBytes(String).
RawStringFixedLength(Order, int) - Constructor for class org.apache.hadoop.hbase.types.RawStringFixedLength
Create a RawStringFixedLength using the specified order and length.
RawStringFixedLength(int) - Constructor for class org.apache.hadoop.hbase.types.RawStringFixedLength
Create a RawStringFixedLength of the specified length.
RawStringTerminated - Class in org.apache.hadoop.hbase.types
An DataType that encodes variable-length values encoded using Bytes.toBytes(String).
RawStringTerminated(Order, byte[]) - Constructor for class org.apache.hadoop.hbase.types.RawStringTerminated
Create a RawStringTerminated using the specified terminator and order.
RawStringTerminated(Order, String) - Constructor for class org.apache.hadoop.hbase.types.RawStringTerminated
Create a RawStringTerminated using the specified terminator and order.
RawStringTerminated(byte[]) - Constructor for class org.apache.hadoop.hbase.types.RawStringTerminated
Create a RawStringTerminated using the specified terminator.
RawStringTerminated(String) - Constructor for class org.apache.hadoop.hbase.types.RawStringTerminated
Create a RawStringTerminated using the specified terminator.
readAllVersions() - Method in class org.apache.hadoop.hbase.client.Get
Get all available versions.
readAllVersions() - Method in class org.apache.hadoop.hbase.client.Scan
Get all available versions.
readAsInt(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to an int value
readAsVLong(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Reads a zero-compressed encoded long from input buffer and returns it.
readByteArray(DataInput) - Static method in class org.apache.hadoop.hbase.util.Bytes
Read byte-array written with a WritableableUtils.vint prefix.
readByteArrayThrowsRuntime(DataInput) - Static method in class org.apache.hadoop.hbase.util.Bytes
Read byte-array written with a WritableableUtils.vint prefix.
readFields(DataInput) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Reads the values of each field.
READONLY - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Used by rest interface to access this metadata attribute which denotes if the table is Read Only.
ReadOnlyByteRangeException - Exception in org.apache.hadoop.hbase.util
Exception thrown when a read only byte range is modified
ReadOnlyByteRangeException() - Constructor for exception org.apache.hadoop.hbase.util.ReadOnlyByteRangeException
 
readStringFixedSize(DataInput, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Reads a fixed-size field and interprets it as a string padded with zeros.
readVersions(int) - Method in class org.apache.hadoop.hbase.client.Get
Get up to the specified number of versions of each column.
readVersions(int) - Method in class org.apache.hadoop.hbase.client.Scan
Get up to the specified number of versions of each column.
recommissionRegionServer(ServerName, List<byte[]>) - Method in interface org.apache.hadoop.hbase.client.Admin
Remove decommission marker from a region server to allow regions assignments.
recommissionRegionServer(ServerName, List<byte[]>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Remove decommission marker from a region server to allow regions assignments.
RECOVERED_EDITS_DIR - Static variable in class org.apache.hadoop.hbase.HConstants
 
RECOVERED_HFILES_DIR - Static variable in class org.apache.hadoop.hbase.HConstants
 
recoverTask(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
 
reduce(Stack<ByteBuffer>, Stack<Filter>, ByteBuffer) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
This function is called while parsing the filterString and an operator is parsed
reduce(ImmutableBytesWritable, Iterator<Put>, OutputCollector<ImmutableBytesWritable, Put>, Reporter) - Method in class org.apache.hadoop.hbase.mapred.IdentityTableReduce
No aggregation, output pairs of (key, record)
reduce(ImmutableBytesWritable, Iterable<Cell>, Reducer<ImmutableBytesWritable, Cell, ImmutableBytesWritable, Cell>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.CellSortReducer
 
reduce(Writable, Iterable<Mutation>, Reducer<Writable, Mutation, Writable, Mutation>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.IdentityTableReducer
Writes each given record, consisting of the row key and the given values, to the configured OutputFormat.
reduce(K, Iterable<Put>, Reducer<K, Put, K, Put>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.PutCombiner
 
reduce(ImmutableBytesWritable, Iterable<Put>, Reducer<ImmutableBytesWritable, Put, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.PutSortReducer
 
reduce(ImmutableBytesWritable, Iterable<Text>, Reducer<ImmutableBytesWritable, Text, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
 
RegexStringComparator - Class in org.apache.hadoop.hbase.filter
This comparator is for use with CompareFilter implementations, such as RowFilter, QualifierFilter, and ValueFilter, for filtering based on the value of a given column.
RegexStringComparator(String) - Constructor for class org.apache.hadoop.hbase.filter.RegexStringComparator
Constructor Adds Pattern.DOTALL to the underlying Pattern
RegexStringComparator(String, RegexStringComparator.EngineType) - Constructor for class org.apache.hadoop.hbase.filter.RegexStringComparator
Constructor Adds Pattern.DOTALL to the underlying Pattern
RegexStringComparator(String, int) - Constructor for class org.apache.hadoop.hbase.filter.RegexStringComparator
Constructor
RegexStringComparator(String, int, RegexStringComparator.EngineType) - Constructor for class org.apache.hadoop.hbase.filter.RegexStringComparator
Constructor
RegexStringComparator.EngineType - Enum in org.apache.hadoop.hbase.filter
Engine implementation type (default=JAVA)
regexStringNoCaseType - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
RegexStringNoCaseType byte array
regexStringType - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
RegexStringType byte array
REGION_IMPL - Static variable in class org.apache.hadoop.hbase.HConstants
 
REGION_MEMSTORE_REPLICATION - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
The flag to indicate whether or not the memstore should be replicated for read-replicas (CONSISTENCY => TIMELINE).
REGION_REPLICATION - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
The number of region replicas for the table.
REGION_REPLICATION_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
 
REGION_SERVER_BULKLOAD_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
 
REGION_SERVER_CLASS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
Optional specification of the rs class name of the peer cluster
REGION_SERVER_HANDLER_ABORT_ON_ERROR_PERCENT - Static variable in class org.apache.hadoop.hbase.HConstants
 
REGION_SERVER_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
 
REGION_SERVER_HIGH_PRIORITY_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
 
REGION_SERVER_IMPL - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for what region server implementation to use.
REGION_SERVER_IMPL - Static variable in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
Optional specification of the rs impl name of the peer cluster
REGION_SERVER_REPLICATION_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
 
REGION_SPLIT_THREADS_MAX - Static variable in class org.apache.hadoop.hbase.HConstants
The max number of threads used for splitting storefiles in parallel during the region split process.
RegionException - Exception in org.apache.hadoop.hbase
Thrown when something happens related to region handling.
RegionException() - Constructor for exception org.apache.hadoop.hbase.RegionException
default constructor
RegionException(String) - Constructor for exception org.apache.hadoop.hbase.RegionException
Constructor
RegionInfo - Interface in org.apache.hadoop.hbase.client
Information about a region.
REGIONINFO_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
The regioninfo column qualifier
REGIONINFO_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
The RegionInfo qualifier as a string
RegionLoadStats - Class in org.apache.hadoop.hbase.client
POJO representing region server load
RegionLoadStats(int, int, int) - Constructor for class org.apache.hadoop.hbase.client.RegionLoadStats
 
RegionLocator - Interface in org.apache.hadoop.hbase.client
Used to view region location information for a single HBase table.
RegionMetrics - Interface in org.apache.hadoop.hbase
Encapsulates per-region load metrics.
RegionMover - Class in org.apache.hadoop.hbase.util
Tool for loading/unloading regions to/from given regionserver This tool can be run from Command line directly as a utility.
RegionOfflineException - Exception in org.apache.hadoop.hbase.client
Thrown when a table can not be located
RegionOfflineException() - Constructor for exception org.apache.hadoop.hbase.client.RegionOfflineException
default constructor
RegionOfflineException(String) - Constructor for exception org.apache.hadoop.hbase.client.RegionOfflineException
 
REGIONS_PER_SERVER_KEY - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
REGIONS_RECOVERY_INTERVAL - Static variable in class org.apache.hadoop.hbase.HConstants
 
REGIONSERVER_INFO_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
A configuration key for regionserver info port
REGIONSERVER_INFO_PORT_AUTO - Static variable in class org.apache.hadoop.hbase.HConstants
A flag that enables automatic selection of regionserver info port
REGIONSERVER_METRICS_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
The period (in milliseconds) between computing region server point in time metrics
REGIONSERVER_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for port region server listens on.
RegionServerAbortedException - Exception in org.apache.hadoop.hbase.regionserver
Thrown by the region server when it is aborting.
RegionServerAbortedException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.RegionServerAbortedException
 
RegionServerRunningException - Exception in org.apache.hadoop.hbase.regionserver
Thrown if the region server log directory exists (which indicates another region server is running at the same address)
RegionServerRunningException() - Constructor for exception org.apache.hadoop.hbase.regionserver.RegionServerRunningException
Default Constructor
RegionServerRunningException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.RegionServerRunningException
Constructs the exception and supplies a string as the message
RegionServerStoppedException - Exception in org.apache.hadoop.hbase.regionserver
Thrown by the region server when it is in shutting down state.
RegionServerStoppedException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.RegionServerStoppedException
 
RegionTooBusyException - Exception in org.apache.hadoop.hbase
Thrown by a region server if it will block and wait to serve a request.
RegionTooBusyException(String) - Constructor for exception org.apache.hadoop.hbase.RegionTooBusyException
 
registerFilter(String, String) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Register a new filter with the parser.
REJECT_DECOMMISSIONED_HOSTS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
REJECT_DECOMMISSIONED_HOSTS_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Should the HMaster reject hosts of decommissioned RegionServers, bypass matching their port and startcode parts of their ServerName or not? When True, the HMaster will reject a RegionServer's request to `reportForDuty` if it's hostname exists in the list of decommissioned RegionServers it maintains internally.
reload(Configuration) - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
Reload configuration for the given algorithm.
REMOTE_CLUSTER_CONF_PREFIX - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
 
REMOTE_CLUSTER_ZOOKEEPER_CLIENT_PORT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
 
REMOTE_CLUSTER_ZOOKEEPER_QUORUM_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
 
REMOTE_CLUSTER_ZOOKEEPER_ZNODE_PARENT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
 
RemoteWithExtrasException - Exception in org.apache.hadoop.hbase.ipc
A RemoteException with some extra information.
RemoteWithExtrasException(String, String, boolean) - Constructor for exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
 
RemoteWithExtrasException(String, String, boolean, boolean) - Constructor for exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
 
RemoteWithExtrasException(String, String, String, int, boolean) - Constructor for exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
 
RemoteWithExtrasException(String, String, String, int, boolean, boolean) - Constructor for exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
 
remove(String) - Method in class org.apache.hadoop.hbase.rest.client.Cluster
Remove a node from the cluster
remove(String, int) - Method in class org.apache.hadoop.hbase.rest.client.Cluster
Remove a node from the cluster
remove() - Method in class org.apache.hadoop.hbase.types.StructIterator
 
removeColumnFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
removeConfiguration(String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
removeConfiguration(String) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor.Builder
 
removeConfiguration(String) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
Remove a config setting represented by the key from the NamespaceDescriptor.configuration map
removeConfiguration(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
Removes a "raw" configuration property for this replication peer.
removeConfiguration(String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
Remove a config setting represented by the key from the RSGroupInfo.configuration map
removeCoprocessor(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
removeExtraHeader(String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Remove an extra header.
removeNamespaceSpaceLimit(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Creates a QuotaSettings object to remove the FileSystem space quota for the given namespace.
removeQuotesFromByteArray(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Takes a quoted byte array and converts it into an unquoted byte array For example: given a byte array representing 'abc', it returns a byte array representing abc
removeReplicationPeer(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Remove a peer and stop the replication.
removeReplicationPeer(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Remove a peer and stop the replication
removeReplicationPeerAsync(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Remove a replication peer but does not block and wait for it.
removeReplicationPeerTableCFs(String, Map<TableName, List<String>>) - Method in interface org.apache.hadoop.hbase.client.Admin
Remove some table-cfs from config of the specified peer.
removeReplicationPeerTableCFs(String, Map<TableName, List<String>>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Remove some table-cfs from config of the specified peer
removeRSGroup(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Remove RegionServer group associated with the given name
removeRSGroup(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Remove RegionServer group associated with the given name
removeServer(Address) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
Remove given server from the group.
removeServersFromRSGroup(Set<Address>) - Method in interface org.apache.hadoop.hbase.client.Admin
Remove decommissioned servers from group 1.
removeServersFromRSGroup(Set<Address>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Remove decommissioned servers from group 1.
removeTable(TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
Deprecated.
Since 3.0.0, will be removed in 4.0.0. The rsgroup information will be stored in the configuration of a table so this will be removed.
removeTableSpaceLimit(TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Creates a QuotaSettings object to remove the FileSystem space quota for the given table.
removeValue(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
removeValue(Bytes) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
removeValue(byte[]) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
removeValue(BiPredicate<Bytes, Bytes>) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
renameRSGroup(String, String) - Method in interface org.apache.hadoop.hbase.client.Admin
Rename rsgroup
renameRSGroup(String, String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Rename rsgroup
renewLease() - Method in interface org.apache.hadoop.hbase.client.ResultScanner
Allow the client to renew the scanner's lease on the server.
REPLAY_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
Deprecated.
since 3.0.0, will be removed in 4.0.0. DLR has been purged for a long time and region replication has its own 'replay' method.
REPLICA_ID_DELIMITER - Static variable in interface org.apache.hadoop.hbase.client.RegionInfo
 
REPLICA_ID_FORMAT - Static variable in interface org.apache.hadoop.hbase.client.RegionInfo
to keep appended int's sorted in string format.
replicateAllUserTables() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
REPLICATION - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
 
REPLICATION_BARRIER_FAMILY - Static variable in class org.apache.hadoop.hbase.HConstants
The replication barrier family
REPLICATION_BARRIER_FAMILY_STR - Static variable in class org.apache.hadoop.hbase.HConstants
The replication barrier family as a string
REPLICATION_BULKLOAD_ENABLE_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
REPLICATION_BULKLOAD_ENABLE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
REPLICATION_CLUSTER_ID - Static variable in class org.apache.hadoop.hbase.HConstants
Replication cluster id of source cluster which uniquely identifies itself with peer cluster
REPLICATION_CODEC_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for setting replication codec class name
REPLICATION_CONF_DIR - Static variable in class org.apache.hadoop.hbase.HConstants
Directory where the source cluster file system client configuration are placed which is used by sink cluster to copy HFiles from source cluster file system
REPLICATION_DROP_ON_DELETED_TABLE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Deprecated.
since 3.0.0. Will be removed in 4.0.0. Moved it into HBaseInterClusterReplicationEndpoint.
REPLICATION_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
 
REPLICATION_SCOPE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
REPLICATION_SCOPE_BYTES - Static variable in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
 
REPLICATION_SCOPE_GLOBAL - Static variable in class org.apache.hadoop.hbase.HConstants
Scope tag for globally scoped data.
REPLICATION_SCOPE_LOCAL - Static variable in class org.apache.hadoop.hbase.HConstants
Scope tag for locally scoped data.
REPLICATION_SERVICE_CLASSNAME_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
REPLICATION_SINK_SERVICE_CLASSNAME - Static variable in class org.apache.hadoop.hbase.HConstants
 
REPLICATION_SINK_SERVICE_CLASSNAME_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
REPLICATION_SOURCE_MAXTHREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
Maximum number of threads used by the replication source for shipping edits to the sinks
REPLICATION_SOURCE_MAXTHREADS_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Maximum number of threads used by the replication source for shipping edits to the sinks
REPLICATION_SOURCE_SERVICE_CLASSNAME - Static variable in class org.apache.hadoop.hbase.HConstants
 
REPLICATION_SOURCE_SHIPEDITS_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for ReplicationSource shipeEdits timeout
REPLICATION_SOURCE_SHIPEDITS_TIMEOUT_DFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
REPLICATION_SOURCE_TOTAL_BUFFER_DFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
REPLICATION_SOURCE_TOTAL_BUFFER_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Max total size of buffered entries in all replication peers.
ReplicationException - Exception in org.apache.hadoop.hbase.replication
An HBase Replication exception.
ReplicationException() - Constructor for exception org.apache.hadoop.hbase.replication.ReplicationException
 
ReplicationException(String) - Constructor for exception org.apache.hadoop.hbase.replication.ReplicationException
 
ReplicationException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.replication.ReplicationException
 
ReplicationException(Throwable) - Constructor for exception org.apache.hadoop.hbase.replication.ReplicationException
 
ReplicationLoadSink - Class in org.apache.hadoop.hbase.replication
A HBase ReplicationLoad to present MetricsSink information
ReplicationLoadSource - Class in org.apache.hadoop.hbase.replication
A HBase ReplicationLoad to present MetricsSource information
ReplicationPeerConfig - Class in org.apache.hadoop.hbase.replication
A configuration for the replication peer cluster.
ReplicationPeerConfigBuilder - Interface in org.apache.hadoop.hbase.replication
For creating ReplicationPeerConfig.
ReplicationPeerDescription - Class in org.apache.hadoop.hbase.replication
The POJO equivalent of ReplicationProtos.ReplicationPeerDescription.
ReplicationPeerDescription(String, boolean, ReplicationPeerConfig, SyncReplicationState) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationPeerDescription
 
replicationPeerModificationSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Enable or disable replication peer modification.
replicationPeerModificationSwitch(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Enable or disable replication peer modification.
replicationPeerModificationSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Enable or disable replication peer modification.
replicationPeerModificationSwitch(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Enable or disable replication peer modification.
ReplicationPeerNotFoundException - Exception in org.apache.hadoop.hbase
Thrown when a replication peer can not be found
ReplicationPeerNotFoundException(String) - Constructor for exception org.apache.hadoop.hbase.ReplicationPeerNotFoundException
 
REQUEST_CONTROLLER_IMPL_CONF_KEY - Static variable in class org.apache.hadoop.hbase.client.RequestControllerFactory
 
RequestController - Interface in org.apache.hadoop.hbase.client
An interface for client request scheduling algorithm.
RequestController.Checker - Interface in org.apache.hadoop.hbase.client
Picks up the valid data.
RequestController.ReturnCode - Enum in org.apache.hadoop.hbase.client
 
RequestControllerFactory - Class in org.apache.hadoop.hbase.client
A factory class that constructs an RequestController.
RequestControllerFactory() - Constructor for class org.apache.hadoop.hbase.client.RequestControllerFactory
 
requestLock() - Method in class org.apache.hadoop.hbase.client.locking.EntityLock
Sends rpc to the master to request lock.
RequestTooBigException - Exception in org.apache.hadoop.hbase.exceptions
Thrown when the size of the rpc request received by the server is too large.
RequestTooBigException() - Constructor for exception org.apache.hadoop.hbase.exceptions.RequestTooBigException
 
RequestTooBigException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.RequestTooBigException
 
RESERVED_NAMESPACES - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
 
RESERVED_NAMESPACES_BYTES - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
 
reset() - Method in interface org.apache.hadoop.hbase.client.RequestController.Checker
Reset the state of the scheduler when completing the iteration of rows.
reset() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
reset() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
reset() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
 
reset() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
reset() - Method in class org.apache.hadoop.hbase.filter.Filter
Reset the state of the filter between rows.
reset() - Method in class org.apache.hadoop.hbase.filter.FilterList
 
reset() - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
reset() - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
 
reset() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
reset() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
reset() - Method in class org.apache.hadoop.hbase.filter.RowFilter
 
reset() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
reset() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
reset() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
reset() - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
Reset state, reinitialize with the key and iv
reset() - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
Reset state, reinitialize with the key and iv
reset() - Method in class org.apache.hadoop.hbase.types.StructBuilder
Reset the sequence of accumulated fields.
resetCacheConfig(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Enable a basic on-heap cache for these jobs.
Response - Class in org.apache.hadoop.hbase.rest.client
The HTTP result code, response headers, and body of an HTTP response.
Response(int) - Constructor for class org.apache.hadoop.hbase.rest.client.Response
Constructor
Response(int, Header[]) - Constructor for class org.apache.hadoop.hbase.rest.client.Response
Constructor
Response(int, Header[], byte[]) - Constructor for class org.apache.hadoop.hbase.rest.client.Response
Constructor
Response(int, Header[], HttpResponse, InputStream) - Constructor for class org.apache.hadoop.hbase.rest.client.Response
Constructor.
REST_AUTHENTICATION_PRINCIPAL - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
REST_AUTHENTICATION_TYPE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
REST_CLIENT_CONN_TIMEOUT - Static variable in interface org.apache.hadoop.hbase.rest.Constants
Configuration parameter to set rest client connection timeout
REST_CLIENT_SOCKET_TIMEOUT - Static variable in interface org.apache.hadoop.hbase.rest.Constants
Configuration parameter to set rest client socket timeout
REST_CONNECTOR_ACCEPT_QUEUE_SIZE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
REST_DNS_INTERFACE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
REST_DNS_NAMESERVER - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
REST_KERBEROS_PRINCIPAL - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
REST_KEYTAB_FILE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
REST_SCANNERCACHE_EXPIRE_TIME - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
REST_SCANNERCACHE_SIZE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
REST_SSL_ENABLED - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
REST_SSL_EXCLUDE_CIPHER_SUITES - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
REST_SSL_EXCLUDE_PROTOCOLS - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
REST_SSL_INCLUDE_CIPHER_SUITES - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
REST_SSL_INCLUDE_PROTOCOLS - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
REST_SSL_KEYSTORE_KEYPASSWORD - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
REST_SSL_KEYSTORE_PASSWORD - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
REST_SSL_KEYSTORE_STORE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
REST_SSL_KEYSTORE_TYPE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
REST_SSL_TRUSTSTORE_PASSWORD - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
REST_SSL_TRUSTSTORE_STORE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
REST_SSL_TRUSTSTORE_TYPE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
REST_THREAD_POOL_TASK_QUEUE_SIZE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
REST_THREAD_POOL_THREAD_IDLE_TIMEOUT - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
REST_THREAD_POOL_THREADS_MAX - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
REST_THREAD_POOL_THREADS_MIN - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
restart(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
Restart from survivable exceptions by creating a new scanner.
restart(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
Restart from survivable exceptions by creating a new scanner.
restart(byte[]) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
Restart from survivable exceptions by creating a new scanner.
restart(byte[]) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
Restart from survivable exceptions by creating a new scanner.
restartHBaseCluster(int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Starts the hbase cluster up again after shutting it down previously in a test.
restartHBaseCluster(int, List<Integer>) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
restartHBaseCluster(StartMiniClusterOption) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
restoreClusterMetrics(ClusterMetrics) - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
Restores the cluster to given state if this is a real cluster, otherwise does nothing.
restoreInitialStatus() - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
Restores the cluster to it's initial state if this is a real cluster, otherwise does nothing.
restoreSnapshot(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Restore the specified snapshot on the original table.
restoreSnapshot(String, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Restore the specified snapshot on the original table.
restoreSnapshot(String, boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Restore the specified snapshot on the original table.
restoreSnapshot(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Restore the specified snapshot on the original table.
restoreSnapshot(String, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Restore the specified snapshot on the original table.
restoreSnapshot(String, boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Restore the specified snapshot on the original table.
RestoreSnapshotException - Exception in org.apache.hadoop.hbase.snapshot
Thrown when a snapshot could not be restored due to a server-side error when restoring it.
RestoreSnapshotException(String, SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
 
RestoreSnapshotException(String, Throwable, SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
 
RestoreSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
 
RestoreSnapshotException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
 
Result - Class in org.apache.hadoop.hbase.client
Single row result of a Get or Scan query.
Result() - Constructor for class org.apache.hadoop.hbase.client.Result
Creates an empty Result w/ no KeyValue payload; returns null if you call Result.rawCells().
ResultScanner - Interface in org.apache.hadoop.hbase.client
Interface for client-side scanning.
ResultSerialization - Class in org.apache.hadoop.hbase.mapreduce
 
ResultSerialization() - Constructor for class org.apache.hadoop.hbase.mapreduce.ResultSerialization
 
resume() - Method in interface org.apache.hadoop.hbase.client.AdvancedScanResultConsumer.ScanResumer
Resume the scan.
resumeRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
Resume the region server
resumeRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
 
resumeRegionServer(int) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
Resume the specified region server
RetriesExhaustedException - Exception in org.apache.hadoop.hbase.client
Exception thrown by HTable methods when an attempt to do something (like commit changes) fails after a bunch of retries.
RetriesExhaustedException(String) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedException
 
RetriesExhaustedException(String, IOException) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedException
 
RetriesExhaustedException(String, int, List<Throwable>) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedException
Create a new RetriesExhaustedException from the list of prior failures.
RetriesExhaustedException(int, List<RetriesExhaustedException.ThrowableWithExtraContext>) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedException
Create a new RetriesExhaustedException from the list of prior failures.
RetriesExhaustedWithDetailsException - Exception in org.apache.hadoop.hbase.client
This subclass of RetriesExhaustedException is thrown when we have more information about which rows were causing which exceptions on what servers.
RetriesExhaustedWithDetailsException(String) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
RetriesExhaustedWithDetailsException(String, IOException) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
RetriesExhaustedWithDetailsException(List<Throwable>, List<Row>, List<String>) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
retrieveGetCounterWithStringsParams(TaskAttemptContext) - Static method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
Deprecated.
since 2.4.0 and 2.3.2, will be removed in 4.0.0
RETRY_ATTEMPTS_KEY - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
 
RETRY_BACKOFF - Static variable in class org.apache.hadoop.hbase.HConstants
Retrying we multiply hbase.client.pause setting by what we have in this array until we run out of array items.
RETRY_SLEEP_INTERVAL_KEY - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
 
RetryImmediatelyException - Exception in org.apache.hadoop.hbase
 
RetryImmediatelyException(String) - Constructor for exception org.apache.hadoop.hbase.RetryImmediatelyException
 
returnCompressor(Compressor) - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
 
returnDecompressor(Decompressor) - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
 
reversed - Variable in class org.apache.hadoop.hbase.filter.Filter
 
revoke(UserPermission) - Method in interface org.apache.hadoop.hbase.client.Admin
Revokes user specific permissions
revoke(UserPermission) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Revokes user specific permissions
RNG_ALGORITHM_KEY - Static variable in class org.apache.hadoop.hbase.io.crypto.Cipher
 
RNG_PROVIDER_KEY - Static variable in class org.apache.hadoop.hbase.io.crypto.Cipher
 
rollWALWriter(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
Roll the log writer.
rollWALWriter(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Roll the log writer.
RoundRobinTableInputFormat - Class in org.apache.hadoop.hbase.mapreduce
Process the return from super-class TableInputFormat (TIF) so as to undo any clumping of InputSplits around RegionServers.
RoundRobinTableInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.RoundRobinTableInputFormat
 
row - Variable in class org.apache.hadoop.hbase.client.Mutation
 
Row - Interface in org.apache.hadoop.hbase.client
Has a row.
ROW_KEYS_PARAM_NAME - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
RowCounter - Class in org.apache.hadoop.hbase.mapred
A job with a map to count rows.
RowCounter() - Constructor for class org.apache.hadoop.hbase.mapred.RowCounter
 
RowCounter - Class in org.apache.hadoop.hbase.mapreduce
A job with a just a map phase to count rows.
RowCounter() - Constructor for class org.apache.hadoop.hbase.mapreduce.RowCounter
 
RowEndKeyComparator() - Constructor for class org.apache.hadoop.hbase.util.Bytes.RowEndKeyComparator
 
RowFilter - Class in org.apache.hadoop.hbase.filter
This filter is used to filter based on the key.
RowFilter(CompareOperator, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.RowFilter
Constructor.
RowMutations - Class in org.apache.hadoop.hbase.client
Performs multiple mutations atomically on a single row.
RowMutations(byte[]) - Constructor for class org.apache.hadoop.hbase.client.RowMutations
 
RowMutations(byte[], int) - Constructor for class org.apache.hadoop.hbase.client.RowMutations
Create an atomic mutation for the specified row.
RowRange() - Constructor for class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
 
RowRange(String, boolean, String, boolean) - Constructor for class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
If the startRow is empty or null, set it to HConstants.EMPTY_BYTE_ARRAY, means begin at the start row of the table.
RowRange(byte[], boolean, byte[], boolean) - Constructor for class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
 
ROWS - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
All the row values for the data loaded by HBaseTestingUtility.loadTable(Table, byte[])
RowTooBigException - Exception in org.apache.hadoop.hbase.client
Gets or Scans throw this exception if running without in-row scan flag set and row size appears to exceed max configured size (configurable via hbase.table.max.rowsize).
RowTooBigException(String) - Constructor for exception org.apache.hadoop.hbase.client.RowTooBigException
 
RowTooBigException - Exception in org.apache.hadoop.hbase.regionserver
Deprecated.
since 0.99.0. Use RowTooBigException instead.
RowTooBigException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.RowTooBigException
Deprecated.
 
RPAREN - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for RPAREN
RPC_CODEC_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for setting RPC codec class name
RPC_CURRENT_VERSION - Static variable in class org.apache.hadoop.hbase.HConstants
 
RPC_HEADER - Static variable in class org.apache.hadoop.hbase.HConstants
The first four bytes of Hadoop RPC connections
RpcThrottlingException - Exception in org.apache.hadoop.hbase.quotas
Describe the throttling result.
RpcThrottlingException(String) - Constructor for exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
 
RpcThrottlingException(RpcThrottlingException.Type, long, String) - Constructor for exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
 
RpcThrottlingException.Type - Enum in org.apache.hadoop.hbase.quotas
 
rpcTimeout(int) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
 
RSGroupInfo - Class in org.apache.hadoop.hbase.rsgroup
Stores the group information of region server groups.
RSGroupInfo(String) - Constructor for class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
 
RSGroupInfo(RSGroupInfo) - Constructor for class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
 
run(String[]) - Method in class org.apache.hadoop.hbase.mapred.RowCounter
 
run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.CellCounter
 
run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.CopyTable
 
run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.Export
 
run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.Import
 
run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.WALPlayer
 
runAs(PrivilegedAction<T>) - Method in class org.apache.hadoop.hbase.security.User
Executes the given action within the context of this user.
runAs(PrivilegedExceptionAction<T>) - Method in class org.apache.hadoop.hbase.security.User
Executes the given action within the context of this user.
runAsLoginUser(PrivilegedExceptionAction<T>) - Static method in class org.apache.hadoop.hbase.security.User
Executes the given action as the login user
runCatalogJanitor() - Method in interface org.apache.hadoop.hbase.client.Admin
Ask for a scan of the catalog table.
runCatalogJanitor() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Ask for a scan of the catalog table.
runCleanerChore() - Method in interface org.apache.hadoop.hbase.client.Admin
Ask for cleaner chore to run.
runCleanerChore() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Ask for cleaner chore to run.

S

S - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'S'
safeGetAsStr(List<T>, int) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
scan(Scan, C) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
The scan API uses the observer pattern.
Scan - Class in org.apache.hadoop.hbase.client
Used to perform Scan operations.
Scan() - Constructor for class org.apache.hadoop.hbase.client.Scan
Create a Scan operation across all rows.
Scan(Scan) - Constructor for class org.apache.hadoop.hbase.client.Scan
Creates a new instance of this class while copying all values.
Scan(Get) - Constructor for class org.apache.hadoop.hbase.client.Scan
Builds a scan object with the same specs as get.
SCAN - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Base-64 encoded scanner.
Scan.ReadType - Enum in org.apache.hadoop.hbase.client
 
SCAN_ATTRIBUTES_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.client.Scan
 
SCAN_BATCH_SIZE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
SCAN_BATCHSIZE - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Set the maximum number of values to return for each call to next().
SCAN_CACHE_BLOCKS - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
SCAN_CACHEBLOCKS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Set to false to disable server-side caching of blocks for this scan.
SCAN_CACHEDROWS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
The number of rows for caching that will be passed to scanners.
SCAN_COLUMN - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
SCAN_COLUMN_FAMILY - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Column Family to Scan
SCAN_COLUMNS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Space delimited list of columns and column families to scan.
SCAN_END_ROW - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
SCAN_END_TIME - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
SCAN_FETCH_SIZE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
SCAN_LIMIT - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
SCAN_MAX_VERSIONS - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
SCAN_MAXVERSIONS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
The maximum number of version to return.
SCAN_REVERSED - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
SCAN_ROW_START - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Scan start row
SCAN_ROW_STOP - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Scan stop row
SCAN_START_ROW - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
SCAN_START_TIME - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
SCAN_TIMERANGE_END - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
The ending timestamp used to filter columns with a specific range of versions.
SCAN_TIMERANGE_START - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
The starting timestamp used to filter columns with a specific range of versions.
SCAN_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
The timestamp used to filter columns with a specific timestamp.
scanAll(Scan) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
Return all the results that match the given scan object.
ScannerResetException - Exception in org.apache.hadoop.hbase.exceptions
Thrown when the server side has received an Exception, and asks the Client to reset the scanner state by closing the current region scanner, and reopening from the start of last seen row.
ScannerResetException() - Constructor for exception org.apache.hadoop.hbase.exceptions.ScannerResetException
constructor
ScannerResetException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.ScannerResetException
Constructor
ScannerResetException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.exceptions.ScannerResetException
 
ScanResultConsumer - Interface in org.apache.hadoop.hbase.client
Receives Result for an asynchronous scan.
ScanResultConsumerBase - Interface in org.apache.hadoop.hbase.client
The base interface for scan result consumer.
SCANS - Static variable in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormat
Job parameter that specifies the scan list.
searchDelimiterIndex(byte[], int, int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Find index of passed delimiter.
searchDelimiterIndexInReverse(byte[], int, int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Find index of passed delimiter walking from end of buffer backwards.
second - Variable in class org.apache.hadoop.hbase.util.Pair
 
secureRandom(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Fill given array with random bytes using a strong random number generator.
secureRandom(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Fill given array with random bytes at the specified position using a strong random number generator.
SecurityCapability - Enum in org.apache.hadoop.hbase.client.security
Available security capabilities
SEPARATOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
SEQNUM_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
The open seqnum column qualifier
SEQNUM_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
The open seqnum column qualifier
serialize(String, Throwable) - Static method in exception org.apache.hadoop.hbase.errorhandling.ForeignException
Converts a ForeignException to an array of bytes.
SERVER_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
The server column qualifier
SERVER_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
The server column qualifier
ServerMetrics - Interface in org.apache.hadoop.hbase
This class is used for exporting current state of load on a RegionServer.
ServerName - Class in org.apache.hadoop.hbase
Name of a particular incarnation of an HBase Server.
ServerName(String, int, long) - Constructor for class org.apache.hadoop.hbase.ServerName
 
SERVERNAME_PATTERN - Static variable in class org.apache.hadoop.hbase.ServerName
 
SERVERNAME_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
 
SERVERNAME_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
The serverName column qualifier.
SERVERNAME_SEPARATOR - Static variable in class org.apache.hadoop.hbase.ServerName
This character is used as separator between server hostname, port and startcode.
ServerNotRunningYetException - Exception in org.apache.hadoop.hbase.ipc
 
ServerNotRunningYetException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.ServerNotRunningYetException
 
SERVERSTART_WAIT_MAX_KEY - Static variable in class org.apache.hadoop.hbase.util.RegionMover
 
ServerTask - Interface in org.apache.hadoop.hbase
Information about active monitored server tasks
ServerTooBusyException - Exception in org.apache.hadoop.hbase.ipc
Throw this in RPC call if there are too many pending requests for one region server
ServerTooBusyException(Address, long) - Constructor for exception org.apache.hadoop.hbase.ipc.ServerTooBusyException
 
ServerTooBusyException(InetSocketAddress, long) - Constructor for exception org.apache.hadoop.hbase.ipc.ServerTooBusyException
Deprecated.
ServerType - Enum in org.apache.hadoop.hbase.client
Select server type i.e destination for RPC request associated with ring buffer.
ServiceCaller<S,R> - Interface in org.apache.hadoop.hbase.client
Delegate to a protobuf rpc call.
SESSION_TIMEOUT_ZK - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
 
set(byte[]) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
Use passed bytes as backing array for this instance.
set(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
Use passed bytes as backing array for this instance.
set(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Reuse this ByteRange over a new byte[].
set(byte[]) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Reuse this ByteRange over a new byte[].
set(byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Reuse this ByteRange over a new byte[].
set(byte[]) - Method in class org.apache.hadoop.hbase.util.Bytes
Use passed bytes as backing array for this instance.
set(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.Bytes
Use passed bytes as backing array for this instance.
set(int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
 
set(byte[]) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
 
set(byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
 
set(int) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
 
set(byte[]) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
 
set(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
 
set(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
set(byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
set(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
set(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
set(byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
set(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
SET_STATUS_SLEEP_TIME - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
 
setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Append
 
setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Append
 
setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Delete
 
setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Delete
 
setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Get
 
setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Get
 
setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Increment
 
setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Increment
 
setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Mutation
Set the ACL for this operation.
setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Mutation
Set the ACL for this operation.
setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Put
 
setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Put
 
setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Query
Set the ACL for the operation.
setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Query
Set the ACL for the operation.
setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Scan
 
setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Scan
 
setAllowPartialResults(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
Setting whether the caller wants to see the partial results when server returns less-than-expected cells.
setAsyncPrefetch(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
Deprecated.
Since 3.0.0, will be removed in 4.0.0. After building sync client upon async client, the implementation is always 'async prefetch', so this flag is useless now.
setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.Append
 
setAttribute(String, byte[]) - Method in interface org.apache.hadoop.hbase.client.Attributes
Sets an attribute.
setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
 
setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.Get
 
setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.Increment
 
setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
 
setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.Put
 
setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
 
setAuthorizations(Authorizations) - Method in class org.apache.hadoop.hbase.client.Get
 
setAuthorizations(Authorizations) - Method in class org.apache.hadoop.hbase.client.Query
Sets the authorizations to be used by this Query
setAuthorizations(Authorizations) - Method in class org.apache.hadoop.hbase.client.Scan
 
setBandwidth(long) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
Sets the speed, in bytes per second, for any one RegionServer to replicate data to the peer.
setBatch(int) - Method in class org.apache.hadoop.hbase.client.Scan
Set the maximum number of cells to return for each call to next().
setBlockCacheEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setBlocksize(int) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setBlocksize(String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setBloomFilterType(BloomType) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setBody(byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Response
 
setCacheBlocks(boolean) - Method in class org.apache.hadoop.hbase.client.Get
Set whether blocks should be cached for this Get.
setCacheBlocks(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
Set whether blocks should be cached for this Scan.
setCacheBloomsOnWrite(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setCacheDataOnWrite(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setCacheIndexesOnWrite(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setCaching(int) - Method in class org.apache.hadoop.hbase.client.Scan
Set the number of rows for caching that will be passed to scanners.
setCellVisibility(CellVisibility) - Method in class org.apache.hadoop.hbase.client.Append
 
setCellVisibility(CellVisibility) - Method in class org.apache.hadoop.hbase.client.Delete
 
setCellVisibility(CellVisibility) - Method in class org.apache.hadoop.hbase.client.Increment
 
setCellVisibility(CellVisibility) - Method in class org.apache.hadoop.hbase.client.Mutation
Sets the visibility expression associated with cells in this Mutation.
setCellVisibility(CellVisibility) - Method in class org.apache.hadoop.hbase.client.Put
 
setChance(float) - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
Set the chance that a row is included.
setCharset(Charset) - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator
Specifies the Charset to use to convert the row key to a String.
setCheckExistenceOnly(boolean) - Method in class org.apache.hadoop.hbase.client.Get
 
setCipher(Cipher) - Method in class org.apache.hadoop.hbase.io.crypto.Context
 
setCipher(Cipher) - Method in class org.apache.hadoop.hbase.io.crypto.Encryption.Context
 
setClientAddress(String) - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
Deprecated.
 
setCluster(Cluster) - Method in class org.apache.hadoop.hbase.rest.client.Client
 
setClusterIds(List<UUID>) - Method in class org.apache.hadoop.hbase.client.Append
 
setClusterIds(List<UUID>) - Method in class org.apache.hadoop.hbase.client.Delete
 
setClusterIds(List<UUID>) - Method in class org.apache.hadoop.hbase.client.Increment
 
setClusterIds(List<UUID>) - Method in class org.apache.hadoop.hbase.client.Mutation
Marks that the clusters with the given clusterIds have consumed the mutation
setClusterIds(List<UUID>) - Method in class org.apache.hadoop.hbase.client.Put
 
setClusterKey(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
Set the clusterKey which is the concatenation of the slave cluster's: hbase.zookeeper.quorum:hbase.zookeeper.property.clientPort:zookeeper.znode.parent
setCode(int) - Method in class org.apache.hadoop.hbase.rest.client.Response
 
setColumnFamilies(Collection<ColumnFamilyDescriptor>) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setColumnFamily(ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setColumnFamilyTimeRange(byte[], long, long) - Method in class org.apache.hadoop.hbase.client.Get
 
setColumnFamilyTimeRange(byte[], long, long) - Method in class org.apache.hadoop.hbase.client.Query
Get versions of columns only within the specified timestamp range, [minStamp, maxStamp) on a per CF bases.
setColumnFamilyTimeRange(byte[], long, long) - Method in class org.apache.hadoop.hbase.client.Scan
 
setCompactionCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setCompactionEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setCompressTags(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.io.crypto.Context
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.io.crypto.CryptoCipherProvider
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
Sets the configuration.
setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.HRegionPartitioner
Sets the configuration.
setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormat
Sets the configuration.
setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Sets the configuration.
setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
 
setConfiguration(String, String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setConfiguration(String, String) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
Setter for storing a configuration setting in NamespaceDescriptor.configuration map.
setConfiguration(String, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
Setter for storing a configuration setting in RSGroupInfo.configuration map.
setConsistency(Consistency) - Method in class org.apache.hadoop.hbase.client.Get
 
setConsistency(Consistency) - Method in class org.apache.hadoop.hbase.client.Query
Sets the consistency level for this operation
setConsistency(Consistency) - Method in class org.apache.hadoop.hbase.client.Scan
 
setCoprocessor(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setCoprocessor(CoprocessorDescriptor) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setCoprocessors(Collection<CoprocessorDescriptor>) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setDataBlockEncoding(DataBlockEncoding) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setDefaultClientPort(int) - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
 
setDFSCluster(MiniDFSCluster) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
setDFSCluster(MiniDFSCluster, boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Set the MiniDFSCluster
setDFSReplication(short) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setDryRun(boolean) - Method in class org.apache.hadoop.hbase.client.BalanceRequest.Builder
Updates BalancerRequest to run the balancer in dryRun mode.
setDurability(Durability) - Method in class org.apache.hadoop.hbase.client.Append
 
setDurability(Durability) - Method in class org.apache.hadoop.hbase.client.Delete
 
setDurability(Durability) - Method in class org.apache.hadoop.hbase.client.Increment
 
setDurability(Durability) - Method in class org.apache.hadoop.hbase.client.Mutation
Set the durability for this mutation
setDurability(Durability) - Method in class org.apache.hadoop.hbase.client.Put
 
setDurability(Durability) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setEncryptionKey(byte[]) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setEncryptionType(String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setEndKey(Configuration, byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
 
setEndRow(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
 
setEndRow(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
 
setErasureCodingPolicy(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setEventLoopConfig(Configuration, EventLoopGroup, Class<? extends Channel>) - Static method in class org.apache.hadoop.hbase.ipc.NettyRpcClientConfigHelper
Set the EventLoopGroup and channel class for AsyncRpcClient.
setEvictBlocksOnClose(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setExcludeNamespaces(Set<String>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
Sets the collection of namespaces which should not be replicated when all user tables are configured to be replicated.
setExcludeTableCFsMap(Map<TableName, List<String>>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
Sets the mapping of table name to column families which should not be replicated.
setExists(Boolean) - Method in class org.apache.hadoop.hbase.client.Result
 
setFamily(byte[]) - Method in interface org.apache.hadoop.hbase.CellBuilder
 
setFamily(byte[], int, int) - Method in interface org.apache.hadoop.hbase.CellBuilder
 
setFamilyMap(Map<byte[], NavigableSet<byte[]>>) - Method in class org.apache.hadoop.hbase.client.Scan
Setting the familyMap
setFileSystemURI(String) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
setFilter(Filter) - Method in class org.apache.hadoop.hbase.client.Get
 
setFilter(Filter) - Method in class org.apache.hadoop.hbase.client.Query
Apply the specified server-side filter when performing the Query.
setFilter(Filter) - Method in class org.apache.hadoop.hbase.client.Scan
 
setFilterByOperator(LogQueryFilter.FilterByOperator) - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
Deprecated.
 
setFilterIfMissing(boolean) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Set whether entire row should be filtered if column is not found.
setFirst(T1) - Method in class org.apache.hadoop.hbase.util.Pair
Replace the first element of the pair.
setFlushPolicyClassName(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setFoundKV(boolean) - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
Set or clear the indication if the first KV has been found.
setHBaseCluster(HBaseCluster) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
setHeaders(Header[]) - Method in class org.apache.hadoop.hbase.rest.client.Response
 
setHTable(Table) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
 
setHTable(Table) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
 
setHTable(Table) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
Sets the HBase table.
setId(String) - Method in class org.apache.hadoop.hbase.client.Append
 
setId(String) - Method in class org.apache.hadoop.hbase.client.Delete
 
setId(String) - Method in class org.apache.hadoop.hbase.client.Get
 
setId(String) - Method in class org.apache.hadoop.hbase.client.Increment
 
setId(String) - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
This method allows you to set an identifier on an operation.
setId(String) - Method in class org.apache.hadoop.hbase.client.Put
 
setId(String) - Method in class org.apache.hadoop.hbase.client.Scan
 
setIgnoreRegionsInTransition(boolean) - Method in class org.apache.hadoop.hbase.client.BalanceRequest.Builder
Updates BalancerRequest to run the balancer even if there are regions in transition.
setIndexBlockEncoding(IndexBlockEncoding) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setInMemory(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setInMemoryCompaction(MemoryCompactionPolicy) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setInput(Configuration, Map<String, Collection<Scan>>, Path) - Static method in class org.apache.hadoop.hbase.mapred.MultiTableSnapshotInputFormat
 
setInput(JobConf, String, Path) - Static method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat
Configures the job to use TableSnapshotInputFormat to read from a snapshot.
setInput(JobConf, String, Path, RegionSplitter.SplitAlgorithm, int) - Static method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat
Configures the job to use TableSnapshotInputFormat to read from a snapshot.
setInput(Configuration, Map<String, Collection<Scan>>, Path) - Static method in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormat
 
setInput(Job, String, Path) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat
Configures the job to use TableSnapshotInputFormat to read from a snapshot.
setInput(Job, String, Path, RegionSplitter.SplitAlgorithm, int) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat
Configures the job to use TableSnapshotInputFormat to read from a snapshot.
setInputColumns(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
 
setInputColumns(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
 
setInputColumns(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
 
setIsolationLevel(IsolationLevel) - Method in class org.apache.hadoop.hbase.client.Get
 
setIsolationLevel(IsolationLevel) - Method in class org.apache.hadoop.hbase.client.Query
Set the isolation level for this query.
setIsolationLevel(IsolationLevel) - Method in class org.apache.hadoop.hbase.client.Scan
 
setIv(byte[]) - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
Set the initialization vector
setIv(byte[]) - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
Set the initialization vector
setJarPath(String) - Method in class org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder
 
setKeepDeletedCells(KeepDeletedCells) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setKey(Key) - Method in class org.apache.hadoop.hbase.io.crypto.Context
 
setKey(Key) - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
Set the secret key
setKey(Key) - Method in class org.apache.hadoop.hbase.io.crypto.Encryption.Context
 
setKey(byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.Encryption.Context
 
setKey(Key) - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
Set the secret key
setKeyValues(Configuration, String, Collection<Map.Entry<String, String>>) - Static method in class org.apache.hadoop.hbase.util.ConfigurationUtil
Store a collection of Map.Entry's in conf, with each entry separated by ',' and key values delimited by ConfigurationUtil.KVP_DELIMITER
setKeyValues(Configuration, String, Collection<Map.Entry<String, String>>, char) - Static method in class org.apache.hadoop.hbase.util.ConfigurationUtil
Store a collection of Map.Entry's in conf, with each entry separated by ',' and key values delimited by delimiter.
setLatestVersionOnly(boolean) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Set whether only the latest version of the column value should be compared.
setLength(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Update the length of this range.
setLength(int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
 
setLength(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
Update the length of this range.
setLimit(int) - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
Deprecated.
 
setLimit(int) - Method in class org.apache.hadoop.hbase.client.Scan
Set the limit of rows for this scan.
setLimit(int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Limits the byte range upto a specified value.
setLimit(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
setLoadColumnFamiliesOnDemand(boolean) - Method in class org.apache.hadoop.hbase.client.Get
 
setLoadColumnFamiliesOnDemand(boolean) - Method in class org.apache.hadoop.hbase.client.Query
Set the value indicating whether loading CFs on demand should be allowed (cluster default is false).
setLoadColumnFamiliesOnDemand(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
 
setMajorCompactionCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setMaxAttempts(int) - Method in interface org.apache.hadoop.hbase.client.AsyncAdminBuilder
Set the max attempt times for an admin operation.
setMaxAttempts(int) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
Set the max attempt times for an operation.
setMaxAttempts(int) - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
Set the max attempt times for an operation.
setMaxFileSize(long) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setMaxFileSize(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setMaxKeyValueSize(int) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
Override the maximum key-value size specified by the provided AsyncConnection's Configuration instance, via the configuration key hbase.client.keyvalue.maxsize.
setMaxRecoveryErrorCount(OutputStream, int) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Set maxRecoveryErrorCount in DFSClient.
setMaxResultSize(long) - Method in class org.apache.hadoop.hbase.client.Scan
Set the maximum result size.
setMaxResultsPerColumnFamily(int) - Method in class org.apache.hadoop.hbase.client.Get
Set the maximum number of values to return per row per Column Family
setMaxResultsPerColumnFamily(int) - Method in class org.apache.hadoop.hbase.client.Scan
Set the maximum number of values to return per row per Column Family
setMaxRetries(int) - Method in interface org.apache.hadoop.hbase.client.AsyncAdminBuilder
Set the max retry times for an admin operation.
setMaxRetries(int) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
Set the max retry times for an operation.
setMaxRetries(int) - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
Set the max retry times for an operation.
setMaxVersions(int) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setMemStoreFlushSize(long) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setMemStoreFlushSize(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setMergeEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setMinorCompactionCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setMinVersions(int) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setMobCompactPartitionPolicy(MobCompactPartitionPolicy) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setMobEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setMobThreshold(long) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setNamespaceFilter(String) - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
Set the namespace filter regex
setNamespaces(Set<String>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
Sets a unique collection of HBase namespaces that should be replicated to this peer.
setNeedCursorResult(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
When the server is slow or we scan a table with many deleted data or we use a sparse filter, the server will response heartbeat to prevent timeout.
setNewVersionBehavior(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setNormalizationEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setNormalizerTargetRegionCount(int) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setNormalizerTargetRegionSize(long) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setNumMapTasks(String, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Sets the number of map tasks for the given job configuration to the number of regions the given table has.
setNumReduceTasks(String, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Sets the number of reduce tasks for the given job configuration to the number of regions the given table has.
setNumReduceTasks(String, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Sets the number of reduce tasks for the given job configuration to the number of regions the given table has.
setOffset(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Update the beginning of this range.
setOffset(int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
 
setOffset(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
Update the beginning of this range.
setOneRowLimit() - Method in class org.apache.hadoop.hbase.client.Scan
Call this when you only want to get one row.
setOperationTimeout(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncAdminBuilder
Set timeout for a whole admin operation.
setOperationTimeout(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
Set timeout for the background flush operation.
setOperationTimeout(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
Set timeout for a whole operation such as get, put or delete.
setOperationTimeout(int) - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
Deprecated.
Since 3.0.0, will be removed in 4.0.0. Please set this through the BufferedMutatorParams.
setOperationTimeout(int) - Method in interface org.apache.hadoop.hbase.client.TableBuilder
Set timeout for a whole operation such as get, put or delete.
setPosition(int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Update the position index.
setPrefetchBlocksOnOpen(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setPriority(int) - Method in class org.apache.hadoop.hbase.client.Append
 
setPriority(int) - Method in class org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder
 
setPriority(int) - Method in class org.apache.hadoop.hbase.client.Delete
 
setPriority(int) - Method in class org.apache.hadoop.hbase.client.Get
 
setPriority(int) - Method in class org.apache.hadoop.hbase.client.Increment
 
setPriority(int) - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
 
setPriority(int) - Method in class org.apache.hadoop.hbase.client.Put
 
setPriority(int) - Method in class org.apache.hadoop.hbase.client.Scan
 
setPriority(int) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setProperties(Map<String, String>) - Method in class org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder
 
setProperty(String, String) - Method in class org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder
 
setQualifier(byte[]) - Method in interface org.apache.hadoop.hbase.CellBuilder
 
setQualifier(byte[], int, int) - Method in interface org.apache.hadoop.hbase.CellBuilder
 
setQuota(QuotaSettings) - Method in interface org.apache.hadoop.hbase.client.Admin
Apply the new quota settings.
setQuota(QuotaSettings) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Apply the new quota settings.
setRaw(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
Enable/disable "raw" mode for this scan.
setReadOnly(boolean) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setReadRpcTimeout(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
Set timeout for each read(get, scan) rpc request.
setReadRpcTimeout(int) - Method in interface org.apache.hadoop.hbase.client.TableBuilder
Set timeout for each read(get, scan) rpc request.
setReadType(Scan.ReadType) - Method in class org.apache.hadoop.hbase.client.Scan
Set the read type for this scan.
setRegionMemStoreReplication(boolean) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setRegionName(String) - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
Deprecated.
 
setRegionReplication(int) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setRegionServerFilter(String) - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
Set the region server filter regex
setRegionServerGroup(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setRegionSplitPolicyClassName(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setRemoteWALDir(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
Set the remote peer cluster's wal directory.
setReplicaId(int) - Method in class org.apache.hadoop.hbase.client.Get
 
setReplicaId(int) - Method in class org.apache.hadoop.hbase.client.Query
Specify region replica id where Query will fetch data from.
setReplicaId(int) - Method in class org.apache.hadoop.hbase.client.Scan
 
setReplicas(Admin, TableName, int) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Set the number of Region replicas.
setReplicateAllUserTables(boolean) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
Configures HBase to replicate all user tables (not system tables) to the peer.
setReplicationEndpointImpl(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
Sets the ReplicationEndpoint plugin class for this peer.
setReplicationScope(int) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Sets replication scope all & only the columns already in the builder.
setRequestAttribute(String, byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
Set a request attribute
setRequestAttribute(String, byte[]) - Method in interface org.apache.hadoop.hbase.client.TableBuilder
Set a request attribute
setRetryPause(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncAdminBuilder
Set the base pause time for retrying.
setRetryPause(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
Set the base pause time for retrying.
setRetryPause(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
Set the base pause time for retrying.
setRetryPauseForCQTBE(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncAdminBuilder
Deprecated.
Since 2.5.0, will be removed in 4.0.0. Please use AsyncAdminBuilder.setRetryPauseForServerOverloaded(long, TimeUnit) instead.
setRetryPauseForCQTBE(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
Deprecated.
Since 2.5.0, will be removed in 4.0.0. Please use AsyncTableBuilder.setRetryPauseForServerOverloaded(long, TimeUnit) instead.
setRetryPauseForServerOverloaded(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncAdminBuilder
Set the base pause time for retrying when HBaseServerException.isServerOverloaded().
setRetryPauseForServerOverloaded(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
Set the base pause time for retrying when HBaseServerException.isServerOverloaded().
setReturnResults(boolean) - Method in class org.apache.hadoop.hbase.client.Append
True (default) if the append operation should return the results.
setReturnResults(boolean) - Method in class org.apache.hadoop.hbase.client.Increment
 
setReturnResults(boolean) - Method in class org.apache.hadoop.hbase.client.Mutation
 
setReversed(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
Set whether this scan is a reversed one
setReversed(boolean) - Method in class org.apache.hadoop.hbase.filter.Filter
alter the reversed scan flag
setReversed(boolean) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
setRow(byte[]) - Method in interface org.apache.hadoop.hbase.CellBuilder
 
setRow(byte[], int, int) - Method in interface org.apache.hadoop.hbase.CellBuilder
 
setRowFilter(Filter) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Allows subclasses to set the Filter to be used.
setRowFilter(Filter) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
 
setRowFilter(Filter) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
 
setRowOffsetPerColumnFamily(int) - Method in class org.apache.hadoop.hbase.client.Get
Set offset for the row per Column Family.
setRowOffsetPerColumnFamily(int) - Method in class org.apache.hadoop.hbase.client.Scan
Set offset for the row per Column Family.
setRowPrefixFilter(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
Deprecated.
since 2.5.0, will be removed in 4.0.0. The name of this method is considered to be confusing as it does not use a Filter but uses setting the startRow and stopRow instead. Use Scan.setStartStopRowForPrefixScan(byte[]) instead.
setRpcTimeout(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncAdminBuilder
Set timeout for each rpc request.
setRpcTimeout(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
Set timeout for each rpc request when doing background flush.
setRpcTimeout(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
Set timeout for each rpc request.
setRpcTimeout(int) - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
Deprecated.
Since 3.0.0, will be removed in 4.0.0. Please set this through the BufferedMutatorParams.
setRpcTimeout(int) - Method in interface org.apache.hadoop.hbase.client.TableBuilder
Set timeout for each rpc request.
setRSGroup(Set<TableName>, String) - Method in interface org.apache.hadoop.hbase.client.Admin
Set the RegionServer group for tables
setRSGroup(Set<TableName>, String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Set the RegionServer group for tables
setScan(Scan) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Sets the scan defining the actual details like columns etc.
setScan(Scan) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
Sets the scan defining the actual details like columns etc.
setScan(Scan) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
Sets the scan defining the actual details like columns etc.
setScanMetricsEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
Enable collection of ScanMetrics.
setScannerCaching(JobConf, int) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Sets the number of rows to return and cache with each scanner iteration.
setScannerCaching(Job, int) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Sets the number of rows to return and cache with each scanner iteration.
setScans(List<Scan>) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
Allows subclasses to set the list of Scan objects.
setScanTimeout(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
As now we have heartbeat support for scan, ideally a scan will never timeout unless the RS is crash.
setScope(int) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setSecond(T2) - Method in class org.apache.hadoop.hbase.util.Pair
Replace the second element of the pair.
setSerial(boolean) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
Sets whether we should preserve order when replicating, i.e, serial replication.
setServerOverloaded(boolean) - Method in exception org.apache.hadoop.hbase.HBaseServerException
Necessary for parsing RemoteException on client side
setSplitEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setStartKey(Configuration, byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
 
setStartLogErrorsCnt(int) - Method in interface org.apache.hadoop.hbase.client.AsyncAdminBuilder
Set the number of retries that are allowed before we start to log.
setStartLogErrorsCnt(int) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
Set the number of retries that are allowed before we start to log.
setStartLogErrorsCnt(int) - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
Set the number of retries that are allowed before we start to log.
setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
 
setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
 
setStartStopRowForPrefixScan(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
Set a filter (using stopRow and startRow) so the result set only contains rows where the rowKey starts with the specified prefix.
setStatistics(RegionLoadStats) - Method in class org.apache.hadoop.hbase.client.Result
Set load information about the region to the information about the result
setSticky(boolean) - Method in class org.apache.hadoop.hbase.rest.client.Client
The default behaviour is load balancing by sending each request to a random host.
setStoragePolicy(String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setTable(Table) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
 
setTableCFsMap(Map<TableName, List<String>>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
Sets an explicit map of tables and column families in those tables that should be replicated to the given peer.
setTableFilter(String) - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
Set the table filter regex
setTableName(String) - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
Deprecated.
 
setTableRecordReader(TableRecordReader) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Allows subclasses to set the TableRecordReader.
setTableRecordReader(TableRecordReader) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
Allows subclasses to set the TableRecordReader.
setTableRecordReader(TableRecordReader) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Allows subclasses to set the TableRecordReader.
setTickTime(int) - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
 
setTimeRange(long, long) - Method in class org.apache.hadoop.hbase.client.Append
Sets the TimeRange to be used on the Get for this append.
setTimeRange(long, long) - Method in class org.apache.hadoop.hbase.client.Get
Get versions of columns only within the specified timestamp range, [minStamp, maxStamp).
setTimeRange(long, long) - Method in class org.apache.hadoop.hbase.client.Increment
Sets the TimeRange to be used on the Get for this increment.
setTimeRange(long, long) - Method in class org.apache.hadoop.hbase.client.Scan
Get versions of columns only within the specified timestamp range, [minStamp, maxStamp).
setTimestamp(long) - Method in interface org.apache.hadoop.hbase.CellBuilder
 
setTimestamp(Cell, long) - Static method in class org.apache.hadoop.hbase.CellUtil
Sets the given timestamp to the cell.
setTimestamp(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
Sets the given timestamp to the cell.
setTimestamp(long) - Method in class org.apache.hadoop.hbase.client.Append
 
setTimestamp(long) - Method in class org.apache.hadoop.hbase.client.Delete
 
setTimestamp(long) - Method in class org.apache.hadoop.hbase.client.Get
Get versions of columns with the specified timestamp.
setTimestamp(long) - Method in class org.apache.hadoop.hbase.client.Increment
 
setTimestamp(long) - Method in class org.apache.hadoop.hbase.client.Mutation
Set the timestamp of the delete.
setTimestamp(long) - Method in class org.apache.hadoop.hbase.client.Put
 
setTimestamp(long) - Method in class org.apache.hadoop.hbase.client.Scan
Get versions of columns with the specified timestamp.
setTimeToLive(int) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setTimeToLive(String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setTTL(long) - Method in class org.apache.hadoop.hbase.client.Append
 
setTTL(long) - Method in class org.apache.hadoop.hbase.client.Delete
 
setTTL(long) - Method in class org.apache.hadoop.hbase.client.Increment
 
setTTL(long) - Method in class org.apache.hadoop.hbase.client.Mutation
Set the TTL desired for the result of the mutation, in milliseconds.
setTTL(long) - Method in class org.apache.hadoop.hbase.client.Put
 
setType(Cell.Type) - Method in interface org.apache.hadoop.hbase.CellBuilder
 
setType(LogQueryFilter.Type) - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
Deprecated.
 
setup(Reducer<ImmutableBytesWritable, Put, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.PutSortReducer
 
setup(Reducer<ImmutableBytesWritable, Text, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
Handles initializing this class with objects specific to it (i.e., the parser).
setup(Mapper<LongWritable, Text, ImmutableBytesWritable, Put>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
Handles initializing this class with objects specific to it (i.e., the parser).
setup(Mapper<LongWritable, Text, ImmutableBytesWritable, Text>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
Handles initializing this class with objects specific to it (i.e., the parser).
setupClusterTestDir() - Method in class org.apache.hadoop.hbase.HBaseZKTestingUtility
Deprecated.
Creates a directory for the cluster, under the test data
setupDataTestDir() - Method in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
Deprecated.
Sets up a directory for a test to use.
setupDataTestDir() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
setupJob(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
 
setupMiniKdc(File) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Sets up MiniKdc for testing security.
setupSetQuotaRequest(MasterProtos.SetQuotaRequest.Builder) - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
Called by toSetQuotaRequestProto() the subclass should implement this method to set the specific SetQuotaRequest properties.
setupTask(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
 
setUserFilter(String) - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
Set the user filter regex
setUserName(String) - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
Deprecated.
 
setValue(byte[]) - Method in interface org.apache.hadoop.hbase.CellBuilder
 
setValue(byte[], int, int) - Method in interface org.apache.hadoop.hbase.CellBuilder
 
setValue(Bytes, Bytes) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setValue(String, String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setValue(String, String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setValue(Bytes, Bytes) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setVersionsWithTimeToLive(int, int) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setWithPrefix(Configuration, String, Iterable<Map.Entry<String, String>>) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
Sets all the entries in the provided Map<String, String> as properties in the given Configuration.
setWriteBufferPeriodicFlush(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
Set the periodical flush interval.
setWriteBufferPeriodicFlush(long) - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
Sets the maximum time before the buffer is automatically flushed checking once per second.
setWriteBufferPeriodicFlush(long, long) - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
Sets the maximum time before the buffer is automatically flushed.
setWriteBufferPeriodicFlushTimeoutMs(long) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
Set the max timeout before the buffer is automatically flushed.
setWriteBufferPeriodicFlushTimerTickMs(long) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
Deprecated.
Since 3.0.0, will be removed in 4.0.0. We use a common timer in the whole client implementation so you can not set it any more.
setWriteBufferSize(long) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
Override the write buffer size specified by the provided AsyncConnection's Configuration instance, via the configuration key hbase.client.write.buffer.
setWriteRpcTimeout(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
Set timeout for each write(put, delete) rpc request.
setWriteRpcTimeout(int) - Method in interface org.apache.hadoop.hbase.client.TableBuilder
Set timeout for each write(put, delete) rpc request.
setZkCluster(MiniZooKeeperCluster) - Method in class org.apache.hadoop.hbase.HBaseZKTestingUtility
Deprecated.
 
shallowCopy() - Method in interface org.apache.hadoop.hbase.util.ByteRange
Create a new ByteRange that points at this range's byte[].
shallowCopy() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
 
shallowCopy() - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
 
shallowCopy() - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
 
shallowCopy() - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
shallowCopy() - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
shallowCopySubRange(int, int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Create a new ByteRange that points at this range's byte[].
shallowCopySubRange(int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
 
shallowCopySubRange(int, int) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
 
shallowCopySubRange(int, int) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
 
shallowCopySubRange(int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
shallowCopySubRange(int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
SHELL_TIMESTAMP_FORMAT_EPOCH_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
shouldLoginFromKeytab(Configuration) - Static method in class org.apache.hadoop.hbase.security.User
In secure environment, if a user specified his keytab and principal, a hbase client will try to login with them.
SHUFFLE_MAPS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Specify if we have to shuffle the map tasks.
shutdown() - Method in interface org.apache.hadoop.hbase.client.Admin
Shuts down the HBase cluster.
shutdown() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Shuts down the HBase cluster.
shutdown() - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
Shut down the HBase cluster
shutdown() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
Shut down the mini HBase cluster
shutdown() - Method in class org.apache.hadoop.hbase.rest.client.Client
Shut down the client.
shutdown() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
 
shutdownMiniCluster() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Stops mini hbase, zk, and hdfs clusters.
shutdownMiniDFSCluster() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Shuts down instance created by call to HBaseTestingUtility.startMiniDFSCluster(int) or does nothing.
shutdownMiniHBaseCluster() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Shutdown HBase mini cluster.Does not shutdown zk or dfs if running.
shutdownMiniMapReduceCluster() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Stops the previously started MiniMRCluster.
shutdownMiniZKCluster() - Method in class org.apache.hadoop.hbase.HBaseZKTestingUtility
Deprecated.
Shuts down zk cluster created by call to HBaseZKTestingUtility.startMiniZKCluster() or does nothing.
SimpleByteRange - Class in org.apache.hadoop.hbase.util
A read only version of the ByteRange.
SimpleByteRange() - Constructor for class org.apache.hadoop.hbase.util.SimpleByteRange
 
SimpleByteRange(int) - Constructor for class org.apache.hadoop.hbase.util.SimpleByteRange
 
SimpleByteRange(byte[]) - Constructor for class org.apache.hadoop.hbase.util.SimpleByteRange
Create a new ByteRange over the provided bytes.
SimpleByteRange(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.util.SimpleByteRange
Create a new ByteRange over the provided bytes.
SimpleMutableByteRange - Class in org.apache.hadoop.hbase.util
A basic mutable ByteRange implementation.
SimpleMutableByteRange() - Constructor for class org.apache.hadoop.hbase.util.SimpleMutableByteRange
Create a new ByteRange lacking a backing array and with an undefined viewport.
SimpleMutableByteRange(int) - Constructor for class org.apache.hadoop.hbase.util.SimpleMutableByteRange
Create a new ByteRange over a new backing array of size capacity.
SimpleMutableByteRange(byte[]) - Constructor for class org.apache.hadoop.hbase.util.SimpleMutableByteRange
Create a new ByteRange over the provided bytes.
SimpleMutableByteRange(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.util.SimpleMutableByteRange
Create a new ByteRange over the provided bytes.
SimplePositionedByteRange - Class in org.apache.hadoop.hbase.util
Extends the basic SimpleMutableByteRange implementation with position support and it is a readonly version.
SimplePositionedByteRange() - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedByteRange
Create a new PositionedByteRange lacking a backing array and with an undefined viewport.
SimplePositionedByteRange(int) - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedByteRange
Create a new PositionedByteRange over a new backing array of size capacity.
SimplePositionedByteRange(byte[]) - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedByteRange
Create a new PositionedByteRange over the provided bytes.
SimplePositionedByteRange(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedByteRange
Create a new PositionedByteRange over the provided bytes.
SimplePositionedMutableByteRange - Class in org.apache.hadoop.hbase.util
Extends the basic AbstractPositionedByteRange implementation with position support and it is a mutable version.
SimplePositionedMutableByteRange() - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
Create a new PositionedByteRange lacking a backing array and with an undefined viewport.
SimplePositionedMutableByteRange(int) - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
Create a new PositionedByteRange over a new backing array of size capacity.
SimplePositionedMutableByteRange(byte[]) - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
Create a new PositionedByteRange over the provided bytes.
SimplePositionedMutableByteRange(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
Create a new PositionedByteRange over the provided bytes.
SimpleTotalOrderPartitioner<VALUE> - Class in org.apache.hadoop.hbase.mapreduce
A partitioner that takes start and end keys and uses bigdecimal to figure which reduce a key belongs to.
SimpleTotalOrderPartitioner() - Constructor for class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
 
SINGLE_QUOTE - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for a single quote
SingleColumnValueExcludeFilter - Class in org.apache.hadoop.hbase.filter
A Filter that checks a single column value, but does not emit the tested column.
SingleColumnValueExcludeFilter(byte[], byte[], CompareOperator, byte[]) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
Constructor for binary compare of the value of a single column.
SingleColumnValueExcludeFilter(byte[], byte[], CompareOperator, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
Constructor for binary compare of the value of a single column.
SingleColumnValueExcludeFilter(byte[], byte[], CompareOperator, ByteArrayComparable, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
Constructor for protobuf deserialization only.
SingleColumnValueFilter - Class in org.apache.hadoop.hbase.filter
This filter is used to filter cells based on value.
SingleColumnValueFilter(byte[], byte[], CompareOperator, byte[]) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Constructor for binary compare of the value of a single column.
SingleColumnValueFilter(byte[], byte[], CompareOperator, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Constructor for binary compare of the value of a single column.
SingleColumnValueFilter(byte[], byte[], CompareOperator, ByteArrayComparable, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Constructor for protobuf deserialization only.
size() - Method in class org.apache.hadoop.hbase.client.Mutation
Number of KeyValues carried by this Mutation.
size() - Method in class org.apache.hadoop.hbase.client.Result
Returns the size of the underlying Cell []
size() - Method in class org.apache.hadoop.hbase.filter.FilterList
 
size() - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
Size - Class in org.apache.hadoop.hbase
It is used to represent the size with different units.
Size(double, Size.Unit) - Constructor for class org.apache.hadoop.hbase.Size
 
SIZEOF_BOOLEAN - Static variable in class org.apache.hadoop.hbase.util.Bytes
Size of boolean in bytes
SIZEOF_BYTE - Static variable in class org.apache.hadoop.hbase.util.Bytes
Size of byte in bytes
SIZEOF_CHAR - Static variable in class org.apache.hadoop.hbase.util.Bytes
Size of char in bytes
SIZEOF_DOUBLE - Static variable in class org.apache.hadoop.hbase.util.Bytes
Size of double in bytes
SIZEOF_FLOAT - Static variable in class org.apache.hadoop.hbase.util.Bytes
Size of float in bytes
SIZEOF_INT - Static variable in class org.apache.hadoop.hbase.util.Bytes
Size of int in bytes
SIZEOF_LONG - Static variable in class org.apache.hadoop.hbase.util.Bytes
Size of long in bytes
SIZEOF_SHORT - Static variable in class org.apache.hadoop.hbase.util.Bytes
Size of short in bytes
sizeToString(long) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettings
 
skip(PositionedByteRange) - Method in interface org.apache.hadoop.hbase.types.DataType
Skip src's position forward over one encoded value.
skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
 
skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedBytesBase
 
skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawByte
 
skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawBytes
 
skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawDouble
 
skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawFloat
 
skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawInteger
 
skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawLong
 
skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawShort
 
skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawString
 
skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Struct
 
skip() - Method in class org.apache.hadoop.hbase.types.StructIterator
Bypass the next encoded value.
skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
Skip src's position forward over one encoded value.
skip(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Skip buff's position forward over one encoded value.
SKIP_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
SKIP Array
SKIP_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
 
SKIP_EMPTY_COLUMNS - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
SKIP_LINES_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
SkipFilter - Class in org.apache.hadoop.hbase.filter
A wrapper filter that filters an entire row if any of the Cell checks do not pass.
SkipFilter(Filter) - Constructor for class org.apache.hadoop.hbase.filter.SkipFilter
 
SLOW_LOG_BUFFER_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
SLOW_LOG_SCAN_PAYLOAD_ENABLED - Static variable in class org.apache.hadoop.hbase.HConstants
 
SLOW_LOG_SCAN_PAYLOAD_ENABLED_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
SLOW_LOG_SYS_TABLE_CHORE_DURATION_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Deprecated.
SLOW_LOG_SYS_TABLE_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
SLOWLOG_INFO_FAMILY - Static variable in class org.apache.hadoop.hbase.HConstants
The slowlog info family
snapshot(String, TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Take a snapshot for the given table.
snapshot(String, TableName, SnapshotType) - Method in interface org.apache.hadoop.hbase.client.Admin
Create typed snapshot of the table.
snapshot(String, TableName, SnapshotType, Map<String, Object>) - Method in interface org.apache.hadoop.hbase.client.Admin
Create typed snapshot of the table.
snapshot(String, TableName, Map<String, Object>) - Method in interface org.apache.hadoop.hbase.client.Admin
Create typed snapshot of the table.
snapshot(SnapshotDescription) - Method in interface org.apache.hadoop.hbase.client.Admin
Take a snapshot and wait for the server to complete that snapshot (blocking).
snapshot(String, TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Take a snapshot for the given table.
snapshot(String, TableName, SnapshotType) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Create typed snapshot of the table.
snapshot(SnapshotDescription) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Take a snapshot and wait for the server to complete that snapshot asynchronously.
SNAPSHOT_DIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
Name of the directory to store all snapshots.
SNAPSHOT_RESTORE_FAILSAFE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
 
SNAPSHOT_RESTORE_TAKE_FAILSAFE_SNAPSHOT - Static variable in class org.apache.hadoop.hbase.HConstants
 
snapshotAsync(SnapshotDescription) - Method in interface org.apache.hadoop.hbase.client.Admin
Take a snapshot without waiting for the server to complete that snapshot (asynchronous).
snapshotCleanupSwitch(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Turn on or off the auto snapshot cleanup based on TTL.
snapshotCleanupSwitch(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Turn on or off the auto snapshot cleanup based on TTL.
SnapshotCreationException - Exception in org.apache.hadoop.hbase.snapshot
Thrown when a snapshot could not be created due to a server-side error when taking the snapshot.
SnapshotCreationException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotCreationException
Used internally by the RPC engine to pass the exception back to the client.
SnapshotCreationException(String, SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotCreationException
Failure to create the specified snapshot.
SnapshotCreationException(String, Throwable, SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotCreationException
Failure to create the specified snapshot due to an external cause.
SnapshotDescription - Class in org.apache.hadoop.hbase.client
The POJO equivalent of HBaseProtos.SnapshotDescription
SnapshotDescription(String) - Constructor for class org.apache.hadoop.hbase.client.SnapshotDescription
 
SnapshotDescription(String, TableName) - Constructor for class org.apache.hadoop.hbase.client.SnapshotDescription
 
SnapshotDescription(String, TableName, SnapshotType) - Constructor for class org.apache.hadoop.hbase.client.SnapshotDescription
 
SnapshotDescription(String, TableName, SnapshotType, String) - Constructor for class org.apache.hadoop.hbase.client.SnapshotDescription
 
SnapshotDescription(String, TableName, SnapshotType, String, long, int) - Constructor for class org.apache.hadoop.hbase.client.SnapshotDescription
Deprecated.
SnapshotDescription(String, TableName, SnapshotType, String, long, int, Map<String, Object>) - Constructor for class org.apache.hadoop.hbase.client.SnapshotDescription
SnapshotDescription Parameterized Constructor
SnapshotDescription(String, TableName, SnapshotType, Map<String, Object>) - Constructor for class org.apache.hadoop.hbase.client.SnapshotDescription
SnapshotDescription Parameterized Constructor
SnapshotDoesNotExistException - Exception in org.apache.hadoop.hbase.snapshot
Thrown when the server is looking for a snapshot, but can't find the snapshot on the filesystem.
SnapshotDoesNotExistException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotDoesNotExistException
 
SnapshotDoesNotExistException(SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotDoesNotExistException
 
SnapshotExistsException - Exception in org.apache.hadoop.hbase.snapshot
Thrown when a snapshot exists, but should not.
SnapshotExistsException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotExistsException
Failure due to the snapshot already existing.
SnapshotExistsException(String, SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotExistsException
Failure due to the snapshot already existing.
SnapshotInfo - Class in org.apache.hadoop.hbase.snapshot
Tool for dumping snapshot information.
SnapshotInfo() - Constructor for class org.apache.hadoop.hbase.snapshot.SnapshotInfo
 
SnapshotTTLExpiredException - Exception in org.apache.hadoop.hbase.snapshot
Thrown when a snapshot could not be restored/cloned because the ttl for snapshot has already expired
SnapshotTTLExpiredException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotTTLExpiredException
Failure when the ttl for snapshot has already expired.
SnapshotTTLExpiredException(SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotTTLExpiredException
Failure when the ttl for snapshot has already expired.
SnapshotType - Enum in org.apache.hadoop.hbase.client
POJO representing the snapshot type
SOCKET_RETRY_WAIT_MS - Static variable in class org.apache.hadoop.hbase.HConstants
The delay when re-trying a socket operation in a loop (HBASE-4712)
sortAndMerge(List<MultiRowRangeFilter.RowRange>) - Static method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
sort the ranges and if the ranges with overlap, then merge them.
sortedPrefixes - Variable in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
SpaceLimitingException - Exception in org.apache.hadoop.hbase.quotas
An Exception that is thrown when a space quota is in violation.
SpaceLimitingException(String) - Constructor for exception org.apache.hadoop.hbase.quotas.SpaceLimitingException
 
SpaceLimitingException(String, String) - Constructor for exception org.apache.hadoop.hbase.quotas.SpaceLimitingException
 
SpaceLimitingException(String, String, Throwable) - Constructor for exception org.apache.hadoop.hbase.quotas.SpaceLimitingException
 
SpaceQuotaSnapshotView - Interface in org.apache.hadoop.hbase.quotas
A point-in-time view of a space quota on a table, read only.
SpaceQuotaSnapshotView.SpaceQuotaStatusView - Interface in org.apache.hadoop.hbase.quotas
Encapsulates the state of a quota on a table.
SpaceViolationPolicy - Enum in org.apache.hadoop.hbase.quotas
Enumeration that represents the action HBase will take when a space quota is violated.
SPARK - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
 
split(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Split a table.
split(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Split a table.
split(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Split a table.
split(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Split a table.
split(byte[], byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Split passed range.
split(byte[], byte[], boolean, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Split passed range.
SPLIT_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 split enabled.
SPLIT_LOGDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
Used to construct the name of the splitlog directory for a region server
SPLIT_POLICY - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
SPLITA_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
The lower-half split region column qualifier
SPLITA_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
The lower-half split region column qualifier string.
SPLITB_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
The upper-half split region column qualifier
SPLITB_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
The upper-half split region column qualifier String.
splitRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Split an individual region.
splitRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Split an individual region.
splitRegionAsync(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Split an individual region.
splitRegionAsync(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Split an individual region.
splitSwitch(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Turn the split switch on or off.
splitSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Turn the Split switch on or off.
splitSwitch(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Turn the Split switch on or off.
src - Variable in class org.apache.hadoop.hbase.types.StructIterator
 
stampSet - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
START - Static variable in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
Deprecated.
since 0.90.0
start() - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
Start the whole mini cluster, including zookeeper cluster, dfs cluster and hbase cluster.
START_KEY - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
START_KEY_BYTES - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
START_TIME_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.WALInputFormat
 
STARTCODE_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
The startcode column qualifier
STARTCODE_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
The startcode column qualifier
startDataNode(ServerName) - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
Starts a new datanode on the given hostname or if this is a mini/local cluster, silently logs warning message.
startDataNode(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
 
startHBaseCluster() - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
Start the hbase cluster.
startMaster(String, int) - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
Starts a new master on the given hostname or if this is a mini/local cluster, starts a master locally.
startMaster(String, int) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
 
startMaster() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
Starts a master thread running
startMaster() - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
Start a new master with localhost and random port.
startMaster(String, int) - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
Start a new master bind on the given host and port.
startMiniCluster(boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
since 2.2.0 and will be removed in 4.0.0. Use HBaseTestingUtility.startMiniCluster(StartMiniClusterOption) instead.
startMiniCluster(int, boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
since 2.2.0 and will be removed in 4.0.0. Use HBaseTestingUtility.startMiniCluster(StartMiniClusterOption) instead.
startMiniCluster(int, boolean, boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
since 2.2.0 and will be removed in 4.0.0. Use HBaseTestingUtility.startMiniCluster(StartMiniClusterOption) instead.
startMiniCluster(int, int, boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
since 2.2.0 and will be removed in 4.0.0. Use HBaseTestingUtility.startMiniCluster(StartMiniClusterOption) instead.
startMiniCluster(int, int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
since 2.2.0 and will be removed in 4.0.0. Use HBaseTestingUtility.startMiniCluster(StartMiniClusterOption) instead.
startMiniCluster(int, int, String[], boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
since 2.2.0 and will be removed in 4.0.0. Use HBaseTestingUtility.startMiniCluster(StartMiniClusterOption) instead.
startMiniCluster(int, int, String[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
since 2.2.0 and will be removed in 4.0.0. Use HBaseTestingUtility.startMiniCluster(StartMiniClusterOption) instead.
startMiniCluster(int, int, int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
since 2.2.0 and will be removed in 4.0.0. Use HBaseTestingUtility.startMiniCluster(StartMiniClusterOption) instead.
startMiniCluster(int, int, String[], Class<? extends HMaster>, Class<? extends MiniHBaseCluster.MiniHBaseClusterRegionServer>) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
since 2.2.0 and will be removed in 4.0.0. Use HBaseTestingUtility.startMiniCluster(StartMiniClusterOption) instead.
startMiniCluster(int, int, int, String[], Class<? extends HMaster>, Class<? extends MiniHBaseCluster.MiniHBaseClusterRegionServer>) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
since 2.2.0 and will be removed in 4.0.0. Use HBaseTestingUtility.startMiniCluster(StartMiniClusterOption) instead.
startMiniCluster(int, int, int, String[], Class<? extends HMaster>, Class<? extends MiniHBaseCluster.MiniHBaseClusterRegionServer>, boolean, boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
since 2.2.0 and will be removed in 4.0.0. Use HBaseTestingUtility.startMiniCluster(StartMiniClusterOption) instead.
startMiniCluster(int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Start up a minicluster of hbase, dfs and zookeeper clusters with given slave node number.
startMiniCluster() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Start up a minicluster of hbase, dfs and zookeeper all using default options.
startMiniCluster(StartMiniClusterOption) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Start up a mini cluster of hbase, optionally dfs and zookeeper if needed.
StartMiniClusterOption - Class in org.apache.hadoop.hbase
Deprecated.
since 3.0.0, will be removed in 4.0.0. Use TestingHBaseCluster instead.
startMiniDFSCluster(int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Start a minidfscluster.
startMiniDFSCluster(String[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Start a minidfscluster.
startMiniDFSCluster(int, String[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Start a minidfscluster.
startMiniDFSCluster(int, String[], String[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
startMiniDFSClusterForTestWAL(int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
startMiniHBaseCluster(StartMiniClusterOption) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Starts up mini hbase cluster.
startMiniHBaseCluster() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Starts up mini hbase cluster using default options.
startMiniHBaseCluster(int, int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
since 2.2.0 and will be removed in 4.0.0. Use HBaseTestingUtility.startMiniHBaseCluster(StartMiniClusterOption) instead.
startMiniHBaseCluster(int, int, List<Integer>) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
since 2.2.0 and will be removed in 4.0.0. Use HBaseTestingUtility.startMiniHBaseCluster(StartMiniClusterOption) instead.
startMiniHBaseCluster(int, int, List<Integer>, Class<? extends HMaster>, Class<? extends MiniHBaseCluster.MiniHBaseClusterRegionServer>, boolean, boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
since 2.2.0 and will be removed in 4.0.0. Use HBaseTestingUtility.startMiniHBaseCluster(StartMiniClusterOption) instead.
startMiniMapReduceCluster() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Starts a MiniMRCluster with a default number of TaskTracker's.
startMiniZKCluster() - Method in class org.apache.hadoop.hbase.HBaseZKTestingUtility
Deprecated.
Call this if you only want a zk cluster.
startMiniZKCluster(int, int...) - Method in class org.apache.hadoop.hbase.HBaseZKTestingUtility
Deprecated.
Call this if you only want a zk cluster.
startNameNode(ServerName) - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
Starts a new namenode on the given hostname or if this is a mini/local cluster, silently logs warning message.
startNameNode(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
 
startRegionServer(String, int) - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
Starts a new region server on the given hostname or if this is a mini/local cluster, starts a region server locally.
startRegionServer(String, int) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
 
startRegionServer() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
Starts a region server thread running
startRegionServer() - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
Start a new region server with localhost and random port.
startRegionServer(String, int) - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
Start a new region server bind on the given host and port.
startRegionServerAndWait(long) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
Starts a region server thread and waits until its processed by master.
startsWith(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Return true if the byte array on the right is a prefix of the byte array on the left.
startup(File) - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
 
startup(File, int) - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
 
startZkNode(String, int) - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
Starts a new zookeeper node on the given hostname or if this is a mini/local cluster, silently logs warning message.
startZkNode(String, int) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
 
STATE_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
 
STATE_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
The state column qualifier
STATUS_MULTICAST_ADDRESS - Static variable in class org.apache.hadoop.hbase.HConstants
IP to use for the multicast status messages between the master and the clients.
STATUS_MULTICAST_BIND_ADDRESS - Static variable in class org.apache.hadoop.hbase.HConstants
The address to use for binding the local socket for receiving multicast.
STATUS_MULTICAST_NI_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
The network interface name to use for the multicast messages.
STATUS_MULTICAST_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
The port to use for the multicast messages.
STATUS_MULTICAST_PUBLISHER_BIND_ADDRESS - Static variable in class org.apache.hadoop.hbase.HConstants
The address to use for binding the local socket for sending multicast.
STATUS_PUBLISHED - Static variable in class org.apache.hadoop.hbase.HConstants
Setting to activate, or not, the publication of the status by the master.
STATUS_PUBLISHED_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
stop(String) - Method in interface org.apache.hadoop.hbase.Stoppable
Stop this service.
stop() - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
Stop the whole mini cluster, including zookeeper cluster, dfs cluster and hbase cluster.
stopDataNode(ServerName) - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
Stops the datanode if this is a distributed cluster, otherwise silently logs warning message.
stopDataNode(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
 
stopHBaseCluster() - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
Stop the hbase cluster.
stopMaster() - Method in interface org.apache.hadoop.hbase.client.Admin
Shuts down the current HBase master only.
stopMaster() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Shuts down the current HBase master only.
stopMaster(ServerName) - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
Stops the given master, by attempting a gradual stop.
stopMaster(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
 
stopMaster(int) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
Shut down the specified master cleanly
stopMaster(int, boolean) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
Shut down the specified master cleanly
stopMaster(ServerName) - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
Stop the given master.
stopNameNode(ServerName) - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
Stops the namenode if this is a distributed cluster, otherwise silently logs warning message.
stopNameNode(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
 
Stoppable - Interface in org.apache.hadoop.hbase
Implementers are Stoppable.
StoppedRpcClientException - Exception in org.apache.hadoop.hbase.ipc
 
StoppedRpcClientException() - Constructor for exception org.apache.hadoop.hbase.ipc.StoppedRpcClientException
 
StoppedRpcClientException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.StoppedRpcClientException
 
stopRegionServer(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Stop the designated regionserver.
stopRegionServer(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Stop the designated regionserver.
stopRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
Stops the given region server, by attempting a gradual stop.
stopRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
 
stopRegionServer(int) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
Shut down the specified region server cleanly
stopRegionServer(int, boolean) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
Shut down the specified region server cleanly
stopRegionServer(ServerName) - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
Stop the given region server.
stopZkNode(ServerName) - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
Stops the region zookeeper if this is a distributed cluster, otherwise silently logs warning message.
stopZkNode(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
 
STORAGE_POLICY - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
STORAGE_POLICY_PREFIX - Static variable in class org.apache.hadoop.hbase.HConstants
Date Tiered Compaction tmp dir prefix name if use storage policy
STORAGE_POLICY_PROPERTY - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
 
STORAGE_POLICY_PROPERTY_CF_PREFIX - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
 
store - Variable in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
 
STORE_FILE_REF_COUNT_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
 
stringFromMillis(long) - Static method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
 
Struct - Class in org.apache.hadoop.hbase.types
Struct is a simple DataType for implementing "compound rowkey" and "compound qualifier" schema design strategies.
Struct(DataType[]) - Constructor for class org.apache.hadoop.hbase.types.Struct
Create a new Struct instance defined as the sequence of HDataTypes in memberTypes.
StructBuilder - Class in org.apache.hadoop.hbase.types
A helper for building Struct instances.
StructBuilder() - Constructor for class org.apache.hadoop.hbase.types.StructBuilder
Create an empty StructBuilder.
StructIterator - Class in org.apache.hadoop.hbase.types
An Iterator over encoded Struct members.
StructIterator(PositionedByteRange, DataType[]) - Constructor for class org.apache.hadoop.hbase.types.StructIterator
Construct StructIterator over the values encoded in src using the specified types definition.
subset(Configuration, String) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
Returns a subset of the configuration properties, matching the given key prefix.
SubstringComparator - Class in org.apache.hadoop.hbase.filter
This comparator is for use with SingleColumnValueFilter, for filtering based on the value of a given column.
SubstringComparator(String) - Constructor for class org.apache.hadoop.hbase.filter.SubstringComparator
Constructor
substringType - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
SubstringType byte array
suspend() - Method in interface org.apache.hadoop.hbase.client.AdvancedScanResultConsumer.ScanController
Suspend the scan.
suspendRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
Suspend the region server
suspendRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
 
suspendRegionServer(int) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
Suspend the specified region server
switchRpcThrottle(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Switch the rpc throttle enable state.
switchRpcThrottle(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Switch the rpc throttle enabled state.
SyncReplicationState - Enum in org.apache.hadoop.hbase.replication
Used by synchronous replication.
SYSTEM_NAMESPACE - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
 
SYSTEM_NAMESPACE_NAME - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
System namespace name.
SYSTEM_NAMESPACE_NAME_STR - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
 
SYSTEMTABLE_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
 

T

TAB - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for tab
Table - Interface in org.apache.hadoop.hbase.client
Used to communicate with a single HBase table.
TABLE_DESC_PROP_GROUP - Static variable in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
 
TABLE_FAMILY - Static variable in class org.apache.hadoop.hbase.HConstants
The catalog family
TABLE_FAMILY_STR - Static variable in class org.apache.hadoop.hbase.HConstants
The catalog family as a string
TABLE_INPUT_CLASS_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
 
TABLE_MAP_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.WALPlayer
 
TABLE_MAX_ROWSIZE_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
Default max row size (1 Gb).
TABLE_MAX_ROWSIZE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Max size of single row for Get's or Scan's without in-row scanning flag set.
TABLE_NAME - Static variable in class org.apache.hadoop.hbase.mapreduce.Import
 
TABLE_STATE_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
The serialized table state qualifier
TableBuilder - Interface in org.apache.hadoop.hbase.client
For creating Table instance.
TableCFs - Class in org.apache.hadoop.hbase.client.replication
TableCFs(TableName, Map<String, Integer>) - Constructor for class org.apache.hadoop.hbase.client.replication.TableCFs
 
TableDescriptor - Interface in org.apache.hadoop.hbase.client
TableDescriptor contains the details about an HBase table such as the descriptors of all the column families, is the table a catalog table, hbase:meta , if the table is read only, the maximum size of the memstore, when the region split should occur, coprocessors associated with it etc...
TableDescriptorBuilder - Class in org.apache.hadoop.hbase.client
Convenience class for composing an instance of TableDescriptor.
TableDescriptorUtils - Class in org.apache.hadoop.hbase.client
 
tableExists(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Check if a table exists.
tableExists(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Check if a table exists.
TableExistsException - Exception in org.apache.hadoop.hbase
Thrown when a table exists but should not.
TableExistsException() - Constructor for exception org.apache.hadoop.hbase.TableExistsException
 
TableExistsException(String) - Constructor for exception org.apache.hadoop.hbase.TableExistsException
 
TableExistsException(TableName) - Constructor for exception org.apache.hadoop.hbase.TableExistsException
 
TableInfoMissingException - Exception in org.apache.hadoop.hbase
Failed to find .tableinfo file under the table directory.
TableInfoMissingException() - Constructor for exception org.apache.hadoop.hbase.TableInfoMissingException
Failed to find .tableinfo file under the table directory.
TableInfoMissingException(String) - Constructor for exception org.apache.hadoop.hbase.TableInfoMissingException
 
TableInfoMissingException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.TableInfoMissingException
 
TableInfoMissingException(Throwable) - Constructor for exception org.apache.hadoop.hbase.TableInfoMissingException
 
TableInputFormat - Class in org.apache.hadoop.hbase.mapred
Convert HBase tabular data into a format that is consumable by Map/Reduce.
TableInputFormat() - Constructor for class org.apache.hadoop.hbase.mapred.TableInputFormat
 
TableInputFormat - Class in org.apache.hadoop.hbase.mapreduce
Convert HBase tabular data into a format that is consumable by Map/Reduce.
TableInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableInputFormat
 
TableInputFormatBase - Class in org.apache.hadoop.hbase.mapred
A Base for TableInputFormats.
TableInputFormatBase() - Constructor for class org.apache.hadoop.hbase.mapred.TableInputFormatBase
 
TableInputFormatBase - Class in org.apache.hadoop.hbase.mapreduce
A base for TableInputFormats.
TableInputFormatBase() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
 
TableMap<K extends org.apache.hadoop.io.WritableComparable<? super K>,V> - Interface in org.apache.hadoop.hbase.mapred
Scan an HBase table to sort by a specified sort column.
TableMapper<KEYOUT,VALUEOUT> - Class in org.apache.hadoop.hbase.mapreduce
Extends the base Mapper class to add the required input key and value classes.
TableMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableMapper
 
TableMapReduceUtil - Class in org.apache.hadoop.hbase.mapred
Utility for TableMap and TableReduce
TableMapReduceUtil() - Constructor for class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
 
TableMapReduceUtil - Class in org.apache.hadoop.hbase.mapreduce
Utility for TableMapper and TableReducer
TableMapReduceUtil() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
 
TableName - Class in org.apache.hadoop.hbase
Immutable POJO class for representing a table name.
TableNotDisabledException - Exception in org.apache.hadoop.hbase
Thrown if a table should be offline but is not.
TableNotDisabledException() - Constructor for exception org.apache.hadoop.hbase.TableNotDisabledException
 
TableNotDisabledException(String) - Constructor for exception org.apache.hadoop.hbase.TableNotDisabledException
 
TableNotDisabledException(byte[]) - Constructor for exception org.apache.hadoop.hbase.TableNotDisabledException
 
TableNotDisabledException(TableName) - Constructor for exception org.apache.hadoop.hbase.TableNotDisabledException
 
TableNotEnabledException - Exception in org.apache.hadoop.hbase
Thrown if a table should be enabled but is not.
TableNotEnabledException() - Constructor for exception org.apache.hadoop.hbase.TableNotEnabledException
default constructor
TableNotEnabledException(String) - Constructor for exception org.apache.hadoop.hbase.TableNotEnabledException
 
TableNotEnabledException(TableName) - Constructor for exception org.apache.hadoop.hbase.TableNotEnabledException
 
TableNotEnabledException(byte[]) - Constructor for exception org.apache.hadoop.hbase.TableNotEnabledException
 
TableNotFoundException - Exception in org.apache.hadoop.hbase
Thrown when a table cannot be located.
TableNotFoundException() - Constructor for exception org.apache.hadoop.hbase.TableNotFoundException
 
TableNotFoundException(String) - Constructor for exception org.apache.hadoop.hbase.TableNotFoundException
 
TableNotFoundException(byte[]) - Constructor for exception org.apache.hadoop.hbase.TableNotFoundException
 
TableNotFoundException(TableName) - Constructor for exception org.apache.hadoop.hbase.TableNotFoundException
 
TableOutputCommitter - Class in org.apache.hadoop.hbase.mapreduce
Small committer class that does not do anything.
TableOutputCommitter() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
 
TableOutputFormat - Class in org.apache.hadoop.hbase.mapred
Convert Map/Reduce output and write it to an HBase table
TableOutputFormat() - Constructor for class org.apache.hadoop.hbase.mapred.TableOutputFormat
 
TableOutputFormat<KEY> - Class in org.apache.hadoop.hbase.mapreduce
Convert Map/Reduce output and write it to an HBase table.
TableOutputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
 
TablePartiallyOpenException - Exception in org.apache.hadoop.hbase.snapshot
Thrown if a table should be online/offline, but is partially open.
TablePartiallyOpenException() - Constructor for exception org.apache.hadoop.hbase.snapshot.TablePartiallyOpenException
Constructs an TablePartiallyOpenException with null as its error detail message.
TablePartiallyOpenException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.TablePartiallyOpenException
 
TablePartiallyOpenException(TableName) - Constructor for exception org.apache.hadoop.hbase.snapshot.TablePartiallyOpenException
 
TablePartiallyOpenException(byte[]) - Constructor for exception org.apache.hadoop.hbase.snapshot.TablePartiallyOpenException
 
TableRecordReader - Class in org.apache.hadoop.hbase.mapred
Iterate over an HBase table data, return (Text, RowResult) pairs
TableRecordReader() - Constructor for class org.apache.hadoop.hbase.mapred.TableRecordReader
 
TableRecordReader - Class in org.apache.hadoop.hbase.mapreduce
Iterate over an HBase table data, return (ImmutableBytesWritable, Result) pairs.
TableRecordReader() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableRecordReader
 
TableRecordReaderImpl - Class in org.apache.hadoop.hbase.mapred
Iterate over an HBase table data, return (Text, RowResult) pairs
TableRecordReaderImpl() - Constructor for class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
 
TableRecordReaderImpl - Class in org.apache.hadoop.hbase.mapreduce
Iterate over an HBase table data, return (ImmutableBytesWritable, Result) pairs.
TableRecordReaderImpl() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
 
TableReduce<K extends org.apache.hadoop.io.WritableComparable,V> - Interface in org.apache.hadoop.hbase.mapred
Write a table, sorting by the input key
TableReducer<KEYIN,VALUEIN,KEYOUT> - Class in org.apache.hadoop.hbase.mapreduce
Extends the basic Reducer class to add the required key and value input/output classes.
TableReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableReducer
 
TABLES_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.WALPlayer
 
tableSeparator - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
 
tableSeparator - Static variable in class org.apache.hadoop.hbase.mapreduce.WALPlayer
 
TableSnapshotInputFormat - Class in org.apache.hadoop.hbase.mapred
TableSnapshotInputFormat allows a MapReduce job to run over a table snapshot.
TableSnapshotInputFormat() - Constructor for class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat
 
TableSnapshotInputFormat - Class in org.apache.hadoop.hbase.mapreduce
TableSnapshotInputFormat allows a MapReduce job to run over a table snapshot.
TableSnapshotInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat
 
TableSplit - Class in org.apache.hadoop.hbase.mapred
A table split corresponds to a key range [low, high)
TableSplit() - Constructor for class org.apache.hadoop.hbase.mapred.TableSplit
default constructor
TableSplit(TableName, byte[], byte[], String) - Constructor for class org.apache.hadoop.hbase.mapred.TableSplit
Constructor
TableSplit(byte[], byte[], byte[], String) - Constructor for class org.apache.hadoop.hbase.mapred.TableSplit
 
TableSplit - Class in org.apache.hadoop.hbase.mapreduce
A table split corresponds to a key range (low, high) and an optional scanner.
TableSplit() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSplit
Default constructor.
TableSplit(TableName, Scan, byte[], byte[], String) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSplit
Creates a new instance while assigning all variables.
TableSplit(TableName, Scan, byte[], byte[], String, long) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSplit
Creates a new instance while assigning all variables.
TableSplit(TableName, Scan, byte[], byte[], String, String, long) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSplit
Creates a new instance while assigning all variables.
TableSplit(TableName, byte[], byte[], String) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSplit
Creates a new instance without a scanner.
TableSplit(TableName, byte[], byte[], String, long) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSplit
Creates a new instance without a scanner.
tail(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Make a new byte array from a subset of bytes at the tail of another.
targetReplicaId - Variable in class org.apache.hadoop.hbase.client.Query
 
TASK_COMPLETION_STRING - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
 
TASK_ERROR_STRING - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
 
TB_IN_BYTES - Static variable in class org.apache.hadoop.hbase.HConstants
 
TEMP_DIR_NAME - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
TEMPORARY_FS_DIRECTORY_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Config key for hbase temporary directory in hdfs
term - Variable in class org.apache.hadoop.hbase.types.TerminatedWrapper
 
terminate() - Method in interface org.apache.hadoop.hbase.client.AdvancedScanResultConsumer.ScanController
Terminate the scan.
TerminatedWrapper<T> - Class in org.apache.hadoop.hbase.types
Wraps an existing DataType implementation as a terminated version of itself.
TerminatedWrapper(DataType<T>, byte[]) - Constructor for class org.apache.hadoop.hbase.types.TerminatedWrapper
Create a terminated version of the wrapped.
TerminatedWrapper(DataType<T>, String) - Constructor for class org.apache.hadoop.hbase.types.TerminatedWrapper
Create a terminated version of the wrapped.
terminatorPosition(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
Return the position at which term begins within src, or -1 if term is not found.
TestingHBaseCluster - Interface in org.apache.hadoop.hbase.testing
A mini hbase cluster used for testing.
TestingHBaseClusterOption - Class in org.apache.hadoop.hbase.testing
Options for starting up a mini testing cluster TestingHBaseCluster (including an hbase, dfs and zookeeper clusters) in test.
TextSortReducer - Class in org.apache.hadoop.hbase.mapreduce
Emits Sorted KeyValues.
TextSortReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.TextSortReducer
 
THREAD_WAKE_FREQUENCY - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for how often threads should wake up
throttleNamespace(String, ThrottleType, long, TimeUnit) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Throttle the specified namespace.
throttleNamespace(String, ThrottleType, long, TimeUnit, QuotaScope) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Throttle the specified namespace.
throttleRegionServer(String, ThrottleType, long, TimeUnit) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Throttle the specified region server.
throttleTable(TableName, ThrottleType, long, TimeUnit) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Throttle the specified table.
throttleTable(TableName, ThrottleType, long, TimeUnit, QuotaScope) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Throttle the specified table.
ThrottleType - Enum in org.apache.hadoop.hbase.quotas
Describe the Throttle Type.
throttleUser(String, ThrottleType, long, TimeUnit) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Throttle the specified user.
throttleUser(String, ThrottleType, long, TimeUnit, QuotaScope) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Throttle the specified user.
throttleUser(String, TableName, ThrottleType, long, TimeUnit) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Throttle the specified user on the specified table.
throttleUser(String, TableName, ThrottleType, long, TimeUnit, QuotaScope) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Throttle the specified user on the specified table.
throttleUser(String, String, ThrottleType, long, TimeUnit) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Throttle the specified user on the specified namespace.
throttleUser(String, String, ThrottleType, long, TimeUnit, QuotaScope) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Throttle the specified user on the specified namespace.
throwNumReadRequestsExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
 
throwNumRequestsExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
 
throwNumWriteRequestsExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
 
throwReadCapacityUnitExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
 
throwReadSizeExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
 
throwRequestCapacityUnitExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
 
throwRequestSizeExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
 
throwWriteCapacityUnitExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
 
throwWriteSizeExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
 
timeFromString(String) - Static method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
 
TimeoutException - Exception in org.apache.hadoop.hbase.errorhandling
Exception for timeout of a task.
TimeoutException(String, long, long, long) - Constructor for exception org.apache.hadoop.hbase.errorhandling.TimeoutException
Exception indicating that an operation attempt has timed out
timeRange(TimeRange) - Method in class org.apache.hadoop.hbase.client.CheckAndMutate.Builder
Specify a timerange
TimeRange - Class in org.apache.hadoop.hbase.io
Represents an interval of version timestamps.
TIMESTAMP_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
TimestampsFilter - Class in org.apache.hadoop.hbase.filter
Filter that returns only cells whose timestamp (version) is in the specified list of timestamps (versions).
TimestampsFilter(List<Long>) - Constructor for class org.apache.hadoop.hbase.filter.TimestampsFilter
Constructor for filter that retains only the specified timestamps in the list.
TimestampsFilter(List<Long>, boolean) - Constructor for class org.apache.hadoop.hbase.filter.TimestampsFilter
Constructor for filter that retains only those cells whose timestamp (version) is in the specified list of timestamps.
timeToString(TimeUnit) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettings
 
toArray(List<byte[]>) - Static method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
Convert a list of byte arrays into an array of byte arrays
toArray(List<byte[]>) - Static method in class org.apache.hadoop.hbase.util.Bytes
Convert a list of byte[] to an array
toAsyncConnection() - Method in interface org.apache.hadoop.hbase.client.Connection
Convert this connection to an AsyncConnection.
toBigDecimal(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to a BigDecimal
toBigDecimal(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to a BigDecimal value
toBinaryByteArrays(String[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Create an array of byte[] given an array of String.
toBinaryFromHex(byte) - Static method in class org.apache.hadoop.hbase.util.Bytes
Takes a ASCII digit in the range A-F0-9 and returns the corresponding integer/ordinal value.
toBoolean(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
toByte() - Method in enum org.apache.hadoop.hbase.client.IsolationLevel
 
toByteArray(ColumnFamilyDescriptor) - Static method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Serialize the table descriptor to a byte array.
toByteArray(RegionInfo) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
Returns This instance serialized as protobuf w/ a magic pb prefix.
toByteArray(TableDescriptor) - Static method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Returns This instance serialized with pb with pb magic prefix
toByteArray() - Method in class org.apache.hadoop.hbase.filter.BigDecimalComparator
Returns The comparator serialized using pb
toByteArray() - Method in class org.apache.hadoop.hbase.filter.BinaryComparator
Returns The comparator serialized using pb
toByteArray() - Method in class org.apache.hadoop.hbase.filter.BinaryComponentComparator
Returns The comparator serialized using pb
toByteArray() - Method in class org.apache.hadoop.hbase.filter.BinaryPrefixComparator
Returns The comparator serialized using pb
toByteArray() - Method in class org.apache.hadoop.hbase.filter.BitComparator
Returns The comparator serialized using pb
toByteArray() - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
Returns The comparator serialized using pb
toByteArray() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
Returns The filter serialized using pb
toByteArray() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
Returns The filter serialized using pb
toByteArray() - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
Returns The filter serialized using pb
toByteArray() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
Returns The filter serialized using pb
toByteArray() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
Returns The filter serialized using pb
toByteArray() - Method in class org.apache.hadoop.hbase.filter.FamilyFilter
Returns The filter serialized using pb
toByteArray() - Method in class org.apache.hadoop.hbase.filter.Filter
TODO: JAVADOC Concrete implementers can signal a failure condition in their code by throwing an IOException.
toByteArray() - Method in class org.apache.hadoop.hbase.filter.FilterList
Returns The filter serialized using pb
toByteArray() - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
Returns The filter serialized using pb
toByteArray() - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
Returns The filter serialized using pb
toByteArray() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
Returns The filter serialized using pb
toByteArray() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
Returns The filter serialized using pb
toByteArray() - Method in class org.apache.hadoop.hbase.filter.LongComparator
Returns The comparator serialized using pb
toByteArray() - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
Returns The filter serialized using pb
toByteArray() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
Returns The filter serialized using pb
toByteArray() - Method in class org.apache.hadoop.hbase.filter.NullComparator
Returns The comparator serialized using pb
toByteArray() - Method in class org.apache.hadoop.hbase.filter.PageFilter
Returns The filter serialized using pb
toByteArray() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
Returns The filter serialized using pb
toByteArray() - Method in class org.apache.hadoop.hbase.filter.QualifierFilter
Returns The filter serialized using pb
toByteArray() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
Returns The filter serialized using pb
toByteArray() - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator
Returns The comparator serialized using pb
toByteArray() - Method in class org.apache.hadoop.hbase.filter.RowFilter
Returns The filter serialized using pb
toByteArray() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
Returns The filter serialized using pb
toByteArray() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Returns The filter serialized using pb
toByteArray() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
Returns The filter serialized using pb
toByteArray() - Method in class org.apache.hadoop.hbase.filter.SubstringComparator
Returns The comparator serialized using pb
toByteArray() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
Returns The filter serialized using pb
toByteArray() - Method in class org.apache.hadoop.hbase.filter.ValueFilter
Returns The filter serialized using pb
toByteArray() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
Returns The filter serialized using pb
toByteArray(int, int) - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
toByteArray(SyncReplicationState) - Static method in enum org.apache.hadoop.hbase.replication.SyncReplicationState
 
toByteArray(SyncReplicationState, SyncReplicationState) - Static method in enum org.apache.hadoop.hbase.replication.SyncReplicationState
 
toByteArrays(String[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Create an array of byte[] given an array of String.
toByteArrays(String) - Static method in class org.apache.hadoop.hbase.util.Bytes
Create a byte[][] where first and only entry is column
toByteArrays(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Create a byte[][] where first and only entry is column
toBytes() - Method in enum org.apache.hadoop.hbase.client.IsolationLevel
 
toBytes() - Method in class org.apache.hadoop.hbase.TableName
Returns A pointer to TableName as String bytes.
toBytes(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.Bytes
Returns a new byte array, copied from the given buf, from the index 0 (inclusive) to the limit (exclusive), regardless of the current position.
toBytes(String) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a string to a UTF-8 byte array.
toBytes(boolean) - Static method in class org.apache.hadoop.hbase.util.Bytes
Convert a boolean to a byte array.
toBytes(long) - Static method in class org.apache.hadoop.hbase.util.Bytes
Convert a long value to a byte array using big-endian.
toBytes(float) - Static method in class org.apache.hadoop.hbase.util.Bytes
Return the float represented as byte[]
toBytes(double) - Static method in class org.apache.hadoop.hbase.util.Bytes
Serialize a double as the IEEE 754 double format output.
toBytes(int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Convert an int value to a byte array.
toBytes(short) - Static method in class org.apache.hadoop.hbase.util.Bytes
Convert a short value to a byte array of Bytes.SIZEOF_SHORT bytes long.
toBytes(BigDecimal) - Static method in class org.apache.hadoop.hbase.util.Bytes
Convert a BigDecimal value to a byte array
toBytesBinary(String) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
toConnection() - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
Convert this connection to a Connection.
toDelimitedByteArray(RegionInfo...) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
Serializes given RegionInfo's as a byte array.
toDelimitedByteArray(RegionInfo) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
Use this instead of RegionInfo.toByteArray(RegionInfo) when writing to a stream and you want to use the pb mergeDelimitedFrom (w/o the delimiter, pb reads to EOF which may not be what you want).
toDouble(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Return double made from passed bytes.
toDouble(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Return double made from passed bytes.
toFloat(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Put a float value out to the specified byte array position.
toFloat(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Put a float value out to the specified byte array position.
toGroupEntry(String) - Static method in class org.apache.hadoop.hbase.AuthUtil
Deprecated.
Returns the group entry with the group prefix for a group principal.
toHex(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Convert a byte range into a hex string
toHex(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Convert a byte array into a hex string
toInt(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to an int value
toInt(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to an int value
toInt(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to an int value
toJSON(int) - Method in class org.apache.hadoop.hbase.client.Operation
Produces a JSON object for fingerprint and details exposure in a parseable format.
toJSON() - Method in class org.apache.hadoop.hbase.client.Operation
Produces a JSON object sufficient for description of a query in a debugging or logging context.
toJsonPrettyPrint() - Method in class org.apache.hadoop.hbase.client.BalancerDecision
 
toJsonPrettyPrint() - Method in class org.apache.hadoop.hbase.client.BalancerRejection
 
toJsonPrettyPrint() - Method in class org.apache.hadoop.hbase.client.LogEntry
Based on response sent by server, provide pretty printed Json representation in string
toJsonPrettyPrint() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
 
toLong(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to a long value.
toLong(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to a long value.
toLong(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to a long value.
toMap(int) - Method in class org.apache.hadoop.hbase.client.Get
Compile the details beyond the scope of getFingerprint (row, columns, timestamps, etc.) into a Map along with the fingerprinted information.
toMap(int) - Method in class org.apache.hadoop.hbase.client.Mutation
Compile the details beyond the scope of getFingerprint (row, columns, timestamps, etc.) into a Map along with the fingerprinted information.
toMap(int) - Method in class org.apache.hadoop.hbase.client.Operation
Produces a Map containing a summary of the details of a query beyond the scope of the fingerprint (i.e.
toMap() - Method in class org.apache.hadoop.hbase.client.Operation
Produces a Map containing a full summary of a query.
toMap(int) - Method in class org.apache.hadoop.hbase.client.Scan
Compile the details beyond the scope of getFingerprint (row, columns, timestamps, etc.) into a Map along with the fingerprinted information.
TOOLS - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
Denotes classes used as tools (Used from cmd line).
toShort(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to a short value
toShort(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to a short value
toShort(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to a short value
toShortString() - Method in class org.apache.hadoop.hbase.ServerName
Return a SHORT version of ServerName.toString(), one that has the host only, minus the domain, and the port only -- no start code; the String is for us internally mostly tying threads to their server.
toSocketAddress(Address) - Static method in class org.apache.hadoop.hbase.net.Address
 
toSocketAddress(Address[]) - Static method in class org.apache.hadoop.hbase.net.Address
 
toString() - Method in class org.apache.hadoop.hbase.CacheEvictionStats
 
toString(Cell, boolean) - Static method in class org.apache.hadoop.hbase.CellUtil
Returns a string representation of the cell
toString() - Method in class org.apache.hadoop.hbase.client.BalancerDecision
 
toString() - Method in class org.apache.hadoop.hbase.client.BalancerRejection
 
toString() - Method in class org.apache.hadoop.hbase.client.Increment
 
toString() - Method in class org.apache.hadoop.hbase.client.locking.EntityLock
 
toString() - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
Deprecated.
 
toString() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
 
toString(int) - Method in class org.apache.hadoop.hbase.client.Operation
Produces a string representation of this Operation.
toString() - Method in class org.apache.hadoop.hbase.client.Operation
Produces a string representation of this Operation.
toString() - Method in class org.apache.hadoop.hbase.client.replication.TableCFs
 
toString() - Method in class org.apache.hadoop.hbase.client.Result
 
toString() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
 
toString() - Method in exception org.apache.hadoop.hbase.errorhandling.ForeignException
 
toString() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.FilterList
 
toString() - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
toString(int) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
 
toString(int) - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
toString() - Method in class org.apache.hadoop.hbase.HRegionLocation
 
toString() - Method in class org.apache.hadoop.hbase.io.crypto.Context
 
toString() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
toString() - Method in class org.apache.hadoop.hbase.io.TimeRange
 
toString() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
toString() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Returns the details about this instance as a string.
toString() - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
 
toString() - Method in class org.apache.hadoop.hbase.net.Address
 
toString() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
toString() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerDescription
 
toString() - Method in class org.apache.hadoop.hbase.rest.client.Cluster
 
toString() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
 
toString() - Method in class org.apache.hadoop.hbase.security.User
 
toString() - Method in class org.apache.hadoop.hbase.ServerName
 
toString() - Method in class org.apache.hadoop.hbase.Size
 
toString() - Method in class org.apache.hadoop.hbase.StartMiniClusterOption
Deprecated.
 
toString() - Method in class org.apache.hadoop.hbase.TableName
 
toString() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
 
toString() - Method in class org.apache.hadoop.hbase.util.Bytes
 
toString(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Convert a byte[] into a string.
toString(byte[], String, byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Joins two byte arrays together using a separator.
toString(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
This method will convert utf8 encoded bytes into a string.
toString(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
This method will convert utf8 encoded bytes into a string.
toString() - Method in class org.apache.hadoop.hbase.util.Pair
 
toString() - Method in class org.apache.hadoop.hbase.util.PairOfSameType
 
toStringBinary(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Write a printable representation of a byte array.
toStringBinary(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts the given byte buffer to a printable representation, from the index 0 (inclusive) to the limit (exclusive), regardless of the current position.
toStringBinary(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Write a printable representation of a byte array.
toStringCustomizedValues() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
Returns Column family descriptor with only the customized attributes.
toStringCustomizedValues() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
Returns Name of this table and then a map of all of the column family descriptors (with only the non-default column family attributes)
toStringWithoutDomain() - Method in class org.apache.hadoop.hbase.net.Address
If hostname is a.b.c and the port is 123, return a:123 instead of a.b.c:123.
toStruct() - Method in class org.apache.hadoop.hbase.types.StructBuilder
Retrieve the Struct represented by this.
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.Filter
Give the filter a chance to transform the passed KeyValue.
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
transitReplicationPeerSyncReplicationState(String, SyncReplicationState) - Method in interface org.apache.hadoop.hbase.client.Admin
Transit current cluster to a new state in a synchronous replication peer.
transitReplicationPeerSyncReplicationState(String, SyncReplicationState) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Transit current cluster to a new state in a synchronous replication peer.
transitReplicationPeerSyncReplicationStateAsync(String, SyncReplicationState) - Method in interface org.apache.hadoop.hbase.client.Admin
Transit current cluster to a new state in a synchronous replication peer.
truncateRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Truncate an individual region.
truncateRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Truncate an individual region.
truncateRegionAsync(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Truncate an individual region.
truncateTable(TableName, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Truncate a table.
truncateTable(TableName, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Truncate a table.
truncateTable(TableName, boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Truncate a table using the admin command.
truncateTable(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Truncate a table using the admin command.
truncateTableAsync(TableName, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Truncate the table but does not block and wait for it to be completely enabled.
ts - Variable in class org.apache.hadoop.hbase.client.Mutation
 
ts - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
Timestamp for all inserted rows
TsvImporterMapper - Class in org.apache.hadoop.hbase.mapreduce
Write table content out to files in hdfs.
TsvImporterMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
 
TsvImporterTextMapper - Class in org.apache.hadoop.hbase.mapreduce
Write table content out to map output files.
TsvImporterTextMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
 
TTL - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
ttl - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
 
typeA - Variable in class org.apache.hadoop.hbase.types.Union2
 
typeB - Variable in class org.apache.hadoop.hbase.types.Union2
 
typeC - Variable in class org.apache.hadoop.hbase.types.Union3
 
typeD - Variable in class org.apache.hadoop.hbase.types.Union4
 
types - Variable in class org.apache.hadoop.hbase.types.StructIterator
 

U

ugi - Variable in class org.apache.hadoop.hbase.security.User
 
unassign(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Unassign a Region.
unassign(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.4.0 and will be removed in 4.0.0. Use Admin.unassign(byte[]) instead.
unassign(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Unassign a region from current hosting regionserver.
unassign(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Deprecated.
since 2.4.0 and will be removed in 4.0.0. Use AsyncAdmin.unassign(byte[]) instead.
unassignRegion(String) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Unassign the named region.
unassignRegion(byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Unassign the named region.
unassignRegionByRow(String, RegionLocator) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Closes the region containing the given row.
unassignRegionByRow(byte[], RegionLocator) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Closes the region containing the given row.
Union2<A,B> - Class in org.apache.hadoop.hbase.types
The Union family of DataTypes encode one of a fixed set of Objects.
Union2(DataType<A>, DataType<B>) - Constructor for class org.apache.hadoop.hbase.types.Union2
Create an instance of Union2 over the set of specified types.
Union3<A,B,C> - Class in org.apache.hadoop.hbase.types
The Union family of DataTypes encode one of a fixed collection of Objects.
Union3(DataType<A>, DataType<B>, DataType<C>) - Constructor for class org.apache.hadoop.hbase.types.Union3
Create an instance of Union3 over the set of specified types.
Union4<A,B,C,D> - Class in org.apache.hadoop.hbase.types
The Union family of DataTypes encode one of a fixed collection of Objects.
Union4(DataType<A>, DataType<B>, DataType<C>, DataType<D>) - Constructor for class org.apache.hadoop.hbase.types.Union4
Create an instance of Union4 over the set of specified types.
UNITTEST - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
 
UNKNOWN_SERVERNAME - Static variable in class org.apache.hadoop.hbase.ServerName
What to use if server name is unknown.
UnknownProtocolException - Exception in org.apache.hadoop.hbase.exceptions
An error requesting an RPC protocol that the server is not serving.
UnknownProtocolException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.UnknownProtocolException
 
UnknownProtocolException(Class<?>) - Constructor for exception org.apache.hadoop.hbase.exceptions.UnknownProtocolException
 
UnknownProtocolException(Class<?>, String) - Constructor for exception org.apache.hadoop.hbase.exceptions.UnknownProtocolException
 
UnknownRegionException - Exception in org.apache.hadoop.hbase
Thrown when we are asked to operate on a region we know nothing about.
UnknownRegionException(String) - Constructor for exception org.apache.hadoop.hbase.UnknownRegionException
Constructs a new UnknownRegionException with the specified detail message.
UnknownRegionException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.UnknownRegionException
Constructs a new UnknownRegionException with the specified detail message and cause.
UnknownScannerException - Exception in org.apache.hadoop.hbase
Thrown if a region server is passed an unknown scanner ID.
UnknownScannerException() - Constructor for exception org.apache.hadoop.hbase.UnknownScannerException
 
UnknownScannerException(String) - Constructor for exception org.apache.hadoop.hbase.UnknownScannerException
 
UnknownScannerException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.UnknownScannerException
 
UnknownSnapshotException - Exception in org.apache.hadoop.hbase.snapshot
Exception thrown when we get a request for a snapshot we don't recognize.
UnknownSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.UnknownSnapshotException
 
UnknownSnapshotException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.snapshot.UnknownSnapshotException
 
unload() - Method in class org.apache.hadoop.hbase.util.RegionMover
Unload regions from given RegionMover.hostname using ack/noAck mode and RegionMover.maxthreads.In noAck mode we do not make sure that region is successfully online on the target region server,hence it is best effort.We do not unload regions to hostnames given in RegionMover.excludeFile.
unloadFromRack() - Method in class org.apache.hadoop.hbase.util.RegionMover
Unload regions from given RegionMover.hostname using ack/noAck mode and RegionMover.maxthreads.In noAck mode we do not make sure that region is successfully online on the target region server,hence it is best effort.We do not unload regions to hostnames given in RegionMover.excludeFile.
unlock() - Method in class org.apache.hadoop.hbase.client.locking.EntityLock
 
unset() - Method in interface org.apache.hadoop.hbase.util.ByteRange
Nullifies this ByteRange.
unset() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
 
unset() - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
 
unset() - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
 
unset() - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
unset() - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
unsignedBinarySearch(byte[], int, int, byte) - Static method in class org.apache.hadoop.hbase.util.Bytes
Search sorted array "a" for byte "key".
unsignedCopyAndIncrement(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Treat the byte[] as an unsigned series of bytes, most significant bits first.
UnsupportedCellCodecException - Exception in org.apache.hadoop.hbase.ipc
 
UnsupportedCellCodecException() - Constructor for exception org.apache.hadoop.hbase.ipc.UnsupportedCellCodecException
 
UnsupportedCellCodecException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.UnsupportedCellCodecException
 
UnsupportedCellCodecException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.ipc.UnsupportedCellCodecException
 
UnsupportedCompressionCodecException - Exception in org.apache.hadoop.hbase.ipc
 
UnsupportedCompressionCodecException() - Constructor for exception org.apache.hadoop.hbase.ipc.UnsupportedCompressionCodecException
 
UnsupportedCompressionCodecException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.UnsupportedCompressionCodecException
 
UnsupportedCompressionCodecException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.ipc.UnsupportedCompressionCodecException
 
UnsupportedCryptoException - Exception in org.apache.hadoop.hbase.ipc
 
UnsupportedCryptoException() - Constructor for exception org.apache.hadoop.hbase.ipc.UnsupportedCryptoException
 
UnsupportedCryptoException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.UnsupportedCryptoException
 
UnsupportedCryptoException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.ipc.UnsupportedCryptoException
 
unthrottleNamespace(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Remove the throttling for the specified namespace.
unthrottleNamespaceByThrottleType(String, ThrottleType) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Remove the throttling for the specified namespace by throttle type.
unthrottleRegionServer(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Remove the throttling for the specified region server.
unthrottleRegionServerByThrottleType(String, ThrottleType) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Remove the throttling for the specified region server by throttle type.
unthrottleTable(TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Remove the throttling for the specified table.
unthrottleTableByThrottleType(TableName, ThrottleType) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Remove the throttling for the specified table.
unthrottleUser(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Remove the throttling for the specified user.
unthrottleUser(String, TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Remove the throttling for the specified user on the specified table.
unthrottleUser(String, String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Remove the throttling for the specified user on the specified namespace.
unthrottleUserByThrottleType(String, ThrottleType) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Remove the throttling for the specified user.
unthrottleUserByThrottleType(String, TableName, ThrottleType) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Remove the throttling for the specified user on the specified table.
unthrottleUserByThrottleType(String, String, ThrottleType) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Remove the throttling for the specified user on the specified namespace.
until(long) - Static method in class org.apache.hadoop.hbase.io.TimeRange
Represents the time interval [0, maxStamp)
unwrapRemoteException() - Method in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
 
updateConfiguration(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
Update the configuration and trigger an online config change on the regionserver.
updateConfiguration() - Method in interface org.apache.hadoop.hbase.client.Admin
Update the configuration and trigger an online config change on all the regionservers.
updateConfiguration(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Update the configuration and trigger an online config change on all the regionservers in the RSGroup.
updateConfiguration(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Update the configuration and trigger an online config change on the regionserver.
updateConfiguration() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Update the configuration and trigger an online config change on all the masters and regionservers.
updateConfiguration(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Update the configuration and trigger an online config change on all the regionservers in the RSGroup.
updateCounters(ScanMetrics, long, Method, TaskAttemptContext, long) - Static method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
Deprecated.
since 2.4.0 and 2.3.2, will be removed in 4.0.0 Use TableRecordReaderImpl.updateCounters(ScanMetrics, long, TaskAttemptContext, long) instead.
updateCounters(ScanMetrics, long, TaskAttemptContext, long) - Static method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
 
updateReplicationPeerConfig(String, ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.client.Admin
Update the peerConfig for the specified peer.
updateReplicationPeerConfig(String, ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Update the peerConfig for the specified peer
updateReplicationPeerConfigAsync(String, ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.client.Admin
Update the peerConfig for the specified peer but does not block and wait for it.
updateRSGroupConfig(String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.client.Admin
Update RSGroup configuration
updateRSGroupConfig(String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Update RSGroup configuration
USE_META_REPLICAS - Static variable in class org.apache.hadoop.hbase.HConstants
Conf key for enabling meta replication
User - Class in org.apache.hadoop.hbase.security
Wrapper to abstract out usage of user and group information in HBase.
User() - Constructor for class org.apache.hadoop.hbase.security.User
 
UserMetrics - Interface in org.apache.hadoop.hbase
Encapsulates per-user load metrics.
UTF8 - Static variable in class org.apache.hadoop.hbase.util.OrderedBytes
 
UTF8_CHARSET - Static variable in class org.apache.hadoop.hbase.HConstants
When we encode strings, we always specify UTF8 encoding
UTF8_ENCODING - Static variable in class org.apache.hadoop.hbase.HConstants
When we encode strings, we always specify UTF8 encoding

V

VALID_NAMESPACE_REGEX - Static variable in class org.apache.hadoop.hbase.TableName
 
VALID_TABLE_QUALIFIER_REGEX - Static variable in class org.apache.hadoop.hbase.TableName
 
VALID_USER_TABLE_REGEX - Static variable in class org.apache.hadoop.hbase.TableName
 
validateInput(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormat
 
value() - Method in class org.apache.hadoop.hbase.client.Result
Returns the value of the first column in the Result.
value() - Method in enum org.apache.hadoop.hbase.replication.SyncReplicationState
 
ValueFilter - Class in org.apache.hadoop.hbase.filter
This filter is used to filter based on column value.
ValueFilter(CompareOperator, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.ValueFilter
Constructor.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.CellBuilderType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.CompactionState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.CompactType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.Consistency
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.Durability
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.IsolationLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.MasterSwitchType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.MobCompactPartitionPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.RequestController.ReturnCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.Scan.ReadType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.security.SecurityCapability
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.hadoop.hbase.client.security.SecurityCapability
 
valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.ServerType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.SnapshotType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.CompareOperator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.filter.BitComparator.BitwiseOp
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.filter.Filter.ReturnCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.filter.FilterList.Operator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.filter.RegexStringComparator.EngineType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.io.encoding.IndexBlockEncoding
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.KeepDeletedCells
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.MemoryCompactionPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.quotas.QuotaScope
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.quotas.QuotaType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.quotas.RpcThrottlingException.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.quotas.SpaceViolationPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.quotas.ThrottleType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.BloomType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.replication.SyncReplicationState
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.hadoop.hbase.replication.SyncReplicationState
 
valueOf(String, int, long) - Static method in class org.apache.hadoop.hbase.ServerName
Retrieve an instance of ServerName.
valueOf(String) - Static method in class org.apache.hadoop.hbase.ServerName
Retrieve an instance of ServerName.
valueOf(String, long) - Static method in class org.apache.hadoop.hbase.ServerName
Retrieve an instance of ServerName.
valueOf(Address, long) - Static method in class org.apache.hadoop.hbase.ServerName
Retrieve an instance of ServerName.
valueOf(String, String) - Static method in class org.apache.hadoop.hbase.TableName
 
valueOf(byte[]) - Static method in class org.apache.hadoop.hbase.TableName
Construct a TableName
valueOf(byte[], int, int) - Static method in class org.apache.hadoop.hbase.TableName
Construct a TableName
valueOf(ByteBuffer) - Static method in class org.apache.hadoop.hbase.TableName
Construct a TableName
valueOf(String) - Static method in class org.apache.hadoop.hbase.TableName
Construct a TableName
valueOf(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.TableName
 
valueOf(ByteBuffer, ByteBuffer) - Static method in class org.apache.hadoop.hbase.TableName
 
valueOf(String) - Static method in enum org.apache.hadoop.hbase.util.Order
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.hadoop.hbase.CellBuilderType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.client.CompactionState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.client.CompactType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.client.Consistency
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.client.Durability
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.client.IsolationLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.client.MasterSwitchType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.client.MobCompactPartitionPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.client.RequestController.ReturnCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.client.Scan.ReadType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.client.security.SecurityCapability
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.client.ServerType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.client.SnapshotType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.CompareOperator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.filter.BitComparator.BitwiseOp
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.filter.Filter.ReturnCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.filter.FilterList.Operator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.filter.RegexStringComparator.EngineType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.io.encoding.IndexBlockEncoding
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.KeepDeletedCells
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.MemoryCompactionPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.quotas.QuotaScope
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.quotas.QuotaType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.quotas.RpcThrottlingException.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.quotas.SpaceViolationPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.quotas.ThrottleType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.regionserver.BloomType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.replication.SyncReplicationState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.util.Order
Returns an array containing the constants of this enum type, in the order they are declared.
verifyNumericRows(Table, byte[], int, int, int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
verifyNumericRows(Region, byte[], int, int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
verifyNumericRows(HRegion, byte[], int, int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
verifyNumericRows(Region, byte[], int, int, boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
verifyNumericRows(HRegion, byte[], int, int, boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
verifyTableDescriptorIgnoreTableName(TableDescriptor, TableDescriptor) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
VERSION_FILE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
name of version file
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
VERSION_STRING - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
VersionInfo - Class in org.apache.hadoop.hbase.util
This class finds the Version information for HBase.
VersionInfo() - Constructor for class org.apache.hadoop.hbase.util.VersionInfo
 
VERSIONS - Static variable in class org.apache.hadoop.hbase.HConstants
 
vintToBytes(long) - Static method in class org.apache.hadoop.hbase.util.Bytes
Encode a long value as a variable length integer.
VISIBILITY_EXP_RESOLVER_CLASS - Static variable in class org.apache.hadoop.hbase.mapreduce.CellCreator
 
VisibilityExpressionResolver - Interface in org.apache.hadoop.hbase.mapreduce
Interface to convert visibility expressions into Tags for storing along with Cells in HFiles.

W

W - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'W'
waitFor(long, <any>) - Method in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
Deprecated.
Wrapper method for Waiter#waitFor(Configuration, long, Predicate).
waitFor(long, long, <any>) - Method in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
Deprecated.
Wrapper method for Waiter#waitFor(Configuration, long, long, Predicate).
waitFor(long, long, boolean, <any>) - Method in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
Deprecated.
Wrapper method for Waiter#waitFor(Configuration, long, long, boolean, Predicate).
waitForActiveAndReadyMaster() - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
Blocks until there is an active master and that master has completed initialization.
waitForActiveAndReadyMaster(long) - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
Blocks until there is an active master and that master has completed initialization.
waitForActiveAndReadyMaster(long) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
Blocks until there is an active master and that master has completed initialization.
waitForDatanodesRegistered(int) - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
 
waitForDataNodeToStart(ServerName, long) - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
Wait for the specified datanode to join the cluster
waitForDataNodeToStart(ServerName, long) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
 
waitForDataNodeToStop(ServerName, long) - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
Wait for the specified datanode to stop the thread / process.
waitForDataNodeToStop(ServerName, long) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
 
waitForFreeSlot(long, int, Consumer<Long>) - Method in interface org.apache.hadoop.hbase.client.RequestController
Wait until there is at least one slot for a new task.
waitForHostPort(String, int) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
waitForMasterToStop(ServerName, long) - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
Wait for the specified master to stop the thread / process.
waitForMasterToStop(ServerName, long) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
 
waitForMaximumCurrentTasks(long, long, int, Consumer<Long>) - Method in interface org.apache.hadoop.hbase.client.RequestController
Waits for the running tasks to complete.
waitForNamenodeAvailable() - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
Wait for the namenode.
waitForNameNodeToStart(ServerName, long) - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
Wait for the specified namenode to join the cluster
waitForNameNodeToStart(ServerName, long) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
 
waitForNameNodeToStop(ServerName, long) - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
Wait for the specified namenode to stop
waitForNameNodeToStop(ServerName, long) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
 
waitForRegionServerToStart(String, int, long) - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
Wait for the specified region server to join the cluster
waitForRegionServerToStop(ServerName, long) - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
Wait for the specified region server to stop the thread / process.
waitForRegionServerToStop(ServerName, long) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
 
waitForZkNodeToStart(ServerName, long) - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
Wait for the specified zookeeper node to join the cluster
waitForZkNodeToStart(ServerName, long) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
 
waitForZkNodeToStop(ServerName, long) - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
Wait for the specified zookeeper node to stop the thread / process.
waitForZkNodeToStop(ServerName, long) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
 
waitLabelAvailable(long, String...) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Wait until labels is ready in VisibilityLabelsCache.
waitOnMaster(int) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
Wait for the specified master to stop.
waitOnRegionServer(int) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
Wait for the specified region server to stop.
waitTableAvailable(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Wait until all regions in a table have been assigned.
waitTableAvailable(TableName, long) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
waitTableAvailable(byte[], long) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Wait until all regions in a table have been assigned
waitTableDisabled(byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Waits for a table to be 'disabled'.
waitTableDisabled(TableName, long) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
waitTableDisabled(byte[], long) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Waits for a table to be 'disabled'.
waitTableEnabled(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Waits for a table to be 'enabled'.
waitTableEnabled(byte[], long) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Waits for a table to be 'enabled'.
waitTableEnabled(TableName, long) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
 
waitUntilAllRegionsAssigned(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Wait until all regions for a table in hbase:meta have a non-empty info:server, up to a configuable timeout value (default is 60 seconds) This means all regions have been deployed, master has been informed and updated hbase:meta with the regions deployed server.
waitUntilAllRegionsAssigned(TableName, long) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Wait until all regions for a table in hbase:meta have a non-empty info:server, or until timeout.
waitUntilAllSystemRegionsAssigned() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Waith until all system table's regions get assigned
waitUntilNoRegionsInTransition(long) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Wait until no regions in transition.
waitUntilNoRegionsInTransition() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
Wait until no regions in transition.
waitUntilShutDown() - Method in class org.apache.hadoop.hbase.HBaseCluster
Deprecated.
Wait for HBase Cluster to shut down.
waitUntilShutDown() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
 
WAL_DURABILITY - Static variable in class org.apache.hadoop.hbase.mapreduce.Import
 
WAL_OFF - Static variable in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
Property value to disable write-ahead logging
WAL_ON - Static variable in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
Property value to use write-ahead logging
WAL_PROPERTY - Static variable in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
Set this to MultiTableOutputFormat.WAL_OFF to turn off write-ahead logging (WAL)
WAL_STORAGE_POLICY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration name of WAL storage policy Valid values are: HOT, COLD, WARM, ALL_SSD, ONE_SSD, LAZY_PERSIST See http://hadoop.apache.org/docs/r2.7.3/hadoop-project-dist/hadoop-hdfs/ArchivalStorage.html
WALInputFormat - Class in org.apache.hadoop.hbase.mapreduce
Simple InputFormat for WAL files.
WALInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.WALInputFormat
 
WALPlayer - Class in org.apache.hadoop.hbase.mapreduce
A tool to replay WAL files as a M/R job.
WALPlayer() - Constructor for class org.apache.hadoop.hbase.mapreduce.WALPlayer
 
WALPlayer(Configuration) - Constructor for class org.apache.hadoop.hbase.mapreduce.WALPlayer
 
wasOperationAttemptedByServer() - Method in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
Deprecated.
Returns true if operation was attempted by server, false otherwise.
WHILE_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
WHILE Array
WHILE_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
 
WhileMatchFilter - Class in org.apache.hadoop.hbase.filter
WhileMatchFilter(Filter) - Constructor for class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
WHITESPACE - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for whitespace
withinOrAfterTimeRange(long) - Method in class org.apache.hadoop.hbase.io.TimeRange
Check if the specified timestamp is within or after this TimeRange.
withinTimeRange(long) - Method in class org.apache.hadoop.hbase.io.TimeRange
Check if the specified timestamp is within this TimeRange.
withStartRow(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
Set the start row of the scan.
withStartRow(byte[], boolean) - Method in class org.apache.hadoop.hbase.client.Scan
Set the start row of the scan.
withStopRow(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
Set the stop row of the scan.
withStopRow(byte[], boolean) - Method in class org.apache.hadoop.hbase.client.Scan
Set the stop row of the scan.
wrapped - Variable in class org.apache.hadoop.hbase.types.TerminatedWrapper
 
write(int) - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
write(byte[]) - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
write(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
write(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Writes the field values to the output.
write(OutputStream, ByteRange) - Static method in class org.apache.hadoop.hbase.util.ByteRangeUtils
 
write(OutputStream, ByteRange, int) - Static method in class org.apache.hadoop.hbase.util.ByteRangeUtils
 
writeBufferSize(long) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
Override the write buffer size specified by the provided Connection's Configuration instance, via the configuration key hbase.client.write.buffer.
writeByteArray(DataOutput, byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Write byte-array with a WritableableUtils.vint prefix.
writeByteArray(DataOutput, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Write byte-array to out with a vint length prefix.
writeByteArray(byte[], int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Write byte-array from src to tgt with a vint length prefix.
writeIdInBytes(OutputStream) - Method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
Writes id in bytes.
writeIdInBytes(byte[], int) - Method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
Writes id bytes to the given array starting from offset.
writeIdInBytes(OutputStream) - Method in enum org.apache.hadoop.hbase.io.encoding.IndexBlockEncoding
Writes id in bytes.
writeIdInBytes(byte[], int) - Method in enum org.apache.hadoop.hbase.io.encoding.IndexBlockEncoding
Writes id bytes to the given array starting from offset.
writeInt(int) - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
Writes an int to the underlying output stream as four bytes, high byte first.
writeMapAsString(Map<String, Object>) - Static method in class org.apache.hadoop.hbase.util.JsonMapper
 
writeObjectAsString(Object) - Static method in class org.apache.hadoop.hbase.util.JsonMapper
 
writeStringFixedSize(DataOutput, String, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Writes a string as a fixed-size field, padded with zeros.
writeTo(OutputStream) - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
Writes the complete contents of this byte buffer output stream to the specified output stream argument.
writeTo(PrintWriter) - Static method in class org.apache.hadoop.hbase.util.VersionInfo
 
writeTo(PrintStream) - Static method in class org.apache.hadoop.hbase.util.VersionInfo
 
WrongRegionException - Exception in org.apache.hadoop.hbase.regionserver
Thrown when a request contains a key which is not part of this region
WrongRegionException() - Constructor for exception org.apache.hadoop.hbase.regionserver.WrongRegionException
constructor
WrongRegionException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.WrongRegionException
Constructor
WrongRowIOException - Exception in org.apache.hadoop.hbase.client
 
WrongRowIOException(String) - Constructor for exception org.apache.hadoop.hbase.client.WrongRowIOException
 
WrongVersionException - Exception in org.apache.hadoop.hbase.ipc
 
WrongVersionException() - Constructor for exception org.apache.hadoop.hbase.ipc.WrongVersionException
 
WrongVersionException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.WrongVersionException
 
WrongVersionException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.ipc.WrongVersionException
 

Z

ZERO - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for Zero
ZERO - Static variable in class org.apache.hadoop.hbase.Size
 
zero(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Fill given array with zeros.
zero(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Fill given array with zeros at the specified position.
ZERO_L - Static variable in class org.apache.hadoop.hbase.HConstants
long constant for zero
ZEROES - Static variable in class org.apache.hadoop.hbase.HConstants
 
ZK_CFG_PROPERTY_PREFIX - Static variable in class org.apache.hadoop.hbase.HConstants
Common prefix of ZooKeeper configuration properties
ZK_CFG_PROPERTY_PREFIX_LEN - Static variable in class org.apache.hadoop.hbase.HConstants
 
ZK_CLIENT_KERBEROS_PRINCIPAL - Static variable in class org.apache.hadoop.hbase.HConstants
 
ZK_CLIENT_KEYTAB_FILE - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration keys for programmatic JAAS configuration for secured ZK interaction
ZK_CONNECTION_REGISTRY_CLASS - Static variable in class org.apache.hadoop.hbase.HConstants
Full class name of the Zookeeper based connection registry implementation
ZK_SERVER_KERBEROS_PRINCIPAL - Static variable in class org.apache.hadoop.hbase.HConstants
 
ZK_SERVER_KEYTAB_FILE - Static variable in class org.apache.hadoop.hbase.HConstants
 
ZK_SESSION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for ZooKeeper session timeout
ZK_SYNC_BLOCKING_TIMEOUT_DEFAULT_MS - Static variable in class org.apache.hadoop.hbase.HConstants
 
ZK_SYNC_BLOCKING_TIMEOUT_MS - Static variable in class org.apache.hadoop.hbase.HConstants
Timeout for the ZK sync() call
ZNODE_PATH_SEPARATOR - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
 
ZOOKEEPER_CLIENT_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for the client port that the zookeeper listens on
ZOOKEEPER_DATA_DIR - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for the ZK data directory
ZOOKEEPER_MAX_CLIENT_CNXNS - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for the limit on concurrent client-side zookeeper connections
ZOOKEEPER_QUORUM - Static variable in class org.apache.hadoop.hbase.HConstants
Name of ZooKeeper quorum configuration parameter.
ZOOKEEPER_TICK_TIME - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for the ZK tick time
ZOOKEEPER_ZNODE_PARENT - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for the root dir in ZK for this cluster
ZooKeeperConnectionException - Exception in org.apache.hadoop.hbase
Thrown if the client can't connect to ZooKeeper.
ZooKeeperConnectionException() - Constructor for exception org.apache.hadoop.hbase.ZooKeeperConnectionException
 
ZooKeeperConnectionException(String) - Constructor for exception org.apache.hadoop.hbase.ZooKeeperConnectionException
 
ZooKeeperConnectionException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.ZooKeeperConnectionException
Constructor taking another exception.
zooKeeperWatcher - Variable in class org.apache.hadoop.hbase.HBaseZKTestingUtility
Deprecated.
 
A B C D E F G H I J K L M N O P Q R S T U V W Z 
Skip navigation links

Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.