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

A

add(long) - Method in class org.hbase.async.jsr166e.LongAdder
Adds the given value.
atomicCreate(PutRequest) - Method in class org.hbase.async.HBaseClient
Atomically insert a new cell in HBase.
atomicIncrement(AtomicIncrementRequest) - Method in class org.hbase.async.HBaseClient
Atomically and durably increments a value in HBase.
atomicIncrement(AtomicIncrementRequest, boolean) - Method in class org.hbase.async.HBaseClient
Atomically increments a value in HBase.
AtomicIncrementRequest - Class in org.hbase.async
Atomically increments a value in HBase.
AtomicIncrementRequest(byte[], byte[], byte[], byte[], long) - Constructor for class org.hbase.async.AtomicIncrementRequest
Constructor.
AtomicIncrementRequest(byte[], byte[], byte[], byte[]) - Constructor for class org.hbase.async.AtomicIncrementRequest
Constructor.
AtomicIncrementRequest(String, String, String, String, long) - Constructor for class org.hbase.async.AtomicIncrementRequest
Constructor.
AtomicIncrementRequest(String, String, String, String) - Constructor for class org.hbase.async.AtomicIncrementRequest
Constructor.
atomicIncrements() - Method in class org.hbase.async.ClientStats
Number of AtomicIncrementRequest sent.

B

BinaryComparator - Class in org.hbase.async
A binary comparator used in comparison filters.
BinaryComparator(byte[]) - Constructor for class org.hbase.async.BinaryComparator
 
BinaryPrefixComparator - Class in org.hbase.async
A binary comparator used in comparison filters.
BinaryPrefixComparator(byte[]) - Constructor for class org.hbase.async.BinaryPrefixComparator
 
BitComparator - Class in org.hbase.async
A bitwise comparator used in comparison filters.
BitComparator(byte[], BitComparator.BitwiseOp) - Constructor for class org.hbase.async.BitComparator
 
BitComparator.BitwiseOp - Enum in org.hbase.async
Bit operators.
bitwiseOperator() - Method in class org.hbase.async.BitComparator
 
BrokenMetaException - Exception in org.hbase.async
Indicates that the .META. or -ROOT- table is corrupted.
bufferAtomicIncrement(AtomicIncrementRequest) - Method in class org.hbase.async.HBaseClient
Buffers a durable atomic increment for coalescing.
Bytes - Class in org.hbase.async
Helper functions to manipulate byte arrays.
Bytes.ByteMap<V> - Class in org.hbase.async
A convenient map keyed with a byte array.
Bytes.ByteMap() - Constructor for class org.hbase.async.Bytes.ByteMap
 

C

charset() - Method in class org.hbase.async.RegexStringComparator
 
clearFilter() - Method in class org.hbase.async.Scanner
Clears any filter that was previously set on this scanner.
ClientStats - Class in org.hbase.async
HBaseClient usage statistics.
close() - Method in class org.hbase.async.Scanner
Closes this scanner (don't forget to call this when you're done with it!).
ColumnPrefixFilter - Class in org.hbase.async
Sets a binary prefix to filter results based on the column qualifier.
ColumnPrefixFilter(String) - Constructor for class org.hbase.async.ColumnPrefixFilter
Constructor for a UTF-8 prefix string.
ColumnPrefixFilter(byte[]) - Constructor for class org.hbase.async.ColumnPrefixFilter
Constructor.
ColumnRangeFilter - Class in org.hbase.async
Filters based on a range of column qualifiers.
ColumnRangeFilter(String, String) - Constructor for class org.hbase.async.ColumnRangeFilter
Constructor for UTF-8 strings.
ColumnRangeFilter(byte[], byte[]) - Constructor for class org.hbase.async.ColumnRangeFilter
Constructor.
ColumnRangeFilter(String, boolean, String, boolean) - Constructor for class org.hbase.async.ColumnRangeFilter
Constructor for UTF-8 strings.
ColumnRangeFilter(byte[], boolean, byte[], boolean) - Constructor for class org.hbase.async.ColumnRangeFilter
Constructor.
comparator() - Method in class org.hbase.async.CompareFilter
 
compareAndSet(PutRequest, byte[]) - Method in class org.hbase.async.HBaseClient
Atomic Compare-And-Set (CAS) on a single cell.
compareAndSet(PutRequest, String) - Method in class org.hbase.async.HBaseClient
Atomic Compare-And-Set (CAS) on a single cell.
CompareFilter - Class in org.hbase.async
A generic scan filter to be used to filter by comparison.
CompareFilter(CompareFilter.CompareOp, FilterComparator) - Constructor for class org.hbase.async.CompareFilter
 
CompareFilter.CompareOp - Enum in org.hbase.async
Comparison operators.
compareOperation() - Method in class org.hbase.async.CompareFilter
 
compareTo(KeyValue) - Method in class org.hbase.async.KeyValue
 
ConnectionResetException - Exception in org.hbase.async
Exception thrown when an RPC was in flight while we got disconnected.
connectionsCreated() - Method in class org.hbase.async.ClientStats
Number of connections created to connect to RegionServers.
contendedMetaLookupCount() - Method in class org.hbase.async.HBaseClient
Deprecated.
This method will be removed in release 2.0. Use HBaseClient.stats().contendedMetaLookups() instead.
contendedMetaLookups() - Method in class org.hbase.async.ClientStats
Returns how many lookups in .META. were performed (contended).
Counter - Class in org.hbase.async
An atomic counter to replace AtomicLong.
Counter() - Constructor for class org.hbase.async.Counter
 

D

decrement() - Method in class org.hbase.async.jsr166e.LongAdder
Equivalent to add(-1).
deDup(byte[], byte[]) - Static method in class org.hbase.async.Bytes
De-duplicates two byte arrays.
DEFAULT_MAX_NUM_KVS - Static variable in class org.hbase.async.Scanner
The default maximum number of KeyValues the server is allowed to return in a single RPC response to a Scanner.
DEFAULT_MAX_NUM_ROWS - Static variable in class org.hbase.async.Scanner
The default maximum number of rows to scan per RPC.
delete(DeleteRequest) - Method in class org.hbase.async.HBaseClient
Deletes data from HBase.
deleteAtTimestampOnly() - Method in class org.hbase.async.DeleteRequest
Returns whether to only delete the cell value at the timestamp.
DeleteRequest - Class in org.hbase.async
Deletes some data into HBase.
DeleteRequest(byte[], byte[]) - Constructor for class org.hbase.async.DeleteRequest
Constructor to delete an entire row.
DeleteRequest(byte[], byte[], long) - Constructor for class org.hbase.async.DeleteRequest
Constructor to delete an entire row before a specific timestamp.
DeleteRequest(byte[], byte[], byte[]) - Constructor for class org.hbase.async.DeleteRequest
Constructor to delete a specific family.
DeleteRequest(byte[], byte[], byte[], long) - Constructor for class org.hbase.async.DeleteRequest
Constructor to delete a specific family before a specific timestamp.
DeleteRequest(byte[], byte[], byte[], byte[]) - Constructor for class org.hbase.async.DeleteRequest
Constructor to delete a specific cell.
DeleteRequest(byte[], byte[], byte[], byte[], long) - Constructor for class org.hbase.async.DeleteRequest
Constructor to delete a specific cell before a specific timestamp.
DeleteRequest(byte[], byte[], byte[], byte[][]) - Constructor for class org.hbase.async.DeleteRequest
Constructor to delete a specific number of cells in a row.
DeleteRequest(byte[], byte[], byte[], byte[][], long) - Constructor for class org.hbase.async.DeleteRequest
Constructor to delete a specific number of cells in a row.
DeleteRequest(byte[], byte[], byte[], byte[], RowLock) - Constructor for class org.hbase.async.DeleteRequest
Constructor to delete a specific cell with an explicit row lock.
DeleteRequest(byte[], byte[], byte[], byte[], long, RowLock) - Constructor for class org.hbase.async.DeleteRequest
Constructor to delete a specific cell with an explicit row lock.
DeleteRequest(byte[], byte[], byte[], byte[][], RowLock) - Constructor for class org.hbase.async.DeleteRequest
Constructor to delete a specific number of cells in a row.
DeleteRequest(byte[], byte[], byte[], byte[][], long, RowLock) - Constructor for class org.hbase.async.DeleteRequest
Constructor to delete a specific number of cells in a row with a row lock.
DeleteRequest(String, String) - Constructor for class org.hbase.async.DeleteRequest
Constructor to delete an entire row.
DeleteRequest(String, String, String) - Constructor for class org.hbase.async.DeleteRequest
Constructor to delete a specific family.
DeleteRequest(String, String, String, String) - Constructor for class org.hbase.async.DeleteRequest
Constructor to delete a specific cell.
DeleteRequest(String, String, String, String, RowLock) - Constructor for class org.hbase.async.DeleteRequest
Constructor to delete a specific cell with an explicit row lock.
DeleteRequest(byte[], KeyValue) - Constructor for class org.hbase.async.DeleteRequest
Constructor to delete a specific cell.
DeleteRequest(byte[], KeyValue, RowLock) - Constructor for class org.hbase.async.DeleteRequest
Constructor to delete a specific cell with an explicit row lock.
deletes() - Method in class org.hbase.async.ClientStats
DependentColumnFilter - Class in org.hbase.async
Filters key values based on the existence of a dependent, or reference, column.
DependentColumnFilter(byte[], byte[], boolean, CompareFilter.CompareOp, FilterComparator) - Constructor for class org.hbase.async.DependentColumnFilter
Creates a DependentColumnFilter with the provided dependent column, additional value filter, and specification of whether the dependent column should be included in the results.
DependentColumnFilter(byte[], byte[], boolean) - Constructor for class org.hbase.async.DependentColumnFilter
Creates a DependentColumnFilter with the provided dependent column, and specify whether the dependent column should be included in the results.
DependentColumnFilter(byte[], byte[], CompareFilter.CompareOp, FilterComparator) - Constructor for class org.hbase.async.DependentColumnFilter
Creates a DependentColumnFilter with the provided dependent column, and dependent-column value comparison filter.
DependentColumnFilter(byte[], byte[]) - Constructor for class org.hbase.async.DependentColumnFilter
Creates a DependentColumnFilter with the provided dependent column.
doubleValue() - Method in class org.hbase.async.jsr166e.LongAdder
Returns the LongAdder.sum() as a double after a widening primitive conversion.
dropDependentColumn() - Method in class org.hbase.async.DependentColumnFilter
Returns whether the dependent column will be included in the results.

E

EMPTY_ARRAY - Static variable in class org.hbase.async.HBaseClient
An empty byte array you can use.
ensureTableExists(String) - Method in class org.hbase.async.HBaseClient
Ensures that a given table really exists.
ensureTableExists(byte[]) - Method in class org.hbase.async.HBaseClient
Ensures that a given table really exists.
ensureTableFamilyExists(String, String) - Method in class org.hbase.async.HBaseClient
Ensures that a given table/family pair really exists.
ensureTableFamilyExists(byte[], byte[]) - Method in class org.hbase.async.HBaseClient
Ensures that a given table/family pair really exists.
equals(byte[], byte[]) - Static method in class org.hbase.async.Bytes
Tests whether two byte arrays have the same contents.
equals(Object) - Method in class org.hbase.async.KeyValue
 
expression() - Method in class org.hbase.async.RegexStringComparator
 

F

failfast() - Method in class org.hbase.async.HBaseRpc
Returns whether or not the RPC not be retried upon encountering a problem.
family() - Method in class org.hbase.async.AtomicIncrementRequest
 
family() - Method in class org.hbase.async.DependentColumnFilter
Returns the column family of the dependent column.
family(byte[]) - Method in class org.hbase.async.GetRequest
Specifies a particular column family to get.
family(String) - Method in class org.hbase.async.GetRequest
Specifies a particular column family to get.
family() - Method in class org.hbase.async.GetRequest
 
family() - Method in interface org.hbase.async.HBaseRpc.HasFamily
Returns the family this RPC is for.
family() - Method in class org.hbase.async.KeyValue
Returns the column family.
FamilyFilter - Class in org.hbase.async
Filter columns based on the column family.
FamilyFilter(CompareFilter.CompareOp, FilterComparator) - Constructor for class org.hbase.async.FamilyFilter
 
FilterComparator - Class in org.hbase.async
Abstract base class for ScanFilter comparators.
FilterComparator() - Constructor for class org.hbase.async.FilterComparator
 
FilterList - Class in org.hbase.async
Combines a list of filters into one.
FilterList(List<ScanFilter>) - Constructor for class org.hbase.async.FilterList
Constructor.
FilterList(List<ScanFilter>, FilterList.Operator) - Constructor for class org.hbase.async.FilterList
Constructor.
FilterList.Operator - Enum in org.hbase.async
Operator to combine the list of filters together.
floatValue() - Method in class org.hbase.async.jsr166e.LongAdder
Returns the LongAdder.sum() as a float after a widening primitive conversion.
flush() - Method in class org.hbase.async.HBaseClient
Flushes to HBase any buffered client-side write operation.
flushes() - Method in class org.hbase.async.ClientStats
Number of calls to HBaseClient.flush().
fromBuffer(ChannelBuffer, KeyValue) - Static method in class org.hbase.async.KeyValue
De-serializes KeyValue from a buffer (HBase 0.94 and before).
fromInt(int) - Static method in class org.hbase.async.Bytes
Creates a new byte array containing a big-endian 4-byte integer.
fromLong(long) - Static method in class org.hbase.async.Bytes
Creates a new byte array containing a big-endian 8-byte long integer.
fromShort(short) - Static method in class org.hbase.async.Bytes
Creates a new byte array containing a big-endian 2-byte short integer.

G

get(ByteString) - Static method in class org.hbase.async.Bytes
Extracts the byte array from the given ByteString without copy.
get() - Method in class org.hbase.async.Counter
Returns the current value of the counter.
get(GetRequest) - Method in class org.hbase.async.HBaseClient
Retrieves data from HBase.
getAmount() - Method in class org.hbase.async.AtomicIncrementRequest
Returns the amount by which the value is going to be incremented.
getChannel() - Method in exception org.hbase.async.ConnectionResetException
Returns the name of the region that's offline.
getCurrentKey() - Method in class org.hbase.async.Scanner
Returns the row key this scanner is currently at.
getDeferred() - Method in exception org.hbase.async.PleaseThrottleException
Returns a deferred one can wait on before retrying the failed RPC.
getFailedRpc() - Method in interface org.hbase.async.HasFailedRpcException
Returns the RPC that caused this exception.
getFailedRpc() - Method in exception org.hbase.async.NoSuchColumnFamilyException
 
getFailedRpc() - Method in exception org.hbase.async.NotServingRegionException
 
getFailedRpc() - Method in exception org.hbase.async.PleaseThrottleException
The RPC that was made to fail with this exception.
getFailedRpc() - Method in exception org.hbase.async.RegionMovedException
 
getFailedRpc() - Method in exception org.hbase.async.UnknownRowLockException
 
getFailedRpc() - Method in exception org.hbase.async.UnknownScannerException
 
getFailedRpc() - Method in exception org.hbase.async.VersionMismatchException
 
getFilter() - Method in class org.hbase.async.Scanner
Returns the possibly-null filter applied to this scanner.
getFlushInterval() - Method in class org.hbase.async.HBaseClient
Returns the maximum time (in milliseconds) for which edits can be buffered.
getIncrementBufferSize() - Method in class org.hbase.async.HBaseClient
Returns the capacity of the increment buffer.
getInt(byte[]) - Static method in class org.hbase.async.Bytes
Reads a big-endian 4-byte integer from the begining of the given array.
getInt(byte[], int) - Static method in class org.hbase.async.Bytes
Reads a big-endian 4-byte integer from an offset in the given array.
getLong(byte[]) - Static method in class org.hbase.async.Bytes
Reads a big-endian 8-byte long from the begining of the given array.
getLong(byte[], int) - Static method in class org.hbase.async.Bytes
Reads a big-endian 8-byte long from an offset in the given array.
getMaxNumBytes() - Method in class org.hbase.async.Scanner
Returns the maximum number of bytes returned at once by the scanner.
getMaxNumKeyValues() - Method in class org.hbase.async.Scanner
Maximum number of KeyValues the server is allowed to return.
getMaxTimestamp() - Method in class org.hbase.async.Scanner
Returns the maximum timestamp to scan (exclusive).
getMaxVersions() - Method in class org.hbase.async.Scanner
Returns the maximum number of versions to return for each cell scanned.
getMessage() - Method in exception org.hbase.async.NotServingRegionException
 
getMessage() - Method in exception org.hbase.async.RegionMovedException
 
getMinTimestamp() - Method in class org.hbase.async.Scanner
Returns the minimum timestamp to scan (inclusive).
getRegion() - Method in exception org.hbase.async.RegionOfflineException
Returns the name of the region that's offline.
GetRequest - Class in org.hbase.async
Reads something from HBase.
GetRequest(byte[], byte[]) - Constructor for class org.hbase.async.GetRequest
Constructor.
GetRequest(String, byte[]) - Constructor for class org.hbase.async.GetRequest
Constructor.
GetRequest(String, String) - Constructor for class org.hbase.async.GetRequest
Constructor.
GetRequest(byte[], byte[], byte[]) - Constructor for class org.hbase.async.GetRequest
Constructor.
GetRequest(String, String, String) - Constructor for class org.hbase.async.GetRequest
Constructor.
GetRequest(byte[], byte[], byte[], byte[]) - Constructor for class org.hbase.async.GetRequest
Constructor.
GetRequest(String, String, String, String) - Constructor for class org.hbase.async.GetRequest
Constructor.
getResponse() - Method in exception org.hbase.async.InvalidResponseException
Returns the possibly null response received from the server.
gets() - Method in class org.hbase.async.ClientStats
getShort(byte[]) - Static method in class org.hbase.async.Bytes
Reads a big-endian 2-byte short from the begining of the given array.
getShort(byte[], int) - Static method in class org.hbase.async.Bytes
Reads a big-endian 2-byte short from an offset in the given array.
getTable() - Method in exception org.hbase.async.TableNotFoundException
Returns the table that was doesn't exist.
getTimer() - Method in class org.hbase.async.HBaseClient
Returns the timer used by this client.
getType() - Method in exception org.hbase.async.RemoteException
Returns the name of the class of the remote exception.
getUnsignedInt(byte[]) - Static method in class org.hbase.async.Bytes
Reads a big-endian 4-byte unsigned integer from the begining of the given array.
getUnsignedInt(byte[], int) - Static method in class org.hbase.async.Bytes
Reads a big-endian 4-byte unsigned integer from an offset in the given array.
getUnsignedShort(byte[]) - Static method in class org.hbase.async.Bytes
Reads a big-endian 2-byte unsigned short from the begining of the given array.
getUnsignedShort(byte[], int) - Static method in class org.hbase.async.Bytes
Reads a big-endian 2-byte unsigned short from an offset in the given array.

H

HasFailedRpcException - Interface in org.hbase.async
Interface implemented by HBaseExceptions that can tell you which RPC failed.
hashCode() - Method in class org.hbase.async.KeyValue
 
HBaseClient - Class in org.hbase.async
A fully asynchronous, thread-safe, modern HBase client.
HBaseClient(String) - Constructor for class org.hbase.async.HBaseClient
Constructor.
HBaseClient(String, String) - Constructor for class org.hbase.async.HBaseClient
Constructor.
HBaseClient(String, String, Executor) - Constructor for class org.hbase.async.HBaseClient
Constructor for advanced users with special needs.
HBaseClient(String, String, ClientSocketChannelFactory) - Constructor for class org.hbase.async.HBaseClient
Constructor for advanced users with special needs.
HBaseException - Exception in org.hbase.async
The parent class of all RuntimeException created by this package.
HBaseRpc - Class in org.hbase.async
Abstract base class for all RPC requests going out to HBase.
HBaseRpc.HasFamily - Interface in org.hbase.async
An RPC from which you can get a family name.
HBaseRpc.HasKey - Interface in org.hbase.async
An RPC from which you can get a row key name.
HBaseRpc.HasQualifier - Interface in org.hbase.async
An RPC from which you can get a column qualifier name.
HBaseRpc.HasQualifiers - Interface in org.hbase.async
An RPC from which you can get multiple column qualifier names.
HBaseRpc.HasTable - Interface in org.hbase.async
An RPC from which you can get a table name.
HBaseRpc.HasTimestamp - Interface in org.hbase.async
An RPC from which you can get a timestamp.
HBaseRpc.HasValue - Interface in org.hbase.async
An RPC from which you can get a value.
HBaseRpc.HasValues - Interface in org.hbase.async
An RPC from which you can get multiple values.
hex(long) - Static method in class org.hbase.async.Bytes
Pretty-prints a long into a fixed-width hexadecimal number.
holdNanoTime() - Method in class org.hbase.async.RowLock
Returns for how long this lock has been held in nanoseconds.

I

increment() - Method in class org.hbase.async.jsr166e.LongAdder
Equivalent to add(1).
incrementBufferStats() - Method in class org.hbase.async.ClientStats
Returns statistics from the buffer used to coalesce increments.
intValue() - Method in class org.hbase.async.jsr166e.LongAdder
Returns the LongAdder.sum() as an int after a narrowing primitive conversion.
InvalidResponseException - Exception in org.hbase.async
Exception used when the server sends an invalid response to an RPC.
ISO88591(String) - Static method in class org.hbase.async.Bytes
Transforms a string into an ISO-8859-1 encoded byte array.
iterator() - Method in class org.hbase.async.Bytes.ByteMap
Returns an iterator that goes through all the entries in this map.

K

key() - Method in class org.hbase.async.AtomicIncrementRequest
 
key() - Method in class org.hbase.async.DeleteRequest
 
key() - Method in class org.hbase.async.GetRequest
 
key() - Method in interface org.hbase.async.HBaseRpc.HasKey
Returns the row key this RPC is for.
key() - Method in class org.hbase.async.KeyValue
Returns the row key.
key() - Method in class org.hbase.async.PutRequest
 
key() - Method in class org.hbase.async.RowLockRequest
 
KeyRegexpFilter - Class in org.hbase.async
Filters rows based on an expression applied to the row key.
KeyRegexpFilter(String) - Constructor for class org.hbase.async.KeyRegexpFilter
Sets a regular expression to filter results based on the row key.
KeyRegexpFilter(String, Charset) - Constructor for class org.hbase.async.KeyRegexpFilter
Sets a regular expression to filter results based on the row key.
KeyRegexpFilter(byte[]) - Constructor for class org.hbase.async.KeyRegexpFilter
Sets a regular expression to filter results based on the row key.
KeyRegexpFilter(byte[], Charset) - Constructor for class org.hbase.async.KeyRegexpFilter
Sets a regular expression to filter results based on the row key.
KeyValue - Class in org.hbase.async
A "cell" in an HBase table.
KeyValue(byte[], byte[], byte[], long, byte[]) - Constructor for class org.hbase.async.KeyValue
Constructor.
KeyValue(byte[], byte[], byte[], byte[]) - Constructor for class org.hbase.async.KeyValue
Constructor.

L

lockRow(RowLockRequest) - Method in class org.hbase.async.HBaseClient
Acquires an explicit row lock.
LongAdder - Class in org.hbase.async.jsr166e
One or more variables that together maintain an initially zero long sum.
LongAdder() - Constructor for class org.hbase.async.jsr166e.LongAdder
Creates a new adder with initial sum of zero.
longValue() - Method in class org.hbase.async.jsr166e.LongAdder
Equivalent to LongAdder.sum().

M

maxVersions(int) - Method in class org.hbase.async.GetRequest
Sets the maximum number of versions to return for each cell read.
maxVersions() - Method in class org.hbase.async.GetRequest
Returns the maximum number of versions to return for each cell scanned.
MEMCMP - Static variable in class org.hbase.async.Bytes
A singleton Comparator for non-null byte arrays.
memcmp(byte[], byte[]) - Static method in class org.hbase.async.Bytes
memcmp in Java, hooray.
memcmp(byte[], byte[], int, int) - Static method in class org.hbase.async.Bytes
memcmp(3) with a given offset and length.
memcmpMaybeNull(byte[], byte[]) - Static method in class org.hbase.async.Bytes
memcmp(3) in Java for possibly null arrays, hooray.

N

newScanner(byte[]) - Method in class org.hbase.async.HBaseClient
Creates a new Scanner for a particular table.
newScanner(String) - Method in class org.hbase.async.HBaseClient
Creates a new Scanner for a particular table.
nextRows(int) - Method in class org.hbase.async.Scanner
Scans a number of rows.
nextRows() - Method in class org.hbase.async.Scanner
Scans a number of rows.
NonRecoverableException - Exception in org.hbase.async
An exception for which it's typically pointless to retry (such as TableNotFoundException).
NoSuchColumnFamilyException - Exception in org.hbase.async
Exception thrown when attempting to use a nonexistent column family.
noSuchRegionExceptions() - Method in class org.hbase.async.ClientStats
Number of NoSuchRegionException handled by the client.
NotServingRegionException - Exception in org.hbase.async
Exception thrown when we attempted to use a region that wasn't serving from that particular RegionServer.
numBatchedRpcSent() - Method in class org.hbase.async.ClientStats
Number of batched RPCs sent to the network.
numRpcDelayedDueToNSRE() - Method in class org.hbase.async.ClientStats
Number of RPCs delayed due to NoSuchRegionExceptions.

O

org.hbase.async - package org.hbase.async
 
org.hbase.async.jsr166e - package org.hbase.async.jsr166e
This package is not part of asynchbase's public interface.

P

PleaseThrottleException - Exception in org.hbase.async
This exception notifies the application to throttle its use of HBase.
prefetchMeta(String) - Method in class org.hbase.async.HBaseClient
Eagerly prefetches and caches a table's region metadata from HBase.
prefetchMeta(String, String, String) - Method in class org.hbase.async.HBaseClient
Eagerly prefetches and caches part of a table's region metadata from HBase.
prefetchMeta(byte[]) - Method in class org.hbase.async.HBaseClient
Eagerly prefetches and caches a table's region metadata from HBase.
prefetchMeta(byte[], byte[], byte[]) - Method in class org.hbase.async.HBaseClient
Eagerly prefetches and caches part of a table's region metadata from HBase.
pretty(StringBuilder, byte[]) - Static method in class org.hbase.async.Bytes
Pretty-prints a byte array into a human-readable output buffer.
pretty(StringBuilder, byte[][]) - Static method in class org.hbase.async.Bytes
Pretty-prints an array of byte arrays into a human-readable output buffer.
pretty(byte[]) - Static method in class org.hbase.async.Bytes
Pretty-prints a byte array into a human-readable string.
pretty(ChannelBuffer) - Static method in class org.hbase.async.Bytes
Pretty-prints all the bytes of a buffer into a human-readable string.
put(PutRequest) - Method in class org.hbase.async.HBaseClient
Stores data in HBase.
PutRequest - Class in org.hbase.async
Puts some data into HBase.
PutRequest(byte[], byte[], byte[], byte[], byte[]) - Constructor for class org.hbase.async.PutRequest
Constructor using current time.
PutRequest(byte[], byte[], byte[], byte[][], byte[][]) - Constructor for class org.hbase.async.PutRequest
Constructor for multiple columns using current time.
PutRequest(byte[], byte[], byte[], byte[], byte[], long) - Constructor for class org.hbase.async.PutRequest
Constructor for a specific timestamp.
PutRequest(byte[], byte[], byte[], byte[][], byte[][], long) - Constructor for class org.hbase.async.PutRequest
Constructor for multiple columns with a specific timestamp.
PutRequest(byte[], byte[], byte[], byte[], byte[], RowLock) - Constructor for class org.hbase.async.PutRequest
Constructor using an explicit row lock.
PutRequest(byte[], byte[], byte[], byte[], byte[], long, RowLock) - Constructor for class org.hbase.async.PutRequest
Constructor using current time and an explicit row lock.
PutRequest(byte[], byte[], byte[], byte[][], byte[][], long, RowLock) - Constructor for class org.hbase.async.PutRequest
Constructor for multiple columns with current time and explicit row lock.
PutRequest(String, String, String, String, String) - Constructor for class org.hbase.async.PutRequest
Convenience constructor from strings (higher overhead).
PutRequest(String, String, String, String, String, RowLock) - Constructor for class org.hbase.async.PutRequest
Convenience constructor with explicit row lock (higher overhead).
PutRequest(byte[], KeyValue) - Constructor for class org.hbase.async.PutRequest
Constructor from a KeyValue.
PutRequest(byte[], KeyValue, RowLock) - Constructor for class org.hbase.async.PutRequest
Constructor from a KeyValue with an explicit row lock.
puts() - Method in class org.hbase.async.ClientStats

Q

qualifier() - Method in class org.hbase.async.AtomicIncrementRequest
 
qualifier() - Method in class org.hbase.async.DependentColumnFilter
Returns the qualifier of the dependent column.
qualifier(byte[]) - Method in class org.hbase.async.GetRequest
Specifies a particular column qualifier to get.
qualifier(String) - Method in class org.hbase.async.GetRequest
Specifies a particular column qualifier to get.
qualifier() - Method in interface org.hbase.async.HBaseRpc.HasQualifier
Returns the column qualifier this RPC is for.
qualifier() - Method in class org.hbase.async.KeyValue
Returns the column qualifier.
qualifier() - Method in class org.hbase.async.PutRequest
Returns the first qualifier of the set of edits in this RPC.
QualifierFilter - Class in org.hbase.async
Filter columns based on the qualifier.
QualifierFilter(CompareFilter.CompareOp, FilterComparator) - Constructor for class org.hbase.async.QualifierFilter
 
qualifiers() - Method in class org.hbase.async.DeleteRequest
 
qualifiers(byte[][]) - Method in class org.hbase.async.GetRequest
Specifies a particular set of column qualifiers to get.
qualifiers() - Method in class org.hbase.async.GetRequest
 
qualifiers() - Method in interface org.hbase.async.HBaseRpc.HasQualifiers
Returns the column qualifiers this RPC is for.
qualifiers() - Method in class org.hbase.async.PutRequest
Returns the column qualifiers this RPC is for.

R

RecoverableException - Exception in org.hbase.async
An exception for which it's typically useful to retry (such as RegionOfflineException).
RegexStringComparator - Class in org.hbase.async
A regular expression comparator used in comparison filters such as RowFilter, QualifierFilter, and ValueFilter.
RegexStringComparator(String) - Constructor for class org.hbase.async.RegexStringComparator
Create a regular expression filter with the specified regular expression.
RegexStringComparator(String, Charset) - Constructor for class org.hbase.async.RegexStringComparator
Create a regular expression filter with the specified regular expression and charset.
RegionMovedException - Exception in org.hbase.async
Exception thrown when we attempted to use a region that was moved from that particular RegionServer to a new one.
RegionOfflineException - Exception in org.hbase.async
Exception thrown when we attempted to find a region, but it wasn't being served by any RegionServer (it's "offline" in HBase speak).
RemoteException - Exception in org.hbase.async
An unclassified exception that occurred on the server side.
reset() - Method in class org.hbase.async.jsr166e.LongAdder
Resets variables maintaining the sum to zero.
rootLookupCount() - Method in class org.hbase.async.HBaseClient
Deprecated.
This method will be removed in release 2.0. Use HBaseClient.stats().rootLookups() instead.
rootLookups() - Method in class org.hbase.async.ClientStats
Returns how many lookups in -ROOT- were performed.
RowFilter - Class in org.hbase.async
Filter rows based on the rowkey.
RowFilter(CompareFilter.CompareOp, FilterComparator) - Constructor for class org.hbase.async.RowFilter
 
RowLock - Class in org.hbase.async
An explicit row lock.
RowLockRequest - Class in org.hbase.async
Acquires an explicit row lock.
RowLockRequest(byte[], byte[]) - Constructor for class org.hbase.async.RowLockRequest
Constructor.
RowLockRequest(String, String) - Constructor for class org.hbase.async.RowLockRequest
Constructor.
rowLocks() - Method in class org.hbase.async.ClientStats

S

ScanFilter - Class in org.hbase.async
Abstract base class for Scanner filters.
Scanner - Class in org.hbase.async
Creates a scanner to read data sequentially from HBase.
scannersOpened() - Method in class org.hbase.async.ClientStats
Number of scanners opened.
scans() - Method in class org.hbase.async.ClientStats
Number of times a scanner had to fetch data from HBase.
setAmount(long) - Method in class org.hbase.async.AtomicIncrementRequest
Changes the amount by which the value is going to be incremented.
setDeleteAtTimestampOnly(boolean) - Method in class org.hbase.async.DeleteRequest
Deletes only the cell value with the timestamp specified in the constructor.
setFailfast(boolean) - Method in class org.hbase.async.HBaseRpc
Set whether or not the RPC not be retried upon encountering a problem.
setFamilies(byte[][], byte[][][]) - Method in class org.hbase.async.Scanner
Specifies multiple column families to scan.
setFamilies(String...) - Method in class org.hbase.async.Scanner
Specifies multiple column families to scan.
setFamily(byte[]) - Method in class org.hbase.async.Scanner
Specifies a particular column family to scan.
setFamily(String) - Method in class org.hbase.async.Scanner
Specifies a particular column family to scan.
setFilter(ScanFilter) - Method in class org.hbase.async.Scanner
Specifies the filter to apply to this scanner.
setFlushInterval(short) - Method in class org.hbase.async.HBaseClient
Sets the maximum time (in milliseconds) for which edits can be buffered.
setIncrementBufferSize(int) - Method in class org.hbase.async.HBaseClient
Changes the size of the increment buffer.
setInt(byte[], int) - Static method in class org.hbase.async.Bytes
Writes a big-endian 4-byte int at the begining of the given array.
setInt(byte[], int, int) - Static method in class org.hbase.async.Bytes
Writes a big-endian 4-byte int at an offset in the given array.
setKeyRegexp(String) - Method in class org.hbase.async.Scanner
Sets a regular expression to filter results based on the row key.
setKeyRegexp(String, Charset) - Method in class org.hbase.async.Scanner
Sets a regular expression to filter results based on the row key.
setLong(byte[], long) - Static method in class org.hbase.async.Bytes
Writes a big-endian 8-byte long at the begining of the given array.
setLong(byte[], long, int) - Static method in class org.hbase.async.Bytes
Writes a big-endian 8-byte long at an offset in the given array.
setMaxNumBytes(long) - Method in class org.hbase.async.Scanner
Sets the maximum number of bytes returned at once by the scanner.
setMaxNumKeyValues(int) - Method in class org.hbase.async.Scanner
Sets the maximum number of KeyValues the server is allowed to return in a single RPC response.
setMaxNumRows(int) - Method in class org.hbase.async.Scanner
Sets the maximum number of rows to scan per RPC (for better performance).
setMaxTimestamp(long) - Method in class org.hbase.async.Scanner
Sets the maximum timestamp to scan (exclusive).
setMaxVersions(int) - Method in class org.hbase.async.Scanner
Sets the maximum number of versions to return for each cell scanned.
setMinTimestamp(long) - Method in class org.hbase.async.Scanner
Sets the minimum timestamp to scan (inclusive).
setQualifier(byte[]) - Method in class org.hbase.async.Scanner
Specifies a particular column qualifier to scan.
setQualifier(String) - Method in class org.hbase.async.Scanner
Specifies a particular column qualifier to scan.
setQualifiers(byte[][]) - Method in class org.hbase.async.Scanner
Specifies one or more column qualifiers to scan.
setServerBlockCache(boolean) - Method in class org.hbase.async.Scanner
Sets whether or not the server should populate its block cache.
setShort(byte[], short) - Static method in class org.hbase.async.Bytes
Writes a big-endian 2-byte short at the begining of the given array.
setShort(byte[], short, int) - Static method in class org.hbase.async.Bytes
Writes a big-endian 2-byte short at an offset in the given array.
setStartKey(byte[]) - Method in class org.hbase.async.Scanner
Specifies from which row key to start scanning (inclusive).
setStartKey(String) - Method in class org.hbase.async.Scanner
Specifies from which row key to start scanning (inclusive).
setStopKey(byte[]) - Method in class org.hbase.async.Scanner
Specifies up to which row key to scan (exclusive).
setStopKey(String) - Method in class org.hbase.async.Scanner
Specifies up to which row key to scan (exclusive).
setTimeRange(long, long) - Method in class org.hbase.async.Scanner
Sets the time range to scan.
shutdown() - Method in class org.hbase.async.HBaseClient
Performs a graceful shutdown of this instance.
stats() - Method in class org.hbase.async.HBaseClient
Returns a snapshot of usage statistics for this client.
substring() - Method in class org.hbase.async.SubstringComparator
 
SubstringComparator - Class in org.hbase.async
A substring comparator used in comparison filters such as RowFilter, QualifierFilter, and ValueFilter.
SubstringComparator(String) - Constructor for class org.hbase.async.SubstringComparator
 
sum() - Method in class org.hbase.async.jsr166e.LongAdder
Returns the current sum.
sumThenReset() - Method in class org.hbase.async.jsr166e.LongAdder
Equivalent in effect to LongAdder.sum() followed by LongAdder.reset().

T

table() - Method in class org.hbase.async.AtomicIncrementRequest
 
table() - Method in exception org.hbase.async.BrokenMetaException
Returns the name of the table for which we were trying to lookup a region.
table() - Method in class org.hbase.async.DeleteRequest
 
table() - Method in class org.hbase.async.GetRequest
 
table() - Method in interface org.hbase.async.HBaseRpc.HasTable
Returns the name of the table this RPC is for.
table() - Method in class org.hbase.async.PutRequest
 
table() - Method in class org.hbase.async.RowLockRequest
 
TableNotFoundException - Exception in org.hbase.async
Exception thrown when an attempt to use an inexistent table was made.
timestamp() - Method in interface org.hbase.async.HBaseRpc.HasTimestamp
Returns the strictly positive timestamp contained in this RPC.
timestamp() - Method in class org.hbase.async.KeyValue
Returns the timestamp stored in this KeyValue.
TIMESTAMP_NOW - Static variable in class org.hbase.async.KeyValue
Timestamp value to let the server set the timestamp at processing time.
TimestampsFilter - Class in org.hbase.async
Filter that returns only cells whose timestamp (version) is in the specified list of timestamps (versions).
TimestampsFilter(Collection<Long>) - Constructor for class org.hbase.async.TimestampsFilter
Create a timestamp filter which filters all key values with a timestamp not in the provided collection.
TimestampsFilter(Long...) - Constructor for class org.hbase.async.TimestampsFilter
Create a timestamp filter which filters all key values with a timestamp not in the provided timestamps.
toProtobuf() - Method in class org.hbase.async.CompareFilter
 
toProtobuf(ByteString) - Method in class org.hbase.async.FilterComparator
Wraps the passed in serialized FilterComparator in a protobuf Comparator.
toString() - Method in class org.hbase.async.AtomicIncrementRequest
 
toString() - Method in class org.hbase.async.BinaryComparator
 
toString() - Method in class org.hbase.async.BinaryPrefixComparator
 
toString() - Method in class org.hbase.async.BitComparator
 
toString() - Method in class org.hbase.async.Bytes.ByteMap
byte[] friendly implementation.
toString() - Method in class org.hbase.async.ColumnPrefixFilter
 
toString() - Method in class org.hbase.async.ColumnRangeFilter
 
toString() - Method in class org.hbase.async.CompareFilter
 
toString() - Method in class org.hbase.async.DeleteRequest
 
toString() - Method in class org.hbase.async.DependentColumnFilter
 
toString() - Method in class org.hbase.async.FilterList
 
toString() - Method in class org.hbase.async.GetRequest
 
toString() - Method in class org.hbase.async.HBaseRpc
 
toString() - Method in class org.hbase.async.jsr166e.LongAdder
Returns the String representation of the LongAdder.sum().
toString() - Method in class org.hbase.async.KeyRegexpFilter
 
toString() - Method in class org.hbase.async.KeyValue
 
toString() - Method in class org.hbase.async.PutRequest
 
toString() - Method in class org.hbase.async.RegexStringComparator
 
toString() - Method in class org.hbase.async.RowLock
 
toString() - Method in class org.hbase.async.Scanner
 
toString() - Method in class org.hbase.async.SubstringComparator
 

U

uncontendedMetaLookupCount() - Method in class org.hbase.async.HBaseClient
Deprecated.
This method will be removed in release 2.0. Use HBaseClient.stats().uncontendedMetaLookups() instead.
uncontendedMetaLookups() - Method in class org.hbase.async.ClientStats
Returns how many lookups in .META. were performed (uncontended).
UnknownRowLockException - Exception in org.hbase.async
Exception thrown when we try to use an invalid or expired RowLock.
UnknownScannerException - Exception in org.hbase.async
Exception thrown when we try to use an invalid or expired scanner ID.
unlockRow(RowLock) - Method in class org.hbase.async.HBaseClient
Releases an explicit row lock.
UTF8(String) - Static method in class org.hbase.async.Bytes
Transforms a string into an UTF-8 encoded byte array.

V

value() - Method in class org.hbase.async.BinaryComparator
 
value() - Method in class org.hbase.async.BinaryPrefixComparator
 
value() - Method in class org.hbase.async.BitComparator
 
value() - Method in interface org.hbase.async.HBaseRpc.HasValue
Returns the value contained in this RPC.
value() - Method in class org.hbase.async.KeyValue
Returns the value, the contents of the cell.
value() - Method in class org.hbase.async.PutRequest
Returns the first value of the set of edits in this RPC.
ValueFilter - Class in org.hbase.async
Filter key values based on their value.
ValueFilter(CompareFilter.CompareOp, FilterComparator) - Constructor for class org.hbase.async.ValueFilter
 
valueOf(String) - Static method in enum org.hbase.async.BitComparator.BitwiseOp
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.hbase.async.CompareFilter.CompareOp
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.hbase.async.FilterList.Operator
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.hbase.async.BitComparator.BitwiseOp
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hbase.async.CompareFilter.CompareOp
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hbase.async.FilterList.Operator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface org.hbase.async.HBaseRpc.HasValues
Returns the values contained in this RPC.
values() - Method in class org.hbase.async.PutRequest
Returns the values contained in this RPC.
VersionMismatchException - Exception in org.hbase.async
Indicates that an RPC version mismatch occurred.

W

withRowLock(RowLock) - Method in class org.hbase.async.GetRequest
Specifies an explicit row lock to use with this request.
wrap(byte[]) - Static method in class org.hbase.async.Bytes
Wraps a byte array in a ByteString without copying it.
A B C D E F G H I K L M N O P Q R S T U V W