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 Y 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.Abortable
Abort the server or client.
abort(String, Throwable) - Method in interface org.apache.hadoop.hbase.client.Admin
 
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.client.HBaseHbck
 
Abortable - Interface in org.apache.hadoop.hbase
Interface to support the aborting of a given server or client.
abortProcedure(long, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Abort a procedure.
abortProcedure(long, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
abort a procedure
abortProcedure(long, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
abortProcedure(RpcController, MasterProtos.AbortProcedureRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
abortProcedureAsync(long, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Abort a procedure but does not block and wait for completion.
abortProcedureAsync(long, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
abortProcedureResult(MasterProtos.AbortProcedureRequest) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
AbstractClientScanner - Class in org.apache.hadoop.hbase.client
Helper class for custom client scanners.
AbstractClientScanner() - Constructor for class org.apache.hadoop.hbase.client.AbstractClientScanner
 
AbstractHBaseSaslRpcClient - Class in org.apache.hadoop.hbase.security
A utility class that encapsulates SASL logic for RPC client.
AbstractHBaseSaslRpcClient(AuthMethod, Token<? extends TokenIdentifier>, String, boolean) - Constructor for class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
Create a HBaseSaslRpcClient for an authentication method
AbstractHBaseSaslRpcClient(AuthMethod, Token<? extends TokenIdentifier>, String, boolean, String) - Constructor for class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
Create a HBaseSaslRpcClient for an authentication method
AbstractRpcClient<T extends org.apache.hadoop.hbase.ipc.RpcConnection> - Class in org.apache.hadoop.hbase.ipc
Provides the basics for a RpcClient implementation like configuration and Logging.
AbstractRpcClient(Configuration, String, SocketAddress, MetricsConnection) - Constructor for class org.apache.hadoop.hbase.ipc.AbstractRpcClient
Construct an IPC client for the cluster clusterId
AbstractRpcClient.BlockingRpcChannelImplementation - Class in org.apache.hadoop.hbase.ipc
Blocking rpc channel that goes via hbase rpc.
AbstractRpcClient.RpcChannelImplementation - Class in org.apache.hadoop.hbase.ipc
Async rpc channel that goes via hbase rpc.
AccessControlClient - Class in org.apache.hadoop.hbase.security.access
Utility client for doing access control admin operations.
AccessControlClient() - Constructor for class org.apache.hadoop.hbase.security.access.AccessControlClient
 
AccessControlConstants - Interface in org.apache.hadoop.hbase.security.access
 
AccessControlUtil - Class in org.apache.hadoop.hbase.security.access
 
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
 
ACL_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlClient
 
Action - Class in org.apache.hadoop.hbase.client
A Get, Put, Increment, Append, or Delete associated with it's region.
Action(Row, int) - Constructor for class org.apache.hadoop.hbase.client.Action
 
Action(Row, int, int) - Constructor for class org.apache.hadoop.hbase.client.Action
 
Action(Action, int) - Constructor for class org.apache.hadoop.hbase.client.Action
Creates an action for a particular replica from original action.
ACTION_BY_CODE - Static variable in class org.apache.hadoop.hbase.security.access.Permission
 
actions - Variable in class org.apache.hadoop.hbase.client.MultiAction
 
actions - Variable in class org.apache.hadoop.hbase.security.access.Permission
 
add(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Append
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Append.addColumn(byte[], byte[], byte[]) instead
add(Cell) - Method in class org.apache.hadoop.hbase.client.Append
Add column and value to this Append operation.
add(BigDecimal, BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
add(Double, Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
add(Long, Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
add(Map.Entry<byte[], List<Action>>) - Method in class org.apache.hadoop.hbase.client.DelayingRunner
 
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(byte[], Action) - Method in class org.apache.hadoop.hbase.client.MultiAction
Add an Action to this container based on it's regionName.
add(byte[], List<Action>) - Method in class org.apache.hadoop.hbase.client.MultiAction
Add an Action to this container based on it's regionName.
add(byte[], int, Object) - Method in class org.apache.hadoop.hbase.client.MultiResponse
Add the pair to the container, grouped by the regionName
add(Cell) - Method in class org.apache.hadoop.hbase.client.Put
Add the specified KeyValue to this Put operation.
add(Put) - Method in class org.apache.hadoop.hbase.client.RowMutations
Deprecated.
since 2.0 version and will be removed in 3.0 version. use RowMutations.add(Mutation)
add(Delete) - Method in class org.apache.hadoop.hbase.client.RowMutations
Deprecated.
since 2.0 version and will be removed in 3.0 version. use RowMutations.add(Mutation)
add(Mutation) - Method in class org.apache.hadoop.hbase.client.RowMutations
Currently only supports Put and Delete mutations.
add(List<? extends Mutation>) - Method in class org.apache.hadoop.hbase.client.RowMutations
Currently only supports Put and Delete mutations.
add(S, S) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
 
addAndGet(Result[], boolean) - Method in class org.apache.hadoop.hbase.client.BatchScanResultCache
 
addColumn(TableName, ColumnFamilyDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
As of release 2.0.0. This will be removed in HBase 3.0.0. Use Admin.addColumnFamily(TableName, ColumnFamilyDescriptor).
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.
addColumn(RpcController, MasterProtos.AddColumnRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
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.
addColumnFamily(TableName, ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
addColumnFamily(ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use TableDescriptorBuilder.setColumnFamily(ColumnFamilyDescriptor) instead
addColumnFamilyAsync(TableName, ColumnFamilyDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Add a column family to an existing table.
addColumnFamilyAsync(TableName, ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
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.
addCoprocessor(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use TableDescriptorBuilder.setCoprocessor(String) instead
addCoprocessor(String, Path, int, Map<String, String>) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use TableDescriptorBuilder.setCoprocessor(CoprocessorDescriptor) instead
addCoprocessor(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Add a table coprocessor to this table.
addCoprocessor(String, Path, int, Map<String, String>) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Add a table coprocessor to this table.
addCoprocessorWithSpec(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use TableDescriptorBuilder.setCoprocessor(CoprocessorDescriptor) instead
addCoprocessorWithSpec(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Add a table coprocessor to this table.
addDaughtersToPut(Put, RegionInfo, RegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Adds split daughters to the Put
addDeleteMarker(Cell) - Method in class org.apache.hadoop.hbase.client.Delete
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Delete.add(Cell) instead
addEstimatedSize(long) - Method in class org.apache.hadoop.hbase.client.ClientAsyncPrefetchScanner
 
addEstimatedSize(long) - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
addException(byte[], Throwable) - Method in class org.apache.hadoop.hbase.CacheEvictionStatsBuilder
 
addException(byte[], Throwable) - Method in class org.apache.hadoop.hbase.client.MultiResponse
 
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.
addFamily(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Adds a column 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.
addFilterLists(List<Filter>) - Method in class org.apache.hadoop.hbase.filter.FilterListBase
 
addFilterLists(List<Filter>) - Method in class org.apache.hadoop.hbase.filter.FilterListWithAND
 
addFilterLists(List<Filter>) - Method in class org.apache.hadoop.hbase.filter.FilterListWithOR
 
addImmutable(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Put.add(Cell) and CellBuilder instead
addImmutable(byte[], byte[], long, byte[]) - Method in class org.apache.hadoop.hbase.client.Put
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Put.add(Cell) and CellBuilder instead
addImmutable(byte[], ByteBuffer, long, ByteBuffer) - Method in class org.apache.hadoop.hbase.client.Put
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Put.add(Cell) and CellBuilder instead
addInfo(String, SecurityInfo) - Static method in class org.apache.hadoop.hbase.security.SecurityInfo
Adds a security configuration for a new service name.
addLabel(Configuration, String) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
addLabel(Connection, String) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
Utility method for adding label to the system.
addLabels(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
addLabels(Connection, String[]) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
Utility method for adding labels to the system.
addLocation(Put, ServerName, long, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
 
addPeer(String, ReplicationPeerConfig, Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0, use ReplicationAdmin.addPeer(String, ReplicationPeerConfig) instead.
addPeer(String, ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
addRegionInfo(Put, RegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
 
addRegionsToMeta(Connection, List<RegionInfo>, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Adds a hbase:meta row for each of the specified new regions.
addRegionToMeta(Connection, RegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Adds a (single) hbase:meta row for the specified new region and its daughters.
addReplicas(TableDescriptor, List<RegionInfo>, int, int) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
Create any replicas for the regions (the default replicas that was already created is passed to the method)
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
addReplicationPeer(String, ReplicationPeerConfig, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
addReplicationPeer(RpcController, ReplicationProtos.AddReplicationPeerRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
addSplitsToParent(Connection, RegionInfo, RegionInfo, RegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Adds daughter region infos to hbase:meta row for the specified region.
addStatistic(byte[], ClientProtos.RegionLoadStats) - Method in class org.apache.hadoop.hbase.client.MultiResponse
 
addToCounter(String, long) - Method in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
 
addToFailedServers(InetSocketAddress, Throwable) - Method in class org.apache.hadoop.hbase.ipc.FailedServers
Add an address to the list of the failed servers list.
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.
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.
allTableRegions(Connection, TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
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
 
AND_OPERATOR - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
 
append(CacheEvictionStats) - Method in class org.apache.hadoop.hbase.CacheEvictionStatsAggregator
 
append(CacheEvictionStats) - Method in class org.apache.hadoop.hbase.CacheEvictionStatsBuilder
 
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 class org.apache.hadoop.hbase.client.HTable
 
append(Append) - Method in interface org.apache.hadoop.hbase.client.Table
Appends values to one or more columns within a single row.
appendMetaData(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKMetadata
 
appendPeerTableCFs(String, String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0, use ReplicationAdmin.appendPeerTableCFs(String, Map) instead.
appendPeerTableCFs(String, Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
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
appendReplicationPeerTableCFs(String, Map<TableName, List<String>>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
appendTableCFsToReplicationPeerConfig(Map<TableName, List<String>>, ReplicationPeerConfig) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
 
appendTracker - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
areAdjacent(RegionInfo, RegionInfo) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
Check whether two regions are adjacent
areAdjacent(HRegionInfo, HRegionInfo) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.areAdjacent(RegionInfo, RegionInfo).
areScanStartRowAndStopRowEqual(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.client.ClientUtil
 
assertSnapshotRequestIsValid(SnapshotProtos.SnapshotDescription) - Static method in class org.apache.hadoop.hbase.snapshot.ClientSnapshotDescriptionUtils
Check to make sure that the description of the snapshot requested is valid
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(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
assignRegion(RpcController, MasterProtos.AssignRegionRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
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.
AsyncAdminRequestRetryingCaller<T> - Class in org.apache.hadoop.hbase.client
 
AsyncAdminRequestRetryingCaller(HashedWheelTimer, AsyncConnectionImpl, long, int, long, long, int, ServerName, AsyncAdminRequestRetryingCaller.Callable<T>) - Constructor for class org.apache.hadoop.hbase.client.AsyncAdminRequestRetryingCaller
 
AsyncAdminRequestRetryingCaller.Callable<T> - Interface in org.apache.hadoop.hbase.client
 
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.
AsyncMasterRequestRpcRetryingCaller<T> - Class in org.apache.hadoop.hbase.client
Retry caller for a request call to master.
AsyncMasterRequestRpcRetryingCaller(HashedWheelTimer, AsyncConnectionImpl, AsyncMasterRequestRpcRetryingCaller.Callable<T>, long, int, long, long, int) - Constructor for class org.apache.hadoop.hbase.client.AsyncMasterRequestRpcRetryingCaller
 
AsyncMasterRequestRpcRetryingCaller.Callable<T> - Interface in org.apache.hadoop.hbase.client
 
AsyncMetaTableAccessor - Class in org.apache.hadoop.hbase
The asynchronous meta table accessor.
AsyncMetaTableAccessor() - Constructor for class org.apache.hadoop.hbase.AsyncMetaTableAccessor
 
AsyncProcessTask<T> - Class in org.apache.hadoop.hbase.client
Contains the attributes of a task which will be executed by AsyncProcess.
AsyncProcessTask.Builder<T> - Class in org.apache.hadoop.hbase.client
 
AsyncProcessTask.SubmittedRows - Enum in org.apache.hadoop.hbase.client
The number of processed rows.
AsyncRequestFuture - Interface in org.apache.hadoop.hbase.client
The context used to wait for results from one submit call.
AsyncRpcRetryingCaller<T> - Class in org.apache.hadoop.hbase.client
 
AsyncRpcRetryingCaller(HashedWheelTimer, AsyncConnectionImpl, long, int, long, long, int) - Constructor for class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
 
AsyncServerRequestRpcRetryingCaller<T> - Class in org.apache.hadoop.hbase.client
Retry caller for a request call to region server.
AsyncServerRequestRpcRetryingCaller(HashedWheelTimer, AsyncConnectionImpl, long, int, long, long, int, ServerName, AsyncServerRequestRpcRetryingCaller.Callable<T>) - Constructor for class org.apache.hadoop.hbase.client.AsyncServerRequestRpcRetryingCaller
 
AsyncServerRequestRpcRetryingCaller.Callable<T> - Interface in org.apache.hadoop.hbase.client
 
AsyncTable<C extends ScanResultConsumerBase> - Interface in org.apache.hadoop.hbase.client
The interface for asynchronous version of Table.
AsyncTable.CheckAndMutateBuilder - Interface in org.apache.hadoop.hbase.client
A helper class for sending checkAndMutate request.
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.
AsyncTable.CoprocessorServiceBuilder<S,R> - Interface in org.apache.hadoop.hbase.client
Helper class for sending coprocessorService request that executes a coprocessor call on regions which are covered by a range.
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.
Attributes - Interface in org.apache.hadoop.hbase.client
 
AUTH_TOKEN_TYPE - Static variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
authenticationMethod - Variable in enum org.apache.hadoop.hbase.security.AuthMethod
 
AuthenticationTokenIdentifier - Class in org.apache.hadoop.hbase.security.token
Represents the identity information stored in an HBase authentication token.
AuthenticationTokenIdentifier() - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
AuthenticationTokenIdentifier(String) - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
AuthenticationTokenIdentifier(String, int, long, long) - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
AuthenticationTokenSelector - Class in org.apache.hadoop.hbase.security.token
 
AuthenticationTokenSelector() - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationTokenSelector
 
AuthMethod - Enum in org.apache.hadoop.hbase.security
Authentication method
Authorizations - Class in org.apache.hadoop.hbase.security.visibility
This class contains visibility labels associated with a Scan/Get deciding which all labeled data current scan/get can access.
Authorizations(String...) - Constructor for class org.apache.hadoop.hbase.security.visibility.Authorizations
 
Authorizations(List<String>) - Constructor for class org.apache.hadoop.hbase.security.visibility.Authorizations
 
available(Configuration) - Static method in class org.apache.hadoop.hbase.client.HBaseAdmin
Is HBase available? Throw an exception if not.

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
backupMasterAddressesZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
 
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(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Invoke the balancer.
balance() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Invoke the balancer.
balance(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Invoke the balancer.
balance() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
balance(boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
balance(RpcController, MasterProtos.BalanceRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
balancer() - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use Admin.balance() instead.
balancer(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use Admin.balance(boolean) instead.
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 class org.apache.hadoop.hbase.client.HBaseAdmin
 
balancerZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
 
baseZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
 
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 - Class in org.apache.hadoop.hbase.client.coprocessor
A collection of interfaces and utilities used for interacting with custom RPC interfaces exposed by Coprocessors.
Batch() - Constructor for class org.apache.hadoop.hbase.client.coprocessor.Batch
 
batch(List<? extends Row>, Object[]) - Method in class org.apache.hadoop.hbase.client.HTable
 
batch(List<? extends Row>, Object[], int) - Method in class org.apache.hadoop.hbase.client.HTable
 
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.Call<T,R> - Interface in org.apache.hadoop.hbase.client.coprocessor
Defines a unit of work to be executed.
Batch.Callback<R> - Interface in org.apache.hadoop.hbase.client.coprocessor
Defines a generic callback to be triggered for each Batch.Call.call(Object) result.
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 class org.apache.hadoop.hbase.client.HTable
 
batchCallback(List<? extends Row>, Object[], Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.Table
Same as Table.batch(List, Object[]), but with a callback.
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R) - Method in class org.apache.hadoop.hbase.client.HTable
 
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTable
 
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R) - Method in interface org.apache.hadoop.hbase.client.Table
Creates an instance of the given Service subclass for each table region spanning the range from the startKey row to endKey row (inclusive), all the invocations to the same region server will be batched into one call.
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R, Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.Table
Creates an instance of the given Service subclass for each table region spanning the range from the startKey row to endKey row (inclusive), all the invocations to the same region server will be batched into one call.
BatchScanResultCache - Class in org.apache.hadoop.hbase.client
A scan result cache for batched scan, i.e, scan.getBatch() > 0 && !scan.getAllowPartialResults().
BatchScanResultCache(int) - Constructor for class org.apache.hadoop.hbase.client.BatchScanResultCache
 
BigDecimalColumnInterpreter - Class in org.apache.hadoop.hbase.client.coprocessor
ColumnInterpreter for doing Aggregation's with BigDecimal columns.
BigDecimalColumnInterpreter() - Constructor for class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
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
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.
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
 
BLOCKCACHE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Key for the BLOCKCACHE attribute.
BLOCKCACHE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
BlockingRpcCallback<R> - Class in org.apache.hadoop.hbase.ipc
Simple RpcCallback implementation providing a Future-like BlockingRpcCallback.get() method, which will block util the instance's BlockingRpcCallback.run(Object) method has been called.
BlockingRpcCallback() - Constructor for class org.apache.hadoop.hbase.ipc.BlockingRpcCallback
 
BlockingRpcCallback() - Constructor for class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils.BlockingRpcCallback
 
BlockingRpcChannelImplementation(AbstractRpcClient<?>, InetSocketAddress, User, int) - Constructor for class org.apache.hadoop.hbase.ipc.AbstractRpcClient.BlockingRpcChannelImplementation
 
BlockingRpcClient - Class in org.apache.hadoop.hbase.ipc
Does RPC against a cluster.
BlockingRpcClient(Configuration, String, SocketAddress, MetricsConnection) - Constructor for class org.apache.hadoop.hbase.ipc.BlockingRpcClient
Construct an IPC client for the cluster clusterId with the default SocketFactory This method is called with reflection by the RpcClientFactory to create an instance
BLOCKSIZE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Size of storefile/hfile 'blocks'.
BLOCKSIZE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
BLOOMFILTER - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
BLOOMFILTER - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
BloomType - Enum in org.apache.hadoop.hbase.regionserver
 
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.
BufferedMutatorImpl - Class in org.apache.hadoop.hbase.client
Used to communicate with a single HBase table similar to Table but meant for batched, potentially asynchronous puts.
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 class org.apache.hadoop.hbase.CacheEvictionStatsBuilder
 
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 class org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
 
build() - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
Create the AsyncTable instance.
build() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
build() - Method in class org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder
 
build() - Method in class org.apache.hadoop.hbase.client.RegionInfoBuilder
 
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.ClusterMetricsBuilder
 
build() - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
 
build() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
Builds the configuration object from the current state of this.
build() - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
 
buildActionResult(Throwable) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
Wrap a throwable to an action result.
buildActionResult(ClientProtos.Result) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
Wrap a throwable to an action result.
buildAddColumnRequest(TableName, ColumnFamilyDescriptor, long, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer AddColumnRequest
buildAddReplicationPeerRequest(String, ReplicationPeerConfig, boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
 
buildAssignRegionRequest(byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer AssignRegionRequest
buildBalanceRequest(boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer BalanceRequest
buildBulkLoadHFileRequest(List<Pair<byte[], String>>, byte[], boolean, Token<?>, String) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer bulk load request
buildBulkLoadHFileRequest(List<Pair<byte[], String>>, byte[], boolean, Token<?>, String, boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer bulk load request
buildCatalogScanRequest() - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a request for running a catalog scan
buildClearCompactionQueuesRequest(Set<String>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
 
buildClearDeadServersRequest(Collection<ServerName>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
 
buildClearRegionBlockCacheRequest(List<RegionInfo>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer ClearRegionBlockCacheRequest
buildClearRegionBlockCacheResponse(HBaseProtos.CacheEvictionStats) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
Creates a protocol buffer ClearRegionBlockCacheResponse
buildCloseRegionRequest(ServerName, byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Create a CloseRegionRequest for a given region name
buildCloseRegionRequest(ServerName, byte[], ServerName) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
buildCompactRegionRequest(byte[], boolean, byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a CompactRegionRequest for a given region name
buildCondition(byte[], byte[], byte[], ByteArrayComparable, HBaseProtos.CompareType, TimeRange) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer Condition
buildCreateNamespaceRequest(NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer CreateNamespaceRequest
buildCreateTableRequest(TableDescriptor, byte[][], long, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer CreateTableRequest
buildDecommissionRegionServersRequest(List<ServerName>, boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
 
buildDeleteColumnRequest(TableName, byte[], long, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer DeleteColumnRequest
buildDeleteNamespaceRequest(String) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer DeleteNamespaceRequest
buildDeleteTableRequest(TableName, long, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer DeleteTableRequest
buildDisableReplicationPeerRequest(String) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
 
buildDisableTableRequest(TableName, long, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer DisableTableRequest
buildEnableCatalogJanitorRequest(boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a request for enabling/disabling the catalog janitor
buildEnableCatalogJanitorResponse(boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
Creates a response for the catalog scan request
buildEnableReplicationPeerRequest(String) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
 
buildEnableTableRequest(TableName, long, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer EnableTableRequest
builder() - Static method in class org.apache.hadoop.hbase.CacheEvictionStats
 
buildException(Throwable) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
 
buildFlushRegionRequest(byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer FlushRegionRequest for a given region name
buildFlushRegionRequest(byte[], boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer FlushRegionRequest for a given region name
buildFromProto(MasterProtos.SetQuotaRequest) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettings
Converts the protocol buffer request into a QuotaSetting POJO.
buildGetClusterStatusRequest(EnumSet<ClusterMetrics.Option>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer GetClusterStatusRequest
buildGetLastFlushedSequenceIdRequest(byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a request for querying the master the last flushed sequence Id for a region
buildGetLastFlushedSequenceIdResponse(ClusterStatusProtos.RegionStoreSequenceIds) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
Creates a response for the last flushed sequence Id request
buildGetNamespaceDescriptorRequest(String) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer GetNamespaceDescriptorRequest
buildGetOnlineRegionRequest() - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer GetOnlineRegionRequest
buildGetOnlineRegionResponse(List<RegionInfo>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
A utility to build a GetOnlineRegionResponse.
buildGetQuotaStatesRequest() - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
buildGetRegionInfoRequest(byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer GetRegionInfoRequest for a given region name
buildGetRegionInfoRequest(byte[], boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer GetRegionInfoRequest for a given region name
buildGetRegionInfoRequest(byte[], boolean, boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
 
buildGetRegionLoadRequest(TableName) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer GetRegionLoadRequest for all regions/regions of a table.
buildGetReplicationPeerConfigRequest(String) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
 
buildGetRequest(byte[], Get) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer GetRequest for a client Get
buildGetSchemaAlterStatusRequest(TableName) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer GetSchemaAlterStatusRequest
buildGetServerInfoRequest() - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Create a new GetServerInfoRequest
buildGetServerInfoRequest() - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a new GetServerInfoRequest
buildGetServerInfoResponse(ServerName, int) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
A utility to build a GetServerInfoResponse.
buildGetSpaceQuotaRegionSizesRequest() - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
buildGetSpaceQuotaSnapshotsRequest() - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
buildGetStoreFileRequest(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Create a protocol buffer GetStoreFileRequest for a given region name
buildGetTableDescriptorsRequest(List<TableName>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer GetTableDescriptorsRequest
buildGetTableDescriptorsRequest(Pattern, boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer GetTableDescriptorsRequest
buildGetTableDescriptorsRequest(TableName) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer GetTableDescriptorsRequest for a single table
buildGetTableNamesRequest(Pattern, boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer GetTableNamesRequest
buildGetTableStateRequest(TableName) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer GetTableStateRequest
buildGetUserPermissionsResponse(List<UserPermission>) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
Converts the permissions list into a protocol buffer GetUserPermissionsResponse
buildGrantRequest(String, TableName, byte[], byte[], boolean, AccessControlProtos.Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
Create a request to grant user permissions.
buildGrantRequest(String, String, boolean, AccessControlProtos.Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
Create a request to grant user permissions.
buildGrantRequest(String, boolean, AccessControlProtos.Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
Create a request to grant user permissions.
buildIncrementRequest(byte[], byte[], byte[], byte[], long, Durability, long, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a client increment
buildIsBalancerEnabledRequest() - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer IsBalancerEnabledRequest
buildIsCatalogJanitorEnabledRequest() - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a request for querying the master whether the catalog janitor is enabled
buildIsCleanerChoreEnabledRequest() - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a request for querying the master whether the cleaner chore is enabled
buildIsMasterRunningRequest() - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer IsMasterRunningRequest
buildIsNormalizerEnabledRequest() - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer IsNormalizerEnabledRequest
buildIsSplitOrMergeEnabledRequest(MasterSwitchType) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer IsSplitOrMergeEnabledRequest
buildListReplicationPeersRequest(Pattern) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
 
buildMergeTableRegionsRequest(byte[][], boolean, long, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
 
buildModifyColumnRequest(TableName, ColumnFamilyDescriptor, long, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer ModifyColumnRequest
buildModifyNamespaceRequest(NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer ModifyNamespaceRequest
buildModifyTableRequest(TableName, TableDescriptor, long, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer ModifyTableRequest
buildMoveRegionRequest(byte[], ServerName) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer MoveRegionRequest
buildMutateRequest(byte[], byte[], byte[], byte[], ByteArrayComparable, HBaseProtos.CompareType, TimeRange, Put) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a conditioned put
buildMutateRequest(byte[], byte[], byte[], byte[], ByteArrayComparable, HBaseProtos.CompareType, TimeRange, Delete) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a conditioned delete
buildMutateRequest(byte[], byte[], byte[], byte[], ByteArrayComparable, HBaseProtos.CompareType, TimeRange, Mutation, ClientProtos.MutationProto.MutationType) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
 
buildMutateRequest(byte[], byte[], byte[], byte[], ByteArrayComparable, HBaseProtos.CompareType, TimeRange, RowMutations) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer MutateRequest for conditioned row mutations
buildMutateRequest(byte[], Put) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a put
buildMutateRequest(byte[], Append, long, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer MutateRequest for an append
buildMutateRequest(byte[], Increment, long, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a client increment
buildMutateRequest(byte[], Delete) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a delete
buildNoDataRegionAction(byte[], RowMutations, List<CellScannable>, ClientProtos.RegionAction.Builder, ClientProtos.Action.Builder, ClientProtos.MutationProto.Builder) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer MultiRequest for row mutations that does not hold data.
buildNoDataRegionActions(byte[], Iterable<Action>, List<CellScannable>, ClientProtos.MultiRequest.Builder, ClientProtos.RegionAction.Builder, ClientProtos.Action.Builder, ClientProtos.MutationProto.Builder, long, Map<Integer, Integer>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer multirequest with NO data for a list of actions (data is carried otherwise than via protobuf).
buildNormalizeRequest() - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer NormalizeRequest
buildOfflineRegionRequest(byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer OfflineRegionRequest
buildOpenRegionRequest(ServerName, List<Pair<RegionInfo, List<ServerName>>>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer OpenRegionRequest to open a list of regions
buildOpenRegionRequest(ServerName, RegionInfo, List<ServerName>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer OpenRegionRequest for a given region
buildProcedureDescription(String, String, Map<String, String>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
buildRecommissionRegionServerRequest(ServerName, List<byte[]>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
 
buildRegionAction(byte[], RowMutations) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer MultiRequest for row mutations.
buildRegionActions(byte[], List<Action>, ClientProtos.MultiRequest.Builder, ClientProtos.RegionAction.Builder, ClientProtos.Action.Builder, ClientProtos.MutationProto.Builder, long, Map<Integer, Integer>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer multi request for a list of actions.
buildRegionOpenInfo(RegionInfo, List<ServerName>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a RegionOpenInfo based on given region info and version of offline node
buildRegionSpecifier(HBaseProtos.RegionSpecifier.RegionSpecifierType, byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a byte array to a protocol buffer RegionSpecifier
buildRegionSpecifier(HBaseProtos.RegionSpecifier.RegionSpecifierType, byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Convert a byte array to a protocol buffer RegionSpecifier
buildRemoveReplicationPeerRequest(String) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
 
buildRevokeRequest(String, AccessControlProtos.Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
Create a request to revoke user permissions.
buildRevokeRequest(String, String, AccessControlProtos.Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
Create a request to revoke user permissions.
buildRevokeRequest(String, TableName, byte[], byte[], AccessControlProtos.Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
Create a request to revoke user permissions.
buildRollWALWriterRequest() - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a new RollWALWriterRequest
buildRunCatalogScanResponse(int) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
Creates a response for the catalog scan request
buildRunCleanerChoreRequest() - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a request for running cleaner chore
buildRunCleanerChoreResponse(boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
Creates a response for the cleaner chore request
buildScanRequest(byte[], Scan, int, boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer ScanRequest for a client Scan
buildScanRequest(long, int, boolean, boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer ScanRequest for a scanner id
buildScanRequest(long, int, boolean, long, boolean, boolean, int) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer ScanRequest for a scanner id
buildSetBalancerRunningRequest(boolean, boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer SetBalancerRunningRequest
buildSetCleanerChoreRunningRequest(boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a request for enabling/disabling the cleaner chore
buildSetNormalizerRunningRequest(boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer SetNormalizerRunningRequest
buildSetQuotaRequestProto(QuotaSettings) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettings
Convert a QuotaSettings to a protocol buffer SetQuotaRequest.
buildSetSplitOrMergeEnabledRequest(boolean, boolean, MasterSwitchType...) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer SetSplitOrMergeEnabledRequest
buildSetTableStateInMetaRequest(TableState) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer SetTableStateInMetaRequest
buildSplitTableRegionRequest(RegionInfo, byte[], long, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
 
buildStopServerRequest(String) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a new StopServerRequest
buildTruncateTableRequest(TableName, boolean, long, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer TruncateTableRequest
buildUnassignRegionRequest(byte[], boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer UnassignRegionRequest
buildUpdateFavoredNodesRequest(List<Pair<RegionInfo, List<ServerName>>>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer UpdateFavoredNodesRequest to update a list of favorednode mappings
buildUpdateReplicationPeerConfigRequest(String, ReplicationPeerConfig) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
 
buildWarmupRegionRequest(RegionInfo) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a WarmupRegionRequest for a given region name
bypassGlobals(String, boolean) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Set the "bypass global settings" for the specified user
BYTES_IN_REMOTE_RESULTS_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
 
BYTES_IN_RESULTS_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
 

C

cache - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
CACHE_BLOOMS_ON_WRITE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
CACHE_BLOOMS_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
CACHE_DATA_IN_L1 - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
CACHE_DATA_ON_WRITE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
CACHE_DATA_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
CACHE_INDEX_ON_WRITE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
CACHE_INDEX_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
CacheEvictionStats - Class in org.apache.hadoop.hbase
 
CacheEvictionStatsAggregator - Class in org.apache.hadoop.hbase
Used to merge CacheEvictionStats.
CacheEvictionStatsAggregator() - Constructor for class org.apache.hadoop.hbase.CacheEvictionStatsAggregator
 
CacheEvictionStatsBuilder - Class in org.apache.hadoop.hbase
 
cacheLocation(TableName, RegionLocations) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
 
cacheLocation(TableName, ServerName, HRegionLocation) - Method in class org.apache.hadoop.hbase.client.MetaCache
Put a newly discovered HRegionLocation into the cache.
cacheLocation(TableName, RegionLocations) - Method in class org.apache.hadoop.hbase.client.MetaCache
Put a newly discovered HRegionLocation into the cache.
caching - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
call(HBaseRpcController, AdminProtos.AdminService.Interface) - Method in interface org.apache.hadoop.hbase.client.AsyncAdminRequestRetryingCaller.Callable
 
call() - Method in class org.apache.hadoop.hbase.client.AsyncMasterRequestRpcRetryingCaller
 
call(HBaseRpcController, MasterProtos.MasterService.Interface) - Method in interface org.apache.hadoop.hbase.client.AsyncMasterRequestRpcRetryingCaller.Callable
 
call(HBaseRpcController, ClientProtos.ClientService.Interface) - Method in interface org.apache.hadoop.hbase.client.AsyncServerRequestRpcRetryingCaller.Callable
 
call(T) - Method in interface org.apache.hadoop.hbase.client.coprocessor.Batch.Call
 
call(HBaseRpcController) - Method in class org.apache.hadoop.hbase.client.FlushRegionCallable
 
call(int) - Method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
Override that changes Exception from Exception to IOException.
call(HBaseRpcController) - Method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
Run RPC call.
call(int) - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
Override that changes call Exception from Exception to IOException.
call(int) - Method in interface org.apache.hadoop.hbase.client.RetryingCallable
Computes a result, or throws an exception if unable to do so.
call(int) - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
Algo: - we put the query into the execution pool.
call(S, RpcController, RpcCallback<R>) - Method in interface org.apache.hadoop.hbase.client.ServiceCaller
Represent the actual protobuf rpc call.
call(Callable<T>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Contain ServiceException inside here.
callable - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
callBlockingMethod(Descriptors.MethodDescriptor, RpcController, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient.BlockingRpcChannelImplementation
 
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
 
caller - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
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
 
callMethod(Descriptors.MethodDescriptor, RpcController, Message, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.client.RegionServerCoprocessorRpcChannelImpl
 
callMethod(Descriptors.MethodDescriptor, RpcController, Message, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient.RpcChannelImplementation
 
CallQueueTooBigException - Exception in org.apache.hadoop.hbase
 
CallQueueTooBigException() - Constructor for exception org.apache.hadoop.hbase.CallQueueTooBigException
 
CallQueueTooBigException(String) - Constructor for exception org.apache.hadoop.hbase.CallQueueTooBigException
 
CallStats() - Constructor for class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
CallTimeoutException - Exception in org.apache.hadoop.hbase.ipc
Client-side call timeout
CallTimeoutException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.CallTimeoutException
 
callWithoutRetries(RetryingCallable<T>, int) - Method in interface org.apache.hadoop.hbase.client.RpcRetryingCaller
Call the server once only.
callWithoutRetries(RetryingCallable<T>, int) - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallerImpl
 
callWithRetries(RetryingCallable<T>, int) - Method in interface org.apache.hadoop.hbase.client.RpcRetryingCaller
Retries if invocation fails.
callWithRetries(RetryingCallable<T>, int) - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallerImpl
 
cancel(boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
cancel() - Method in interface org.apache.hadoop.hbase.client.RpcRetryingCaller
 
cancel() - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallerImpl
 
cancelAll() - Method in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService
 
cancelConnections(ServerName) - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
Interrupt the connections to the given ip:port server.
cancelConnections(ServerName) - Method in interface org.apache.hadoop.hbase.ipc.RpcClient
Interrupt the connections to the given server.
canTakeRow(HRegionLocation, Row) - Method in interface org.apache.hadoop.hbase.client.RequestController.Checker
Checks the data whether it is valid to submit.
castToCellType(BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
castToCellType(Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
castToCellType(Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
castToCellType(S) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
The response message comes as type S.
castToReturnType(BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
castToReturnType(Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
castToReturnType(Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
castToReturnType(T) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
provides casting opportunity between the data types.
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.
catalogJanitorSwitch(boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
cConnection - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
 
cellBlockBuilder - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
cellScanner() - Method in class org.apache.hadoop.hbase.client.Mutation
 
cellScanner() - Method in class org.apache.hadoop.hbase.client.Result
 
cellScanner() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
cellScanner() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
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
 
CellVisibility - Class in org.apache.hadoop.hbase.security.visibility
This contains a visibility expression which can be associated with a cell.
CellVisibility(String) - Constructor for class org.apache.hadoop.hbase.security.visibility.CellVisibility
 
CF_ATTRIBUTE_EARLY_OUT - Static variable in interface org.apache.hadoop.hbase.security.access.AccessControlConstants
Configuration or CF schema option for early termination of access checks if table or CF permissions grant access.
CFNAME - Static variable in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
 
chance - Variable in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
channelInactive(ChannelHandlerContext) - Method in class org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClientHandler
 
channelInactive(ChannelHandlerContext) - Method in class org.apache.hadoop.hbase.security.SaslUnwrapHandler
 
channelRead0(ChannelHandlerContext, ByteBuf) - Method in class org.apache.hadoop.hbase.security.CryptoAESUnwrapHandler
 
channelRead0(ChannelHandlerContext, ByteBuf) - Method in class org.apache.hadoop.hbase.security.NettyHBaseRpcConnectionHeaderHandler
 
channelRead0(ChannelHandlerContext, ByteBuf) - Method in class org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClientHandler
 
channelRead0(ChannelHandlerContext, ByteBuf) - Method in class org.apache.hadoop.hbase.security.SaslUnwrapHandler
 
CHECK_AUTHS_FOR_MUTATION - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
 
checkAndDelete(byte[], byte[], byte[], byte[], Delete) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
checkAndDelete(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Delete) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
checkAndDelete(byte[], byte[], byte[], CompareOperator, byte[], Delete) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
checkAndDelete(byte[], byte[], byte[], byte[], Delete) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use Table.checkAndMutate(byte[], byte[])
checkAndDelete(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Delete) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use Table.checkAndMutate(byte[], byte[])
checkAndDelete(byte[], byte[], byte[], CompareOperator, byte[], Delete) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use Table.checkAndMutate(byte[], byte[])
checkAndGetReversed(List<Filter>, boolean) - Static method in class org.apache.hadoop.hbase.filter.FilterListBase
 
checkAndMutate(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndMutate(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
 
checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], RowMutations) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
checkAndMutate(byte[], byte[], byte[], CompareOperator, byte[], RowMutations) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
checkAndMutate(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Table
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], RowMutations) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use Table.checkAndMutate(byte[], byte[])
checkAndMutate(byte[], byte[], byte[], CompareOperator, byte[], RowMutations) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use Table.checkAndMutate(byte[], byte[])
checkAndPut(byte[], byte[], byte[], byte[], Put) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
checkAndPut(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Put) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
checkAndPut(byte[], byte[], byte[], CompareOperator, byte[], Put) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
checkAndPut(byte[], byte[], byte[], byte[], Put) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use Table.checkAndMutate(byte[], byte[])
checkAndPut(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Put) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use Table.checkAndMutate(byte[], byte[])
checkAndPut(byte[], byte[], byte[], CompareOperator, byte[], Put) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use Table.checkAndMutate(byte[], byte[])
checkFailed() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
Throws an IOException back out if one is currently stored.
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'
checkIfRegionServerIsRemote() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
compare the local machine hostname with region server's hostname to decide if hbase client connects to a remote region server
checkState(int) - Method in interface org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture.WaitForStateCallable
 
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
Key to use setting non-default BufferedMutator implementation in Configuration.
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.
cleanerChoreSwitch(boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
cleanupBulkLoad(Connection, String) - Method in class org.apache.hadoop.hbase.client.SecureBulkLoadClient
 
clear() - Method in class org.apache.hadoop.hbase.client.BatchScanResultCache
 
clear() - Method in class org.apache.hadoop.hbase.util.PoolMap
 
clear() - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
 
clearAuths(Configuration, String[], String) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
clearAuths(Connection, String[], String) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
Removes given labels from user's globally authorized list of labels.
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.
clearBlockCache(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Clear all the blocks corresponding to this table from BlockCache.
clearCache() - Method in class org.apache.hadoop.hbase.client.MetaCache
Delete all cached entries.
clearCache(ServerName) - Method in class org.apache.hadoop.hbase.client.MetaCache
Delete all cached entries of a server.
clearCache(TableName) - Method in class org.apache.hadoop.hbase.client.MetaCache
Delete all cached entries of a table.
clearCache(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.MetaCache
Delete a cached location, no matter what it is.
clearCache(TableName, byte[], int) - Method in class org.apache.hadoop.hbase.client.MetaCache
Delete a cached location with specific replicaId.
clearCache(TableName, byte[], ServerName) - Method in class org.apache.hadoop.hbase.client.MetaCache
Delete a cached location for a table, row and server
clearCache(RegionInfo) - Method in class org.apache.hadoop.hbase.client.MetaCache
Deletes the cached location of the region if necessary, based on some error from source.
clearCache(HRegionLocation) - Method in class org.apache.hadoop.hbase.client.MetaCache
 
clearCaches(ServerName) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Clear any caches that pertain to server name sn.
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.
clearCompactionQueues(ServerName, Set<String>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
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.
clearDeadServers(List<ServerName>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
clearDeadServers(RpcController, MasterProtos.ClearDeadServersRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
clearRegionCache() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Allows flushing the region cache.
clearRegionCache(TableName) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Allows flushing the region cache of all locations that pertain to tableName
clearRegionCache() - Method in class org.apache.hadoop.hbase.client.HTable
Explicitly clears the region cache to fetch the latest value from META.
CLIENT_NONCES_ENABLED_KEY - Static variable in interface org.apache.hadoop.hbase.client.NonceGenerator
 
CLIENT_SIDE_METRICS_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.client.MetricsConnection
Set this key to true to enable metrics collection of client requests.
ClientAsyncPrefetchScanner - Class in org.apache.hadoop.hbase.client
ClientAsyncPrefetchScanner implements async scanner behaviour.
ClientAsyncPrefetchScanner(Configuration, Scan, TableName, ClusterConnection, RpcRetryingCallerFactory, RpcControllerFactory, ExecutorService, int) - Constructor for class org.apache.hadoop.hbase.client.ClientAsyncPrefetchScanner
 
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.
ClientBackoffPolicyFactory - Class in org.apache.hadoop.hbase.client.backoff
 
ClientBackoffPolicyFactory.NoBackoffPolicy - Class in org.apache.hadoop.hbase.client.backoff
Default backoff policy that doesn't create any backoff for the client, regardless of load
ClientCoprocessorRpcController - Class in org.apache.hadoop.hbase.client
Client side rpc controller for coprocessor implementation.
ClientCoprocessorRpcController() - Constructor for class org.apache.hadoop.hbase.client.ClientCoprocessorRpcController
 
ClientExceptionsUtil - Class in org.apache.hadoop.hbase.exceptions
 
ClientScanner - Class in org.apache.hadoop.hbase.client
Implements the scanner interface for the HBase client.
ClientScanner(Configuration, Scan, TableName, ClusterConnection, RpcRetryingCallerFactory, RpcControllerFactory, ExecutorService, int) - Constructor for class org.apache.hadoop.hbase.client.ClientScanner
Create a new ClientScanner for the specified table Note that the passed Scan's start row maybe changed changed.
ClientServiceCallable<T> - Class in org.apache.hadoop.hbase.client
A RegionServerCallable set to use the Client protocol.
ClientServiceCallable(Connection, TableName, byte[], RpcController, int) - Constructor for class org.apache.hadoop.hbase.client.ClientServiceCallable
 
ClientSimpleScanner - Class in org.apache.hadoop.hbase.client
ClientSimpleScanner implements a sync scanner behaviour.
ClientSimpleScanner(Configuration, Scan, TableName, ClusterConnection, RpcRetryingCallerFactory, RpcControllerFactory, ExecutorService, int) - Constructor for class org.apache.hadoop.hbase.client.ClientSimpleScanner
 
ClientSnapshotDescriptionUtils - Class in org.apache.hadoop.hbase.snapshot
Class to help with dealing with a snapshot description on the client side.
ClientSnapshotDescriptionUtils() - Constructor for class org.apache.hadoop.hbase.snapshot.ClientSnapshotDescriptionUtils
 
ClientUtil - Class in org.apache.hadoop.hbase.client
 
ClientUtil() - Constructor for class org.apache.hadoop.hbase.client.ClientUtil
 
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
 
cloneSnapshot(byte[], TableName) - 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.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(byte[], TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
cloneSnapshot(String, TableName, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
cloneSnapshot(String, TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
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) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
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 class org.apache.hadoop.hbase.client.BufferedMutatorImpl
 
close() - Method in class org.apache.hadoop.hbase.client.ClientAsyncPrefetchScanner
 
close() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
close() - Method in interface org.apache.hadoop.hbase.client.Connection
 
close() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
close() - Method in class org.apache.hadoop.hbase.client.HBaseHbck
 
close() - Method in class org.apache.hadoop.hbase.client.HRegionLocator
close() - Method in class org.apache.hadoop.hbase.client.HTable
 
close() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
Closes the internal Connection.
close() - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
 
close() - Method in interface org.apache.hadoop.hbase.client.ResultScanner
Closes the scanner and releases any resources it has allocated
close() - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
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.ipc.AbstractRpcClient
 
close() - Method in interface org.apache.hadoop.hbase.ipc.RpcClient
Stop all threads related to this client.
close() - Method in class org.apache.hadoop.hbase.quotas.QuotaRetriever
 
close(ChannelHandlerContext, ChannelPromise) - Method in class org.apache.hadoop.hbase.security.CryptoAESWrapHandler
 
close(ChannelHandlerContext, ChannelPromise) - Method in class org.apache.hadoop.hbase.security.SaslWrapHandler
 
close() - Method in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
 
closed - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
closed - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
CLOSED_PARAN - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
 
closeInternal() - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
closeInternal() - Method in class org.apache.hadoop.hbase.ipc.BlockingRpcClient
 
closeInternal() - Method in class org.apache.hadoop.hbase.ipc.NettyRpcClient
 
closeRegion(String, String) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Admin.unassign(byte[], boolean).
closeRegion(byte[], String) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Admin.unassign(byte[], boolean).
closeRegion(ServerName, HRegionInfo) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 (HBASE-18231). Use Admin.unassign(byte[], boolean).
closeRegion(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Deprecated.
closeRegion(byte[], String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Deprecated.
closeRegion(ServerName, HRegionInfo) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Deprecated.
closeRegion(RpcController, AdminProtos.AdminService.BlockingInterface, ServerName, byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
A helper to close a region given a region name using admin protocol.
closeRegionWithEncodedRegionName(String, String) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Admin.unassign(byte[], boolean).
closeRegionWithEncodedRegionName(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Deprecated.
ClusterConnection - Interface in org.apache.hadoop.hbase.client
Internal methods on Connection that should not be used by user code.
ClusterId - Class in org.apache.hadoop.hbase
The identifier for this cluster.
ClusterId() - Constructor for class org.apache.hadoop.hbase.ClusterId
New ClusterID.
ClusterId(String) - Constructor for class org.apache.hadoop.hbase.ClusterId
 
clusterId - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
clusterIdZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
 
ClusterMetrics - Interface in org.apache.hadoop.hbase
Metrics information on the HBase cluster.
ClusterMetrics.Option - Enum in org.apache.hadoop.hbase
Kinds of ClusterMetrics
ClusterMetricsBuilder - Class in org.apache.hadoop.hbase
 
clusterStateZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
 
ClusterStatus - Class in org.apache.hadoop.hbase
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ClusterMetrics instead.
ClusterStatus(String, String, Map<ServerName, ServerLoad>, Collection<ServerName>, ServerName, Collection<ServerName>, List<RegionState>, String[], Boolean, int) - Constructor for class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0
ClusterStatus(ClusterMetrics) - Constructor for class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
 
code() - Method in enum org.apache.hadoop.hbase.security.access.Permission.Action
 
code - Variable in enum org.apache.hadoop.hbase.security.AuthMethod
The code for this method.
codec - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
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 (:)
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
 
ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor - Class in org.apache.hadoop.hbase.client
An ModifyableFamilyDescriptor contains information about a column family such as the number of versions, compression settings, etc.
ColumnInterpreter<T,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,R extends com.google.protobuf.Message> - Class in org.apache.hadoop.hbase.coprocessor
Defines how value for specific column is interpreted and provides utility methods like compare, add, multiply etc for them.
ColumnInterpreter() - Constructor for class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
 
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.
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
 
COMMA - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for a comma
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(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Compact a table.
compact(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Compact a column family within a table.
compact(TableName, byte[], CompactType) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Compact a column family within a table.
compact(TableName, CompactType) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Compact a 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_ENABLED - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
CompactionState - Enum in org.apache.hadoop.hbase.client
POJO representing the compaction state
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.
compactRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
compactRegion(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Compact a column family within a region.
compactRegionServer(ServerName, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Admin.compactRegionServer(ServerName) or Admin.majorCompactRegionServer(ServerName).
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.
compactRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
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_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(BigDecimal, BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
compare(Double, Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
compare(Long, Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
compare(T, T) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
This takes care if either of arguments are null.
compareCell(Cell, Cell) - Method in class org.apache.hadoop.hbase.filter.FilterListBase
 
compareFamily(CompareFilter.CompareOp, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
Deprecated.
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(CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.CompareFilter
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use other constructor.
CompareFilter(CompareOperator, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.CompareFilter
Constructor.
CompareFilter.CompareOp - Enum in org.apache.hadoop.hbase.filter
Deprecated.
since 2.0.0. Will be removed in 3.0.0. Use CompareOperator instead.
CompareOperator - Enum in org.apache.hadoop.hbase
Generic set of comparison operators.
compareQualifier(CompareFilter.CompareOp, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
Deprecated.
compareQualifier(CompareOperator, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
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.
compareRow(CompareFilter.CompareOp, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
Deprecated.
compareRow(CompareOperator, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
compareTo(Action) - Method in class org.apache.hadoop.hbase.client.Action
 
compareTo(ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
compareTo(Row) - Method in class org.apache.hadoop.hbase.client.Get
 
compareTo(Row) - Method in class org.apache.hadoop.hbase.client.Mutation
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Row.COMPARATOR instead
compareTo(Row) - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
 
compareTo(Row) - Method in interface org.apache.hadoop.hbase.client.Row
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Row.COMPARATOR instead
compareTo(Row) - Method in class org.apache.hadoop.hbase.client.RowMutations
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Row.COMPARATOR instead
compareTo(TableDescriptorBuilder.ModifyableTableDescriptor) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Compares the descriptor with another descriptor which is passed as a parameter.
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[], 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[], 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(MultiRowRangeFilter.RowRange) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
 
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(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
compareTo(HRegionInfo) - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
 
compareTo(HRegionLocation) - Method in class org.apache.hadoop.hbase.HRegionLocation
 
compareTo(HTableDescriptor) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Compares the descriptor with another descriptor which is passed as a parameter.
compareTo(Size) - Method in class org.apache.hadoop.hbase.Size
 
compareValue(CompareFilter.CompareOp, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
Deprecated.
compareValue(CompareOperator, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
completeExceptionally() - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
 
COMPRESS_TAGS - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
COMPRESS_TAGS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
COMPRESSION - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
COMPRESSION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
COMPRESSION_COMPACT - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
COMPRESSION_COMPACT - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
compressor - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
concurrentCallsPerServerHist - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
conf - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
conf - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
 
conf - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
 
conf - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
conf - Variable in class org.apache.hadoop.hbase.ipc.RpcControllerFactory
 
conn - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
 
Connection - Interface in org.apache.hadoop.hbase.client
A cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.
connection - Variable in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
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
 
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
 
ConnectionConfiguration - Class in org.apache.hadoop.hbase.client
Configuration parameters for the connection.
ConnectionConfiguration() - Constructor for class org.apache.hadoop.hbase.client.ConnectionConfiguration
Constructor This is for internal testing purpose (using the default value).
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
connections - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
ConnectionUtils - Class in org.apache.hadoop.hbase.client
Utility used by client connections.
ConnectionUtils.ShortCircuitingClusterConnection - Class in org.apache.hadoop.hbase.client
A ClusterConnection that will short-circuit RPC making direct invocations against the localhost if the invocation target is 'this' server; save on network and protobuf invocations.
connectTO - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
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
 
contains(byte[]) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
 
contains(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
 
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).
containsKey(Object) - Method in class org.apache.hadoop.hbase.util.PoolMap
 
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
 
containsRange(byte[], byte[]) - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
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
 
containsRow(byte[]) - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
 
containsValue(Object) - Method in class org.apache.hadoop.hbase.util.PoolMap
 
controller - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
 
convert(Map<TableName, ? extends Collection<String>>) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
convert map to TableCFs Object
convert(String) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
Convert string to TableCFs Object.
convert(ReplicationProtos.TableCF[]) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
Convert TableCFs Object to String.
convert(ReplicationProtos.ReplicationPeer) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
 
convert(ReplicationPeerConfig) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
 
convert() - Method in class org.apache.hadoop.hbase.client.TableState
Covert to PB version of TableState
convert(TableName, HBaseProtos.TableState) - Static method in class org.apache.hadoop.hbase.client.TableState
Covert from PB version of TableState
convert(HBaseProtos.TableState.State) - Static method in enum org.apache.hadoop.hbase.client.TableState.State
Covert from PB version of State
convert() - Method in enum org.apache.hadoop.hbase.client.TableState.State
Covert to PB version of State
convert() - Method in class org.apache.hadoop.hbase.ClusterId
 
convert(ClusterIdProtos.ClusterId) - Static method in class org.apache.hadoop.hbase.ClusterId
 
convert(HRegionInfo) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use toRegionInfo(org.apache.hadoop.hbase.client.RegionInfo) in org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil.
convert(HBaseProtos.RegionInfo) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use toRegionInfo(HBaseProtos.RegionInfo) in org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil.
convert() - Method in class org.apache.hadoop.hbase.master.RegionState
Convert a RegionState to an HBaseProtos.RegionState
convert(ClusterStatusProtos.RegionState) - Static method in class org.apache.hadoop.hbase.master.RegionState
Convert a protobuf HBaseProtos.RegionState to a RegionState
convert() - Method in enum org.apache.hadoop.hbase.master.RegionState.State
Convert to protobuf ClusterStatusProtos.RegionState.State
convert(ClusterStatusProtos.RegionState.State) - Static method in enum org.apache.hadoop.hbase.master.RegionState.State
Convert a protobuf HBaseProtos.RegionState.State to a RegionState.State
convert2Map(ReplicationProtos.TableCF[]) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
Convert tableCFs Object to Map.
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
convertResult(MasterProtos.GetProcedureResultResponse) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
Convert the procedure result response to a specified type.
convertToString(Set<String>) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
 
convertToString(Map<TableName, ? extends Collection<String>>) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
 
Coprocessor - Interface in org.apache.hadoop.hbase
Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor, RegionServerCoprocessor, and WALCoprocessor.
Coprocessor.State - Enum in org.apache.hadoop.hbase
Lifecycle state of a given coprocessor instance.
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
CoprocessorEnvironment<C extends Coprocessor> - Interface in org.apache.hadoop.hbase
Coprocessor environment state.
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
Base interface which provides clients with an RPC connection to call coprocessor endpoint Services.
CoprocessorRpcUtils - Class in org.apache.hadoop.hbase.ipc
Utilities for handling coprocessor rpc service calls.
CoprocessorRpcUtils.BlockingRpcCallback<R> - Class in org.apache.hadoop.hbase.ipc
Simple RpcCallback implementation providing a Future-like BlockingRpcCallback.get() method, which will block util the instance's BlockingRpcCallback.run(Object) method has been called.
coprocessorService() - Method in interface org.apache.hadoop.hbase.client.Admin
Creates and returns a RpcChannel instance connected to the active master.
coprocessorService(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
Creates and returns a RpcChannel instance connected to the passed region server.
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() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
coprocessorService(ServerName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
coprocessorService(byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
 
coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>) - Method in class org.apache.hadoop.hbase.client.HTable
 
coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTable
 
coprocessorService(byte[]) - Method in interface org.apache.hadoop.hbase.client.Table
Creates and returns a RpcChannel instance connected to the table region containing the specified row.
coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>) - Method in interface org.apache.hadoop.hbase.client.Table
Creates an instance of the given Service subclass for each table region spanning the range from the startKey row to endKey row (inclusive), and invokes the passed Batch.Call.call(T) method with each Service instance.
coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>, Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.Table
Creates an instance of the given Service subclass for each table region spanning the range from the startKey row to endKey row (inclusive), and invokes the passed Batch.Call.call(T) method with each Service instance.
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
 
copyFrom(Result) - Method in class org.apache.hadoop.hbase.client.Result
Copy another Result into this one.
copyWritable(Writable, Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
Copy one Writable to another.
copyWritable(byte[], Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
Copy one Writable to another.
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
 
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
 
COUNT_OF_ROWS_FILTERED_KEY - Static variable in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 (HBASE-17886). Use ServerSideScanMetrics.COUNT_OF_ROWS_FILTERED_KEY_METRIC_NAME.
COUNT_OF_ROWS_FILTERED_KEY_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
 
COUNT_OF_ROWS_SCANNED_KEY - Static variable in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 (HBASE-17886). Use ServerSideScanMetrics.COUNT_OF_ROWS_SCANNED_KEY_METRIC_NAME.
COUNT_OF_ROWS_SCANNED_KEY_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
 
countOfBytesInRemoteResults - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
number of bytes in Result objects from remote region servers
countOfBytesInResults - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
number of bytes in Result objects from region servers
countOfNSRE - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
number of NotServingRegionException caught
countOfRegions - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
number of regions
countOfRemoteRPCcalls - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
number of remote RPC calls
countOfRemoteRPCRetries - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
number of remote RPC retries
countOfRowsFiltered - Variable in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
number of rows filtered during scan RPC
countOfRowsScanned - Variable in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
number of rows scanned during scan RPC.
countOfRPCcalls - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
number of RPC calls
countOfRPCRetries - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
number of RPC retries
create(Configuration) - Static method in class org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicyFactory
 
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(Configuration) - Static method in class org.apache.hadoop.hbase.client.ServerStatisticTracker
 
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.
createBlockingRpcChannel(ServerName, User, int) - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
createBlockingRpcChannel(ServerName, User, int) - Method in interface org.apache.hadoop.hbase.ipc.RpcClient
Creates a "channel" that can be used by a blocking protobuf service.
createClient(Configuration, String) - Static method in class org.apache.hadoop.hbase.ipc.RpcClientFactory
Helper method for tests only.
createClient(Configuration, String, MetricsConnection) - Static method in class org.apache.hadoop.hbase.ipc.RpcClientFactory
Creates a new RpcClient by the class defined in the configuration or falls back to RpcClientImpl
createClient(Configuration, String, SocketAddress, MetricsConnection) - Static method in class org.apache.hadoop.hbase.ipc.RpcClientFactory
Creates a new RpcClient by the class defined in the configuration or falls back to RpcClientImpl
createCompactionState(AdminProtos.GetRegionInfoResponse.CompactionState) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
createCompactionState(CompactionState) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
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
createCompareOp(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Deprecated.
Since 2.0

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.
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(ConnectionId) - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
Not connected.
createConnection(ConnectionId) - Method in class org.apache.hadoop.hbase.ipc.BlockingRpcClient
Creates a connection.
createConnection(ConnectionId) - Method in class org.apache.hadoop.hbase.ipc.NettyRpcClient
 
createCounter(String) - Method in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
Create a new counter with the specified name
createCryptoAES(RPCProtos.CryptoCipherMeta, Configuration) - Static method in class org.apache.hadoop.hbase.security.EncryptionUtil
Helper to create an instance of CryptoAES.
createCursor(byte[]) - Static method in class org.apache.hadoop.hbase.client.ClientUtil
 
createCursorResult(Cursor) - Static method in class org.apache.hadoop.hbase.client.Result
 
createDigestSaslClient(String[], String, CallbackHandler) - Method in class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
 
createEncryptionContext(Configuration, ColumnFamilyDescriptor) - Static method in class org.apache.hadoop.hbase.security.EncryptionUtil
Helper to create an encyption context.
createEventLoopPerClient(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.NettyRpcClientConfigHelper
The AsyncRpcClient 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.FilterBase
Given the filter's arguments it constructs the filter
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
 
createForTesting(RegionInfo, RegionState.State) - Static method in class org.apache.hadoop.hbase.master.RegionState
 
createHBaseProtosSnapshotDesc(SnapshotDescription) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
createKerberosSaslClient(String[], String, String) - Method in class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
 
createMobRegionInfo(TableName) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
Creates a RegionInfo object for MOB data.
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.
createNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
createNamespace(RpcController, MasterProtos.CreateNamespaceRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
createNamespaceAsync(NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Create a new namespace.
createNamespaceAsync(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
createPool() - Method in class org.apache.hadoop.hbase.util.PoolMap
 
createProtosSnapShotDescType(SnapshotType) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
createProtosSnapShotDescType(SnapshotType) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
createProtosSnapShotDescType(String) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Creates HBaseProtos.SnapshotDescription.Type from the type of SnapshotDescription string
createRegionLoadStats(ClientProtos.RegionLoadStats) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
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.
createRegionName(TableName, byte[], long, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.createRegionName(TableName, byte[], long, boolean).
createRegionName(TableName, byte[], String, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.createRegionName(TableName, byte[], String, boolean).
createRegionName(TableName, byte[], long, int, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.createRegionName(TableName, byte[], long, int, boolean).
createRegionName(TableName, byte[], byte[], boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.createRegionName(TableName, byte[], byte[], boolean).
createRegionName(TableName, byte[], byte[], int, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.createRegionName(TableName, byte[], byte[], int, boolean).
createRpcChannel(ServerName, User, int) - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
createRpcChannel(ServerName, User, int) - Method in interface org.apache.hadoop.hbase.ipc.RpcClient
Creates a "channel" that can be used by a protobuf service.
createScanFromCursor(Cursor) - Static method in class org.apache.hadoop.hbase.client.Scan
Create a new Scan with a cursor.
createScannerCallable() - Method in class org.apache.hadoop.hbase.client.ClientScanner
Will be called in moveToNextRegion to create ScannerCallable.
createScannerCallable() - Method in class org.apache.hadoop.hbase.client.ClientSimpleScanner
 
createScannerCallable() - Method in class org.apache.hadoop.hbase.client.ReversedClientScanner
 
createScanResultCache(Scan) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
 
createShortCircuitConnection(Configuration, ExecutorService, User, ServerName, AdminProtos.AdminService.BlockingInterface, ClientProtos.ClientService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
Creates a short-circuit connection that can bypass the RPC layer (serialization, deserialization, networking, etc..) when talking to a local server.
createSnapshotDesc(SnapshotProtos.SnapshotDescription) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
createSnapshotType(SnapshotProtos.SnapshotDescription.Type) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
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(TableDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
createTable(TableDescriptor, byte[], byte[], int) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
createTable(TableDescriptor, byte[][]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
createTable(RpcController, MasterProtos.CreateTableRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
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.
createTableAsync(TableDescriptor, byte[][]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
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
CryptoAESUnwrapHandler - Class in org.apache.hadoop.hbase.security
Unwrap messages with Crypto AES.
CryptoAESUnwrapHandler(CryptoAES) - Constructor for class org.apache.hadoop.hbase.security.CryptoAESUnwrapHandler
 
CryptoAESWrapHandler - Class in org.apache.hadoop.hbase.security
wrap messages with Crypto AES.
CryptoAESWrapHandler(CryptoAES) - Constructor for class org.apache.hadoop.hbase.security.CryptoAESWrapHandler
 
current() - Method in class org.apache.hadoop.hbase.client.Result
 
currentRegion - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
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()
cursor - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
CUSTOM_CALLER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
Configuration key for a custom RpcRetryingCaller
CUSTOM_CONTROLLER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.RpcControllerFactory
Custom RPC Controller factory allows frameworks to change the RPC controller.
CUSTOM_RPC_CLIENT_IMPL_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.RpcClientFactory
 

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_BLOCK_ENCODING - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class org.apache.hadoop.hbase.security.SaslChallengeDecoder
 
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.
decommissionRegionServers(List<ServerName>, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
decommissionRegionServers(RpcController, MasterProtos.DecommissionRegionServersRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
decTaskCounters(Collection<byte[]>, ServerName) - Method in interface org.apache.hadoop.hbase.client.RequestController
Decrement the counter if a task is accomplished.
DEFAULT_ATTRIBUTE_EARLY_OUT - Static variable in interface org.apache.hadoop.hbase.security.access.AccessControlConstants
Default setting for hbase.security.access.early_out
DEFAULT_BLOCKCACHE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Default setting for whether to use a block cache or not.
DEFAULT_BLOCKCACHE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
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.HColumnDescriptor
Deprecated.
 
DEFAULT_BLOOMFILTER - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Default setting for whether or not to use bloomfilters.
DEFAULT_BLOOMFILTER - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
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_BLOOMS_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_CACHE_DATA_IN_L1 - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
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_DATA_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
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_CACHE_INDEX_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_CODEC_CLASS - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
 
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_COMPACTION_ENABLED - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
DEFAULT_COMPRESS_TAGS - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Default compress tags along with any type of DataBlockEncoding.
DEFAULT_COMPRESS_TAGS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_COMPRESSION - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Default compression type.
DEFAULT_COMPRESSION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_DATA_BLOCK_ENCODING - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Default data block encoding algorithm.
DEFAULT_DATA_BLOCK_ENCODING - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_DFS_REPLICATION - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
DEFAULT_DFS_REPLICATION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_ENCODE_ON_DISK - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
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_BLOCKS_ON_CLOSE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_EXEC_PERMISSION_CHECKS - Static variable in interface org.apache.hadoop.hbase.security.access.AccessControlConstants
Default setting for hbase.security.exec.permission.checks; false
DEFAULT_HBASE_CLIENT_SCANNER_ASYNC_PREFETCH - Static variable in class org.apache.hadoop.hbase.client.Scan
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_IN_MEMORY - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_KEEP_DELETED - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Default setting for preventing deleted from being collected immediately.
DEFAULT_KEEP_DELETED - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_MAX_BACKOFF - Static variable in class org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
 
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_MEMSTORE_FLUSH_SIZE - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
DEFAULT_MIN_VERSIONS - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Default is not to keep a minimum of versions.
DEFAULT_MIN_VERSIONS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_MOB_COMPACT_PARTITION_POLICY - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
DEFAULT_MOB_COMPACT_PARTITION_POLICY - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_MOB_THRESHOLD - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
DEFAULT_MOB_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_NEW_VERSION_BEHAVIOR - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
DEFAULT_NEW_VERSION_BEHAVIOR - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_NORMALIZATION_ENABLED - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Constant that denotes whether the table is normalized by default.
DEFAULT_NORMALIZATION_ENABLED - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
DEFAULT_PREFETCH_BLOCKS_ON_OPEN - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
DEFAULT_PREFETCH_BLOCKS_ON_OPEN - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
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_READONLY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
DEFAULT_REGION_MEMSTORE_REPLICATION - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
DEFAULT_REGION_MEMSTORE_REPLICATION - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
DEFAULT_REGION_REPLICA_WAIT_FOR_PRIMARY_FLUSH - Static variable in class org.apache.hadoop.hbase.client.RegionReplicaUtil
 
DEFAULT_REGION_REPLICATION - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
DEFAULT_REGION_REPLICATION - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
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_REPLICATION_SCOPE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_SOCKET_TIMEOUT_CONNECT - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
 
DEFAULT_SOCKET_TIMEOUT_READ - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
 
DEFAULT_SOCKET_TIMEOUT_WRITE - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
 
DEFAULT_TTL - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Default time to live of cell contents.
DEFAULT_TTL - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_VERSIONS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DefaultVisitorBase() - Constructor for class org.apache.hadoop.hbase.MetaTableAccessor.DefaultVisitorBase
 
DelayingRunner - Class in org.apache.hadoop.hbase.client
A wrapper for a runnable for a group of actions for a single regionserver.
DelayingRunner(long, Map.Entry<byte[], List<Action>>) - Constructor for class org.apache.hadoop.hbase.client.DelayingRunner
 
delegatee - Variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
delegatee - Variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
DelegatingHBaseRpcController - Class in org.apache.hadoop.hbase.ipc
Simple delegating controller for use with the RpcControllerFactory to help override standard behavior of a HBaseRpcController.
DelegatingHBaseRpcController(HBaseRpcController) - Constructor for class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
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
 
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 class org.apache.hadoop.hbase.client.HTable
 
delete(List<Delete>) - Method in class org.apache.hadoop.hbase.client.HTable
 
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.
deleteAll(List<Delete>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
A simple version of batch delete.
deleteCachedRegionLocation(HRegionLocation) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Deletes cached locations for the specific region.
deleteColumn(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
As of release 2.0.0. This will be removed in HBase 3.0.0. Use Admin.deleteColumnFamily(TableName, byte[])}.
deleteColumn(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Deprecated.
Since 2.0. Will be removed in 3.0. Use HBaseAdmin.deleteColumnFamily(TableName, byte[]) instead.
deleteColumn(RpcController, MasterProtos.DeleteColumnRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
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.
deleteColumnFamily(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
deleteColumnFamilyAsync(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Delete a column family from a table.
deleteColumnFamilyAsync(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
deleteMergeQualifiers(Connection, RegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Deletes merge qualifiers for the specified merged region.
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.
deleteNamespace(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
deleteNamespace(RpcController, MasterProtos.DeleteNamespaceRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
deleteNamespaceAsync(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Delete an existing namespace.
deleteNamespaceAsync(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
deleteRegion(Connection, RegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Deletes the specified region from META.
deleteRegions(Connection, List<RegionInfo>) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Deletes the specified regions from META.
deleteRegions(Connection, List<RegionInfo>, long) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Deletes the specified regions from META.
deleteSnapshot(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Delete an existing snapshot.
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.
deleteSnapshot(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
deleteSnapshot(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
deleteSnapshot(RpcController, MasterProtos.DeleteSnapshotRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
deleteSnapshots(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.0 version and will be removed in 3.0 version. Use Admin.deleteSnapshots(Pattern) instead.
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.
deleteSnapshots(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
deleteSnapshots(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
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.client.HBaseAdmin
 
deleteTable(RpcController, MasterProtos.DeleteTableRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
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.
deleteTableAsync(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
deleteTables(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.0 version and will be removed in 3.0 version This is just a trivial helper method without any magic. Consider using Admin.listTableDescriptors(Pattern) and Admin.deleteTable(TableName)
deleteTables(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.0 version and will be removed in 3.0 version This is just a trivial helper method without any magic. Consider using Admin.listTableDescriptors(java.util.regex.Pattern) and Admin.deleteTable(TableName)
deleteTables(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
deleteTables(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Delete tables matching the passed in pattern and wait on completion.
deleteTableSnapshots(String, String) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.0 version and will be removed in 3.0 version. Use Admin.deleteTableSnapshots(Pattern, Pattern) instead.
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.
deleteTableSnapshots(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
deleteTableSnapshots(Pattern, Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
deleteTableState(Connection, TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Remove state for table from meta
deleteTracker - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
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, CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.DependentColumnFilter
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.
DFS_REPLICATION - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
DFS_REPLICATION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
disablePeer(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
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
disableReplicationPeer(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
disableReplicationPeer(RpcController, ReplicationProtos.DisableReplicationPeerRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
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.
disableTable(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
disableTable(RpcController, MasterProtos.DisableTableRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
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.
disableTableAsync(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
disableTableRep(TableName) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
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.
disableTableReplication(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
disableTables(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.0 version and will be removed in 3.0 version This is just a trivial helper method without any magic. Consider using Admin.listTableDescriptors(Pattern) and Admin.disableTable(org.apache.hadoop.hbase.TableName)
disableTables(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.0 version and will be removed in 3.0 version This is just a trivial helper method without any magic. Consider using Admin.listTableDescriptors(java.util.regex.Pattern) and Admin.disableTable(org.apache.hadoop.hbase.TableName)
disableTables(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
disableTables(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
disableWriteBufferPeriodicFlush() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
Disable periodic flushing of the write buffer.
DISPLAY_KEYS_KEY - Static variable in class org.apache.hadoop.hbase.client.RegionInfoDisplay
 
dispose() - Method in class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
Release resources used by wrapped saslClient
divideForAvg(BigDecimal, Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
divideForAvg(Double, Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
divideForAvg(Long, Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
divideForAvg(S, Long) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
used for computing average of <S> data values.
doBatchWithCallback(List<? extends Row>, Object[], Batch.Callback<R>, ClusterConnection, ExecutorService, TableName) - Static method in class org.apache.hadoop.hbase.client.HTable
 
doCall() - Method in class org.apache.hadoop.hbase.client.AsyncAdminRequestRetryingCaller
 
doCall() - Method in class org.apache.hadoop.hbase.client.AsyncMasterRequestRpcRetryingCaller
 
doCall() - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
 
doCall() - Method in class org.apache.hadoop.hbase.client.AsyncServerRequestRpcRetryingCaller
 
doGet(ClientProtos.GetRequest) - Method in class org.apache.hadoop.hbase.client.ClientServiceCallable
 
doGet(Connection, Get) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
doGet(Connection, List<Get>) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
doLoadColumnFamiliesOnDemand() - Method in class org.apache.hadoop.hbase.client.Query
Get the logical value indicating whether on-demand CF loading should be allowed.
doMutate(ClientProtos.MutateRequest) - Method in class org.apache.hadoop.hbase.client.ClientServiceCallable
 
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
default constructor
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(Throwable) - Constructor for exception org.apache.hadoop.hbase.client.DoNotRetryRegionException
 
DoubleColumnInterpreter - Class in org.apache.hadoop.hbase.client.coprocessor
a concrete column interpreter implementation.
DoubleColumnInterpreter() - Constructor for class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
drainingZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
 
dropDependentColumn - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
dropDependentColumn() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
DroppedSnapshotException - Exception in org.apache.hadoop.hbase
Thrown during flush if the possibility snapshot content was not properly persisted into store files.
DroppedSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.DroppedSnapshotException
 
DroppedSnapshotException() - Constructor for exception org.apache.hadoop.hbase.DroppedSnapshotException
default constructor
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.
DURABILITY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 

E

E - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'E'
EMPTY_RESULT - Static variable in class org.apache.hadoop.hbase.client.Result
 
EMPTY_SERVERLOAD - Static variable in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerMetricsBuilder.of(ServerName) instead.
enableCatalogJanitor(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use Admin.catalogJanitorSwitch(boolean)} instead.
enableCatalogJanitor(RpcController, MasterProtos.EnableCatalogJanitorRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
enablePeer(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
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
enableReplicationPeer(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
enableReplicationPeer(RpcController, ReplicationProtos.EnableReplicationPeerRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
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.
enableTable(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
enableTable(RpcController, MasterProtos.EnableTableRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
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.
enableTableAsync(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
enableTableRep(TableName) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
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.
enableTableReplication(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
enableTables(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.0 version and will be removed in 3.0 version This is just a trivial helper method without any magic. Consider using Admin.listTableDescriptors(Pattern) and Admin.enableTable(org.apache.hadoop.hbase.TableName)
enableTables(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.0 version and will be removed in 3.0 version This is just a trivial helper method without any magic. Consider using Admin.listTableDescriptors(java.util.regex.Pattern) and Admin.enableTable(org.apache.hadoop.hbase.TableName)
enableTables(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
enableTables(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
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_ON_DISK - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
ENCODED_REGION_NAME_REGEX - Static variable in class org.apache.hadoop.hbase.client.RegionInfoBuilder
A non-capture group so that this can be embedded.
ENCODED_REGION_NAME_REGEX - Static variable in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
A non-capture group so that this can be embedded.
encodeRegionName(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
 
encodeRegionName(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.encodeRegionName(byte[]).
ENCRYPTION - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
ENCRYPTION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
ENCRYPTION_KEY - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
ENCRYPTION_KEY - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
EncryptionUtil - Class in org.apache.hadoop.hbase.security
Some static utility methods for encryption uses in hbase-client.
ensureConnectedZooKeeper(ZooKeeper, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperHelper
Ensure passed zookeeper is connected.
Entry() - Constructor for class org.apache.hadoop.hbase.client.SingleResponse.Entry
 
entrySet() - Method in class org.apache.hadoop.hbase.util.PoolMap
 
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(Object) - Method in class org.apache.hadoop.hbase.client.Action
 
equals(Object) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
equals(Object) - Method in class org.apache.hadoop.hbase.client.Get
 
equals(Object) - Method in class org.apache.hadoop.hbase.client.Increment
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Row.COMPARATOR instead
equals(Object) - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
 
equals(Object) - Method in class org.apache.hadoop.hbase.client.RowMutations
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. No replacement
equals(Object) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Compare the contents of the descriptor with another one passed as a parameter.
equals(Object) - Method in class org.apache.hadoop.hbase.client.TableState
 
equals(Object) - Method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.BigDecimalComparator
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.NullComparator
 
equals(Object) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
equals(Object) - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
 
equals(Object) - Method in class org.apache.hadoop.hbase.HRegionLocation
 
equals(Object) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Compare the contents of the descriptor with another one passed as a parameter.
equals(Object) - Method in class org.apache.hadoop.hbase.master.RegionState
Check if two states are the same, except timestamp
equals(Object) - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
 
equals(Object) - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot.SpaceQuotaStatus
 
equals(Object) - Method in class org.apache.hadoop.hbase.security.access.Permission
 
equals(Object) - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
equals(Object) - Method in class org.apache.hadoop.hbase.security.access.UserPermission
 
equals(Object) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
equals(Object) - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
 
equals(Object) - Method in class org.apache.hadoop.hbase.Size
 
errorText() - Method in class org.apache.hadoop.hbase.client.ClientCoprocessorRpcController
 
errorText() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
errorText() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
errorText() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
 
evaluateChallenge(byte[]) - Method in class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
 
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
 
EVICT_BLOCKS_ON_CLOSE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.hadoop.hbase.security.NettyHBaseRpcConnectionHeaderHandler
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClientHandler
 
EXEC_PERMISSION_CHECKS_KEY - Static variable in interface org.apache.hadoop.hbase.security.access.AccessControlConstants
Configuration option that toggles whether EXEC permission checking is performed during coprocessor endpoint invocations.
execMasterService(RpcController, ClientProtos.CoprocessorServiceRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
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.
execProcedure(String, String, Map<String, String>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
execProcedure(RpcController, MasterProtos.ExecProcedureRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
execProcedureWithRet(String, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use Admin.execProcedureWithReturn(String, String, Map) } instead.
execProcedureWithRet(RpcController, MasterProtos.ExecProcedureRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
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.
execProcedureWithReturn(String, String, Map<String, String>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
execute() - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CoprocessorServiceBuilder
Execute the coprocessorService request.
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 class org.apache.hadoop.hbase.client.HTable
 
exists(List<Get>) - Method in class org.apache.hadoop.hbase.client.HTable
 
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.
exists(String) - Method in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
 
existsAll(List<Get>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
A simple version for batch exists.
existsAll(List<Get>) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
since 2.0 version and will be removed in 3.0 version. use Table.exists(List)
expectPBMagicPrefix(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
expectPBMagicPrefix(byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
expirationDate - Variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
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
 
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
 
extractArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.CompareFilter
 
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
extractQuotaSnapshot(Result, Map<TableName, SpaceQuotaSnapshot>) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
Extracts the SpaceViolationPolicy and TableName from the provided Result and adds them to the given Map.
extractSnapshotNameFromSizeCell(Cell) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
extractSnapshotSize(byte[], int, int) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
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

failed() - Method in class org.apache.hadoop.hbase.client.ClientCoprocessorRpcController
 
failed() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
failed() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
failed() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
 
FAILED_SERVER_EXPIRY_DEFAULT - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
 
FAILED_SERVER_EXPIRY_KEY - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
 
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
 
failedOnException() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
Returns whether or not a server exception was generated in the prior RPC invocation.
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
 
failedServers - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
FailedServers - Class in org.apache.hadoop.hbase.ipc
A class to manage a list of servers that failed recently.
FailedServers(Configuration) - Constructor for class org.apache.hadoop.hbase.ipc.FailedServers
 
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
 
failureSleep - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
fallbackAllowed - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
fallbackAllowed - Variable in class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
 
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
 
FamilyFilter - Class in org.apache.hadoop.hbase.filter
This filter is used to filter based on the column family.
FamilyFilter(CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.FamilyFilter
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use FamilyFilter.FamilyFilter(CompareOperator, ByteArrayComparable)
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
 
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.ReturnCode - Enum in org.apache.hadoop.hbase.filter
Return codes for filterValue().
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.FilterBase
Filters that never filter all remaining can inherit this implementation that never stops the filter early.
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.FilterList
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.FilterListWithAND
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.FilterListWithOR
 
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
 
FilterBase - Class in org.apache.hadoop.hbase.filter
Abstract base class to help you implement new Filters.
FilterBase() - Constructor for class org.apache.hadoop.hbase.filter.FilterBase
 
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.FilterListWithAND
 
filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterListWithOR
 
filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
Deprecated.
 
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
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
Deprecated.
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
Deprecated.
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
Deprecated.
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
Deprecated.
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
Deprecated.
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.FamilyFilter
Deprecated.
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.Filter
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Instead use filterCell(Cell)
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterList
Deprecated.
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterListBase
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
Deprecated.
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
Deprecated.
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
Deprecated.
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
Deprecated.
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
Deprecated.
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
Deprecated.
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
Deprecated.
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.PageFilter
Deprecated.
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
Deprecated.
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.QualifierFilter
Deprecated.
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
Deprecated.
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.RowFilter
Deprecated.
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Deprecated.
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
Deprecated.
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
Deprecated.
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.ValueFilter
Deprecated.
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
Deprecated.
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
FilterListBase - Class in org.apache.hadoop.hbase.filter
Base class for FilterList.
FilterListBase(List<Filter>) - Constructor for class org.apache.hadoop.hbase.filter.FilterListBase
 
FilterListWithAND - Class in org.apache.hadoop.hbase.filter
FilterListWithAND represents an ordered list of filters which will be evaluated with an AND operator.
FilterListWithAND(List<Filter>) - Constructor for class org.apache.hadoop.hbase.filter.FilterListWithAND
 
FilterListWithOR - Class in org.apache.hadoop.hbase.filter
FilterListWithOR represents an ordered list of filters which will be evaluated with an OR operator.
FilterListWithOR(List<Filter>) - Constructor for class org.apache.hadoop.hbase.filter.FilterListWithOR
 
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.FilterBase
Filters that never filter by rows based on previously gathered state from Filter.filterCell(Cell) can inherit this implementation that never filters a row.
filterRow() - Method in class org.apache.hadoop.hbase.filter.FilterList
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.FilterListWithAND
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.FilterListWithOR
 
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.FilterBase
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.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.FilterListBase
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(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.Filter
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Instead use Filter.filterRowKey(Cell)
filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.Filter
Filters a row based on the row key.
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.FilterBase
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Instead use FilterBase.filterRowKey(Cell)
filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterBase
 
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.FilterListWithAND
 
filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterListWithAND
 
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.FilterListWithOR
 
filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterListWithOR
 
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(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
filters - Variable in class org.apache.hadoop.hbase.filter.FilterListBase
 
findException(Object) - Static method in class org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
Look for an exception we know in the remote exception: - hadoop.ipc wrapped exceptions - nested exceptions Looks for: RegionMovedException / RegionOpeningException / RegionTooBusyException / RpcThrottlingException
FIRST_META_REGIONINFO - Static variable in class org.apache.hadoop.hbase.client.RegionInfoBuilder
RegionInfo for first meta region You cannot use this builder to make an instance of the RegionInfoBuilder.FIRST_META_REGIONINFO.
FIRST_META_REGIONINFO - Static variable in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
HRegionInfo for first meta region
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. See HBASE-13347
FirstKeyValueMatchingQualifiersFilter(Set<byte[]>) - Constructor for class org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
Deprecated.
Constructor which takes a set of columns.
flush(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Flush a table.
flush(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Flush a 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.client.BufferedMutatorImpl
 
flush(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
flush(ChannelHandlerContext) - Method in class org.apache.hadoop.hbase.security.CryptoAESWrapHandler
 
flush(ChannelHandlerContext) - Method in class org.apache.hadoop.hbase.security.SaslWrapHandler
 
FLUSH_POLICY - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
FLUSH_POLICY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
flushRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Flush an individual region.
flushRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Flush an individual region.
flushRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
FlushRegionCallable - Class in org.apache.hadoop.hbase.client
A Callable for flushRegion() RPC.
FlushRegionCallable(ClusterConnection, RpcControllerFactory, TableName, byte[], byte[], boolean) - Constructor for class org.apache.hadoop.hbase.client.FlushRegionCallable
 
FlushRegionCallable(ClusterConnection, RpcControllerFactory, RegionInfo, boolean) - Constructor for class org.apache.hadoop.hbase.client.FlushRegionCallable
 
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.
flushRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
FOREVER - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
formatLogFilters(List<Filter>) - Method in class org.apache.hadoop.hbase.filter.FilterListBase
 
formatLogFilters(List<Filter>) - Method in class org.apache.hadoop.hbase.filter.FilterListWithAND
 
formatLogFilters(List<Filter>) - Method in class org.apache.hadoop.hbase.filter.FilterListWithOR
 
formatTime(long) - Static method in exception org.apache.hadoop.hbase.quotas.ThrottlingException
Deprecated.
 
foundColumn - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
fromByte(byte) - Static method in enum org.apache.hadoop.hbase.client.IsolationLevel
 
fromBytes(byte[]) - Static method in enum org.apache.hadoop.hbase.client.IsolationLevel
 
fromDeleteType(ClientProtos.MutationProto.DeleteType) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer DeleteType to delete KeyValue type.
fromDeleteType(ClientProtos.MutationProto.DeleteType) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a protocol buffer DeleteType to delete KeyValue type.
fromRow(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CoprocessorServiceBuilder
 
fromRow(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CoprocessorServiceBuilder
 
fromThrottle(String, TableName, String, QuotaProtos.Throttle) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
 
fullScan(Connection, MetaTableAccessor.QueryType) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Performs a full scan of hbase:meta.
fullScanMetaAndPrint(Connection) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
 
fullScanRegions(Connection, MetaTableAccessor.Visitor) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Performs a full scan of hbase:meta for regions.
fullScanRegions(Connection) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Performs a full scan of hbase:meta for regions.
fullScanTables(Connection, MetaTableAccessor.Visitor) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Performs a full scan of hbase:meta for tables.
future - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
 
fuzzyMatch(String) - Static method in enum org.apache.hadoop.hbase.util.PoolMap.PoolType
 
fuzzyNormalize(String) - Static method in enum org.apache.hadoop.hbase.util.PoolMap.PoolType
 
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

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() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
get(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
get(Get) - Method in class org.apache.hadoop.hbase.client.HTable
 
get(List<Get>) - Method in class org.apache.hadoop.hbase.client.HTable
 
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() - Static method in class org.apache.hadoop.hbase.client.PerClientRandomNonceGenerator
Get the singleton nonce generator.
get - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
 
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.ipc.BlockingRpcCallback
Returns the parameter passed to BlockingRpcCallback.run(Object) or null if a null value was passed.
get() - Method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils.BlockingRpcCallback
Returns the parameter passed to CoprocessorRpcUtils.BlockingRpcCallback.run(Object) or null if a null value was passed.
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(Object) - Method in class org.apache.hadoop.hbase.util.PoolMap
 
get() - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
 
get() - Method in class org.apache.hadoop.hbase.util.PoolMap.ReusablePool
 
get(String) - Method in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
 
getACL() - Method in class org.apache.hadoop.hbase.client.Mutation
 
getACL() - Method in class org.apache.hadoop.hbase.client.Query
 
getAction() - Method in class org.apache.hadoop.hbase.client.Action
 
getActions() - Method in class org.apache.hadoop.hbase.client.DelayingRunner
 
getActions() - Method in class org.apache.hadoop.hbase.security.access.Permission
 
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(ServerName) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Establishes a connection to the region server at the specified address.
getAdmin() - Method in interface org.apache.hadoop.hbase.client.Connection
Retrieve an Admin implementation to administer an HBase cluster.
getAdmin(ServerName) - Method in class org.apache.hadoop.hbase.client.ConnectionUtils.ShortCircuitingClusterConnection
 
getAdmin() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
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.
getAdminForMaster() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Get the admin service for master.
getAgeOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSink
 
getAgeOfLastShippedOp() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
 
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
getAllowPartialResults() - Method in class org.apache.hadoop.hbase.client.Scan
 
getAllRegionLocations() - Method in class org.apache.hadoop.hbase.client.HRegionLocator
 
getAllRegionLocations() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
Retrieves all of the regions associated with this table.
getAllRegions(Connection, boolean) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Lists all of the regions currently in META.
getAllRSGroupInfo(Connection) - Static method in class org.apache.hadoop.hbase.RSGroupTableAccessor
 
getAlterStatus(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. No longer needed now you get a Future on an operation.
getAlterStatus(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. No longer needed now you get a Future on an operation.
getAlterStatus(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getAlterStatus(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getAsyncProcess() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
 
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
 
getAuthorizations() - Method in class org.apache.hadoop.hbase.client.Query
 
getAuths(Configuration, String) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
getAuths(Connection, String) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
 
getAverageLatencyForEachRegionServer() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
getAverageLoad() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
 
getBackoffPolicy() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
 
getBackoffTime(ServerName, byte[], ServerStatistics) - Method in interface org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicy
 
getBackoffTime(ServerName, byte[], ServerStatistics) - Method in class org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicyFactory.NoBackoffPolicy
 
getBackoffTime(ServerName, byte[], ServerStatistics) - Method in class org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
 
getBackupMasterNames() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
 
getBackupMasterNames() - Method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
 
getBackupMasters() - Method in interface org.apache.hadoop.hbase.client.Admin
 
getBackupMasters() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
 
getBackupMasters() - Method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ClusterStatus.getBackupMasterNames() instead.
getBackupMastersSize() - Method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ClusterStatus.getBackupMasterNames() instead.
getBalancerOn() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
 
getBalancerOn() - Method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
 
getBandwidth() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
getBatch() - Method in class org.apache.hadoop.hbase.client.Scan
 
getBlocksize() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
 
getBlocksize() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
getBlocksize() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
getBloomFilterSize() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
 
getBloomFilterSize() - Method in interface org.apache.hadoop.hbase.RegionMetrics
 
getBloomFilterType() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
 
getBloomFilterType() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
getBloomFilterType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
getBufferedCounterForEachRegionServer() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
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
getBytes(Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
 
getBytes(Writable...) - Static method in class org.apache.hadoop.hbase.util.Writables
Put a bunch of Writables as bytes all into the one byte array.
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.
getCacheCount() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
getCachedLocation(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.MetaCache
Search the cache for a location that fits our table and row key.
getCacheSize() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
getCaching() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
getCaching() - Method in class org.apache.hadoop.hbase.client.Scan
 
getCaching() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
Get the number of rows that will be fetched on next
getCallback() - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask
 
getCallTimeMs() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
getCallTimeout() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
getCallTimeout() - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
 
getCallTimeout() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
getCause(int) - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
getCauses() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
getCellValueFromProto(HBaseProtos.BigDecimalMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
getCellValueFromProto(HBaseProtos.DoubleMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
getCellValueFromProto(HBaseProtos.LongMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
getCellValueFromProto(Q) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
This method gets the PB message corresponding to the cell type
getCellVisibility() - Method in class org.apache.hadoop.hbase.client.Mutation
 
getChance() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
getClassLoader() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
 
getClassName() - Method in interface org.apache.hadoop.hbase.client.CoprocessorDescriptor
 
getClient(ServerName) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Establishes a connection to the region server at the specified address, and returns a region client protocol.
getClient(ServerName) - Method in class org.apache.hadoop.hbase.client.ConnectionUtils.ShortCircuitingClusterConnection
 
getClusterId() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
 
getClusterId() - Method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
 
getClusterIds() - Method in class org.apache.hadoop.hbase.client.Mutation
 
getClusterKey() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
getClusterMetrics() - Method in interface org.apache.hadoop.hbase.client.Admin
Get whole cluster metrics, containing status about:
getClusterMetrics(EnumSet<ClusterMetrics.Option>) - Method in interface org.apache.hadoop.hbase.client.Admin
Get cluster status with a set of ClusterMetrics.Option to get desired status.
getClusterMetrics() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
 
getClusterMetrics(EnumSet<ClusterMetrics.Option>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
 
getClusterMetrics(EnumSet<ClusterMetrics.Option>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getClusterStatus() - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.0 version and will be removed in 3.0 version. use Admin.getClusterMetrics()
getClusterStatus(RpcController, MasterProtos.GetClusterStatusRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
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.
getColumnFamilies() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
 
getColumnFamilies() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
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.
getColumnFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Returns the ColumnFamilyDescriptor for a specific column family with name as specified by the parameter column.
getColumnFamily(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
getColumnFamilyCount() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
Returns the count of the column families of the table.
getColumnFamilyCount() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
 
getColumnFamilyCount() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
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.
getColumnFamilyNames() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Returns all the column family names of the current table.
getColumnFamilyNames() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
getColumnFamilyTimeRange() - Method in class org.apache.hadoop.hbase.client.Query
 
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 class org.apache.hadoop.hbase.RegionLoad
Deprecated.
 
getCompactedCellCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
 
getCompactingCellCount() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
 
getCompactingCellCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
 
getCompactionCompression() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 (HBASE-13655). Use HColumnDescriptor.getCompactionCompressionType().
getCompactionCompressionType() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
 
getCompactionCompressionType() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
getCompactionCompressionType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
getCompactionPressure() - Method in class org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
 
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(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getCompactionState(TableName, CompactType) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Get the current compaction state of a table.
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.
getCompactionStateForRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getComparator(Comparator<ColumnFamilyDescriptor>) - Static method in interface org.apache.hadoop.hbase.client.TableDescriptor
 
getComparator() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
 
getComparator() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
getComparator() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
getComparator() - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
Use Region#getCellComparator(). deprecated for hbase 2.0, remove for hbase 3.0
getCompareOperator() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
 
getCompareOperator() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
getCompareOperator() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
getCompletedSequenceId() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
 
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.
getCompletedSnapshots(RpcController, MasterProtos.GetCompletedSnapshotsRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
getCompleteSequenceId() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getCompletedSequenceId() instead.
getCompression() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 (HBASE-13655). Use HColumnDescriptor.getCompressionType().
getCompressionType() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
 
getCompressionType() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
getCompressionType() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
getCompressionType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
getConcurrentCallsPerServer() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
getConf() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
getConfiguration() - Method in interface org.apache.hadoop.hbase.client.Admin
 
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 class org.apache.hadoop.hbase.client.BufferedMutatorImpl
 
getConfiguration() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
 
getConfiguration() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
getConfiguration() - Method in interface org.apache.hadoop.hbase.client.Connection
 
getConfiguration() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getConfiguration() - Method in class org.apache.hadoop.hbase.client.HRegionLocator
 
getConfiguration() - Method in class org.apache.hadoop.hbase.client.HTable
 
getConfiguration() - Method in interface org.apache.hadoop.hbase.client.Table
Returns the Configuration object used by this instance.
getConfiguration() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
 
getConfiguration() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
getConfiguration() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Getter for fetching an unmodifiable map.
getConfiguration() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
getConfigurationValue(String) - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
 
getConfigurationValue(String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
getConfigurationValue(String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
getConfigurationValue(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Getter for accessing the configuration value by key
getConnectedZooKeeper(String, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperHelper
Get a ZooKeeper instance and wait until it connected before returning.
getConnection() - Method in interface org.apache.hadoop.hbase.client.Admin
 
getConnection() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
getConnection() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getConnection() - Method in class org.apache.hadoop.hbase.client.HTable
INTERNAL Used by unit tests and tools to do low-level manipulations.
getConnection() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
 
getConnectionConfiguration() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
 
getConnectionMetrics() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
 
getConnectString() - Method in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
 
getConsistency() - Method in class org.apache.hadoop.hbase.client.Query
Returns the consistency level for this operation
getControllerException(RpcController) - Static method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
Retreivies exception stored during RPC invocation.
getControllerException(RpcController) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
Retreivies exception stored during RPC invocation.
getCoprocessorDescriptors() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
Return the list of attached co-processor represented
getCoprocessorDescriptors() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Return the list of attached co-processor represented by their name className
getCoprocessorDescriptors() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
getCoprocessorNames() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
 
getCoprocessorNames() - Method in interface org.apache.hadoop.hbase.ServerMetrics
Return the RegionServer-level and Region-level coprocessors
getCoprocessors() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use TableDescriptor.getCoprocessorDescriptors() instead
getCoprocessorServiceRequest(Descriptors.MethodDescriptor, Message) - Static method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
 
getCoprocessorServiceRequest(Descriptors.MethodDescriptor, Message, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
 
getCounter(String) - Method in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
 
getCreationTime() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
 
getCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getCompactedCellCount() instead.
getCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
getCurrentNrHRS() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
 
getCurrentSnapshot(Connection, TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
Returns the Master's view of a quota on the given tableName or null if the Master has no quota information on that table.
getCurrentSnapshot(Connection, String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
Returns the Master's view of a quota on the given namespace or null if the Master has no quota information on that namespace.
getCursor() - Method in class org.apache.hadoop.hbase.client.Result
Return the cursor if this Result is a cursor result.
getCursor() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
getDataBlockEncoding() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
 
getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
getDataLocality() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
 
getDataLocality() - Method in interface org.apache.hadoop.hbase.RegionMetrics
 
getDaughterRegions(Result) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Returns the daughter regions by reading the corresponding columns of the catalog table Result.
getDeadServerNames() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
 
getDeadServerNames() - Method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
 
getDeadServers() - Method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 (HBASE-13656). Use ClusterStatus.getDeadServerNames().
getDeadServersSize() - Method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ClusterStatus.getDeadServerNames().
getDefaultCodec(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
getDefaultExecutor(Configuration) - Static method in class org.apache.hadoop.hbase.client.HTable
 
getDefaultRegionLocation() - Method in class org.apache.hadoop.hbase.RegionLocations
 
getDefaultValues() - Static method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
getDefaultValues() - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
getDelegateeForModification() - Method in class org.apache.hadoop.hbase.client.ImmutableHColumnDescriptor
Deprecated.
 
getDelegateeForModification() - Method in class org.apache.hadoop.hbase.client.ImmutableHTableDescriptor
Deprecated.
 
getDelegateeForModification() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
getDelegateeForModification() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
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 class org.apache.hadoop.hbase.client.HBaseAdmin.TableFuture
 
getDescriptiveNameFromRegionStateForDisplay(RegionState, Configuration) - Static method in class org.apache.hadoop.hbase.client.RegionInfoDisplay
Get the descriptive name as RegionState does it but with hidden startkey optionally
getDescriptiveNameFromRegionStateForDisplay(RegionState, Configuration) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfoDisplay#getDescriptiveNameFromRegionStateForDisplay(RegionState, Configuration) over in hbase-server module.
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(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getDescriptor() - Method in class org.apache.hadoop.hbase.client.HTable
 
getDescriptor() - Method in interface org.apache.hadoop.hbase.client.Table
Gets the table descriptor for this table.
getDFSReplication() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
 
getDFSReplication() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
getDFSReplication() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
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.
getDurability() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Returns the durability setting for the table.
getDurability() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Returns the durability setting for the table.
getEncodedName() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
 
getEncodedName() - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
 
getEncodedNameAsBytes() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
 
getEncodedNameAsBytes() - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
 
getEncryptionKey() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
 
getEncryptionKey() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
getEncryptionKey() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
getEncryptionType() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
 
getEncryptionType() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
getEncryptionType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
getEndKey() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
 
getEndKey() - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
 
getEndKeyForDisplay(RegionInfo, Configuration) - Static method in class org.apache.hadoop.hbase.client.RegionInfoDisplay
Get the end key for display.
getEndKeyForDisplay(HRegionInfo, Configuration) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfoDisplay#getEndKeyForDisplay(RegionInfo, Configuration) over in hbase-server module.
getEndKeys() - Method in class org.apache.hadoop.hbase.client.HRegionLocator
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.
getEntry() - Method in class org.apache.hadoop.hbase.client.SingleResponse
 
getErrors() - Method in interface org.apache.hadoop.hbase.client.AsyncRequestFuture
 
getEvictedBlocks() - Method in class org.apache.hadoop.hbase.CacheEvictionStats
 
getException(byte[]) - Method in class org.apache.hadoop.hbase.client.MultiResponse
 
getExceptionCount() - Method in class org.apache.hadoop.hbase.CacheEvictionStats
 
getExceptionMessage() - Method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
getExceptionMessageAdditionalDetail() - Method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
getExceptionMessageAdditionalDetail() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
 
getExceptionMessageAdditionalDetail() - Method in interface org.apache.hadoop.hbase.client.RetryingCallable
 
getExceptions() - Method in class org.apache.hadoop.hbase.CacheEvictionStats
 
getExceptions() - Method in class org.apache.hadoop.hbase.client.MultiResponse
 
getExcludeNamespaces() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
getExcludeTableCFsMap() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
getExecutedWriteBufferPeriodicFlushes() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
 
getExhaustiveDescription() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
getExists() - Method in class org.apache.hadoop.hbase.client.Result
 
getExpirationDate() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
getExpression() - Method in class org.apache.hadoop.hbase.security.visibility.CellVisibility
 
getFailed() - Method in class org.apache.hadoop.hbase.client.ClientCoprocessorRpcController
 
getFailed() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
getFailed() - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
Return the failed exception, null if not failed.
getFailed() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
getFailedCounterForEachRegionServer() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
getFailedOn() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
Returns any exception thrown during service method invocation, or null if no exception was thrown.
getFailedOperations() - Method in interface org.apache.hadoop.hbase.client.AsyncRequestFuture
 
getFailureCount() - Method in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
 
getFamilies() - Method in class org.apache.hadoop.hbase.client.Scan
 
getFamilies() - Method in class org.apache.hadoop.hbase.HTableDescriptor
getFamiliesKeys() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 (HBASE-18008). Use HTableDescriptor.getColumnFamilyNames().
getFamily() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
 
getFamily() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
getFamily() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
getFamily(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
getFamily() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
getFamilyCellMap() - Method in class org.apache.hadoop.hbase.client.Mutation
Method for retrieving the put's familyMap
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.
getFilter() - Method in class org.apache.hadoop.hbase.client.Query
 
getFilter() - Method in class org.apache.hadoop.hbase.client.Scan
 
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
getFilteredReadRequestCount() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
 
getFilteredReadRequestCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
 
getFilteredReadRequestsCount() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getFilteredReadRequestCount() instead.
getFilteredReadRequestsCount() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
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.
getFilters() - Method in class org.apache.hadoop.hbase.filter.FilterListBase
 
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.
getFirstFailureAt() - Method in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
 
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.
getFlushPolicyClassName() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
This gets the class associated with the flush policy which determines the stores need to be flushed when flushing a region.
getFlushPolicyClassName() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
This gets the class associated with the flush policy which determines the stores need to be flushed when flushing a region.
getHBaseVersion() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
 
getHBaseVersion() - Method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
 
getHBaseVersion() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
 
getHbck() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Retrieve an Hbck implementation to fix an HBase cluster.
getHbck(ServerName) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Retrieve an Hbck implementation to fix an HBase cluster.
getHeapOccupancy() - Method in class org.apache.hadoop.hbase.client.RegionLoadStats
 
getHeapOccupancyPercent() - Method in class org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
 
getHostname() - Method in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
 
getHostname() - Method in class org.apache.hadoop.hbase.HRegionLocation
 
getHostname() - Method in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
 
getHostnamePort(int) - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
getHostnamePort() - Method in class org.apache.hadoop.hbase.HRegionLocation
 
getHRegionInfo() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
 
getHRegionInfo() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
getHTableMultiplexerStatus() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
 
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.
getImplementationClassName() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
 
getInfo(String) - Static method in class org.apache.hadoop.hbase.security.SecurityInfo
Returns the security configuration associated with the given service name.
getInfoServerPort() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
 
getInfoServerPort() - Method in interface org.apache.hadoop.hbase.ServerMetrics
 
getInitialResponse() - Method in class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
 
getInMemoryCompaction() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
 
getInMemoryCompaction() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
getInMemoryCompaction() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
getInputStream() - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
Get a SASL wrapped InputStream.
getInstance() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
 
getIsolationLevel() - Method in class org.apache.hadoop.hbase.client.Query
 
getIssueDate() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
getJarPath() - Method in interface org.apache.hadoop.hbase.client.CoprocessorDescriptor
 
getKeepDeletedCells() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
 
getKeepDeletedCells() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
getKeepDeletedCells() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
getKeyId() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
getKind() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
getLabels() - Method in class org.apache.hadoop.hbase.security.visibility.Authorizations
 
getLastAttemptAt() - Method in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
 
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 class org.apache.hadoop.hbase.client.HBaseAdmin
 
getLastMajorCompactionTimestamp(RpcController, MasterProtos.MajorCompactionTimestampRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
getLastMajorCompactionTimestamp(TableName) - Method in interface org.apache.hadoop.hbase.ClusterMetrics
 
getLastMajorCompactionTimestamp(byte[]) - Method in interface org.apache.hadoop.hbase.ClusterMetrics
 
getLastMajorCompactionTimestamp() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
 
getLastMajorCompactionTimestamp() - Method in interface org.apache.hadoop.hbase.RegionMetrics
 
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.
getLastMajorCompactionTimestampForRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getLastMajorCompactionTimestampForRegion(RpcController, MasterProtos.MajorCompactionTimestampForRegionRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
getLastMajorCompactionTs() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getLastMajorCompactionTimestamp() instead.
getLastMajorCompactionTsForRegion(byte[]) - Method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ClusterMetrics.getLastMajorCompactionTimestamp(byte[]) instead.
getLastMajorCompactionTsForTable(TableName) - Method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ClusterMetrics.getLastMajorCompactionTimestamp(TableName) instead.
getLastReportTimestamp() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
 
getLastReportTimestamp() - Method in interface org.apache.hadoop.hbase.ServerMetrics
 
getLatestVersionOnly() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Get whether only the latest version of the column value should be compared.
getLimit() - Method in class org.apache.hadoop.hbase.client.Scan
 
getLimit() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
getLimit() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
getLimit() - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
Returns the limit, in bytes, of the target (e.g.
getListener() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
 
getLiveServerMetrics() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
 
getLiveServerMetrics() - Method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
 
getLoad(ServerName) - Method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ClusterStatus.getLiveServerMetrics() instead.
getLoad() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getNumberOfRegions() instead.
getLoadColumnFamiliesOnDemandValue() - Method in class org.apache.hadoop.hbase.client.Query
Get the raw loadColumnFamiliesOnDemand setting; if it's not set, can be null.
getLoadSequence() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
 
getLocation(boolean) - Method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
getLocation() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
 
getLocationSeqNum() - Method in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
 
getLocks() - Method in interface org.apache.hadoop.hbase.client.Admin
Get locks.
getLocks() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
List locks.
getLocks() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getLocks(RpcController, MasterProtos.GetLocksRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
getLongValue() - Method in class org.apache.hadoop.hbase.Size
get the value
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
 
getMaster() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
 
getMaster() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Returns a MasterKeepAliveConnection to the active master
getMaster() - Method in class org.apache.hadoop.hbase.client.ConnectionUtils.ShortCircuitingClusterConnection
 
getMaster() - Method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ClusterStatus.getMasterName() instead.
getMasterCoprocessorNames() - Method in interface org.apache.hadoop.hbase.client.Admin
Helper that delegates to getClusterMetrics().getMasterCoprocessorNames().
getMasterCoprocessorNames() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
 
getMasterCoprocessorNames() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
 
getMasterCoprocessorNames() - Method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
 
getMasterCoprocessors() - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.0 version and will be removed in 3.0 version. use Admin.getMasterCoprocessorNames()
getMasterCoprocessors() - Method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ClusterStatus.getMasterCoprocessorNames() instead.
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
 
getMasterInfoPort() - Method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
 
getMasterName() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
Returns detailed information about the current master ServerName.
getMasterName() - Method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
 
getMasterQuotaStates(ClusterConnection, int) - Static method in class org.apache.hadoop.hbase.client.QuotaStatusCalls
getMasterQuotaStates(Connection, RpcControllerFactory, RpcRetryingCallerFactory, int) - Static method in class org.apache.hadoop.hbase.client.QuotaStatusCalls
Executes an RPC tot he HBase master to fetch its view on space quotas.
getMasterRegionSizes(ClusterConnection, int) - Static method in class org.apache.hadoop.hbase.client.QuotaStatusCalls
getMasterRegionSizes(Connection, RpcControllerFactory, RpcRetryingCallerFactory, int) - Static method in class org.apache.hadoop.hbase.client.QuotaStatusCalls
Executes an RPC to the HBase master to fetch its view on the Region sizes.
getMasterReportedTableSizes(Connection) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
Fetches the table sizes on the filesystem as tracked by the HBase Master.
getMaxCacheSize() - Method in class org.apache.hadoop.hbase.CacheEvictionStats
 
getMaxColumn() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
getMaxColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
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.
getMaxFileSize() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Returns the maximum size upto which a region can grow to after which a region split is triggered.
getMaxFileSize() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Returns the maximum size upto which a region can grow to after which a region split is triggered.
getMaxHeapMB() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getMaxHeapSize() instead.
getMaxHeapSize() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
 
getMaxHeapSize() - Method in interface org.apache.hadoop.hbase.ServerMetrics
 
getMaxKeyValueSize() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
 
getMaxKeyValueSize() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getMaxKeyValueSize(Configuration) - Static method in class org.apache.hadoop.hbase.client.HTable
 
getMaxLatency() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
getMaxLatencyForEachRegionServer() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
getMaxPriority() - Method in class org.apache.hadoop.hbase.client.RowMutations
 
getMaxResultSize() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
getMaxResultSize() - Method in class org.apache.hadoop.hbase.client.Scan
 
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
 
getMaxValue() - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
getMaxValue() - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
getMaxValue() - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
getMaxValue() - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
returns the maximum value for this type T
getMaxVersions() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
 
getMaxVersions() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
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
 
getMaxVersions() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
getMechanismName() - Method in enum org.apache.hadoop.hbase.security.AuthMethod
Return the SASL mechanism name
getMemStoreFlushSize() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
Returns the size of the memstore after which a flush to filesystem is triggered.
getMemStoreFlushSize() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Returns the size of the memstore after which a flush to filesystem is triggered.
getMemStoreFlushSize() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Returns the size of the memstore after which a flush to filesystem is triggered.
getMemstoreLoad() - Method in class org.apache.hadoop.hbase.client.RegionLoadStats
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use RegionLoadStats.getMemStoreLoad() instead
getMemStoreLoad() - Method in class org.apache.hadoop.hbase.client.RegionLoadStats
 
getMemStoreLoadPercent() - Method in class org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
 
getMemStoreSize() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
 
getMemStoreSize() - Method in interface org.apache.hadoop.hbase.RegionMetrics
 
getMemstoreSizeInMB() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
getMemStoreSizeMB() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getMemStoreSize() instead.
getMemStoreSizeMB() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
getMergeRegions(Result) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Returns the merge regions by reading the corresponding columns of the catalog table Result.
getMessage() - Method in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
 
getMetaHTable(Connection) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Callers should call close on the returned Table instance.
getMetaKeyForRegion(RegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Returns the row key to use for this regionInfo
getMetaOperationTimeout() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getMetaReplicaCallTimeoutMicroSecondScan() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getMetaReplicaIdFromZnode(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
Parse the meta replicaId from the passed znode
getMethod() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
 
getMethodDescriptor(String, Descriptors.ServiceDescriptor) - Static method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
 
getMetricsMap() - Method in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
Get all of the values since the last time this function was called.
getMetricsMap(boolean) - Method in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
Get all of the values.
getMin() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
Gets the minimum timestamp requested by filter.
getMinColumn() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
getMinColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
getMinValue() - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
getMinValue() - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
getMinValue() - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
getMinValue() - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
 
getMinVersions() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
 
getMinVersions() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
getMinVersions() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
getMobCompactPartitionPolicy() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
Get the mob compact partition policy for this family
getMobCompactPartitionPolicy() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
getMobCompactPartitionPolicy() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
getMobThreshold() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
Gets the mob threshold of the family.
getMobThreshold() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
getMobThreshold() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
getMutations() - Method in class org.apache.hadoop.hbase.client.RowMutations
 
getMvccReadPoint(Scan) - Static method in class org.apache.hadoop.hbase.client.PackagePrivateFieldAccessor
 
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 class org.apache.hadoop.hbase.client.BufferedMutatorImpl
 
getName() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
 
getName() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
getName() - Method in class org.apache.hadoop.hbase.client.HRegionLocator
 
getName() - Method in class org.apache.hadoop.hbase.client.HTable
 
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 class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
getName() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getRegionName() instead.
getNameAsString() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
 
getNameAsString() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
getNameAsString() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
getNameAsString() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
getNameAsString() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Get the name of the table as a String
getNameAsString() - Method in interface org.apache.hadoop.hbase.RegionMetrics
 
getNamespace() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
 
getNamespace() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
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
getNamespaceDescriptor(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getNamespaceDescriptor(RpcController, MasterProtos.GetNamespaceDescriptorRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
getNamespaceFilter() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
 
getNamespaceFromRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getNamespaceName() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.NamespaceFuture
 
getNamespaceQuota(Connection, String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getNamespaceRowKey(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getNamespaceRowKeyRegex(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getNamespaces() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
getNeedResults() - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask
 
getNewRpcRetryingCallerFactory(Configuration) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Returns a new RpcRetryingCallerFactory from the given Configuration.
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.FilterBase
Filters that are not sure which key must be next seeked to, can inherit this implementation that, by default, returns a null Cell.
getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterListWithAND
 
getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterListWithOR
 
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.
getNonce() - Method in class org.apache.hadoop.hbase.client.Action
 
getNonceGenerator() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
 
getNonceGroup() - Method in class org.apache.hadoop.hbase.client.MultiAction
 
getNonceGroup() - Method in interface org.apache.hadoop.hbase.client.NonceGenerator
 
getNonceGroup() - Method in class org.apache.hadoop.hbase.client.PerClientRandomNonceGenerator
 
getNoSuchSnapshot() - Static method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
Returns a singleton that corresponds to no snapshot information.
getNoVersionMap() - Method in class org.apache.hadoop.hbase.client.Result
Map of families to their most recent qualifiers and values.
getNumberOfCachedRegionLocations(TableName) - Method in class org.apache.hadoop.hbase.client.MetaCache
Return the number of cached region for a table.
getNumberOfRegions() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
getNumberOfRequests() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use ServerLoad.getRequestCountPerSecond() instead.
getNumberOfTasksInProgress() - Method in interface org.apache.hadoop.hbase.client.RequestController
 
getNumExceptions() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
getObservedSnapshotSizes(Connection) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
Fetches any persisted HBase snapshot sizes stored in the quota table.
getOffset() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
getOnlineRegions(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 (HBASE-17980). Use Admin.getRegions(ServerName sn).
getOnlineRegions(ServerName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use HBaseAdmin.getRegions(ServerName).
getOnlineRegions(AdminProtos.AdminService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
A helper to get the all the online regions on a region server using admin protocol.
getOnlineRegions(RpcController, AdminProtos.AdminService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
A helper to get the all the online regions on a region server using admin protocol.
getOperationTimeout() - Method in interface org.apache.hadoop.hbase.client.Admin
 
getOperationTimeout() - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask
 
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() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getOperationTimeout() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getOperationTimeout(TimeUnit) - Method in class org.apache.hadoop.hbase.client.HTable
 
getOperationTimeout() - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
getOperationTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.Table
Get timeout of each operation in Table instance.
getOperationTimeout() - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
since 2.0 and will be removed in 3.0 version use Table.getOperationTimeout(TimeUnit) instead
getOperationType() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.NamespaceFuture
 
getOperationType() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.TableFuture
 
getOperator() - Method in class org.apache.hadoop.hbase.filter.BitComparator
 
getOperator() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
Deprecated.
since 2.0.0. Will be removed in 3.0.0. Use CompareFilter.getCompareOperator() instead.
getOperator() - Method in class org.apache.hadoop.hbase.filter.FilterList
Get the operator.
getOperator() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Deprecated.
since 2.0.0. Will be removed in 3.0.0. Use SingleColumnValueFilter.getCompareOperator() instead.
getOrderOfSize() - Method in enum org.apache.hadoop.hbase.Size.Unit
 
getOriginalIndex() - Method in class org.apache.hadoop.hbase.client.Action
 
getOutputStream() - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
Get a SASL wrapped OutputStream.
getOverallAverageLatency() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
getOwner() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
 
getOwnerString() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
Deprecated.
getOwnerString() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Deprecated.
getOwnerString() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
getPageSize() - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
getPauseTime(long, int) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
Calculate pause time.
getPeerClusterConfiguration(Configuration, ReplicationPeerDescription) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
Returns the configuration needed to talk to the remote slave cluster.
getPeerConfig(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
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
 
getPeersCount() - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated. 
getPeerState(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
getPeerTableCFs(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0, use ReplicationAdmin.getPeerConfig(String) instead.
getPolicy() - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot.SpaceQuotaStatus
Returns the violation policy, which may be null.
getPool() - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask
 
getPool() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
 
getPool() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
getPort() - Method in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
 
getPort() - Method in class org.apache.hadoop.hbase.HRegionLocation
 
getPort() - Method in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
 
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
 
getPrimaryCallTimeoutMicroSecond() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getPrimaryOperationTimeout() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
getPriority() - Method in class org.apache.hadoop.hbase.client.Action
 
getPriority() - Method in interface org.apache.hadoop.hbase.client.CoprocessorDescriptor
 
getPriority() - Method in class org.apache.hadoop.hbase.client.MultiAction
 
getPriority() - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
 
getPriority() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
 
getPriority() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
 
getPriority() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
 
getPriority() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
 
getPriority() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
getPriority() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
getPriority() - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
 
getPriority() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
getProcedureResult(MasterProtos.GetProcedureResultRequest) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
getProcedureResult(RpcController, MasterProtos.GetProcedureResultRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
getProcedures() - Method in interface org.apache.hadoop.hbase.client.Admin
Get procedures.
getProcedures() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
List procedures
getProcedures() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getProcedures(RpcController, MasterProtos.GetProceduresRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
getPromotedValueFromProto(HBaseProtos.BigDecimalMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
getPromotedValueFromProto(HBaseProtos.DoubleMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
getPromotedValueFromProto(HBaseProtos.LongMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
getPromotedValueFromProto(R) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
This method gets the promoted type from the proto message
getProperties() - Method in interface org.apache.hadoop.hbase.client.CoprocessorDescriptor
 
getProtocol() - Method in exception org.apache.hadoop.hbase.exceptions.UnknownProtocolException
 
getProtoForCellType(BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
getProtoForCellType(Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
getProtoForCellType(Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
getProtoForCellType(T) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
This method gets the PB message corresponding to the cell type
getProtoForPromotedType(BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
getProtoForPromotedType(Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
getProtoForPromotedType(Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
getProtoForPromotedType(S) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
This method gets the PB message corresponding to the promoted type
getProtoViolationPolicy(SpaceViolationPolicy) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getQop(String) - Static method in class org.apache.hadoop.hbase.security.SaslUtil
Returns SaslUtil.QualityOfProtection corresponding to the given stringQop value.
getQualifier() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
 
getQualifier() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
getQualifier() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
getQualifier() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
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.
getQuota(QuotaFilter) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getQuotaRetriever(QuotaFilter) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use Admin.getQuota(QuotaFilter).
getQuotaRetriever(QuotaFilter) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getQuotaStates(RpcController, QuotaProtos.GetQuotaStatesRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
getQuotaStatus() - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
Returns the status of the quota.
getQuotaType() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
 
getReadRequestCount() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
 
getReadRequestCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
 
getReadRequestsCount() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getReadRequestCount() instead.
getReadRequestsCount() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
getReadRpcTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
Get timeout of each rpc read request in this Table instance.
getReadRpcTimeout() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getReadRpcTimeout(TimeUnit) - Method in class org.apache.hadoop.hbase.client.HTable
 
getReadRpcTimeout() - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
getReadRpcTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.Table
Get timeout of each rpc read request in this Table instance.
getReadRpcTimeout() - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
since 2.0 and will be removed in 3.0 version use Table.getReadRpcTimeout(TimeUnit) instead
getReadType() - Method in class org.apache.hadoop.hbase.client.Scan
 
getRegion() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
 
getRegion() - Method in class org.apache.hadoop.hbase.HRegionLocation
 
getRegion() - Method in class org.apache.hadoop.hbase.master.RegionState
 
getRegion(Connection, byte[]) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
getRegionActionBuilderWithRegion(ClientProtos.RegionAction.Builder, byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
 
getRegionCount() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
 
getRegionCount(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Count regions in hbase:meta for passed table.
getRegionCount(Connection, TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Count regions in hbase:meta for passed table.
getRegionEncodedName(HBaseProtos.RegionSpecifier) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Find the HRegion encoded name based on a region specifier
getRegionId() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
 
getRegionId() - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
 
getRegionInfo() - Method in class org.apache.hadoop.hbase.HRegionLocation
Deprecated.
Since 2.0.0. Will remove in 3.0.0. Use HRegionLocation.getRegion()} instead.
getRegionInfo(Result) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Returns RegionInfo object from the column HConstants.CATALOG_FAMILY:HConstants.REGIONINFO_QUALIFIER of the catalog table Result.
getRegionInfo(RpcController, AdminProtos.AdminService.BlockingInterface, byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
A helper to retrieve region info given a region name using admin protocol.
getRegionInfoForDefaultReplica(RegionInfo) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
Returns the RegionInfo for the default replicaId (0).
getRegionInfoForReplica(RegionInfo, int) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
Returns the RegionInfo for the given replicaId.
getRegionInfos(AdminProtos.GetOnlineRegionResponse) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Get the list of region info from a GetOnlineRegionResponse
getRegionInfos(AdminProtos.GetOnlineRegionResponse) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
Get the list of region info from a GetOnlineRegionResponse
getRegionLoadInfo(AdminProtos.GetRegionLoadResponse) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
getRegionLocation(AsyncTable<?>, byte[]) - Static method in class org.apache.hadoop.hbase.AsyncMetaTableAccessor
Returns the HRegionLocation from meta for the given region
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(TableName, byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Find region location hosting passed row
getRegionLocation(byte[]) - Method in class org.apache.hadoop.hbase.client.HRegionLocator
Finds the region on which the given row is being served.
getRegionLocation(byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HRegionLocator
Finds the region 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(Connection, byte[]) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Returns the HRegionLocation from meta for the given region
getRegionLocation(Connection, RegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Returns the HRegionLocation from meta for the given region
getRegionLocation(int) - Method in class org.apache.hadoop.hbase.RegionLocations
 
getRegionLocation() - Method in class org.apache.hadoop.hbase.RegionLocations
Returns the first not-null region location in the list
getRegionLocationByRegionName(byte[]) - Method in class org.apache.hadoop.hbase.RegionLocations
Returns the region location from the list for matching regionName, which can be regionName or encodedRegionName
getRegionLocations(ClusterConnection, TableName, byte[], boolean, int) - Static method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
getRegionLocations(Result) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Returns an HRegionLocationList extracted from the result.
getRegionLocations() - Method in class org.apache.hadoop.hbase.RegionLocations
 
getRegionLocationWithEncodedName(AsyncTable<?>, byte[]) - Static method in class org.apache.hadoop.hbase.AsyncMetaTableAccessor
Returns the HRegionLocation from meta for the given encoded region name
getRegionLocator(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
Retrieve a AsyncRegionLocator implementation to inspect region information on a 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 class org.apache.hadoop.hbase.client.HTable
 
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 seerver.
getRegionMetrics(ServerName, TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Get a list of RegionMetrics of all regions hosted on a region seerver for a table.
getRegionMetrics(ServerName, TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getRegionMetrics() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
 
getRegionMetrics() - Method in interface org.apache.hadoop.hbase.ServerMetrics
 
getRegionName() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
 
getRegionName() - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
 
getRegionName() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
 
getRegionName() - Method in interface org.apache.hadoop.hbase.RegionMetrics
 
getRegionNameAsString() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
 
getRegionNameAsString() - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
 
getRegionNameAsStringForDisplay(RegionInfo, Configuration) - Static method in class org.apache.hadoop.hbase.client.RegionInfoDisplay
Get the region name for display.
getRegionNameAsStringForDisplay(HRegionInfo, Configuration) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfoDisplay#getRegionNameAsStringForDisplay(RegionInfo, Configuration) over in hbase-server module.
getRegionNameForDisplay(RegionInfo, Configuration) - Static method in class org.apache.hadoop.hbase.client.RegionInfoDisplay
Get the region name for display.
getRegionNameForDisplay(HRegionInfo, Configuration) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfoDisplay#getRegionNameForDisplay(RegionInfo, Configuration) over in hbase-server module.
getRegionReplication() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
 
getRegionReplication() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Returns the configured replicas per region
getRegionReplication() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Returns the configured replicas per region
getRegionResult(Connection, byte[]) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Gets the result in hbase:meta for the specified 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(ServerName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getRegions(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getRegions() - Method in class org.apache.hadoop.hbase.client.MultiAction
 
getRegionsCount() - Method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ClusterMetrics.getRegionCount().
getRegionServerCoprocessors() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getCoprocessorNames() instead.
getRegionServerQuotaSnapshot(ClusterConnection, int, ServerName) - Static method in class org.apache.hadoop.hbase.client.QuotaStatusCalls
getRegionServerQuotaSnapshot(ClusterConnection, RpcControllerFactory, int, ServerName) - Static method in class org.apache.hadoop.hbase.client.QuotaStatusCalls
Executes an RPC to the RegionServer identified by the ServerName to fetch its view on space quotas.
getRegionServerQuotaSnapshots(Connection, ServerName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
Fetches the observed SpaceQuotaSnapshots observed by a RegionServer.
getRegionServers() - Method in interface org.apache.hadoop.hbase.client.Admin
 
getRegionServers() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
 
getRegionsFromMergeQualifier(Connection, byte[]) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Get regions from the merge qualifier of the specified merged region
getRegionsLoad() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
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.
getRegionSplitPolicyClassName() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
This gets the class associated with the region split policy which determines when a region split should occur.
getRegionSplitPolicyClassName() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
This gets the class associated with the region split policy which determines when a region split should occur.
getRegionStatesInTransition() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
 
getRegionStatesInTransition() - Method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
 
getRemoteException(ServiceException) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Return the IOException thrown by the remote server wrapped in ServiceException as cause.
getRemoteException(ServiceException) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Return the IOException thrown by the remote server wrapped in ServiceException as cause.
getReplicaCallTimeoutMicroSecondScan() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getReplicaId() - Method in class org.apache.hadoop.hbase.client.Action
 
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
 
getReplicaId() - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
Returns the 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 class org.apache.hadoop.hbase.ServerLoad
Deprecated.
Call directly from client such as hbase shell
getReplicationLoadSink() - Method in interface org.apache.hadoop.hbase.ServerMetrics
Call directly from client such as hbase shell
getReplicationLoadSourceList() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
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
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
getReplicationPeerConfig(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getReplicationPeerConfig(RpcController, ReplicationProtos.GetReplicationPeerConfigRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
getReportTime() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getReportTimestamp() instead.
getReportTimestamp() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
 
getReportTimestamp() - Method in interface org.apache.hadoop.hbase.ServerMetrics
 
getRequest() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
 
getRequest(Service, Descriptors.MethodDescriptor, ByteString) - Static method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
 
getRequestCount() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
 
getRequestCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
 
getRequestCount() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
 
getRequestCount() - Method in interface org.apache.hadoop.hbase.ServerMetrics
 
getRequestCountPerSecond() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
 
getRequestCountPerSecond() - Method in interface org.apache.hadoop.hbase.ServerMetrics
 
getRequestData() - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
getRequestData() - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
getRequestData() - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
getRequestData() - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
This method should return any additional data that is needed on the server side to construct the ColumnInterpreter.
getRequestsCount() - Method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ClusterMetrics.getRequestCount() instead.
getRequestsCount() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionMetrics.getRequestCount() instead.
getRequestSizeBytes() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
getRequestsPerSecond() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRequestCountPerSecond() instead.
getResponse(ClientProtos.CoprocessorServiceResponse, Message) - Static method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
 
getResponse(Message, byte[]) - Static method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
 
getResponseSizeBytes() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
getResult() - Method in class org.apache.hadoop.hbase.client.SingleResponse.Entry
 
getResult(ClientProtos.MutateRequest, ClientProtos.MutateResponse, CellScanner) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
 
getResults() - Method in interface org.apache.hadoop.hbase.client.AsyncRequestFuture
 
getResults() - Method in class org.apache.hadoop.hbase.client.MultiResponse
 
getResults(ClientProtos.MultiRequest, ClientProtos.MultiResponse, CellScanner) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
Get the results from a protocol buffer MultiResponse
getResults(ClientProtos.MultiRequest, Map<Integer, Integer>, ClientProtos.MultiResponse, CellScanner) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
Get the results from a protocol buffer MultiResponse
getResults(CellScanner, ClientProtos.ScanResponse) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
Create Results from the cells using the cells meta data.
getRetries() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
getRetriesNumber() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getRitDuration() - Method in class org.apache.hadoop.hbase.master.RegionState
 
getRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getStoreFileRootLevelIndexSize() instead.
getRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
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.RegionCoprocessorServiceExec
 
getRow() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
 
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
 
getRow() - Method in class org.apache.hadoop.hbase.client.RowMutations
 
getRowAccess() - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask
 
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
 
getRpcController() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
 
getRpcControllerCellScanner() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
Get the RpcController CellScanner.
getRpcControllerFactory() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
 
getRpcRetryingCallerFactory() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
 
getRpcTimeout() - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask
 
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() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getRpcTimeout(TimeUnit) - Method in class org.apache.hadoop.hbase.client.HTable
 
getRpcTimeout() - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
getRpcTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.Table
Get timeout of each rpc request in this Table instance.
getRpcTimeout() - Method in interface org.apache.hadoop.hbase.client.Table
getRsCoprocessors() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getCoprocessorNames() instead.
getRSGroupInfo(Connection, byte[]) - Static method in class org.apache.hadoop.hbase.RSGroupTableAccessor
 
getSaslQOP() - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
 
getSaslQOP() - Method in class org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClient
 
getSaslQop() - Method in enum org.apache.hadoop.hbase.security.SaslUtil.QualityOfProtection
 
getScan() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
getScan() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
getScanForTableName(Connection, TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Deprecated.
getScanMetrics() - Method in class org.apache.hadoop.hbase.client.AbstractClientScanner
Used internally accumulating metrics on scan.
getScanMetrics() - Method in interface org.apache.hadoop.hbase.client.ResultScanner
 
getScanMetrics() - Method in class org.apache.hadoop.hbase.client.Scan
Deprecated.
Use ResultScanner.getScanMetrics() instead. And notice that, please do not use this method and ResultScanner.getScanMetrics() together, the metrics will be messed up.
getScanMetrics(ClientProtos.ScanResponse) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
 
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 class org.apache.hadoop.hbase.client.HTable
The underlying HTable must not be closed.
getScanner(byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
The underlying HTable must not be closed.
getScanner(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
The underlying HTable must not be closed.
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.
getScannerCaching() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getScannerCallableForReplica(int) - Method in class org.apache.hadoop.hbase.client.ReversedScannerCallable
 
getScannerCallableForReplica(int) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
getScannerMaxResultSize() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getScannerTimeout() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
getScanTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
Get the timeout of a single operation in a scan.
getSchemaAlterStatus(RpcController, MasterProtos.GetSchemaAlterStatusRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
getScope() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
 
getScope() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
getScope() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
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
 
getSecurityCapabilities() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getSecurityCapabilities(RpcController, MasterProtos.SecurityCapabilitiesRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
getSeqNum() - Method in class org.apache.hadoop.hbase.HRegionLocation
 
getSeqNumColumn(int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Returns the column qualifier for seqNum column for replicaId
getSequenceNumber() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
getServerColumn(int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Returns the column qualifier for server column for replicaId
getServerInfo(RpcController, AdminProtos.AdminService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to get the info of a region server using admin protocol.
getServerInfo(RpcController, AdminProtos.AdminService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
A helper to get the info of a region server using admin protocol.
getServerName() - Method in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
 
getServerName() - Method in class org.apache.hadoop.hbase.HRegionLocation
 
getServerName() - Method in class org.apache.hadoop.hbase.master.RegionState
 
getServerName(Result, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Returns a ServerName from catalog table Result.
getServerName() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
 
getServerName() - Method in interface org.apache.hadoop.hbase.ServerMetrics
 
getServerPrincipal() - Method in class org.apache.hadoop.hbase.security.SecurityInfo
 
getServers() - Method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ClusterStatus.getLiveServerMetrics() instead.
getServersSize() - Method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ClusterStatus.getLiveServerMetrics().
getServerUserRegions(Connection, ServerName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
 
getServiceException(ServiceException) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Return the Exception thrown by the remote server wrapped in ServiceException as cause.
getServiceName(Descriptors.ServiceDescriptor) - Static method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
Returns the name to use for coprocessor service calls.
getServices() - Method in interface org.apache.hadoop.hbase.Coprocessor
Coprocessor endpoints providing protobuf services should override this method.
getSettingsQualifierForUserNamespace(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getSettingsQualifierForUserTable(TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getSettingsQualifierRegexForUserNamespace(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getSettingsQualifierRegexForUserTable(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getShortNameToLog() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
 
getShortNameToLog(RegionInfo...) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
 
getShortNameToLog(List<RegionInfo>) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
 
getShortNameToLog() - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
 
getShortNameToLog(HRegionInfo...) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.getShortNameToLog(RegionInfo...).
getShortNameToLog(List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.getShortNameToLog(List))}.
getShortTextFormat(Message) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Return short version of Message toString'd, shorter than TextFormat#shortDebugString.
getSimpleName() - Method in enum org.apache.hadoop.hbase.Size.Unit
 
getSizeOfLogQueue() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
 
getSleepTime() - Method in class org.apache.hadoop.hbase.client.DelayingRunner
 
getSnapshotDescription() - Method in exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
 
getSnapshots(Connection) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
Fetches all SpaceQuotaSnapshot objects from the hbase:quota table.
getSnapshotSizeQualifier(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getSpaceQuotaRegionSizes(RpcController, QuotaProtos.GetSpaceQuotaRegionSizesRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
getSplitKeysArray(MasterProtos.CreateTableRequest) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
get the split keys in form "byte [][]" from a CreateTableRequest proto
getStamp() - Method in class org.apache.hadoop.hbase.master.RegionState
 
getStartCodeColumn(int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Returns the column qualifier for server start code column for replicaId
getStartEndKeys() - Method in class org.apache.hadoop.hbase.client.HRegionLocator
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.
getStartKey() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
 
getStartKey(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
Gets the start key from the specified region name.
getStartKey(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.getStartKey(byte[]).
getStartKey() - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
 
getStartKeyForDisplay(RegionInfo, Configuration) - Static method in class org.apache.hadoop.hbase.client.RegionInfoDisplay
Get the start key for display.
getStartKeyForDisplay(HRegionInfo, Configuration) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfoDisplay#getStartKeyForDisplay(RegionInfo, Configuration) over in hbase-server module.
getStartKeys() - Method in class org.apache.hadoop.hbase.client.HRegionLocator
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
 
getStartRow() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
 
getStartTime() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
getState() - Method in class org.apache.hadoop.hbase.client.TableState
 
getState() - Method in class org.apache.hadoop.hbase.master.RegionState
 
getStatisticsTracker() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
 
getStats() - Method in class org.apache.hadoop.hbase.client.Result
 
getStats(ServerName) - Method in class org.apache.hadoop.hbase.client.ServerStatisticTracker
 
getStatsForRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.backoff.ServerStatistics
 
getStopRow() - Method in class org.apache.hadoop.hbase.client.Scan
 
getStopRow() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
 
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.
getStoragePolicy() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
getStoragePolicy() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
getStoreCompleteSequenceId() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getStoreSequenceId() instead.
getStoreCount() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
 
getStoreCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
 
getStoreFileCount() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
 
getStoreFileCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
 
getStoreFileIndexSize() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
 
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.
getStorefileIndexSizeInMB() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
getStorefileIndexSizeKB() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getStoreFileRootLevelIndexSize() instead.
getStorefileIndexSizeKB() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
getStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 ((HBASE-3935)). Use RegionLoad.getStoreFileRootLevelIndexSize() instead.
getStoreFileRootLevelIndexSize() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
 
getStoreFileRootLevelIndexSize() - Method in interface org.apache.hadoop.hbase.RegionMetrics
 
getStorefiles() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getStoreFileCount() instead.
getStorefiles() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use ServerLoad.getRegionMetrics() instead.
getStoreFiles(AdminProtos.AdminService.BlockingInterface, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
A helper to get the list of files of a column family on a given region using admin protocol.
getStoreFiles(RpcController, AdminProtos.AdminService.BlockingInterface, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
A helper to get the list of files of a column family on a given region using admin protocol.
getStoreFileSize() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
 
getStoreFileSize() - Method in interface org.apache.hadoop.hbase.RegionMetrics
 
getStorefileSizeInMB() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
getStorefileSizeMB() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getStoreFileSize() instead.
getStorefileSizeMB() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
getStoreFileUncompressedDataIndexSize() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
 
getStoreFileUncompressedDataIndexSize() - Method in interface org.apache.hadoop.hbase.RegionMetrics
 
getStores() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getStoreCount() instead.
getStores() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
getStoreSequenceId() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
 
getStoreSequenceId() - Method in interface org.apache.hadoop.hbase.RegionMetrics
 
getStoreUncompressedSizeMB() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getUncompressedStoreFileSize() instead.
getStoreUncompressedSizeMB() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
getStub() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
 
getSubmittedRows() - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask
 
getSupportedFilters() - Method in class org.apache.hadoop.hbase.filter.ParseFilter
Return a Set of filters supported by the Filter Language
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() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
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
 
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.client.SnapshotDescription
Deprecated.
Use getTableName() or getTableNameAsString() instead.
getTable(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.getTable(byte[]).
getTable() - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
Get current table name of the region
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.
getTableCF(ReplicationProtos.TableCF[], String) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
Get TableCF in TableCFs, if not exist, return null.
getTableCFsMap() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
getTableDescriptor(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.0 version and will be removed in 3.0 version. Use Admin.getDescriptor(TableName).
getTableDescriptor(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getTableDescriptor() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.TableFuture
 
getTableDescriptor() - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
getTableDescriptor() - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
since 2.0 version and will be removed in 3.0 version. use Table.getDescriptor()
getTableDescriptors(List<String>) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.0 version and will be removed in 3.0 version. use Admin.listTableDescriptors(List)
getTableDescriptors(List<String>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getTableDescriptors(RpcController, MasterProtos.GetTableDescriptorsRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
getTableDescriptorsByTableName(List<TableName>) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.0 version and will be removed in 3.0 version. use Admin.listTableDescriptors(List)
getTableDescriptorsByTableName(List<TableName>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getTableFilter() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
 
getTableFromRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getTableHRegionLocations(AsyncTable<AdvancedScanResultConsumer>, Optional<TableName>) - Static method in class org.apache.hadoop.hbase.AsyncMetaTableAccessor
Used to get all region locations for the specific table.
getTableName() - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask
 
getTableName() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
 
getTableName() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.TableFuture
 
getTableName() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
 
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.client.TableDescriptorBuilder.ModifyableTableDescriptor
Get the name of the table
getTableName() - Method in class org.apache.hadoop.hbase.client.TableState
Table name for state
getTableName() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Get the name of the table
getTableName() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
 
getTableName() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
getTableNameArray(List<HBaseProtos.TableName>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
getTableNameAsString() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
 
getTableNames(RpcController, MasterProtos.GetTableNamesRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
getTableQuota(Connection, TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getTableRegions(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 (HBASE-17980). Use Admin.getRegions(TableName).
getTableRegions(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use HBaseAdmin.getRegions(TableName).
getTableRegions(Connection, TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Gets all of the regions of the specified table.
getTableRegions(Connection, TableName, boolean) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Gets all of the regions of the specified table.
getTableRegionsAndLocations(Connection, TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Do not use this method to get meta table regions, use methods in MetaTableLocator instead.
getTableRegionsAndLocations(Connection, TableName, boolean) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Do not use this method to get meta table regions, use methods in MetaTableLocator instead.
getTableRowKey(TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getTableRowKeyRegex(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getTableStartRowForMeta(TableName, MetaTableAccessor.QueryType) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
 
getTableState(AsyncTable<?>, TableName) - Static method in class org.apache.hadoop.hbase.AsyncMetaTableAccessor
 
getTableState(TableName) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Retrieve TableState, represent current table state.
getTableState(RpcController, MasterProtos.GetTableStateRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
getTableState(Connection, TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Fetch table state for given table from META table
getTableState(Result) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Decode table state from META Result.
getTableStates(Connection) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Fetch table states from META table
getTableStopRowForMeta(TableName, MetaTableAccessor.QueryType) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
 
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.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
 
getTimestamp() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
getTimeStamp() - Method in class org.apache.hadoop.hbase.client.Mutation
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Mutation.getTimestamp() instead
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
Deprecated.
Since 2.0.0. Will be removed in 3.0.0.
getTimestampOfLastShippedOp() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
 
getTimestamps() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
 
getTimeStampsOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSink
Deprecated.
Since hbase-2.0.0. Will be removed in 3.0.0.
getTimestampsOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSink
 
getTimeToLive() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
 
getTimeToLive() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
getTimeToLive() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
getTokenKind() - Method in class org.apache.hadoop.hbase.security.SecurityInfo
 
getTotalBufferedCounter() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
getTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getCompactingCellCount() instead.
getTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
getTotalFailedCounter() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
getTotalNumberOfRequests() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use ServerLoad.getRequestCount() instead.
getTotalRequestsCount(ClusterStatusProtos.RegionLoad) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
getTotalSizeOfCells(Result) - Static method in class org.apache.hadoop.hbase.client.Result
Get total size of raw cells
getTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getBloomFilterSize() instead.
getTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
getTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getStoreFileUncompressedDataIndexSize() instead.
getTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
getTracker - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
getTTL() - Method in class org.apache.hadoop.hbase.client.Mutation
Return the TTL requested for the result of the mutation, in milliseconds.
getType() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
 
getType() - Method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
 
getType() - Method in exception org.apache.hadoop.hbase.quotas.ThrottlingException
Deprecated.
 
getTypeFilters() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
 
getUncompressedStoreFileSize() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
 
getUncompressedStoreFileSize() - Method in interface org.apache.hadoop.hbase.RegionMetrics
 
getUnit(String) - Static method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
getUnit(String) - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
getUnit() - Method in class org.apache.hadoop.hbase.Size
 
getUsage() - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
Returns the current usage, in bytes, of the target (e.g.
getUsedHeapMB() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use ServerLoad.getUsedHeapSize() instead.
getUsedHeapSize() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
 
getUsedHeapSize() - Method in interface org.apache.hadoop.hbase.ServerMetrics
 
getUser() - Method in class org.apache.hadoop.hbase.security.access.UserPermission
 
getUser() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
getUserFilter() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
 
getUserFromRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getUserName() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
 
getUsername() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
getUserPermissions(Connection, String) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
List all the userPermissions matching the given pattern.
getUserPermissions(RpcController, AccessControlProtos.AccessControlService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
A utility used to get user's global permissions.
getUserPermissions(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, TableName) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
A utility used to get user table permissions.
getUserPermissions(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, byte[]) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
A utility used to get permissions for selected namespace.
getUserQuota(Connection, String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getUserQuota(Connection, String, TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getUserQuota(Connection, String, String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getUserRowKey(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getUserRowKeyRegex(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getValue(Bytes) - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
 
getValue(byte[]) - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
 
getValue(Bytes) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
getValue(byte[]) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
getValue(byte[], byte[], Cell) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
getValue(byte[], byte[], Cell) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
getValue(byte[], byte[], Cell) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
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(Bytes) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
 
getValue(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
 
getValue(byte[]) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
 
getValue(byte[], byte[], Cell) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
 
getValue() - Method in class org.apache.hadoop.hbase.filter.SubstringComparator
 
getValue(byte[]) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
getValue(String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
getValue(Bytes) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
getValue(Bytes) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
getValue(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
getValue(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
getValue(String) - Static method in enum org.apache.hadoop.hbase.KeepDeletedCells
 
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.
getValues() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
It clone all bytes of all elements.
getValues() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
getValues() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
 
getValues() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Getter for fetching an unmodifiable TableDescriptorBuilder.ModifyableTableDescriptor.values map.
getValues() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
getValues() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
getVersion() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
 
getVersion() - Method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0
getVersion() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
 
getVersion() - Method in class org.apache.hadoop.hbase.security.access.Permission
 
getVersionInfo() - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Get a protocol buffer VersionInfo
getVersionNumber() - Method in interface org.apache.hadoop.hbase.ServerMetrics
 
getViolationPolicy(QuotaProtos.SpaceQuota) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getWaitInterval() - Method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
 
getWaitInterval() - Method in exception org.apache.hadoop.hbase.quotas.ThrottlingException
Deprecated.
 
getWritable(byte[], Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
Set bytes into the passed Writable by calling its Writable.readFields(java.io.DataInput).
getWritable(byte[], int, int, Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
Set bytes into the passed Writable by calling its Writable.readFields(java.io.DataInput).
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.BufferedMutatorImpl
 
getWriteBufferPeriodicFlushTimeoutMs() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
 
getWriteBufferPeriodicFlushTimeoutMs() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
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.BufferedMutatorImpl
 
getWriteBufferPeriodicFlushTimerTickMs() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
 
getWriteBufferPeriodicFlushTimerTickMs() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
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.BufferedMutatorImpl
Returns the maximum size in bytes of the write buffer for this HTable.
getWriteBufferSize() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
 
getWriteBufferSize() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getWriteRequestCount() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
 
getWriteRequestCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
 
getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getWriteRequestCount() instead.
getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
getWriteRpcTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
Get timeout of each rpc write request in this Table instance.
getWriteRpcTimeout() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getWriteRpcTimeout(TimeUnit) - Method in class org.apache.hadoop.hbase.client.HTable
 
getWriteRpcTimeout() - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
getWriteRpcTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.Table
Get timeout of each rpc write request in this Table instance.
getWriteRpcTimeout() - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
since 2.0 and will be removed in 3.0 version use Table.getWriteRpcTimeout(TimeUnit) instead
getZNodeForReplica(int) - Method in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
Get the znode string corresponding to a replicaId
grant(Connection, TableName, String, byte[], byte[], Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
Grants permission on the specified table for the specified user.
grant(Connection, String, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
Grants permission on the specified namespace for the specified user.
grant(Connection, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
Grant global permissions for the specified user.
grant(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, boolean, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
A utility used to grant a user global permissions.
grant(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, TableName, byte[], byte[], boolean, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
A utility used to grant a user table permissions.
grant(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, String, boolean, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
A utility used to grant a user namespace 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
 

H

H - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'H'
handlerAdded(ChannelHandlerContext) - Method in class org.apache.hadoop.hbase.security.CryptoAESWrapHandler
 
handlerAdded(ChannelHandlerContext) - Method in class org.apache.hadoop.hbase.security.NettyHBaseRpcConnectionHeaderHandler
 
handlerAdded(ChannelHandlerContext) - Method in class org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClientHandler
 
handlerAdded(ChannelHandlerContext) - Method in class org.apache.hadoop.hbase.security.SaslWrapHandler
 
handleRemoteException(Exception) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Like ProtobufUtil.getRemoteException(ServiceException) but more generic, able to handle more than just ServiceException.
handleRemoteException(Exception) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Like ProtobufUtil.getRemoteException(ServiceException) but more generic, able to handle more than just ServiceException.
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
 
hasCallTimeout() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
hasCallTimeout() - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
 
hasCallTimeout() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
hasCellBlockSupport() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
 
hasCellBlockSupport() - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
hasCellBlockSupport() - Method in interface org.apache.hadoop.hbase.ipc.RpcClient
 
hasColumnFamily(byte[]) - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
Checks to see if this table contains the given column family
hasColumnFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Checks to see if this table contains the given column family
hasColumnFamily(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
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.ModifyableTableDescriptor
Check if the table has an attached co-processor represented by the name className
hasCoprocessor(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Check if the table has an attached co-processor represented by the name className
hasCounter(String) - Method in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
 
hasEncodedName(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
Does region name contain its encoded name?
hasError() - Method in interface org.apache.hadoop.hbase.client.AsyncRequestFuture
 
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
 
hasFamily(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Checks to see if this table contains the given column family
hasFamily() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
hasFilter() - Method in class org.apache.hadoop.hbase.client.Scan
 
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.FilterBase
Fitlers that never filter by modifying the returned List of Cells can inherit this implementation that does nothing.
hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.FilterList
 
hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.FilterListBase
 
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
 
hashCode() - Method in class org.apache.hadoop.hbase.client.Action
 
hashCode() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
hashCode() - Method in class org.apache.hadoop.hbase.client.Get
 
hashCode() - Method in class org.apache.hadoop.hbase.client.Increment
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. No replacement.
hashCode() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
 
hashCode() - Method in class org.apache.hadoop.hbase.client.RowMutations
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. No replacement
hashCode() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
 
hashCode() - Method in class org.apache.hadoop.hbase.client.TableState
 
hashCode() - Method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.BigDecimalComparator
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.NullComparator
 
hashCode() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
hashCode() - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
 
hashCode() - Method in class org.apache.hadoop.hbase.HRegionLocation
 
hashCode() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
hashCode() - Method in class org.apache.hadoop.hbase.master.RegionState
Don't count timestamp in hash code calculation
hashCode() - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
 
hashCode() - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot.SpaceQuotaStatus
 
hashCode() - Method in class org.apache.hadoop.hbase.security.access.Permission
 
hashCode() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
hashCode() - Method in class org.apache.hadoop.hbase.security.access.UserPermission
 
hashCode() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
hashCode() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
 
hashCode() - Method in class org.apache.hadoop.hbase.Size
 
hasHigherPriority(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
Returns which operator has higher precedence
hasMaxHeapMB() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 No flag in 2.0
hasNamespace() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
hasNonce() - Method in class org.apache.hadoop.hbase.client.Action
 
hasNonceGroup() - Method in class org.apache.hadoop.hbase.client.MultiAction
 
hasNumberOfRequests() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 No flag in 2.0
hasQualifier() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
hasRegionMemStoreReplication() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
 
hasRegionMemStoreReplication() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
 
hasRegionMemstoreReplication() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use HTableDescriptor.hasRegionMemStoreReplication() instead
hasRegionMemStoreReplication() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
hasTable() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
hasTotalNumberOfRequests() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 No flag in 2.0
hasUsedHeapMB() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 No flag in 2.0
HBASE_CLIENT_ASYNC_CONNECTION_IMPL - Static variable in class org.apache.hadoop.hbase.client.ConnectionFactory
 
HBASE_CLIENT_CONNECTION_IMPL - Static variable in interface org.apache.hadoop.hbase.client.ClusterConnection
Key for configuration in Configuration whose value is the class we implement making a new Connection instance.
HBASE_CLIENT_SCANNER_ASYNC_PREFETCH - Static variable in class org.apache.hadoop.hbase.client.Scan
Parameter name for client scanner sync/async prefetch toggle.
HBaseAdmin - Class in org.apache.hadoop.hbase.client
HBaseAdmin is no longer a client API.
HBaseAdmin.NamespaceFuture - Class in org.apache.hadoop.hbase.client
 
HBaseAdmin.ProcedureFuture<V> - Class in org.apache.hadoop.hbase.client
Future that waits on a procedure result.
HBaseAdmin.ProcedureFuture.WaitForStateCallable - Interface in org.apache.hadoop.hbase.client
 
HBaseAdmin.TableFuture<V> - Class in org.apache.hadoop.hbase.client
 
HBaseAdmin.TableFuture.TableWaitForStateCallable - Class in org.apache.hadoop.hbase.client
 
HBaseHbck - Class in org.apache.hadoop.hbase.client
Use ClusterConnection.getHbck() to obtain an instance of Hbck instead of constructing an HBaseHbck directly.
HBaseRpcController - Interface in org.apache.hadoop.hbase.ipc
Optionally carries Cells across the proxy/service interface down into ipc.
HBaseRpcController.CancellationCallback - Interface in org.apache.hadoop.hbase.ipc
 
HBaseRpcControllerImpl - Class in org.apache.hadoop.hbase.ipc
Optionally carries Cells across the proxy/service interface down into ipc.
HBaseRpcControllerImpl() - Constructor for class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
HBaseRpcControllerImpl(CellScanner) - Constructor for class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
HBaseRpcControllerImpl(List<CellScannable>) - Constructor for class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
HBaseSaslRpcClient - Class in org.apache.hadoop.hbase.security
A utility class that encapsulates SASL logic for RPC client.
HBaseSaslRpcClient(AuthMethod, Token<? extends TokenIdentifier>, String, boolean) - Constructor for class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
 
HBaseSaslRpcClient(AuthMethod, Token<? extends TokenIdentifier>, String, boolean, String, boolean) - Constructor for class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
 
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, Exception) - 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
Hbck - Interface in org.apache.hadoop.hbase.client
Hbck APIs for HBase.
HColumnDescriptor - Class in org.apache.hadoop.hbase
Deprecated.
HColumnDescriptor(String) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 (HBASE-18433). Use ColumnFamilyDescriptorBuilder.of(String).
HColumnDescriptor(byte[]) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 (HBASE-18433). Use ColumnFamilyDescriptorBuilder.of(byte[]).
HColumnDescriptor(HColumnDescriptor) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 (HBASE-18433). Use ColumnFamilyDescriptorBuilder.copy(ColumnFamilyDescriptor).
HColumnDescriptor(HColumnDescriptor, boolean) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
HColumnDescriptor(ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
heapSize() - Method in class org.apache.hadoop.hbase.client.Mutation
 
heartbeatMessage - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
Saves whether or not the most recent response from the server was a heartbeat message.
hedgedReadOps - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
hedgedReadWin - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
hfileRefsZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
 
HIDDEN_END_KEY - Static variable in class org.apache.hadoop.hbase.client.RegionInfoDisplay
 
HIDDEN_END_KEY - Static variable in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
 
HIDDEN_START_KEY - Static variable in class org.apache.hadoop.hbase.client.RegionInfoDisplay
 
HIDDEN_START_KEY - Static variable in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
 
hint - Variable in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
HRegionInfo - Class in org.apache.hadoop.hbase
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. use RegionInfoBuilder to build RegionInfo.
HRegionInfo(long, TableName, int) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
 
HRegionInfo(TableName) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
 
HRegionInfo(TableName, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
Construct HRegionInfo with explicit parameters
HRegionInfo(TableName, byte[], byte[], boolean) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
Construct HRegionInfo with explicit parameters
HRegionInfo(TableName, byte[], byte[], boolean, long) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
Construct HRegionInfo with explicit parameters
HRegionInfo(TableName, byte[], byte[], boolean, long, int) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
Construct HRegionInfo with explicit parameters
HRegionInfo(RegionInfo) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
Costruct a copy of another HRegionInfo
HRegionInfo(HRegionInfo, int) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
 
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
 
HRegionLocator - Class in org.apache.hadoop.hbase.client
An implementation of RegionLocator.
HRegionLocator(TableName, ClusterConnection) - Constructor for class org.apache.hadoop.hbase.client.HRegionLocator
 
HTable - Class in org.apache.hadoop.hbase.client
An implementation of Table.
HTable(ClusterConnection, TableBuilderBase, RpcRetryingCallerFactory, RpcControllerFactory, ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.HTable
Creates an object to access a HBase table.
HTableDescriptor - Class in org.apache.hadoop.hbase
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use TableDescriptorBuilder to build HTableDescriptor.
HTableDescriptor(TableName) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Construct a table descriptor specifying a TableName object
HTableDescriptor(HTableDescriptor) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Construct a table descriptor by cloning the descriptor passed as a parameter.
HTableDescriptor(HTableDescriptor, boolean) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
HTableDescriptor(TableDescriptor) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
HTableDescriptor(TableName, HTableDescriptor) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Construct a table descriptor by cloning the descriptor passed as a parameter but using a different table name.
HTableDescriptor(TableDescriptorBuilder.ModifyableTableDescriptor) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
HTableMultiplexer - Class in org.apache.hadoop.hbase.client
HTableMultiplexer provides a thread-safe non blocking PUT API across all the tables.
HTableMultiplexer(Configuration, int) - Constructor for class org.apache.hadoop.hbase.client.HTableMultiplexer
 
HTableMultiplexer(Connection, Configuration, int) - Constructor for class org.apache.hadoop.hbase.client.HTableMultiplexer
 
HTableMultiplexer.HTableMultiplexerStatus - Class in org.apache.hadoop.hbase.client
HTableMultiplexerStatus keeps track of the current status of the HTableMultiplexer.
HTableMultiplexerStatus(Map<HRegionLocation, HTableMultiplexer.FlushWorker>) - Constructor for class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 

I

I - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'I'
id - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
ID_ATRIBUTE - Static variable in class org.apache.hadoop.hbase.client.OperationWithAttributes
 
IDLE_TIME - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
 
ifEquals(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateBuilder
Check for equality.
ifEquals(byte[]) - Method in interface org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder
Check for equality.
ifMatches(CompareOperator, byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateBuilder
 
ifMatches(CompareOperator, byte[]) - Method in interface org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder
 
ifNotExists() - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateBuilder
Check for lack of column.
ifNotExists() - Method in interface org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder
Check for lack of column.
ImmutableHColumnDescriptor - Class in org.apache.hadoop.hbase.client
Deprecated.
ImmutableHColumnDescriptor(ColumnFamilyDescriptor) - Constructor for class org.apache.hadoop.hbase.client.ImmutableHColumnDescriptor
Deprecated.
 
ImmutableHRegionInfo - Class in org.apache.hadoop.hbase.client
Deprecated.
ImmutableHRegionInfo(RegionInfo) - Constructor for class org.apache.hadoop.hbase.client.ImmutableHRegionInfo
Deprecated.
 
ImmutableHTableDescriptor - Class in org.apache.hadoop.hbase.client
Deprecated.
ImmutableHTableDescriptor(HTableDescriptor) - Constructor for class org.apache.hadoop.hbase.client.ImmutableHTableDescriptor
Deprecated.
 
ImmutableHTableDescriptor(TableDescriptor) - Constructor for class org.apache.hadoop.hbase.client.ImmutableHTableDescriptor
Deprecated.
 
implementationClassName(String) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
Specify a BufferedMutator implementation other than the default.
implies(Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.Permission
 
implies(String, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TablePermission
Checks that a given table operation is authorized by this permission instance.
implies(TableName, byte[], byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TablePermission
Checks that a given table operation is authorized by this permission instance.
implies(TableName, KeyValue, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TablePermission
Checks if this permission grants access to perform the given action on the given table and key value.
IN_MEMORY - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
IN_MEMORY_COMPACTION - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
IN_MEMORY_COMPACTION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
includeStartRow() - Method in class org.apache.hadoop.hbase.client.Scan
 
includeStopRow() - Method in class org.apache.hadoop.hbase.client.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
incrCacheDroppingExceptions(Object) - Method in class org.apache.hadoop.hbase.client.MetricsConnection
 
incrDelayRunners() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
Increment the number of delay runner counts.
incrDelayRunners() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.RunnerStats
 
increment(Increment) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
Increments one or more columns within a single row.
increment(BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
increment(Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
increment(Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
increment(Increment) - Method in class org.apache.hadoop.hbase.client.HTable
 
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.
increment(S) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
 
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 class org.apache.hadoop.hbase.client.HTable
 
incrementColumnValue(byte[], byte[], byte[], long, Durability) - Method in class org.apache.hadoop.hbase.client.HTable
 
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.
incrementTracker - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
incrHedgedReadOps() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
Increment the number of hedged read that have occurred.
incrHedgedReadWin() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
Increment the number of hedged read returned faster than the original read.
incrMetaCacheHit() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
Increment the number of meta cache hits.
incrMetaCacheMiss() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
Increment the number of meta cache misses.
incrMetaCacheNumClearRegion() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
Increment the number of meta cache drops requested for individual region.
incrMetaCacheNumClearServer() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
Increment the number of meta cache drops requested for entire RegionServer.
incrNormalRunners() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
Increment the number of normal runner counts.
incrNormalRunners() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.RunnerStats
 
incTaskCounters(Collection<byte[]>, ServerName) - Method in interface org.apache.hadoop.hbase.client.RequestController
Increment the counter if we build a valid task.
initCache() - Method in class org.apache.hadoop.hbase.client.ClientAsyncPrefetchScanner
 
initCache() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
initCryptoCipher(RPCProtos.CryptoCipherMeta, Configuration) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
 
initialize(HBaseProtos.EmptyMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
initialize(HBaseProtos.EmptyMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
initialize(HBaseProtos.EmptyMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
initialize(P) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
This method should initialize any field(s) of the ColumnInterpreter with a parsing of the passed message bytes (used on the server side).
initSaslProperties(String) - Static method in class org.apache.hadoop.hbase.security.SaslUtil
 
initScanMetrics(Scan) - Method in class org.apache.hadoop.hbase.client.AbstractClientScanner
Check and initialize if application wants to collect scan metrics
initSyncCache() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
injectNonceGeneratorForTesting(ClusterConnection, NonceGenerator) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
 
instantiate(Configuration) - Static method in class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
 
instantiate(Configuration, ServerStatisticTracker) - Static method in class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
 
instantiate(Configuration, RetryingCallerInterceptor, ServerStatisticTracker) - Static method in class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
 
instantiate(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.RpcControllerFactory
 
instantiated - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
inStates(TableState.State) - Method in class org.apache.hadoop.hbase.client.TableState
Check that table in given states
inStates(TableState.State...) - Method in class org.apache.hadoop.hbase.client.TableState
Check that table in given states
INVALID_REGION_NAME_FORMAT_MESSAGE - Static variable in interface org.apache.hadoop.hbase.client.RegionInfo
 
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.
InvalidLabelException - Exception in org.apache.hadoop.hbase.security.visibility
 
InvalidLabelException(String) - Constructor for exception org.apache.hadoop.hbase.security.visibility.InvalidLabelException
 
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
IPC_CLIENT_FALLBACK_TO_SIMPLE_AUTH_ALLOWED_DEFAULT - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
 
IPC_CLIENT_FALLBACK_TO_SIMPLE_AUTH_ALLOWED_KEY - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
 
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_META - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
IS_MOB - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
IS_MOB - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
IS_MOB_BYTES - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
IS_ROOT - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
isAborted() - Method in interface org.apache.hadoop.hbase.Abortable
Check if the server or client was aborted.
isAborted() - Method in interface org.apache.hadoop.hbase.client.Admin
 
isAborted() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isAborted() - Method in class org.apache.hadoop.hbase.client.HBaseHbck
 
isAccessControllerRunning(Connection) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
 
isAnyMetaReplicaZNode(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
Is the znode of any meta replica
isAsyncPrefetch() - Method in class org.apache.hadoop.hbase.client.Scan
 
isAuthorizationEnabled(Connection) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
Return true if authorization is supported and enabled
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.
isBalancerEnabled() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isBalancerEnabled(RpcController, MasterProtos.IsBalancerEnabledRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
isBalancerOn() - Method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 No flag in 2.0
isBlockCacheEnabled() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
 
isBlockCacheEnabled() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
isBlockCacheEnabled() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
isCacheBloomsOnWrite() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
 
isCacheBloomsOnWrite() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
isCacheBloomsOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
isCacheDataOnWrite() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
 
isCacheDataOnWrite() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
isCacheDataOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
isCacheIndexesOnWrite() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
 
isCacheIndexesOnWrite() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
isCacheIndexesOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
isCallDroppedException(Throwable) - Static method in class org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
Checks if the exception is CallDroppedException (maybe wrapped into some RemoteException).
isCallQueueTooBigException(Throwable) - Static method in class org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
Checks if the exception is CallQueueTooBig exception (maybe wrapped into some RemoteException).
isCanceled() - Method in class org.apache.hadoop.hbase.client.ClientCoprocessorRpcController
 
isCanceled() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
isCanceled() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
isCanceled() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
 
isCancelled() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
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.
isCatalogJanitorEnabled() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isCatalogJanitorEnabled(RpcController, MasterProtos.IsCatalogJanitorEnabledRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
isCellAuthorizationEnabled(Connection) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
Return true if cell authorization is supported and enabled
isCellVisibilityEnabled(Connection) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
Return true if cell visibility features are supported and enabled
isCheckExistenceOnly() - Method in class org.apache.hadoop.hbase.client.Get
 
isClassLoaderLoaded() - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
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.
isCleanerChoreEnabled() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isCleanerChoreEnabled(RpcController, MasterProtos.IsCleanerChoreEnabledRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
isClientReadable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
Returns whether the znode is supposed to be readable by the client and DOES NOT contain sensitive information (world readable).
isClientScannerAsyncPrefetch() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
isClosed() - Method in interface org.apache.hadoop.hbase.client.Connection
Returns whether the connection is closed or not.
isClosed() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isClosed(AdminProtos.CloseRegionResponse) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
Check if the region is closed from a CloseRegionResponse
isClosestRowBefore() - Method in class org.apache.hadoop.hbase.client.Get
Deprecated.
since 2.0.0 and will be removed in 3.0.0
isClosing() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isClosingOrClosedOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
 
isCompactionEnabled() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
Check if the compaction enable flag of the table is true.
isCompactionEnabled() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Check if the compaction enable flag of the table is true.
isCompactionEnabled() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Check if the compaction enable flag of the table is true.
isComplete() - Method in class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
 
isCompressTags() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
 
isCompressTags() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
isCompressTags() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
isConnectionException(Throwable) - Static method in class org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
Check if the exception is something that indicates that we cannot contact/communicate with the server.
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.
isDefaultMetaReplicaZnode(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
Is it the default meta replica's znode
isDefaultReplica(int) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
 
isDefaultReplica(RegionInfo) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
 
isDisabled() - Method in class org.apache.hadoop.hbase.client.TableState
 
isDisabledOrDisabling() - Method in class org.apache.hadoop.hbase.client.TableState
 
isDone() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
isDoNotRetry() - Method in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
 
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 interface org.apache.hadoop.hbase.client.RowAccess
 
isEmpty() - Method in class org.apache.hadoop.hbase.filter.FilterListBase
 
isEmpty() - Method in class org.apache.hadoop.hbase.RegionLocations
Returns whether there are non-null elements in the list
isEmpty() - Method in class org.apache.hadoop.hbase.util.PoolMap
 
isEmptyQuota(QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
isEnabled() - Method in class org.apache.hadoop.hbase.client.TableState
 
isEnabled() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerDescription
 
isEnabledOrEnabling() - Method in class org.apache.hadoop.hbase.client.TableState
 
isEncodedRegionName(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
 
isEncodedRegionName(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.isEncodedRegionName(byte[]).
isEvictBlocksOnClose() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
 
isEvictBlocksOnClose() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
isEvictBlocksOnClose() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
isFailedClose() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isFailedOpen() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isFailedServer(InetSocketAddress) - Method in class org.apache.hadoop.hbase.ipc.FailedServers
Check if the server should be considered as bad.
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.FilterBase
By default, we require all scan's column families to be present.
isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.FilterListBase
 
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
 
isGetScan() - Method in class org.apache.hadoop.hbase.client.Scan
 
isGlobal() - Method in class org.apache.hadoop.hbase.security.access.UserPermission
Returns true if this permission describes a global user permission.
isGuaranteedClientSideOnly() - Method in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
 
isInMemory() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
 
isInMemory() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
isInMemory() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
isInReturnCodes(Filter.ReturnCode, Filter.ReturnCode...) - Static method in class org.apache.hadoop.hbase.filter.FilterListBase
 
isInStates(TableState.State...) - Method in class org.apache.hadoop.hbase.client.TableState
Static version of state checker
isInViolation() - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot.SpaceQuotaStatus
 
isLegalColumnFamilyName(byte[]) - Static method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
isLegalFamilyName(byte[]) - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
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
isMasterInMaintenanceMode() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isMasterInMaintenanceMode(RpcController, MasterProtos.IsInMaintenanceModeRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
isMasterRunning() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Deprecated.
this has been deprecated without a replacement
isMasterRunning(RpcController, MasterProtos.IsMasterRunningRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
isMaxColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
isMerged() - Method in class org.apache.hadoop.hbase.master.RegionState
 
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 class org.apache.hadoop.hbase.client.HBaseAdmin
 
isMerging() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isMergingNew() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isMergingNewOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
 
isMergingNewOrOfflineOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
 
isMergingNewOrOpenedOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
 
isMergingOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
 
isMetaClearingException(Throwable) - Static method in class org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
 
isMetaRegion() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
 
isMetaRegion() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
Checks if this table is hbase:meta region.
isMetaRegion() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Checks if this table is hbase:meta region.
isMetaRegion() - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
 
isMetaRegion() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
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
isMetaTable() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Checks if the table is a hbase:meta table
isMetaTable() - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
 
isMetaTable() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Checks if the table is a hbase:meta table
isMinColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
isMobEnabled() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
Gets whether the mob is enabled for the family.
isMobEnabled() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
isMobEnabled() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
isNamespaceRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
isNeedCursorResult() - Method in class org.apache.hadoop.hbase.client.Scan
 
isNeedProcessConnectionHeader() - Method in class org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClientHandler
 
isNewVersionBehavior() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
By default, HBase only consider timestamp in versions.
isNewVersionBehavior() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
By default, HBase only consider timestamp in versions.
isNewVersionBehavior() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
By default, HBase only consider timestamp in versions.
isNormalizationEnabled() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
Check if normalization enable flag of the table is true.
isNormalizationEnabled() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Check if normalization enable flag of the table is true.
isNormalizationEnabled() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
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
isNormalizerEnabled() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isNormalizerEnabled(RpcController, MasterProtos.IsNormalizerEnabledRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
isNull() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
 
isOffline() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
 
isOffline() - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
 
isOffline() - Method in class org.apache.hadoop.hbase.master.RegionState
 
IsolationLevel - Enum in org.apache.hadoop.hbase.client
Specify Isolation levels in Scan operations.
isOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
 
isOpened() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isOpenedOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
 
isOpening() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isOpeningOrFailedOpenOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
 
isOpeningOrOpenedOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
 
isPartial() - Method in class org.apache.hadoop.hbase.client.Result
Deprecated.
the word 'partial' ambiguous, use Result.mayHaveMoreCellsInRow() instead. Deprecated since 1.4.0.
isPBMagicPrefix(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufMagic
 
isPBMagicPrefix(byte[], int, int) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufMagic
 
isPBMagicPrefix(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
isPBMagicPrefix(byte[], int, int) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
isPBMagicPrefix(byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
isPBMagicPrefix(byte[], int, int) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
isPrefetchBlocksOnOpen() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
 
isPrefetchBlocksOnOpen() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
isPrefetchBlocksOnOpen() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
isProcedureDone(RpcController, MasterProtos.IsProcedureDoneRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
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.
isProcedureFinished(String, String, Map<String, String>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isProcessed() - Method in class org.apache.hadoop.hbase.client.SingleResponse.Entry
 
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
 
isReadOnly() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
Check if the readOnly flag of the table is set.
isReadOnly() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Check if the readOnly flag of the table is set.
isReadOnly() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Check if the readOnly flag of the table is set.
isReadyToOffline() - Method in class org.apache.hadoop.hbase.master.RegionState
Check if a region state can transition to offline
isReadyToOnline() - Method in class org.apache.hadoop.hbase.master.RegionState
Check if a region state can transition to online
isRegionCached(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.MetaCache
Check the region cache to see whether a region is cached yet or not.
isRegionServerRemote - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
isReplicasForSameRegion(RegionInfo, RegionInfo) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
 
isReturnResults() - Method in class org.apache.hadoop.hbase.client.Append
 
isReturnResults() - Method in class org.apache.hadoop.hbase.client.Increment
 
isReturnResults() - Method in class org.apache.hadoop.hbase.client.Mutation
 
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
 
isRootRegion() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
This is vestigial API.
isRSGroupsEnabled(Connection) - Static method in class org.apache.hadoop.hbase.RSGroupTableAccessor
 
isScanMetricsEnabled() - Method in class org.apache.hadoop.hbase.client.Scan
 
isSmall() - Method in class org.apache.hadoop.hbase.client.Scan
Deprecated.
since 2.0.0. See the comment of Scan.setSmall(boolean)
isSnapshotDone(RpcController, MasterProtos.IsSnapshotDoneRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
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.
isSnapshotFinished(SnapshotDescription) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isSpecialException(Throwable) - Static method in class org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
 
isSplit() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
 
isSplit() - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
 
isSplit() - Method in class org.apache.hadoop.hbase.master.RegionState
 
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 class org.apache.hadoop.hbase.client.HBaseAdmin
 
isSplitOrMergeEnabled(MasterSwitchType) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use Admin.isSplitEnabled() or Admin.isMergeEnabled() instead.
isSplitOrMergeEnabled(RpcController, MasterProtos.IsSplitOrMergeEnabledRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
isSplitParent() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
 
isSplitParent() - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
 
isSplitting() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isSplittingNew() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isSplittingNewOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
 
isSplittingOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
 
isSplittingOrOpenedOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
 
isSplittingOrSplitOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
 
isStale() - Method in class org.apache.hadoop.hbase.client.Result
Whether or not the results are coming from possibly stale data.
isStartRowInclusive() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
 
isStopRowInclusive() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
 
issueDate - Variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
isSystemTable() - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
 
isTableAvailable(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
 
isTableAvailable(TableName, byte[][]) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use Admin.isTableAvailable(TableName)
isTableAvailable(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
 
isTableAvailable(TableName, byte[][]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Use this api to check if the table has been created with the specified number of splitkeys which was used while creating the given table.
isTableAvailable(TableName, byte[][]) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Use this api to check if the table has been created with the specified number of splitkeys which was used while creating the given table.
isTableAvailable(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableAvailable(TableName, byte[][]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableDisabled(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
 
isTableDisabled(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
 
isTableDisabled(TableName) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
 
isTableDisabled(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableEnabled(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
 
isTableEnabled(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
 
isTableEnabled(TableName) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
A table that isTableEnabled == false and isTableDisabled == false is possible.
isTableEnabled(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
isUnassignable() - Method in class org.apache.hadoop.hbase.master.RegionState
Check if a region state is one of offline states that can't transition to pending_close/closing (unassign/offline)
isUnassignable(RegionState.State) - Static method in class org.apache.hadoop.hbase.master.RegionState
Check if a region state is one of offline states that can't transition to pending_close/closing (unassign/offline)
isUserRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
isValid() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
 
isValidLabel(byte[]) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsValidator
 
iterator() - Method in interface org.apache.hadoop.hbase.client.ResultScanner
 
iterator() - Method in class org.apache.hadoop.hbase.quotas.QuotaRetriever
 

J

joinZNode(String, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
Join the prefix znode name with the suffix znode name to generate a proper full znode name.
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'
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_DELETED_CELLS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
KEEPALIVE_MILLIS - Static variable in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
 
KeepDeletedCells - Enum in org.apache.hadoop.hbase
Ways to keep cells marked for delete around.
keyId - Variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
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
 
keySet() - Method in class org.apache.hadoop.hbase.util.PoolMap
 

L

L - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'L'
LABEL_QUALIFIER - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
Qualifier for the internal storage table for visibility labels
LabelAlreadyExistsException - Exception in org.apache.hadoop.hbase.security.visibility
 
LabelAlreadyExistsException(String) - Constructor for exception org.apache.hadoop.hbase.security.visibility.LabelAlreadyExistsException
 
LABELS_TABLE_FAMILY - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
Family for the internal storage table for visibility labels
LABELS_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
Internal storage table for visibility labels
lastNext - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
lastResult - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
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
 
LENGTH - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
lengthOfPBMagic() - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufMagic
 
lengthOfPBMagic() - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
lengthOfPBMagic() - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
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.
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.
listDecommissionedRegionServers() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
listDecommissionedRegionServers(RpcController, MasterProtos.ListDecommissionedRegionServersRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
listener(BufferedMutator.ExceptionListener) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
Override the default error handler.
listLabels(Configuration, String) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
listLabels(Connection, String) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
Retrieve the list of visibility labels defined in the system.
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
listNamespaceDescriptors() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
listNamespaceDescriptors(RpcController, MasterProtos.ListNamespaceDescriptorsRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
listPeerConfigs() - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
listReplicated() - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
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
listReplicatedTableCFs() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
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.
listReplicationPeers() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
listReplicationPeers(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
listReplicationPeers(RpcController, ReplicationProtos.ListReplicationPeersRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
listSnapshots() - Method in interface org.apache.hadoop.hbase.client.Admin
List completed snapshots.
listSnapshots(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.0 version and will be removed in 3.0 version. Use Admin.listSnapshots(Pattern) instead.
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.
listSnapshots() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
listSnapshots(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
listSnapshots(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
listTableDescriptors() - Method in interface org.apache.hadoop.hbase.client.Admin
List all the userspace 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() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
listTableDescriptors(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
listTableDescriptors(Pattern, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
listTableDescriptors(List<TableName>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
listTableDescriptorsByNamespace(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.0 version and will be removed in 3.0 version. use Admin.listTableDescriptorsByNamespace(byte[])
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.
listTableDescriptorsByNamespace(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
listTableDescriptorsByNamespace(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
listTableDescriptorsByNamespace(RpcController, MasterProtos.ListTableDescriptorsByNamespaceRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
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(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.0 version and will be removed in 3.0 version. Use Admin.listTableNames(Pattern) instead.
listTableNames(Pattern, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
List all of the names of userspace tables.
listTableNames(String, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.0 version and will be removed in 3.0 version. Use Admin.listTableNames(Pattern, boolean) instead.
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.
listTableNames() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
listTableNames(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
listTableNames(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
listTableNames(Pattern, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
listTableNames(String, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
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.
listTableNamesByNamespace(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
listTableNamesByNamespace(RpcController, MasterProtos.ListTableNamesByNamespaceRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
listTables() - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.0 version and will be removed in 3.0 version. Use Admin.listTableDescriptors().
listTables(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.0 version and will be removed in 3.0 version. Use Admin.listTableDescriptors(java.util.regex.Pattern).
listTables(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.0 version and will be removed in 3.0 version. Use Admin.listTableDescriptors(Pattern) instead.
listTables(Pattern, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.0 version and will be removed in 3.0 version. Use Admin.listTableDescriptors(java.util.regex.Pattern, boolean).
listTables(String, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.0 version and will be removed in 3.0 version. Use Admin.listTableDescriptors(Pattern, boolean).
listTables() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
listTables(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
listTables(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
listTables(Pattern, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
listTables(String, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
listTableSnapshots(String, String) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.0 version and will be removed in 3.0 version. Use Admin.listTableSnapshots(Pattern, Pattern) instead.
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.
listTableSnapshots(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
listTableSnapshots(Pattern, Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
loadCache() - Method in class org.apache.hadoop.hbase.client.ClientScanner
Contact the servers to load more Results in the cache.
loadColumnFamiliesOnDemand - Variable in class org.apache.hadoop.hbase.client.Query
 
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.
localAddr - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
locateRegion(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Find the location of the region of tableName that row lives in.
locateRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Gets the location of the region of regionName.
locateRegion(TableName, byte[], boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
 
locateRegion(TableName, byte[], boolean, boolean, int) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
 
locateRegions(TableName) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Gets the locations of all regions in the specified table, tableName.
locateRegions(TableName, boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Gets the locations of all regions in the specified table, tableName.
location - Variable in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
location - Variable in class org.apache.hadoop.hbase.client.RegionServerCallable
Some subclasses want to set their own location.
LOG - Static variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerImpl
 
LOG - Static variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
LOG - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
LOG - Static variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
LOG_SCANNER_ACTIVITY - Static variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
LOG_SCANNER_LATENCY_CUTOFF - Static variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
LongColumnInterpreter - Class in org.apache.hadoop.hbase.client.coprocessor
a concrete column interpreter implementation.
LongColumnInterpreter() - Constructor for class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
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
 
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

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.
majorCompact(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
majorCompact(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Major compact a column family within a table.
majorCompact(TableName, byte[], CompactType) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Major compact a column family within a table.
majorCompact(TableName, CompactType) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Major compact 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.
majorCompactRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
majorCompactRegion(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
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.
majorCompactRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
makeFilter(QuotaFilter) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
converts quotafilter to serializeable filterlists.
makeGetForNamespaceQuotas(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
makeGetForTableQuotas(TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
makeGetForUserQuotas(String, Iterable<TableName>, Iterable<String>) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
makePutFromRegionInfo(RegionInfo, long) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Generates and returns a Put containing the region into for the catalog table
makePutFromTableState(TableState, long) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Construct PUT for given state
makeQuotaSnapshotScan() - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
Creates a Scan which returns only quota snapshots from the quota table.
makeQuotaSnapshotScanForTable(TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
Creates a Scan which returns only SpaceQuotaSnapshot from the quota table for a specific table.
makeScan(QuotaFilter) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
masterAddressZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
 
masterMaintZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
 
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
 
matches(String) - Method in enum org.apache.hadoop.hbase.security.SaslUtil.QualityOfProtection
 
matchesFamily(TableName, byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TablePermission
Returns true if this permission matches the given column family at least.
matchesFamilyQualifier(TableName, byte[], byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TablePermission
Returns if the given permission matches the given qualifier.
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_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_FILESIZE - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
MAX_KEYVALUE_SIZE_DEFAULT - Static variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
MAX_KEYVALUE_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
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
 
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.
maxRetries - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
maxScannerResultSize - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
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.
MD5_HEX_LENGTH - Static variable in interface org.apache.hadoop.hbase.client.RegionInfo
 
mechanismName - Variable in enum org.apache.hadoop.hbase.security.AuthMethod
 
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.
MEMSTORE_FLUSHSIZE - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
mergeDelimitedFrom(Message.Builder, InputStream) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
This version of protobuf's mergeDelimitedFrom avoid the hard-coded 64MB limit for decoding buffers
mergeFrom(Message.Builder, byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
This version of protobuf's mergeFrom avoids the hard-coded 64MB limit for decoding buffers when working with byte arrays
mergeFrom(Message.Builder, byte[], int, int) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
This version of protobuf's mergeFrom avoids the hard-coded 64MB limit for decoding buffers when working with byte arrays
mergeFrom(Message.Builder, InputStream, int) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
This version of protobuf's mergeFrom avoids the hard-coded 64MB limit for decoding buffers where the message size is known
mergeFrom(Message.Builder, InputStream) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
This version of protobuf's mergeFrom avoids the hard-coded 64MB limit for decoding buffers where the message size is not known
mergeFrom(Message.Builder, ByteString) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
This version of protobuf's mergeFrom avoids the hard-coded 64MB limit for decoding buffers when working with ByteStrings
mergeFrom(Message.Builder, byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
This version of protobuf's mergeFrom avoids the hard-coded 64MB limit for decoding buffers when working with byte arrays
mergeFrom(Message.Builder, byte[], int, int) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
This version of protobuf's mergeFrom avoids the hard-coded 64MB limit for decoding buffers when working with byte arrays
mergeFrom(Message.Builder, CodedInputStream, int) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
mergeLocations(RegionLocations) - Method in class org.apache.hadoop.hbase.RegionLocations
Merges this RegionLocations list with the given list assuming same range, and keeping the most up to date version of the HRegionLocation entries from either list according to seqNum.
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.Admin
Deprecated.
Since 2.0. Will be removed in 3.0. Use Admin.mergeRegionsAsync(byte[], byte[], boolean) instead.
mergeRegions(byte[], byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Merge two regions.
mergeRegions(byte[], byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Deprecated.
Since 2.0. Will be removed in 3.0. Use HBaseAdmin.mergeRegionsAsync(byte[], byte[], boolean) instead.
mergeRegions(Connection, RegionInfo, RegionInfo, RegionInfo, ServerName, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Merge the two regions into one in an atomic operation.
mergeRegionsAsync(byte[], byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Merge two regions.
mergeRegionsAsync(byte[][], boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Merge regions.
mergeRegionsAsync(byte[], byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Merge two regions.
mergeRegionsAsync(byte[][], boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Merge two regions.
mergeRegionsSync(byte[], byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Merge two regions.
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 class org.apache.hadoop.hbase.client.HBaseAdmin
 
mergeTableRegions(RpcController, MasterProtos.MergeTableRegionsRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
META_REPLICA_ID_DELIMITER - Static variable in class org.apache.hadoop.hbase.MetaTableAccessor
The delimiter for meta columns for replicaIds > 0
META_ZNODE_PREFIX - Static variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
 
MetaCache - Class in org.apache.hadoop.hbase.client
A cache implementation for region locations from meta.
MetaCache(MetricsConnection) - Constructor for class org.apache.hadoop.hbase.client.MetaCache
 
metaCacheHits - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
metaCacheMisses - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
metaCacheNumClearRegion - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
metaCacheNumClearServer - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
metaReplicaZNodes - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
 
MetaTableAccessor - Class in org.apache.hadoop.hbase
Read/write operations on region and assignment information store in hbase:meta.
MetaTableAccessor() - Constructor for class org.apache.hadoop.hbase.MetaTableAccessor
 
MetaTableAccessor.CloseableVisitor - Interface in org.apache.hadoop.hbase
Implementations 'visit' a catalog table row but with close() at the end.
MetaTableAccessor.DefaultVisitorBase - Class in org.apache.hadoop.hbase
A Visitor that skips offline regions and split parents
MetaTableAccessor.QueryType - Enum in org.apache.hadoop.hbase
 
MetaTableAccessor.TableVisitorBase - Class in org.apache.hadoop.hbase
A Visitor for a table.
MetaTableAccessor.Visitor - Interface in org.apache.hadoop.hbase
Implementations 'visit' a catalog table row.
metaZNodePrefix - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
 
metrics - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
MetricsConnection - Class in org.apache.hadoop.hbase.client
This class is for maintaining the various connection statistics and publishing them through the metrics interfaces.
MetricsConnection.CallStats - Class in org.apache.hadoop.hbase.client
A container class for collecting details about the RPC call as it percolates.
MetricsConnection.CallTracker - Class in org.apache.hadoop.hbase.client
 
MetricsConnection.RegionStats - Class in org.apache.hadoop.hbase.client
 
MetricsConnection.RunnerStats - Class in org.apache.hadoop.hbase.client
 
MILLIS_BETWEEN_NEXTS_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
 
MIN_VERSIONS - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
MIN_VERSIONS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
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
 
minIdleTimeBeforeClose - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
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
MOB_COMPACT_PARTITION_POLICY - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
MOB_COMPACT_PARTITION_POLICY - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
MOB_COMPACT_PARTITION_POLICY_BYTES - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
MOB_THRESHOLD - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
MOB_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
MOB_THRESHOLD_BYTES - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
MobCompactPartitionPolicy - Enum in org.apache.hadoop.hbase.client
Enum describing the mob compact partition policy types.
ModifyableColumnFamilyDescriptor(byte[]) - Constructor for class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
Construct a column descriptor specifying only the family name The other attributes are defaulted.
ModifyableColumnFamilyDescriptor(ColumnFamilyDescriptor) - Constructor for class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
Constructor.
ModifyableTableDescriptor(TableName) - Constructor for class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Construct a table descriptor specifying a TableName object
ModifyableTableDescriptor(TableName, TableDescriptor) - Constructor for class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Deprecated.
modifyColumn(TableName, ColumnFamilyDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
As of release 2.0.0. This will be removed in HBase 3.0.0. Use Admin.modifyColumnFamily(TableName, ColumnFamilyDescriptor).
modifyColumn(RpcController, MasterProtos.ModifyColumnRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
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(TableName, ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
modifyColumnFamily(ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Modifies the existing column family.
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.
modifyColumnFamilyAsync(TableName, ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
modifyFamily(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Modifies the existing column 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.
modifyNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
modifyNamespace(RpcController, MasterProtos.ModifyNamespaceRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
modifyNamespaceAsync(NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Modify an existing namespace.
modifyNamespaceAsync(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
modifyTable(TableName, TableDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.0 version and will be removed in 3.0 version. use Admin.modifyTable(TableDescriptor)
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) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
modifyTable(TableName, TableDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
modifyTable(RpcController, MasterProtos.ModifyTableRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
modifyTableAsync(TableName, TableDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.0 version and will be removed in 3.0 version. use Admin.modifyTableAsync(TableDescriptor)
modifyTableAsync(TableDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Modify an existing table, more IRB (ruby) friendly version.
modifyTableAsync(TableDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
modifyTableAsync(TableName, TableDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
move(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Move the region r to dest.
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(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
moveRegion(RpcController, MasterProtos.MoveRegionRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
moveToNextRegion() - Method in class org.apache.hadoop.hbase.client.ClientScanner
Close the previous scanner and create a new ScannerCallable for the next scanner.
MultiAction - Class in org.apache.hadoop.hbase.client
Container for Actions (i.e.
MultiAction() - Constructor for class org.apache.hadoop.hbase.client.MultiAction
 
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
 
multiMutate(Connection, Table, byte[], List<Mutation>) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Performs an atomic multi-mutate operation against the given table.
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
 
multiply(BigDecimal, BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
multiply(Double, Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
multiply(Long, Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
multiply(S, S) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
 
MultiResponse - Class in org.apache.hadoop.hbase.client
A container for Result objects, grouped by regionName.
MultiResponse() - Constructor for class org.apache.hadoop.hbase.client.MultiResponse
 
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.RowRange - Class in org.apache.hadoop.hbase.filter
 
multiTracker - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
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.
mutate(Mutation) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
 
mutate(List<? extends Mutation>) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
 
mutateMetaTable(Connection, List<Mutation>) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Execute the passed mutations against hbase:meta table.
mutateRow(RowMutations) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
Performs multiple mutations atomically on a single row.
mutateRow(RowMutations) - Method in class org.apache.hadoop.hbase.client.HTable
 
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
 

N

N - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'N'
NAMESPACE_COL_DESC_BYTES - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
NAMESPACE_COL_DESC_BYTES - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
NAMESPACE_FAMILY_INFO - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
NAMESPACE_FAMILY_INFO - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
NAMESPACE_FAMILY_INFO_BYTES - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
NAMESPACE_FAMILY_INFO_BYTES - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
NAMESPACE_TABLEDESC - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Table descriptor for namespace table
NAMESPACE_TABLEDESC - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Table descriptor for namespace table
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
 
NamespaceFuture(HBaseAdmin, String, Long) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin.NamespaceFuture
 
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
 
namespaceZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
 
needToReplicate(TableName) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
Decide whether the table need replicate to the peer cluster
NettyHBaseRpcConnectionHeaderHandler - Class in org.apache.hadoop.hbase.security
Implement logic to deal with the rpc connection header.
NettyHBaseRpcConnectionHeaderHandler(Promise<Boolean>, Configuration, ByteBuf) - Constructor for class org.apache.hadoop.hbase.security.NettyHBaseRpcConnectionHeaderHandler
 
NettyHBaseSaslRpcClient - Class in org.apache.hadoop.hbase.security
Implement SASL logic for netty rpc client.
NettyHBaseSaslRpcClient(AuthMethod, Token<? extends TokenIdentifier>, String, boolean, String) - Constructor for class org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClient
 
NettyHBaseSaslRpcClientHandler - Class in org.apache.hadoop.hbase.security
Implement SASL logic for netty rpc client.
NettyHBaseSaslRpcClientHandler(Promise<Boolean>, UserGroupInformation, AuthMethod, Token<? extends TokenIdentifier>, String, boolean, Configuration) - Constructor for class org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClientHandler
 
NettyRpcClient - Class in org.apache.hadoop.hbase.ipc
Netty client for the requests and responses.
NettyRpcClient(Configuration, String, SocketAddress, MetricsConnection) - Constructor for class org.apache.hadoop.hbase.ipc.NettyRpcClient
 
NettyRpcClientConfigHelper - Class in org.apache.hadoop.hbase.ipc
Helper class for passing config to NettyRpcClient.
NettyRpcClientConfigHelper() - Constructor for class org.apache.hadoop.hbase.ipc.NettyRpcClientConfigHelper
 
NEW_VERSION_BEHAVIOR - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
NEW_VERSION_BEHAVIOR - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
newBuilder(Batch.Callback<T>) - Static method in class org.apache.hadoop.hbase.client.AsyncProcessTask
 
newBuilder() - Static method in class org.apache.hadoop.hbase.client.AsyncProcessTask
 
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.RegionInfoBuilder
 
newBuilder(RegionInfo) - Static method in class org.apache.hadoop.hbase.client.RegionInfoBuilder
 
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.ClusterMetricsBuilder
 
newBuilder(byte[]) - Static method in class org.apache.hadoop.hbase.RegionMetricsBuilder
 
newBuilder() - Static method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
newBuilder(ReplicationPeerConfig) - Static method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
newBuilder(ServerName) - Static method in class org.apache.hadoop.hbase.ServerMetricsBuilder
 
newCaller(int) - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
Create a new RetryingCaller with specific rpc timeout.
newCaller() - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
Create a new RetryingCaller with configured rpc timeout.
newCallStats() - Static method in class org.apache.hadoop.hbase.client.MetricsConnection
Produce an instance of MetricsConnection.CallStats for clients to attach to RPCs.
newChecker() - Method in interface org.apache.hadoop.hbase.client.RequestController
 
newController() - Method in class org.apache.hadoop.hbase.ipc.RpcControllerFactory
 
newController(CellScanner) - Method in class org.apache.hadoop.hbase.ipc.RpcControllerFactory
 
newController(List<CellScannable>) - Method in class org.apache.hadoop.hbase.ipc.RpcControllerFactory
 
newNonce() - Method in interface org.apache.hadoop.hbase.client.NonceGenerator
 
newNonce() - Method in class org.apache.hadoop.hbase.client.PerClientRandomNonceGenerator
 
newServiceStub(Class<T>, RpcChannel) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
newServiceStub(Class<T>, RpcChannel) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
next() - Method in class org.apache.hadoop.hbase.client.ClientAsyncPrefetchScanner
 
next() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
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() - Method in class org.apache.hadoop.hbase.quotas.QuotaRetriever
 
nextWithSyncCache() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
NINE - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code foe Nine
NO_HASH - Static variable in class org.apache.hadoop.hbase.client.RegionInfoBuilder
 
NO_HASH - Static variable in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
 
NoBackoffPolicy(Configuration) - Constructor for class org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicyFactory.NoBackoffPolicy
 
NON_EXIST_LABEL_ORDINAL - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
Label ordinal value for invalid labels
NoncedRegionServerCallable<T> - Class in org.apache.hadoop.hbase.client
Implementations make an rpc call against a RegionService via a protobuf Service.
NoncedRegionServerCallable(Connection, TableName, byte[], HBaseRpcController, int) - Constructor for class org.apache.hadoop.hbase.client.NoncedRegionServerCallable
 
NonceGenerator - Interface in org.apache.hadoop.hbase.client
NonceGenerator interface.
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.
NORMALIZATION_ENABLED - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
normalize() - 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() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Invoke region normalizer.
normalize(RpcController, MasterProtos.NormalizeRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
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.
normalizerSwitch(boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
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_OPERATOR - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
 
NOT_SERVING_REGION_EXCEPTION_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
 
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
 
notifyOnCancel(RpcCallback<Object>) - Method in class org.apache.hadoop.hbase.client.ClientCoprocessorRpcController
 
notifyOnCancel(RpcCallback<Object>) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
notifyOnCancel(RpcCallback<Object>, HBaseRpcController.CancellationCallback) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
notifyOnCancel(RpcCallback<Object>) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
A little different from the basic RpcController: You can register multiple callbacks to an HBaseRpcController. The callback will not be called if the rpc call is finished without any cancellation. You can call me at client side also.
notifyOnCancel(RpcCallback<Object>, HBaseRpcController.CancellationCallback) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
If not cancelled, add the callback to cancellation callback list.
notifyOnCancel(RpcCallback<Object>) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
notifyOnCancel(RpcCallback<Object>, HBaseRpcController.CancellationCallback) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
notifyOnCancel(RpcCallback<Object>) - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
 
notInViolation() - Static method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot.SpaceQuotaStatus
Returns a singleton referring to a quota which is not in violation.
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
default constructor
NotServingRegionException(String) - Constructor for exception org.apache.hadoop.hbase.NotServingRegionException
Constructor
NotServingRegionException(byte[]) - Constructor for exception org.apache.hadoop.hbase.NotServingRegionException
Constructor
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
 
numberOfCompleteRows() - Method in class org.apache.hadoop.hbase.client.BatchScanResultCache
 
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
 
numFamilies() - Method in class org.apache.hadoop.hbase.client.Scan
 
numNonNullElements() - Method in class org.apache.hadoop.hbase.RegionLocations
Returns the size of not-null locations

O

O - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'O'
obtainServerLoadPB() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
DONT use this pb object since the byte array backed may be modified in rpc layer
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.
of(ServerName) - Static method in class org.apache.hadoop.hbase.ServerMetricsBuilder
 
of(ServerName, int) - Static method in class org.apache.hadoop.hbase.ServerMetricsBuilder
 
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.
offline(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
offlineRegion(RpcController, MasterProtos.OfflineRegionRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
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, Supplier<String>, Consumer<Throwable>) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
 
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).
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
 
onRegionComplete(RegionInfo, R) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CoprocessorCallback
 
onRegionError(RegionInfo, Throwable) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CoprocessorCallback
 
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
 
OP_ATTRIBUTE_ACL - Static variable in interface org.apache.hadoop.hbase.security.access.AccessControlConstants
Cell level ACL
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.
OPEN_PARAN - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
 
openRegion(RpcController, AdminProtos.AdminService.BlockingInterface, ServerName, RegionInfo) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
A helper to open a region using admin protocol.
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
 
operationTimeoutNs - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
 
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
 
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
 
OR_OPERATOR - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
 
org.apache.hadoop.hbase - package org.apache.hadoop.hbase
 
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.coprocessor - package org.apache.hadoop.hbase.client.coprocessor
Provides client classes for invoking Coprocessor RPC protocols Overview Example Usage
org.apache.hadoop.hbase.client.metrics - package org.apache.hadoop.hbase.client.metrics
 
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.coprocessor - package org.apache.hadoop.hbase.coprocessor
 
org.apache.hadoop.hbase.exceptions - package org.apache.hadoop.hbase.exceptions
 
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.ipc - package org.apache.hadoop.hbase.ipc
 
org.apache.hadoop.hbase.master - package org.apache.hadoop.hbase.master
 
org.apache.hadoop.hbase.protobuf - package org.apache.hadoop.hbase.protobuf
Holds classes generated from protobuf src/main/protobuf definition files.
org.apache.hadoop.hbase.quotas - package org.apache.hadoop.hbase.quotas
 
org.apache.hadoop.hbase.regionserver - package org.apache.hadoop.hbase.regionserver
 
org.apache.hadoop.hbase.regionserver.wal - package org.apache.hadoop.hbase.regionserver.wal
 
org.apache.hadoop.hbase.replication - package org.apache.hadoop.hbase.replication
 
org.apache.hadoop.hbase.security - package org.apache.hadoop.hbase.security
 
org.apache.hadoop.hbase.security.access - package org.apache.hadoop.hbase.security.access
 
org.apache.hadoop.hbase.security.token - package org.apache.hadoop.hbase.security.token
 
org.apache.hadoop.hbase.security.visibility - package org.apache.hadoop.hbase.security.visibility
 
org.apache.hadoop.hbase.shaded.protobuf - package org.apache.hadoop.hbase.shaded.protobuf
 
org.apache.hadoop.hbase.snapshot - package org.apache.hadoop.hbase.snapshot
 
org.apache.hadoop.hbase.util - package org.apache.hadoop.hbase.util
 
org.apache.hadoop.hbase.zookeeper - package org.apache.hadoop.hbase.zookeeper
 
OutOfOrderScannerNextException - Exception in org.apache.hadoop.hbase.exceptions
Thrown by a RegionServer while doing next() calls on a ResultScanner.
OutOfOrderScannerNextException() - Constructor for exception org.apache.hadoop.hbase.exceptions.OutOfOrderScannerNextException
 
OutOfOrderScannerNextException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.OutOfOrderScannerNextException
 
overwriteRegions(Connection, List<RegionInfo>, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Overwrites the specified regions from hbase:meta.
OWNER - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
OWNER - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
OWNER_KEY - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
OWNER_KEY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
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'
PackagePrivateFieldAccessor - Class in org.apache.hadoop.hbase.client
A helper class used to access the package private field in o.a.h.h.client package.
PackagePrivateFieldAccessor() - Constructor for class org.apache.hadoop.hbase.client.PackagePrivateFieldAccessor
 
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.
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.
parseDelimitedFrom(byte[], int, int) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.parseDelimitedFrom(byte[], int, int).
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
 
parseFrom(byte[], int, int) - Static method in interface org.apache.hadoop.hbase.client.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(TableName, byte[]) - Static method in class org.apache.hadoop.hbase.client.TableState
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.ClusterId
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.BigDecimalComparator
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.BinaryComparator
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.BinaryPrefixComparator
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.BitComparator
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
Parse protobuf bytes to a ColumnValueFilter
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.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
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
Deprecated.
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.LongComparator
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.NullComparator
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.PageFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.QualifierFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.RegexStringComparator
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.RowFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.SkipFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.SubstringComparator
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.TimestampsFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ValueFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.parseFrom(byte[]).
parseFrom(byte[], int, int) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.parseFrom(byte[], int, int).
parseFrom(DataInputStream) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.parseFrom(DataInputStream).
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
parseFromOrNull(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
 
parseFromOrNull(byte[], int, int) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
 
parseFromOrNull(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.parseFromOrNull(byte[]).
parseFromOrNull(byte[], int, int) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.parseFromOrNull(byte[], int, int).
parseNamespaceResult(Result, QuotaTableUtil.NamespaceQuotasVisitor) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
parseNamespaceResult(String, Result, QuotaTableUtil.NamespaceQuotasVisitor) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
parsePeerFrom(byte[]) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
 
parseRegionInfoFromRegionName(byte[]) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Returns an HRI parsed from this regionName.
parseRegionName(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
Separate elements of a regionName.
parseRegionName(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.parseRegionName(byte[]).
parseResult(Result, QuotaTableUtil.QuotasVisitor) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
parseResultToCollection(Result, Collection<QuotaSettings>) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
parseServerNameFrom(byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Get a ServerName from the passed in data bytes.
parseSimpleFilterExpression(byte[]) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
Constructs a filter object given a simple filter expression
parseTableCFs(byte[]) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
Parse bytes into TableCFs.
parseTableCFsFromConfig(String) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0
parseTableCFsFromConfig(String) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
Convert tableCFs string into Map.
parseTableResult(Result, QuotaTableUtil.TableQuotasVisitor) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
parseTableResult(TableName, Result, QuotaTableUtil.TableQuotasVisitor) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
parseUserResult(Result, QuotaTableUtil.UserQuotasVisitor) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
parseUserResult(String, Result, QuotaTableUtil.UserQuotasVisitor) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
passedPrefix - Variable in class org.apache.hadoop.hbase.filter.PrefixFilter
 
pattern - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsValidator
 
PB_MAGIC - Static variable in class org.apache.hadoop.hbase.protobuf.ProtobufMagic
Magic we put ahead of a serialized protobuf message.
peersZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
 
PerClientRandomNonceGenerator - Class in org.apache.hadoop.hbase.client
NonceGenerator implementation that uses client ID hash + random int as nonce group, and random numbers as nonces.
Permission - Class in org.apache.hadoop.hbase.security.access
Base permissions instance representing the ability to perform a given set of actions.
Permission() - Constructor for class org.apache.hadoop.hbase.security.access.Permission
Empty constructor for Writable implementation.
Permission(Permission.Action...) - Constructor for class org.apache.hadoop.hbase.security.access.Permission
 
Permission(byte[]) - Constructor for class org.apache.hadoop.hbase.security.access.Permission
 
Permission.Action - Enum in org.apache.hadoop.hbase.security.access
 
PING_CALL_ID - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
 
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
 
pluralize(Collection<?>) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
pluralize(int) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
poll(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService
Poll for the first completed task whether it is a success or execution exception.
pollForFirstSuccessfullyCompletedTask(long, TimeUnit, int, int) - Method in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService
Poll for the first successfully completed task whose completed order is in startIndex, endIndex(exclusive) range
pool(ExecutorService) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
Override the default executor pool defined by the hbase.htable.threads.* configuration values.
pool - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
pool - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
 
PoolMap<K,V> - Class in org.apache.hadoop.hbase.util
The PoolMap maps a key to a collection of values, the elements of which are managed by a pool.
PoolMap(PoolMap.PoolType) - Constructor for class org.apache.hadoop.hbase.util.PoolMap
 
PoolMap(PoolMap.PoolType, int) - Constructor for class org.apache.hadoop.hbase.util.PoolMap
 
PoolMap.Pool<R> - Interface in org.apache.hadoop.hbase.util
 
PoolMap.PoolType - Enum in org.apache.hadoop.hbase.util
 
PoolMap.ReusablePool<R> - Class in org.apache.hadoop.hbase.util
The ReusablePool represents a PoolMap.Pool that builds on the LinkedList class.
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
postOperationFailure(IOException, long) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
Called after the operation is terminated with a failure.
postOperationFailure(IOException, long) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.TableFuture
 
postOperationResult(V, long) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
Called after the operation is completed and the result fetched.
postOperationResult(V, long) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.TableFuture
 
PreemptiveFastFailException - 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.
PreemptiveFastFailException(long, long, long, ServerName) - Constructor for exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
 
PreemptiveFastFailException(long, long, long, ServerName, boolean) - Constructor for exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
 
PREFETCH_BLOCKS_ON_OPEN - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Key for the PREFETCH_BLOCKS_ON_OPEN attribute.
PREFETCH_BLOCKS_ON_OPEN - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
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
 
prepare(boolean) - Method in class org.apache.hadoop.hbase.client.FlushRegionCallable
 
prepare(boolean) - Method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
prepare(boolean) - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
 
prepare(boolean) - Method in interface org.apache.hadoop.hbase.client.RetryingCallable
Prepare by setting up any connections to servers, etc., ahead of call invocation.
prepare(boolean) - Method in class org.apache.hadoop.hbase.client.ReversedScannerCallable
 
prepare(boolean) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
prepareBulkLoad(Connection) - Method in class org.apache.hadoop.hbase.client.SecureBulkLoadClient
 
prependPBMagic(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Prepend the passed bytes with four bytes of magic, ProtobufMagic.PB_MAGIC, to flag what follows as a protobuf in hbase.
prependPBMagic(byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Prepend the passed bytes with four bytes of magic, ProtobufMagic.PB_MAGIC, to flag what follows as a protobuf in hbase.
prettyPrint(String) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
Use logging.
prettyPrint(String) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.prettyPrint(String).
primaryOperationTimeout - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
PRIORITY - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
PRIORITY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
PRIORITY_HIGHEST - Static variable in interface org.apache.hadoop.hbase.Coprocessor
Highest installation priority
PRIORITY_LOWEST - Static variable in interface org.apache.hadoop.hbase.Coprocessor
Lowest installation priority
PRIORITY_SYSTEM - Static variable in interface org.apache.hadoop.hbase.Coprocessor
High (system) installation priority
PRIORITY_USER - Static variable in interface org.apache.hadoop.hbase.Coprocessor
Default installation priority for user coprocessors
ProcedureFuture(HBaseAdmin, Long) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
processBatchCallback(List<? extends Row>, Object[], Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTable
Process a mixed batch of Get, Put and Delete actions.
procId - Variable in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
ProtobufMagic - Class in org.apache.hadoop.hbase.protobuf
Protobufs utility.
ProtobufMessageConverter - Class in org.apache.hadoop.hbase.protobuf
This class converts PB Messages to various representations, like: JSON string: ProtobufMessageConverter.toJsonElement(MessageOrBuilder) JSON object (gson): ProtobufMessageConverter.toJsonElement(MessageOrBuilder) Java objects (Boolean, Number, String, List, Map): ProtobufMessageConverter.toJavaObject(JsonElement)
ProtobufUtil - Class in org.apache.hadoop.hbase.protobuf
Protobufs utility.
ProtobufUtil - Class in org.apache.hadoop.hbase.shaded.protobuf
Protobufs utility.
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(Put) - Method in class org.apache.hadoop.hbase.client.HTable
 
put(List<Put>) - Method in class org.apache.hadoop.hbase.client.HTable
 
put(TableName, Put) - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
The put request will be buffered by its corresponding buffer queue.
put(TableName, List<Put>) - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
The puts request will be buffered by their corresponding buffer queue.
put(byte[], List<Put>) - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
Deprecated.
put(TableName, Put, int) - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
The put request will be buffered by its corresponding buffer queue.
put(byte[], Put, int) - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
Deprecated.
put(byte[], Put) - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
Deprecated.
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(R) - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
 
put(K, V) - Method in class org.apache.hadoop.hbase.util.PoolMap
 
put(R) - Method in class org.apache.hadoop.hbase.util.PoolMap.ReusablePool
 
putAll(List<Put>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
A simple version of batch put.
putAll(Map<? extends K, ? extends V>) - Method in class org.apache.hadoop.hbase.util.PoolMap
 
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.
putConfiguration(String, String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
Sets a "raw" configuration property for this replication peer.
putPeerData(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
Sets the serialized peer configuration data
putsToMetaTable(Connection, List<Put>) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Put the passed ps to the hbase:meta table.
putTracker - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 

Q

qualifier(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateBuilder
 
qualifier(byte[]) - Method in interface org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder
 
QualifierFilter - Class in org.apache.hadoop.hbase.filter
This filter is used to filter based on the column qualifier.
QualifierFilter(CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.QualifierFilter
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use QualifierFilter.QualifierFilter(CompareOperator, ByteArrayComparable) instead.
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
 
queuesZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
 
QUOTA_FAMILY_INFO - Static variable in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
QUOTA_FAMILY_USAGE - Static variable in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
QUOTA_NAMESPACE_ROW_KEY_PREFIX - Static variable in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
QUOTA_POLICY_COLUMN - Static variable in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
QUOTA_QUALIFIER_POLICY - Static variable in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
QUOTA_QUALIFIER_SETTINGS - Static variable in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
QUOTA_QUALIFIER_SETTINGS_PREFIX - Static variable in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
QUOTA_SNAPSHOT_SIZE_QUALIFIER - Static variable in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
QUOTA_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
System table for quotas
QUOTA_TABLE_ROW_KEY_PREFIX - Static variable in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
QUOTA_USER_ROW_KEY_PREFIX - Static variable in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
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) - 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
 
quotasFromData(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
quotasFromData(byte[], int, int) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
QuotaStatusCalls - Class in org.apache.hadoop.hbase.client
Client class to wrap RPCs to HBase servers for space quota status information.
QuotaStatusCalls() - Constructor for class org.apache.hadoop.hbase.client.QuotaStatusCalls
 
quotasToData(QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
QuotaTableUtil - Class in org.apache.hadoop.hbase.quotas
Helper class to interact with the quota table.
QuotaTableUtil() - Constructor for class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
QuotaTableUtil.NamespaceQuotasVisitor - Interface in org.apache.hadoop.hbase.quotas
 
QuotaTableUtil.QuotasVisitor - Interface in org.apache.hadoop.hbase.quotas
 
QuotaTableUtil.TableQuotasVisitor - Interface in org.apache.hadoop.hbase.quotas
 
QuotaTableUtil.UserQuotasVisitor - Interface in org.apache.hadoop.hbase.quotas
 
QuotaType - Enum in org.apache.hadoop.hbase.quotas
Describe the Quota Type.
quote(String) - Static method in class org.apache.hadoop.hbase.security.visibility.CellVisibility
Helps in quoting authentication Strings.
quote(byte[]) - Static method in class org.apache.hadoop.hbase.security.visibility.CellVisibility
Helps in quoting authentication Strings.

R

R - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'R'
random - Static variable in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
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.
rawCells() - Method in class org.apache.hadoop.hbase.client.Result
Return the array of Cells backing this Result instance.
read(DataInput) - Static method in enum org.apache.hadoop.hbase.security.AuthMethod
Read from in
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.
readFields(DataInput) - Method in class org.apache.hadoop.hbase.security.access.Permission
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.security.access.UserPermission
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
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.
READONLY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
ReadOnlyZKClient - Class in org.apache.hadoop.hbase.zookeeper
A very simple read only zookeeper implementation without watcher support.
ReadOnlyZKClient(Configuration) - Constructor for class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
 
readTO - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
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.
recommissionRegionServer(ServerName, List<byte[]>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
recommissionRegionServer(RpcController, MasterProtos.RecommissionRegionServerRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
RECOVERY_RETRY - Static variable in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
 
RECOVERY_RETRY_INTERVAL_MILLIS - Static variable in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
 
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
regex - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsValidator
 
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)
regexStringType - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
RegexStringType byte array
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_MEMSTORE_REPLICATION - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
REGION_REPLICA_WAIT_FOR_PRIMARY_FLUSH_CONF_KEY - Static variable in class org.apache.hadoop.hbase.client.RegionReplicaUtil
Whether or not the secondary region will wait for observing a flush / region open event from the primary region via async wal replication before enabling read requests.
REGION_REPLICATION - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
The number of region replicas for the table.
REGION_REPLICATION - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
RegionAdminServiceCallable<T> - Class in org.apache.hadoop.hbase.client
Similar to RegionServerCallable but for the AdminService interface.
RegionAdminServiceCallable(ClusterConnection, RpcControllerFactory, TableName, byte[]) - Constructor for class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
RegionAdminServiceCallable(ClusterConnection, RpcControllerFactory, HRegionLocation, TableName, byte[]) - Constructor for class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
RegionAdminServiceCallable(ClusterConnection, RpcControllerFactory, HRegionLocation, TableName, byte[], int) - Constructor for class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
RegionCoprocessorServiceExec - Class in org.apache.hadoop.hbase.client
Represents a coprocessor service method execution against a single region.
RegionCoprocessorServiceExec(byte[], byte[], Descriptors.MethodDescriptor, Message) - Constructor for class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
 
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.
RegionInfoBuilder - Class in org.apache.hadoop.hbase.client
 
RegionInfoDisplay - Class in org.apache.hadoop.hbase.client
Utility used composing RegionInfo for 'display'; e.g.
RegionInfoDisplay() - Constructor for class org.apache.hadoop.hbase.client.RegionInfoDisplay
 
RegionLoad - Class in org.apache.hadoop.hbase
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionMetrics instead.
RegionLoad(ClusterStatusProtos.RegionLoad) - Constructor for class org.apache.hadoop.hbase.RegionLoad
Deprecated.
 
regionLoadPB - Variable in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
 
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
 
RegionLocations - Class in org.apache.hadoop.hbase
Container for holding a list of HRegionLocation's that correspond to the same range.
RegionLocations(HRegionLocation...) - Constructor for class org.apache.hadoop.hbase.RegionLocations
Constructs the region location list.
RegionLocations(Collection<HRegionLocation>) - Constructor for class org.apache.hadoop.hbase.RegionLocations
 
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.
RegionMetricsBuilder - Class in org.apache.hadoop.hbase
 
RegionMovedException - Exception in org.apache.hadoop.hbase.exceptions
Subclass if the server knows the region is now on another server.
RegionMovedException(ServerName, long) - Constructor for exception org.apache.hadoop.hbase.exceptions.RegionMovedException
 
RegionMovedException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.RegionMovedException
For hadoop.ipc internal call.
regionNormalizerZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
 
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
 
RegionOpeningException - Exception in org.apache.hadoop.hbase.exceptions
Subclass if the server knows the region is now on another server.
RegionOpeningException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.RegionOpeningException
 
RegionReplicaUtil - Class in org.apache.hadoop.hbase.client
Utility methods which contain the logic for regions and replicas.
RegionReplicaUtil() - Constructor for class org.apache.hadoop.hbase.client.RegionReplicaUtil
 
REGIONS_SCANNED_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
 
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
 
RegionServerCallable<T,S> - Class in org.apache.hadoop.hbase.client
Implementations make a RPC call against a RegionService via a protobuf Service.
RegionServerCallable(Connection, TableName, byte[], RpcController) - Constructor for class org.apache.hadoop.hbase.client.RegionServerCallable
 
RegionServerCallable(Connection, TableName, byte[], RpcController, int) - Constructor for class org.apache.hadoop.hbase.client.RegionServerCallable
 
RegionServerCoprocessorRpcChannelImpl - Class in org.apache.hadoop.hbase.client
The implementation of a region server based coprocessor rpc channel.
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
 
RegionState - Class in org.apache.hadoop.hbase.master
State of a Region while undergoing transitions.
RegionState(RegionInfo, RegionState.State, ServerName) - Constructor for class org.apache.hadoop.hbase.master.RegionState
 
RegionState(RegionInfo, RegionState.State, long, ServerName) - Constructor for class org.apache.hadoop.hbase.master.RegionState
 
RegionState(RegionInfo, RegionState.State, long, ServerName, long) - Constructor for class org.apache.hadoop.hbase.master.RegionState
 
RegionState.State - Enum in org.apache.hadoop.hbase.master
 
RegionStatistics() - Constructor for class org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
 
RegionStats(MetricRegistry, String) - Constructor for class org.apache.hadoop.hbase.client.MetricsConnection.RegionStats
 
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.
relocateRegion(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Find the location of the region of tableName that row lives in, ignoring any value that might be in the cache.
relocateRegion(TableName, byte[], int) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Find the location of the region of tableName that row lives in, ignoring any value that might be in the cache.
remainingTimeNs() - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
 
REMOTE_RPC_CALLS_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
 
REMOTE_RPC_RETRIES_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
 
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, String, int, boolean) - Constructor for exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
 
remove(byte[]) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
remove(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Remove metadata represented by the key from the map
remove(Bytes) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Remove metadata represented by the key from the map
remove(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Remove metadata represented by the key from the map
remove(HRegionLocation) - Method in class org.apache.hadoop.hbase.RegionLocations
Removes the given location from the list
remove(int) - Method in class org.apache.hadoop.hbase.RegionLocations
Removes location of the given replicaId from the list
remove(R) - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
 
remove(Object) - Method in class org.apache.hadoop.hbase.util.PoolMap
 
removeByServer(ServerName) - Method in class org.apache.hadoop.hbase.RegionLocations
Returns a new RegionLocations with the locations removed (set to null) which have the destination server as given.
removeColumnFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Removes the ColumnFamilyDescriptor with name specified by the parameter column from the table descriptor
removeColumnFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
removeConfiguration(String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
Remove a configuration setting represented by the key from the ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor.configuration map.
removeConfiguration(String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
removeConfiguration(String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
Remove a configuration setting represented by the key.
removeConfiguration(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Remove a config setting represented by the key from the map
removeCoprocessor(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Remove a coprocessor from those set on the table
removeCoprocessor(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
removeCoprocessor(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Remove a coprocessor from those set on the table
removeFamily(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Removes the HColumnDescriptor with name specified by the parameter column from the table descriptor
removeMetaData(byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKMetadata
 
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.
removeNonDefaultRegions(Collection<RegionInfo>) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
Removes the non-default replicas from the passed regions collection
removePeer(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
removePeerTableCFs(String, String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0, use ReplicationAdmin.removePeerTableCFs(String, Map) instead.
removePeerTableCFs(String, Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
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
removeRegionReplicasFromMeta(Set<byte[]>, int, int, Connection) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Deletes some replica columns corresponding to replicas for the passed rows
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
removeReplicationPeer(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
removeReplicationPeer(RpcController, ReplicationProtos.RemoveReplicationPeerRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
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
removeReplicationPeerTableCFs(String, Map<TableName, List<String>>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
removeTableCFsFromReplicationPeerConfig(Map<TableName, List<String>>, ReplicationPeerConfig, String) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
 
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(Bytes) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
removeValue(Bytes) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Remove metadata represented by the key from the TableDescriptorBuilder.ModifyableTableDescriptor.values map
removeValue(byte[]) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Remove metadata represented by the key from the TableDescriptorBuilder.ModifyableTableDescriptor.values map
removeValue(Bytes) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
removeValue(byte[]) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
removeValue(K, V) - Method in class org.apache.hadoop.hbase.util.PoolMap
 
renew - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
renewLease() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
renewLease() - Method in interface org.apache.hadoop.hbase.client.ResultScanner
Allow the client to renew the scanner's lease on the server.
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.
replicaId - Variable in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
replicateAllUserTables() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
REPLICATION_SCOPE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
REPLICATION_SCOPE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
REPLICATION_SCOPE_BYTES - Static variable in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
 
REPLICATION_SCOPE_BYTES - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
ReplicationAdmin - Class in org.apache.hadoop.hbase.client.replication
Deprecated.
use Admin instead.
ReplicationAdmin(Configuration) - Constructor for class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
Constructor that creates a connection to the local ZooKeeper ensemble.
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
 
REPLICATIONGLOBAL - Static variable in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
 
ReplicationLoadSink - Class in org.apache.hadoop.hbase.replication
A HBase ReplicationLoad to present MetricsSink information
ReplicationLoadSink(long, long) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationLoadSink
 
ReplicationLoadSource - Class in org.apache.hadoop.hbase.replication
A HBase ReplicationLoad to present MetricsSource information
ReplicationLoadSource(String, long, int, long, long) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationLoadSource
 
ReplicationPeerConfig - Class in org.apache.hadoop.hbase.replication
A configuration for the replication peer cluster.
ReplicationPeerConfig() - Constructor for class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0. Use ReplicationPeerConfigBuilder to create new ReplicationPeerConfig.
ReplicationPeerConfigBuilder - Interface in org.apache.hadoop.hbase.replication
For creating ReplicationPeerConfig.
ReplicationPeerConfigUtil - Class in org.apache.hadoop.hbase.client.replication
Helper for TableCFs Operations.
ReplicationPeerDescription - Class in org.apache.hadoop.hbase.replication
The POJO equivalent of ReplicationProtos.ReplicationPeerDescription
ReplicationPeerDescription(String, boolean, ReplicationPeerConfig) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationPeerDescription
 
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
 
REPLICATIONTYPE - Static variable in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
 
replicationZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
 
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
 
RequestConverter - Class in org.apache.hadoop.hbase.shaded.protobuf
Helper utility to build protocol buffer requests, or build components for protocol buffer requests.
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
 
reset() - Method in class org.apache.hadoop.hbase.client.ClientCoprocessorRpcController
 
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.FilterBase
Filters that are purely stateless and do nothing in their reset() methods can inherit this null/empty implementation.
reset() - Method in class org.apache.hadoop.hbase.filter.FilterList
 
reset() - Method in class org.apache.hadoop.hbase.filter.FilterListWithAND
 
reset() - Method in class org.apache.hadoop.hbase.filter.FilterListWithOR
 
reset() - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
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 class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
reset() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
reset() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
 
resetCallTimeout() - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
 
ResponseConverter - Class in org.apache.hadoop.hbase.shaded.protobuf
Helper utility to build protocol buffer responses, or retrieve data from protocol buffer responses.
restoreSnapshot(byte[]) - 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.Admin
Restore the specified snapshot on the original table.
restoreSnapshot(byte[], boolean) - 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(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
restoreSnapshot(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
restoreSnapshot(byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
restoreSnapshot(String, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
restoreSnapshot(String, boolean, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
restoreSnapshot(RpcController, MasterProtos.RestoreSnapshotRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
restoreSnapshotAsync(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Restore the specified snapshot on the original table.
restoreSnapshotAsync(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
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, Exception) - 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().
ResultBoundedCompletionService<V> - Class in org.apache.hadoop.hbase.client
A completion service for the RpcRetryingCallerFactory.
ResultBoundedCompletionService(RpcRetryingCallerFactory, Executor, int) - Constructor for class org.apache.hadoop.hbase.client.ResultBoundedCompletionService
 
ResultScanner - Interface in org.apache.hadoop.hbase.client
Interface for client-side scanning.
ResultStatsUtil - Class in org.apache.hadoop.hbase.client
A Result with some statistics about the server/region status
resume() - Method in interface org.apache.hadoop.hbase.client.AdvancedScanResultConsumer.ScanResumer
Resume the scan.
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.
RetriesExhaustedException.ThrowableWithExtraContext - Class in org.apache.hadoop.hbase.client
Datastructure that allows adding more info around Throwable incident.
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
 
RetryImmediatelyException - Exception in org.apache.hadoop.hbase
 
RetryImmediatelyException(String) - Constructor for exception org.apache.hadoop.hbase.RetryImmediatelyException
 
RetryingCallable<T> - Interface in org.apache.hadoop.hbase.client
A Callable<T> that will be retried.
ReusablePool(int) - Constructor for class org.apache.hadoop.hbase.util.PoolMap.ReusablePool
 
reversed - Variable in class org.apache.hadoop.hbase.filter.Filter
 
ReversedClientScanner - Class in org.apache.hadoop.hbase.client
A reversed client scanner which support backward scanning
ReversedClientScanner(Configuration, Scan, TableName, ClusterConnection, RpcRetryingCallerFactory, RpcControllerFactory, ExecutorService, int) - Constructor for class org.apache.hadoop.hbase.client.ReversedClientScanner
Create a new ReversibleClientScanner for the specified table Note that the passed Scan's start row maybe changed.
ReversedScannerCallable - Class in org.apache.hadoop.hbase.client
A reversed ScannerCallable which supports backward scanning.
ReversedScannerCallable(ClusterConnection, TableName, Scan, ScanMetrics, RpcControllerFactory) - Constructor for class org.apache.hadoop.hbase.client.ReversedScannerCallable
 
ReversedScannerCallable(ClusterConnection, TableName, Scan, ScanMetrics, RpcControllerFactory, int) - Constructor for class org.apache.hadoop.hbase.client.ReversedScannerCallable
 
revoke(Connection, TableName, String, byte[], byte[], Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
Revokes the permission on the table
revoke(Connection, String, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
Revokes the permission on the table for the specified user.
revoke(Connection, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
Revoke global permissions for the specified user.
revoke(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
A utility used to revoke a user's global permissions.
revoke(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, TableName, byte[], byte[], Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
A utility used to revoke a user's table permissions.
revoke(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
A utility used to revoke a user's namespace permissions.
rollHLogWriter(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
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.
rollWALWriter(ServerName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
row - Variable in class org.apache.hadoop.hbase.client.Mutation
 
row - Variable in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
Row - Interface in org.apache.hadoop.hbase.client
Has a row.
RowAccess<T> - Interface in org.apache.hadoop.hbase.client
Provide a way to access the inner buffer.
RowFilter - Class in org.apache.hadoop.hbase.filter
This filter is used to filter based on the key.
RowFilter(CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.RowFilter
Deprecated.
Since 2.0.0. Will remove in 3.0.0. Use RowFilter.RowFilter(CompareOperator, ByteArrayComparable)} instead.
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
 
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
 
RPAREN - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for RPAREN
RPC_CALLS_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
 
RPC_RETRIES_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
 
rpcCall() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
Run the RPC call.
rpcCall() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
RpcChannelImplementation(AbstractRpcClient<?>, InetSocketAddress, User, int) - Constructor for class org.apache.hadoop.hbase.ipc.AbstractRpcClient.RpcChannelImplementation
 
RpcClient - Interface in org.apache.hadoop.hbase.ipc
Interface for RpcClient implementations so ConnectionManager can handle it.
RpcClientFactory - Class in org.apache.hadoop.hbase.ipc
Factory to create a RpcClient
rpcController - Variable in class org.apache.hadoop.hbase.client.RegionServerCallable
This is 99% of the time a HBaseRpcController but also used doing Coprocessor Endpoints and in this case, it is a ServerRpcControllable which is not a HBaseRpcController.
rpcControllerFactory - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
rpcControllerFactory - Variable in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
rpcControllerFactory - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
RpcControllerFactory - Class in org.apache.hadoop.hbase.ipc
Factory to create a HBaseRpcController
RpcControllerFactory(Configuration) - Constructor for class org.apache.hadoop.hbase.ipc.RpcControllerFactory
 
rpcHistograms - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
RpcRetryingCaller<T> - Interface in org.apache.hadoop.hbase.client
 
RpcRetryingCallerFactory - Class in org.apache.hadoop.hbase.client
Factory to create an RpcRetryingCaller
RpcRetryingCallerFactory(Configuration) - Constructor for class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
 
RpcRetryingCallerFactory(Configuration, RetryingCallerInterceptor) - Constructor for class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
 
RpcRetryingCallerImpl<T> - Class in org.apache.hadoop.hbase.client
Runs an rpc'ing RetryingCallable.
RpcRetryingCallerImpl(long, long, int, int) - Constructor for class org.apache.hadoop.hbase.client.RpcRetryingCallerImpl
 
RpcRetryingCallerImpl(long, long, int, RetryingCallerInterceptor, int, int) - Constructor for class org.apache.hadoop.hbase.client.RpcRetryingCallerImpl
 
RpcRetryingCallerWithReadReplicas - Class in org.apache.hadoop.hbase.client
Caller that goes to replica if the primary region does no answer within a configurable timeout.
RpcRetryingCallerWithReadReplicas(RpcControllerFactory, TableName, ClusterConnection, Get, ExecutorService, int, int, int, int) - Constructor for class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
 
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
 
rpcTimers - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
RSGroupTableAccessor - Class in org.apache.hadoop.hbase
Read rs group information from hbase:rsgroup.
rsZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
 
run() - Method in class org.apache.hadoop.hbase.client.DelayingRunner
 
run(R) - Method in class org.apache.hadoop.hbase.ipc.BlockingRpcCallback
Called on completion of the RPC call with the response object, or null in the case of an error.
run(R) - Method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils.BlockingRpcCallback
Called on completion of the RPC call with the response object, or null in the case of an error.
run(boolean) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController.CancellationCallback
 
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.
runCatalogJanitor() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
runCatalogScan() - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use Admin.runCatalogJanitor()} instead.
runCatalogScan(RpcController, MasterProtos.RunCatalogScanRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
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.
runCleanerChore() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
runCleanerChore(RpcController, MasterProtos.RunCleanerChoreRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
runnerStats - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
RunnerStats(MetricRegistry) - Constructor for class org.apache.hadoop.hbase.client.MetricsConnection.RunnerStats
 
running - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 

S

S - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'S'
SASL_DEFAULT_REALM - Static variable in class org.apache.hadoop.hbase.security.SaslUtil
 
SaslChallengeDecoder - Class in org.apache.hadoop.hbase.security
Decode the sasl challenge sent by RpcServer.
SaslChallengeDecoder() - Constructor for class org.apache.hadoop.hbase.security.SaslChallengeDecoder
 
saslClient - Variable in class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
 
saslConnect(InputStream, OutputStream) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
Do client side SASL authentication with server via the given InputStream and OutputStream
saslProps - Variable in class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
 
SaslStatus - Enum in org.apache.hadoop.hbase.security
 
SaslUnwrapHandler - Class in org.apache.hadoop.hbase.security
Unwrap sasl messages.
SaslUnwrapHandler(SaslClient) - Constructor for class org.apache.hadoop.hbase.security.SaslUnwrapHandler
 
SaslUtil - Class in org.apache.hadoop.hbase.security
 
SaslUtil() - Constructor for class org.apache.hadoop.hbase.security.SaslUtil
 
SaslUtil.QualityOfProtection - Enum in org.apache.hadoop.hbase.security
 
SaslWrapHandler - Class in org.apache.hadoop.hbase.security
wrap sasl messages.
SaslWrapHandler(SaslClient) - Constructor for class org.apache.hadoop.hbase.security.SaslWrapHandler
 
scan(Scan, C) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
The scan API uses the observer pattern.
scan - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
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(byte[], Filter) - Constructor for class org.apache.hadoop.hbase.client.Scan
Deprecated.
use new Scan().withStartRow(startRow).setFilter(filter) instead.
Scan(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Scan
Deprecated.
use new Scan().withStartRow(startRow) instead.
Scan(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.client.Scan
Deprecated.
use new Scan().withStartRow(startRow).withStopRow(stopRow) instead.
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 - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
Scan.ReadType - Enum in org.apache.hadoop.hbase.client
 
SCAN_ATTRIBUTES_METRICS_DATA - Static variable in class org.apache.hadoop.hbase.client.Scan
Deprecated.
SCAN_ATTRIBUTES_METRICS_ENABLE - Static variable in class org.apache.hadoop.hbase.client.Scan
Deprecated.
SCAN_ATTRIBUTES_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.client.Scan
 
scanAll(Scan) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
Return all the results that match the given scan object.
scanMeta(Connection, TableName, MetaTableAccessor.QueryType, int, MetaTableAccessor.Visitor) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
 
scanMeta(Connection, byte[], byte[], MetaTableAccessor.QueryType, MetaTableAccessor.Visitor) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
 
scanMeta(Connection, MetaTableAccessor.Visitor, TableName, byte[], int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Performs a scan of META table for given table starting from given row.
scanMeta(Connection, byte[], byte[], MetaTableAccessor.QueryType, int, MetaTableAccessor.Visitor) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Performs a scan of META table.
scanMetaForTableRegions(Connection, MetaTableAccessor.Visitor, TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
 
scanMetrics - Variable in class org.apache.hadoop.hbase.client.AbstractClientScanner
 
ScanMetrics - Class in org.apache.hadoop.hbase.client.metrics
Provides metrics related to scan operations (both server side and client side metrics).
ScanMetrics() - Constructor for class org.apache.hadoop.hbase.client.metrics.ScanMetrics
constructor
scanMetrics - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
scanMetricsPublished - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
ScannerCallable - Class in org.apache.hadoop.hbase.client
Scanner operations such as create, next, etc.
ScannerCallable(ClusterConnection, TableName, Scan, ScanMetrics, RpcControllerFactory) - Constructor for class org.apache.hadoop.hbase.client.ScannerCallable
 
ScannerCallable(ClusterConnection, TableName, Scan, ScanMetrics, RpcControllerFactory, int) - Constructor for class org.apache.hadoop.hbase.client.ScannerCallable
 
scannerId - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
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
 
scannerTimeout - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
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.
scanTracker - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
SecureBulkLoadClient - Class in org.apache.hadoop.hbase.client
Client proxy for SecureBulkLoadProtocol
SecureBulkLoadClient(Configuration, Table) - Constructor for class org.apache.hadoop.hbase.client.SecureBulkLoadClient
 
secureBulkLoadHFiles(ClientProtos.ClientService.BlockingInterface, List<Pair<byte[], String>>, byte[], boolean, Token<?>, String) - Method in class org.apache.hadoop.hbase.client.SecureBulkLoadClient
Securely bulk load a list of HFiles using client protocol.
secureBulkLoadHFiles(ClientProtos.ClientService.BlockingInterface, List<Pair<byte[], String>>, byte[], boolean, Token<?>, String, boolean) - Method in class org.apache.hadoop.hbase.client.SecureBulkLoadClient
Securely bulk load a list of HFiles using client protocol.
SecurityCapability - Enum in org.apache.hadoop.hbase.client.security
Available security capabilities
SecurityInfo - Class in org.apache.hadoop.hbase.security
Maps RPC protocol interfaces to required configuration
SecurityInfo(String, AuthenticationProtos.TokenIdentifier.Kind) - Constructor for class org.apache.hadoop.hbase.security.SecurityInfo
 
selectToken(Text, Collection<Token<? extends TokenIdentifier>>) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSelector
 
sequenceNumber - Variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
ServerLoad - Class in org.apache.hadoop.hbase
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerMetrics instead.
ServerLoad(ClusterStatusProtos.ServerLoad) - Constructor for class org.apache.hadoop.hbase.ServerLoad
Deprecated.
DONT USE this construction.
ServerLoad(ServerName, ClusterStatusProtos.ServerLoad) - Constructor for class org.apache.hadoop.hbase.ServerLoad
Deprecated.
 
ServerLoad(ServerMetrics) - Constructor for class org.apache.hadoop.hbase.ServerLoad
Deprecated.
 
serverLoad - Variable in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
 
ServerMetrics - Interface in org.apache.hadoop.hbase
This class is used for exporting current state of load on a RegionServer.
ServerMetricsBuilder - Class in org.apache.hadoop.hbase
 
ServerNotRunningYetException - Exception in org.apache.hadoop.hbase.ipc
 
ServerNotRunningYetException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.ServerNotRunningYetException
 
ServerRpcController - Class in org.apache.hadoop.hbase.ipc
Used for server-side protobuf RPC service invocations.
ServerRpcController() - Constructor for class org.apache.hadoop.hbase.ipc.ServerRpcController
 
ServerSideScanMetrics - Class in org.apache.hadoop.hbase.client.metrics
Provides server side metrics related to scan operations.
ServerSideScanMetrics() - Constructor for class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
 
ServerStatistics - Class in org.apache.hadoop.hbase.client.backoff
Track the statistics for a single region
ServerStatistics() - Constructor for class org.apache.hadoop.hbase.client.backoff.ServerStatistics
 
ServerStatistics.RegionStatistics - Class in org.apache.hadoop.hbase.client.backoff
 
ServerStatisticTracker - Class in org.apache.hadoop.hbase.client
Tracks the statistics for multiple regions
ServerStatisticTracker() - Constructor for class org.apache.hadoop.hbase.client.ServerStatisticTracker
 
serverStats - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
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(InetSocketAddress, long) - Constructor for exception org.apache.hadoop.hbase.ipc.ServerTooBusyException
 
ServiceCaller<S,R> - Interface in org.apache.hadoop.hbase.client
Delegate to a protobuf rpc call.
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
 
setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Mutation
 
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
 
setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Query
 
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
 
setActions(Permission.Action[]) - Method in class org.apache.hadoop.hbase.security.access.Permission
 
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
 
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
 
setAuths(Configuration, String[], String) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
setAuths(Connection, String[], String) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
Sets given labels globally authorized for the user.
setBackerMasterNames(List<ServerName>) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
 
setBalancerOn(Boolean) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
 
setBalancerRunning(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use Admin.balancerSwitch(boolean, boolean) instead.
setBalancerRunning(RpcController, MasterProtos.SetBalancerRunningRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
setBandwidth(long) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0. Use ReplicationPeerConfigBuilder.setBandwidth(long) instead.
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.ModifyableColumnFamilyDescriptor
 
setBlockCacheEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setBlockCacheEnabled(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
setBlocksize(int) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
setBlocksize(int) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setBlocksize(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
setBloomFilterSize(Size) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
 
setBloomFilterType(BloomType) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
setBloomFilterType(BloomType) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setBloomFilterType(BloomType) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
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.ModifyableColumnFamilyDescriptor
 
setCacheBloomsOnWrite(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setCacheBloomsOnWrite(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
setCacheDataInL1(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
Since 2.0 and will be removed in 3.0 with out any replacement. Caching data in on heap Cache, when there are both on heap LRU Cache and Bucket Cache will no longer be supported from 2.0.
setCacheDataOnWrite(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
setCacheDataOnWrite(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setCacheDataOnWrite(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
setCacheIndexesOnWrite(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
setCacheIndexesOnWrite(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setCacheIndexesOnWrite(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
setCaching(int) - Method in class org.apache.hadoop.hbase.client.Scan
Set the number of rows for caching that will be passed to scanners.
setCaching(int) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
Set the number of rows that will be fetched on next
setCallTimeMs(long) - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
setCallTimeout(int) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
setCallTimeout(int) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
 
setCallTimeout(int) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
setCellScanner(CellScanner) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
setCellScanner(CellScanner) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
Only used to send cells to rpc server, the returned cells should be set by HBaseRpcController.setDone(CellScanner).
setCellScanner(CellScanner) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
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
 
setCleanerChoreRunning(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use Admin.cleanerChoreSwitch(boolean)} instead.
setCleanerChoreRunning(RpcController, MasterProtos.SetCleanerChoreRunningRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
setClose() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
Call this when the next invocation of call should close the scanner
setClosestRowBefore(boolean) - Method in class org.apache.hadoop.hbase.client.Get
Deprecated.
since 2.0.0 and will be removed in 3.0.0
setClusterId(String) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
 
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 class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0. Use ReplicationPeerConfigBuilder.setClusterKey(String) instead.
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
setColumnFamilies(Collection<ColumnFamilyDescriptor>) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setColumnFamily(ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Adds a column family.
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
 
setCompactedCellCount(long) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
 
setCompactingCellCount(long) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
 
setCompactionCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
Compression types supported in hbase.
setCompactionCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setCompactionCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
Compression types supported in hbase.
setCompactionEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Setting the table compaction enable flag.
setCompactionEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setCompactionEnabled(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Setting the table compaction enable flag.
setCompletedSequenceId(long) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
 
setCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
Compression types supported in hbase.
setCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
Compression types supported in hbase.
setCompressTags(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
Set whether the tags should be compressed along with DataBlockEncoding.
setCompressTags(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setCompressTags(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
Set whether the tags should be compressed along with DataBlockEncoding.
setConcurrentCallsPerServer(int) - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
setConfiguration(String, String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
Setter for storing a configuration setting in ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor.configuration map.
setConfiguration(String, String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setConfiguration(String, String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
Setter for storing a configuration setting.
setConfiguration(String, String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Setter for storing a configuration setting in 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
 
setControllerException(RpcController, IOException) - Static method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
Stores an exception encountered during RPC invocation so it can be passed back through to the client.
setControllerException(RpcController, IOException) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
Stores an exception encountered during RPC invocation so it can be passed back through to the client.
setCoprocessor(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Add a table coprocessor to this table.
setCoprocessor(CoprocessorDescriptor) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Add a table coprocessor to this table.
setCoprocessor(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setCoprocessor(CoprocessorDescriptor) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setCoprocessorNames(List<String>) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
 
setCoprocessors(Collection<CoprocessorDescriptor>) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setCoprocessorWithSpec(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Deprecated.
used by HTableDescriptor and admin.rb. As of release 2.0.0, this will be removed in HBase 3.0.0.
setCounter(String, long) - Method in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
 
setDataBlockEncoding(DataBlockEncoding) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
Set data block encoding algorithm used in block cache.
setDataBlockEncoding(DataBlockEncoding) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setDataBlockEncoding(DataBlockEncoding) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
Set data block encoding algorithm used in block cache.
setDataLocality(float) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
 
setDeadServerNames(List<ServerName>) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
 
setDFSReplication(short) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
Set the replication factor to hfile(s) belonging to this family
setDFSReplication(short) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setDFSReplication(short) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
Set the replication factor to hfile(s) belonging to this family
setDone(CellScanner) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
setDone(CellScanner) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
IMPORTANT: always call this method if the call finished without any exception to tell the HBaseRpcController that we are done.
setDone(CellScanner) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
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.ModifyableTableDescriptor
Sets the Durability setting for the table.
setDurability(Durability) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setDurability(Durability) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Sets the Durability setting for the table.
setEncryptionKey(byte[]) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
Set the raw crypto key attribute for the family
setEncryptionKey(byte[]) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setEncryptionKey(byte[]) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
Set the raw crypto key attribute for the family
setEncryptionType(String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
Set the encryption algorithm for use with this family
setEncryptionType(String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setEncryptionType(String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
Set the encryption algorithm for use with this family
setEndKey(byte[]) - Method in class org.apache.hadoop.hbase.client.RegionInfoBuilder
 
setEntry(SingleResponse.Entry) - Method in class org.apache.hadoop.hbase.client.SingleResponse
 
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.ModifyableColumnFamilyDescriptor
 
setEvictBlocksOnClose(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setEvictBlocksOnClose(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
setExcludeNamespaces(Set<String>) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0. Use ReplicationPeerConfigBuilder.setExcludeNamespaces(Set) instead.
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, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0. Use ReplicationPeerConfigBuilder.setExcludeTableCFsMap(Map) instead.
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
 
setFailed(String) - Method in class org.apache.hadoop.hbase.client.ClientCoprocessorRpcController
 
setFailed(Throwable) - Method in class org.apache.hadoop.hbase.client.ClientCoprocessorRpcController
 
setFailed(String) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
setFailed(IOException) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
setFailed(IOException) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
Set failed with an exception to pass on.
setFailed(String) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
setFailed(IOException) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
setFailed(String) - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
 
setFailedOn(IOException) - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
Sets an exception to be communicated back to the Service client.
setFamilyCellMap(NavigableMap<byte[], List<Cell>>) - Method in class org.apache.hadoop.hbase.client.Append
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Append.Append(byte[], long, NavigableMap) instead
setFamilyCellMap(NavigableMap<byte[], List<Cell>>) - Method in class org.apache.hadoop.hbase.client.Delete
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Delete.Delete(byte[], long, NavigableMap) instead
setFamilyCellMap(NavigableMap<byte[], List<Cell>>) - Method in class org.apache.hadoop.hbase.client.Increment
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Increment.Increment(byte[], long, NavigableMap) instead
setFamilyCellMap(NavigableMap<byte[], List<Cell>>) - Method in class org.apache.hadoop.hbase.client.Mutation
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Mutation.Mutation(byte[], long, NavigableMap) instead
setFamilyCellMap(NavigableMap<byte[], List<Cell>>) - Method in class org.apache.hadoop.hbase.client.Put
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Put.Put(byte[], long, NavigableMap) instead
setFamilyMap(Map<byte[], NavigableSet<byte[]>>) - Method in class org.apache.hadoop.hbase.client.Scan
Setting the familyMap
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
 
setFilteredReadRequestCount(long) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
 
setFilterIfMissing(boolean) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Set whether entire row should be filtered if column is not found.
setFlushPolicyClassName(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
This sets the class associated with the flush policy which determines determines the stores need to be flushed when flushing a region.
setFlushPolicyClassName(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setFlushPolicyClassName(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
This sets the class associated with the flush policy which determines determines the stores need to be flushed when flushing a region.
setFoundKV(boolean) - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
setHBaseVersion(String) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
 
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
 
setInfoServerPort(int) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
 
setInMemory(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
setInMemory(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setInMemory(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
setInMemoryCompaction(MemoryCompactionPolicy) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
setInMemoryCompaction(MemoryCompactionPolicy) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setInMemoryCompaction(MemoryCompactionPolicy) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
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
 
setJarPath(String) - Method in class org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder
 
setKeepDeletedCells(KeepDeletedCells) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
setKeepDeletedCells(KeepDeletedCells) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setKeepDeletedCells(KeepDeletedCells) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
setLastMajorCompactionTimestamp(long) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
 
setLastReportTimestamp(long) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
 
setLatestVersionOnly(boolean) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Set whether only the latest version of the column value should be compared.
setLimit(int) - Method in class org.apache.hadoop.hbase.client.Scan
Set the limit of rows for this scan.
setLiveServerMetrics(Map<ServerName, ServerMetrics>) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
 
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
 
setLocation(HRegionLocation) - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
 
setMasterCoprocessorNames(List<String>) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
 
setMasterInfoPort(int) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
 
setMasterName(ServerName) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
 
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.ModifyableTableDescriptor
Sets the maximum size upto which a region can grow to after which a region split is triggered.
setMaxFileSize(long) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setMaxFileSize(long) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Sets the maximum size upto which a region can grow to after which a region split is triggered.
setMaxHeapSize(Size) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
 
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.ModifyableColumnFamilyDescriptor
 
setMaxVersions(int) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setMaxVersions() - Method in class org.apache.hadoop.hbase.client.Get
Deprecated.
It is easy to misunderstand with column family's max versions, so use Get.readAllVersions() instead.
setMaxVersions(int) - Method in class org.apache.hadoop.hbase.client.Get
Deprecated.
It is easy to misunderstand with column family's max versions, so use Get.readVersions(int) instead.
setMaxVersions() - Method in class org.apache.hadoop.hbase.client.Scan
Deprecated.
It is easy to misunderstand with column family's max versions, so use Scan.readAllVersions() instead.
setMaxVersions(int) - Method in class org.apache.hadoop.hbase.client.Scan
Deprecated.
It is easy to misunderstand with column family's max versions, so use Scan.readVersions(int) instead.
setMaxVersions(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
setMemStoreFlushSize(long) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Represents the maximum size of the memstore after which the contents of the memstore are flushed to the filesystem.
setMemStoreFlushSize(long) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setMemStoreFlushSize(long) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Represents the maximum size of the memstore after which the contents of the memstore are flushed to the filesystem.
setMemStoreSize(Size) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
 
setMinVersions(int) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
setMinVersions(int) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setMinVersions(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
setMobCompactPartitionPolicy(MobCompactPartitionPolicy) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
Set the mob compact partition policy for the family.
setMobCompactPartitionPolicy(MobCompactPartitionPolicy) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setMobCompactPartitionPolicy(MobCompactPartitionPolicy) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
Set the mob compact partition policy for the family.
setMobEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
Enables the mob for the family.
setMobEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setMobEnabled(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
Enables the mob for the family.
setMobThreshold(long) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
Sets the mob threshold of the family.
setMobThreshold(long) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setMobThreshold(long) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
Sets the mob threshold of the family.
setMvccReadPoint(Scan, long) - Static method in class org.apache.hadoop.hbase.client.PackagePrivateFieldAccessor
 
setNamespaceFilter(String) - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
Set the namespace filter regex
setNamespaces(Set<String>) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0. Use ReplicationPeerConfigBuilder.setNamespaces(Set) instead.
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.
setNeedResults(boolean) - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
 
setNewStartKey() - Method in class org.apache.hadoop.hbase.client.ClientScanner
Will be called in moveToNextRegion when currentRegion is null.
setNewStartKey() - Method in class org.apache.hadoop.hbase.client.ClientSimpleScanner
 
setNewStartKey() - Method in class org.apache.hadoop.hbase.client.ReversedClientScanner
 
setNewVersionBehavior(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
setNewVersionBehavior(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setNewVersionBehavior(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
setNonce(long) - Method in class org.apache.hadoop.hbase.client.Action
 
setNonceGroup(long) - Method in class org.apache.hadoop.hbase.client.MultiAction
 
setNormalizationEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Setting the table normalization enable flag.
setNormalizationEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setNormalizationEnabled(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Setting the table normalization enable flag.
setNormalizerRunning(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use Admin.normalizerSwitch(boolean)} instead.
setNormalizerRunning(RpcController, MasterProtos.SetNormalizerRunningRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
setOffline(boolean) - Method in class org.apache.hadoop.hbase.client.ImmutableHRegionInfo
Deprecated.
 
setOffline(boolean) - Method in class org.apache.hadoop.hbase.client.RegionInfoBuilder
 
setOffline(boolean) - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
The parent of a region split is offline while split daughters hold references to the parent.
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(int) - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
 
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
Set operation timeout for this mutator instance
setOperationTimeout(int) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
 
setOperationTimeout(int) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
setOperationTimeout(int) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
since 2.0.0, use TableBuilder.setOperationTimeout(int) instead
setOperationTimeout(int) - Method in interface org.apache.hadoop.hbase.client.TableBuilder
Set timeout for a whole operation such as get, put or delete.
setOwner(User) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Deprecated.
setOwner(User) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Deprecated.
setOwner(User) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
setOwnerString(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Deprecated.
setOwnerString(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Deprecated.
setOwnerString(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
setPeerTableCFs(String, Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
setPool(ExecutorService) - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
 
setPrefetchBlocksOnOpen(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
setPrefetchBlocksOnOpen(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setPrefetchBlocksOnOpen(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
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.Scan
 
setPriority(int) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
 
setPriority(int) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setPriority(int) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
setPriority(int) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
setPriority(TableName) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
setPriority(int) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
 
setPriority(TableName) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
 
setPriority(int) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
setPriority(TableName) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
setProcessed(boolean) - Method in class org.apache.hadoop.hbase.client.SingleResponse.Entry
 
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
 
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.
setQuota(QuotaSettings) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
setQuota(RpcController, MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
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.ModifyableTableDescriptor
Setting the table as read only sets all the columns in the table as read only.
setReadOnly(boolean) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setReadOnly(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Setting the table as read only sets all the columns in the table as read only.
setReadRequestCount(long) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
 
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 class org.apache.hadoop.hbase.client.HTable
Deprecated.
setReadRpcTimeout(int) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
since 2.0.0, use TableBuilder.setReadRpcTimeout(int) instead
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.
setRegionId(long) - Method in class org.apache.hadoop.hbase.client.RegionInfoBuilder
 
setRegionMemStoreReplication(boolean) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Enable or Disable the memstore replication from the primary region to the replicas.
setRegionMemStoreReplication(boolean) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setRegionMemstoreReplication(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use HTableDescriptor.setRegionMemStoreReplication(boolean) instead
setRegionMemStoreReplication(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Enable or Disable the memstore replication from the primary region to the replicas.
setRegionMetrics(List<RegionMetrics>) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
 
setRegionReplication(int) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Sets the number of replicas per region.
setRegionReplication(int) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setRegionReplication(int) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Sets the number of replicas per region.
setRegionsInTransition(List<RegionState>) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
 
setRegionSplitPolicyClassName(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
This sets the class associated with the region split policy which determines when a region split should occur.
setRegionSplitPolicyClassName(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
setRegionSplitPolicyClassName(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
This sets the class associated with the region split policy which determines when a region split should occur.
setRenew(boolean) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
Indicate whether we make a call only to renew the lease, but without affected the scanner in any other way.
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.RegionInfoBuilder
 
setReplicaId(int) - Method in class org.apache.hadoop.hbase.client.Scan
 
setReplicateAllUserTables(boolean) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0. Use ReplicationPeerConfigBuilder.setReplicateAllUserTables(boolean) instead.
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 class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0. Use ReplicationPeerConfigBuilder.setReplicationEndpointImpl(String) instead.
setReplicationEndpointImpl(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
Sets the ReplicationEndpoint plugin class for this peer.
setReplicationLoadSink(ReplicationLoadSink) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
 
setReplicationLoadSources(List<ReplicationLoadSource>) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
 
setReplicationScope(int) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Sets replication scope all & only the columns already in the builder.
setReportTimestamp(long) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
 
setRequestCount(long) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
 
setRequestCountPerSecond(long) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
 
setRequestSizeBytes(long) - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
setResponseSizeBytes(long) - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
setResult(Result) - Method in class org.apache.hadoop.hbase.client.SingleResponse.Entry
 
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.
setReturnResults(boolean) - Method in class org.apache.hadoop.hbase.client.Append
 
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
 
setReversed(boolean) - Method in class org.apache.hadoop.hbase.filter.FilterListBase
 
setRowAccess(List<? extends Row>) - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
 
setRowAccess(RowAccess<? extends Row>) - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
 
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
Set a filter (using stopRow and startRow) so the result set only contains rows where the rowKey starts with the specified prefix.
setRpcControllerCellScanner(CellScanner) - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
 
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(int) - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
 
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
Set rpc timeout for this mutator instance
setRpcTimeout(int) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
 
setRpcTimeout(int) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
setRpcTimeout(int) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
Use setReadRpcTimeout or setWriteRpcTimeout instead
setRpcTimeout(int) - Method in interface org.apache.hadoop.hbase.client.TableBuilder
Set timeout for each rpc request.
setRunner(Runnable) - Method in class org.apache.hadoop.hbase.client.DelayingRunner
 
setScanMetricsEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
Enable collection of ScanMetrics.
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.ModifyableColumnFamilyDescriptor
 
setScope(int) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setScope(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
setServerSideHConnectionRetriesConfig(Configuration, String, Logger) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
Changes the configuration to set the number of retries needed when using Connection internally, e.g.
setSmall(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
Deprecated.
since 2.0.0. Use Scan.setLimit(int) and Scan.setReadType(ReadType) instead. And for the one rpc optimization, now we will also fetch data when openScanner, and if the number of rows reaches the limit then we will close the scanner automatically which means we will fall back to one rpc.
setSplit(boolean) - Method in class org.apache.hadoop.hbase.client.ImmutableHRegionInfo
Deprecated.
 
setSplit(boolean) - Method in class org.apache.hadoop.hbase.client.RegionInfoBuilder
 
setSplit(boolean) - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
 
setSplitOrMergeEnabled(boolean, boolean, MasterSwitchType...) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use Admin.splitSwitch(boolean, boolean) or Admin.mergeSwitch(boolean, boolean) instead.
setSplitOrMergeEnabled(RpcController, MasterProtos.SetSplitOrMergeEnabledRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
setStartKey(byte[]) - Method in class org.apache.hadoop.hbase.client.RegionInfoBuilder
 
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.client.Scan
Deprecated.
use Scan.withStartRow(byte[]) instead. This method may change the inclusive of the stop row to keep compatible with the old behavior.
setStartTime(long) - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
setStatistics(RegionLoadStats) - Method in class org.apache.hadoop.hbase.client.Result
Set load information about the region to the information about the result
setStatisticTracker(ServerStatisticTracker) - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
Set the tracker that should be used for tracking statistics about the server
setStopRow(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
Deprecated.
use Scan.withStopRow(byte[]) instead. This method may change the inclusive of the stop row to keep compatible with the old behavior.
setStoragePolicy(String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
Set the storage policy for use with this family
setStoragePolicy(String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setStoragePolicy(String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
Set the storage policy for use with this family
setStoreCount(int) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
 
setStoreFileCount(int) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
 
setStoreFileIndexSize(Size) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
 
setStoreFileRootLevelIndexSize(Size) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
 
setStoreFileSize(Size) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
 
setStoreFileUncompressedDataIndexSize(Size) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
 
setStoreSequenceIds(Map<byte[], Long>) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
 
setStub(AdminProtos.AdminService.BlockingInterface) - Method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
setStub(S) - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
 
setStubByServiceName(ServerName) - Method in class org.apache.hadoop.hbase.client.ClientServiceCallable
 
setStubByServiceName(ServerName) - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
Set the RCP client stub
setSubmittedRows(AsyncProcessTask.SubmittedRows) - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
 
setTableCFsMap(Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0. Use ReplicationPeerConfigBuilder.setTableCFsMap(Map) instead.
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(TableName) - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
 
setTableName(TableName) - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
setTableStateInMeta(TableState) - Method in class org.apache.hadoop.hbase.client.HBaseHbck
NOTE: This is a dangerous action, as existing running procedures for the table or regions which belong to the table may get confused.
setTableStateInMeta(TableState) - Method in interface org.apache.hadoop.hbase.client.Hbck
Update table state in Meta only.
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 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
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Get.setTimestamp(long) instead
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
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Scan.setTimestamp(long) instead
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.ModifyableColumnFamilyDescriptor
 
setTimeToLive(String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
setTimeToLive(int) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setTimeToLive(String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
setTimeToLive(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
setTimeToLive(String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
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
 
setUncompressedStoreFileSize(Size) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
 
setupMasterlessConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
Setup the connection class, so that it will not depend on master being online.
setupSaslHandler(ChannelPipeline) - Method in class org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClient
 
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.
setUsedHeapSize(Size) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
 
setUserFilter(String) - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
Set the user filter regex
setValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
setValue(String, String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
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(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Setter for storing metadata as a (key, value) pair in TableDescriptorBuilder.ModifyableTableDescriptor.values map
setValue(String, String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
 
setValue(Bytes, Bytes) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
 
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
 
setValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
setValue(String, String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
setValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Setter for storing metadata as a (key, value) pair in map
setValue(Bytes, Bytes) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
setValue(String, String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Setter for storing metadata as a (key, value) pair in map
setVersionNumber(int) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
 
setVersions(int, int) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
Set minimum and maximum versions to keep
setVersions(int, int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
Set minimum and maximum versions to keep
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.
setWriteBufferPeriodicFlush(long, long) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
 
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
Set the TimerTick how often the buffer timeout if checked.
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.
setWriteRequestCount(long) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
 
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 class org.apache.hadoop.hbase.client.HTable
Deprecated.
setWriteRpcTimeout(int) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
since 2.0.0, use TableBuilder.setWriteRpcTimeout(int) instead
setWriteRpcTimeout(int) - Method in interface org.apache.hadoop.hbase.client.TableBuilder
Set timeout for each write(put, delete) rpc request.
ShadedAccessControlUtil - Class in org.apache.hadoop.hbase.security.access
Convert protobuf objects in AccessControl.proto under hbase-protocol-shaded to user-oriented objects and vice versa.
ShadedAccessControlUtil() - Constructor for class org.apache.hadoop.hbase.security.access.ShadedAccessControlUtil
 
ShortCircuitMasterConnection - Class in org.apache.hadoop.hbase.client
A short-circuit connection that can bypass the RPC layer (serialization, deserialization, networking, etc..) when talking to a local master
ShortCircuitMasterConnection(MasterProtos.MasterService.BlockingInterface) - Constructor for class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
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.client.HBaseAdmin
 
shutdown() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
 
shutdown(RpcController, MasterProtos.ShutdownRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
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[], CompareFilter.CompareOp, byte[]) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
Deprecated.
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[], CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
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[], CompareFilter.CompareOp, ByteArrayComparable, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
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[], CompareFilter.CompareOp, byte[]) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Deprecated.
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[], CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
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[], CompareFilter.CompareOp, ByteArrayComparable, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
SingleColumnValueFilter(byte[], byte[], CompareOperator, ByteArrayComparable, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Constructor for protobuf deserialization only.
SingleResponse - Class in org.apache.hadoop.hbase.client
Class for single action response
SingleResponse() - Constructor for class org.apache.hadoop.hbase.client.SingleResponse
 
SingleResponse.Entry - Class in org.apache.hadoop.hbase.client
 
size() - Method in class org.apache.hadoop.hbase.client.MultiAction
Get the total number of Actions
size() - Method in class org.apache.hadoop.hbase.client.MultiResponse
 
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
 
size() - Method in interface org.apache.hadoop.hbase.client.RowAccess
 
size() - Method in class org.apache.hadoop.hbase.filter.FilterList
 
size() - Method in class org.apache.hadoop.hbase.filter.FilterListBase
 
size() - Method in class org.apache.hadoop.hbase.RegionLocations
Returns the size of the list even if some of the elements might be null.
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
 
size() - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
 
size() - Method in class org.apache.hadoop.hbase.util.PoolMap
 
size(K) - Method in class org.apache.hadoop.hbase.util.PoolMap
 
Size.Unit - Enum in org.apache.hadoop.hbase
 
sizeToString(long) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettings
 
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
 
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
 
sleep(long, int) - Method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
sleep(long, int) - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
 
sleep(long, int) - Method in interface org.apache.hadoop.hbase.client.RetryingCallable
 
snapshot(String, TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Take a snapshot for the given table.
snapshot(byte[], TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Create a timestamp consistent 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(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(String, TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
snapshot(byte[], TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
snapshot(String, TableName, SnapshotType) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
snapshot(SnapshotDescription) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
snapshot(RpcController, MasterProtos.SnapshotRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
snapshotAsync(SnapshotDescription) - Method in interface org.apache.hadoop.hbase.client.Admin
Take a snapshot without waiting for the server to complete that snapshot (asynchronous) Only a single snapshot should be taken at a time, or results may be undefined.
snapshotAsync(SnapshotDescription) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
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, String) - Constructor for class org.apache.hadoop.hbase.client.SnapshotDescription
Deprecated.
Use the version with the TableName instance instead
SnapshotDescription(String, TableName) - Constructor for class org.apache.hadoop.hbase.client.SnapshotDescription
 
SnapshotDescription(String, String, SnapshotType) - Constructor for class org.apache.hadoop.hbase.client.SnapshotDescription
Deprecated.
Use the version with the TableName instance instead
SnapshotDescription(String, TableName, SnapshotType) - Constructor for class org.apache.hadoop.hbase.client.SnapshotDescription
 
SnapshotDescription(String, String, SnapshotType, String) - Constructor for class org.apache.hadoop.hbase.client.SnapshotDescription
Deprecated.
Use the version with the TableName instance instead
SnapshotDescription(String, TableName, SnapshotType, String) - Constructor for class org.apache.hadoop.hbase.client.SnapshotDescription
 
SnapshotDescription(String, String, SnapshotType, String, long, int) - Constructor for class org.apache.hadoop.hbase.client.SnapshotDescription
Deprecated.
Use the version with the TableName instance instead
SnapshotDescription(String, TableName, SnapshotType, String, long, int) - Constructor for class org.apache.hadoop.hbase.client.SnapshotDescription
 
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
 
SnapshotExistsException(String, SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotExistsException
Failure due to the snapshot already existing
SnapshotType - Enum in org.apache.hadoop.hbase.client
POJO representing the snapshot type
SOCKET_TIMEOUT_CONNECT - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
 
SOCKET_TIMEOUT_READ - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
How long we wait when we wait for an answer.
SOCKET_TIMEOUT_WRITE - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
 
socketFactory - Variable in class org.apache.hadoop.hbase.ipc.BlockingRpcClient
 
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.
SORTED_ORDINAL_SERIALIZATION_FORMAT - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
Visibility serialization version format.
SORTED_ORDINAL_SERIALIZATION_FORMAT_TAG_VAL - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
Byte representation of the visibility_serialization_version
sortedPrefixes - Variable in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
SpaceQuotaSnapshot - Class in org.apache.hadoop.hbase.quotas
A point-in-time view of a space quota on a table.
SpaceQuotaSnapshot(SpaceQuotaSnapshot.SpaceQuotaStatus, long, long) - Constructor for class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
 
SpaceQuotaSnapshot.SpaceQuotaStatus - Class in org.apache.hadoop.hbase.quotas
Encapsulates the state of a quota on a table.
SpaceQuotaStatus(SpaceViolationPolicy) - Constructor for class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot.SpaceQuotaStatus
Constructs a SpaceQuotaSnapshot which is in violation of the provided policy.
SpaceViolationPolicy - Enum in org.apache.hadoop.hbase.quotas
Enumeration that represents the action HBase will take when a space quota is violated.
SPECIFIC_WRITE_THREAD - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
 
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(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
split(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
SPLIT_POLICY - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
SPLIT_POLICY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
splitKerberosName(String) - Static method in class org.apache.hadoop.hbase.security.SaslUtil
Splitting fully qualified Kerberos name into parts
splitLogZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
 
splitRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Admin.splitRegionAsync(byte[], byte[]).
splitRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Admin.splitRegionAsync(byte[], byte[]).
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.
splitRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
splitRegion(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
splitRegion(RpcController, MasterProtos.SplitTableRegionRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
splitRegion(Connection, RegionInfo, RegionInfo, RegionInfo, ServerName, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Splits the region into two in an atomic operation.
splitRegionAsync(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Split an individual region.
splitRegionAsync(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
splitRegionSync(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Split one region.
splitRegionSync(byte[], byte[], long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Split one 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 class org.apache.hadoop.hbase.client.HBaseAdmin
 
stampSet - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
start(CoprocessorEnvironment) - Method in interface org.apache.hadoop.hbase.Coprocessor
Called by the CoprocessorEnvironment during it's own startup to initialize the coprocessor.
startCancel() - Method in class org.apache.hadoop.hbase.client.ClientCoprocessorRpcController
 
startCancel() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
startCancel() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
startCancel() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
 
state - Variable in enum org.apache.hadoop.hbase.security.SaslStatus
 
StatisticTrackable - Interface in org.apache.hadoop.hbase.client
Parent interface for an object to get updates about per-region statistics.
stop(CoprocessorEnvironment) - Method in interface org.apache.hadoop.hbase.Coprocessor
Called by the CoprocessorEnvironment during it's own shutdown to stop the coprocessor.
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() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
stopMaster(RpcController, MasterProtos.StopMasterRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
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(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
STORAGE_POLICY - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
STORAGE_POLICY - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
stub - Variable in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
stub - Variable in class org.apache.hadoop.hbase.client.RegionServerCallable
 
subFiltersIncludedCell - Variable in class org.apache.hadoop.hbase.filter.FilterListBase
For each sub-filter in filter list, we save a boolean flag to indicate that whether the return code of filterCell(c) for sub-filter is INCLUDE* (INCLUDE, INCLUDE_AND_NEXT_COL, INCLUDE_AND_SEEK_NEXT_ROW) case.
submit(RetryingCallable<V>, int, int) - Method in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService
 
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
sum() - Method in class org.apache.hadoop.hbase.CacheEvictionStatsAggregator
 
sumOfMillisSecBetweenNexts - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
sum of milliseconds between sequential next calls
suspend() - Method in interface org.apache.hadoop.hbase.client.AdvancedScanResultConsumer.ScanController
Suspend the scan.
SWITCH_TO_SIMPLE_AUTH - Static variable in class org.apache.hadoop.hbase.security.SaslUtil
 
switchZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
 

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.CheckAndMutateBuilder - Interface in org.apache.hadoop.hbase.client
A helper class for sending checkAndMutate request.
TABLE_MULTIPLEXER_FLUSH_PERIOD_MS - Static variable in class org.apache.hadoop.hbase.client.HTableMultiplexer
 
TABLE_MULTIPLEXER_INIT_THREADS - Static variable in class org.apache.hadoop.hbase.client.HTableMultiplexer
 
TABLE_MULTIPLEXER_MAX_RETRIES_IN_QUEUE - Static variable in class org.apache.hadoop.hbase.client.HTableMultiplexer
 
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
 
TableDescriptorBuilder.ModifyableTableDescriptor - Class in org.apache.hadoop.hbase.client
TODO: make this private after removing the HTableDescriptor
tableExists(AsyncTable<?>, TableName) - Static method in class org.apache.hadoop.hbase.AsyncMetaTableAccessor
 
tableExists(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
 
tableExists(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
 
tableExists(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
tableExists(Connection, TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Checks if the specified 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
default constructor
TableExistsException(String) - Constructor for exception org.apache.hadoop.hbase.TableExistsException
Constructor
TableExistsException(TableName) - Constructor for exception org.apache.hadoop.hbase.TableExistsException
 
tableFieldsEqual(TablePermission) - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
TableFuture(HBaseAdmin, TableName, Long) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin.TableFuture
 
TableInfoMissingException - Exception in org.apache.hadoop.hbase
Failed to find .tableinfo file under table dir
TableInfoMissingException() - Constructor for exception org.apache.hadoop.hbase.TableInfoMissingException
 
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
 
tableLockZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
 
tableName - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
tableName - Variable in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
tableName - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
 
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
default constructor
TableNotDisabledException(String) - Constructor for exception org.apache.hadoop.hbase.TableNotDisabledException
Constructor
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
Constructor
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 can not be located
TableNotFoundException() - Constructor for exception org.apache.hadoop.hbase.TableNotFoundException
default constructor
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
 
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
 
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
 
TablePermission - Class in org.apache.hadoop.hbase.security.access
Represents an authorization for access for the given actions, optionally restricted to the given column family or column qualifier, over the given table.
TablePermission() - Constructor for class org.apache.hadoop.hbase.security.access.TablePermission
Nullary constructor for Writable, do not use
TablePermission(TableName, byte[], Permission.Action...) - Constructor for class org.apache.hadoop.hbase.security.access.TablePermission
Create a new permission for the given table and (optionally) column family, allowing the given actions.
TablePermission(TableName, byte[], byte[], Permission.Action...) - Constructor for class org.apache.hadoop.hbase.security.access.TablePermission
Creates a new permission for the given table, restricted to the given column family and qualifier, allowing the assigned actions to be performed.
TablePermission(TableName, byte[], byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.security.access.TablePermission
Creates a new permission for the given table, family and column qualifier, allowing the actions matching the provided byte codes to be performed.
TablePermission(String, TableName, byte[], byte[], Permission.Action...) - Constructor for class org.apache.hadoop.hbase.security.access.TablePermission
Creates a new permission for the given namespace or table, restricted to the given column family and qualifier, allowing the assigned actions to be performed.
TablePermission(String, TableName, byte[], byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.security.access.TablePermission
Creates a new permission for the given namespace or table, family and column qualifier, allowing the actions matching the provided byte codes to be performed.
TablePermission(String, byte[]) - Constructor for class org.apache.hadoop.hbase.security.access.TablePermission
Creates a new permission for the given namespace, allowing the actions matching the provided byte codes to be performed.
TablePermission(String, Permission.Action...) - Constructor for class org.apache.hadoop.hbase.security.access.TablePermission
Create a new permission for the given namespace, allowing the given actions.
TableState - Class in org.apache.hadoop.hbase.client
Represents table state.
TableState(TableName, TableState.State) - Constructor for class org.apache.hadoop.hbase.client.TableState
Create instance of TableState.
TableState.State - Enum in org.apache.hadoop.hbase.client
 
TableVisitorBase(TableName) - Constructor for class org.apache.hadoop.hbase.MetaTableAccessor.TableVisitorBase
 
TableWaitForStateCallable() - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin.TableFuture.TableWaitForStateCallable
 
tableZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
Deprecated.
take() - Method in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService
 
takeSnapshotAsync(SnapshotDescription) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use Admin.snapshotAsync(SnapshotDescription) instead.
targetReplicaId - Variable in class org.apache.hadoop.hbase.client.Query
 
tcpKeepAlive - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
tcpNoDelay - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
terminate() - Method in interface org.apache.hadoop.hbase.client.AdvancedScanResultConsumer.ScanController
Terminate the scan.
thenDelete(Delete) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateBuilder
 
thenDelete(Delete) - Method in interface org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder
 
thenMutate(RowMutations) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateBuilder
 
thenMutate(RowMutations) - Method in interface org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder
 
thenPut(Put) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateBuilder
 
thenPut(Put) - Method in interface org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder
 
throttleNamespace(String, ThrottleType, long, TimeUnit) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Throttle the specified namespace.
throttleTable(TableName, ThrottleType, long, TimeUnit) - 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, TableName, ThrottleType, long, TimeUnit) - 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.
ThrottlingException - Exception in org.apache.hadoop.hbase.quotas
Deprecated.
replaced by RpcThrottlingException since hbase-2.0.0.
ThrottlingException(String) - Constructor for exception org.apache.hadoop.hbase.quotas.ThrottlingException
Deprecated.
 
ThrottlingException(ThrottlingException.Type, long, String) - Constructor for exception org.apache.hadoop.hbase.quotas.ThrottlingException
Deprecated.
 
ThrottlingException.Type - Enum in org.apache.hadoop.hbase.quotas
Deprecated.
 
throwable(Throwable, boolean) - Method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
throwable(Throwable, boolean) - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
 
throwable(Throwable, boolean) - Method in interface org.apache.hadoop.hbase.client.RetryingCallable
Called when call throws an exception and we are going to retry; take action to make it so we succeed on next call (clear caches, do relookup of locations, etc.).
ThrowableWithExtraContext(Throwable, long, String) - Constructor for class org.apache.hadoop.hbase.client.RetriesExhaustedException.ThrowableWithExtraContext
 
throwInterruptedException() - Method in interface org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture.WaitForStateCallable
 
throwInterruptedException() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.TableFuture.TableWaitForStateCallable
 
throwNumReadRequestsExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
 
throwNumReadRequestsExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.ThrottlingException
Deprecated.
 
throwNumRequestsExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
 
throwNumRequestsExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.ThrottlingException
Deprecated.
 
throwNumWriteRequestsExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
 
throwNumWriteRequestsExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.ThrottlingException
Deprecated.
 
throwReadSizeExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
 
throwReadSizeExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.ThrottlingException
Deprecated.
 
throwRequestSizeExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
 
throwRequestSizeExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.ThrottlingException
Deprecated.
 
throwTimeoutException(long) - Method in interface org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture.WaitForStateCallable
 
throwTimeoutException(long) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.TableFuture.TableWaitForStateCallable
 
throwWriteSizeExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
 
throwWriteSizeExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.ThrottlingException
Deprecated.
 
timeBeforeReplicas - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
 
timeRange(TimeRange) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateBuilder
 
timeRange(TimeRange) - Method in interface org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder
 
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
 
TNAME - Static variable in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
 
toAppend(ClientProtos.MutationProto, CellScanner) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Mutate to an Append
toAppend(ClientProtos.MutationProto, CellScanner) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a protocol buffer Mutate to an Append
toAuthorizations(ClientProtos.Authorizations) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a protocol buffer Authorizations to a client Authorizations
toAuthorizations(byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a protocol buffer Authorizations bytes to a client Authorizations
toAuthorizations(Authorizations) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Create a protocol buffer Authorizations based on a client Authorizations.
toBulkLoadDescriptor(TableName, ByteString, Map<byte[], List<Path>>, Map<String, Long>, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Generates a marker for the WAL so that we propagate the notion of a bulk region load throughout the WAL.
toByte() - Method in enum org.apache.hadoop.hbase.client.IsolationLevel
 
toByteArray(ColumnFamilyDescriptor) - Static method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
toByteArray(RegionInfo) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
 
toByteArray(ReplicationPeerConfig) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
 
toByteArray(TableDescriptor) - Static method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
toByteArray() - Method in class org.apache.hadoop.hbase.ClusterId
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.BigDecimalComparator
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.BinaryComparator
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.BinaryPrefixComparator
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.BitComparator
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.FamilyFilter
 
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.FilterBase
Return length 0 byte array for Filters that don't require special serialization
toByteArray() - Method in class org.apache.hadoop.hbase.filter.FilterList
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
Deprecated.
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.LongComparator
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.NullComparator
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.QualifierFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.RowFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.SubstringComparator
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.ValueFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
toByteArray() - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.toByteArray(RegionInfo).
toByteArray() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
toByteArrayComparable(byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toBytes() - Method in enum org.apache.hadoop.hbase.client.IsolationLevel
 
toBytes() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
toBytes(ByteString) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toCacheEvictionStats(HBaseProtos.CacheEvictionStats) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toCacheEvictionStats(CacheEvictionStats) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toCell(Cell) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toCell(ExtendedCellBuilder, CellProtos.Cell) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toCell(Cell) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toCell(ExtendedCellBuilder, CellProtos.Cell) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toCellVisibility(ClientProtos.CellVisibility) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a protocol buffer CellVisibility to a client CellVisibility
toCellVisibility(byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a protocol buffer CellVisibility bytes to a client CellVisibility
toCellVisibility(CellVisibility) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Create a protocol buffer CellVisibility based on a client CellVisibility.
toClusterMetrics(ClusterStatusProtos.ClusterStatus) - Static method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
 
toClusterStatus(ClusterMetrics) - Static method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
 
toColumnFamilyDescriptor(HBaseProtos.ColumnFamilySchema) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Converts a ColumnFamilySchema to ColumnFamilyDescriptor
toColumnFamilySchema(ColumnFamilyDescriptor) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Converts an ColumnFamilyDescriptor to ColumnFamilySchema
toCompactionDescriptor(RegionInfo, byte[], List<Path>, List<Path>, Path) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toCompactionDescriptor(RegionInfo, byte[], byte[], List<Path>, List<Path>, Path) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toComparator(ByteArrayComparable) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a ByteArrayComparable to a protocol buffer Comparator
toComparator(ComparatorProtos.Comparator) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Comparator to a ByteArrayComparable
toComparator(ByteArrayComparable) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a ByteArrayComparable to a protocol buffer Comparator
toComparator(ComparatorProtos.Comparator) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a protocol buffer Comparator to a ByteArrayComparable
toConsistency(ClientProtos.Consistency) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toConsistency(Consistency) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toConsistency(ClientProtos.Consistency) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toConsistency(Consistency) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toCoprocessor(Collection<String>) - Static method in class org.apache.hadoop.hbase.ServerMetricsBuilder
 
toCursor(Cursor) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toCursor(Cell) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toCursor(ClientProtos.Cursor) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toDelete(ClientProtos.MutationProto) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Mutate to a Delete
toDelete(ClientProtos.MutationProto, CellScanner) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Mutate to a Delete
toDelete(ClientProtos.MutationProto) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a protocol buffer Mutate to a Delete
toDelete(ClientProtos.MutationProto, CellScanner) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a protocol buffer Mutate to a Delete
toDeleteType(KeyValue.Type) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a delete KeyValue type to protocol buffer DeleteType.
toDeleteType(KeyValue.Type) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a delete KeyValue type to protocol buffer DeleteType.
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).
toDelimitedByteArray() - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.toDelimitedByteArray(RegionInfo).
toDelimitedByteArray(HRegionInfo...) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.toDelimitedByteArray(RegionInfo...).
toDelimitedByteArray(Message) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toDescriptiveString() - Method in class org.apache.hadoop.hbase.master.RegionState
A slower (but more easy-to-read) stringification
toDurability(ClientProtos.MutationProto.Durability) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protobuf Durability into a client Durability
toDurability(Durability) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client Durability into a protbuf Durability
toDurability(ClientProtos.MutationProto.Durability) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a protobuf Durability into a client Durability
toDurability(Durability) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a client Durability into a protbuf Durability
toException(HBaseProtos.NameBytesPair) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a stringified protocol buffer exception Parameter to a Java Exception
toException(HBaseProtos.NameBytesPair) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a stringified protocol buffer exception Parameter to a Java Exception
toFilter(FilterProtos.Filter) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Filter to a client Filter
toFilter(Filter) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client Filter to a protocol buffer Filter
toFilter(FilterProtos.Filter) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a protocol buffer Filter to a client Filter
toFilter(Filter) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a client Filter to a protocol buffer Filter
toFlushDescriptor(WALProtos.FlushDescriptor.FlushAction, RegionInfo, long, Map<byte[], List<Path>>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toGet(ClientProtos.Get) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Get to a client Get
toGet(ClientProtos.MutationProto, CellScanner) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Mutate to a Get.
toGet(Get) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Create a protocol buffer Get based on a client Get.
toGet(ClientProtos.Get) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a protocol buffer Get to a client Get
toGet(ClientProtos.MutationProto, CellScanner) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a protocol buffer Mutate to a Get.
toGet(Get) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Create a protocol buffer Get based on a client Get.
toGroupInfo(RSGroupProtos.RSGroupInfo) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toHColumnDescriptor(ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.client.ImmutableHTableDescriptor
Deprecated.
 
toHColumnDescriptor(ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Return a HColumnDescriptor for user to keep the compatibility as much as possible.
toIncrement(ClientProtos.MutationProto, CellScanner) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Mutate to an Increment
toIncrement(ClientProtos.MutationProto, CellScanner) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a protocol buffer Mutate to an Increment
toIOException(ServiceException) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Unwraps an exception from a protobuf service into the underlying (expected) IOException.
toIOException(ServiceException) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Unwraps an exception from a protobuf service into the underlying (expected) IOException.
toJavaObject(MessageOrBuilder) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufMessageConverter
 
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.
toJsonElement(MessageOrBuilder) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufMessageConverter
 
toJsonElement(MessageOrBuilder, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufMessageConverter
 
toJsonString(MessageOrBuilder) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufMessageConverter
 
TOKEN_HANDLERS - Static variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
toLockJson(List<LockServiceProtos.LockedResource>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
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.
toMutation(ClientProtos.MutationProto) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a MutateRequest to Mutation
toMutation(ClientProtos.MutationProto.MutationType, Mutation) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toMutation(ClientProtos.MutationProto.MutationType, Mutation, long) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Create a protocol buffer Mutate based on a client Mutation
toMutation(ClientProtos.MutationProto.MutationType, Mutation, ClientProtos.MutationProto.Builder) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toMutation(ClientProtos.MutationProto.MutationType, Mutation, ClientProtos.MutationProto.Builder, long) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toMutation(ClientProtos.MutationProto) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a MutateRequest to Mutation
toMutation(ClientProtos.MutationProto.MutationType, Mutation) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toMutation(ClientProtos.MutationProto.MutationType, Mutation, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Create a protocol buffer Mutate based on a client Mutation
toMutation(ClientProtos.MutationProto.MutationType, Mutation, ClientProtos.MutationProto.Builder) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toMutation(ClientProtos.MutationProto.MutationType, Mutation, ClientProtos.MutationProto.Builder, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toMutationNoData(ClientProtos.MutationProto.MutationType, Mutation, ClientProtos.MutationProto.Builder) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Create a protocol buffer MutationProto based on a client Mutation.
toMutationNoData(ClientProtos.MutationProto.MutationType, Mutation) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Create a protocol buffer MutationProto based on a client Mutation.
toMutationNoData(ClientProtos.MutationProto.MutationType, Mutation, ClientProtos.MutationProto.Builder, long) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toMutationNoData(ClientProtos.MutationProto.MutationType, Mutation, ClientProtos.MutationProto.Builder) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Create a protocol buffer MutationProto based on a client Mutation.
toMutationNoData(ClientProtos.MutationProto.MutationType, Mutation) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Create a protocol buffer MutationProto based on a client Mutation.
toMutationNoData(ClientProtos.MutationProto.MutationType, Mutation, ClientProtos.MutationProto.Builder, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toNamespaceDescriptor(HBaseProtos.NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toNamespaceDescriptorList(MasterProtos.ListNamespaceDescriptorsResponse) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Get a list of NamespaceDescriptor from ListNamespaceDescriptorsResponse protobuf
toOption(ClusterStatusProtos.Option) - Static method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
Convert ClusterStatusProtos.Option to ClusterMetrics.Option
toOption(ClusterMetrics.Option) - Static method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
Convert ClusterMetrics.Option to ClusterStatusProtos.Option
toOptionalTimestamp(MasterProtos.MajorCompactionTimestampResponse) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toOptions(List<ClusterStatusProtos.Option>) - Static method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
Convert a list of ClusterStatusProtos.Option to an enum set of ClusterMetrics.Option
toOptions(EnumSet<ClusterMetrics.Option>) - Static method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
Convert an enum set of ClusterMetrics.Option to a list of ClusterStatusProtos.Option
toPermission(AccessControlProtos.Permission) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
Converts a Permission proto to a client Permission object.
toPermission(Permission) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
Convert a client Permission to a Permission proto
toPermission(Permission) - Static method in class org.apache.hadoop.hbase.security.access.ShadedAccessControlUtil
Convert a client Permission to a Permission shaded proto
toPermissionAction(AccessControlProtos.Permission.Action) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
Converts a Permission.Action proto to a client Permission.Action object.
toPermissionAction(Permission.Action) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
Convert a client Permission.Action to a Permission.Action proto
toPermissionAction(Permission.Action) - Static method in class org.apache.hadoop.hbase.security.access.ShadedAccessControlUtil
Convert a client user permission to a user permission shaded proto.
toPermissionAction(AccessControlProtos.Permission.Action) - Static method in class org.apache.hadoop.hbase.security.access.ShadedAccessControlUtil
Convert a Permission.Action shaded proto to a client Permission.Action object.
toPermissionActions(List<AccessControlProtos.Permission.Action>) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
Converts a list of Permission.Action proto to a list of client Permission.Action objects.
toPermissionActions(List<AccessControlProtos.Permission.Action>) - Static method in class org.apache.hadoop.hbase.security.access.ShadedAccessControlUtil
Converts a list of Permission.Action shaded proto to a list of client Permission.Action objects.
toProcedureJson(List<ProcedureProtos.Procedure>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Helper to convert the protobuf Procedure to JSON String
toProto(SpaceQuotaSnapshot.SpaceQuotaStatus) - Static method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot.SpaceQuotaStatus
 
toProtoNamespaceDescriptor(NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toProtoQuotaScope(QuotaScope) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a client QuotaScope to a protocol buffer QuotaScope
toProtoQuotaScope(QuotaType) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a client QuotaType to a protocol buffer QuotaType
toProtoReplicationPeerDescription(ReplicationPeerDescription) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
 
toProtoSnapshot(SpaceQuotaSnapshot) - Static method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
 
toProtoSpaceQuota(long, SpaceViolationPolicy) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Builds a protocol buffer SpaceQuota.
toProtoTableName(TableName) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toProtoTableName(TableName) - Static method in class org.apache.hadoop.hbase.security.access.ShadedAccessControlUtil
 
toProtoTableName(TableName) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toProtoThrottleType(ThrottleType) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a client ThrottleType to a protocol buffer ThrottleType
toProtoTimeUnit(TimeUnit) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a client TimeUnit to a protocol buffer TimeUnit
toProtoViolationPolicy(SpaceViolationPolicy) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Converts a client SpaceViolationPolicy to a protocol buffer SpaceViolationPolicy.
toPut(ClientProtos.MutationProto) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Mutate to a Put.
toPut(ClientProtos.MutationProto, CellScanner) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Mutate to a Put.
toPut(ClientProtos.MutationProto) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a protocol buffer Mutate to a Put.
toPut(ClientProtos.MutationProto, CellScanner) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a protocol buffer Mutate to a Put.
toQuotaScope(QuotaProtos.QuotaScope) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a protocol buffer QuotaScope to a client QuotaScope
toQuotaScope(QuotaProtos.QuotaType) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a protocol buffer QuotaType to a client QuotaType
toReadType(Scan.ReadType) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toReadType(ClientProtos.Scan.ReadType) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toReadType(Scan.ReadType) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toReadType(ClientProtos.Scan.ReadType) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toRegionEventDescriptor(WALProtos.RegionEventDescriptor.EventType, RegionInfo, long, ServerName, Map<byte[], List<Path>>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toRegionEventDescriptor(WALProtos.RegionEventDescriptor.EventType, byte[], byte[], byte[], long, ServerName, Map<byte[], List<Path>>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toRegionInfo(RegionInfo) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a RegionInfo to a Proto RegionInfo
toRegionInfo(HBaseProtos.RegionInfo) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert HBaseProto.RegionInfo to a RegionInfo
toRegionLoad(RegionMetrics) - Static method in class org.apache.hadoop.hbase.RegionMetricsBuilder
 
toRegionLocation(HRegionLocation) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toRegionLocation(HBaseProtos.RegionLocation) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toRegionMetrics(AdminProtos.GetRegionLoadResponse) - Static method in class org.apache.hadoop.hbase.RegionMetricsBuilder
 
toRegionMetrics(ClusterStatusProtos.RegionLoad) - Static method in class org.apache.hadoop.hbase.RegionMetricsBuilder
 
toReplicationLoadSink(ClusterStatusProtos.ReplicationLoadSink) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toReplicationLoadSink(ReplicationLoadSink) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toReplicationLoadSource(ClusterStatusProtos.ReplicationLoadSource) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toReplicationLoadSource(ReplicationLoadSource) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toReplicationPeerDescription(ReplicationProtos.ReplicationPeerDescription) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
 
toResult(Result) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client Result to a protocol buffer Result
toResult(boolean, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client Result to a protocol buffer Result
toResult(ClientProtos.Result) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Result to a client Result
toResult(ClientProtos.Result, CellScanner) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Result to a client Result
toResult(Result) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a client Result to a protocol buffer Result
toResult(boolean, boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a client Result to a protocol buffer Result
toResult(ClientProtos.Result) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a protocol buffer Result to a client Result
toResult(ClientProtos.Result, CellScanner) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a protocol buffer Result to a client Result
toResultNoData(Result) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client Result to a protocol buffer Result.
toResultNoData(Result) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a client Result to a protocol buffer Result.
toRow(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CoprocessorServiceBuilder
 
toRow(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CoprocessorServiceBuilder
 
toScan(Scan) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client Scan to a protocol buffer Scan
toScan(ClientProtos.Scan) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Scan to a client Scan
toScan(Scan) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a client Scan to a protocol buffer Scan
toScan(ClientProtos.Scan) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a protocol buffer Scan to a client Scan
toScanMetrics(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toScanMetrics(byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toScanMetrics(ScanMetrics, boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toSecurityCapabilityList(List<MasterProtos.SecurityCapabilitiesResponse.Capability>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert SecurityCapabilitiesResponse.Capability to SecurityCapability
toServerLoad(ServerMetrics) - Static method in class org.apache.hadoop.hbase.ServerMetricsBuilder
 
toServerMetrics(ClusterStatusProtos.LiveServerInfo) - Static method in class org.apache.hadoop.hbase.ServerMetricsBuilder
 
toServerMetrics(ServerName, ClusterStatusProtos.ServerLoad) - Static method in class org.apache.hadoop.hbase.ServerMetricsBuilder
 
toServerMetrics(ServerName, int, ClusterStatusProtos.ServerLoad) - Static method in class org.apache.hadoop.hbase.ServerMetricsBuilder
 
toServerName(ServerName) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a ServerName to a protocol buffer ServerName
toServerName(HBaseProtos.ServerName) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer ServerName to a ServerName
toServerName(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Get a ServerName from the passed in data bytes.
toServerName(ServerName) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a ServerName to a protocol buffer ServerName
toServerName(HBaseProtos.ServerName) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a protocol buffer ServerName to a ServerName
toServerNameList(List<HBaseProtos.ServerName>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a list of protocol buffer ServerName to a list of ServerName
toSnapshotDescriptionList(MasterProtos.GetCompletedSnapshotsResponse, Pattern) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toSpaceQuotaSnapshot(QuotaProtos.SpaceQuotaSnapshot) - Static method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
 
toStatus(QuotaProtos.SpaceQuotaStatus) - Static method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot.SpaceQuotaStatus
 
toString() - Method in class org.apache.hadoop.hbase.CacheEvictionStats
 
toString() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
toString() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.NamespaceFuture
 
toString() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.TableFuture
 
toString() - Method in class org.apache.hadoop.hbase.client.HTable
 
toString() - Method in class org.apache.hadoop.hbase.client.Increment
 
toString() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallTracker
 
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.RegionCoprocessorServiceExec
 
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.RetriesExhaustedException.ThrowableWithExtraContext
 
toString() - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallerImpl
 
toString() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
 
toString() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
 
toString() - Method in class org.apache.hadoop.hbase.client.TableState
 
toString() - Method in class org.apache.hadoop.hbase.ClusterId
 
toString() - Method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
 
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.FilterBase
Return filter's info for debugging and logging purpose.
toString() - Method in class org.apache.hadoop.hbase.filter.FilterList
 
toString() - Method in class org.apache.hadoop.hbase.filter.FilterListBase
 
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.HColumnDescriptor
Deprecated.
 
toString() - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
 
toString() - Method in class org.apache.hadoop.hbase.HRegionLocation
 
toString() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
toString() - Method in class org.apache.hadoop.hbase.master.RegionState
 
toString() - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot.SpaceQuotaStatus
 
toString() - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
 
toString() - Method in class org.apache.hadoop.hbase.RegionLoad
Deprecated.
 
toString() - Method in class org.apache.hadoop.hbase.RegionLocations
 
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.security.access.Permission
 
toString() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
toString() - Method in class org.apache.hadoop.hbase.security.access.UserPermission
 
toString() - Method in class org.apache.hadoop.hbase.security.visibility.Authorizations
 
toString() - Method in class org.apache.hadoop.hbase.security.visibility.CellVisibility
 
toString() - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
 
toString() - Method in class org.apache.hadoop.hbase.Size
 
toString(SnapshotProtos.SnapshotDescription) - Static method in class org.apache.hadoop.hbase.snapshot.ClientSnapshotDescriptionUtils
Returns a single line (no \n) representation of snapshot metadata.
toString() - Method in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
 
toStringCustomizedValues() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
 
toStringCustomizedValues() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
toStringCustomizedValues() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
 
toStringCustomizedValues() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
toStringCustomizedValues() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
toStringTableAttributes() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
 
toStringTableAttributes() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
toTableDescriptor(HBaseProtos.TableSchema) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Converts a TableSchema to TableDescriptor
toTableDescriptorList(MasterProtos.GetTableDescriptorsResponse) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Get a list of TableDescriptor from GetTableDescriptorsResponse protobuf
toTableDescriptorList(MasterProtos.ListTableDescriptorsByNamespaceResponse) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Get a list of TableDescriptor from ListTableDescriptorsByNamespaceResponse protobuf
toTableName(TableProtos.TableName) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toTableName(HBaseProtos.TableName) - Static method in class org.apache.hadoop.hbase.security.access.ShadedAccessControlUtil
 
toTableName(HBaseProtos.TableName) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toTableNameList(List<HBaseProtos.TableName>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toTablePermission(AccessControlProtos.Permission) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
Converts a Permission proto to a client TablePermission object.
toTablePermission(AccessControlProtos.Permission) - Static method in class org.apache.hadoop.hbase.security.access.ShadedAccessControlUtil
Converts a Permission shaded proto to a client TablePermission object.
toTableSchema(TableDescriptor) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Converts an TableDescriptor to TableSchema
toText(Message) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toThrottleType(QuotaProtos.ThrottleType) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a protocol buffer ThrottleType to a client ThrottleType
toTimedQuota(long, TimeUnit, QuotaScope) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Build a protocol buffer TimedQuota
toTimeRange(TimeRange) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toTimeRange(HBaseProtos.TimeRange) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toTimeRange(TimeRange) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
toTimeUnit(HBaseProtos.TimeUnit) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a protocol buffer TimeUnit to a client TimeUnit
toUserPermission(UserPermission) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
Convert a client user permission to a user permission proto
toUserPermission(AccessControlProtos.UserPermission) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
Converts a user permission proto to a client user permission object.
toUsersAndPermissions(String, Permission) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
 
toUsersAndPermissions(ListMultimap<String, Permission>) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
 
toUsersAndPermissions(AccessControlProtos.UsersAndPermissions) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
 
toUserTablePermissions(ListMultimap<String, TablePermission>) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
Convert a ListMultimap<String, TablePermission> where key is username to a protobuf UserPermission
toUserTablePermissions(AccessControlProtos.UsersAndPermissions) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
Convert a protobuf UserTablePermissions to a ListMultimap<String, TablePermission> where key is username.
toUserTablePermissions(AccessControlProtos.UsersAndPermissions) - Static method in class org.apache.hadoop.hbase.security.access.ShadedAccessControlUtil
Convert a shaded protobuf UserTablePermissions to a ListMultimap<String, TablePermission> where key is username.
toUserTablePermissions(ListMultimap<String, TablePermission>) - Static method in class org.apache.hadoop.hbase.security.access.ShadedAccessControlUtil
Convert a ListMultimap<String, TablePermission> where key is username to a shaded protobuf UserPermission
toViolationPolicy(QuotaProtos.SpaceViolationPolicy) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Converts a protocol buffer SpaceViolationPolicy to a client SpaceViolationPolicy.
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.FilterBase
By default no transformation takes place 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.FilterListBase
For FilterList, we can consider a filter list as a node in a tree.
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
 
translatePFFE(Throwable) - Static method in class org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
Translates exception for preemptive fast fail checks.
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.client.HBaseAdmin
 
truncateTable(RpcController, MasterProtos.TruncateTableRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
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.
truncateTableAsync(TableName, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
ts - Variable in class org.apache.hadoop.hbase.client.Mutation
 
TTL - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
TTL - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
type() - Method in class org.apache.hadoop.hbase.client.MultiResponse
 
type() - Method in class org.apache.hadoop.hbase.client.SingleResponse
 

U

unassign(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Unassign a region from current hosting regionserver.
unassign(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Unassign a region from current hosting regionserver.
unassign(byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
unassignRegion(RpcController, MasterProtos.UnassignRegionRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
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
 
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
constructor
UnknownScannerException(String) - Constructor for exception org.apache.hadoop.hbase.UnknownScannerException
Constructor
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
 
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.
unthrottleTable(TableName) - 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.
unwrapKey(Configuration, String, byte[]) - Static method in class org.apache.hadoop.hbase.security.EncryptionUtil
Unwrap a key by decrypting it with the secret key of the given subject.
unwrapKey(Configuration, byte[]) - Static method in class org.apache.hadoop.hbase.security.EncryptionUtil
Helper for EncryptionUtil.unwrapKey(Configuration, String, byte[]) which automatically uses the configured master and alternative keys, rather than having to specify a key type to unwrap with.
unwrapRemoteException() - Method in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
 
unwrapWALKey(Configuration, String, byte[]) - Static method in class org.apache.hadoop.hbase.security.EncryptionUtil
Unwrap a wal key by decrypting it with the secret key of the given subject.
update(RegionLoadStats) - Method in class org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
 
update(byte[], RegionLoadStats) - Method in class org.apache.hadoop.hbase.client.backoff.ServerStatistics
Good enough attempt.
update(byte[], byte[], R) - Method in interface org.apache.hadoop.hbase.client.coprocessor.Batch.Callback
 
update(RegionLoadStats) - Method in class org.apache.hadoop.hbase.client.MetricsConnection.RegionStats
 
updateCachedLocations(TableName, byte[], byte[], Object, ServerName) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Update the location cache.
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(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(ServerName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
updateConfiguration() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
updateDelayInterval(long) - Method in class org.apache.hadoop.hbase.client.MetricsConnection.RunnerStats
 
updateDelayInterval(long) - Method in class org.apache.hadoop.hbase.client.MetricsConnection
Update delay interval of delay runner.
updateLocation(HRegionLocation, boolean, boolean) - Method in class org.apache.hadoop.hbase.RegionLocations
Updates the location with new only if the new location has a higher seqNum than the old one or force is true.
updatePeerConfig(String, ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
updateRegionLocation(Connection, RegionInfo, ServerName, long, long) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Updates the location of the specified region in hbase:meta to be the specified server hostname and startcode.
updateRegionStats(ServerName, byte[], RegionLoadStats) - Method in class org.apache.hadoop.hbase.client.MetricsConnection
 
updateRegionStats(ServerName, byte[], RegionLoadStats) - Method in class org.apache.hadoop.hbase.client.ServerStatisticTracker
 
updateRegionStats(ServerName, byte[], RegionLoadStats) - Method in interface org.apache.hadoop.hbase.client.StatisticTrackable
Update stats per region.
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
updateReplicationPeerConfig(String, ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
updateReplicationPeerConfig(RpcController, ReplicationProtos.UpdateReplicationPeerConfigRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
updateRpc(MetricsConnection.CallStats) - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallTracker
 
updateRpc(Descriptors.MethodDescriptor, Message, MetricsConnection.CallStats) - Method in class org.apache.hadoop.hbase.client.MetricsConnection
Report RPC context to metrics system.
updateServerStats(ServerName, byte[], Object) - Method in class org.apache.hadoop.hbase.client.MetricsConnection
 
updateStats(T, ServerStatisticTracker, ServerName, byte[]) - Static method in class org.apache.hadoop.hbase.client.ResultStatsUtil
Update the stats for the specified region if the result is an instance of ResultStatsUtil
updateStats(StatisticTrackable, ServerName, byte[], RegionLoadStats) - Static method in class org.apache.hadoop.hbase.client.ResultStatsUtil
 
updateStats(T, ServerStatisticTracker, HRegionLocation) - Static method in class org.apache.hadoop.hbase.client.ResultStatsUtil
 
updateTableState(Connection, TableName, TableState.State) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Updates state in META
username - Variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
UserPermission - Class in org.apache.hadoop.hbase.security.access
Represents an authorization for access over the given table, column family plus qualifier, for the given user.
UserPermission() - Constructor for class org.apache.hadoop.hbase.security.access.UserPermission
Nullary constructor for Writable, do not use
UserPermission(byte[], Permission.Action...) - Constructor for class org.apache.hadoop.hbase.security.access.UserPermission
Creates a new instance for the given user.
UserPermission(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.security.access.UserPermission
Creates a new instance for the given user, matching the actions with the given codes.
UserPermission(byte[], String, Permission.Action...) - Constructor for class org.apache.hadoop.hbase.security.access.UserPermission
Creates a new instance for the given user.
UserPermission(byte[], String, byte[]) - Constructor for class org.apache.hadoop.hbase.security.access.UserPermission
Creates a new instance for the given user, matching the actions with the given codes.
UserPermission(byte[], TableName, byte[], Permission.Action...) - Constructor for class org.apache.hadoop.hbase.security.access.UserPermission
Creates a new instance for the given user, table and column family.
UserPermission(byte[], TableName, byte[], byte[], Permission.Action...) - Constructor for class org.apache.hadoop.hbase.security.access.UserPermission
Creates a new permission for the given user, table, column family and column qualifier.
UserPermission(byte[], TableName, byte[], byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.security.access.UserPermission
Creates a new instance for the given user, table, column family and qualifier, matching the actions with the given codes.
UserPermission(byte[], TablePermission) - Constructor for class org.apache.hadoop.hbase.security.access.UserPermission
Creates a new instance for the given user, table, column family and qualifier, matching the actions with the given codes.
userProvider - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 

V

validatePut(Put) - Method in class org.apache.hadoop.hbase.client.HTable
 
validatePut(Put, int) - Static method in class org.apache.hadoop.hbase.client.HTable
 
value() - Method in class org.apache.hadoop.hbase.client.Result
Returns the value of the first column in the Result.
ValueFilter - Class in org.apache.hadoop.hbase.filter
This filter is used to filter based on column value.
ValueFilter(CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.ValueFilter
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use ValueFilter.ValueFilter(CompareOperator, ByteArrayComparable)
ValueFilter(CompareOperator, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.ValueFilter
Constructor.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.AsyncProcessTask.SubmittedRows
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.SnapshotType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.TableState.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.ClusterMetrics.Option
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.Coprocessor.State
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.CompareFilter.CompareOp
Deprecated.
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.KeepDeletedCells
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.RegionState.State
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.MetaTableAccessor.QueryType
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.quotas.ThrottlingException.Type
Deprecated.
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.security.access.Permission.Action
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.security.AuthMethod
Returns the enum constant of this type with the specified name.
valueOf(byte) - Static method in enum org.apache.hadoop.hbase.security.AuthMethod
Return the object represented by the code.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.security.SaslStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.security.SaslUtil.QualityOfProtection
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.Size.Unit
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.util.PoolMap.PoolType
Returns the enum constant of this type with the specified name.
valueOf(String, PoolMap.PoolType, PoolMap.PoolType...) - Static method in enum org.apache.hadoop.hbase.util.PoolMap.PoolType
 
values() - Static method in enum org.apache.hadoop.hbase.client.AsyncProcessTask.SubmittedRows
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.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.client.TableState.State
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.ClusterMetrics.Option
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.Coprocessor.State
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.CompareFilter.CompareOp
Deprecated.
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.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.master.RegionState.State
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.MetaTableAccessor.QueryType
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.quotas.ThrottlingException.Type
Deprecated.
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.security.access.Permission.Action
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.security.AuthMethod
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.security.SaslStatus
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.security.SaslUtil.QualityOfProtection
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.Size.Unit
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
 
values() - Static method in enum org.apache.hadoop.hbase.util.PoolMap.PoolType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.hadoop.hbase.util.PoolMap.ReusablePool
 
values() - Method in class org.apache.hadoop.hbase.util.PoolMap
 
values(K) - Method in class org.apache.hadoop.hbase.util.PoolMap
 
VERSION - Static variable in interface org.apache.hadoop.hbase.Coprocessor
 
VERSION - Static variable in class org.apache.hadoop.hbase.security.access.Permission
 
VISIBILITY_LABELS_ATTR_KEY - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
The string that is used as key in setting the Operation attributes for visibility labels
VisibilityClient - Class in org.apache.hadoop.hbase.security.visibility
Utility client for doing visibility labels admin operations.
VisibilityClient() - Constructor for class org.apache.hadoop.hbase.security.visibility.VisibilityClient
 
VisibilityConstants - Class in org.apache.hadoop.hbase.security.visibility
 
VisibilityConstants() - Constructor for class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
 
VisibilityControllerNotReadyException - Exception in org.apache.hadoop.hbase.security.visibility
 
VisibilityControllerNotReadyException(String) - Constructor for exception org.apache.hadoop.hbase.security.visibility.VisibilityControllerNotReadyException
 
VisibilityLabelsValidator - Class in org.apache.hadoop.hbase.security.visibility
A simple validator that validates the labels passed
VisibilityLabelsValidator() - Constructor for class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsValidator
 
visit(Result) - Method in class org.apache.hadoop.hbase.MetaTableAccessor.DefaultVisitorBase
 
visit(Result) - Method in class org.apache.hadoop.hbase.MetaTableAccessor.TableVisitorBase
 
visit(Result) - Method in interface org.apache.hadoop.hbase.MetaTableAccessor.Visitor
Visit the catalog table row.
visitInternal(Result) - Method in class org.apache.hadoop.hbase.MetaTableAccessor.DefaultVisitorBase
 
visitNamespaceQuotas(String, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.quotas.QuotaTableUtil.NamespaceQuotasVisitor
 
visitTableQuotas(TableName, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.quotas.QuotaTableUtil.TableQuotasVisitor
 
visitUserQuotas(String, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.quotas.QuotaTableUtil.UserQuotasVisitor
 
visitUserQuotas(String, TableName, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.quotas.QuotaTableUtil.UserQuotasVisitor
 
visitUserQuotas(String, String, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.quotas.QuotaTableUtil.UserQuotasVisitor
 

W

W - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'W'
waitForAllRegionsOnline(long, byte[][]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.TableFuture
 
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.
waitForMaximumCurrentTasks(long, long, int, Consumer<Long>) - Method in interface org.apache.hadoop.hbase.client.RequestController
Waits for the running tasks to complete.
waitForSchemaUpdate(long) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.TableFuture
 
waitForState(long, HBaseAdmin.ProcedureFuture.WaitForStateCallable) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
waitForTableDisabled(long) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.TableFuture
 
waitForTableEnabled(long) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.TableFuture
 
waitOperationResult(long) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
Fallback implementation in case the procedure is not supported by the server.
waitTableNotFound(long) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.TableFuture
 
waitUntilDone() - Method in interface org.apache.hadoop.hbase.client.AsyncRequestFuture
Wait until all tasks are executed, successfully or not.
warmupRegion(RpcController, AdminProtos.AdminService.BlockingInterface, RegionInfo) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
A helper to warmup a region given a region name using admin protocol
wasOperationAttemptedByServer() - Method in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
 
WHEEL_TIMER - Static variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
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
withEvictedBlocks(long) - Method in class org.apache.hadoop.hbase.CacheEvictionStatsBuilder
 
withMaxCacheSize(long) - Method in class org.apache.hadoop.hbase.CacheEvictionStatsBuilder
 
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.
wrapKey(Configuration, byte[], String) - Static method in class org.apache.hadoop.hbase.security.EncryptionUtil
Protect a key by encrypting it with the secret key of the given subject.
wrapKey(Configuration, String, Key) - Static method in class org.apache.hadoop.hbase.security.EncryptionUtil
Protect a key by encrypting it with the secret key of the given subject.
Writables - Class in org.apache.hadoop.hbase.util
Utility class with methods for manipulating Writable objects
Writables() - Constructor for class org.apache.hadoop.hbase.util.Writables
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.security.access.Permission
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.security.access.UserPermission
 
write(DataOutput) - Method in enum org.apache.hadoop.hbase.security.AuthMethod
Write to out
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class org.apache.hadoop.hbase.security.CryptoAESWrapHandler
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class org.apache.hadoop.hbase.security.SaslWrapHandler
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
WRITE_BUFFER_PERIODIC_FLUSH_TIMEOUT_MS - Static variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
WRITE_BUFFER_PERIODIC_FLUSH_TIMEOUT_MS_DEFAULT - Static variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
WRITE_BUFFER_PERIODIC_FLUSH_TIMERTICK_MS - Static variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
WRITE_BUFFER_PERIODIC_FLUSH_TIMERTICK_MS_DEFAULT - Static variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
WRITE_BUFFER_SIZE_DEFAULT - Static variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
WRITE_BUFFER_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
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.
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
 
writeScanMetrics() - Method in class org.apache.hadoop.hbase.client.ClientScanner
Publish the scan metrics.
writeTO - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
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
 

Y

YouAreDeadException - Exception in org.apache.hadoop.hbase
This exception is thrown by the master when a region server reports and is already being processed as dead.
YouAreDeadException(String) - Constructor for exception org.apache.hadoop.hbase.YouAreDeadException
 

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
 
ZKMetadata - Class in org.apache.hadoop.hbase.zookeeper
The metadata append to the start of data on zookeeper.
ZNODE_PATH_SEPARATOR - Static variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
 
ZNodePaths - Class in org.apache.hadoop.hbase.zookeeper
Class that hold all the paths of znode for HBase.
ZNodePaths(Configuration) - Constructor for class org.apache.hadoop.hbase.zookeeper.ZNodePaths
 
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
default constructor
ZooKeeperConnectionException(String) - Constructor for exception org.apache.hadoop.hbase.ZooKeeperConnectionException
Constructor
ZooKeeperConnectionException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.ZooKeeperConnectionException
Constructor taking another exception.
ZooKeeperHelper - Class in org.apache.hadoop.hbase.zookeeper
Methods that help working with ZooKeeper
A B C D E F G H I J K L M N O P Q R S T U V W Y Z 
Skip navigation links

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