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.replication.ReplicationPeerZKImpl
 
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
Abortable - Interface in org.apache.hadoop.hbase
Interface to support the aborting of a given server or client.
abortable - Variable in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
 
abortable - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
Used to abort if a fatal error occurs
abortable - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
abortProcedure(long, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
abort a procedure
abortProcedure(long, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Abort a procedure
abortProcedureAsync(long, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Abort a procedure but does not block and wait for it be completely removed.
abortProcedureAsync(long, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Abort a procedure but does not block and wait for it be completely removed.
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
 
AbstractRpcClient - 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.BlockingRpcChannelImplementation(AbstractRpcClient, ServerName, User, int) - Constructor for class org.apache.hadoop.hbase.ipc.AbstractRpcClient.BlockingRpcChannelImplementation
 
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
 
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<R> - 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(Action<R>, 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
Add the specified column and value to this Append operation.
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<T>>>) - Method in class org.apache.hadoop.hbase.client.DelayingRunner
 
add(Cell) - Method in class org.apache.hadoop.hbase.client.Increment
Add the specified KeyValue to this operation.
add(byte[], Action<R>) - Method in class org.apache.hadoop.hbase.client.MultiAction
Add an Action to this container based on it's regionName.
add(byte[], List<Action<R>>) - 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(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
Deprecated.
add(byte[], byte[], long, byte[]) - Method in class org.apache.hadoop.hbase.client.Put
Deprecated.
add(byte[], ByteBuffer, long, ByteBuffer) - Method in class org.apache.hadoop.hbase.client.Put
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
Add a Put operation to the list of mutations
add(Delete) - Method in class org.apache.hadoop.hbase.client.RowMutations
Add a Delete operation to the list of mutations
add(S, S) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
 
addColumn(TableName, HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Add a column to an existing table.
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[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Add a column to an existing table.
addColumn(String, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Add a column to an existing table.
addColumn(TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Add a column to an existing table.
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.
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.HTableDescriptor
Add a table coprocessor to this table.
addCoprocessor(String, Path, int, Map<String, String>) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Add a table coprocessor to this table.
addCoprocessorWithSpec(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Add a table coprocessor to this table.
addDaughter(Connection, HRegionInfo, ServerName, long) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Adds a daughter region entry to meta.
addDaughtersToPut(Put, HRegionInfo, HRegionInfo) - 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
Advanced use only.
addEmptyLocation(Put, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
 
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.client.UnmodifyableHTableDescriptor
Does NOT add a column family.
addFamily(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.HTableDescriptor
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(Filter) - Method in class org.apache.hadoop.hbase.filter.FilterList
Add a filter.
addImmutable(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
addImmutable(byte[], byte[], byte[], Tag[]) - Method in class org.apache.hadoop.hbase.client.Put
This expects that the underlying arrays won't change.
addImmutable(byte[], byte[], long, byte[]) - Method in class org.apache.hadoop.hbase.client.Put
addImmutable(byte[], byte[], long, byte[], Tag[]) - Method in class org.apache.hadoop.hbase.client.Put
This expects that the underlying arrays won't change.
addImmutable(byte[], ByteBuffer, long, ByteBuffer, Tag[]) - Method in class org.apache.hadoop.hbase.client.Put
This expects that the underlying arrays won't change.
addImmutable(byte[], ByteBuffer, long, ByteBuffer) - Method in class org.apache.hadoop.hbase.client.Put
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, long, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
 
addLog(String, String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
Add a new WAL file to the given queue.
addLog(String, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
addPeer(String, String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
Use addPeer(String, ReplicationPeerConfig, Map) instead.
addPeer(String, String, String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
addPeer(String, ReplicationPeerConfig, Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Add a new remote slave cluster for replication.
addPeer(String, ReplicationPeerConfig, String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
Add a new remote slave cluster for replication.
addPeer(String, ReplicationPeerConfig, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
addRegionsToMeta(Connection, List<HRegionInfo>, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Adds a hbase:meta row for each of the specified new regions.
addRegionsToMeta(Connection, List<HRegionInfo>, int, long) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Adds a hbase:meta row for each of the specified new regions.
addRegionToMeta(Connection, HRegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Adds a hbase:meta row for the specified new region.
addRegionToMeta(Table, HRegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Adds a hbase:meta row for the specified new region to the given catalog table.
addRegionToMeta(Table, HRegionInfo, HRegionInfo, HRegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Adds a (single) hbase:meta row for the specified new region and its daughters.
addRegionToMeta(Connection, HRegionInfo, HRegionInfo, HRegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Adds a (single) hbase:meta row for the specified new region and its daughters.
addResults(ClientProtos.RegionLoadStats) - Method in class org.apache.hadoop.hbase.client.Result
addToCounter(String, long) - Method in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
 
addToFailedServers(InetSocketAddress) - Method in class org.apache.hadoop.hbase.ipc.FailedServers
Add an address to the list of the failed servers list.
addTokenForJob(Connection, JobConf, User) - Static method in class org.apache.hadoop.hbase.security.token.TokenUtil
Checks for an authentication token for the given user, obtaining a new token if necessary, and adds it to the credentials for the given map reduce job.
addTokenForJob(Connection, User, Job) - Static method in class org.apache.hadoop.hbase.security.token.TokenUtil
Checks for an authentication token for the given user, obtaining a new token if necessary, and adds it to the credentials for the given map reduce job.
addTokenIfMissing(Connection, User) - Static method in class org.apache.hadoop.hbase.security.token.TokenUtil
Checks if an authentication tokens exists for the connected cluster, obtaining one if needed and adding it to the user's credentials.
addTypeFilter(QuotaType) - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
Add a type to the filter list
Admin - Interface in org.apache.hadoop.hbase.client
The administrative API for HBase.
advance() - Method in class org.apache.hadoop.hbase.client.Result
 
AggregationClient - Class in org.apache.hadoop.hbase.client.coprocessor
This client class is for invoking the aggregate functions deployed on the Region Server side via the AggregateService.
AggregationClient(Configuration) - Constructor for class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
Constructor with Conf object
allTableRegions(Configuration, Connection, TableName, boolean) - Static method in class org.apache.hadoop.hbase.client.MetaScanner
allTableRegions(Connection, TableName) - Static method in class org.apache.hadoop.hbase.client.MetaScanner
Lists all of the table regions currently in META.
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
 
ap - Variable in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
 
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(Append) - Method in class org.apache.hadoop.hbase.client.HTable
Appends values to one or more columns within a single row.
append(Append) - Method in interface org.apache.hadoop.hbase.client.Table
Appends values to one or more columns within a single row.
appendPeerTableCFs(String, String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Append the replicable table-cf config of the specified peer
appendPeerTableCFs(String, Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Append the replicable table-cf config of the specified peer
appendTracker - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
areAdjacent(HRegionInfo, HRegionInfo) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Check whether two regions are adjacent
assertSnapshotRequestIsValid(HBaseProtos.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(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
assignmentZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
AsyncCall - Class in org.apache.hadoop.hbase.ipc
Represents an Async Hbase call and its response.
AsyncCall(EventLoop, int, Descriptors.MethodDescriptor, Message, PayloadCarryingRpcController, Message, MetricsConnection.CallStats) - Constructor for class org.apache.hadoop.hbase.ipc.AsyncCall
Constructor
asyncCreate(ZooKeeperWatcher, String, byte[], AsyncCallback.StringCallback, Object) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Async creates the specified node with the specified data.
asyncCreateNodeOffline(ZooKeeperWatcher, HRegionInfo, ServerName, AsyncCallback.StringCallback, Object) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Creates an unassigned node in the OFFLINE state for the specified region.
AsyncRpcChannel - Class in org.apache.hadoop.hbase.ipc
Netty RPC channel
AsyncRpcChannel(Bootstrap, AsyncRpcClient, User, String, InetSocketAddress) - Constructor for class org.apache.hadoop.hbase.ipc.AsyncRpcChannel
Constructor for netty RPC channel
AsyncRpcClient - Class in org.apache.hadoop.hbase.ipc
Netty client for the requests and responses
AsyncRpcClient(Configuration, String, SocketAddress, MetricsConnection, ChannelInitializer<SocketChannel>) - Constructor for class org.apache.hadoop.hbase.ipc.AsyncRpcClient
Constructor for tests
AsyncRpcClient(Configuration, String, SocketAddress, MetricsConnection) - Constructor for class org.apache.hadoop.hbase.ipc.AsyncRpcClient
Constructor
AsyncRpcClient.RpcChannelImplementation - Class in org.apache.hadoop.hbase.ipc
Blocking rpc channel that goes via hbase rpc.
AsyncRpcClient.RpcChannelImplementation(AsyncRpcClient, ServerName, User, int) - Constructor for class org.apache.hadoop.hbase.ipc.AsyncRpcClient.RpcChannelImplementation
 
AsyncServerResponseHandler - Class in org.apache.hadoop.hbase.ipc
Handles Hbase responses
AsyncServerResponseHandler(AsyncRpcChannel) - Constructor for class org.apache.hadoop.hbase.ipc.AsyncServerResponseHandler
Constructor
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
 
avg(TableName, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
This is the client side interface/handle for calling the average method for a given cf-cq combination.
avg(Table, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
This is the client side interface/handle for calling the average method for a given cf-cq combination.

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.ZooKeeperWatcher
 
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
 
balancer() - Method in interface org.apache.hadoop.hbase.client.Admin
Invoke the balancer.
balancer() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Invoke the balancer.
balancerZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
baseZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
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
Method that does a batch call on Deletes, Gets, Puts, Increments and Appends.
batch(List<? extends Row>) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
If any exception is thrown by one of the actions, there is no way to retrieve the partially executed results. Use HTable.batch(List, Object[]) instead.
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 and Appends.
batch(List<? extends Row>) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
If any exception is thrown by one of the actions, there is no way to retrieve the partially executed results. Use Table.batch(List, Object[]) instead.
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.
batchCallback(List<? extends Row>, Object[], Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTable
Same as Table.batch(List, Object[]), but with a callback.
batchCallback(List<? extends Row>, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
If any exception is thrown by one of the actions, there is no way to retrieve the partially executed results. Use HTable.batchCallback(List, Object[], org.apache.hadoop.hbase.client.coprocessor.Batch.Callback) instead.
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.
batchCallback(List<? extends Row>, Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
If any exception is thrown by one of the actions, there is no way to retrieve the partially executed results. Use Table.batchCallback(List, Object[], org.apache.hadoop.hbase.client.coprocessor.Batch.Callback) instead.
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R) - Method in class org.apache.hadoop.hbase.client.HTable
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 class org.apache.hadoop.hbase.client.HTable
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) - 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.
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
 
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.HColumnDescriptor
Key for the BLOCKCACHE attribute.
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
 
BLOCKSIZE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Size of storefile/hfile 'blocks'.
blockUntilAvailable(ZooKeeperWatcher, long, Configuration) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Wait until the primary meta region is available.
blockUntilAvailable(ZooKeeperWatcher, long) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Wait until the meta region is available and is not in transition.
blockUntilAvailable(ZooKeeperWatcher, int, long) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Wait until the meta region is available and is not in transition.
blockUntilAvailable(ZooKeeperWatcher, String, long) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
 
blockUntilAvailable() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
Gets the data of the node, blocking until the node is available.
blockUntilAvailable(long, boolean) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
Gets the data of the node, blocking until the node is available or the specified timeout has elapsed.
blockUntilNoRIT(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Blocks until there are no node in regions in transition.
blockUntilRIT(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Blocks until there is at least one node in regions in transition.
BLOOMFILTER - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
BloomType - Enum in org.apache.hadoop.hbase.regionserver
 
bucketRsBatch(HTable, List<Row>) - Static method in class org.apache.hadoop.hbase.client.HTableUtil
Deprecated.
Processes a List of Rows (Put, Delete) and writes them to an HTable instance in RegionServer buckets via the htable.batch method.
bucketRsPut(HTable, List<Put>) - Static method in class org.apache.hadoop.hbase.client.HTableUtil
Deprecated.
Processes a List of Puts and writes them to an HTable instance in RegionServer buckets via the htable.put method.
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 HTable 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
 
buildActionResult(Throwable) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Wrap a throwable to an action result.
buildActionResult(ClientProtos.Result, ClientProtos.RegionLoadStats) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Wrap a throwable to an action result.
buildAddColumnRequest(TableName, HColumnDescriptor, long, long) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer AddColumnRequest
buildAssignRegionRequest(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer AssignRegionRequest
buildBalanceRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer BalanceRequest
buildBulkLoadHFileRequest(List<Pair<byte[], String>>, byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer bulk load request
buildCatalogScanRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a request for running a catalog scan
buildCellBlock(CellScanner) - Method in class org.apache.hadoop.hbase.ipc.AsyncRpcClient
Build cell block
buildCellBlock(Codec, CompressionCodec, CellScanner) - Method in class org.apache.hadoop.hbase.ipc.IPCUtil
Puts CellScanner Cells into a cell block using passed in codec and/or compressor.
buildCellBlock(Codec, CompressionCodec, CellScanner, BoundedByteBufferPool) - Method in class org.apache.hadoop.hbase.ipc.IPCUtil
Puts CellScanner Cells into a cell block using passed in codec and/or compressor.
buildCloseRegionRequest(ServerName, byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a CloseRegionRequest for a given region name
buildCloseRegionRequest(ServerName, byte[], int, ServerName, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
 
buildCloseRegionRequest(ServerName, String, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a CloseRegionRequest for a given encoded region name
buildCompactRegionRequest(byte[], boolean, byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a CompactRegionRequest for a given region name
buildCondition(byte[], byte[], byte[], ByteArrayComparable, HBaseProtos.CompareType) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer Condition
buildCreateTableRequest(HTableDescriptor, byte[][], long, long) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer CreateTableRequest
buildDeleteColumnRequest(TableName, byte[], long, long) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer DeleteColumnRequest
buildDeleteTableRequest(TableName, long, long) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer DeleteTableRequest
buildDisableTableRequest(TableName, long, long) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer DisableTableRequest
buildDispatchMergingRegionsRequest(byte[], byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
 
buildEnableCatalogJanitorRequest(boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a request for enabling/disabling the catalog janitor
buildEnableCatalogJanitorResponse(boolean) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Creates a response for the catalog scan request
buildEnableTableRequest(TableName, long, long) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer EnableTableRequest
buildException(Throwable) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
 
buildFlushRegionRequest(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer FlushRegionRequest for a given region name
buildFlushRegionRequest(byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer FlushRegionRequest for a given region name
buildGetClusterStatusRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer GetClusterStatusRequest
buildGetLastFlushedSequenceIdRequest(byte[]) - Static method in class org.apache.hadoop.hbase.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.protobuf.ResponseConverter
Creates a response for the last flushed sequence Id request
buildGetOnlineRegionRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer GetOnlineRegionRequest
buildGetOnlineRegionResponse(List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
A utility to build a GetOnlineRegionResponse.
buildGetRegionInfoRequest(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer GetRegionInfoRequest for a given region name
buildGetRegionInfoRequest(byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer GetRegionInfoRequest for a given region name
buildGetRequest(byte[], Get) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer GetRequest for a client Get
buildGetRowOrBeforeRequest(byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a new protocol buffer GetRequest to get a row, all columns in a family.
buildGetSchemaAlterStatusRequest(TableName) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer GetSchemaAlterStatusRequest
buildGetServerInfoRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a new GetServerInfoRequest
buildGetServerInfoResponse(ServerName, int) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
A utility to build a GetServerInfoResponse.
buildGetStoreFileRequest(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer GetStoreFileRequest for a given region name
buildGetTableDescriptorsRequest(List<TableName>) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer GetTableDescriptorsRequest
buildGetTableDescriptorsRequest(Pattern, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer GetTableDescriptorsRequest
buildGetTableDescriptorsRequest(TableName) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer GetTableDescriptorsRequest for a single table
buildGetTableNamesRequest(Pattern, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer GetTableNamesRequest
buildGetUserPermissionsResponse(List<UserPermission>) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Converts the permissions list into a protocol buffer GetUserPermissionsResponse
buildGrantRequest(String, AccessControlProtos.Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a request to grant user permissions.
buildGrantRequest(String, TableName, byte[], byte[], AccessControlProtos.Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a request to grant user permissions.
buildGrantRequest(String, String, AccessControlProtos.Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a request to grant user permissions.
buildIncrementRequest(byte[], byte[], byte[], byte[], long, Durability, long, long) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a client increment
buildIsBalancerEnabledRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer IsBalancerEnabledRequest
buildIsCatalogJanitorEnabledRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a request for querying the master whether the catalog janitor is enabled
buildIsMasterRunningRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer IsMasterRunningRequest
buildIsNormalizerEnabledRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer IsNormalizerEnabledRequest
buildMergeRegionsRequest(byte[], byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a MergeRegionsRequest for the given regions
buildModifyColumnRequest(TableName, HColumnDescriptor, long, long) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer ModifyColumnRequest
buildModifyTableRequest(TableName, HTableDescriptor, long, long) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer ModifyTableRequest
buildMoveRegionRequest(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MoveRegionRequest
buildMutateRequest(byte[], byte[], byte[], byte[], ByteArrayComparable, HBaseProtos.CompareType, Put) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a conditioned put
buildMutateRequest(byte[], byte[], byte[], byte[], ByteArrayComparable, HBaseProtos.CompareType, Delete) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a conditioned delete
buildMutateRequest(byte[], byte[], byte[], byte[], ByteArrayComparable, HBaseProtos.CompareType, RowMutations) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MutateRequest for conditioned row mutations
buildMutateRequest(byte[], Put) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a put
buildMutateRequest(byte[], Append, long, long) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MutateRequest for an append
buildMutateRequest(byte[], Increment, long, long) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a client increment
buildMutateRequest(byte[], Delete) - Static method in class org.apache.hadoop.hbase.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.protobuf.RequestConverter
Create a protocol buffer MultiRequest for row mutations that does not hold data.
buildNoDataRegionAction(byte[], List<Action<R>>, List<CellScannable>, ClientProtos.RegionAction.Builder, ClientProtos.Action.Builder, ClientProtos.MutationProto.Builder) - Static method in class org.apache.hadoop.hbase.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.protobuf.RequestConverter
Creates a protocol buffer NormalizeRequest
buildOfflineRegionRequest(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer OfflineRegionRequest
buildOpenRegionRequest(ServerName, List<Triple<HRegionInfo, Integer, List<ServerName>>>, Boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer OpenRegionRequest to open a list of regions
buildOpenRegionRequest(ServerName, HRegionInfo, int, List<ServerName>, Boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer OpenRegionRequest for a given region
buildRegionAction(byte[], RowMutations) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MultiRequest for row mutations.
buildRegionAction(byte[], List<Action<R>>, ClientProtos.RegionAction.Builder, ClientProtos.Action.Builder, ClientProtos.MutationProto.Builder) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer multi request for a list of actions.
buildRegionSpecifier(HBaseProtos.RegionSpecifier.RegionSpecifierType, byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Convert a byte array to a protocol buffer RegionSpecifier
buildRevokeRequest(String, AccessControlProtos.Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a request to revoke user permissions.
buildRevokeRequest(String, TableName, byte[], byte[], AccessControlProtos.Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a request to revoke user permissions.
buildRevokeRequest(String, String, AccessControlProtos.Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a request to revoke user permissions.
buildRollWALWriterRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a new RollWALWriterRequest
buildRunCatalogScanResponse(int) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Creates a response for the catalog scan request
buildScanRequest(byte[], Scan, int, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer ScanRequest for a client Scan
buildScanRequest(long, int, boolean, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer ScanRequest for a scanner id
buildScanRequest(long, int, boolean, long, boolean, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer ScanRequest for a scanner id
buildSetBalancerRunningRequest(boolean, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer SetBalancerRunningRequest
buildSetNormalizerRunningRequest(boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer SetNormalizerRunningRequest
buildSetQuotaRequestProto(QuotaSettings) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettings
Deprecated.
Removed in HBase 2.0+ as a part of removing protobuf from our API
buildSplitRegionRequest(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a SplitRegionRequest for a given region name
buildStopServerRequest(String) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a new StopServerRequest
buildTruncateTableRequest(TableName, boolean, long, long) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer TruncateTableRequest
buildUnassignRegionRequest(byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer UnassignRegionRequest
buildUpdateFavoredNodesRequest(List<Pair<HRegionInfo, List<ServerName>>>) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer UpdateFavoredNodesRequest to update a list of favorednode mappings
buildWarmupRegionRequest(HRegionInfo) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a WarmupRegionRequest for a given region name
bulkLoadHFile(ClientProtos.ClientService.BlockingInterface, List<Pair<byte[], String>>, byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to bulk load a list of HFiles using client protocol.
bulkLoadHFiles(List<Pair<byte[], String>>, Token<?>, String, byte[]) - Method in class org.apache.hadoop.hbase.client.coprocessor.SecureBulkLoadClient
 
bypassGlobals(String, boolean) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Set the "bypass global settings" for the specified user
ByteArrayComparable - Class in org.apache.hadoop.hbase.filter
Base class for byte array comparators
ByteArrayComparable(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.ByteArrayComparable
Constructor.
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.HColumnDescriptor
 
CACHE_DATA_IN_L1 - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Key for cache data into L1 if cache is set up with more than one tier.
CACHE_DATA_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
CACHE_INDEX_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
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(T) - Method in interface org.apache.hadoop.hbase.client.coprocessor.Batch.Call
 
call(int) - Method in class org.apache.hadoop.hbase.client.DelegatingRetryingCallable
 
call(int) - Method in class org.apache.hadoop.hbase.client.FlushRegionCallable
 
call(int) - Method in interface org.apache.hadoop.hbase.client.RetryingCallable
Computes a result, or throws an exception if unable to do so.
call() - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
Algo: - we put the query into the execution pool.
call(int) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
call(PayloadCarryingRpcController, Descriptors.MethodDescriptor, Message, Message, User, InetSocketAddress, MetricsConnection.CallStats) - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
Make a call, passing param, to the IPC server running at address which is servicing the protocol protocol, with the ticket credentials, returning the value.
call(PayloadCarryingRpcController, Descriptors.MethodDescriptor, Message, Message, User, InetSocketAddress, MetricsConnection.CallStats) - Method in class org.apache.hadoop.hbase.ipc.AsyncRpcClient
Make a call, passing param, to the IPC server running at address which is servicing the protocol protocol, with the ticket credentials, returning the value.
Call - Class in org.apache.hadoop.hbase.ipc
A call waiting for a value.
Call(int, Descriptors.MethodDescriptor, Message, CellScanner, Message, int, MetricsConnection.CallStats) - Constructor for class org.apache.hadoop.hbase.ipc.Call
 
call(PayloadCarryingRpcController, Descriptors.MethodDescriptor, Message, Message, User, InetSocketAddress, MetricsConnection.CallStats) - Method in class org.apache.hadoop.hbase.ipc.RpcClientImpl
Make a call, passing param, to the IPC server running at address which is servicing the protocol protocol, with the ticket credentials, returning the value.
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
 
callBlockingMethod(Descriptors.MethodDescriptor, RpcController, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
 
callComplete() - Method in class org.apache.hadoop.hbase.ipc.Call
Indicate when the call is complete and the value or error are available.
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
 
callExecService(RpcController, Descriptors.MethodDescriptor, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
 
callExecService(RpcController, Descriptors.MethodDescriptor, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.MasterCoprocessorRpcChannel
 
callExecService(RpcController, Descriptors.MethodDescriptor, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.RegionCoprocessorRpcChannel
 
callExecService(RpcController, Descriptors.MethodDescriptor, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.RegionServerCoprocessorRpcChannel
 
callIdCnt - Variable in class org.apache.hadoop.hbase.ipc.AsyncRpcClient
 
callIdCnt - Variable in class org.apache.hadoop.hbase.ipc.RpcClientImpl
 
callMethod(Descriptors.MethodDescriptor, PayloadCarryingRpcController, Message, Message, MetricsConnection.CallStats) - Method in class org.apache.hadoop.hbase.ipc.AsyncRpcChannel
Calls method on channel
callMethod(Descriptors.MethodDescriptor, RpcController, Message, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.ipc.AsyncRpcClient.RpcChannelImplementation
 
callMethod(Descriptors.MethodDescriptor, RpcController, Message, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
 
CallQueueTooBigException - Exception in org.apache.hadoop.hbase
 
CallQueueTooBigException() - Constructor for exception org.apache.hadoop.hbase.CallQueueTooBigException
 
calls - Variable in class org.apache.hadoop.hbase.ipc.RpcClientImpl.Connection
 
callSender - Variable in class org.apache.hadoop.hbase.ipc.RpcClientImpl.Connection
 
callTimeout - Variable in class org.apache.hadoop.hbase.ipc.TimeLimitedRpcController
The time, in ms before the call should expire.
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 class org.apache.hadoop.hbase.client.RpcRetryingCaller
Call the server once only.
callWithoutRetries(RetryingCallable<T>, int) - Method in class org.apache.hadoop.hbase.client.StatsTrackingRpcRetryingCaller
 
callWithRetries(RetryingCallable<T>, int) - Method in class org.apache.hadoop.hbase.client.RpcRetryingCaller
Retries if invocation fails.
callWithRetries(RetryingCallable<T>, int) - Method in class org.apache.hadoop.hbase.client.StatsTrackingRpcRetryingCaller
 
cancel(boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
cancel() - Method in class org.apache.hadoop.hbase.client.RpcRetryingCaller
 
cancelAll() - Method in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService
 
cancelConnections(ServerName) - Method in class org.apache.hadoop.hbase.ipc.AsyncRpcClient
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.
cancelConnections(ServerName) - Method in class org.apache.hadoop.hbase.ipc.RpcClientImpl
Interrupt the connections to the given ip:port server.
cancellationCb - Variable in class org.apache.hadoop.hbase.ipc.TimeLimitedRpcController
 
cancelled - Variable in class org.apache.hadoop.hbase.ipc.TimeLimitedRpcController
 
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.
cConnection - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
 
cConnection - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
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.DelegatingPayloadCarryingRpcController
 
cellScanner() - Method in class org.apache.hadoop.hbase.ipc.PayloadCarryingRpcController
 
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
 
chance - Variable in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.hadoop.hbase.ipc.AsyncServerResponseHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.hadoop.hbase.security.SaslClientHandler
 
channelUnregistered(ChannelHandlerContext) - Method in class org.apache.hadoop.hbase.security.SaslClientHandler
 
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
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndDelete(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Delete) - Method in class org.apache.hadoop.hbase.client.HTable
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndDelete(byte[], byte[], byte[], byte[], Delete) - Method in interface org.apache.hadoop.hbase.client.Table
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndDelete(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Delete) - 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 class org.apache.hadoop.hbase.client.HTable
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
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndPut(byte[], byte[], byte[], byte[], Put) - Method in class org.apache.hadoop.hbase.client.HTable
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndPut(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Put) - Method in class org.apache.hadoop.hbase.client.HTable
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndPut(byte[], byte[], byte[], byte[], Put) - Method in interface org.apache.hadoop.hbase.client.Table
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndPut(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Put) - Method in interface org.apache.hadoop.hbase.client.Table
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndSetTimeout() - Method in class org.apache.hadoop.hbase.ipc.Call
Check if the call did timeout.
checkAndSetZNodeAcls() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
On master start, we check the znode ACLs under the root directory and set the ACLs properly if needed.
checkClosingState(ZooKeeperWatcher, HRegionInfo, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
 
checkExists(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Check if the specified node exists.
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'
checkHBaseAvailable(Configuration) - Static method in class org.apache.hadoop.hbase.client.HBaseAdmin
Check to see if HBase is running.
checkIfBaseNodeAvailable() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
Checks if the baseznode set as per the property 'zookeeper.znode.parent' exists.
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
checkIOException(IOException) - Static method in class org.apache.hadoop.hbase.RemoteExceptionHandler
Examine passed IOException.
checkLockExists(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
checkScanStopRow(byte[]) - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
checkScanStopRow(byte[]) - Method in class org.apache.hadoop.hbase.client.ReversedClientScanner
 
checkState(int) - Method in interface org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture.WaitForStateCallable
 
checkThrowable(Throwable) - Static method in class org.apache.hadoop.hbase.RemoteExceptionHandler
Examine passed Throwable.
checkZk() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
Try to create a Zookeeper connection.
claimQueues(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
Take ownership for the set of queues belonging to a dead region server.
claimQueues(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
classifyExs(List<Throwable>) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
cleanupBulkLoad(String) - Method in class org.apache.hadoop.hbase.client.coprocessor.SecureBulkLoadClient
 
cleanupCalls(boolean) - Method in class org.apache.hadoop.hbase.ipc.RpcClientImpl.Connection
Cleanup the calls older than a given timeout, in milli seconds.
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.
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[], int) - Method in class org.apache.hadoop.hbase.client.MetaCache
Delete a cached location, no matter what it is.
clearCache(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.MetaCache
Delete a cached location, no matter what it is.
clearCache(TableName, byte[], ServerName) - Method in class org.apache.hadoop.hbase.client.MetaCache
Delete a cached location for a table, row and server
clearCache(HRegionInfo) - 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.
clearCaches(ServerName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
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 interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
clearRegionCache(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
clearRegionCache(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
clearRegionCache() - Method in class org.apache.hadoop.hbase.client.HTable
Explicitly clears the region cache to fetch the latest value from META.
CLIENT_MAX_THREADS - Static variable in class org.apache.hadoop.hbase.ipc.AsyncRpcClient
 
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.
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
ClientBackoffPolicyFactory.NoBackoffPolicy(Configuration) - Constructor for class org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicyFactory.NoBackoffPolicy
 
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.
ClientSmallReversedScanner - Class in org.apache.hadoop.hbase.client
Client scanner for small reversed scan.
ClientSmallReversedScanner(Configuration, Scan, TableName, ClusterConnection, RpcRetryingCallerFactory, RpcControllerFactory, ExecutorService, int) - Constructor for class org.apache.hadoop.hbase.client.ClientSmallReversedScanner
Create a new ReversibleClientScanner for the specified table.
ClientSmallReversedScanner.SmallReversedScannerCallableFactory - Class in org.apache.hadoop.hbase.client
 
ClientSmallReversedScanner.SmallReversedScannerCallableFactory() - Constructor for class org.apache.hadoop.hbase.client.ClientSmallReversedScanner.SmallReversedScannerCallableFactory
 
ClientSmallScanner - Class in org.apache.hadoop.hbase.client
Client scanner for small scan.
ClientSmallScanner(Configuration, Scan, TableName, ClusterConnection, RpcRetryingCallerFactory, RpcControllerFactory, ExecutorService, int) - Constructor for class org.apache.hadoop.hbase.client.ClientSmallScanner
Create a new ShortClientScanner for the specified table.
ClientSmallScanner.SmallScannerCallableFactory - Class in org.apache.hadoop.hbase.client
 
ClientSmallScanner.SmallScannerCallableFactory() - Constructor for class org.apache.hadoop.hbase.client.ClientSmallScanner.SmallScannerCallableFactory
 
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
 
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
 
cloneSnapshot(byte[], 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.Admin
Create a new table by cloning the snapshot content.
cloneSnapshot(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Create a new table by cloning the snapshot content.
cloneSnapshot(byte[], TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Create a new table by cloning the snapshot content.
cloneSnapshot(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Create a new table by cloning the snapshot content.
cloneSnapshot(String, TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Create a new table by cloning the snapshot content.
close() - Method in interface org.apache.hadoop.hbase.client.Admin
 
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.ClientScanner
 
close() - Method in class org.apache.hadoop.hbase.client.ClientSmallReversedScanner
 
close() - Method in class org.apache.hadoop.hbase.client.ClientSmallScanner
 
close() - Method in interface org.apache.hadoop.hbase.client.Connection
 
close() - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
 
close() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
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.HTablePool
Deprecated.
Closes all the HTable instances , belonging to all tables in the table pool.
close() - Method in class org.apache.hadoop.hbase.client.MetaScanner.MetaScannerVisitorBase
 
close() - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
 
close() - Method in interface org.apache.hadoop.hbase.client.ResultScanner
Closes the scanner and releases any resources it has allocated
close() - Method in interface org.apache.hadoop.hbase.client.Table
Releases any resources held or pending changes in internal buffers.
close(Throwable) - Method in class org.apache.hadoop.hbase.ipc.AsyncRpcChannel
Close connection
close() - Method in class org.apache.hadoop.hbase.ipc.AsyncRpcClient
Close netty
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.ipc.RpcClientImpl
Stop all threads related to this client.
close() - Method in class org.apache.hadoop.hbase.ipc.RpcClientImpl.Connection
Close the connection.
close() - Method in class org.apache.hadoop.hbase.quotas.QuotaRetriever
 
close() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
 
close() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
close() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Close the connection to ZooKeeper.
closeConnection() - Method in class org.apache.hadoop.hbase.ipc.RpcClientImpl.Connection
 
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
 
closeRegion(String, String) - Method in interface org.apache.hadoop.hbase.client.Admin
Close a region.
closeRegion(byte[], String) - Method in interface org.apache.hadoop.hbase.client.Admin
Close a region.
closeRegion(ServerName, HRegionInfo) - Method in interface org.apache.hadoop.hbase.client.Admin
Close a region.
closeRegion(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Close a region.
closeRegion(byte[], String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Close a region.
closeRegion(ServerName, HRegionInfo) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Close a region.
closeRegion(RpcController, AdminProtos.AdminService.BlockingInterface, ServerName, byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to close a region given a region name using admin protocol.
closeRegion(RpcController, AdminProtos.AdminService.BlockingInterface, ServerName, byte[], int, ServerName, boolean) - Static method in class org.apache.hadoop.hbase.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
For expert-admins.
closeRegionWithEncodedRegionName(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
For expert-admins.
closeTablePool(String) - Method in class org.apache.hadoop.hbase.client.HTablePool
Deprecated.
Closes all the HTable instances , belonging to the given table, in the table pool.
closeTablePool(byte[]) - Method in class org.apache.hadoop.hbase.client.HTablePool
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.ZooKeeperWatcher
 
clusterStateZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
ClusterStatus - Class in org.apache.hadoop.hbase
Status information on the HBase cluster.
ClusterStatus() - Constructor for class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
As of release 0.96 (HBASE-6038). This will be removed in HBase 2.0.0. Used by Writables and Writables are going away.
ClusterStatus(String, String, Map<ServerName, ServerLoad>, Collection<ServerName>, ServerName, Collection<ServerName>, Map<String, RegionState>, String[], Boolean) - Constructor for class org.apache.hadoop.hbase.ClusterStatus
 
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
 
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.
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) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Compact a table.
compact(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
compact(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
compact(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Compact a column family within a table.
compact(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
compact(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
COMPACTION_ENABLED - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Used by HBase Shell interface to access this metadata attribute which denotes if the table is compaction enabled
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 class org.apache.hadoop.hbase.client.HBaseAdmin
Compact an individual region.
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
Compact all regions on the region server
compactRegionServer(ServerName, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Compact all regions on the region server
comparator - Variable in class org.apache.hadoop.hbase.filter.CompareFilter
 
comparator - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
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.
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
Constructor.
CompareFilter.CompareOp - Enum in org.apache.hadoop.hbase.filter
Comparison operators.
compareOp - Variable in class org.apache.hadoop.hbase.filter.CompareFilter
 
compareOp - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
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.
compareTo(Object) - Method in class org.apache.hadoop.hbase.client.Action
 
compareTo(Row) - Method in class org.apache.hadoop.hbase.client.Get
 
compareTo(Row) - Method in class org.apache.hadoop.hbase.client.Increment
 
compareTo(Row) - Method in class org.apache.hadoop.hbase.client.Mutation
 
compareTo(Row) - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
 
compareTo(Row) - Method in class org.apache.hadoop.hbase.client.RowMutations
 
compareTo(byte[], 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(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.BitComparator
 
compareTo(byte[]) - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
 
compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
Special compareTo method for subclasses, to avoid copying byte[] unnecessarily.
compareTo(byte[], 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(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
 
compareTo(HRegionInfo) - Method in class org.apache.hadoop.hbase.HRegionInfo
 
compareTo(HRegionLocation) - Method in class org.apache.hadoop.hbase.HRegionLocation
 
compareTo(HTableDescriptor) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Compares the descriptor with another descriptor which is passed as a parameter.
compareTo(ServerName) - Method in class org.apache.hadoop.hbase.ServerName
 
COMPRESS_TAGS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
COMPRESSION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
COMPRESSION_COMPACT - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
compressor - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
conf - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
conf - Variable in class org.apache.hadoop.hbase.client.HConnectable
 
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
 
conf - Variable in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
 
confirmNodeOpening(ZooKeeperWatcher, HRegionInfo, ServerName, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Confirm an existing unassigned node for the specified region which is currently in the OPENING state to be still in the OPENING state on the specified server.
connect(HConnection) - Method in class org.apache.hadoop.hbase.client.HConnectable
 
connect(Configuration, Watcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Creates a new connection to ZooKeeper, pulling settings and ensemble config from the specified configuration object using methods from ZKConfig.
connect(Configuration, String, Watcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
 
connect(Configuration, String, Watcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
 
connection - Variable in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
 
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.HTable
 
connection - Variable in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
connection - Variable in class org.apache.hadoop.hbase.client.RegionServerCallable
 
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
ConnectionId - Class in org.apache.hadoop.hbase.ipc
This class holds the address and the user ticket, etc.
ConnectionId(User, String, InetSocketAddress) - Constructor for class org.apache.hadoop.hbase.ipc.ConnectionId
 
connections - Variable in class org.apache.hadoop.hbase.ipc.RpcClientImpl
 
ConnectionUtils - Class in org.apache.hadoop.hbase.client
Utility used by client connections.
ConnectionUtils() - Constructor for class org.apache.hadoop.hbase.client.ConnectionUtils
 
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 class org.apache.hadoop.hbase.HRegionInfo
Returns true if the given inclusive range of rows is fully contained by this region.
containsRow(byte[]) - Method in class org.apache.hadoop.hbase.HRegionInfo
Return true if the given row falls in this region.
containsValue(Object) - Method in class org.apache.hadoop.hbase.util.PoolMap
 
controller - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
controllerFactory - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
convert() - Method in class org.apache.hadoop.hbase.ClusterStatus
Convert a ClusterStatus to a protobuf ClusterStatus
convert(ClusterStatusProtos.ClusterStatus) - Static method in class org.apache.hadoop.hbase.ClusterStatus
Convert a protobuf ClusterStatus to a ClusterStatus
convert(HBaseProtos.ColumnFamilySchema) - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
 
convert() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
convert(HRegionInfo) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Convert a HRegionInfo to a RegionInfo
convert(HBaseProtos.RegionInfo) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Convert a RegionInfo to a HRegionInfo
convert() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
convert(HBaseProtos.TableSchema) - Static method in class org.apache.hadoop.hbase.HTableDescriptor
 
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
convert(DeserializationException) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Convert a DeserializationException to a more palatable KeeperException.
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.
CoordinatedStateException - Exception in org.apache.hadoop.hbase
Thrown by operations requiring coordination state access or manipulation when internal error within coordination engine (or other internal implementation) occurs.
CoordinatedStateException() - Constructor for exception org.apache.hadoop.hbase.CoordinatedStateException
 
CoordinatedStateException(String) - Constructor for exception org.apache.hadoop.hbase.CoordinatedStateException
 
CoordinatedStateException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.CoordinatedStateException
 
CoordinatedStateException(Throwable) - Constructor for exception org.apache.hadoop.hbase.CoordinatedStateException
 
Coprocessor - Interface in org.apache.hadoop.hbase
Coprocessor interface.
Coprocessor.State - Enum in org.apache.hadoop.hbase
Lifecycle state of a given coprocessor instance.
CoprocessorEnvironment - 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 - Class in org.apache.hadoop.hbase.ipc
Base class which provides clients with an RPC connection to call coprocessor endpoint Services.
CoprocessorRpcChannel() - Constructor for class org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
 
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() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Creates and returns a RpcChannel instance connected to the active master.
coprocessorService(ServerName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Creates and returns a RpcChannel instance connected to the passed region server.
coprocessorService(byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
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 class org.apache.hadoop.hbase.client.HTable
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 class org.apache.hadoop.hbase.client.HTable
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(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.
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, HBaseProtos.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
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
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(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
 
create(String, byte[], List<ACL>, CreateMode) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
NONSEQUENTIAL create is idempotent operation.
createACL(ZooKeeperWatcher, String, boolean) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
 
createAndAddPeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
Attempt to connect to a new remote slave cluster.
createAndFailSilent(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Creates the specified node, iff the node does not exist.
createAndFailSilent(ZooKeeperWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Creates the specified node containing specified data, iff the node does not exist.
createAndFailSilent(String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
 
createAndWatch(ZooKeeperWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Creates the specified node with the specified data and watches it.
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.
createCellScanner(byte[]) - Method in class org.apache.hadoop.hbase.ipc.AsyncRpcClient
Create a cell scanner
createCellScanner(Codec, CompressionCodec, byte[]) - Method in class org.apache.hadoop.hbase.ipc.IPCUtil
 
createCellScanner(Codec, CompressionCodec, byte[], int, int) - Method in class org.apache.hadoop.hbase.ipc.IPCUtil
 
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
createClosestRowBefore(byte[]) - Static method in class org.apache.hadoop.hbase.client.ClientScanner
Create the closest row before the specified row
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
Takes a compareOperator symbol as a byte array and returns the corresponding CompareOperator
createCompleteResult(List<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(Configuration) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated.
createConnection(Configuration, ExecutorService) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated.
createConnection(Configuration, User) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated.
createConnection(Configuration, ExecutorService, User) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated.
createConnection(ConnectionId, Codec, CompressionCodec) - Method in class org.apache.hadoop.hbase.ipc.RpcClientImpl
Creates a connection.
createCounter(String) - Method in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
Create a new counter with the specified name
createDigestSaslClient(String[], String, CallbackHandler) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
 
createDigestSaslClient(String[], String, CallbackHandler) - Method in class org.apache.hadoop.hbase.security.SaslClientHandler
Create a Digest Sasl client
createEphemeralNodeAndWatch(ZooKeeperWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Set the specified znode to be an ephemeral node carrying the specified data.
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.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
 
createHTable(String) - Method in class org.apache.hadoop.hbase.client.HTablePool
Deprecated.
 
createHTableInterface(Configuration, byte[]) - Method in class org.apache.hadoop.hbase.client.HTableFactory
Deprecated.
 
createHTableInterface(Configuration, byte[]) - Method in interface org.apache.hadoop.hbase.client.HTableInterfaceFactory
Deprecated.
Creates a new HTableInterface.
createKerberosSaslClient(String[], String, String) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
 
createKerberosSaslClient(String[], String, String) - Method in class org.apache.hadoop.hbase.security.SaslClientHandler
Create Kerberos client
createNamespace(NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Create a new namespace
createNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Create a new namespace
createNodeClosing(ZooKeeperWatcher, HRegionInfo, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Creates a new unassigned node in the CLOSING state for the specified region.
createNodeIfNotExistsAndWatch(ZooKeeperWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Creates the specified znode to be a persistent node carrying the specified data.
createNodeIfNotExistsNoWatch(ZooKeeperWatcher, String, byte[], CreateMode) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Creates the specified znode with the specified data but does not watch it.
createNodeOffline(ZooKeeperWatcher, HRegionInfo, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Creates a new unassigned node in the OFFLINE state for the specified region.
createNodeOffline(ZooKeeperWatcher, HRegionInfo, ServerName, EventType) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
 
createOrForceNodeOffline(ZooKeeperWatcher, HRegionInfo, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Creates or force updates an unassigned node to the OFFLINE state for the specified region.
createPool() - Method in class org.apache.hadoop.hbase.util.PoolMap
 
createRegionName(TableName, byte[], long, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Make a region name of passed parameters.
createRegionName(TableName, byte[], String, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Make a region name of passed parameters.
createRegionName(TableName, byte[], long, int, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Make a region name of passed parameters.
createRegionName(TableName, byte[], byte[], boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Make a region name of passed parameters.
createRegionName(TableName, byte[], byte[], int, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Make a region name of passed parameters.
createRegionTransition(EventType, byte[], ServerName) - Static method in class org.apache.hadoop.hbase.RegionTransition
 
createRegionTransition(EventType, byte[], ServerName, byte[]) - Static method in class org.apache.hadoop.hbase.RegionTransition
 
createRpcChannel(ServerName, User, int) - Method in class org.apache.hadoop.hbase.ipc.AsyncRpcClient
Creates a "channel" that can be used by a protobuf service.
createSetData(ZooKeeperWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Set data into node creating node if it doesn't yet exist.
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.
createShortCircuitHConnection(Connection, ServerName, AdminProtos.AdminService.BlockingInterface, ClientProtos.ClientService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
Deprecated.
createTable(HTableDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Creates a new table.
createTable(HTableDescriptor, byte[], byte[], int) - Method in interface org.apache.hadoop.hbase.client.Admin
Creates a new table with the specified number of regions.
createTable(HTableDescriptor, 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(HTableDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Creates a new table.
createTable(HTableDescriptor, byte[], byte[], int) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Creates a new table with the specified number of regions.
createTable(HTableDescriptor, byte[][]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Creates a new table with an initial set of empty regions defined by the specified split keys.
createTableAsync(HTableDescriptor, 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(HTableDescriptor, byte[][]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Creates a new table but does not block and wait for it to come online.
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
createWithParents(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Creates the specified node and all parent nodes required for it to exist.
createWithParents(ZooKeeperWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Creates the specified node and all parent nodes required for it to exist.
CREATOR_ALL_AND_WORLD_READABLE - Static variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
current() - Method in class org.apache.hadoop.hbase.client.Result
 
currentRegion - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
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.HColumnDescriptor
 
decodeRemoteException(RemoteException) - Static method in class org.apache.hadoop.hbase.RemoteExceptionHandler
Deprecated.
Use RemoteException.unwrapRemoteException() instead. In fact we should look into deprecating this whole class - St.Ack 2010929
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.HColumnDescriptor
Default setting for whether to use a block cache or not.
DEFAULT_BLOCKSIZE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default size of blocks in files stored to the filesytem (hfiles).
DEFAULT_BLOOMFILTER - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default setting for whether or not to use bloomfilters.
DEFAULT_CACHE_BLOOMS_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default setting for whether to cache bloom filter blocks on write if block caching is enabled.
DEFAULT_CACHE_DATA_IN_L1 - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default setting for whether to cache data blocks in L1 tier.
DEFAULT_CACHE_DATA_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default setting for whether to cache data blocks on write if block caching is enabled.
DEFAULT_CACHE_INDEX_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default setting for whether to cache index blocks on write if block caching is enabled.
DEFAULT_CODEC_CLASS - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
 
DEFAULT_COMPACTION_ENABLED - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Constant that denotes whether the table is compaction enabled by default
DEFAULT_COMPRESS_TAGS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default compress tags along with any type of DataBlockEncoding.
DEFAULT_COMPRESSION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default compression type.
DEFAULT_DATA_BLOCK_ENCODING - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default data block encoding algorithm.
DEFAULT_DFS_REPLICATION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
DEFAULT_ENCODE_ON_DISK - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default value of the flag that enables data block encoding on disk, as opposed to encoding in cache only.
DEFAULT_EVICT_BLOCKS_ON_CLOSE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default setting for whether to evict cached blocks from the blockcache on close.
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_IN_MEMORY - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default setting for whether to try and serve this column family from memory or not.
DEFAULT_KEEP_DELETED - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default setting for preventing deleted from being collected immediately.
DEFAULT_MAX_BACKOFF - Static variable in class org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
 
DEFAULT_MEMSTORE_FLUSH_SIZE - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Constant that denotes the maximum default size of the memstore after which the contents are flushed to the store files
DEFAULT_MIN_VERSIONS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default is not to keep a minimum of versions.
DEFAULT_NORMALIZATION_ENABLED - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Constant that denotes whether the table is normalized by default.
DEFAULT_PREFETCH_BLOCKS_ON_OPEN - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
DEFAULT_READONLY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Constant that denotes whether the table is READONLY by default and is false
DEFAULT_REGION_MEMSTORE_REPLICATION - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
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.HTableDescriptor
 
DEFAULT_REPLICA_ID - Static variable in class org.apache.hadoop.hbase.HRegionInfo
 
DEFAULT_REPLICATION_SCOPE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default scope.
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.HColumnDescriptor
Default time to live of cell contents.
DEFAULT_VERSIONS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default number of versions of a record to keep.
DEFERRED_LOG_FLUSH - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
DelayingRunner<T> - 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<T>>>) - Constructor for class org.apache.hadoop.hbase.client.DelayingRunner
 
delegate - Variable in class org.apache.hadoop.hbase.client.DelegatingRetryingCallable
 
DelegatingPayloadCarryingRpcController - Class in org.apache.hadoop.hbase.ipc
Simple delegating controller for use with the RpcControllerFactory to help override standard behavior of a PayloadCarryingRpcController.
DelegatingPayloadCarryingRpcController(PayloadCarryingRpcController) - Constructor for class org.apache.hadoop.hbase.ipc.DelegatingPayloadCarryingRpcController
 
DelegatingRetryingCallable<T,D extends RetryingCallable<T>> - Class in org.apache.hadoop.hbase.client
Helper callable for internal use when you just want to override a single method of a RetryingCallable.
DelegatingRetryingCallable(D) - Constructor for class org.apache.hadoop.hbase.client.DelegatingRetryingCallable
 
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(Delete) - Method in class org.apache.hadoop.hbase.client.HTable
Deletes the specified cells/row.
delete(List<Delete>) - Method in class org.apache.hadoop.hbase.client.HTable
Deletes the specified cells/rows in bulk.
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
Deletes the specified cells/rows in bulk.
delete(String, int) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
delete is an idempotent operation.
deleteAllConnections(boolean) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated. 
deleteAllConnections() - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated.
kept for backward compatibility, but the behavior is broken. HBASE-8983
deleteAllNodes(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Deletes all unassigned nodes regardless of their state.
deleteCachedRegionLocation(HRegionLocation) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Deletes cached locations for the specific region.
deleteCachedRegionLocation(HRegionLocation) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
deleteChildrenRecursively(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Delete all the children of the specified node but not the node itself.
deleteChildrenRecursivelyMultiOrSequential(ZooKeeperWatcher, boolean, String...) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Delete all the children of the specified node but not the node itself.
deleteClosedNode(ZooKeeperWatcher, String, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Deletes an existing unassigned node that is in the CLOSED state for the specified region.
deleteClosingNode(ZooKeeperWatcher, HRegionInfo, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Deletes an existing unassigned node that is in the CLOSING state for the specified region.
deleteColumn(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Delete a column from a table.
deleteColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
Deprecated.
Since hbase-1.0.0. Use Delete.addColumn(byte[], byte[])
deleteColumn(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
Deprecated.
deleteColumn(byte[], String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Delete a column from a table.
deleteColumn(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Delete a column from a table.
deleteColumn(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Delete a column from a table.
deleteColumns(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
Deprecated.
Since hbase-1.0.0. Use Delete.addColumns(byte[], byte[])
deleteColumns(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
Deprecated.
deleteConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated. 
deleteFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
Deprecated.
Since 1.0.0. Use Delete.addFamily(byte[])
deleteFamily(byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
Deprecated.
deleteFamilyVersion(byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
Deprecated.
deleteFromMetaTable(Connection, List<Delete>) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Delete the passed deletes from the hbase:meta table.
deleteIfEquals(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
delete the master znode if its content is same as the parameter
deleteMergeQualifiers(Connection, HRegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Deletes merge qualifiers for the specified merged region.
deleteMetaLocation(ZooKeeperWatcher) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Deletes the location of hbase:meta in ZooKeeper.
deleteMetaLocation(ZooKeeperWatcher, int) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
 
deleteNamespace(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Delete an existing namespace.
deleteNamespace(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Delete an existing namespace.
deleteNode(ZooKeeperWatcher, String, EventType, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Deletes an existing unassigned node that is in the specified state for the specified region.
deleteNode(ZooKeeperWatcher, String, EventType, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Deletes an existing unassigned node that is in the specified state for the specified region.
deleteNode(ZooKeeperWatcher, String, EventType, ServerName, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Deletes an existing unassigned node that is in the specified state for the specified region.
deleteNode(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Delete the specified node.
deleteNode(ZooKeeperWatcher, String, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Delete the specified node with the specified version.
deleteNodeFailSilent(ZooKeeperWatcher, HRegionInfo) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Delete the assignment node regardless of its current state.
deleteNodeFailSilent(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Deletes the specified node.
deleteNodeFailSilent(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
 
deleteNodeRecursively(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Delete the specified node and all of it's children.
deleteNodeRecursivelyMultiOrSequential(ZooKeeperWatcher, boolean, String...) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Delete the specified node and its children.
deleteOfflineNode(ZooKeeperWatcher, String, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Deletes an existing unassigned node that is in the OFFLINE state for the specified region.
deleteOpenedNode(ZooKeeperWatcher, String, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Deletes an existing unassigned node that is in the OPENED state for the specified region.
deleteRegion(Connection, HRegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Deletes the specified region from META.
deleteRegions(Connection, List<HRegionInfo>, long) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Deletes the specified regions from META.
deleteRegions(Connection, List<HRegionInfo>) - 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(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Delete an existing snapshot.
deleteSnapshot(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Delete an existing snapshot.
deleteSnapshots(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Delete existing snapshots whose names match the pattern passed.
deleteSnapshots(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
Delete existing snapshots whose names match the pattern passed.
deleteSnapshots(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Delete existing snapshots whose names match the pattern passed.
deleteSnapshots(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Delete existing snapshots whose names match the pattern passed.
deleteStaleConnection(HConnection) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated. 
deleteTable(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Deletes a table.
deleteTable(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
deleteTable(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
deleteTable(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Deletes a table.
deleteTables(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Deletes tables matching the passed in pattern and wait on completion.
deleteTables(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
Delete tables matching the passed in pattern and wait on completion.
deleteTables(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Deletes tables matching the passed in pattern and wait on completion.
deleteTables(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Delete tables matching the passed in pattern and wait on completion.
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
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.
DeserializationException - Exception in org.apache.hadoop.hbase.exceptions
Failed deserialization.
DeserializationException() - Constructor for exception org.apache.hadoop.hbase.exceptions.DeserializationException
 
DeserializationException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.DeserializationException
 
DeserializationException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.DeserializationException
 
DeserializationException(Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.DeserializationException
 
DFS_REPLICATION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
DISABLED_ZNODE_BYTES - Static variable in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
 
disablePeer(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Stop the replication stream to the specified peer.
disablePeer(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
Stop the replication to the specified remote slave cluster.
disablePeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
disableTable(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Disable table and wait on completion.
disableTable(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Disable table and wait on completion.
disableTable(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
disableTable(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
disableTableAsync(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Starts the disable of a table.
disableTableAsync(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Starts the disable of a table.
disableTableAsync(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
disableTableAsync(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
disableTableRep(TableName) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Disable a table's replication switch.
disableTables(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Disable tables matching the passed in pattern and wait on completion.
disableTables(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
Disable tables matching the passed in pattern and wait on completion.
disableTables(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Disable tables matching the passed in pattern and wait on completion.
disableTables(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Disable tables matching the passed in pattern and wait on completion.
dispose() - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
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.
doCompare(CompareFilter.CompareOp, ByteArrayComparable, byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
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.
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
 
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.ZooKeeperWatcher
 
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
dump(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
 
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.HTableDescriptor
INTERNAL Durability setting for the table.

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_SERVER_LIST - Static variable in class org.apache.hadoop.hbase.ServerName
 
EMPTY_SERVERLOAD - Static variable in class org.apache.hadoop.hbase.ServerLoad
 
EmptyWatcher - Class in org.apache.hadoop.hbase.zookeeper
An empty ZooKeeper watcher
enableCatalogJanitor(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Enable/Disable the catalog janitor
enableCatalogJanitor(boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Enable/Disable the catalog janitor
ENABLED_ZNODE_BYTES - Static variable in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
 
enablePeer(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Restart the replication stream to the specified peer.
enablePeer(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
Restart the replication to the specified remote slave cluster.
enablePeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
enableTable(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Enable a table.
enableTable(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Enable a table.
enableTable(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
enableTable(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
enableTableAsync(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Brings a table on-line (enables it).
enableTableAsync(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Brings a table on-line (enables it).
enableTableAsync(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
enableTableAsync(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
enableTableRep(TableName) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Enable a table's replication switch.
enableTables(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Enable tables matching the passed in pattern and wait on completion.
enableTables(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
Enable tables matching the passed in pattern and wait on completion.
enableTables(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Enable tables matching the passed in pattern and wait on completion.
enableTables(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Enable tables matching the passed in pattern and wait on completion.
ENCODE_ON_DISK - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
ENCODED_REGION_NAME_REGEX - Static variable in class org.apache.hadoop.hbase.HRegionInfo
A non-capture group so that this can be embedded.
encodeRegionName(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
 
ENCRYPTION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
ENCRYPTION_KEY - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
EncryptionUtil - Class in org.apache.hadoop.hbase.security
Some static utility methods for encryption uses in hbase-client.
EncryptionUtil() - Constructor for class org.apache.hadoop.hbase.security.EncryptionUtil
 
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.Get
 
equals(Object) - Method in class org.apache.hadoop.hbase.client.Increment
 
equals(Object) - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
 
equals(Object) - Method in class org.apache.hadoop.hbase.client.RowMutations
 
equals(Object) - Method in class org.apache.hadoop.hbase.ClusterStatus
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.NullComparator
 
equals(Object) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
equals(Object) - Method in class org.apache.hadoop.hbase.HRegionInfo
 
equals(Object) - Method in class org.apache.hadoop.hbase.HRegionLocation
 
equals(Object) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Compare the contents of the descriptor with another one passed as a parameter.
equals(Object) - Method in class org.apache.hadoop.hbase.ipc.AsyncRpcChannel
 
equals(Object) - Method in class org.apache.hadoop.hbase.ipc.ConnectionId
 
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.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.ServerName
 
equals(Object) - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.CreateAndFailSilent
 
equals(Object) - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.DeleteNodeFailSilent
 
equals(Object) - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.SetData
 
errorText() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
 
errorText() - Method in class org.apache.hadoop.hbase.ipc.TimeLimitedRpcController
 
EventType - Enum in org.apache.hadoop.hbase.executor
List of all HBase event handler types.
EVICT_BLOCKS_ON_CLOSE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.hadoop.hbase.security.SaslClientHandler
 
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.
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 class org.apache.hadoop.hbase.client.HBaseAdmin
Execute a distributed procedure on a cluster.
execProcedureWithRet(String, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.client.Admin
Execute a distributed procedure on a cluster.
execProcedureWithRet(String, String, Map<String, String>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Execute a distributed procedure on a cluster synchronously with return data
execRegionServerService(RpcController, ClientProtos.ClientService.BlockingInterface, ClientProtos.CoprocessorServiceCall) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Make a region server endpoint call
execService(RpcController, ClientProtos.ClientService.BlockingInterface, ClientProtos.CoprocessorServiceCall, byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
execService(RpcController, MasterProtos.MasterService.BlockingInterface, ClientProtos.CoprocessorServiceCall) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
execute(HConnectable<T>) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated.
Internal method, do not use thru HConnectionManager.
ExecutorType - Enum in org.apache.hadoop.hbase.executor
The following is a list of all executor types, both those that run in the master and those that run in the regionserver.
exists(Get) - Method in class org.apache.hadoop.hbase.client.HTable
Test for the existence of columns in the table, as specified by the Get.
exists(List<Get>) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
exists(List<Get>) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Deprecated.
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(String, Watcher) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
exists is an idempotent operation.
exists(String, boolean) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
exists is an idempotent operation.
existsAll(List<Get>) - Method in class org.apache.hadoop.hbase.client.HTable
Test for the existence of columns in the table, as specified by the Gets.
existsAll(List<Get>) - Method in interface org.apache.hadoop.hbase.client.Table
Test for the existence of columns in the table, as specified by the Gets.
expectPBMagicPrefix(byte[]) - Static method in class org.apache.hadoop.hbase.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
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.ipc.ServerRpcController
 
failed() - Method in class org.apache.hadoop.hbase.ipc.TimeLimitedRpcController
For use in async rpc clients
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 - 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
 
failedServers - Variable in class org.apache.hadoop.hbase.ipc.RpcClientImpl
 
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
 
failureCb - Variable in class org.apache.hadoop.hbase.ipc.TimeLimitedRpcController
 
failureSleep - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
fallbackAllowed - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
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
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.FilterWrapper
 
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
 
filterColumn(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
filterColumn(byte[], int, int) - 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
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.FamilyFilter
 
filterKeyValue(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.
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.QualifierFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.RowFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.ValueFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
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(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, List<Filter>) - Constructor for class org.apache.hadoop.hbase.filter.FilterList
Constructor that takes a set of Filters and an operator.
FilterList(FilterList.Operator, Filter...) - Constructor for class org.apache.hadoop.hbase.filter.FilterList
Constructor that takes a var arg number of Filters and an operator.
FilterList.Operator - Enum in org.apache.hadoop.hbase.filter
set operator
filterOutRow - Variable in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.Filter
Last chance to veto row based on previous Filter.filterKeyValue(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.filterKeyValue(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.FilterWrapper
 
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.FilterWrapper
 
filterRowCells(List<Cell>) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
 
filterRowCellsWithRet(List<Cell>) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
 
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
Filters a row based on the row key.
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.FilterBase
Filters that do not filter by row key can inherit this implementation that never filters anything.
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
 
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.RowFilter
 
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
FilterWrapper - Class in org.apache.hadoop.hbase.filter
This is a Filter wrapper class which is used in the server side.
FilterWrapper(Filter) - Constructor for class org.apache.hadoop.hbase.filter.FilterWrapper
 
FilterWrapper.FilterRowRetCode - Enum in org.apache.hadoop.hbase.filter
 
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 / ThrottlingException
FIRST_META_REGIONINFO - Static variable in class org.apache.hadoop.hbase.HRegionInfo
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
The filter looks for the given columns in KeyValue.
FirstKeyValueMatchingQualifiersFilter(Set<byte[]>) - Constructor for class org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
Constructor which takes a set of columns.
flush(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Flush a table.
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 a table.
flush(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
flush(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
FLUSH_POLICY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
flushCommits() - Method in class org.apache.hadoop.hbase.client.HTable
Executes all the buffered Put operations.
flushCommits() - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Deprecated.
as of 1.0.0. Replaced by BufferedMutator.flush()
flushRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Flush an individual region.
flushRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Flush an individual region.
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, HRegionInfo, boolean) - Constructor for class org.apache.hadoop.hbase.client.FlushRegionCallable
 
FOREVER - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
formatTime(long) - Static method in exception org.apache.hadoop.hbase.quotas.ThrottlingException
 
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.
fullScan(Connection, MetaTableAccessor.Visitor) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Performs a full scan of hbase:meta.
fullScan(Connection) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Performs a full scan of hbase:meta.
fullScan(Connection, MetaTableAccessor.Visitor, byte[]) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Performs a full scan of a catalog table.
fullScanMetaAndPrint(Connection) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
 
fullScanOfMeta(Connection) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Performs a full scan of a hbase:meta table.
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 - 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() - 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
Extracts certain cells from a given row.
get(List<Get>) - Method in class org.apache.hadoop.hbase.client.HTable
Extracts certain cells from the given rows, in batch.
get(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
Returns a list of all KeyValue objects with matching column family and qualifier.
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 certain cells from the given rows, in batch.
get(int) - Static method in enum org.apache.hadoop.hbase.executor.EventType
 
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(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
 
getACL() - Method in class org.apache.hadoop.hbase.client.Mutation
 
getACL() - Method in class org.apache.hadoop.hbase.client.Query
 
getAcl(String, Stat) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
getAcl is an idempotent operation.
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
 
getAddress() - Method in class org.apache.hadoop.hbase.ipc.ConnectionId
 
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() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
getAdmin() - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Retrieve an Admin implementation to administer an HBase cluster.
getAdmin(ServerName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
getAdmin(ServerName, boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
You can pass master flag but nothing special is done.
getAgeOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSink
 
getAgeOfLastShippedOp() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
 
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
 
getAllPeerConfigs() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
List the cluster replication configs of all remote slave clusters (whether they are enabled/disabled or connected/disconnected).
getAllPeerConfigs() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
getAllPeerIds() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
List the peer ids of all remote slave clusters (whether they are enabled/disabled or connected/disconnected).
getAllPeerIds() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
List all registered peer clusters and set a watch on their znodes.
getAllQueues() - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
Get a list of all queues for this region server.
getAllQueues(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueuesClient
Get a list of all queues for the specified region server.
getAllQueues(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesClientZKImpl
 
getAllQueues() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
getAllRegionLocations() - Method in class org.apache.hadoop.hbase.client.HRegionLocator
 
getAllRegionLocations() - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
getAllRegionLocations() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
Retrieves all of the regions associated with this table.
getAlterStatus(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Get the status of alter command - indicates how many regions have received the updated schema Asynchronous operation.
getAlterStatus(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Get the status of alter command - indicates how many regions have received the updated schema Asynchronous operation.
getAlterStatus(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Get the status of alter command - indicates how many regions have received the updated schema Asynchronous operation.
getAlterStatus(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Get the status of alter command - indicates how many regions have received the updated schema Asynchronous operation.
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 class org.apache.hadoop.hbase.ClusterStatus
 
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
 
getBackupMasterInfoPort(ServerName) - Method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
Get the info port of the backup master if it is available.
getBackupMasters() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getBackupMastersSize() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getBalancerOn() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getBaseStagingDir(Configuration) - Static method in class org.apache.hadoop.hbase.security.SecureBulkLoadUtil
 
getBaseZNode() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
getBatch() - Method in class org.apache.hadoop.hbase.client.Scan
 
getBlocksize() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getBloomFilterType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getBufferedCounterForEachRegionServer() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
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.
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.
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
getCallable(ClusterConnection, TableName, Scan, ScanMetrics, byte[], int, RpcControllerFactory, ExecutorService, int, int, int, Configuration, RpcRetryingCaller<Result[]>, boolean) - Method in class org.apache.hadoop.hbase.client.ClientSmallReversedScanner.SmallReversedScannerCallableFactory
 
getCallable(ClusterConnection, TableName, Scan, ScanMetrics, byte[], int, RpcControllerFactory, ExecutorService, int, int, int, Configuration, RpcRetryingCaller<Result[]>) - Method in class org.apache.hadoop.hbase.client.ClientSmallScanner.SmallScannerCallableFactory
 
getCallTimeMs() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
getCallTimeout() - Method in class org.apache.hadoop.hbase.ipc.TimeLimitedRpcController
 
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
 
getChildDataAndWatchForNewChildren(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Deprecated.
Unused
getChildren(String, Watcher) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
getChildren is an idempotent operation.
getChildren(String, boolean) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
getChildren is an idempotent operation.
getClassLoader() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
 
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 interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
getClusterId() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getClusterIds() - Method in class org.apache.hadoop.hbase.client.Mutation
 
getClusterKey() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
getClusterStatus() - Method in interface org.apache.hadoop.hbase.client.Admin
 
getClusterStatus() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getCode() - Method in enum org.apache.hadoop.hbase.executor.EventType
 
getColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
Deprecated.
getColumnCells(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
Return the Cells for the specific column.
getColumnFamilies() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Returns an array all the HColumnDescriptor of the column families of the table.
getColumnFamilyTimeRange() - Method in class org.apache.hadoop.hbase.client.Query
 
getColumnLatest(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
getColumnLatest(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
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
 
getCompactionCompression() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getCompactionCompressionType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getCompactionPressure() - Method in class org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
 
getCompactionState(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Get the current compaction state of a table.
getCompactionState(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Get the current compaction state of a table.
getCompactionState(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
getCompactionState(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
getCompactionStateForRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Get the current compaction state of region.
getCompactionStateForRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Get the current compaction state of region.
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
 
getCompleteSequenceId() - Method in class org.apache.hadoop.hbase.RegionLoad
This does not really belong inside RegionLoad but its being done in the name of expediency.
getCompression() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getCompressionType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
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.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.Connection
 
getConfiguration() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getConfiguration() - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
 
getConfiguration() - Method in class org.apache.hadoop.hbase.client.HRegionLocator
 
getConfiguration() - Method in class org.apache.hadoop.hbase.client.HTable
Returns the Configuration object used by this instance.
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
Getter for fetching an unmodifiable HColumnDescriptor.configuration map.
getConfiguration() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Getter for fetching an unmodifiable HTableDescriptor.configuration map.
getConfiguration() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
Get the configuration object required to communicate with this peer
getConfiguration() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
getConfiguration() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
Get the configuration object required to communicate with this peer
getConfiguration() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
getConfigurationValue(String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Getter for accessing the configuration value by key.
getConfigurationValue(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Getter for accessing the configuration value by key
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(Configuration) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated.
getConnection() - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
This method will be changed from public to package protected.
getConnection() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
getConnection(User, Call, InetSocketAddress) - Method in class org.apache.hadoop.hbase.ipc.RpcClientImpl
Get a connection from the pool, or create a new one and add it to the pool.
getConnectionConfiguration() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
 
getConnectionHashCode() - Method in class org.apache.hadoop.hbase.ipc.AsyncRpcChannel
 
getConnectionMetrics() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
 
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.protobuf.ResponseConverter
Retreivies exception stored during RPC invocation.
getCoprocessors() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Return the list of attached co-processor represented by their name className
getCounter(String) - Method in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
 
getCreateTime() - Method in class org.apache.hadoop.hbase.RegionTransition
 
getCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getCurrentNrHRS() - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
This method will be changed from public to package protected.
getCurrentPoolSize(String) - Method in class org.apache.hadoop.hbase.client.HTablePool
Deprecated.
 
getData(String, Watcher, Stat) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
getData is an idempotent operation.
getData(String, boolean, Stat) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
getData is an idemnpotent operation.
getData(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Gets the current data in the unassigned node for the specified region name or fully-qualified path.
getData(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Get znode data.
getData() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData
Deprecated.
 
getData() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.CreateAndFailSilent
 
getData() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.SetData
 
getData(boolean) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
Gets the data of the node.
getDataAndWatch(ZooKeeperWatcher, String, Stat) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Gets the current data in the unassigned node for the specified region name or fully-qualified path.
getDataAndWatch(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Get the data at the specified znode and set a watch.
getDataAndWatch(ZooKeeperWatcher, String, Stat) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Get the data at the specified znode and set a watch.
getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getDataBlockEncodingOnDisk() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 0.98 (HBASE-9870). This will be removed in HBase 2.0.0. See HColumnDescriptor.getDataBlockEncoding()}
getDataLocality() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getDataNoWatch(ZooKeeperWatcher, String, Stat) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Gets the current data in the unassigned node for the specified region name or fully-qualified path.
getDataNoWatch(ZooKeeperWatcher, String, Stat) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Get the data at the specified znode without setting a watch.
getDaughterRegions(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
use MetaTableAccessor methods for interacting with meta layouts
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.
getDeadRegionServers() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueueInfo
 
getDeadServerNames() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getDeadServers() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
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.HColumnDescriptor
 
getDelimitedMessageAsByteBuffer(Message) - Static method in class org.apache.hadoop.hbase.ipc.IPCUtil
 
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
 
getDFSReplication() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getDisabledOrDisablingTables(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateClientSideReader
Gets a list of all the tables set as disabled in zookeeper.
getDisabledTables(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateClientSideReader
Gets a list of all the tables set as disabled in zookeeper.
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 class org.apache.hadoop.hbase.HTableDescriptor
Returns the durability setting for the table.
getEnablingTables(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateClientSideReader
Gets a list of all the tables set as enabling in zookeeper.
getEncodedName() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getEncodedNameAsBytes() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getEncryptionKey() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Return the raw crypto key attribute for the family, or null if not set
getEncryptionType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Return the encryption algorithm in use by this family
getEndKey() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
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 class org.apache.hadoop.hbase.client.HTable
Deprecated.
Since 1.1.0. Use RegionLocator.getEndKeys() instead;
getEndKeys() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
Gets the ending row key for every region in the currently open table.
getEventType() - Method in class org.apache.hadoop.hbase.RegionTransition
 
getException(byte[]) - Method in class org.apache.hadoop.hbase.client.MultiResponse
 
getExceptionMessage() - Method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
getExceptionMessageAdditionalDetail() - Method in class org.apache.hadoop.hbase.client.DelegatingRetryingCallable
 
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.client.MultiResponse
 
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
 
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.
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
Returns an unmodifiable collection of all the HColumnDescriptor of all the column families of the table.
getFamiliesKeys() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Returns all the column family names of the current table.
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
Returns the HColumnDescriptor for a specific column family with name as specified by the parameter column.
getFamily() - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Returns the column family used for meta columns.
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() - Method in class org.apache.hadoop.hbase.client.Mutation
Deprecated.
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
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.
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 class org.apache.hadoop.hbase.HTableDescriptor
This gets the class associated with the flush policy which determines the stores need to be flushed when flushing a region.
getHBaseVersion() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getHBaseVersion() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
 
getHeapOccupancyPercent() - Method in class org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
 
getHostAndPort() - Method in class org.apache.hadoop.hbase.ServerName
 
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
 
getHostname() - Method in class org.apache.hadoop.hbase.ServerName
 
getHostnamePort(int) - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
getHostnamePort() - Method in class org.apache.hadoop.hbase.HRegionLocation
 
getHRegionInfo(Result) - Static method in class org.apache.hadoop.hbase.client.MetaScanner
getHRegionInfo() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
 
getHRegionInfo() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
getHRegionInfo(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
use MetaTableAccessor methods for interacting with meta layouts
getHRegionInfo(Result, byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
use MetaTableAccessor methods for interacting with meta layouts
getHRegionInfo(Result) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Returns HRegionInfo object from the column HConstants.CATALOG_FAMILY:HConstants.REGIONINFO_QUALIFIER of the catalog table Result.
getHRegionInfoAndServerName(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
use MetaTableAccessor methods for interacting with meta layouts
getHTableDescriptor(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
getHTableDescriptor(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
getHTableDescriptorArray(MasterProtos.GetTableDescriptorsResponse) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Get HTableDescriptor[] from GetTableDescriptorsResponse protobuf
getHTableDescriptors(List<String>) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
getHTableDescriptorsByTableName(List<TableName>) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
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.
getId() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
Get the identifier of this peer
getId() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
Get the identifier of this peer
getId() - Method in class org.apache.hadoop.hbase.zookeeper.ZKClusterId
 
getIdentifier() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
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
 
getInputStream(InputStream) - 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
 
getKeepAliveMasterService() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Deprecated.
getKeepAliveMasterService() - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Since 0.96.0
getKeepDeletedCells() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
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 class org.apache.hadoop.hbase.client.HBaseAdmin
 
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 class org.apache.hadoop.hbase.client.HBaseAdmin
 
getLastMajorCompactionTs() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getLastMajorCompactionTsForRegion(byte[]) - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getLastMajorCompactionTsForTable(TableName) - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getLastRegion() - Method in class org.apache.hadoop.hbase.ipc.RegionCoprocessorRpcChannel
 
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.filter.ColumnCountGetFilter
 
getLimit() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
getListener() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
 
getListeners() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Get a copy of current registered listeners
getListOfRegionServers() - Method in interface org.apache.hadoop.hbase.replication.ReplicationTracker
Returns a list of other live region servers in the cluster.
getListOfRegionServers() - Method in class org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl
Return a snapshot of the current region servers.
getListOfReplicators() - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
Get a list of all region servers that have outstanding replication queues.
getListOfReplicators() - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueuesClient
Get a list of all region servers that have outstanding replication queues.
getListOfReplicators() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesClientZKImpl
 
getListOfReplicators() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
getListOfReplicatorsZK() - Method in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
Subclasses that use ZK explicitly can just call this directly while classes that are trying to hide internal details of storage can wrap the KeeperException into a ReplicationException or something else.
getLoad(ServerName) - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getLoad() - Method in class org.apache.hadoop.hbase.ServerLoad
Originally, this method factored in the effect of requests going to the server as well.
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
 
getLockZNode(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
getLogPosition(String, String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
Get the current position for a specific WAL in a given queue.
getLogPosition(String, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
getLogsInQueue(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
Get a list of all WALs in the given queue.
getLogsInQueue(String, String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueuesClient
Get a list of all WALs in the given queue on the given region server.
getLogsInQueue(String, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesClientZKImpl
 
getLogsInQueue(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
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.ClusterConnection
Returns a MasterKeepAliveConnection to the active master
getMaster() - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
getMaster() - Method in class org.apache.hadoop.hbase.ClusterStatus
Returns detailed information about the current master ServerName.
getMasterAddress() - Method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
Get the address of the current master if one is available.
getMasterAddress(boolean) - Method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
Get the address of the current master if one is available.
getMasterAddress(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
Get master address.
getMasterAddressZNode() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
getMasterCoprocessors() - Method in interface org.apache.hadoop.hbase.client.Admin
Helper delegage to getClusterStatus().getMasterCoprocessors().
getMasterCoprocessors() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getMasterCoprocessors() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
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 class org.apache.hadoop.hbase.client.HBaseAdmin
 
getMasterInfoPort() - Method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
Get the info port of the current master of one is available.
getMasterInfoPort(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
Get master info port.
getMaxColumn() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
getMaxColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
getMaxFileSize() - Method in class org.apache.hadoop.hbase.HTableDescriptor
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
 
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
 
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 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
 
getMechanismName() - Method in enum org.apache.hadoop.hbase.security.AuthMethod
Return the SASL mechanism name
getMemStoreFlushSize() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Returns the size of the memstore after which a flush to filesystem is triggered.
getMemstoreLoadPercent() - Method in class org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
 
getMemstoreSizeInMB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getMemStoreSizeMB() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getMergeRegions(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
use MetaTableAccessor methods for interacting with meta layouts
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
 
getMetaKeyForRegion(HRegionInfo) - 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
 
getMetaRegionLocation(ZooKeeperWatcher) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Gets the meta region location, if available.
getMetaRegionLocation(ZooKeeperWatcher, int) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Gets the meta region location, if available.
getMetaRegions(ZooKeeperWatcher) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
 
getMetaRegions(ZooKeeperWatcher, int) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
 
getMetaRegionsAndLocations(ZooKeeperWatcher) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
 
getMetaRegionsAndLocations(ZooKeeperWatcher, int) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
 
getMetaRegionState(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Load the meta region state from the meta server ZNode.
getMetaRegionState(ZooKeeperWatcher, int) - Static method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Load the meta region state from the meta server ZNode.
getMetaReplicaIdFromZnode(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Parse the meta replicaId from the passed znode
getMetaReplicaNodes() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Get the znodes corresponding to the meta replicas from ZK
getMethod() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
 
getMetricsMap() - Method in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
Get all of the values since the last time this function was called.
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 class org.apache.hadoop.hbase.HColumnDescriptor
 
getMutations() - Method in class org.apache.hadoop.hbase.client.RowMutations
 
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 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 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
 
getName() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
getName() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getNameAsString() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getNameAsString() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Get the name of the table as a String
getNameAsString() - Method in class org.apache.hadoop.hbase.RegionLoad
 
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 class org.apache.hadoop.hbase.client.HBaseAdmin
Get a namespace descriptor by name
getNamespaceFilter() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
 
getNamespaceFromRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
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
 
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.FilterWrapper
 
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
 
getNextKeyHint(KeyValue) - Method in class org.apache.hadoop.hbase.filter.Filter
Deprecated.
getNextKeyHint(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterBase
Deprecated.
getNextKeyHint(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterList
Deprecated.
getNextKeyHint(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
Deprecated.
getNode() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData
Deprecated.
 
getNode() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
 
getNodeName(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Gets the full path node name for the unassigned node for the specified region.
getNodeName(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Get the name of the current node from the specified fully-qualified path.
getNonce() - Method in class org.apache.hadoop.hbase.client.Action
 
getNonceGenerator() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
 
getNonceGenerator() - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
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
 
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.
getNumberOfChildren(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Get the number of children of the specified node.
getNumberOfListeners() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
getNumberOfRegions() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getNumberOfRequests() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getNumExceptions() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
getOffset() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
getOnlineRegions(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
Get all the online regions on a region server.
getOnlineRegions(ServerName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Get all the online regions on a region server.
getOnlineRegions(AdminProtos.AdminService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.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.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.ConnectionConfiguration
 
getOperationTimeout() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getOperationTimeout() - Method in class org.apache.hadoop.hbase.client.HTable
 
getOperator() - Method in class org.apache.hadoop.hbase.filter.BitComparator
 
getOperator() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
getOperator() - Method in class org.apache.hadoop.hbase.filter.FilterList
Get the operator.
getOperator() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
getOriginalIndex() - Method in class org.apache.hadoop.hbase.client.Action
 
getOutputStream(OutputStream) - 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
 
getOwnerString() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
getPageSize() - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
getParent(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Returns the full path of the immediate parent of the specified node.
getParsedGenericInstance(Class<?>, int, ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Get an instance of the argument type declared in a class's signature.
getPath(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
 
getPath() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
 
getPauseTime(long, int) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
Calculate pause time.
getPayload() - Method in class org.apache.hadoop.hbase.RegionTransition
 
getPeer(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
Returns the ReplicationPeer
getPeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
getPeerClusterZnode() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueueInfo
 
getPeerConf(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
Returns the configuration needed to talk to the remote slave cluster.
getPeerConf(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
getPeerConfig(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
 
getPeerConfig() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
Get the peer config object
getPeerConfig() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
Get the peer config object
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.ReplicationQueueInfo
 
getPeerIds() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
Returns the set of peerIds defined
getPeerIds() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
getPeersCount() - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Get the number of slave clusters the local cluster has.
getPeerState(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Get the state of the specified peer cluster
getPeerState() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
Returns the state of the peer
getPeerState() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
 
getPeerTableCFs(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Get the replicable table-cf config of the specified peer.
getPeerTableCFsConfig(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
Get the table and column-family list string of the peer from ZK.
getPeerTableCFsConfig(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
getPool() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
 
getPool() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
getPoolSize(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
Return the pool size specified in the configuration, which is applicable only if the pool type is PoolMap.PoolType.RoundRobin.
getPoolType(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
Return the pool type specified in the configuration, which must be set to either PoolMap.PoolType.RoundRobin or PoolMap.PoolType.ThreadLocal, otherwise default to the former.
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
 
getPort() - Method in class org.apache.hadoop.hbase.ServerName
 
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 interface org.apache.hadoop.hbase.CoprocessorEnvironment
 
getPriority() - Method in class org.apache.hadoop.hbase.ipc.DelegatingPayloadCarryingRpcController
 
getPriority() - Method in class org.apache.hadoop.hbase.ipc.PayloadCarryingRpcController
 
getProcedureResult(MasterProtos.GetProcedureResultRequest) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
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
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
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.DependentColumnFilter
 
getQualifier() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
getQualifier() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
getQueuesZNodeCversion() - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueuesClient
Get the cversion of replication rs node.
getQueuesZNodeCversion() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesClientZKImpl
 
getQuorum() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Get the quorum address of this instance.
getQuotaRetriever(QuotaFilter) - Method in interface org.apache.hadoop.hbase.client.Admin
Return a QuotaRetriever to list the quotas based on the filter.
getQuotaRetriever(QuotaFilter) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Return a Quota Scanner to list the quotas based on the filter.
getQuotaType() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
 
getReadRequestsCount() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getReadRequestsCount() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getRecoverableZooKeeper() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Get the connection to ZooKeeper.
getRegion() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
 
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.protobuf.RequestConverter
 
getRegionCachePrefetch(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
always return false since 0.99
getRegionCachePrefetch(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
always return false since 0.99
getRegionCachePrefetch(Configuration, byte[]) - Static method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
always return false since 0.99
getRegionCachePrefetch(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
always return false since 0.99
getRegionCachePrefetch(byte[]) - Static method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
always return false since 0.99
getRegionCachePrefetch(TableName) - Static method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
always return false since 0.99
getRegionCount(Configuration, String) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Deprecated.
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.protobuf.ProtobufUtil
Find the HRegion encoded name based on a region specifier
getRegionId() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getRegionInfo() - Method in class org.apache.hadoop.hbase.HRegionLocation
 
getRegionInfo(RpcController, AdminProtos.AdminService.BlockingInterface, byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to retrieve region info given a region name using admin protocol.
getRegionInfoColumn() - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Returns the column qualifier for serialized region info
getRegionInfoForDefaultReplica(HRegionInfo) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
Returns the HRegionInfo for the default replicaId (0).
getRegionInfoForReplica(HRegionInfo, int) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
Returns the HRegionInfo for the given replicaId.
getRegionInfos(AdminProtos.GetOnlineRegionResponse) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Get the list of region info from a GetOnlineRegionResponse
getRegionLocation(TableName, byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Find region location hosting passed row
getRegionLocation(TableName, byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
getRegionLocation(byte[], byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
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(String) - Method in class org.apache.hadoop.hbase.client.HTable
getRegionLocation(byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
getRegionLocation(byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HTable
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, HRegionInfo) - 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() - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
This is no longer a public API. Use HTable.getAllRegionLocations() instead.
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
 
getRegionLocator(TableName) - Method in interface org.apache.hadoop.hbase.client.Connection
Retrieve a RegionLocator implementation to inspect region information on a table.
getRegionLocator(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Retrieve a RegionLocator implementation to inspect region information on a table.
getRegionLocator() - Method in class org.apache.hadoop.hbase.client.HTable
 
getRegionName() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getRegionName() - Method in class org.apache.hadoop.hbase.RegionTransition
 
getRegionName(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Gets the region name from the full path node name of an unassigned node.
getRegionNameAsString() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getRegionNormalizerZNode() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
getRegionOpeningState(AdminProtos.OpenRegionResponse) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Get the region opening state from a OpenRegionResponse
getRegionOpeningStateList(AdminProtos.OpenRegionResponse) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Get a list of region opening state from a OpenRegionResponse
getRegionReplication() - Method in class org.apache.hadoop.hbase.HTableDescriptor
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() - Method in class org.apache.hadoop.hbase.client.MultiAction
 
getRegionsCount() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getRegionServerCoprocessors() - Method in class org.apache.hadoop.hbase.ServerLoad
Return the RegionServer-level coprocessors
getRegionsFromMergeQualifier(Connection, byte[]) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Get regions from the merge qualifier of the specified merged region
getRegionsInRange(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
This is no longer a public API
getRegionsInRange(byte[], byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
This is no longer a public API
getRegionsInTransition() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getRegionsLoad() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getRegionSplitPolicyClassName() - Method in class org.apache.hadoop.hbase.HTableDescriptor
This gets the class associated with the region split policy which determines when a region split should occur.
getRemoteAddress() - Method in class org.apache.hadoop.hbase.ipc.RpcClientImpl.Connection
 
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.
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 class org.apache.hadoop.hbase.HRegionInfo
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
Call directly from client such as hbase shell
getReplicationLoadSourceList() - Method in class org.apache.hadoop.hbase.ServerLoad
Call directly from client such as hbase shell
getReplicationPeerConfig(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
Returns the configured ReplicationPeerConfig for this peerId
getReplicationPeerConfig(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
Returns a ReplicationPeerConfig from the znode or null for the given peerId.
getReplicationPeers(ZooKeeperWatcher, Configuration, Abortable) - Static method in class org.apache.hadoop.hbase.replication.ReplicationFactory
 
getReplicationQueues(ZooKeeperWatcher, Configuration, Abortable) - Static method in class org.apache.hadoop.hbase.replication.ReplicationFactory
 
getReplicationQueuesClient(ZooKeeperWatcher, Configuration, Abortable) - Static method in class org.apache.hadoop.hbase.replication.ReplicationFactory
 
getReplicationTracker(ZooKeeperWatcher, ReplicationPeers, Configuration, Abortable, Stoppable) - Static method in class org.apache.hadoop.hbase.replication.ReplicationFactory
 
getRequest() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
 
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
 
getRequestsCount() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getRequestSizeBytes() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
getRequestsPerSecond() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getResponseSizeBytes() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
getResults() - Method in class org.apache.hadoop.hbase.client.MultiResponse
 
getResults(ClientProtos.MultiRequest, ClientProtos.MultiResponse, CellScanner) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Get the results from a protocol buffer MultiResponse
getResults(CellScanner, ClientProtos.ScanResponse) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Create Results from the cells using the cells meta data.
getResultsToAddToCache(Result[], boolean) - Method in class org.apache.hadoop.hbase.client.ClientScanner
This method ensures all of our book keeping regarding partial results is kept up to date.
getRetries() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
getRetriesNumber() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
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
 
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)
getRowOrBefore(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
Use reversed scan instead.
getRowOrBefore(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Deprecated.
As of version 0.92 this method is deprecated without replacement. Since version 0.96+, you can use reversed scan. getRowOrBefore is used internally to find entries in hbase:meta and makes various assumptions about the table (which are true for hbase:meta but not in general) to be efficient.
getRowOrBefore(ClientProtos.ClientService.BlockingInterface, byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Deprecated.
since 0.99 - use reversed scanner instead.
getRowRanges() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
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.HTable
 
getRpcTimeout() - Method in class org.apache.hadoop.hbase.ipc.AsyncCall
Get the rpc timeout
getRsCoprocessors() - Method in class org.apache.hadoop.hbase.ServerLoad
Return the RegionServer-level and Region-level coprocessors
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(TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
This method creates a Scan object that will only scan catalog rows that belong to the specified table.
getScanMetrics() - Method in class org.apache.hadoop.hbase.client.AbstractClientScanner
Used internally accumulating metrics on scan.
getScanMetrics() - Method in class org.apache.hadoop.hbase.client.Scan
 
getScanMetrics(ClientProtos.ScanResponse) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
 
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
 
getScannerCaching() - Method in class org.apache.hadoop.hbase.client.HTable
getScannerCallable(byte[], int) - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
getScannerCallable(byte[], int, byte[]) - Method in class org.apache.hadoop.hbase.client.ReversedClientScanner
 
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
 
getScope() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getSecurityCapabilities() - Method in interface org.apache.hadoop.hbase.client.Admin
Return the set of supported security capabilities.
getSecurityCapabilities() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
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
getSeqNumDuringOpen(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
use MetaTableAccessor methods for interacting with meta layouts
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
getServerHasMoreResults() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
Should the client attempt to fetch more results from this region
getServerInfo() - Method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
As of release 0.92 (HBASE-1502). This will be removed in HBase 2.0.0. Use ClusterStatus.getServers().
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.
getServerName() - Method in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
 
getServerName(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
use MetaTableAccessor methods for interacting with meta layouts
getServerName() - Method in class org.apache.hadoop.hbase.HRegionLocation
 
getServerName() - Method in class org.apache.hadoop.hbase.master.RegionState
 
getServerName() - Method in class org.apache.hadoop.hbase.RegionTransition
 
getServerName() - Method in class org.apache.hadoop.hbase.ServerName
 
getServerName(String, long) - Static method in class org.apache.hadoop.hbase.ServerName
 
getServerNameLessStartCode(String) - Static method in class org.apache.hadoop.hbase.ServerName
Utility method to excise the start code from a server name
getServerPrincipal() - Method in class org.apache.hadoop.hbase.security.SecurityInfo
 
getServers() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getServersSize() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getServerStartcodeFromServerName(String) - Static method in class org.apache.hadoop.hbase.ServerName
 
getServerStats(String, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Gets the statistics from the given server.
getServerUserRegions(Connection, ServerName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
 
getServiceName() - Method in class org.apache.hadoop.hbase.ipc.ConnectionId
 
getSessionId() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
getSessionPasswd() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
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 class org.apache.hadoop.hbase.HRegionInfo
 
getShortTextFormat(Message) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Return short version of Message toString'd, shorter than TextFormat#shortDebugString.
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
 
getSplitKeysArray(MasterProtos.CreateTableRequest) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
get the split keys in form "byte [][]" from a CreateTableRequest proto
getStagingPath(String, byte[]) - Method in class org.apache.hadoop.hbase.client.coprocessor.SecureBulkLoadClient
 
getStagingPath(Configuration, String, byte[]) - Static method in class org.apache.hadoop.hbase.security.SecureBulkLoadUtil
This returns the staging path for a given column family.
getStamp() - Method in class org.apache.hadoop.hbase.master.RegionState
 
getStartcode() - Method in class org.apache.hadoop.hbase.ServerName
 
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 class org.apache.hadoop.hbase.client.HTable
Deprecated.
Since 1.1.0. Use RegionLocator.getStartEndKeys() instead;
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(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Gets the start key from the specified region name.
getStartKey() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
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 class org.apache.hadoop.hbase.client.HTable
Deprecated.
Since 1.1.0. Use RegionLocator.getStartEndKeys() instead
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
 
getStartTime() - Method in class org.apache.hadoop.hbase.ipc.AsyncCall
Get the start time
getStartTime() - Method in class org.apache.hadoop.hbase.ipc.Call
 
getState() - Method in class org.apache.hadoop.hbase.master.RegionState
 
getState() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
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
 
getStatusOfPeer(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
Get the replication status for the specified connected remote slave cluster.
getStatusOfPeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
getStatusOfPeerFromBackingStore(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
Get the replication status for the specified remote slave cluster, which doesn't have to be connected.
getStatusOfPeerFromBackingStore(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
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
 
getStoreCompleteSequenceId() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getStorefileIndexSizeInMB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getStoreFiles(AdminProtos.AdminService.BlockingInterface, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.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.protobuf.ProtobufUtil
A helper to get the list of files of a column family on a given region using admin protocol.
getStorefiles() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getStorefiles() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getStorefileSizeInMB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getStorefileSizeMB() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getStores() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getStores() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getStoreUncompressedSizeMB() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getStoreUncompressedSizeMB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getStub() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
 
getSupportedFilters() - Method in class org.apache.hadoop.hbase.filter.ParseFilter
Return a Set of filters supported by the Filter Language
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(String) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Retrieve an HTableInterface implementation for access to a table.
getTable(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Retrieve an HTableInterface implementation for access to a table.
getTable(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Retrieve an HTableInterface implementation for access to a table.
getTable(String, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Retrieve an HTableInterface implementation for access to a table.
getTable(byte[], ExecutorService) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Retrieve an HTableInterface implementation for access to a table.
getTable(TableName, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Retrieve an HTableInterface implementation for access to a table.
getTable(String) - Method in class org.apache.hadoop.hbase.client.HTablePool
Deprecated.
Get a reference to the specified table from the pool.
getTable(byte[]) - Method in class org.apache.hadoop.hbase.client.HTablePool
Deprecated.
Get a reference to the specified table from the pool.
getTable(TableName) - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
 
getTable(TableName, ExecutorService) - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
 
getTable(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Gets the table name from the specified region name.
getTable() - Method in class org.apache.hadoop.hbase.HRegionInfo
Get current table name of the region
getTableCFs() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
Get replicable (table, cf-list) map of this peer
getTableCFs(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
Get the table and column-family-list map of the peer.
getTableCFs(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
getTableCFs() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
Get replicable (table, cf-list) map of this peer
getTableDescriptor(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Method for getting the tableDescriptor
getTableDescriptor(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Method for getting the tableDescriptor
getTableDescriptor(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getTableDescriptor() - Method in class org.apache.hadoop.hbase.client.HTable
Gets the table descriptor for this table.
getTableDescriptor() - Method in interface org.apache.hadoop.hbase.client.Table
Gets the table descriptor for this table.
getTableDescriptors(List<String>) - Method in interface org.apache.hadoop.hbase.client.Admin
Get tableDescriptors
getTableDescriptors(List<String>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Get tableDescriptors
getTableDescriptorsByTableName(List<TableName>) - Method in interface org.apache.hadoop.hbase.client.Admin
Get tableDescriptors
getTableDescriptorsByTableName(List<TableName>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Get tableDescriptors
getTableDir(Path, byte[]) - Static method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
getTableFilter() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
 
getTableFromRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getTableName() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
 
getTableName() - Method in class org.apache.hadoop.hbase.client.ClientScanner
Deprecated.
As of release 0.96 (HBASE-9508). This will be removed in HBase 2.0.0. Use ClientScanner.getTable().
getTableName() - Method in class org.apache.hadoop.hbase.client.HTable
Gets the name of this table.
getTableName() - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Deprecated.
Use Table.getName() instead
getTableName() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
 
getTableName(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 0.96 (HBASE-9508). This will be removed in HBase 2.0.0. Use HRegionInfo.getTable(byte[]).
getTableName() - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 0.96 (HBASE-9508). This will be removed in HBase 2.0.0. Use HRegionInfo.getTable().
getTableName() - Method in class org.apache.hadoop.hbase.HTableDescriptor
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.protobuf.ProtobufUtil
 
getTableNames() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Deprecated.
getTableNames(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Deprecated.
getTableNames(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Deprecated.
getTableNames() - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
getTableQuota(Connection, TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getTableRegions(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Get the regions of a given table.
getTableRegions(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
get the regions of a given table.
getTableRegions(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getTableRegions(ZooKeeperWatcher, Connection, TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Gets all of the regions of the specified table.
getTableRegions(ZooKeeperWatcher, Connection, TableName, boolean) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Gets all of the regions of the specified table.
getTableRegionsAndLocations(ZooKeeperWatcher, Connection, TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
 
getTableRegionsAndLocations(ZooKeeperWatcher, Connection, TableName, boolean) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
 
getTableRowKey(TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getTableRowKeyRegex(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getTicket() - Method in class org.apache.hadoop.hbase.ipc.ConnectionId
 
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
Method for retrieving the timestamp
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
 
getTimeToLive() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
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
 
getTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getTotalFailedCounter() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
getTotalNumberOfRequests() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getTotalRequestsCount(ClusterStatusProtos.RegionLoad) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
getTotalSizeOfCells(Result) - Static method in class org.apache.hadoop.hbase.client.Result
Get total size of raw cells
getTotalSizeWhenWrittenDelimited(Message...) - Static method in class org.apache.hadoop.hbase.ipc.IPCUtil
 
getTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
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 exception org.apache.hadoop.hbase.quotas.ThrottlingException
 
getTypeFilters() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
 
getUnit(String) - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getUsedHeapMB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
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(RpcController, AccessControlProtos.AccessControlService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A utility used to get user's global permissions.
getUserPermissions(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, TableName) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A utility used to get user table permissions.
getUserPermissions(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A utility used to get permissions for selected namespace.
getUserPermissions(Connection, String) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
List all the userPermissions matching the given pattern.
getUserPermissions(Configuration, String) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
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
 
getUUIDForCluster(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKClusterId
Get the UUID for the provided ZK watcher.
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(byte[], byte[], Cell) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
 
getValue() - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
 
getValue() - Method in class org.apache.hadoop.hbase.filter.SubstringComparator
 
getValue(byte[]) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getValue(String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getValue(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Getter for accessing the metadata associated with the key
getValue(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Getter for accessing the metadata associated with the key
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 class org.apache.hadoop.hbase.HColumnDescriptor
 
getValues() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Getter for fetching an unmodifiable HTableDescriptor.values map.
getVersion() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getVersion() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
 
getVersion() - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
HRI is no longer a VersionedWritable
getVersion() - Method in class org.apache.hadoop.hbase.security.access.Permission
 
getVersion(ZooKeeperWatcher, HRegionInfo) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Get the version of the specified znode
getVersionedBytes() - Method in class org.apache.hadoop.hbase.ServerName
 
getVersionInfo() - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Get a protocol buffer VersionInfo
getWaitInterval() - Method in exception org.apache.hadoop.hbase.quotas.ThrottlingException
 
getWatcher() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperListener
 
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).
getWriteBuffer() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
Deprecated.
Going away when we drop public support for HTableInterface. Ó
getWriteBuffer() - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
since 0.96. This is an internal buffer that should not be read nor write.
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
 
getWriteBufferSize() - Method in class org.apache.hadoop.hbase.client.HTable
Returns the maximum size in bytes of the write buffer for this HTable.
getWriteBufferSize() - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Deprecated.
as of 1.0.0. Replaced by BufferedMutator.getWriteBufferSize()
getWriteBufferSize() - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
as of 1.0.1 (should not have been in 1.0.0). Replaced by BufferedMutator.getWriteBufferSize()
getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getWriteToWAL() - Method in class org.apache.hadoop.hbase.client.Mutation
Deprecated.
getZNodeForReplica(int) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Get the znode string corresponding to a replicaId
getZooKeeper() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
grant(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A utility used to grant a user global permissions.
grant(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, TableName, byte[], byte[], Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A utility used to grant a user table permissions.
grant(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A utility used to grant a user namespace permissions.
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(Configuration, TableName, String, byte[], byte[], Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
grant(Configuration, String, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
grant(Configuration, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
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'
handle(int, Random, Throwable) - Method in interface org.apache.hadoop.hbase.security.SaslClientHandler.SaslExceptionHandler
Handle the exception
handlerAdded(ChannelHandlerContext) - Method in class org.apache.hadoop.hbase.security.SaslClientHandler
 
has(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
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.Put
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.Put
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.Put
A convenience method to determine if this object's familyMap contains the given value assigned to the given family, qualifier and timestamp.
hasCallTimeout() - Method in class org.apache.hadoop.hbase.ipc.TimeLimitedRpcController
 
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
 
hasCoprocessor(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
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
 
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
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.FilterWrapper
 
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.Get
 
hashCode() - Method in class org.apache.hadoop.hbase.client.Increment
 
hashCode() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
 
hashCode() - Method in class org.apache.hadoop.hbase.client.RowMutations
 
hashCode() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.NullComparator
 
hashCode() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
hashCode() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
hashCode() - Method in class org.apache.hadoop.hbase.HRegionLocation
 
hashCode() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
hashCode() - Method in class org.apache.hadoop.hbase.ipc.AsyncRpcChannel
 
hashCode() - Method in class org.apache.hadoop.hbase.ipc.ConnectionId
 
hashCode(User, String, InetSocketAddress) - Static method in class org.apache.hadoop.hbase.ipc.ConnectionId
 
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.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.ServerName
 
hashCode() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.CreateAndFailSilent
 
hashCode() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.DeleteNodeFailSilent
 
hashCode() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.SetData
 
hasHigherPriority(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
Returns which operator has higher precedence
hasId() - Method in class org.apache.hadoop.hbase.zookeeper.ZKClusterId
 
hasLeader() - Method in class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
Deprecated.
 
hasMaster() - Method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
Check if there is a master available.
hasMaxHeapMB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
hasMoreResultsContext() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
Did the server respond with information about whether more results might exist.
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
 
hasQualifier() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
hasRegionMemstoreReplication() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
hasTable() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
hasTotalNumberOfRequests() - Method in class org.apache.hadoop.hbase.ServerLoad
 
hasUsedHeapMB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
HBASE_CLIENT_CONNECTION_IMPL - Static variable in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Key for configuration in Configuration whose value is the class we implement making a new HConnection instance.
HBaseAdmin - Class in org.apache.hadoop.hbase.client
HBaseAdmin is no longer a client API.
HBaseAdmin(Configuration) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin
Deprecated.
Constructing HBaseAdmin objects manually has been deprecated. Use Connection.getAdmin() to obtain an instance of Admin instead.
HBaseAdmin(Connection) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin
Deprecated.
Constructing HBaseAdmin objects manually has been deprecated. Use Connection.getAdmin() to obtain an instance of Admin instead.
HBaseAdmin.ProcedureFuture<V> - Class in org.apache.hadoop.hbase.client
Future that waits on a procedure result.
HBaseAdmin.ProcedureFuture(HBaseAdmin, Long) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
HBaseAdmin.ProcedureFuture(HBaseAdmin, Long, boolean) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
HBaseAdmin.ProcedureFuture.WaitForStateCallable - Interface in org.apache.hadoop.hbase.client
 
HBaseException - Exception in org.apache.hadoop.hbase.exceptions
Base checked exception in HBase.
HBaseException() - Constructor for exception org.apache.hadoop.hbase.exceptions.HBaseException
 
HBaseException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.HBaseException
 
HBaseException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.HBaseException
 
HBaseException(Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.HBaseException
 
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
Create a HBaseSaslRpcClient for an authentication method
HBaseSaslRpcClient(AuthMethod, Token<? extends TokenIdentifier>, String, boolean, String) - Constructor for class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
Create a HBaseSaslRpcClient for an authentication method
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, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
Exception for the given snapshot that has no previous root cause
HBaseSnapshotException(String, Throwable, HBaseProtos.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
HColumnDescriptor - Class in org.apache.hadoop.hbase
An HColumnDescriptor contains information about a column family such as the number of versions, compression settings, etc.
HColumnDescriptor() - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 0.96 (HBASE-5453). This will be made private in HBase 2.0.0. Used by Writables and Writables are going away.
HColumnDescriptor(String) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Construct a column descriptor specifying only the family name The other attributes are defaulted.
HColumnDescriptor(byte[]) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Construct a column descriptor specifying only the family name The other attributes are defaulted.
HColumnDescriptor(HColumnDescriptor) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Constructor.
HColumnDescriptor(byte[], int, String, boolean, boolean, int, String) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 0.96 (HBASE-). This will be removed in HBase 2.0.0. Use HColumnDescriptor.HColumnDescriptor(String) and setters.
HColumnDescriptor(byte[], int, String, boolean, boolean, int, int, String, int) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 0.96 (HBASE-). This will be removed in HBase 2.0.0. Use HColumnDescriptor.HColumnDescriptor(String) and setters.
HColumnDescriptor(byte[], int, int, KeepDeletedCells, String, boolean, String, boolean, boolean, int, int, String, int) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 0.96 (HBASE-). This will be removed in HBase 2.0.0. Use HColumnDescriptor.HColumnDescriptor(String) and setters.
HConnectable<T> - Class in org.apache.hadoop.hbase.client
This class makes it convenient for one to execute a command in the context of a HConnection instance based on the given Configuration.
HConnectable(Configuration) - Constructor for class org.apache.hadoop.hbase.client.HConnectable
 
HConnection - Interface in org.apache.hadoop.hbase.client
Deprecated.
HConnectionManager - Class in org.apache.hadoop.hbase.client
Deprecated.
Please use ConnectionFactory instead
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.
hint - Variable in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
HINT_LOOKAHEAD - Static variable in class org.apache.hadoop.hbase.client.Scan
Deprecated.
without replacement This is now a no-op, SEEKs and SKIPs are optimizated automatically. Will be removed in 2.0+
HQuorumPeer - Class in org.apache.hadoop.hbase.zookeeper
HBase's version of ZooKeeper's QuorumPeer.
HQuorumPeer() - Constructor for class org.apache.hadoop.hbase.zookeeper.HQuorumPeer
 
HRegionInfo - Class in org.apache.hadoop.hbase
Information about a region.
HRegionInfo(long, TableName, int) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
 
HRegionInfo() - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 0.96 (HBASE-5453). This will be removed in HBase 2.0.0. Used by Writables and Writables are going away.
HRegionInfo(TableName) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
 
HRegionInfo(TableName, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Construct HRegionInfo with explicit parameters
HRegionInfo(TableName, byte[], byte[], boolean) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Construct HRegionInfo with explicit parameters
HRegionInfo(TableName, byte[], byte[], boolean, long) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Construct HRegionInfo with explicit parameters
HRegionInfo(TableName, byte[], byte[], boolean, long, int) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Construct HRegionInfo with explicit parameters
HRegionInfo(HRegionInfo) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Costruct a copy of another HRegionInfo
HRegionInfo(HRegionInfo, int) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
 
HRegionLocation - Class in org.apache.hadoop.hbase
Data structure to hold HRegionInfo and the address for the hosting HRegionServer.
HRegionLocation(HRegionInfo, ServerName) - Constructor for class org.apache.hadoop.hbase.HRegionLocation
 
HRegionLocation(HRegionInfo, 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(Configuration, String) - Constructor for class org.apache.hadoop.hbase.client.HTable
Deprecated.
Constructing HTable objects manually has been deprecated. Please use Connection to instantiate a Table instead.
HTable(Configuration, byte[]) - Constructor for class org.apache.hadoop.hbase.client.HTable
Deprecated.
Constructing HTable objects manually has been deprecated. Please use Connection to instantiate a Table instead.
HTable(Configuration, TableName) - Constructor for class org.apache.hadoop.hbase.client.HTable
Deprecated.
Constructing HTable objects manually has been deprecated. Please use Connection to instantiate a Table instead.
HTable(TableName, Connection) - Constructor for class org.apache.hadoop.hbase.client.HTable
Deprecated.
Do not use.
HTable(Configuration, byte[], ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.HTable
Deprecated.
Constructing HTable objects manually has been deprecated. Please use Connection to instantiate a Table instead.
HTable(Configuration, TableName, ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.HTable
Deprecated.
Constructing HTable objects manually has been deprecated. Please use Connection to instantiate a Table instead.
HTable(byte[], Connection, ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.HTable
Deprecated.
Do not use, internal ctor.
HTable(TableName, Connection, ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.HTable
Deprecated.
Do not use, internal ctor.
HTable(TableName, ClusterConnection, ConnectionConfiguration, RpcRetryingCallerFactory, RpcControllerFactory, ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.HTable
Creates an object to access a HBase table.
HTable(ClusterConnection, BufferedMutatorParams) - Constructor for class org.apache.hadoop.hbase.client.HTable
For internal testing.
HTableDescriptor - Class in org.apache.hadoop.hbase
HTableDescriptor contains the details about an HBase table such as the descriptors of all the column families, is the table a catalog table, -ROOT- or 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...
HTableDescriptor(TableName, HColumnDescriptor[]) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Private constructor used internally creating table descriptors for catalog tables, hbase:meta and -ROOT-.
HTableDescriptor(TableName, HColumnDescriptor[], Map<ImmutableBytesWritable, ImmutableBytesWritable>) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Private constructor used internally creating table descriptors for catalog tables, hbase:meta and -ROOT-.
HTableDescriptor() - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
As of release 0.96 (HBASE-5453). This will be removed in HBase 2.0.0. Used by Writables and Writables are going away.
HTableDescriptor(TableName) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Construct a table descriptor specifying a TableName object
HTableDescriptor(byte[]) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
HTableDescriptor(String) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
HTableDescriptor(HTableDescriptor) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Construct a table descriptor by cloning the descriptor passed as a parameter.
HTableDescriptor(TableName, HTableDescriptor) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Construct a table descriptor by cloning the descriptor passed as a parameter but using a different table name.
HTableFactory - Class in org.apache.hadoop.hbase.client
HTableFactory() - Constructor for class org.apache.hadoop.hbase.client.HTableFactory
Deprecated.
 
HTableInterface - Interface in org.apache.hadoop.hbase.client
Deprecated.
use Table instead
HTableInterfaceFactory - Interface in org.apache.hadoop.hbase.client
Deprecated.
in favor of ConnectionFactory and Connection.
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.
HTableMultiplexer.HTableMultiplexerStatus(Map<HRegionLocation, HTableMultiplexer.FlushWorker>) - Constructor for class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
HTablePool - Class in org.apache.hadoop.hbase.client
Deprecated.
as of 0.98.1. See HConnection.getTable(String).
HTablePool() - Constructor for class org.apache.hadoop.hbase.client.HTablePool
Deprecated.
Default Constructor.
HTablePool(Configuration, int) - Constructor for class org.apache.hadoop.hbase.client.HTablePool
Deprecated.
Constructor to set maximum versions and use the specified configuration.
HTablePool(Configuration, int, HTableInterfaceFactory) - Constructor for class org.apache.hadoop.hbase.client.HTablePool
Deprecated.
Constructor to set maximum versions and use the specified configuration and table factory.
HTablePool(Configuration, int, PoolMap.PoolType) - Constructor for class org.apache.hadoop.hbase.client.HTablePool
Deprecated.
Constructor to set maximum versions and use the specified configuration and pool type.
HTablePool(Configuration, int, HTableInterfaceFactory, PoolMap.PoolType) - Constructor for class org.apache.hadoop.hbase.client.HTablePool
Deprecated.
Constructor to set maximum versions and use the specified configuration, table factory and pool type.
HTableUtil - Class in org.apache.hadoop.hbase.client
Deprecated.
since 1.0
HTableUtil() - Constructor for class org.apache.hadoop.hbase.client.HTableUtil
Deprecated.
 

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
 
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 - Variable in class org.apache.hadoop.hbase.ipc.RpcClientImpl.Connection
 
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
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(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
Increments one or more columns within a single row.
Increment - Class in org.apache.hadoop.hbase.client
Used to perform Increment operations on a single row.
Increment(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Increment
Create a Increment operation for the specified row.
Increment(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.client.Increment
Create a Increment operation for the specified row.
Increment(Increment) - Constructor for class org.apache.hadoop.hbase.client.Increment
Copy constructor
increment(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 class org.apache.hadoop.hbase.client.HTable
incrementColumnValue(byte[], byte[], byte[], long, boolean) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
As of release 0.96 (HBASE-9508). This will be removed in HBase 2.0.0. Use HTable.incrementColumnValue(byte[], byte[], byte[], long, Durability).
incrementColumnValue(byte[], byte[], byte[], long, Durability) - Method in class org.apache.hadoop.hbase.client.HTable
Atomically increments a column value.
incrementColumnValue(byte[], byte[], byte[], long, boolean) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Deprecated.
As of release 0.96 (HBASE-9508). This will be removed in HBase 2.0.0. Use Table.incrementColumnValue(byte[], byte[], byte[], long, Durability).
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
 
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.
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
 
init() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
Initialize the ReplicationPeers interface.
init() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
init(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
Initialize the region server replication queue interface.
init() - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueuesClient
Initialize the replication queue client interface.
init() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesClientZKImpl
 
init(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
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).
initializeScannerInConstruction() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
initializeScannerInConstruction() - Method in class org.apache.hadoop.hbase.client.ClientSmallReversedScanner
 
initializeScannerInConstruction() - Method in class org.apache.hadoop.hbase.client.ClientSmallScanner
 
initScanMetrics(Scan) - Method in class org.apache.hadoop.hbase.client.AbstractClientScanner
Check and initialize if application wants to collect scan metrics
injectNonceGeneratorForTesting(ClusterConnection, NonceGenerator) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
 
instance - Static variable in class org.apache.hadoop.hbase.zookeeper.EmptyWatcher
 
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
 
interruptedException(InterruptedException) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Handles InterruptedExceptions in client calls.
interruptedExceptionNoThrow(InterruptedException, boolean) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Log the InterruptedException and interrupt current thread
INVALID_REGION_NAME_FORMAT_MESSAGE - Static variable in class org.apache.hadoop.hbase.HRegionInfo
 
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
 
InvalidQuotaSettingsException - Exception in org.apache.hadoop.hbase.quotas
Generic quota exceeded exception for invalid settings
InvalidQuotaSettingsException(String) - Constructor for exception org.apache.hadoop.hbase.quotas.InvalidQuotaSettingsException
 
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
 
ipcUtil - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
IPCUtil - Class in org.apache.hadoop.hbase.ipc
Utility to help ipc'ing.
IPCUtil(Configuration) - Constructor for class org.apache.hadoop.hbase.ipc.IPCUtil
 
IPCUtil.CellScannerButNoCodecException - Exception in org.apache.hadoop.hbase.ipc
Thrown if a cellscanner but no codec to encode it with.
IPCUtil.CellScannerButNoCodecException() - Constructor for exception org.apache.hadoop.hbase.ipc.IPCUtil.CellScannerButNoCodecException
 
IS_META - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Used by rest interface to access this metadata attribute which denotes if it is a catalog table, either hbase:meta or -ROOT-
IS_ROOT - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Used by rest interface to access this metadata attribute which denotes if the table is a -ROOT- region or not
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.replication.ReplicationPeerZKImpl
 
isAborted() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
isAccessControllerRunning(Connection) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
 
isAccessControllerRunning(Configuration) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
isAlive() - Method in class org.apache.hadoop.hbase.ipc.AsyncRpcChannel
Check if the connection is alive
isAnyMetaReplicaZnode(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Is the znode of any meta replica
isAuthorizationEnabled(Connection) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
Return true if authorization is supported and enabled
isAutoFlush() - Method in class org.apache.hadoop.hbase.client.HTable
Tells whether or not 'auto-flush' is turned on.
isAutoFlush() - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Deprecated.
as of 1.0.0. Replaced by BufferedMutator
isBalancerEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
Query the current state of the balancer
isBalancerEnabled() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Query the state of the balancer from the Master.
isBalancerOn() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
isBlockCacheEnabled() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
isCacheBloomsOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
isCacheDataInL1() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
isCacheDataOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
isCacheIndexesOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
isCanceled() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
 
isCanceled() - Method in class org.apache.hadoop.hbase.ipc.TimeLimitedRpcController
 
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 class org.apache.hadoop.hbase.client.HBaseAdmin
Query on the catalog janitor state (Enabled/Disabled?)
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
 
isClientReadable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Returns whether the znode is supposed to be readable by the client and DOES NOT contain sensitive information (world readable).
isClosed() - Method in interface org.apache.hadoop.hbase.client.Connection
Returns whether the connection is closed or not.
isClosed() - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
 
isClosed() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isClosed(AdminProtos.CloseRegionResponse) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Check if the region is closed from a CloseRegionResponse
isClosestRowBefore() - Method in class org.apache.hadoop.hbase.client.Get
 
isClosing() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isCompactionEnabled() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Check if the compaction enable flag of the table is true.
isCompressTags() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
isDeadServer(ServerName) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Deprecated.
internal method, do not use thru HConnection
isDeadServer(ServerName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
isDefaultMetaReplicaZnode(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Is it the default meta replica's znode
isDefaultReplica(int) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
 
isDefaultReplica(HRegionInfo) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
 
isDisabledTable(ZooKeeperWatcher, TableName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateClientSideReader
Go to zookeeper and see if state of table is ZooKeeperProtos.Table.State#DISABLED.
isDisablingOrDisabledTable(ZooKeeperWatcher, TableName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateClientSideReader
Go to zookeeper and see if state of table is ZooKeeperProtos.Table.State#DISABLING of ZooKeeperProtos.Table.State#DISABLED.
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 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
 
isEmpty() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData
Deprecated.
 
isEmptyQuota(QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
isEnabledTable(ZooKeeperWatcher, TableName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateClientSideReader
Go to zookeeper and see if state of table is ZooKeeperProtos.Table.State#ENABLED.
isEvictBlocksOnClose() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
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.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.FilterWrapper
 
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
 
isFullServerName(String) - Static method in class org.apache.hadoop.hbase.ServerName
 
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.
isHeartbeatMessage() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
isInMemory() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
isLegalFamilyName(byte[]) - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
 
isLocationAvailable(ZooKeeperWatcher) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Checks if the meta region location is available.
isManaged() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
 
isMasterRunning() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Deprecated.
this has been deprecated without a replacement
isMasterRunning() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Deprecated.
this has been deprecated without a replacement
isMasterRunning() - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
isMaxColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
isMerged() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isMerging() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isMergingNew() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isMetaClearingException(Throwable) - Static method in class org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
 
isMetaRegion() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
isMetaRegion() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Checks if this table is hbase:meta region.
isMetaTable() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
isMetaTable() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Checks if the table is a hbase:meta table
isMinColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
isNamespaceRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
isNormalizationEnabled() - Method in class org.apache.hadoop.hbase.HTableDescriptor
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 class org.apache.hadoop.hbase.client.HBaseAdmin
Query the current state of the region normalizer
isNull() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
 
isOffline() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
isOffline() - Method in class org.apache.hadoop.hbase.master.RegionState
 
IsolationLevel - Enum in org.apache.hadoop.hbase.client
Specify Isolation levels in Scan operations.
isOnlineSchemaChangeSupported() - Method in enum org.apache.hadoop.hbase.executor.EventType
 
isOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
 
isOpened() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isOpening() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isOpenOrMergingNewOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
 
isOpenOrMergingOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
 
isOpenOrSplittingNewOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
 
isOpenOrSplittingOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
 
isPartial() - Method in class org.apache.hadoop.hbase.client.Result
Whether or not the result is a partial result.
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
 
isPeerPath(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
Determine if a ZK path points to a peer node.
isPendingClose() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isPendingCloseOrClosing() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isPendingCloseOrClosingOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
 
isPendingOpen() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isPendingOpenOrOpening() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isPendingOpenOrOpeningOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
 
isPrefetchBlocksOnOpen() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
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 class org.apache.hadoop.hbase.client.HBaseAdmin
Check the current state of the specified procedure.
isQueueRecovered() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueueInfo
 
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 class org.apache.hadoop.hbase.HTableDescriptor
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(HRegionInfo, HRegionInfo) - 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
 
isRootRegion() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Check if the descriptor represents a -ROOT- region.
isSameHostnameAndPort(ServerName, ServerName) - Static method in class org.apache.hadoop.hbase.ServerName
 
isScanMetricsEnabled() - Method in class org.apache.hadoop.hbase.client.Scan
 
isSecureZooKeeper(Configuration) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Returns whether or not secure authentication is enabled (whether hbase.security.authentication is set to kerberos.
isSmall() - Method in class org.apache.hadoop.hbase.client.Scan
Get whether this scan is a small scan
isSnapshotFinished(HBaseProtos.SnapshotDescription) - Method in interface org.apache.hadoop.hbase.client.Admin
Check the current state of the passed snapshot.
isSnapshotFinished(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Check the current state of the passed snapshot.
isSpecialException(Throwable) - Static method in class org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
 
isSplit() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
isSplit() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isSplitParent() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
isSplitting() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isSplittingNew() - 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
 
isStateEnabled(byte[]) - Static method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
Parse the raw data from ZK to get a peer's state
isStopRowInclusive() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
 
issueDate - Variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
isSuperUserId(String[], Id) - Static method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
isSystemTable() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
isTableAvailable(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
 
isTableAvailable(TableName, byte[][]) - Method in interface org.apache.hadoop.hbase.client.Admin
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(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableAvailable(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableAvailable(TableName, byte[][]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
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(byte[], byte[][]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableAvailable(String, byte[][]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableAvailable(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
 
isTableAvailable(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
isTableAvailable(TableName, byte[][]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
isTableAvailable(byte[], byte[][]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
isTableDisabled(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
 
isTableDisabled(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableDisabled(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableDisabled(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableDisabled(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
 
isTableDisabled(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
isTableEnabled(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
 
isTableEnabled(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableEnabled(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableEnabled(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableEnabled(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
A table that isTableEnabled == false and isTableDisabled == false is possible.
isTableEnabled(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
isTableEnabled(String) - Static method in class org.apache.hadoop.hbase.client.HTable
isTableEnabled(byte[]) - Static method in class org.apache.hadoop.hbase.client.HTable
isTableEnabled(TableName) - Static method in class org.apache.hadoop.hbase.client.HTable
isTableEnabled(Configuration, String) - Static method in class org.apache.hadoop.hbase.client.HTable
isTableEnabled(Configuration, byte[]) - Static method in class org.apache.hadoop.hbase.client.HTable
isTableEnabled(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.client.HTable
isTableRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
isThisOurZnode(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
Checks if the provided znode is the same as this region server's
isThisOurZnode(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
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 class org.apache.hadoop.hbase.client.AbstractClientScanner
 
iterator() - Method in class org.apache.hadoop.hbase.quotas.QuotaRetriever
 

J

joinZNode(String, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
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.HColumnDescriptor
 
KeepDeletedCells - Enum in org.apache.hadoop.hbase
Ways to keep cells marked for delete around.
keeperException(KeeperException) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Handles KeeperExceptions in client calls.
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
lastCellLoadedToCache - Variable in class org.apache.hadoop.hbase.client.ClientScanner
The last cell from a not full Row which is added to cache
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
 
lengthOfPBMagic() - Static method in class org.apache.hadoop.hbase.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
 
list() - Method in class org.apache.hadoop.hbase.client.Result
Deprecated.
as of 0.96, use Result.listCells()
listAllRegions(Configuration, Connection, boolean) - Static method in class org.apache.hadoop.hbase.client.MetaScanner
Lists all of the regions currently in META.
listCells() - Method in class org.apache.hadoop.hbase.client.Result
Create a sorted list of the Cell's in this result.
listChildrenAndWatchForNewChildren(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Lists the children znodes of the specified znode.
listChildrenAndWatchThem(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
List all the children of the specified znode, setting a watch for children changes and also setting a watch on every individual child in order to get the NodeCreated and NodeDeleted events.
listChildrenNoWatch(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Lists the children of the specified znode without setting any watches.
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 class org.apache.hadoop.hbase.client.HBaseAdmin
List available namespace descriptors
listPeerConfigs() - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
 
listPeers() - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
listProcedures() - Method in interface org.apache.hadoop.hbase.client.Admin
List procedures
listProcedures() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
List procedures
listReplicated() - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Find all column families that are replicated from this cluster
listSnapshots() - Method in interface org.apache.hadoop.hbase.client.Admin
List completed snapshots.
listSnapshots(String) - Method in interface org.apache.hadoop.hbase.client.Admin
List all the completed snapshots matching the given regular expression.
listSnapshots(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
List all the completed snapshots matching the given pattern.
listSnapshots() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
List completed snapshots.
listSnapshots(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
List all the completed snapshots matching the given regular expression.
listSnapshots(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
List all the completed snapshots matching the given pattern.
listTableDescriptorsByNamespace(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Get list of table descriptors by namespace
listTableDescriptorsByNamespace(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Get list of table descriptors by namespace
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
List all of the names of userspace tables.
listTableNames(Pattern, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
List all of the names of userspace tables.
listTableNames(String, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
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
 
listTableNames() - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Use Admin.listTables() instead.
listTableNamesByNamespace(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Get list of table names by namespace
listTableNamesByNamespace(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Get list of table names by namespace
listTableRegionLocations(Configuration, Connection, TableName) - Static method in class org.apache.hadoop.hbase.client.MetaScanner
Lists table regions and locations grouped by region range from META.
listTables() - Method in interface org.apache.hadoop.hbase.client.Admin
List all the userspace tables.
listTables(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
List all the userspace tables matching the given pattern.
listTables(String) - Method in interface org.apache.hadoop.hbase.client.Admin
List all the userspace tables matching the given regular expression.
listTables(Pattern, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
List all the tables matching the given pattern.
listTables(String, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
List all the tables matching the given pattern.
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
 
listTables() - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Use Admin.listTables() instead.
loadCache() - Method in class org.apache.hadoop.hbase.client.ClientScanner
Contact the servers to load more Results in the cache.
loadCache() - Method in class org.apache.hadoop.hbase.client.ClientSmallReversedScanner
 
loadCache() - Method in class org.apache.hadoop.hbase.client.ClientSmallScanner
 
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
 
locateRegion(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
locateRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
locateRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
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.
locateRegions(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
locateRegions(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
locateRegions(TableName, boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
locateRegions(byte[], boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
locateStartRow - Variable in class org.apache.hadoop.hbase.client.ReversedScannerCallable
The start row for locating regions.
location - Variable in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
location - Variable in class org.apache.hadoop.hbase.client.RegionServerCallable
 
lockOtherRS(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
Try to set a lock in another region server's znode.
LockTimeoutException - Exception in org.apache.hadoop.hbase.exceptions
Thrown when there is a timeout when trying to acquire a lock
LockTimeoutException() - Constructor for exception org.apache.hadoop.hbase.exceptions.LockTimeoutException
Default constructor
LockTimeoutException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.LockTimeoutException
 
LOG - Static variable in class org.apache.hadoop.hbase.client.RpcRetryingCaller
 
LOG - Static variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
LOG - Static variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
LOG - Static variable in class org.apache.hadoop.hbase.ipc.IPCUtil
 
LOG - Static variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
 
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
 
loginClient(Configuration, String, String, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Log in the current zookeeper client using the given configuration keys for the credential file and login principal.
loginServer(Configuration, String, String, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Log in the current zookeeper server process using the given configuration keys for the credential file and login principal.
logZKTree(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Recursively print the current state of ZK (non-transactional)
logZKTree(ZooKeeperWatcher, String, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Helper method to print the current state of the ZK tree.
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

main(String[]) - Static method in class org.apache.hadoop.hbase.zookeeper.HQuorumPeer
Parse ZooKeeper configuration from HBase XML config and run a QuorumPeer.
main(String[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZkAclReset
 
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) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Major compact a table.
majorCompact(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
majorCompact(byte[]) - 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(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
majorCompact(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
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 class org.apache.hadoop.hbase.client.HBaseAdmin
Major compact a table or an individual region.
majorCompactRegion(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Major compact a column family within region.
makeDeleteFromRegionInfo(HRegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Generates and returns a Delete containing the region info for the catalog table
makeDeleteFromRegionInfo(HRegionInfo, long) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Generates and returns a Delete containing the region info for the catalog table
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(HRegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Generates and returns a Put containing the region into for the catalog table
makePutFromRegionInfo(HRegionInfo, long) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Generates and returns a Put containing the region into for the catalog table
makeScan(QuotaFilter) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
markClosed(IOException) - Method in class org.apache.hadoop.hbase.ipc.RpcClientImpl.Connection
 
MasterAddressTracker - Class in org.apache.hadoop.hbase.zookeeper
Manages the location of the current active Master for the RegionServer.
MasterAddressTracker(ZooKeeperWatcher, Abortable) - Constructor for class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
Construct a master address listener with the specified zookeeper reference.
MasterCoprocessorRpcChannel - Class in org.apache.hadoop.hbase.ipc
Provides clients with an RPC connection to call coprocessor endpoint Services against the active master.
MasterCoprocessorRpcChannel(ClusterConnection) - Constructor for class org.apache.hadoop.hbase.ipc.MasterCoprocessorRpcChannel
 
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
 
matchedColumn - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
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.
max(TableName, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
It gives the maximum value of a column for a given column family for the given range.
max(Table, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
It gives the maximum value of a column for a given column family for the given range.
MAX_BACKOFF_KEY - Static variable in class org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
 
MAX_CACHED_CONNECTION_INSTANCES - Static variable in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated.
MAX_FILESIZE - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL 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_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
 
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
 
MD5_HEX_LENGTH - Static variable in class org.apache.hadoop.hbase.HRegionInfo
 
mechanismName - Variable in enum org.apache.hadoop.hbase.security.AuthMethod
 
median(TableName, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
This is the client side interface/handler for calling the median method for a given cf-cq combination.
median(Table, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
This is the client side interface/handler for calling the median method for a given cf-cq combination.
MEMSTORE_FLUSHSIZE - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL 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
mergeDelimitedFrom(Message.Builder, InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
This version of protobuf's mergeDelimitedFrom avoids the hard-coded 64MB limit for decoding buffers
mergeFrom(Message.Builder, InputStream, 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 where the message size is known
mergeFrom(Message.Builder, InputStream) - 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 where the message size is not known
mergeFrom(Message.Builder, ByteString) - 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 ByteStrings
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
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
mergeRegions(byte[], byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Merge two regions.
mergeRegions(byte[], byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Merge two regions.
mergeRegions(Connection, HRegionInfo, HRegionInfo, HRegionInfo, ServerName, int, long) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Merge the two regions into one in an atomic operation.
mergeRegions(RpcController, AdminProtos.AdminService.BlockingInterface, HRegionInfo, HRegionInfo, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to merge regions using admin protocol.
META_REPLICA_ID_DELIMITER - Static variable in class org.apache.hadoop.hbase.MetaTableAccessor
The delimiter for meta columns for replicaIds > 0
META_TABLEDESC - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Use TableDescriptors#get(TableName.META_TABLE_NAME) or HBaseAdmin#getTableDescriptor(TableName.META_TABLE_NAME) instead.
META_ZNODE_PREFIX - Static variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
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
 
metaScan(Connection, MetaScanner.MetaScannerVisitor) - Static method in class org.apache.hadoop.hbase.client.MetaScanner
Scans the meta table and calls a visitor on each RowResult and uses a empty start row value as table name.
metaScan(Connection, MetaScanner.MetaScannerVisitor, TableName) - Static method in class org.apache.hadoop.hbase.client.MetaScanner
Scans the meta table and calls a visitor on each RowResult.
metaScan(Connection, MetaScanner.MetaScannerVisitor, TableName, byte[], int) - Static method in class org.apache.hadoop.hbase.client.MetaScanner
Scans the meta table and calls a visitor on each RowResult.
MetaScanner - Class in org.apache.hadoop.hbase.client
Scanner class that contains the hbase:meta table scanning logic.
MetaScanner() - Constructor for class org.apache.hadoop.hbase.client.MetaScanner
 
MetaScanner.DefaultMetaScannerVisitor - Class in org.apache.hadoop.hbase.client
A MetaScannerVisitor that skips offline regions and split parents
MetaScanner.DefaultMetaScannerVisitor() - Constructor for class org.apache.hadoop.hbase.client.MetaScanner.DefaultMetaScannerVisitor
 
MetaScanner.MetaScannerVisitor - Interface in org.apache.hadoop.hbase.client
Visitor class called to process each row of the hbase:meta table
MetaScanner.MetaScannerVisitorBase - Class in org.apache.hadoop.hbase.client
 
MetaScanner.MetaScannerVisitorBase() - Constructor for class org.apache.hadoop.hbase.client.MetaScanner.MetaScannerVisitorBase
 
MetaScanner.TableMetaScannerVisitor - Class in org.apache.hadoop.hbase.client
A MetaScannerVisitor for a table.
MetaScanner.TableMetaScannerVisitor(TableName) - Constructor for class org.apache.hadoop.hbase.client.MetaScanner.TableMetaScannerVisitor
 
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.Visitor - Interface in org.apache.hadoop.hbase
Implementations 'visit' a catalog table row.
metaTableDescriptor(Configuration) - Static method in class org.apache.hadoop.hbase.HTableDescriptor
 
MetaTableLocator - Class in org.apache.hadoop.hbase.zookeeper
Utility class to perform operation (get/wait for/verify/set/delete) on znode in ZooKeeper which keeps hbase:meta region server location.
MetaTableLocator() - Constructor for class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
 
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(ConnectionManager.HConnectionImplementation) - Constructor for class org.apache.hadoop.hbase.client.MetricsConnection
 
MetricsConnection.CallStats - Class in org.apache.hadoop.hbase.client
A container class for collecting details about the RPC call as it percolates.
MetricsConnection.CallStats() - Constructor for class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
MetricsConnection.CallTracker - Class in org.apache.hadoop.hbase.client
 
MetricsConnection.RegionStats - Class in org.apache.hadoop.hbase.client
 
MetricsConnection.RegionStats(MetricsRegistry, String) - Constructor for class org.apache.hadoop.hbase.client.MetricsConnection.RegionStats
 
MetricsConnection.RunnerStats - Class in org.apache.hadoop.hbase.client
 
MetricsConnection.RunnerStats(MetricsRegistry) - Constructor for class org.apache.hadoop.hbase.client.MetricsConnection.RunnerStats
 
MILLIS_BETWEEN_NEXTS_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
 
min(TableName, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
It gives the minimum value of a column for a given column family for the given range.
min(Table, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
It gives the minimum value of a column for a given column family for the given range.
MIN_VERSIONS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
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
 
MINUS_SIGN - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII for Minus Sign
modifyColumn(TableName, HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Modify an existing column family on a table.
modifyColumn(String, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Modify an existing column family on a table.
modifyColumn(byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Modify an existing column family on a table.
modifyColumn(TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Modify an existing column family on a table.
modifyFamily(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
 
modifyFamily(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Modifies the existing column family.
modifyNamespace(NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Modify an existing namespace
modifyNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Modify an existing namespace
modifyTable(TableName, HTableDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Modify an existing table, more IRB friendly version.
modifyTable(TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Modify an existing table, more IRB friendly version.
modifyTable(byte[], HTableDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
modifyTable(String, HTableDescriptor) - 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[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Move the region r to dest.
multi(Iterable<Op>) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
Run multiple operations in a transactional manner.
MultiAction<R> - 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
 
multiAp - Variable in class org.apache.hadoop.hbase.client.HTable
The Async process for batch
multiOrSequential(ZooKeeperWatcher, List<ZKUtil.ZKUtilOp>, boolean) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
If hbase.zookeeper.useMulti is true, use ZooKeeper's multi-update functionality.
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
 
MultiRowRangeFilter.RowRange() - Constructor for class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
 
MultiRowRangeFilter.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.
MultiRowRangeFilter.RowRange(byte[], boolean, byte[], boolean) - Constructor for class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
 
multiTracker - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
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.
mutateRegions(Connection, List<HRegionInfo>, List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Adds and Removes the specified regions from hbase:meta
mutateRow(RowMutations) - Method in class org.apache.hadoop.hbase.client.HTable
Performs multiple mutations atomically on a single row.
mutateRow(RowMutations) - Method in interface org.apache.hadoop.hbase.client.Table
Performs multiple mutations atomically on a single row.
Mutation - Class in org.apache.hadoop.hbase.client
 
Mutation() - Constructor for class org.apache.hadoop.hbase.client.Mutation
 
MUTATION_OVERHEAD - Static variable in class org.apache.hadoop.hbase.client.Mutation
 
mutator - Variable in class org.apache.hadoop.hbase.client.HTable
 

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.HTableDescriptor
 
NAMESPACE_FAMILY_INFO - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
NAMESPACE_FAMILY_INFO_BYTES - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
NAMESPACE_TABLEDESC - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
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
 
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 - Static variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
NeedUnmanagedConnectionException - Exception in org.apache.hadoop.hbase.client
Used for internal signalling that a Connection implementation needs to be user-managed to be used for particular request types.
NeedUnmanagedConnectionException() - Constructor for exception org.apache.hadoop.hbase.client.NeedUnmanagedConnectionException
 
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.
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
 
next(int) - Method in class org.apache.hadoop.hbase.client.AbstractClientScanner
Get nbRows rows.
next() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
next() - Method in class org.apache.hadoop.hbase.client.ClientSmallReversedScanner
 
next() - Method in class org.apache.hadoop.hbase.client.ClientSmallScanner
 
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
 
next() - Method in class org.apache.hadoop.hbase.quotas.QuotaRetriever
 
nextScanner(int, boolean) - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
nextScanner(int, boolean) - Method in class org.apache.hadoop.hbase.client.ReversedClientScanner
 
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.HRegionInfo
 
node - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
Path of node being tracked
nodeChildrenChanged(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl.OtherRegionServerWatcher
Called when an existing node has a child node added or removed.
nodeChildrenChanged(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl.PeersWatcher
Called when an existing node has a child node added or removed.
nodeChildrenChanged(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperListener
Called when an existing node has a child node added or removed.
nodeCreated(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl.TableCFsTracker
 
nodeCreated(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl.OtherRegionServerWatcher
Called when a new node has been created.
nodeCreated(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
Deprecated.
 
nodeCreated(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperListener
Called when a new node has been created.
nodeCreated(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
 
nodeDataChanged(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl.PeerStateTracker
 
nodeDataChanged(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl.TableCFsTracker
 
nodeDataChanged(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperListener
Called when an existing node has changed data.
nodeDataChanged(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
 
nodeDeleted(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl.OtherRegionServerWatcher
Called when a node has been deleted
nodeDeleted(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl.PeersWatcher
Called when a node has been deleted
nodeDeleted(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
Deprecated.
 
nodeDeleted(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperListener
Called when a node has been deleted
nodeDeleted(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
 
nodeHasChildren(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Checks if the specified znode has any children.
NON_EXIST_LABEL_ORDINAL - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
Label ordinal value for invalid labels
NON_STARTCODE - Static variable in class org.apache.hadoop.hbase.ServerName
What to use if no startcode supplied.
NonceGenerator - Interface in org.apache.hadoop.hbase.client
NonceGenerator interface.
NORMALIZATION_ENABLED - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Used by shell/rest interface to access this metadata attribute which denotes if the table should be treated by region normalizer.
normalize() - Method in interface org.apache.hadoop.hbase.client.Admin
Invoke region normalizer.
normalize() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Invoke region normalizer.
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.ipc.ServerRpcController
 
notifyOnCancel(RpcCallback<Object>) - Method in class org.apache.hadoop.hbase.ipc.TimeLimitedRpcController
 
notifyOnFail(RpcCallback<IOException>) - Method in class org.apache.hadoop.hbase.ipc.TimeLimitedRpcController
Notify a callback on error.
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
 
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'
obtainAndCacheToken(Configuration, UserGroupInformation) - Static method in class org.apache.hadoop.hbase.security.token.TokenUtil
obtainAndCacheToken(Connection, User) - Static method in class org.apache.hadoop.hbase.security.token.TokenUtil
Obtain an authentication token for the given user and add it to the user's credentials.
obtainServerLoadPB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
obtainToken(Configuration) - Static method in class org.apache.hadoop.hbase.security.token.TokenUtil
Deprecated.
obtainToken(Connection) - Static method in class org.apache.hadoop.hbase.security.token.TokenUtil
Obtain and return an authentication token for the current user.
obtainToken(Connection, User) - Static method in class org.apache.hadoop.hbase.security.token.TokenUtil
Obtain and return an authentication token for the current user.
obtainTokenForJob(Configuration, UserGroupInformation, Job) - Static method in class org.apache.hadoop.hbase.security.token.TokenUtil
obtainTokenForJob(Connection, User, Job) - Static method in class org.apache.hadoop.hbase.security.token.TokenUtil
Obtain an authentication token on behalf of the given user and add it to the credentials for the given map reduce job.
obtainTokenForJob(JobConf, UserGroupInformation) - Static method in class org.apache.hadoop.hbase.security.token.TokenUtil
obtainTokenForJob(Connection, JobConf, User) - Static method in class org.apache.hadoop.hbase.security.token.TokenUtil
Obtain an authentication token on behalf of the given user and add it to the credentials for the given map reduce job.
offline(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Offline specified region from master's in-memory state.
offline(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Offline specified region from master's in-memory state.
onException(RetriesExhaustedWithDetailsException, BufferedMutator) - Method in interface org.apache.hadoop.hbase.client.BufferedMutator.ExceptionListener
 
onSuccess(Channel) - Method in interface org.apache.hadoop.hbase.security.SaslClientHandler.SaslSuccessfulConnectHandler
Runs on success
OP_ATTRIBUTE_ACL - Static variable in interface org.apache.hadoop.hbase.security.access.AccessControlConstants
Cell level ACL
OP_ATTRIBUTE_ACL_STRATEGY - Static variable in interface org.apache.hadoop.hbase.security.access.AccessControlConstants
Cell level ACL evaluation strategy
OP_ATTRIBUTE_ACL_STRATEGY_CELL_FIRST - Static variable in interface org.apache.hadoop.hbase.security.access.AccessControlConstants
Alternate cell ACL evaluation strategy: Cell ACL first, then table and CF
OP_ATTRIBUTE_ACL_STRATEGY_DEFAULT - Static variable in interface org.apache.hadoop.hbase.security.access.AccessControlConstants
Default cell ACL evaluation strategy: Table and CF first, then 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, HRegionInfo) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to open a region using admin protocol.
openScanner() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
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
 
OperationConflictException - Exception in org.apache.hadoop.hbase.exceptions
The exception that is thrown if there's duplicate execution of non-idempotent operation.
OperationConflictException() - Constructor for exception org.apache.hadoop.hbase.exceptions.OperationConflictException
 
OperationConflictException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.OperationConflictException
 
OperationConflictException(Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.OperationConflictException
 
OperationConflictException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.OperationConflictException
 
OperationWithAttributes - Class in org.apache.hadoop.hbase.client
 
OperationWithAttributes() - Constructor for class org.apache.hadoop.hbase.client.OperationWithAttributes
 
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.executor - package org.apache.hadoop.hbase.executor
 
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.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
 
ourClusterKey - Variable in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
The cluster key of the local cluster
out - Variable in class org.apache.hadoop.hbase.ipc.RpcClientImpl.Connection
 
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<HRegionInfo>, 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.HTableDescriptor
 
OWNER_KEY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
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'
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.
parse(byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
 
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 class org.apache.hadoop.hbase.HRegionInfo
Parses all the HRegionInfo instances from the passed in stream until EOF.
ParseFilter - Class in org.apache.hadoop.hbase.filter
This class allows a user to specify a filter via a string The string is parsed using the methods of this class and a filter object is constructed.
ParseFilter() - Constructor for class org.apache.hadoop.hbase.filter.ParseFilter
 
parseFilterString(String) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
Parses the filterString and constructs a filter using it
parseFilterString(byte[]) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
Parses the filterString and constructs a filter using it
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.ClusterId
 
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.ByteArrayComparable
 
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.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.FilterWrapper
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
 
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
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
 
parseFrom(byte[], int, int) - Static method in class org.apache.hadoop.hbase.HRegionInfo
 
parseFrom(DataInputStream) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Parses an HRegionInfo instance from the passed in stream.
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.HTableDescriptor
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.RegionTransition
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.ServerName
Get a ServerName from the passed in data bytes.
parseFromOrNull(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
 
parseFromOrNull(byte[], int, int) - Static method in class org.apache.hadoop.hbase.HRegionInfo
 
parseHostname(String) - Static method in class org.apache.hadoop.hbase.ServerName
 
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
 
parsePort(String) - Static method in class org.apache.hadoop.hbase.ServerName
 
parseRegionInfoFromRegionName(byte[]) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Returns an HRI parsed from this regionName.
parseRegionName(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Separate elements of a regionName.
parseRegionStoreSequenceIds(byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
 
parseResult(Result, QuotaTableUtil.QuotasVisitor) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
parseServerName(String) - Static method in class org.apache.hadoop.hbase.ServerName
 
parseSimpleFilterExpression(byte[]) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
Constructs a filter object given a simple filter expression
parseStartcode(String) - Static method in class org.apache.hadoop.hbase.ServerName
 
parseTableCFsFromConfig(String) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
 
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
 
parseVersionedServerName(byte[]) - Static method in class org.apache.hadoop.hbase.ServerName
Use this method instantiating a ServerName from bytes gotten from a call to ServerName.getVersionedBytes().
parseWALPositionFrom(byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
 
partialResults - Variable in class org.apache.hadoop.hbase.client.ClientScanner
A list of partial results that have been returned from the server.
partialResultsRow - Variable in class org.apache.hadoop.hbase.client.ClientScanner
The row for which we are accumulating partial Results (i.e.
passedPrefix - Variable in class org.apache.hadoop.hbase.filter.PrefixFilter
 
pattern - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsValidator
 
PayloadCarryingRpcController - Class in org.apache.hadoop.hbase.ipc
Optionally carries Cells across the proxy/service interface down into ipc.
PayloadCarryingRpcController() - Constructor for class org.apache.hadoop.hbase.ipc.PayloadCarryingRpcController
 
PayloadCarryingRpcController(CellScanner) - Constructor for class org.apache.hadoop.hbase.ipc.PayloadCarryingRpcController
 
PayloadCarryingRpcController(List<CellScannable>) - Constructor for class org.apache.hadoop.hbase.ipc.PayloadCarryingRpcController
 
PB_MAGIC - Static variable in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Magic we put ahead of a serialized protobuf message.
peerAdded(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
 
peerAdded(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
peerExists(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
 
peerListChanged(List<String>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationListener
The list of registered peer clusters has changed.
peerRemoved(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationListener
A peer cluster has been removed (i.e.
peerRemoved(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
 
peerRemoved(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
peerStateNodeName - Variable in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
The name of the znode that contains the replication status of a remote slave (i.e.
peersZNode - Variable in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
The name of the znode that contains a list of all remote slave (i.e.
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.
PerClientRandomNonceGenerator() - Constructor for class org.apache.hadoop.hbase.client.PerClientRandomNonceGenerator
 
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
 
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.
PoolMap.ReusablePool(int) - Constructor for class org.apache.hadoop.hbase.util.PoolMap.ReusablePool
 
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
positionToByteArray(long) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
 
postOpeartionFailure(IOException, long) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
Called after the operation is terminated with a failure.
postOperationResult(V, long) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
Called after the operation is completed and the result fetched.
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
 
PREFETCH_BLOCKS_ON_OPEN - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Key for the PREFETCH_BLOCKS_ON_OPEN attribute.
prefix - Variable in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
prefix - Variable in class org.apache.hadoop.hbase.filter.PrefixFilter
 
prefix(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Adds this instance's identifier as a prefix to the passed str
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.DelegatingRetryingCallable
 
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 for connection to the server hosting region with row from tablename.
prepare(boolean) - Method in interface org.apache.hadoop.hbase.client.RetryingCallable
Prepare by setting up any connections to servers, etc., ahead of RetryingCallable.call(int) invocation.
prepare(boolean) - Method in class org.apache.hadoop.hbase.client.ReversedScannerCallable
 
prepare(boolean) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
prepareBulkLoad(TableName) - Method in class org.apache.hadoop.hbase.client.coprocessor.SecureBulkLoadClient
 
prependPBMagic(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Prepend the passed bytes with four bytes of magic, PB_MAGIC, to flag what follows as a protobuf in hbase.
prettyPrint(String) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Use logging.
primaryOperationTimeout - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
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
process(WatchedEvent) - Method in class org.apache.hadoop.hbase.zookeeper.EmptyWatcher
 
process(WatchedEvent) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Method called from ZooKeeper for events and connection status.
processBatch(List<? extends Row>, TableName, ExecutorService, Object[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
processBatch(List<? extends Row>, byte[], ExecutorService, Object[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
processBatch(List<? extends Row>, Object[]) - Method in class org.apache.hadoop.hbase.client.HTable
Parameterized batch processing, allowing varying return types for different Row implementations.
processBatchCallback(List<? extends Row>, TableName, ExecutorService, Object[], Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.HConnection
processBatchCallback(List<? extends Row>, byte[], ExecutorService, Object[], Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
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.
processRow(Result) - Method in class org.apache.hadoop.hbase.client.MetaScanner.DefaultMetaScannerVisitor
 
processRow(Result) - Method in interface org.apache.hadoop.hbase.client.MetaScanner.MetaScannerVisitor
Visitor method that accepts a RowResult and the meta region location.
processRow(Result) - Method in class org.apache.hadoop.hbase.client.MetaScanner.TableMetaScannerVisitor
 
processRowInternal(Result) - Method in class org.apache.hadoop.hbase.client.MetaScanner.DefaultMetaScannerVisitor
 
ProtobufUtil - Class in org.apache.hadoop.hbase.protobuf
Protobufs utility.
put(Put) - Method in class org.apache.hadoop.hbase.client.HTable
Puts some data in the table.
put(List<Put>) - Method in class org.apache.hadoop.hbase.client.HTable
Puts some data in the table, in batch.
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(Put) - Constructor for class org.apache.hadoop.hbase.client.Put
Copy constructor.
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
Puts some data in the table, in batch.
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(Map<? extends K, ? extends V>) - Method in class org.apache.hadoop.hbase.util.PoolMap
 
putsToMetaTable(Connection, List<Put>) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Put the passed ps to the hbase:meta table.
putTable(HTableInterface) - Method in class org.apache.hadoop.hbase.client.HTablePool
Deprecated. 
putTracker - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 

Q

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
Constructor.
Query - Class in org.apache.hadoop.hbase.client
 
Query() - Constructor for class org.apache.hadoop.hbase.client.Query
 
queuesZNode - Variable in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
The name of the znode that contains all replication queues
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_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_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
 
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
 
quotasFromData(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
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.
raw() - Method in class org.apache.hadoop.hbase.client.Result
Deprecated.
as of 0.96, use Result.rawCells()
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
readChunked(DataInput, byte[], int, int) - Static method in class org.apache.hadoop.hbase.ipc.IPCUtil
Read in chunks of 8K (HBASE-7239)
readClusterIdZNode(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKClusterId
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
Writables are going away. Use pb HColumnDescriptor.parseFrom(byte[]) instead.
readFields(DataInput) - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
Use protobuf deserialization instead.
readFields(DataInput) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Writables are going away. Use pb HTableDescriptor.parseFrom(byte[]) instead.
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.HTableDescriptor
INTERNAL Used by rest interface to access this metadata attribute which denotes if the table is Read Only
readResponse() - Method in class org.apache.hadoop.hbase.ipc.RpcClientImpl.Connection
 
readTO - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
reconnectAfterExpiration() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
reconnectAfterExpiration() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
RecoverableZooKeeper - Class in org.apache.hadoop.hbase.zookeeper
A zookeeper that can handle 'recoverable' errors.
RecoverableZooKeeper(String, int, Watcher, int, int) - Constructor for class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
RecoverableZooKeeper(String, int, Watcher, int, int, String) - Constructor for class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
recoveringRegionsZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
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.HTableDescriptor
INTERNAL flag to indicate whether or not the memstore should be replicated for read-replicas (CONSISTENCY => TIMELINE).
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.HTableDescriptor
INTERNAL number of region replicas for the table.
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
 
RegionAlreadyInTransitionException - Exception in org.apache.hadoop.hbase.regionserver
This exception is thrown when a region server is asked to open or close a region but it's already processing it
RegionAlreadyInTransitionException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.RegionAlreadyInTransitionException
 
RegionCoprocessorRpcChannel - Class in org.apache.hadoop.hbase.ipc
Provides clients with an RPC connection to call coprocessor endpoint Services against a given table region.
RegionCoprocessorRpcChannel(ClusterConnection, TableName, byte[]) - Constructor for class org.apache.hadoop.hbase.ipc.RegionCoprocessorRpcChannel
 
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
RegionInRecoveryException - Exception in org.apache.hadoop.hbase.exceptions
Thrown when a read request issued against a region which is in recovering state.
RegionInRecoveryException() - Constructor for exception org.apache.hadoop.hbase.exceptions.RegionInRecoveryException
default constructor
RegionInRecoveryException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.RegionInRecoveryException
Constructor
RegionLoad - Class in org.apache.hadoop.hbase
Encapsulates per-region load metrics.
RegionLoad(ClusterStatusProtos.RegionLoad) - Constructor for class org.apache.hadoop.hbase.RegionLoad
 
regionLoadPB - Variable in class org.apache.hadoop.hbase.RegionLoad
 
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.
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.
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
 
RegionOpeningState - Enum in org.apache.hadoop.hbase.regionserver
 
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
 
regionSequenceIdsToByteArray(Long, Map<byte[], Long>) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
 
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> - Class in org.apache.hadoop.hbase.client
Implementations call a RegionServer and implement RetryingCallable.call(int).
RegionServerCallable(Connection, TableName, byte[]) - Constructor for class org.apache.hadoop.hbase.client.RegionServerCallable
 
RegionServerCoprocessorRpcChannel - Class in org.apache.hadoop.hbase.ipc
Provides clients with an RPC connection to call coprocessor endpoint Services against a given region server.
RegionServerCoprocessorRpcChannel(ClusterConnection, ServerName) - Constructor for class org.apache.hadoop.hbase.ipc.RegionServerCoprocessorRpcChannel
 
regionServerRemoved(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationListener
A region server has been removed from the local cluster
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() - Constructor for class org.apache.hadoop.hbase.master.RegionState
 
RegionState(HRegionInfo, RegionState.State) - Constructor for class org.apache.hadoop.hbase.master.RegionState
 
RegionState(HRegionInfo, RegionState.State, ServerName) - Constructor for class org.apache.hadoop.hbase.master.RegionState
 
RegionState(HRegionInfo, RegionState.State, long, ServerName) - Constructor for class org.apache.hadoop.hbase.master.RegionState
 
RegionState.State - Enum in org.apache.hadoop.hbase.master
 
RegionTooBusyException - Exception in org.apache.hadoop.hbase
Thrown by a region server if it will block and wait to serve a request.
RegionTooBusyException() - Constructor for exception org.apache.hadoop.hbase.RegionTooBusyException
default constructor
RegionTooBusyException(String) - Constructor for exception org.apache.hadoop.hbase.RegionTooBusyException
Constructor
RegionTransition - Class in org.apache.hadoop.hbase
Current state of a region in transition.
registerFilter(String, String) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Register a new filter with the parser.
registerListener(ReplicationListener) - Method in interface org.apache.hadoop.hbase.replication.ReplicationTracker
Register a replication listener to receive replication events.
registerListener(ReplicationListener) - Method in class org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl
 
registerListener(ZooKeeperListener) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Register the specified listener to receive ZooKeeper events.
registerListenerFirst(ZooKeeperListener) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Register the specified listener to receive ZooKeeper events and add it as the first in the list of current listeners.
releaseHTableInterface(HTableInterface) - Method in class org.apache.hadoop.hbase.client.HTableFactory
Deprecated.
 
releaseHTableInterface(HTableInterface) - Method in interface org.apache.hadoop.hbase.client.HTableInterfaceFactory
Deprecated.
Release the HTable resource represented by the table.
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.
relocateRegion(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
relocateRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
remainingTime() - Method in class org.apache.hadoop.hbase.ipc.Call
 
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
 
RemoteExceptionHandler - Class in org.apache.hadoop.hbase
An immutable class which contains a static method for handling org.apache.hadoop.ipc.RemoteException exceptions.
remoteId - Variable in class org.apache.hadoop.hbase.ipc.RpcClientImpl.Connection
 
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
 
remove(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Remove metadata represented by the key from the HTableDescriptor.values map
remove(ImmutableBytesWritable) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Remove metadata represented by the key from the HTableDescriptor.values map
remove(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Remove metadata represented by the key from the HTableDescriptor.values 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
 
removeAllQueues() - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
Remove all replication queues for this region server.
removeAllQueues() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
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.
removeConfiguration(String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Remove a configuration setting represented by the key from the HColumnDescriptor.configuration map.
removeConfiguration(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Remove a config setting represented by the key from the HTableDescriptor.configuration map
removeConnection(AsyncRpcChannel) - Method in class org.apache.hadoop.hbase.ipc.AsyncRpcClient
Remove connection from pool
removeCoprocessor(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Remove a coprocessor from those set on the table
removeFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
 
removeFamily(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Removes the HColumnDescriptor with name specified by the parameter column from the table descriptor
removeListener(ReplicationListener) - Method in interface org.apache.hadoop.hbase.replication.ReplicationTracker
 
removeListener(ReplicationListener) - Method in class org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl
 
removeLog(String, String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
Remove an WAL file from the given queue.
removeLog(String, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
removeMetaData(byte[]) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
removeNonDefaultRegions(Collection<HRegionInfo>) - 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
Removes a peer cluster and stops the replication to it.
removePeer(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
Removes a remote slave cluster and stops the replication to it.
removePeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
removePeerTableCFs(String, String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Remove some table-cfs from table-cfs config of the specified peer
removePeerTableCFs(String, Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Remove some table-cfs from config of the specified peer
removeQueue(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
Remove a replication queue.
removeQueue(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
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
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.AbstractClientScanner
Allow the client to renew the scanner's lease on the server.
renewLease() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
REPLICA_ID_DELIMITER - Static variable in class org.apache.hadoop.hbase.HRegionInfo
 
REPLICA_ID_FORMAT - Static variable in class org.apache.hadoop.hbase.HRegionInfo
 
replicaId - Variable in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
REPLICATION_SCOPE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
REPLICATION_SCOPE_BYTES - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
ReplicationAdmin - Class in org.apache.hadoop.hbase.client.replication
This class provides the administrative interface to HBase cluster replication.
ReplicationAdmin(Configuration) - Constructor for class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
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
 
ReplicationFactory - Class in org.apache.hadoop.hbase.replication
A factory class for instantiating replication objects that deal with replication state.
ReplicationFactory() - Constructor for class org.apache.hadoop.hbase.replication.ReplicationFactory
 
REPLICATIONGLOBAL - Static variable in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
 
ReplicationListener - Interface in org.apache.hadoop.hbase.replication
The replication listener interface can be implemented if a class needs to subscribe to events generated by the ReplicationTracker.
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
 
ReplicationPeer - Interface in org.apache.hadoop.hbase.replication
ReplicationPeer manages enabled / disabled state for the peer.
ReplicationPeer.PeerState - Enum in org.apache.hadoop.hbase.replication
State of the peer, whether it is enabled or not
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
 
ReplicationPeers - Interface in org.apache.hadoop.hbase.replication
This provides an interface for maintaining a set of peer clusters.
ReplicationPeersZKImpl - Class in org.apache.hadoop.hbase.replication
This class provides an implementation of the ReplicationPeers interface using Zookeeper.
ReplicationPeersZKImpl(ZooKeeperWatcher, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
ReplicationPeerZKImpl - Class in org.apache.hadoop.hbase.replication
 
ReplicationPeerZKImpl(Configuration, String, ReplicationPeerConfig) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
Constructor that takes all the objects required to communicate with the specified peer, except for the region server addresses.
ReplicationPeerZKImpl(Configuration, String, ReplicationPeerConfig, Map<TableName, List<String>>) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
Constructor that takes all the objects required to communicate with the specified peer, except for the region server addresses.
ReplicationPeerZKImpl.PeerStateTracker - Class in org.apache.hadoop.hbase.replication
Tracker for state of this peer
ReplicationPeerZKImpl.PeerStateTracker(String, ZooKeeperWatcher, Abortable) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl.PeerStateTracker
 
ReplicationPeerZKImpl.TableCFsTracker - Class in org.apache.hadoop.hbase.replication
Tracker for (table, cf-list) map of this peer
ReplicationPeerZKImpl.TableCFsTracker(String, ZooKeeperWatcher, Abortable) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl.TableCFsTracker
 
ReplicationQueueInfo - Class in org.apache.hadoop.hbase.replication
This class is responsible for the parsing logic for a znode representing a queue.
ReplicationQueueInfo(String) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationQueueInfo
The passed znode will be either the id of the peer cluster or the handling story of that queue in the form of id-servername-*
ReplicationQueues - Interface in org.apache.hadoop.hbase.replication
This provides an interface for maintaining a region server's replication queues.
ReplicationQueuesClient - Interface in org.apache.hadoop.hbase.replication
This provides an interface for clients of replication to view replication queues.
ReplicationQueuesClientZKImpl - Class in org.apache.hadoop.hbase.replication
 
ReplicationQueuesClientZKImpl(ZooKeeperWatcher, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationQueuesClientZKImpl
 
ReplicationQueuesZKImpl - Class in org.apache.hadoop.hbase.replication
This class provides an implementation of the ReplicationQueues interface using Zookeeper.
ReplicationQueuesZKImpl(ZooKeeperWatcher, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
ReplicationStateZKBase - Class in org.apache.hadoop.hbase.replication
This is a base class for maintaining replication state in zookeeper.
ReplicationStateZKBase(ZooKeeperWatcher, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
 
ReplicationTracker - Interface in org.apache.hadoop.hbase.replication
This is the interface for a Replication Tracker.
ReplicationTrackerZKImpl - Class in org.apache.hadoop.hbase.replication
This class is a Zookeeper implementation of the ReplicationTracker interface.
ReplicationTrackerZKImpl(ZooKeeperWatcher, ReplicationPeers, Configuration, Abortable, Stoppable) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl
 
ReplicationTrackerZKImpl.OtherRegionServerWatcher - Class in org.apache.hadoop.hbase.replication
Watcher used to be notified of the other region server's death in the local cluster.
ReplicationTrackerZKImpl.OtherRegionServerWatcher(ZooKeeperWatcher) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl.OtherRegionServerWatcher
Construct a ZooKeeper event listener.
ReplicationTrackerZKImpl.PeersWatcher - Class in org.apache.hadoop.hbase.replication
Watcher used to follow the creation and deletion of peer clusters.
ReplicationTrackerZKImpl.PeersWatcher(ZooKeeperWatcher) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl.PeersWatcher
Construct a ZooKeeper event listener.
REPLICATIONTYPE - Static variable in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
 
replicationZNode - Variable in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
The name of the base znode that contains all replication state.
RequestConverter - Class in org.apache.hadoop.hbase.protobuf
Helper utility to build protocol buffer requests, or build components for protocol buffer requests.
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.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.FilterWrapper
 
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.PayloadCarryingRpcController
 
reset() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
 
reset() - Method in class org.apache.hadoop.hbase.ipc.TimeLimitedRpcController
 
ResponseConverter - Class in org.apache.hadoop.hbase.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(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Restore the specified snapshot on the original table.
restoreSnapshot(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Restore the specified snapshot on the original table.
restoreSnapshot(byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Restore the specified snapshot on the original table.
restoreSnapshot(String, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Restore the specified snapshot on the original table.
RestoreSnapshotException - Exception in org.apache.hadoop.hbase.snapshot
Thrown when a snapshot could not be restored due to a server-side error when restoring it.
RestoreSnapshotException(String, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
 
RestoreSnapshotException(String, Throwable, HBaseProtos.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().
Result(KeyValue[]) - Constructor for class org.apache.hadoop.hbase.client.Result
Deprecated.
Use Result.create(List) instead.
Result(List<KeyValue>) - Constructor for class org.apache.hadoop.hbase.client.Result
Deprecated.
Use Result.create(List) instead.
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
RETRIES_BY_SERVER_KEY - Static variable in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated.
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.
RetriesExhaustedException.ThrowableWithExtraContext(Throwable, long, String) - Constructor for class org.apache.hadoop.hbase.client.RetriesExhaustedException.ThrowableWithExtraContext
 
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(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.
RETURN_RESULTS - Static variable in class org.apache.hadoop.hbase.client.Mutation
Deprecated.
this field is private as of HBase 2.0.
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, byte[], RpcControllerFactory) - Constructor for class org.apache.hadoop.hbase.client.ReversedScannerCallable
 
ReversedScannerCallable(ClusterConnection, TableName, Scan, ScanMetrics, byte[], RpcControllerFactory, int) - Constructor for class org.apache.hadoop.hbase.client.ReversedScannerCallable
 
ReversedScannerCallable(ClusterConnection, TableName, Scan, ScanMetrics, byte[]) - Constructor for class org.apache.hadoop.hbase.client.ReversedScannerCallable
revoke(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
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.protobuf.ProtobufUtil
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.protobuf.ProtobufUtil
A utility used to revoke a user's namespace permissions.
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(Configuration, TableName, String, byte[], byte[], Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
revoke(Configuration, String, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
revoke(Configuration, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
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 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 - Variable in class org.apache.hadoop.hbase.client.RegionServerCallable
 
Row - Interface in org.apache.hadoop.hbase.client
Has a row.
rowCount(TableName, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
It gives the row count, by summing up the individual results obtained from regions.
rowCount(Table, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
It gives the row count, by summing up the individual results obtained from regions.
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
Constructor.
RowMutations - Class in org.apache.hadoop.hbase.client
Performs multiple mutations atomically on a single row.
RowMutations() - Constructor for class org.apache.hadoop.hbase.client.RowMutations
Constructor for Writable.
RowMutations(byte[]) - Constructor for class org.apache.hadoop.hbase.client.RowMutations
Create an atomic mutation for the specified row.
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
 
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
RpcClientImpl - Class in org.apache.hadoop.hbase.ipc
Does RPC against a cluster.
RpcClientImpl(Configuration, String, SocketAddress, MetricsConnection) - Constructor for class org.apache.hadoop.hbase.ipc.RpcClientImpl
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
RpcClientImpl.Connection - Class in org.apache.hadoop.hbase.ipc
Thread that reads responses and notifies callers.
rpcControllerFactory - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
rpcControllerFactory - Variable in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
RpcControllerFactory - Class in org.apache.hadoop.hbase.ipc
Factory to create a PayloadCarryingRpcController
RpcControllerFactory(Configuration) - Constructor for class org.apache.hadoop.hbase.ipc.RpcControllerFactory
 
rpcHistograms - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
RpcRetryingCaller<T> - Class in org.apache.hadoop.hbase.client
Runs an rpc'ing RetryingCallable.
RpcRetryingCaller(long, int, int) - Constructor for class org.apache.hadoop.hbase.client.RpcRetryingCaller
 
RpcRetryingCaller(long, int, RetryingCallerInterceptor, int, int) - Constructor for class org.apache.hadoop.hbase.client.RpcRetryingCaller
 
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
 
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) - Constructor for class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
 
rpcTimers - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
RS_LOCK_ZNODE - Static variable in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
Name of znode we use to lock during failover
rsZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
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() - Method in class org.apache.hadoop.hbase.ipc.RpcClientImpl.Connection
 
run(String[]) - Method in class org.apache.hadoop.hbase.zookeeper.ZkAclReset
 
runCatalogScan() - Method in interface org.apache.hadoop.hbase.client.Admin
Ask for a scan of the catalog table
runCatalogScan() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Ask for a scan of the catalog table
runnerStats - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
running - Variable in class org.apache.hadoop.hbase.ipc.RpcClientImpl
 

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
 
SASL_PROPS - Static variable in class org.apache.hadoop.hbase.security.SaslUtil
 
SaslClientHandler - Class in org.apache.hadoop.hbase.security
Handles Sasl connections
SaslClientHandler(UserGroupInformation, AuthMethod, Token<? extends TokenIdentifier>, String, boolean, String, SaslClientHandler.SaslExceptionHandler, SaslClientHandler.SaslSuccessfulConnectHandler) - Constructor for class org.apache.hadoop.hbase.security.SaslClientHandler
Constructor
SaslClientHandler.SaslExceptionHandler - Interface in org.apache.hadoop.hbase.security
Handler for exceptions during Sasl connection
SaslClientHandler.SaslSuccessfulConnectHandler - Interface in org.apache.hadoop.hbase.security
Handler for successful connects
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
saslLatch - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
saslQop - Variable in enum org.apache.hadoop.hbase.security.SaslUtil.QualityOfProtection
 
SaslStatus - Enum in org.apache.hadoop.hbase.security
 
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
 
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
 
Scan(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Scan
Create a Scan operation starting at the specified row.
Scan(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.client.Scan
Create a Scan operation for the range of rows specified.
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_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
 
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
 
scannerCaching - Variable in class org.apache.hadoop.hbase.client.HTable
 
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
 
scannerMaxResultSize - Variable in class org.apache.hadoop.hbase.client.HTable
 
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
 
ScannerTimeoutException - Exception in org.apache.hadoop.hbase.client
Thrown when a scanner has timed out.
scanTracker - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
SecureBulkLoadClient - Class in org.apache.hadoop.hbase.client.coprocessor
Client proxy for SecureBulkLoadProtocol used in conjunction with SecureBulkLoadEndpoint
SecureBulkLoadClient(Table) - Constructor for class org.apache.hadoop.hbase.client.coprocessor.SecureBulkLoadClient
 
SecureBulkLoadUtil - Class in org.apache.hadoop.hbase.security
 
SecureBulkLoadUtil() - Constructor for class org.apache.hadoop.hbase.security.SecureBulkLoadUtil
 
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
 
serverHasMoreResults - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
serverHasMoreResultsContext - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
ServerLoad - Class in org.apache.hadoop.hbase
This class is used for exporting current state of load on a RegionServer.
ServerLoad(ClusterStatusProtos.ServerLoad) - Constructor for class org.apache.hadoop.hbase.ServerLoad
 
serverLoad - Variable in class org.apache.hadoop.hbase.ServerLoad
 
ServerName - Class in org.apache.hadoop.hbase
Instance of an HBase ServerName.
SERVERNAME_PATTERN - Static variable in class org.apache.hadoop.hbase.ServerName
 
SERVERNAME_SEPARATOR - Static variable in class org.apache.hadoop.hbase.ServerName
This character is used as separator between server hostname, port and startcode.
ServerNotRunningYetException - Exception in org.apache.hadoop.hbase.ipc
 
ServerNotRunningYetException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.ServerNotRunningYetException
 
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
 
ServerStatistics.RegionStatistics() - Constructor for class org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
 
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
 
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
 
setAcl(String, List<ACL>, int) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
setAcl is an idempotent operation.
setAllowPartialResults(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
Setting whether the caller wants to see the partial results that may be returned from the server.
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.
setAutoFlush(boolean) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
setAutoFlush(boolean, boolean) - Method in class org.apache.hadoop.hbase.client.HTable
Turns 'auto-flush' on or off.
setAutoFlush(boolean) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Deprecated.
in 0.96. When called with setAutoFlush(false), this function also set clearBufferOnFail to true, which is unexpected but kept for historical reasons. Replace it with setAutoFlush(false, false) if this is exactly what you want, though this is the method you want for most cases.
setAutoFlush(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Deprecated.
in 0.99 since setting clearBufferOnFail is deprecated. Use HTableInterface.setAutoFlush(boolean)} instead.
setAutoFlushTo(boolean) - Method in class org.apache.hadoop.hbase.client.HTable
Set the autoFlush behavior, without changing the value of clearBufferOnFail.
setAutoFlushTo(boolean) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Deprecated.
in 0.99 since setting clearBufferOnFail is deprecated. Use HTableInterface.setAutoFlush(boolean) instead, or better still, move on to BufferedMutator
setBalancerRunning(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Turn the load balancer on or off.
setBalancerRunning(boolean, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Turn the load balancer on or off.
setBatch(int) - Method in class org.apache.hadoop.hbase.client.Scan
Set the maximum number of values to return for each call to next().
setBlockCacheEnabled(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setBlocksize(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setBloomFilterType(BloomType) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
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.HColumnDescriptor
 
setCacheDataInL1(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setCacheDataOnWrite(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setCacheIndexesOnWrite(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
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.TimeLimitedRpcController
 
setCellScanner(CellScanner) - Method in class org.apache.hadoop.hbase.ipc.DelegatingPayloadCarryingRpcController
 
setCellScanner(CellScanner) - Method in class org.apache.hadoop.hbase.ipc.PayloadCarryingRpcController
 
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
 
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
 
setClusterId(ZooKeeperWatcher, ClusterId) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKClusterId
 
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
Set the clusterKey which is the concatenation of the slave cluster's: hbase.zookeeper.quorum:hbase.zookeeper.property.clientPort:zookeeper.znode.parent
setColumnFamilyTimeRange(byte[], long, long) - Method in class org.apache.hadoop.hbase.client.Get
 
setColumnFamilyTimeRange(byte[], long, long) - Method in class org.apache.hadoop.hbase.client.Query
Get versions of columns only within the specified timestamp range, [minStamp, maxStamp) on a per CF bases.
setColumnFamilyTimeRange(byte[], long, long) - Method in class org.apache.hadoop.hbase.client.Scan
 
setCompactionCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Compression types supported in hbase.
setCompactionEnabled(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Setting the table compaction enable flag.
setCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Compression types supported in hbase.
setCompressTags(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Set whether the tags should be compressed along with DataBlockEncoding.
setConfiguration(String, String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Setter for storing a configuration setting in HColumnDescriptor.configuration map.
setConfiguration(String, String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Setter for storing a configuration setting in HTableDescriptor.configuration map.
setConsistency(Consistency) - Method in class org.apache.hadoop.hbase.client.Get
 
setConsistency(Consistency) - Method in class org.apache.hadoop.hbase.client.Query
Sets the consistency level for this operation
setConsistency(Consistency) - Method in class org.apache.hadoop.hbase.client.Scan
 
setControllerException(RpcController, IOException) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Stores an exception encountered during RPC invocation so it can be passed back through to the client.
setCounter(String, long) - Method in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
 
setData(String, byte[], int) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
setData is NOT an idempotent operation.
setData(ZooKeeperWatcher, String, byte[], int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Sets the data of the existing znode to be the specified data.
setData(ZooKeeperWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Sets the data of the existing znode to be the specified data.
setData(String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
 
setDataBlockEncoding(DataBlockEncoding) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Set data block encoding algorithm used in block cache.
setDFSReplication(short) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Set the replication factor to hfile(s) belonging to this family
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.HTableDescriptor
Sets the Durability setting for the table.
setEncodeOnDisk(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 0.98 (HBASE-9870). This will be removed in HBase 2.0.0. This method does nothing now.
setEncryptionKey(byte[]) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Set the raw crypto key attribute for the family
setEncryptionType(String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Set the encryption algorithm for use with this family
setEvictBlocksOnClose(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setException(IOException) - Method in class org.apache.hadoop.hbase.ipc.Call
Set the exception when there is an error.
setExists(Boolean) - Method in class org.apache.hadoop.hbase.client.Result
 
setFailed(IOException) - Method in class org.apache.hadoop.hbase.ipc.AsyncCall
Set failed
setFailed(String) - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
 
setFailed(String) - Method in class org.apache.hadoop.hbase.ipc.TimeLimitedRpcController
 
setFailed(IOException) - Method in class org.apache.hadoop.hbase.ipc.TimeLimitedRpcController
Set failed with an exception to pass on.
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
 
setFamilyCellMap(NavigableMap<byte[], List<Cell>>) - Method in class org.apache.hadoop.hbase.client.Delete
 
setFamilyCellMap(NavigableMap<byte[], List<Cell>>) - Method in class org.apache.hadoop.hbase.client.Increment
 
setFamilyCellMap(NavigableMap<byte[], List<Cell>>) - Method in class org.apache.hadoop.hbase.client.Mutation
Method for setting the put's familyMap
setFamilyCellMap(NavigableMap<byte[], List<Cell>>) - Method in class org.apache.hadoop.hbase.client.Put
 
setFamilyMap(NavigableMap<byte[], List<KeyValue>>) - Method in class org.apache.hadoop.hbase.client.Append
Deprecated.
setFamilyMap(NavigableMap<byte[], List<KeyValue>>) - Method in class org.apache.hadoop.hbase.client.Delete
Deprecated.
setFamilyMap(NavigableMap<byte[], List<KeyValue>>) - Method in class org.apache.hadoop.hbase.client.Increment
Deprecated.
setFamilyMap(NavigableMap<byte[], List<KeyValue>>) - Method in class org.apache.hadoop.hbase.client.Mutation
Deprecated.
setFamilyMap(NavigableMap<byte[], List<KeyValue>>) - Method in class org.apache.hadoop.hbase.client.Put
Deprecated.
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
 
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.HTableDescriptor
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
 
setHasMoreResultsContext(boolean) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
setHeartbeatMessage(boolean) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
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
 
setInMemory(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
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
 
setKeepDeletedCells(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 1.0.0 (HBASE-12363). This will be removed in HBase 2.0.0. Use HColumnDescriptor.setKeepDeletedCells(KeepDeletedCells).
setKeepDeletedCells(KeepDeletedCells) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setLatestVersionOnly(boolean) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Set whether only the latest version of the column value should be compared.
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
 
setLogPosition(String, String, long) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
Set the current position for a specific WAL in a given queue.
setLogPosition(String, String, long) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
setMasterAddress(ZooKeeperWatcher, String, ServerName, int) - Static method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
Set master address into the master znode or into the backup subdirectory of backup masters; switch off the passed in znode path.
setMaxFileSize(long) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
 
setMaxFileSize(long) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Sets the maximum size upto which a region can grow to after which a region split is triggered.
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
setMaxVersions() - Method in class org.apache.hadoop.hbase.client.Get
Get all available versions.
setMaxVersions(int) - Method in class org.apache.hadoop.hbase.client.Get
Get up to the specified number of versions of each column.
setMaxVersions() - Method in class org.apache.hadoop.hbase.client.Scan
Get all available versions.
setMaxVersions(int) - Method in class org.apache.hadoop.hbase.client.Scan
Get up to the specified number of versions of each column.
setMaxVersions(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setMemStoreFlushSize(long) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
 
setMemStoreFlushSize(long) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Represents the maximum size of the memstore after which the contents of the memstore are flushed to the filesystem.
setMetaLocation(ZooKeeperWatcher, ServerName, RegionState.State) - Static method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Sets the location of hbase:meta in ZooKeeper to the specified server address.
setMetaLocation(ZooKeeperWatcher, ServerName, int, RegionState.State) - Static method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Sets the location of hbase:meta in ZooKeeper to the specified server address.
setMetaRegion(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Used to denote if the current table represents -ROOT- or hbase:meta region.
setMinVersions(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setName(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
setName(TableName) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
setNamespaceFilter(String) - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
Set the namespace filter regex
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.HTableDescriptor
Setting the table normalization enable flag.
setNormalizerRunning(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Turn region normalizer on or off.
setNormalizerRunning(boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Turn region normalizer on or off.
setOffline(boolean) - Method in class org.apache.hadoop.hbase.HRegionInfo
The parent of a region split is offline while split daughters hold references to the parent.
setOperationTimeout(int) - Method in class org.apache.hadoop.hbase.client.HTable
 
setOwner(User) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
setOwnerString(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
setPeerTableCFs(String, String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
setPeerTableCFs(String, Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Set the replicable table-cf config of the specified peer
setPeerTableCFsConfig(String, String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
Set the table and column-family list string of the peer to ZK.
setPeerTableCFsConfig(String, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
setPrefetchBlocksOnOpen(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setPriority(int) - Method in class org.apache.hadoop.hbase.ipc.DelegatingPayloadCarryingRpcController
 
setPriority(TableName) - Method in class org.apache.hadoop.hbase.ipc.DelegatingPayloadCarryingRpcController
 
setPriority(int) - Method in class org.apache.hadoop.hbase.ipc.PayloadCarryingRpcController
 
setPriority(TableName) - Method in class org.apache.hadoop.hbase.ipc.PayloadCarryingRpcController
 
setQuota(QuotaSettings) - Method in interface org.apache.hadoop.hbase.client.Admin
Apply the new quota settings.
setQuota(QuotaSettings) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Apply the new quota settings.
setRaw(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
Enable/disable "raw" mode for this scan.
setReadOnly(boolean) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
 
setReadOnly(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Setting the table as read only sets all the columns in the table as read only.
setRegionCachePrefetch(TableName, boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
does nothing since since 0.99
setRegionCachePrefetch(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
does nothing since 0.99
setRegionCachePrefetch(byte[], boolean) - Static method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
does nothing since 0.99
setRegionCachePrefetch(TableName, boolean) - Static method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
does nothing since 0.99
setRegionCachePrefetch(Configuration, byte[], boolean) - Static method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
does nothing since 0.99
setRegionCachePrefetch(Configuration, TableName, boolean) - Static method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
does nothing since 0.99
setRegionMemstoreReplication(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Enable or Disable the memstore replication from the primary region to the replicas.
setRegionReplication(int) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Sets the number of replicas per region.
setRegionSplitPolicyClassName(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
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.Scan
 
setReplicationEndpointImpl(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
Sets the ReplicationEndpoint plugin class for this peer.
setRequestSizeBytes(long) - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
setResponse(Message, CellScanner) - Method in class org.apache.hadoop.hbase.ipc.Call
Set the return value when there is no error.
setResponseSizeBytes(long) - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
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
 
setRootRegion(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Used to denote if the current table represents -ROOT- region.
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.
setRpcTimeout(int) - Method in class org.apache.hadoop.hbase.client.HTable
 
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.
setScannerCaching(int) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
setScannerCallableFactory(ClientSmallReversedScanner.SmallReversedScannerCallableFactory) - Method in class org.apache.hadoop.hbase.client.ClientSmallReversedScanner
 
setScannerCallableFactory(ClientSmallScanner.SmallScannerCallableFactory) - Method in class org.apache.hadoop.hbase.client.ClientSmallScanner
 
setScope(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setServerHasMoreResults(boolean) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
setServerSideHConnectionRetries(Configuration, String, Log) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated.
Internal method, do not use.
setServerSideHConnectionRetriesConfig(Configuration, String, Log) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
Changes the configuration to set the number of retries needed when using HConnection internally, e.g.
setSmall(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
Set whether this scan is a small scan
setSplit(boolean) - Method in class org.apache.hadoop.hbase.HRegionInfo
 
setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
Set the start row of the scan.
setStartTime(long) - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
setStatistics(ClientProtos.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
Set the stop row.
setStub(AdminProtos.AdminService.BlockingInterface) - Method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
setSuccess(Message, CellScanner) - Method in class org.apache.hadoop.hbase.ipc.AsyncCall
Set success with a cellBlockScanner
setTableFilter(String) - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
Set the table filter regex
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.Delete
Set the timestamp of the delete.
setTimeStamp(long) - Method in class org.apache.hadoop.hbase.client.Get
Get versions of columns with the specified timestamp.
setTimeStamp(long) - Method in class org.apache.hadoop.hbase.client.Scan
Get versions of columns with the specified timestamp.
setTimestamp(long) - Method in class org.apache.hadoop.hbase.master.RegionState
 
setTimeToLive(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
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
 
setupConnection() - Method in class org.apache.hadoop.hbase.ipc.RpcClientImpl.Connection
 
setupIOstreams() - Method in class org.apache.hadoop.hbase.ipc.RpcClientImpl.Connection
 
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.
setupSetQuotaRequest(MasterProtos.SetQuotaRequest.Builder) - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
Deprecated.
Removed in HBase 2.0+ as a part of removing protobuf from our API
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.UnmodifyableHTableDescriptor
 
setValue(String, String) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
 
setValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setValue(String, String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Setter for storing metadata as a (key, value) pair in HTableDescriptor.values map
setValue(ImmutableBytesWritable, ImmutableBytesWritable) - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
setValue(String, String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Setter for storing metadata as a (key, value) pair in HTableDescriptor.values map
setVersions(int, int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Set minimum and maximum versions to keep
setWatchIfNodeExists(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Watch the specified znode, but only if exists.
setWriteBufferSize(long) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
Deprecated.
Going away when we drop public support for HTableInterface.
setWriteBufferSize(long) - Method in class org.apache.hadoop.hbase.client.HTable
Sets the size of the buffer in bytes.
setWriteBufferSize(long) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Deprecated.
setWriteBufferSize(long) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
as of 1.0.1 (should not have been in 1.0.0). Replaced by BufferedMutator and BufferedMutatorParams.writeBufferSize(long)
setWriteToWAL(boolean) - Method in class org.apache.hadoop.hbase.client.Append
Deprecated.
setWriteToWAL(boolean) - Method in class org.apache.hadoop.hbase.client.Delete
Deprecated.
setWriteToWAL(boolean) - Method in class org.apache.hadoop.hbase.client.Increment
Deprecated.
setWriteToWAL(boolean) - Method in class org.apache.hadoop.hbase.client.Mutation
Deprecated.
setWriteToWAL(boolean) - Method in class org.apache.hadoop.hbase.client.Put
Deprecated.
shouldCacheBloomsOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 1.0.0 (HBASE-10870). This will be removed in HBase 2.0.0. Use HColumnDescriptor.isCacheBloomsOnWrite()} instead.
shouldCacheDataInL1() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 1.0.0 (HBASE-10870). This will be removed in HBase 2.0.0. Use HColumnDescriptor.isCacheDataInL1()} instead.
shouldCacheDataOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 1.0.0 (HBASE-10870). This will be removed in HBase 2.0.0. Use HColumnDescriptor.isCacheDataOnWrite()} instead.
shouldCacheIndexesOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 1.0.0 (HBASE-10870). This will be removed in HBase 2.0.0. Use HColumnDescriptor.isCacheIndexesOnWrite() instead.
shouldCloseConnection - Variable in class org.apache.hadoop.hbase.ipc.RpcClientImpl.Connection
 
shouldCompressTags() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 1.0.0 (HBASE-10870). This will be removed in HBase 2.0.0. Use HColumnDescriptor.isCompressTags() instead.
shouldEvictBlocksOnClose() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 1.0.0 (HBASE-10870). This will be removed in HBase 2.0.0. Use HColumnDescriptor.isEvictBlocksOnClose()} instead.
shouldPrefetchBlocksOnOpen() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 1.0.0 (HBASE-10870). This will be removed in HBase 2.0.0. Use HColumnDescriptor.isPrefetchBlocksOnOpen()}} instead.
shutdown() - Method in interface org.apache.hadoop.hbase.client.Admin
Shuts down the HBase cluster
shutdown() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Shuts down the HBase cluster
shutdown() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
 
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
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
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
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
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
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
Constructor for protobuf deserialization only.
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 class org.apache.hadoop.hbase.RegionLocations
Returns the size of the list even if some of the elements might be null.
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
 
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.DelegatingRetryingCallable
 
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
public void snapshot(final String snapshotName, Create a timestamp consistent snapshot for the given table.
snapshot(String, TableName, HBaseProtos.SnapshotDescription.Type) - Method in interface org.apache.hadoop.hbase.client.Admin
Create typed snapshot of the table.
snapshot(HBaseProtos.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 class org.apache.hadoop.hbase.client.HBaseAdmin
Take a snapshot for the given table.
snapshot(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
snapshot(byte[], byte[], HBaseProtos.SnapshotDescription.Type) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Create snapshot for the given table of given flush type.
snapshot(byte[], TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
public void snapshot(final String snapshotName, Create a timestamp consistent snapshot for the given table.
snapshot(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
snapshot(String, TableName, HBaseProtos.SnapshotDescription.Type) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Create typed snapshot of the table.
snapshot(String, String, HBaseProtos.SnapshotDescription.Type) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
snapshot(String, byte[], HBaseProtos.SnapshotDescription.Type) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
snapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Take a snapshot and wait for the server to complete that snapshot (blocking).
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, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotCreationException
Failure to create the specified snapshot
SnapshotCreationException(String, Throwable, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotCreationException
Failure to create the specified snapshot due to an external cause
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(HBaseProtos.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, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotExistsException
Failure due to the snapshot already existing
socket - Variable in class org.apache.hadoop.hbase.ipc.RpcClientImpl.Connection
 
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.RpcClientImpl
 
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
 
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 class org.apache.hadoop.hbase.client.HBaseAdmin
Split a table.
split(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
split(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
split(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Split a table.
split(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
split(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
split(ServerName, HRegionInfo, byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
split(RpcController, AdminProtos.AdminService.BlockingInterface, HRegionInfo, byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to split a region using admin protocol.
SPLIT_POLICY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
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.ZooKeeperWatcher
 
splitRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Split an individual region.
splitRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Split an individual region.
splitRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Split an individual region.
splitRegion(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Split an individual region.
splitRegion(Connection, HRegionInfo, HRegionInfo, HRegionInfo, ServerName, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Splits the region into two in an atomic operation.
stampSet - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
start(CoprocessorEnvironment) - Method in interface org.apache.hadoop.hbase.Coprocessor
 
start() - Method in class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
Deprecated.
 
start() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
Starts the tracking of the node in ZooKeeper.
startCancel() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
 
startCancel() - Method in class org.apache.hadoop.hbase.ipc.TimeLimitedRpcController
 
startStateTracker(ZooKeeperWatcher, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
start a state tracker to check whether this peer is enabled or not
startTableCFsTracker(ZooKeeperWatcher, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
start a table-cfs tracker to listen the (table, cf-list) map change
state - Variable in enum org.apache.hadoop.hbase.security.SaslStatus
 
StatsTrackingRpcRetryingCaller<T> - Class in org.apache.hadoop.hbase.client
An RpcRetryingCaller that will update the per-region stats for the call on return, if stats are available
StatsTrackingRpcRetryingCaller(long, int, int, ServerStatisticTracker) - Constructor for class org.apache.hadoop.hbase.client.StatsTrackingRpcRetryingCaller
 
StatsTrackingRpcRetryingCaller(long, int, RetryingCallerInterceptor, int, ServerStatisticTracker) - Constructor for class org.apache.hadoop.hbase.client.StatsTrackingRpcRetryingCaller
 
std(TableName, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
This is the client side interface/handle for calling the std method for a given cf-cq combination.
std(Table, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
This is the client side interface/handle for calling the std method for a given cf-cq combination.
stepDownAsLeader() - Method in class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
Deprecated.
Removes the leader znode, if it is currently claimed by this instance.
stop(CoprocessorEnvironment) - Method in interface org.apache.hadoop.hbase.Coprocessor
 
stop() - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Stop working.
stop() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
 
stopMaster() - Method in interface org.apache.hadoop.hbase.client.Admin
Shuts down the current HBase master only.
stopMaster() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Shuts down the current HBase master only.
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(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Stop the designated regionserver
stub - Variable in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
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(TableName, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
It sums up the value returned from various regions.
sum(Table, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
It sums up the value returned from various regions.
sumOfMillisSecBetweenNexts - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
sum of milliseconds between sequential next calls
SWITCH_TO_SIMPLE_AUTH - Static variable in class org.apache.hadoop.hbase.security.SaslUtil
 
sync(String, AsyncCallback.VoidCallback, Object) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
sync(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Forces a synchronization of this ZooKeeper client connection.

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_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
 
tableExists(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
 
tableExists(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
tableExists(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
tableExists(String) - 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
 
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.ZooKeeperWatcher
 
tableName - Variable in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
tableName - Variable in class org.apache.hadoop.hbase.client.RegionServerCallable
 
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.
tableZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
take() - Method in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService
 
takeSnapshotAsync(HBaseProtos.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.
takeSnapshotAsync(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Take a snapshot without waiting for the server to complete that snapshot (asynchronous)
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
 
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
Describe the throttling result.
ThrottlingException(String) - Constructor for exception org.apache.hadoop.hbase.quotas.ThrottlingException
 
ThrottlingException(ThrottlingException.Type, long, String) - Constructor for exception org.apache.hadoop.hbase.quotas.ThrottlingException
 
ThrottlingException.Type - Enum in org.apache.hadoop.hbase.quotas
 
throwable(Throwable, boolean) - Method in class org.apache.hadoop.hbase.client.DelegatingRetryingCallable
 
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 RetryingCallable.call(int) 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.).
throwInterruptedException() - Method in interface org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture.WaitForStateCallable
 
throwNumReadRequestsExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.ThrottlingException
 
throwNumRequestsExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.ThrottlingException
 
throwNumWriteRequestsExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.ThrottlingException
 
throwReadSizeExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.ThrottlingException
 
throwRequestSizeExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.ThrottlingException
 
throwTimeoutException(long) - Method in interface org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture.WaitForStateCallable
 
throwWriteSizeExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.ThrottlingException
 
timeBeforeReplicas - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
 
TimeLimitedRpcController - Class in org.apache.hadoop.hbase.ipc
 
TimeLimitedRpcController() - Constructor for class org.apache.hadoop.hbase.ipc.TimeLimitedRpcController
 
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 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
 
toAppend(ClientProtos.MutationProto, CellScanner) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Mutate to an Append
toAuthorizations(ClientProtos.Authorizations) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Authorizations to a client Authorizations
toAuthorizations(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Authorizations bytes to a client Authorizations
toAuthorizations(Authorizations) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Create a protocol buffer Authorizations based on a client Authorizations.
toBulkLoadDescriptor(TableName, ByteString, Map<byte[], List<Path>>, long) - Static method in class org.apache.hadoop.hbase.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() - Method in class org.apache.hadoop.hbase.ClusterId
 
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.ByteArrayComparable
 
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.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.FilterWrapper
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
 
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
 
toByteArray() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
toByteArray() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
toByteArray() - Method in class org.apache.hadoop.hbase.RegionTransition
 
toByteArray(ZooKeeperProtos.ReplicationState.State) - Static method in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
 
toBytes() - Method in enum org.apache.hadoop.hbase.client.IsolationLevel
 
toBytes() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
toCell(Cell) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toCell(CellProtos.Cell) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toCellVisibility(ClientProtos.CellVisibility) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer CellVisibility to a client CellVisibility
toCellVisibility(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer CellVisibility bytes to a client CellVisibility
toCellVisibility(CellVisibility) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Create a protocol buffer CellVisibility based on a client CellVisibility.
toCompactionDescriptor(HRegionInfo, byte[], List<Path>, List<Path>, Path) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toCompactionDescriptor(HRegionInfo, byte[], byte[], List<Path>, List<Path>, Path) - Static method in class org.apache.hadoop.hbase.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
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
 
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
toDeleteType(KeyValue.Type) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a delete KeyValue type to protocol buffer DeleteType.
toDelimitedByteArray() - Method in class org.apache.hadoop.hbase.HRegionInfo
Use this instead of HRegionInfo.toByteArray() 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(HRegionInfo...) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Serializes given HRegionInfo's as a byte array.
toDelimitedByteArray(Message) - Static method in class org.apache.hadoop.hbase.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
toException(HBaseProtos.NameBytesPair) - Static method in class org.apache.hadoop.hbase.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
toFlushDescriptor(WALProtos.FlushDescriptor.FlushAction, HRegionInfo, long, Map<byte[], List<Path>>) - Static method in class org.apache.hadoop.hbase.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(Get) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Create a protocol buffer Get based on a client Get.
toIncrement(ClientProtos.MutationProto, CellScanner) - Static method in class org.apache.hadoop.hbase.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.
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.
tokenHandlers - Static variable in class org.apache.hadoop.hbase.ipc.AsyncRpcChannel
 
tokenHandlers - Static variable in class org.apache.hadoop.hbase.ipc.RpcClientImpl
 
TokenUtil - Class in org.apache.hadoop.hbase.security.token
Utility methods for obtaining authentication tokens.
TokenUtil() - Constructor for class org.apache.hadoop.hbase.security.token.TokenUtil
 
toMap(int) - Method in class org.apache.hadoop.hbase.client.Delete
 
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(Increment, ClientProtos.MutationProto.Builder, long) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client Increment to a protobuf Mutate.
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
 
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
 
toNamespaceDescriptor(HBaseProtos.NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toPermission(AccessControlProtos.Permission) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Converts a Permission proto to a client Permission object.
toPermission(Permission) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client Permission to a Permission proto
toPermissionAction(AccessControlProtos.Permission.Action) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Converts a Permission.Action proto to a client Permission.Action object.
toPermissionAction(Permission.Action) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client Permission.Action to a Permission.Action proto
toPermissionActions(List<AccessControlProtos.Permission.Action>) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Converts a list of Permission.Action proto to a list of client Permission.Action objects.
toProtoNamespaceDescriptor(NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toProtoQuotaScope(QuotaScope) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client QuotaScope to a protocol buffer QuotaScope
toProtoQuotaScope(QuotaType) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client QuotaType to a protocol buffer QuotaType
toProtoTableName(TableName) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toProtoThrottleType(ThrottleType) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client ThrottleType to a protocol buffer ThrottleType
toProtoTimeUnit(TimeUnit) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client TimeUnit to a protocol buffer TimeUnit
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.
toQuotaScope(QuotaProtos.QuotaScope) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer QuotaScope to a client QuotaScope
toQuotaScope(QuotaProtos.QuotaType) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer QuotaType to a client QuotaType
toRegionEventDescriptor(WALProtos.RegionEventDescriptor.EventType, HRegionInfo, long, ServerName, Map<byte[], List<Path>>) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toRegionEventDescriptor(WALProtos.RegionEventDescriptor.EventType, byte[], byte[], byte[], long, ServerName, Map<byte[], List<Path>>) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toReplicationLoadSink(ClusterStatusProtos.ReplicationLoadSink) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toReplicationLoadSource(ClusterStatusProtos.ReplicationLoadSource) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toReplicationLoadSourceList(List<ClusterStatusProtos.ReplicationLoadSource>) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
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
toResultNoData(Result) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client Result to a protocol buffer Result.
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
toScanMetrics(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toScanMetrics(ScanMetrics) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toSecurityCapabilityList(List<MasterProtos.SecurityCapabilitiesResponse.Capability>) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert SecurityCapabilitiesResponse.Capability to SecurityCapability
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
toShortString() - Method in class org.apache.hadoop.hbase.ServerName
 
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.Result
 
toString() - Method in class org.apache.hadoop.hbase.client.RetriesExhaustedException.ThrowableWithExtraContext
 
toString() - Method in class org.apache.hadoop.hbase.client.RpcRetryingCaller
 
toString() - Method in class org.apache.hadoop.hbase.ClusterId
 
toString() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
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.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(int) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
toString() - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
toString(int) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
 
toString(int) - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
toString() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
toString() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
toString() - Method in class org.apache.hadoop.hbase.HRegionLocation
 
toString() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
toString() - Method in class org.apache.hadoop.hbase.ipc.AsyncCall
 
toString() - Method in class org.apache.hadoop.hbase.ipc.AsyncRpcChannel
 
toString() - Method in class org.apache.hadoop.hbase.ipc.Call
 
toString() - Method in class org.apache.hadoop.hbase.ipc.ConnectionId
 
toString() - Method in class org.apache.hadoop.hbase.master.RegionState
 
toString() - Method in class org.apache.hadoop.hbase.RegionLoad
 
toString() - Method in class org.apache.hadoop.hbase.RegionLocations
 
toString() - Method in class org.apache.hadoop.hbase.RegionTransition
 
toString() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
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
 
toString() - Method in class org.apache.hadoop.hbase.ServerName
 
toString(HBaseProtos.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.ZKUtil.NodeAndData
Deprecated.
 
toString() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
 
toString() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
toStringCustomizedValues() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
toStringCustomizedValues() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
toStringTableAttributes() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
toTableName(HBaseProtos.TableName) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toTablePermission(AccessControlProtos.Permission) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Converts a Permission proto to a client TablePermission object.
toThrottleType(QuotaProtos.ThrottleType) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer ThrottleType to a client ThrottleType
toTimedQuota(long, TimeUnit, QuotaScope) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Build a protocol buffer TimedQuota
toTimeUnit(HBaseProtos.TimeUnit) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer TimeUnit to a client TimeUnit
toToken(Token<AuthenticationTokenIdentifier>) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Converts a Token instance (with embedded identifier) to the protobuf representation.
toToken(AuthenticationProtos.Token) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Converts a protobuf Token message back into a Token instance.
toUserPermission(UserPermission) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client user permission to a user permission proto
toUserPermission(AccessControlProtos.UserPermission) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Converts a user permission proto to a client user permission object.
toUsersAndPermissions(String, Permission) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toUsersAndPermissions(ListMultimap<String, Permission>) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toUsersAndPermissions(AccessControlProtos.UsersAndPermissions) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toUserTablePermissions(ListMultimap<String, TablePermission>) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a ListMultimap<String, TablePermission> where key is username to a protobuf UserPermission
toUserTablePermissions(AccessControlProtos.UsersAndPermissions) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protobuf UserTablePermissions to a ListMultimap<String, TablePermission> where key is username.
tracedWriteRequest(Call, int, Span) - Method in class org.apache.hadoop.hbase.ipc.RpcClientImpl.Connection
 
transform(KeyValue) - Method in class org.apache.hadoop.hbase.filter.Filter
Deprecated.
transform(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterBase
Deprecated.
transform(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterList
Deprecated.
transform(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
Deprecated.
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
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.FilterWrapper
 
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
 
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
transitionNode(ZooKeeperWatcher, HRegionInfo, ServerName, EventType, EventType, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Method that actually performs unassigned node transitions.
transitionNode(ZooKeeperWatcher, HRegionInfo, ServerName, EventType, EventType, int, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
 
transitionNodeClosed(ZooKeeperWatcher, HRegionInfo, ServerName, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Transitions an existing unassigned node for the specified region which is currently in the CLOSING state to be in the CLOSED state.
transitionNodeOpened(ZooKeeperWatcher, HRegionInfo, ServerName, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Transitions an existing unassigned node for the specified region which is currently in the OPENING state to be in the OPENED state.
transitionNodeOpening(ZooKeeperWatcher, HRegionInfo, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Transitions an existing unassigned node for the specified region which is currently in the OFFLINE state to be in the OPENING state.
transitionNodeOpening(ZooKeeperWatcher, HRegionInfo, ServerName, EventType) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
 
truncateTable(TableName, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Truncate a table.
truncateTable(TableName, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Truncate a table.
ts - Variable in class org.apache.hadoop.hbase.client.Mutation
 
TTL - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 

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 class org.apache.hadoop.hbase.client.HBaseAdmin
Unassign a region from current hosting regionserver.
UNKNOWN_SERVERNAME - Static variable in class org.apache.hadoop.hbase.ServerName
What to use if server name is unknown.
UnknownProtocolException - Exception in org.apache.hadoop.hbase.exceptions
An error requesting an RPC protocol that the server is not serving.
UnknownProtocolException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.UnknownProtocolException
 
UnknownProtocolException(Class<?>) - Constructor for exception org.apache.hadoop.hbase.exceptions.UnknownProtocolException
 
UnknownProtocolException(Class<?>, String) - Constructor for exception org.apache.hadoop.hbase.exceptions.UnknownProtocolException
 
UnknownRegionException - Exception in org.apache.hadoop.hbase
Thrown when we are asked to operate on a region we know nothing about.
UnknownRegionException(String) - Constructor for exception org.apache.hadoop.hbase.UnknownRegionException
 
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
 
UnmodifyableHTableDescriptor - Class in org.apache.hadoop.hbase.client
Read-only table descriptor.
UnmodifyableHTableDescriptor() - Constructor for class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
Default constructor
unregisterAllListeners() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Clean all existing listeners
unregisterListener(ZooKeeperListener) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
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
 
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.
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(ClientProtos.RegionLoadStats) - Method in class org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
 
update(byte[], ClientProtos.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(ClientProtos.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.
updateCachedLocations(TableName, byte[], Object, HRegionLocation) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
updateCachedLocations(TableName, byte[], byte[], Object, ServerName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
updateCachedLocations(byte[], byte[], Object, HRegionLocation) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
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 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.
updateExistingNodeData(ZooKeeperWatcher, String, byte[], int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Deprecated.
Unused
updateLastCellLoadedToCache(Result) - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
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.
updateRegionLocation(Connection, HRegionInfo, 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[], ClientProtos.RegionLoadStats) - Method in class org.apache.hadoop.hbase.client.ServerStatisticTracker
 
updateResultsMetrics(Result[]) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
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(T, ServerStatisticTracker, HRegionLocation) - Static method in class org.apache.hadoop.hbase.client.ResultStatsUtil
 
updateTimestampToNow() - Method in class org.apache.hadoop.hbase.master.RegionState
 
USE_GLOBAL_EVENT_LOOP_GROUP - Static variable in class org.apache.hadoop.hbase.ipc.AsyncRpcClient
 
USE_NATIVE_TRANSPORT - Static variable in class org.apache.hadoop.hbase.ipc.AsyncRpcClient
 
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.BufferedMutatorImpl
 
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
Constructor.
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.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.Coprocessor.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.executor.EventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.executor.ExecutorType
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
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.FilterWrapper.FilterRowRetCode
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.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.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
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.regionserver.RegionOpeningState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.replication.ReplicationPeer.PeerState
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, int, long) - Static method in class org.apache.hadoop.hbase.ServerName
Retrieve an instance of ServerName.
valueOf(String) - Static method in class org.apache.hadoop.hbase.ServerName
Retrieve an instance of ServerName.
valueOf(String, long) - Static method in class org.apache.hadoop.hbase.ServerName
Retrieve an instance of ServerName.
valueOf(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.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.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.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.executor.EventType
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.executor.ExecutorType
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
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.FilterWrapper.FilterRowRetCode
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.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.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
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.regionserver.RegionOpeningState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.replication.ReplicationPeer.PeerState
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() - 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
 
verifyMetaRegionLocation(HConnection, ZooKeeperWatcher, long) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Verify hbase:meta is deployed and accessible.
verifyMetaRegionLocation(HConnection, ZooKeeperWatcher, long, int) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Verify hbase:meta is deployed and accessible.
VERSION - Static variable in interface org.apache.hadoop.hbase.Coprocessor
 
VERSION - Static variable in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
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 interface org.apache.hadoop.hbase.MetaTableAccessor.Visitor
Visit the catalog table row.
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'
waitForBaseZNode(Configuration) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Waits for HBase installation's base (parent) znode to become available.
waitForState(long, HBaseAdmin.ProcedureFuture.WaitForStateCallable) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
waitForWork() - Method in class org.apache.hadoop.hbase.ipc.RpcClientImpl.Connection
 
waitMetaRegionLocation(ZooKeeperWatcher, long) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Gets the meta region location, if available, and waits for up to the specified timeout if not immediately available.
waitMetaRegionLocation(ZooKeeperWatcher, int, long) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Gets the meta region location, if available, and waits for up to the specified timeout if not immediately available.
waitMetaRegionLocation(ZooKeeperWatcher) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Waits indefinitely for availability of hbase:meta.
waitOperationResult(long) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
Fallback implementation in case the procedure is not supported by the server.
waitToBecomeLeader() - Method in class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
Deprecated.
Blocks until this instance has claimed the leader ZNode in ZooKeeper
warmupRegion(RpcController, AdminProtos.AdminService.BlockingInterface, HRegionInfo) - Static method in class org.apache.hadoop.hbase.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
 
watchAndCheckExists(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Watch the specified znode for delete/create/change events.
watcher - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperListener
 
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
wrapException(InetSocketAddress, Exception) - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
Takes an Exception and the address we were trying to connect to and return an IOException with the input exception as the cause.
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.HColumnDescriptor
Deprecated.
Writables are going away. Use HColumnDescriptor.toByteArray() instead.
write(DataOutput) - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
Use protobuf serialization instead. See HRegionInfo.toByteArray() and HRegionInfo.toDelimitedByteArray()
write(DataOutput) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Writables are going away. Use MessageLite.toByteArray() instead.
write(OutputStream, Message, Message, ByteBuffer) - Static method in class org.apache.hadoop.hbase.ipc.IPCUtil
Write out header, param, and cell block if there is one.
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.SaslClientHandler
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
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
ZkAclReset - Class in org.apache.hadoop.hbase.zookeeper
You may add the jaas.conf option -Djava.security.auth.login.config=/PATH/jaas.conf You may also specify -D to set options "hbase.zookeeper.quorum" (it should be in hbase-site.xml) "zookeeper.znode.parent" (it should be in hbase-site.xml) Use -set-acls to set the ACLs, no option to erase ACLs
ZkAclReset() - Constructor for class org.apache.hadoop.hbase.zookeeper.ZkAclReset
 
ZKAssign - Class in org.apache.hadoop.hbase.zookeeper
Utility class for doing region assignment in ZooKeeper.
ZKAssign() - Constructor for class org.apache.hadoop.hbase.zookeeper.ZKAssign
 
ZKClusterId - Class in org.apache.hadoop.hbase.zookeeper
Publishes and synchronizes a unique identifier specific to a given HBase cluster.
ZKClusterId(ZooKeeperWatcher, Abortable) - Constructor for class org.apache.hadoop.hbase.zookeeper.ZKClusterId
 
ZKLeaderManager - Class in org.apache.hadoop.hbase.zookeeper
Deprecated.
Not used
ZKLeaderManager(ZooKeeperWatcher, String, byte[], Stoppable) - Constructor for class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
Deprecated.
 
ZKTableStateClientSideReader - Class in org.apache.hadoop.hbase.zookeeper
Non-instantiable class that provides helper functions to learn about HBase table state for code running on client side (hence, not having access to consensus context).
ZKUtil - Class in org.apache.hadoop.hbase.zookeeper
Internal HBase utility class for ZooKeeper.
ZKUtil() - Constructor for class org.apache.hadoop.hbase.zookeeper.ZKUtil
 
ZKUtil.NodeAndData - Class in org.apache.hadoop.hbase.zookeeper
Deprecated.
Unused
ZKUtil.NodeAndData(String, byte[]) - Constructor for class org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData
Deprecated.
 
ZKUtil.ZKUtilOp - Class in org.apache.hadoop.hbase.zookeeper
Represents an action taken by ZKUtil, e.g.
ZKUtil.ZKUtilOp.CreateAndFailSilent - Class in org.apache.hadoop.hbase.zookeeper
ZKUtilOp representing createAndFailSilent in ZooKeeper (attempt to create node, ignore error if already exists)
ZKUtil.ZKUtilOp.DeleteNodeFailSilent - Class in org.apache.hadoop.hbase.zookeeper
ZKUtilOp representing deleteNodeFailSilent in ZooKeeper (attempt to delete node, ignore error if node doesn't exist)
ZKUtil.ZKUtilOp.SetData - Class in org.apache.hadoop.hbase.zookeeper
ZKUtilOp representing setData in ZooKeeper
ZNODE_PATH_SEPARATOR - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKUtil
 
zookeeper - Variable in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
 
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.
ZooKeeperListener - Class in org.apache.hadoop.hbase.zookeeper
Base class for internal listeners of ZooKeeper events.
ZooKeeperListener(ZooKeeperWatcher) - Constructor for class org.apache.hadoop.hbase.zookeeper.ZooKeeperListener
Construct a ZooKeeper event listener.
ZooKeeperNodeTracker - Class in org.apache.hadoop.hbase.zookeeper
Tracks the availability and value of a single ZooKeeper node.
ZooKeeperNodeTracker(ZooKeeperWatcher, String, Abortable) - Constructor for class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
Constructs a new ZK node tracker.
ZooKeeperWatcher - Class in org.apache.hadoop.hbase.zookeeper
Acts as the single ZooKeeper Watcher.
ZooKeeperWatcher(Configuration, String, Abortable) - Constructor for class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Instantiate a ZooKeeper connection and watcher.
ZooKeeperWatcher(Configuration, String, Abortable, boolean) - Constructor for class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Instantiate a ZooKeeper connection and watcher.
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 

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