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

A

abort(TransactionState) - Method in class org.apache.hadoop.hbase.client.transactional.TransactionManager
Abort a s transaction.
abort(byte[], long) - Method in interface org.apache.hadoop.hbase.ipc.TransactionalRegionInterface
Abort the transaction.
abort() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Cause the server to exit without closing the regions it is serving, the log it is using and without notifying the master.
abort(long) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegion
Commit the transaction.
abort(byte[], long) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegionServer
 
abortRequested - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
ACCEPT - Static variable in class org.apache.hadoop.hbase.rest.GenericHandler
 
add(byte[], long) - Method in class org.apache.hadoop.hbase.io.Cell
Add a new timestamp and value to this cell, provided timestamp does not already exist.
add(HStoreKey, byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HStore
Adds a value to the memcache
add(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
add(byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
addColumn(String, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Add a column to an existing table
addColumn(byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Add a column to an existing table
addColumn(byte[], HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.ipc.HMasterInterface
Adds a column to the specified table
addColumn(byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.HMaster
 
addColumn(byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.util.MetaUtils
Offline version of the online TableOperation, org.apache.hadoop.hbase.master.AddColumn.
addDelimiter(byte[]) - Static method in class org.apache.hadoop.hbase.HStoreKey
 
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.
addFilter(RowFilterInterface) - Method in class org.apache.hadoop.hbase.filter.RowFilterSet
Add a filter.
addFromXML(String) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
 
addIndex(IndexSpecification) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
 
addIndex(IndexSpecification) - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
addProcessingMessage(HRegionInfo) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
addRegionAssignment(HRegionInfo, String) - Method in class org.apache.hadoop.hbase.RegionHistorian
Method to add a creation event to the row in the .META table
addRegionCompaction(HRegionInfo, String) - Method in class org.apache.hadoop.hbase.RegionHistorian
Method to add a compaction event to the row in the .META table
addRegionCreation(HRegionInfo) - Method in class org.apache.hadoop.hbase.RegionHistorian
Method to add a creation event to the row in the .META table
addRegionFlush(HRegionInfo, String) - Method in class org.apache.hadoop.hbase.RegionHistorian
Method to add a flush event to the row in the .META table
addRegionInfo(HServerLoad.RegionLoad) - Method in class org.apache.hadoop.hbase.HServerLoad
 
addRegionInfo(byte[], int, int, int, int) - Method in class org.apache.hadoop.hbase.HServerLoad
Deprecated. Use HServerLoad.addRegionInfo(RegionLoad)
addRegionOpen(HRegionInfo, HServerAddress) - Method in class org.apache.hadoop.hbase.RegionHistorian
Method to add a opening event to the row in the .META table
addRegionServer() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
Creates a region server.
addRegionSplit(HRegionInfo, HRegionInfo, HRegionInfo) - Method in class org.apache.hadoop.hbase.RegionHistorian
Method to add a split event to the rows in the .META table with information from oldInfo.
addRegionToMETA(HRegion, HRegion) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Inserts a new region's meta information into the passed meta region.
addRowLock(Integer, HRegion) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
addScanner(InternalScanner) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
addScanner(Scanner) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
Assigns a unique ID to the scanner and adds the mapping to an internal hash-map.
admin - Variable in class org.apache.hadoop.hbase.rest.GenericHandler
 
admin - Variable in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
ALL_META_COLUMNS - Static variable in interface org.apache.hadoop.hbase.HConstants
All the columns in the catalog -ROOT- and .META.
ALL_VERSIONS - Static variable in interface org.apache.hadoop.hbase.HConstants
Define for 'return-all-versions'.
AlreadyExists - Exception in org.apache.hadoop.hbase.thrift.generated
An AlreadyExists exceptions signals that a table with the specified name already exists
AlreadyExists() - Constructor for exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
 
AlreadyExists(String) - Constructor for exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
 
AlreadyExists.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
AlreadyExists.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.AlreadyExists.Isset
 
append(WritableComparable, Writable) - Method in class org.apache.hadoop.hbase.io.BloomFilterMapFile.Writer
 
append(WritableComparable, Writable) - Method in class org.apache.hadoop.hbase.io.MapFile.Writer
Append a key/value pair to the map.
append(Writable, Writable) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Writer
Append a key/value pair.
append(Object, Object) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Writer
Append a key/value pair.
append(HRegionInfo, HLogEdit) - Method in class org.apache.hadoop.hbase.regionserver.HLog
Append an entry without a row to the log.
append(HRegionInfo, byte[], HLogEdit) - Method in class org.apache.hadoop.hbase.regionserver.HLog
Append an entry to the log.
appendKeyValue(StringBuilder, String, Object) - Static method in class org.apache.hadoop.hbase.util.Strings
Append to a StringBuilder a key/value.
appendKeyValue(StringBuilder, String, Object, String, String) - Static method in class org.apache.hadoop.hbase.util.Strings
Append to a StringBuilder a key/value.
appendRaw(byte[], int, int, SequenceFile.ValueBytes) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Writer
 
atomicIncrement(byte[], byte[], byte[], long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
atomicIncrement(byte[], byte[], byte[], long) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
 
atomicIncrement(byte[], byte[], byte[], long) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
available() - Method in class org.apache.hadoop.hbase.io.BlockFSInputStream
 

B

Base64 - Class in org.apache.hadoop.hbase.util
Encodes and decodes to and from Base64 notation.
Base64.Base64InputStream - Class in org.apache.hadoop.hbase.util
A Base64.Base64InputStream will read data from another InputStream, given in the constructor, and encode/decode to/from Base64 notation on the fly.
Base64.Base64InputStream(InputStream) - Constructor for class org.apache.hadoop.hbase.util.Base64.Base64InputStream
Constructs a Base64.Base64InputStream in DECODE mode.
Base64.Base64InputStream(InputStream, int) - Constructor for class org.apache.hadoop.hbase.util.Base64.Base64InputStream
Constructs a Base64.Base64InputStream in either ENCODE or DECODE mode.
Base64.Base64OutputStream - Class in org.apache.hadoop.hbase.util
A Base64.Base64OutputStream will write data to another OutputStream, given in the constructor, and encode/decode to/from Base64 notation on the fly.
Base64.Base64OutputStream(OutputStream) - Constructor for class org.apache.hadoop.hbase.util.Base64.Base64OutputStream
Constructs a Base64.Base64OutputStream in ENCODE mode.
Base64.Base64OutputStream(OutputStream, int) - Constructor for class org.apache.hadoop.hbase.util.Base64.Base64OutputStream
Constructs a Base64.Base64OutputStream in either ENCODE or DECODE mode.
BatchMutation - Class in org.apache.hadoop.hbase.thrift.generated
A BatchMutation object is used to apply a number of Mutations to a single row.
BatchMutation() - Constructor for class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
BatchMutation(byte[], List<Mutation>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
BatchMutation.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
BatchMutation.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.BatchMutation.Isset
 
BatchOperation - Class in org.apache.hadoop.hbase.io
Batch update operation.
BatchOperation() - Constructor for class org.apache.hadoop.hbase.io.BatchOperation
Default constructor
BatchOperation(byte[]) - Constructor for class org.apache.hadoop.hbase.io.BatchOperation
Creates a DELETE batch operation.
BatchOperation(String) - Constructor for class org.apache.hadoop.hbase.io.BatchOperation
Creates a DELETE batch operation.
BatchOperation(String, String) - Constructor for class org.apache.hadoop.hbase.io.BatchOperation
Create a batch operation.
BatchOperation(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.io.BatchOperation
Create a batch operation.
BatchUpdate - Class in org.apache.hadoop.hbase.io
A Writable object that contains a series of BatchOperations There is one BatchUpdate object per server, so a series of batch operations can result in multiple BatchUpdate objects if the batch contains rows that are served by multiple region servers.
BatchUpdate() - Constructor for class org.apache.hadoop.hbase.io.BatchUpdate
Default constructor used serializing.
BatchUpdate(String) - Constructor for class org.apache.hadoop.hbase.io.BatchUpdate
Initialize a BatchUpdate operation on a row.
BatchUpdate(byte[]) - Constructor for class org.apache.hadoop.hbase.io.BatchUpdate
Initialize a BatchUpdate operation on a row.
BatchUpdate(String, long) - Constructor for class org.apache.hadoop.hbase.io.BatchUpdate
Initialize a BatchUpdate operation on a row with a specific timestamp.
BatchUpdate(BatchUpdate) - Constructor for class org.apache.hadoop.hbase.io.BatchUpdate
Recopy constructor
BatchUpdate(byte[], long) - Constructor for class org.apache.hadoop.hbase.io.BatchUpdate
Initialize a BatchUpdate operation on a row with a specific timestamp.
BatchUpdate(RowResult) - Constructor for class org.apache.hadoop.hbase.io.BatchUpdate
Create a batch operation.
batchUpdate(byte[], BatchUpdate, long) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
Applies a batch of updates via one RPC
batchUpdate(long, byte[], BatchUpdate) - Method in interface org.apache.hadoop.hbase.ipc.TransactionalRegionInterface
Applies a batch of updates via one RPC
batchUpdate(BatchUpdate) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
batchUpdate(BatchUpdate, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
batchUpdate(BatchUpdate, Integer) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
batchUpdate(BatchUpdate, Integer, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
batchUpdate(byte[], BatchUpdate, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
batchUpdate(long, BatchUpdate) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegion
Add a write to the transaction.
batchUpdate(long, byte[], BatchUpdate) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegionServer
 
batchUpdates(byte[], BatchUpdate[]) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
Applies a batch of updates via one RPC for many rows
batchUpdates(byte[], BatchUpdate[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
beginTransaction() - Method in class org.apache.hadoop.hbase.client.transactional.TransactionManager
Called to start a transaction.
beginTransaction(long, byte[]) - Method in interface org.apache.hadoop.hbase.ipc.TransactionalRegionInterface
Sent to initiate a transaction.
beginTransaction(long) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegion
 
beginTransaction(long, byte[]) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegionServer
 
bind(ServerSocket, InetSocketAddress, int) - Static method in class org.apache.hadoop.hbase.ipc.HBaseServer
A convenience method to bind to a given address and report better exceptions if the address is not a valid host.
BLOCKCACHE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
blockCacheEnabled - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
blockCacheEnabled - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor.Isset
 
BlockFSInputStream - Class in org.apache.hadoop.hbase.io
An implementation of FSInputStream that reads the stream in blocks of a fixed, configurable size.
BlockFSInputStream(InputStream, long, int) - Constructor for class org.apache.hadoop.hbase.io.BlockFSInputStream
 
BLOOMFILTER - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
BLOOMFILTER_FILE_NAME - Static variable in class org.apache.hadoop.hbase.io.BloomFilterMapFile
 
BloomFilterMapFile - Class in org.apache.hadoop.hbase.io
On write, all keys are added to a bloom filter.
BloomFilterMapFile() - Constructor for class org.apache.hadoop.hbase.io.BloomFilterMapFile
 
BloomFilterMapFile.Reader - Class in org.apache.hadoop.hbase.io
 
BloomFilterMapFile.Reader(FileSystem, String, Configuration, boolean, boolean, HRegionInfo) - Constructor for class org.apache.hadoop.hbase.io.BloomFilterMapFile.Reader
 
BloomFilterMapFile.Writer - Class in org.apache.hadoop.hbase.io
 
BloomFilterMapFile.Writer(Configuration, FileSystem, String, SequenceFile.CompressionType, boolean, int, HRegionInfo) - Constructor for class org.apache.hadoop.hbase.io.BloomFilterMapFile.Writer
 
bloomFilterNbHashes - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
bloomFilterNbHashes - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor.Isset
 
bloomFilterType - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
bloomFilterType - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor.Isset
 
bloomFilterVectorSize - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
bloomFilterVectorSize - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor.Isset
 
BuildTableIndex - Class in org.apache.hadoop.hbase.mapred
Example table column indexing class.
BuildTableIndex() - Constructor for class org.apache.hadoop.hbase.mapred.BuildTableIndex
default constructor
Bytes - Class in org.apache.hadoop.hbase.util
Utility class that handles byte arrays, conversions to/from other types, comparisons, hash code generation, manufacturing keys for HashMaps or HashSets, etc.
Bytes() - Constructor for class org.apache.hadoop.hbase.util.Bytes
 
BYTES_COMPARATOR - Static variable in class org.apache.hadoop.hbase.util.Bytes
Pass this to TreeMaps where byte [] are keys.

C

call() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
call(Writable, InetSocketAddress) - Method in class org.apache.hadoop.hbase.ipc.HBaseClient
Make a call, passing param, to the IPC server running at address, returning the value.
call(Writable, InetSocketAddress, UserGroupInformation) - Method in class org.apache.hadoop.hbase.ipc.HBaseClient
 
call(Writable[], InetSocketAddress[]) - Method in class org.apache.hadoop.hbase.ipc.HBaseClient
Makes a set of calls in parallel.
call(Method, Object[][], InetSocketAddress[], Configuration) - Static method in class org.apache.hadoop.hbase.ipc.HBaseRPC
Expert: Make multiple, parallel calls to a set of servers.
call(Writable, long) - Method in class org.apache.hadoop.hbase.ipc.HBaseRPC.Server
 
call(Writable, long) - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
Called for each call.
cancelLease(String) - Method in class org.apache.hadoop.hbase.Leases
Client explicitly cancels a lease.
Cell - Class in org.apache.hadoop.hbase.io
Cell - Used to transport a cell value (byte[]) and the timestamp it was stored with together as a result for get and getRow methods.
Cell() - Constructor for class org.apache.hadoop.hbase.io.Cell
For Writable compatibility
Cell(String, long) - Constructor for class org.apache.hadoop.hbase.io.Cell
Create a new Cell with a given value and timestamp.
Cell(byte[], long) - Constructor for class org.apache.hadoop.hbase.io.Cell
Create a new Cell with a given value and timestamp.
Cell(String[], long[]) - Constructor for class org.apache.hadoop.hbase.io.Cell
 
Cell(byte[][], long[]) - Constructor for class org.apache.hadoop.hbase.io.Cell
 
cellFromHBase(Cell) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
This utility method creates a new Thrift TCell "struct" based on an Hbase Cell object.
cellToLong(Cell) - Static method in class org.apache.hadoop.hbase.util.Writables
 
cellToString(Cell) - Static method in class org.apache.hadoop.hbase.util.Writables
 
ChangedReadersObserver - Interface in org.apache.hadoop.hbase.regionserver
If set of MapFile.Readers in Store change, implementors are notified.
changeOnlineStatus(HBaseConfiguration, byte[], boolean) - Static method in class org.apache.hadoop.hbase.util.MetaUtils
Set a single region on/offline.
checkAndSave(BatchUpdate, HbaseMapWritable<byte[], byte[]>, RowLock) - Method in class org.apache.hadoop.hbase.client.HTable
Atomically checks if a row's values match the expectedValues.
checkAndSave(byte[], BatchUpdate, HbaseMapWritable<byte[], byte[]>) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
Applies a batch of updates to one row atomically via one RPC if the columns specified in expectedValues match the given values in expectedValues
checkAndSave(BatchUpdate, HbaseMapWritable<byte[], byte[]>, Integer, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Performs an atomic check and save operation.
checkAndSave(byte[], BatchUpdate, HbaseMapWritable<byte[], byte[]>) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
checkFileSystem() - Method in class org.apache.hadoop.hbase.master.HMaster
Checks to see if the file system is still accessible.
checkFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Checks to see if the file system is still accessible.
checkFileSystemAvailable(FileSystem) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Checks to see if the specified file system is available
checkHBaseAvailable(HBaseConfiguration) - Static method in class org.apache.hadoop.hbase.client.HBaseAdmin
Check to see if HBase is running.
checkIOException(IOException) - Static method in class org.apache.hadoop.hbase.RemoteExceptionHandler
Examine passed IOException.
checkOOME(Throwable) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRPCErrorHandler
Take actions on the event of an OutOfMemoryError.
checkOOME(Throwable) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
checkOpen() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Called to verify that this server is up and running.
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat
 
checkReadOnly() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
checkReferences() - Method in class org.apache.hadoop.hbase.io.BlockFSInputStream
Call frequently to clear Soft Reference Reference Queue.
checkReferences() - Method in class org.apache.hadoop.hbase.util.SoftValueMap
Checks soft references and cleans any that have been placed on ReferenceQueue.
checkReferences() - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
Checks soft references and cleans any that have been placed on ReferenceQueue.
checkThrowable(Throwable) - Static method in class org.apache.hadoop.hbase.RemoteExceptionHandler
Examine passed Throwable.
checkVersion(FileSystem, Path, boolean) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Verifies current version of file system
Chore - Class in org.apache.hadoop.hbase
Chore is a task performed on a period in hbase.
Chore(int, AtomicBoolean) - Constructor for class org.apache.hadoop.hbase.Chore
 
chore() - Method in class org.apache.hadoop.hbase.Chore
Look for chores.
chore() - Method in class org.apache.hadoop.hbase.regionserver.LogFlusher
 
cleanRegionInMETA(HRegionInterface, byte[], HRegionInfo) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Clean COL_SERVER and COL_STARTCODE for passed info in .META.
cleanup() - Method in class org.apache.hadoop.hbase.io.SequenceFile.Sorter.SegmentDescriptor
The default cleanup.
clear() - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
clear() - Method in class org.apache.hadoop.hbase.io.RowResult
 
clear() - Method in class org.apache.hadoop.hbase.util.SoftValueMap
 
clear() - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
cloneFileAttributes(Path, Path, Progressable) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Sorter
Clones the attributes (like compression of the input file and creates a corresponding Writer
close() - Method in class org.apache.hadoop.hbase.client.HTable.ClientScanner
 
close() - Method in class org.apache.hadoop.hbase.client.HTable
Release held resources
close() - Method in interface org.apache.hadoop.hbase.client.Scanner
Closes the scanner and releases any resources it has allocated
close() - Method in class org.apache.hadoop.hbase.io.BlockFSInputStream
 
close() - Method in class org.apache.hadoop.hbase.io.BloomFilterMapFile.Writer
 
close() - Method in class org.apache.hadoop.hbase.io.MapFile.Reader
Close the map.
close() - Method in class org.apache.hadoop.hbase.io.MapFile.Writer
Close the map.
close() - Method in class org.apache.hadoop.hbase.io.SequenceFile.Reader
Close the file.
close() - Method in interface org.apache.hadoop.hbase.io.SequenceFile.Sorter.RawKeyValueIterator
closes the iterator so that the underlying streams can be closed
close() - Method in class org.apache.hadoop.hbase.io.SequenceFile.Writer
Close the file.
close(long) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
Close a scanner
close() - Method in class org.apache.hadoop.hbase.Leases
Shut down this Leases instance.
close() - Method in class org.apache.hadoop.hbase.mapred.IndexTableReduce
 
close() - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase.TableRecordReader
 
close(Reporter) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat.TableRecordWriter
 
close() - Method in class org.apache.hadoop.hbase.regionserver.HLog
Shut down the log.
close() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Close down this HRegion.
close(long) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
close() - Method in interface org.apache.hadoop.hbase.regionserver.InternalScanner
Closes the scanner and releases any resources it has allocated
close() - Method in class org.apache.hadoop.hbase.util.Base64.Base64OutputStream
Flushes and closes (I think, in the superclass) the stream.
closeAfterLeasesExpire() - Method in class org.apache.hadoop.hbase.Leases
Shuts down this lease instance when all outstanding leases expire.
closeAndDelete() - Method in class org.apache.hadoop.hbase.regionserver.HLog
Shut down the log and delete the log directory
closeRegion(String, Object...) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Close a region.
closeRegion(byte[], Object...) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Close a region.
COL_REGIONINFO - Static variable in interface org.apache.hadoop.hbase.HConstants
ROOT/META column family member - contains HRegionInfo
COL_REGIONINFO_ARRAY - Static variable in interface org.apache.hadoop.hbase.HConstants
Array of column - contains HRegionInfo
COL_SERVER - Static variable in interface org.apache.hadoop.hbase.HConstants
ROOT/META column family member - contains HServerAddress.toString()
COL_SPLITA - Static variable in interface org.apache.hadoop.hbase.HConstants
the lower half of a split region
COL_SPLITB - Static variable in interface org.apache.hadoop.hbase.HConstants
the upper half of a split region
COL_STARTCODE - Static variable in interface org.apache.hadoop.hbase.HConstants
ROOT/META column family member - contains server start code (a long)
colDescFromHbase(HColumnDescriptor) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
This utility method creates a new Thrift ColumnDescriptor "struct" based on an Hbase HColumnDescriptor object.
colDescFromThrift(ColumnDescriptor) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
This utility method creates a new Hbase HColumnDescriptor object based on a Thrift ColumnDescriptor "struct".
COLUMN - Static variable in class org.apache.hadoop.hbase.rest.GenericHandler
 
column - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
column - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args.Isset
 
column - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
column - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args.Isset
 
column - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
column - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args.Isset
 
column - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
column - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args.Isset
 
column - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
column - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args.Isset
 
column - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
column - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args.Isset
 
column - Variable in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
column - Variable in class org.apache.hadoop.hbase.thrift.generated.Mutation.Isset
 
COLUMN_FAMILY - Static variable in interface org.apache.hadoop.hbase.HConstants
The ROOT and META column family
COLUMN_FAMILY_ARRAY - Static variable in interface org.apache.hadoop.hbase.HConstants
Array of meta column names
COLUMN_FAMILY_DELIMITER - Static variable in class org.apache.hadoop.hbase.HStoreKey
Colon character in UTF-8
COLUMN_FAMILY_HISTORIAN - Static variable in interface org.apache.hadoop.hbase.HConstants
The META historian column family
COLUMN_FAMILY_HISTORIAN_STR - Static variable in interface org.apache.hadoop.hbase.HConstants
The META historian column family (string)
COLUMN_FAMILY_STR - Static variable in interface org.apache.hadoop.hbase.HConstants
The ROOT and META column family (string)
COLUMN_LIST - Static variable in class org.apache.hadoop.hbase.mapred.TableInputFormat
space delimited list of columns
ColumnDescriptor - Class in org.apache.hadoop.hbase.thrift.generated
An HColumnDescriptor contains information about a column family such as the number of versions, compression settings, etc.
ColumnDescriptor() - Constructor for class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
ColumnDescriptor(byte[], int, String, boolean, int, String, int, int, boolean, int) - Constructor for class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
ColumnDescriptor.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
ColumnDescriptor.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor.Isset
 
columnFamilies - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
columnFamilies - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args.Isset
 
columnMatch(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HAbstractScanner
For a particular column, find all the matchers defined for the column.
columnNameIterator() - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
 
ColumnNameParseException - Exception in org.apache.hadoop.hbase
Thrown if issue with passed column name.
ColumnNameParseException() - Constructor for exception org.apache.hadoop.hbase.ColumnNameParseException
default constructor
ColumnNameParseException(String) - Constructor for exception org.apache.hadoop.hbase.ColumnNameParseException
 
columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args.Isset
 
columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args.Isset
 
columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args.Isset
 
columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args.Isset
 
columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args.Isset
 
columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args.Isset
 
columns - Variable in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
columns - Variable in class org.apache.hadoop.hbase.thrift.generated.TRowResult.Isset
 
ColumnValueFilter - Class in org.apache.hadoop.hbase.filter
This filter is used to filter based on the value of a given column.
ColumnValueFilter(byte[], ColumnValueFilter.CompareOp, byte[]) - Constructor for class org.apache.hadoop.hbase.filter.ColumnValueFilter
Constructor.
ColumnValueFilter(byte[], ColumnValueFilter.CompareOp, byte[], boolean) - Constructor for class org.apache.hadoop.hbase.filter.ColumnValueFilter
Constructor.
ColumnValueFilter(byte[], ColumnValueFilter.CompareOp, WritableByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.ColumnValueFilter
Constructor.
ColumnValueFilter(byte[], ColumnValueFilter.CompareOp, WritableByteArrayComparable, boolean) - Constructor for class org.apache.hadoop.hbase.filter.ColumnValueFilter
Constructor.
ColumnValueFilter.CompareOp - Enum in org.apache.hadoop.hbase.filter
Comparison operators.
commit(BatchUpdate) - Method in class org.apache.hadoop.hbase.client.HTable
Commit a BatchUpdate to the table.
commit(BatchUpdate, RowLock) - Method in class org.apache.hadoop.hbase.client.HTable
Commit a BatchUpdate to the table using existing row lock.
commit(List<BatchUpdate>) - Method in class org.apache.hadoop.hbase.client.HTable
Commit a List of BatchUpdate to the table.
commit(TransactionState, BatchUpdate) - Method in class org.apache.hadoop.hbase.client.transactional.TransactionalTable
Commit a BatchUpdate to the table.
commit(byte[], long) - Method in interface org.apache.hadoop.hbase.ipc.TransactionalRegionInterface
Commit the transaction.
commit(long) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegion
Commit the transaction.
commit(byte[], long) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegionServer
 
commitRequest(byte[], long) - Method in interface org.apache.hadoop.hbase.ipc.TransactionalRegionInterface
Ask if we can commit the given transaction.
commitRequest(long) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegion
 
commitRequest(byte[], long) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegionServer
 
CommitUnsuccessfulException - Exception in org.apache.hadoop.hbase.client.transactional
Thrown when a transaction cannot be committed.
CommitUnsuccessfulException() - Constructor for exception org.apache.hadoop.hbase.client.transactional.CommitUnsuccessfulException
Default Constructor
CommitUnsuccessfulException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.client.transactional.CommitUnsuccessfulException
 
CommitUnsuccessfulException(String) - Constructor for exception org.apache.hadoop.hbase.client.transactional.CommitUnsuccessfulException
 
CommitUnsuccessfulException(Throwable) - Constructor for exception org.apache.hadoop.hbase.client.transactional.CommitUnsuccessfulException
 
compact(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Compact a table or an individual region
compact(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Compact a table or an individual region
compactStores() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Called by compaction thread and after region is opened to compact the HStores if necessary.
comparator() - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
comparator() - Method in class org.apache.hadoop.hbase.io.RowResult
 
comparator() - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
compare(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.tableindexed.ReverseByteArrayComparator
compare(WritableComparable, WritableComparable) - Method in class org.apache.hadoop.hbase.HStoreKey.HStoreKeyWritableComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable.Comparator
 
compareTo(byte[]) - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator
 
compareTo(byte[]) - 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(HServerAddress) - Method in class org.apache.hadoop.hbase.HServerAddress
 
compareTo(HServerInfo) - Method in class org.apache.hadoop.hbase.HServerInfo
 
compareTo(HServerLoad) - Method in class org.apache.hadoop.hbase.HServerLoad
 
compareTo(HStoreKey) - Method in class org.apache.hadoop.hbase.HStoreKey.BeforeThisStoreKey
 
compareTo(HStoreKey) - Method in class org.apache.hadoop.hbase.HStoreKey
 
compareTo(HTableDescriptor) - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
compareTo(BatchUpdate) - Method in class org.apache.hadoop.hbase.io.BatchUpdate
 
compareTo(ImmutableBytesWritable) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
Define the sort order of the BytesWritable.
compareTo(byte[]) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
Compares the bytes in this object to the specified byte array
compareTo(Object) - Method in class org.apache.hadoop.hbase.io.RowResult
Comparing this RowResult with another one by comparing the row in it.
compareTo(Object) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Sorter.SegmentDescriptor
 
compareTo(Object) - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
compareTo(MetaRegion) - Method in class org.apache.hadoop.hbase.master.MetaRegion
 
compareTo(RegionHistorian.RegionHistoryInformation) - Method in class org.apache.hadoop.hbase.RegionHistorian.RegionHistoryInformation
 
compareTo(Object) - Method in class org.apache.hadoop.hbase.regionserver.HLogKey
 
compareTo(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
compareTo(byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
compareTwoRowKeys(HRegionInfo, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.HStoreKey
Utility method to compare two row keys.
completeCacheFlush - Static variable in class org.apache.hadoop.hbase.regionserver.HLogEdit
Value written to HLog on a complete cache flush
compressedValSerializer - Variable in class org.apache.hadoop.hbase.io.SequenceFile.Writer
 
COMPRESSION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
compression - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
compression - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor.Isset
 
computeFilename(long) - Method in class org.apache.hadoop.hbase.regionserver.HLog
This is a convenience method that computes a new filename with a given file-number.
conf - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
conf - Variable in class org.apache.hadoop.hbase.rest.GenericHandler
 
conf - Variable in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
 
configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.HRegionPartitioner
 
configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.IndexTableReduce
 
configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormat
 
connection - Variable in class org.apache.hadoop.hbase.client.ServerCallable
 
Constants - Class in org.apache.hadoop.hbase.thrift.generated
 
Constants() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Constants
 
containsColumn(byte[]) - Method in class org.apache.hadoop.hbase.client.tableindexed.IndexSpecification
 
containsKey(Object) - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
containsKey(Object) - Method in class org.apache.hadoop.hbase.io.RowResult
 
containsKey(String) - Method in class org.apache.hadoop.hbase.io.RowResult
 
containsKey(Object) - Method in class org.apache.hadoop.hbase.util.SoftValueMap
 
containsKey(Object) - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
containsValue(Object) - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
containsValue(Object) - Method in class org.apache.hadoop.hbase.io.RowResult
 
containsValue(Object) - Method in class org.apache.hadoop.hbase.util.SoftValueMap
 
containsValue(Object) - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
CONTENT_TYPE - Static variable in class org.apache.hadoop.hbase.rest.GenericHandler
 
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.
countRegionsOnFS() - Method in class org.apache.hadoop.hbase.master.HMaster
 
createConfigurationSubset() - Method in class org.apache.hadoop.hbase.master.HMaster
 
createDataFileReader(FileSystem, Path, Configuration) - Method in class org.apache.hadoop.hbase.io.HBaseMapFile.HBaseReader
 
createDataFileReader(FileSystem, Path, Configuration) - Method in class org.apache.hadoop.hbase.io.MapFile.Reader
Override this method to specialize the type of SequenceFile.Reader returned.
createGroupKey(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
Create a key by concatenating multiple column values.
createHRegion(HRegionInfo, Path, HBaseConfiguration) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Convenience method creating new HRegions.
createIndexKey(byte[], Map<byte[], byte[]>) - Method in interface org.apache.hadoop.hbase.client.tableindexed.IndexKeyGenerator
 
createIndexKey(byte[], Map<byte[], byte[]>) - Method in class org.apache.hadoop.hbase.client.tableindexed.SimpleIndexKeyGenerator
createJob(Configuration, int, int, String, String, String) - Method in class org.apache.hadoop.hbase.mapred.BuildTableIndex
 
createKey() - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase.TableRecordReader
 
createKey(String) - Static method in class org.apache.hadoop.hbase.util.Keying
Makes a key out of passed URI for use as row name or column qualifier.
createLease(String, LeaseListener) - Method in class org.apache.hadoop.hbase.Leases
Obtain a lease
createNewTransactionLog() - Method in class org.apache.hadoop.hbase.client.transactional.LocalTransactionLogger
 
createNewTransactionLog() - Method in interface org.apache.hadoop.hbase.client.transactional.TransactionLogger
Create a new transaction log.
createRegionLoad(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
createRegionName(byte[], byte[], String) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Make a region name of passed parameters.
createRegionName(byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Make a region name of passed parameters.
createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.mapred.RowCounter
 
createTable(HTableDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Creates a new table
createTable(HTableDescriptor) - Method in class org.apache.hadoop.hbase.client.tableindexed.IndexedTableAdmin
Creates a new table
createTable(HTableDescriptor) - Method in interface org.apache.hadoop.hbase.ipc.HMasterInterface
Creates a new table
createTable(HTableDescriptor) - Method in class org.apache.hadoop.hbase.master.HMaster
 
createTable(byte[], List<ColumnDescriptor>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
createTable(byte[], List<ColumnDescriptor>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Create a table with the specified column families.
createTable(byte[], List<ColumnDescriptor>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
createTableAsync(HTableDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Creates a new table but does not block and wait for it to come online.
createValue() - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase.TableRecordReader
 
createValueBytes() - Method in class org.apache.hadoop.hbase.io.SequenceFile.Reader
 
createWriter(FileSystem, Configuration, Path, Class, Class) - Static method in class org.apache.hadoop.hbase.io.SequenceFile
Construct the preferred type of SequenceFile Writer.
createWriter(FileSystem, Configuration, Path, Class, Class, SequenceFile.CompressionType) - Static method in class org.apache.hadoop.hbase.io.SequenceFile
Construct the preferred type of SequenceFile Writer.
createWriter(FileSystem, Configuration, Path, Class, Class, SequenceFile.CompressionType, Progressable) - Static method in class org.apache.hadoop.hbase.io.SequenceFile
Construct the preferred type of SequenceFile Writer.
createWriter(FileSystem, Configuration, Path, Class, Class, SequenceFile.CompressionType, CompressionCodec) - Static method in class org.apache.hadoop.hbase.io.SequenceFile
Construct the preferred type of SequenceFile Writer.
createWriter(FileSystem, Configuration, Path, Class, Class, SequenceFile.CompressionType, CompressionCodec, Progressable, SequenceFile.Metadata) - Static method in class org.apache.hadoop.hbase.io.SequenceFile
Construct the preferred type of SequenceFile Writer.
createWriter(FileSystem, Configuration, Path, Class, Class, int, short, long, SequenceFile.CompressionType, CompressionCodec, Progressable, SequenceFile.Metadata) - Static method in class org.apache.hadoop.hbase.io.SequenceFile
Construct the preferred type of SequenceFile Writer.
createWriter(FileSystem, Configuration, Path, Class, Class, SequenceFile.CompressionType, CompressionCodec, Progressable) - Static method in class org.apache.hadoop.hbase.io.SequenceFile
Construct the preferred type of SequenceFile Writer.
createWriter(Configuration, FSDataOutputStream, Class, Class, SequenceFile.CompressionType, CompressionCodec, SequenceFile.Metadata) - Static method in class org.apache.hadoop.hbase.io.SequenceFile
Construct the preferred type of 'raw' SequenceFile Writer.
createWriter(Configuration, FSDataOutputStream, Class, Class, SequenceFile.CompressionType, CompressionCodec) - Static method in class org.apache.hadoop.hbase.io.SequenceFile
Construct the preferred type of 'raw' SequenceFile Writer.
CURRENT_VERSION - Static variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 

D

DATA_FILE_NAME - Static variable in class org.apache.hadoop.hbase.io.MapFile
The name of the data file.
DataOutputBuffer - Class in org.apache.hadoop.hbase.io
A reusable DataOutput implementation that writes to an in-memory buffer.
DataOutputBuffer() - Constructor for class org.apache.hadoop.hbase.io.DataOutputBuffer
Constructs a new empty buffer.
DataOutputBuffer(int) - Constructor for class org.apache.hadoop.hbase.io.DataOutputBuffer
 
DECODE - Static variable in class org.apache.hadoop.hbase.util.Base64
Specify decoding.
decode(byte[], int, int, int) - Static method in class org.apache.hadoop.hbase.util.Base64
Very low-level access to decoding ASCII characters in the form of a byte array.
decode(String) - Static method in class org.apache.hadoop.hbase.util.Base64
Decodes data from Base64 notation, automatically detecting gzip-compressed data and decompressing it.
decode(String, int) - Static method in class org.apache.hadoop.hbase.util.Base64
Decodes data from Base64 notation, automatically detecting gzip-compressed data and decompressing it.
decode4to3(byte[], int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Base64
Decodes four bytes from array source and writes the resulting bytes (up to three of them) to destination.
decodeFileToFile(String, String) - Static method in class org.apache.hadoop.hbase.util.Base64
Reads infile and decodes it to outfile.
decodeFromFile(String) - Static method in class org.apache.hadoop.hbase.util.Base64
Convenience method for reading a base64-encoded file and decoding it.
decodeRemoteException(RemoteException) - Static method in class org.apache.hadoop.hbase.RemoteExceptionHandler
Converts org.apache.hadoop.ipc.RemoteException into original exception, if possible.
decodeToFile(String, String) - Static method in class org.apache.hadoop.hbase.util.Base64
Convenience method for decoding data to a file.
decodeToObject(String) - Static method in class org.apache.hadoop.hbase.util.Base64
Attempts to decode Base64 data and deserialize a Java Object within.
DEFAULT_BLOCKCACHE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default setting for whether to use a block cache or not.
DEFAULT_BLOOMFILTER - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default setting for whether or not to use bloomfilters.
DEFAULT_COMPRESSION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default compression type.
DEFAULT_HOST - Static variable in interface org.apache.hadoop.hbase.HConstants
default host address
DEFAULT_IN_MEMORY - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default setting for whether to serve from memory or not.
DEFAULT_IN_MEMORY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
DEFAULT_KEYVALUE_SEPARATOR - Static variable in class org.apache.hadoop.hbase.util.Strings
 
DEFAULT_LENGTH - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default maximum cell length.
DEFAULT_LENGTH_INTEGER - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
DEFAULT_MAPFILE_INDEX_INTERVAL - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default mapfile index interval.
DEFAULT_MASTER_ADDRESS - Static variable in interface org.apache.hadoop.hbase.HConstants
Default master address
DEFAULT_MASTER_INFOPORT - Static variable in interface org.apache.hadoop.hbase.HConstants
default port for master web api
DEFAULT_MASTER_PORT - Static variable in interface org.apache.hadoop.hbase.HConstants
default port that the master listens on
DEFAULT_MAX_FILE_SIZE - Static variable in interface org.apache.hadoop.hbase.HConstants
Default maximum file size
DEFAULT_MAX_FILESIZE - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
DEFAULT_MEMCACHE_FLUSH_SIZE - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
DEFAULT_READONLY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
DEFAULT_REGION_SERVER_CLASS - Static variable in interface org.apache.hadoop.hbase.HConstants
Default region server interface class name.
DEFAULT_REGIONSERVER_ADDRESS - Static variable in interface org.apache.hadoop.hbase.HConstants
Default region server address
DEFAULT_REGIONSERVER_INFOPORT - Static variable in interface org.apache.hadoop.hbase.HConstants
default port for region server web api
DEFAULT_SEPARATOR - Static variable in class org.apache.hadoop.hbase.util.Strings
 
DEFAULT_SIZE_RESERVATION_BLOCK - Static variable in interface org.apache.hadoop.hbase.HConstants
Default size of a reservation block
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.
delete(String) - Method in class org.apache.hadoop.hbase.io.BatchUpdate
Delete the value for a column Deletes the cell whose row/column/commit-timestamp match those of the delete.
delete(byte[]) - Method in class org.apache.hadoop.hbase.io.BatchUpdate
Delete the value for a column Deletes the cell whose row/column/commit-timestamp match those of the delete.
delete(FileSystem, String) - Static method in class org.apache.hadoop.hbase.io.MapFile
Deletes the named map file.
delete() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
Delete store map files.
deleteAll(byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Completely delete the row's cells.
deleteAll(String) - Method in class org.apache.hadoop.hbase.client.HTable
Completely delete the row's cells.
deleteAll(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Completely delete the row's cells.
deleteAll(byte[], long) - Method in class org.apache.hadoop.hbase.client.HTable
Completely delete the row's cells.
deleteAll(String, long) - Method in class org.apache.hadoop.hbase.client.HTable
Completely delete the row's cells.
deleteAll(String, String) - Method in class org.apache.hadoop.hbase.client.HTable
Delete all cells that match the passed row and column.
deleteAll(String, String, long) - Method in class org.apache.hadoop.hbase.client.HTable
Delete all cells that match the passed row and column and whose timestamp is equal-to or older than the passed timestamp.
deleteAll(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.HTable
Delete all cells that match the passed row and column and whose timestamp is equal-to or older than the passed timestamp.
deleteAll(byte[], byte[], long, RowLock) - Method in class org.apache.hadoop.hbase.client.HTable
Delete all cells that match the passed row and column and whose timestamp is equal-to or older than the passed timestamp, using an existing row lock.
deleteAll(TransactionState, byte[], long) - Method in class org.apache.hadoop.hbase.client.transactional.TransactionalTable
Delete all cells that match the passed row and whose timestamp is equal-to or older than the passed timestamp.
deleteAll(byte[], byte[], byte[], long, long) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
Delete all cells that match the passed row and column and whose timestamp is equal-to or older than the passed timestamp.
deleteAll(byte[], byte[], long, long) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
Delete all cells that match the passed row and whose timestamp is equal-to or older than the passed timestamp.
deleteAll(long, byte[], byte[], long) - Method in interface org.apache.hadoop.hbase.ipc.TransactionalRegionInterface
Delete all cells that match the passed row and whose timestamp is equal-to or older than the passed timestamp.
deleteAll(byte[], byte[], long, Integer) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Delete all cells of the same age as the passed timestamp or older.
deleteAll(byte[], long, Integer) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Delete all cells of the same age as the passed timestamp or older.
deleteAll(byte[], byte[], byte[], long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
deleteAll(byte[], byte[], long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
deleteAll(long, byte[], long) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegion
Add a delete to the transaction.
deleteAll(long, byte[], byte[], long) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegionServer
 
deleteAll(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
deleteAll(byte[], byte[], byte[]) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Delete all cells that match the passed row and column.
deleteAll(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
deleteAllByRegex(String, String) - Method in class org.apache.hadoop.hbase.client.HTable
Delete all cells that match the passed row and column.
deleteAllByRegex(String, String, long) - Method in class org.apache.hadoop.hbase.client.HTable
Delete all cells that match the passed row and column and whose timestamp is equal-to or older than the passed timestamp.
deleteAllByRegex(byte[], String, long) - Method in class org.apache.hadoop.hbase.client.HTable
Delete all cells that match the passed row and column and whose timestamp is equal-to or older than the passed timestamp.
deleteAllByRegex(byte[], String, long, RowLock) - Method in class org.apache.hadoop.hbase.client.HTable
Delete all cells that match the passed row and column and whose timestamp is equal-to or older than the passed timestamp, using an existing row lock.
deleteAllByRegex(byte[], byte[], String, long, long) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
Delete all cells that match the passed row & the column regex and whose timestamp is equal-to or older than the passed timestamp.
deleteAllByRegex(byte[], String, long, Integer) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Delete all cells for a row with matching columns with timestamps less than or equal to timestamp.
deleteAllByRegex(byte[], byte[], String, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
deleteAllRow(byte[], byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
deleteAllRow(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Completely delete the row's cells.
deleteAllRow(byte[], byte[]) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
deleteAllRowTs(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
deleteAllRowTs(byte[], byte[], long) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Completely delete the row's cells marked with a timestamp equal-to or older than the passed timestamp.
deleteAllRowTs(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
deleteAllTs(byte[], byte[], byte[], long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
deleteAllTs(byte[], byte[], byte[], long) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Delete all cells that match the passed row and column and whose timestamp is equal-to or older than the passed timestamp.
deleteAllTs(byte[], byte[], byte[], long) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
deleteBytes - Static variable in class org.apache.hadoop.hbase.regionserver.HLogEdit
Value stored for a deleted item
deleteColumn(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Delete a column from a table
deleteColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Delete a column from a table
deleteColumn(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.ipc.HMasterInterface
Deletes a column from the specified table
deleteColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.master.HMaster
 
deleteColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.MetaUtils
Offline version of the online TableOperation, org.apache.hadoop.hbase.master.DeleteColumn.
deleteColumnFamily(FileSystem, Path, int, byte[]) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Delete the directories used by the column family under the passed region.
deleteConnectionInfo(HBaseConfiguration, boolean) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Delete connection information for the instance specified by configuration
deleteEmptyMetaRows(HRegionInterface, byte[], List<byte[]>) - Method in class org.apache.hadoop.hbase.master.HMaster
 
deleteFamily(String, String) - Method in class org.apache.hadoop.hbase.client.HTable
Delete all cells for a row with matching column family at all timestamps.
deleteFamily(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Delete all cells for a row with matching column family at all timestamps.
deleteFamily(String, String, long) - Method in class org.apache.hadoop.hbase.client.HTable
Delete all cells for a row with matching column family with timestamps less than or equal to timestamp.
deleteFamily(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.HTable
Delete all cells for a row with matching column family with timestamps less than or equal to timestamp.
deleteFamily(byte[], byte[], long, RowLock) - Method in class org.apache.hadoop.hbase.client.HTable
Delete all cells for a row with matching column family with timestamps less than or equal to timestamp, using existing row lock.
deleteFamily(byte[], byte[], byte[], long, long) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
Delete all cells for a row with matching column family with timestamps less than or equal to timestamp.
deleteFamily(byte[], byte[], long, Integer) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Delete all cells for a row with matching column family with timestamps less than or equal to timestamp.
deleteFamily(byte[], byte[], byte[], long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
deleteFamilyByRegex(String, String) - Method in class org.apache.hadoop.hbase.client.HTable
Delete all cells for a row with matching column family regex at all timestamps.
deleteFamilyByRegex(byte[], String) - Method in class org.apache.hadoop.hbase.client.HTable
Delete all cells for a row with matching column family regex at all timestamps.
deleteFamilyByRegex(String, String, long) - Method in class org.apache.hadoop.hbase.client.HTable
Delete all cells for a row with matching column family regex with timestamps less than or equal to timestamp.
deleteFamilyByRegex(byte[], String, long) - Method in class org.apache.hadoop.hbase.client.HTable
Delete all cells for a row with matching column family regex with timestamps less than or equal to timestamp.
deleteFamilyByRegex(byte[], String, long, RowLock) - Method in class org.apache.hadoop.hbase.client.HTable
Delete all cells for a row with matching column family regex with timestamps less than or equal to timestamp, using existing row lock.
deleteFamilyByRegex(byte[], byte[], String, long, long) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
Delete all cells for a row with matching column family regex with timestamps less than or equal to timestamp.
deleteFamilyByRegex(byte[], String, long, Integer) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Delete all cells for a row with all the matching column families by familyRegex with timestamps less than or equal to timestamp.
deleteFamilyByRegex(byte[], byte[], String, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
deleteRegion(FileSystem, Path, HRegionInfo) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Deletes all the files for a HRegion
deleteTable(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Deletes a table
deleteTable(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Deletes a table
deleteTable(byte[]) - Method in interface org.apache.hadoop.hbase.ipc.HMasterInterface
Deletes a table
deleteTable(byte[]) - Method in class org.apache.hadoop.hbase.master.HMaster
 
deleteTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
deleteTable(byte[]) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Deletes a table
deleteTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
DELIMITER - Static variable in class org.apache.hadoop.hbase.HRegionInfo
delimiter used between portions of a region name
DISABLE - Static variable in class org.apache.hadoop.hbase.rest.TableHandler
 
disableTable(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Disables a table (takes it off-line) If it is being served, the master will tell the servers to stop serving it.
disableTable(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Disables a table (takes it off-line) If it is being served, the master will tell the servers to stop serving it.
disableTable(byte[]) - Method in interface org.apache.hadoop.hbase.ipc.HMasterInterface
Take table offline
disableTable(byte[]) - Method in class org.apache.hadoop.hbase.master.HMaster
 
disableTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
disableTable(byte[]) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Disables a table (takes it off-line) If it is being served, the master will tell the servers to stop serving it.
disableTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
Dispatcher - Class in org.apache.hadoop.hbase.rest
Servlet implementation class for hbase REST interface.
Dispatcher() - Constructor for class org.apache.hadoop.hbase.rest.Dispatcher
Default constructor
doDelete(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.rest.Dispatcher
 
doDelete(HttpServletRequest, HttpServletResponse, String[]) - Method in class org.apache.hadoop.hbase.rest.MetaHandler
 
doDelete(HttpServletRequest, HttpServletResponse, String[]) - Method in class org.apache.hadoop.hbase.rest.RowHandler
 
doDelete(HttpServletRequest, HttpServletResponse, String[]) - Method in class org.apache.hadoop.hbase.rest.ScannerHandler
 
doDelete(HttpServletRequest, HttpServletResponse, String[]) - Method in class org.apache.hadoop.hbase.rest.TableHandler
 
doElement(XMLOutputter, String, String) - Method in class org.apache.hadoop.hbase.rest.GenericHandler
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.rest.Dispatcher
 
doGet(HttpServletRequest, HttpServletResponse, String[]) - Method in class org.apache.hadoop.hbase.rest.MetaHandler
 
doGet(HttpServletRequest, HttpServletResponse, String[]) - Method in class org.apache.hadoop.hbase.rest.RowHandler
 
doGet(HttpServletRequest, HttpServletResponse, String[]) - Method in class org.apache.hadoop.hbase.rest.ScannerHandler
 
doGet(HttpServletRequest, HttpServletResponse, String[]) - Method in class org.apache.hadoop.hbase.rest.TableHandler
 
doLocal(HBaseConfiguration) - Static method in class org.apache.hadoop.hbase.LocalHBaseCluster
Changes hbase.master from 'local' to 'localhost:PORT' in passed Configuration instance.
doMain(String[], Class<? extends HMaster>) - Static method in class org.apache.hadoop.hbase.master.HMaster
 
doMain(String[], Class<? extends HRegionServer>) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Do class main.
doMain(String[]) - Static method in class org.apache.hadoop.hbase.rest.Dispatcher
 
doMain(String[]) - Static method in class org.apache.hadoop.hbase.thrift.ThriftServer
 
doMethodNotAllowed(HttpServletResponse, String) - Static method in class org.apache.hadoop.hbase.rest.GenericHandler
 
doMetrics() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
doNotAcceptable(HttpServletResponse) - Static method in class org.apache.hadoop.hbase.rest.GenericHandler
 
doNotAcceptable(HttpServletResponse, String) - Static method in class org.apache.hadoop.hbase.rest.GenericHandler
 
doNotFound(HttpServletResponse) - Static method in class org.apache.hadoop.hbase.rest.GenericHandler
 
doNotFound(HttpServletResponse, String) - Static method in class org.apache.hadoop.hbase.rest.GenericHandler
 
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
 
DONT_BREAK_LINES - Static variable in class org.apache.hadoop.hbase.util.Base64
Don't break lines when encoding (violates strict Base64 specification)
doOptimize() - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
 
doPost(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.rest.Dispatcher
 
doPost(HttpServletRequest, HttpServletResponse, String[]) - Method in class org.apache.hadoop.hbase.rest.MetaHandler
 
doPost(HttpServletRequest, HttpServletResponse, String[]) - Method in class org.apache.hadoop.hbase.rest.RowHandler
 
doPost(HttpServletRequest, HttpServletResponse, String[]) - Method in class org.apache.hadoop.hbase.rest.ScannerHandler
 
doPost(HttpServletRequest, HttpServletResponse, String[]) - Method in class org.apache.hadoop.hbase.rest.TableHandler
 
doPut(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.rest.Dispatcher
 
doPut(HttpServletRequest, HttpServletResponse, String[]) - Method in class org.apache.hadoop.hbase.rest.MetaHandler
 
doPut(HttpServletRequest, HttpServletResponse, String[]) - Method in class org.apache.hadoop.hbase.rest.RowHandler
 
doPut(HttpServletRequest, HttpServletResponse, String[]) - Method in class org.apache.hadoop.hbase.rest.ScannerHandler
 
doPut(HttpServletRequest, HttpServletResponse, String[]) - Method in class org.apache.hadoop.hbase.rest.TableHandler
 
doReconstructionLog(Path, long, long, Progressable) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
doReconstructionLog(Path, long, long, Progressable) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegion
 
doSync() - Method in class org.apache.hadoop.hbase.io.SequenceFile.Sorter.SegmentDescriptor
Do the sync checks
doUpdates(MetricsContext) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcMetrics
Push the metrics to the monitoring subsystem on doUpdate() call.
doUpdates(MetricsContext) - Method in class org.apache.hadoop.hbase.master.metrics.MasterMetrics
Since this object is a registered updater, this method will be called periodically, e.g.
doUpdates(MetricsContext) - Method in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
Since this object is a registered updater, this method will be called periodically, e.g.
Driver - Class in org.apache.hadoop.hbase.mapred
Driver for hbase mapreduce jobs.
Driver() - Constructor for class org.apache.hadoop.hbase.mapred.Driver
 
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

E

emitRecord(String, String, OutputRecord) - Method in class org.apache.hadoop.hbase.metrics.file.TimeStampingFileContext
 
EMPTY_BYTE_ARRAY - Static variable in interface org.apache.hadoop.hbase.HConstants
An empty instance.
EMPTY_END_ROW - Static variable in interface org.apache.hadoop.hbase.HConstants
Last row in a table.
EMPTY_START_ROW - Static variable in interface org.apache.hadoop.hbase.HConstants
Used by scanners, etc when they want to start at the beginning of a region
ENABLE - Static variable in class org.apache.hadoop.hbase.rest.TableHandler
 
enableTable(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Brings a table on-line (enables it)
enableTable(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Brings a table on-line (enables it)
enableTable(byte[]) - Method in interface org.apache.hadoop.hbase.ipc.HMasterInterface
Puts the table on-line (only needed if table has been previously taken offline)
enableTable(byte[]) - Method in class org.apache.hadoop.hbase.master.HMaster
 
enableTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
enableTable(byte[]) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Brings a table on-line (enables it)
enableTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
ENCODE - Static variable in class org.apache.hadoop.hbase.util.Base64
Specify encoding.
encode3to4(byte[], byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Base64
Encodes up to the first three bytes of array threeBytes and returns a four-byte array in Base64 notation.
encode3to4(byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Base64
Encodes up to three bytes of the array source and writes the resulting four Base64 bytes to destination.
encodeBytes(byte[]) - Static method in class org.apache.hadoop.hbase.util.Base64
Encodes a byte array into Base64 notation.
encodeBytes(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Base64
Encodes a byte array into Base64 notation.
encodeBytes(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Base64
Encodes a byte array into Base64 notation.
encodeBytes(byte[], int, int, int) - Static method in class org.apache.hadoop.hbase.util.Base64
Encodes a byte array into Base64 notation.
encodeFileToFile(String, String) - Static method in class org.apache.hadoop.hbase.util.Base64
Reads infile and encodes it to outfile.
encodeFromFile(String) - Static method in class org.apache.hadoop.hbase.util.Base64
Convenience method for reading a binary file and base64-encoding it.
encodeObject(Serializable) - Static method in class org.apache.hadoop.hbase.util.Base64
Serializes an object and returns the Base64-encoded version of that serialized object.
encodeObject(Serializable, int) - Static method in class org.apache.hadoop.hbase.util.Base64
Serializes an object and returns the Base64-encoded version of that serialized object.
encodeRegionName(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
 
encodeToFile(byte[], String) - Static method in class org.apache.hadoop.hbase.util.Base64
Convenience method for encoding data to a file.
END_ROW - Static variable in class org.apache.hadoop.hbase.rest.GenericHandler
 
endKey - Variable in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
endKey - Variable in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo.Isset
 
entrySet() - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
entrySet() - Method in class org.apache.hadoop.hbase.io.RowResult
 
entrySet() - Method in class org.apache.hadoop.hbase.util.SoftValueMap
 
entrySet() - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
equals(Object) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
equals(Object) - Method in class org.apache.hadoop.hbase.HMsg
 
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.HServerAddress
 
equals(Object) - Method in class org.apache.hadoop.hbase.HServerInfo
 
equals(Object) - Method in class org.apache.hadoop.hbase.HServerLoad
 
equals(Object) - Method in class org.apache.hadoop.hbase.HStoreKey.BeforeThisStoreKey
 
equals(Object) - Method in class org.apache.hadoop.hbase.HStoreKey
 
equals(Object) - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
equals(Object) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
equals(SequenceFile.Metadata) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Metadata
 
equals(Object) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Sorter.SegmentDescriptor
 
equals(Object) - Method in class org.apache.hadoop.hbase.master.MetaRegion
 
equals(Object) - Method in class org.apache.hadoop.hbase.regionserver.HLogKey
 
equals(Object) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
equals(Object) - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
 
equals(AlreadyExists) - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
equals(BatchMutation) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
equals(ColumnDescriptor) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
equals(Hbase.atomicIncrement_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
equals(Hbase.atomicIncrement_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
equals(Hbase.createTable_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
equals(Hbase.createTable_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
equals(Hbase.deleteAll_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
 
equals(Hbase.deleteAll_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
equals(Hbase.deleteAllRow_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
 
equals(Hbase.deleteAllRow_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
equals(Hbase.deleteAllRowTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
 
equals(Hbase.deleteAllRowTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
equals(Hbase.deleteAllTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
 
equals(Hbase.deleteAllTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
 
equals(Hbase.deleteTable_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
 
equals(Hbase.deleteTable_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
 
equals(Hbase.disableTable_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
 
equals(Hbase.disableTable_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
 
equals(Hbase.enableTable_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
 
equals(Hbase.enableTable_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
equals(Hbase.get_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
equals(Hbase.get_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
 
equals(Hbase.getColumnDescriptors_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
equals(Hbase.getColumnDescriptors_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
equals(Hbase.getRow_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
equals(Hbase.getRow_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
equals(Hbase.getRowTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
equals(Hbase.getRowTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
equals(Hbase.getRowWithColumns_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
equals(Hbase.getRowWithColumns_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
equals(Hbase.getRowWithColumnsTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
equals(Hbase.getRowWithColumnsTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
 
equals(Hbase.getTableNames_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
equals(Hbase.getTableNames_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
 
equals(Hbase.getTableRegions_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
equals(Hbase.getTableRegions_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
equals(Hbase.getVer_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
equals(Hbase.getVer_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
equals(Hbase.getVerTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
equals(Hbase.getVerTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
 
equals(Hbase.isTableEnabled_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
equals(Hbase.isTableEnabled_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
equals(Hbase.mutateRow_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
equals(Hbase.mutateRow_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
equals(Hbase.mutateRows_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
equals(Hbase.mutateRows_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
equals(Hbase.mutateRowsTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
equals(Hbase.mutateRowsTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
equals(Hbase.mutateRowTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
equals(Hbase.mutateRowTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
 
equals(Hbase.scannerClose_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
equals(Hbase.scannerClose_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
 
equals(Hbase.scannerGet_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
equals(Hbase.scannerGet_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
equals(Hbase.scannerOpen_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
equals(Hbase.scannerOpen_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
equals(Hbase.scannerOpenTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
equals(Hbase.scannerOpenTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
equals(Hbase.scannerOpenWithStop_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
equals(Hbase.scannerOpenWithStop_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
equals(Hbase.scannerOpenWithStopTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
equals(Hbase.scannerOpenWithStopTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
equals(Object) - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
 
equals(IllegalArgument) - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
 
equals(Object) - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
 
equals(IOError) - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
equals(Mutation) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
equals(Object) - Method in exception org.apache.hadoop.hbase.thrift.generated.NotFound
 
equals(NotFound) - Method in exception org.apache.hadoop.hbase.thrift.generated.NotFound
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
 
equals(TCell) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
equals(TRegionInfo) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
equals(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
equals(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
equals(Object) - Method in class org.apache.hadoop.hbase.util.Pair
 
equalsTwoRowKeys(HRegionInfo, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.HStoreKey
Utility method to check if two row keys are equal.
ESTIMATED_HEAP_TAX - Static variable in class org.apache.hadoop.hbase.HStoreKey
Estimated size tax paid for each instance of HSK.
ESTIMATED_HEAP_TAX - Variable in class org.apache.hadoop.hbase.io.BatchOperation
Estimated size of this object.
ESTIMATED_HEAP_TAX - Static variable in class org.apache.hadoop.hbase.io.BatchUpdate
Estimated 'shallow size' of this object not counting payload.
ESTIMATED_HEAP_TAX - Static variable in class org.apache.hadoop.hbase.util.Bytes
Estimate of size cost to pay beyond payload in jvm for instance of byte [].
exist - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
exist - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result.Isset
 
exists(byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Test for the existence of a row in the table.
exists(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Test for the existence of a row and column in the table.
exists(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.HTable
Test for the existence of a coordinate in the table.
exists(byte[], byte[], long, RowLock) - Method in class org.apache.hadoop.hbase.client.HTable
Test for the existence of a coordinate in the table.
exists(byte[], byte[], byte[], long, long) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
Returns true if any cells exist for the given coordinate.
exists(byte[], byte[], long, Integer) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Tests for the existence of any cells for a given coordinate.
exists(byte[], byte[], byte[], long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
extractKeyValues(RowResult) - Method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
Extract columns values from the current record.

F

FAMILIES - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
FAMILIES_KEY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
FILE_SYSTEM_VERSION - Static variable in interface org.apache.hadoop.hbase.HConstants
Current version of file system.
FileSystemVersionException - Exception in org.apache.hadoop.hbase.util
Thrown when the file system needs to be upgraded
FileSystemVersionException() - Constructor for exception org.apache.hadoop.hbase.util.FileSystemVersionException
default constructor
FileSystemVersionException(String) - Constructor for exception org.apache.hadoop.hbase.util.FileSystemVersionException
 
filter - Variable in class org.apache.hadoop.hbase.client.HTable.ClientScanner
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.PageRowFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.PrefixRowFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.RegExpRowFilter
 
filterAllRemaining() - Method in interface org.apache.hadoop.hbase.filter.RowFilterInterface
Determines if the filter has decided that all remaining results should be filtered (skipped).
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.RowFilterSet
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.StopRowFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.WhileMatchRowFilter
Returns true once the nested filter has filtered out a row (returned true on a call to one of it's filtering methods).
filterColumn(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
 
filterColumn(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.filter.PageRowFilter
 
filterColumn(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.filter.PrefixRowFilter
 
filterColumn(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.filter.RegExpRowFilter
 
filterColumn(byte[], byte[], byte[]) - Method in interface org.apache.hadoop.hbase.filter.RowFilterInterface
Filters on row key, column name, and column value.
filterColumn(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.filter.RowFilterSet
 
filterColumn(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.filter.StopRowFilter
Because StopRowFilter does not examine column information, this method defaults to calling the rowKey-only version of filter.
filterColumn(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.filter.WhileMatchRowFilter
 
filterRow(SortedMap<byte[], Cell>) - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
 
filterRow(SortedMap<byte[], Cell>) - Method in class org.apache.hadoop.hbase.filter.PageRowFilter
 
filterRow(SortedMap<byte[], Cell>) - Method in class org.apache.hadoop.hbase.filter.PrefixRowFilter
 
filterRow(SortedMap<byte[], Cell>) - Method in class org.apache.hadoop.hbase.filter.RegExpRowFilter
 
filterRow(SortedMap<byte[], Cell>) - Method in interface org.apache.hadoop.hbase.filter.RowFilterInterface
Filter on the fully assembled row.
filterRow(SortedMap<byte[], Cell>) - Method in class org.apache.hadoop.hbase.filter.RowFilterSet
 
filterRow(SortedMap<byte[], Cell>) - Method in class org.apache.hadoop.hbase.filter.StopRowFilter
Because StopRowFilter does not examine column information, this method defaults to calling filterAllRemaining().
filterRow(SortedMap<byte[], Cell>) - Method in class org.apache.hadoop.hbase.filter.WhileMatchRowFilter
 
filterRowKey(byte[]) - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
 
filterRowKey(byte[]) - Method in class org.apache.hadoop.hbase.filter.InclusiveStopRowFilter
 
filterRowKey(byte[]) - Method in class org.apache.hadoop.hbase.filter.PageRowFilter
 
filterRowKey(byte[]) - Method in class org.apache.hadoop.hbase.filter.PrefixRowFilter
 
filterRowKey(byte[]) - Method in class org.apache.hadoop.hbase.filter.RegExpRowFilter
 
filterRowKey(byte[]) - Method in interface org.apache.hadoop.hbase.filter.RowFilterInterface
Filters on just a row key.
filterRowKey(byte[]) - Method in class org.apache.hadoop.hbase.filter.RowFilterSet
 
filterRowKey(byte[]) - Method in class org.apache.hadoop.hbase.filter.StopRowFilter
 
filterRowKey(byte[]) - Method in class org.apache.hadoop.hbase.filter.WhileMatchRowFilter
 
finalKey(WritableComparable) - Method in class org.apache.hadoop.hbase.io.HalfMapFileReader
 
finalKey(WritableComparable) - Method in class org.apache.hadoop.hbase.io.MapFile.Reader
Reads the final key from the file.
findRootRegion() - Method in interface org.apache.hadoop.hbase.ipc.HMasterInterface
Get the location of the root region
findRootRegion() - Method in class org.apache.hadoop.hbase.master.HMaster
 
first - Variable in class org.apache.hadoop.hbase.util.Pair
 
FIRST_META_REGIONINFO - Static variable in class org.apache.hadoop.hbase.HRegionInfo
HRegionInfo for first meta region
firstKey() - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
firstKey() - Method in class org.apache.hadoop.hbase.io.RowResult
 
firstKey() - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
fix(FileSystem, Path, Class<? extends Writable>, Class<? extends Writable>, boolean, Configuration) - Static method in class org.apache.hadoop.hbase.io.MapFile
This method attempts to fix a corrupt MapFile by re-creating its index.
flush(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Flush a table or an individual region
flush(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Flush a table or an individual region
flush() - Method in class org.apache.hadoop.hbase.metrics.file.TimeStampingFileContext
 
flushBase64() - Method in class org.apache.hadoop.hbase.util.Base64.Base64OutputStream
Method added by PHIL.
flushcache() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Flush the cache.
flushCommits() - Method in class org.apache.hadoop.hbase.client.HTable
Commit to the table the buffer of BatchUpdate.
FlushRequester - Interface in org.apache.hadoop.hbase.regionserver
Implementors of this interface want to be notified when an HRegion determines that a cache flush is needed.
FOREVER - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
FOREVER - Static variable in interface org.apache.hadoop.hbase.HConstants
Unlimited time-to-live.
fsOk - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
FSUtils - Class in org.apache.hadoop.hbase.util
Utility methods for interacting with the underlying file system.

G

GenericHandler - Class in org.apache.hadoop.hbase.rest
GenericHandler contains some basic common stuff that all the individual REST handler types take advantage of.
GenericHandler(HBaseConfiguration, HBaseAdmin) - Constructor for class org.apache.hadoop.hbase.rest.GenericHandler
 
GenericHandler.ContentType - Enum in org.apache.hadoop.hbase.rest
 
get(String, String) - Method in class org.apache.hadoop.hbase.client.HTable
Get a single value for the specified row and column
get(String, String, int) - Method in class org.apache.hadoop.hbase.client.HTable
Get a single value for the specified row and column
get(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Get a single value for the specified row and column
get(byte[], byte[], int) - Method in class org.apache.hadoop.hbase.client.HTable
Get the specified number of versions of the specified row and column
get(String, String, long, int) - Method in class org.apache.hadoop.hbase.client.HTable
Get the specified number of versions of the specified row and column with the specified timestamp.
get(byte[], byte[], long, int) - Method in class org.apache.hadoop.hbase.client.HTable
Get the specified number of versions of the specified row and column with the specified timestamp.
get(TransactionState, byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.transactional.TransactionalTable
Get a single value for the specified row and column
get(TransactionState, byte[], byte[], int) - Method in class org.apache.hadoop.hbase.client.transactional.TransactionalTable
Get the specified number of versions of the specified row and column
get(TransactionState, byte[], byte[], long, int) - Method in class org.apache.hadoop.hbase.client.transactional.TransactionalTable
Get the specified number of versions of the specified row and column with the specified timestamp.
get(String) - Method in class org.apache.hadoop.hbase.io.BatchUpdate
Get the current value of the specified column
get(byte[]) - Method in class org.apache.hadoop.hbase.io.BatchUpdate
Get the current value of the specified column
get(WritableComparable, Writable) - Method in class org.apache.hadoop.hbase.io.BloomFilterMapFile.Reader
 
get(WritableComparable, Writable) - Method in class org.apache.hadoop.hbase.io.HalfMapFileReader
 
get(Object) - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
get() - Method in class org.apache.hadoop.hbase.io.HbaseObjectWritable
 
get() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
Get the data from the BytesWritable.
get(WritableComparable, Writable) - Method in class org.apache.hadoop.hbase.io.MapFile.Reader
Return the value for the named key, or null if none exists.
get(Object) - Method in class org.apache.hadoop.hbase.io.RowResult
 
get(byte[]) - Method in class org.apache.hadoop.hbase.io.RowResult
Get the Cell that corresponds to column
get(String) - Method in class org.apache.hadoop.hbase.io.RowResult
Get the Cell that corresponds to column, using a String key
get(Text) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Metadata
 
get() - Static method in class org.apache.hadoop.hbase.ipc.HBaseServer
Returns the server instance called under or null.
get(byte[], byte[], byte[], long, int) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
Get the specified number of versions of the specified row and column with the specified timestamp.
get(long, byte[], byte[], byte[]) - Method in interface org.apache.hadoop.hbase.ipc.TransactionalRegionInterface
Retrieve a single value from the specified region for the specified row and column keys
get(long, byte[], byte[], byte[], int) - Method in interface org.apache.hadoop.hbase.ipc.TransactionalRegionInterface
Get the specified number of versions of the specified row and column
get(long, byte[], byte[], byte[], long, int) - Method in interface org.apache.hadoop.hbase.ipc.TransactionalRegionInterface
Get the specified number of versions of the specified row and column with the specified timestamp.
get(byte[], byte[], long, int) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Fetch multiple versions of a single data item, with timestamp.
get(byte[], byte[], byte[], long, int) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
get(long, byte[], byte[]) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegion
Fetch a single data item.
get(long, byte[], byte[], int) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegion
Fetch multiple versions of a single data item
get(long, byte[], byte[], long, int) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegion
Fetch multiple versions of a single data item, with timestamp.
get(long, byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegionServer
 
get(long, byte[], byte[], byte[], int) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegionServer
 
get(long, byte[], byte[], byte[], long, int) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegionServer
 
get(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
get(byte[], byte[], byte[]) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Get a single TCell for the specified table, row, and column at the latest timestamp.
get(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
get(Object) - Method in class org.apache.hadoop.hbase.util.SoftValueMap
 
get(Object) - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
getAdditionalColumns() - Method in class org.apache.hadoop.hbase.client.tableindexed.IndexSpecification
Get the additionalColumns.
getAllColumns() - Method in class org.apache.hadoop.hbase.client.tableindexed.IndexSpecification
 
getAlphabet(int) - Static method in class org.apache.hadoop.hbase.util.Base64
Returns one of the _SOMETHING_ALPHABET byte arrays depending on the options specified.
getAnalyzerName() - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
 
getAverageLoad() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getBaseDir() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getBindAddress() - Method in class org.apache.hadoop.hbase.HServerAddress
 
getBloomFilterKey(WritableComparable) - Static method in class org.apache.hadoop.hbase.io.BloomFilterMapFile
Custom bloom filter key maker.
getBloomFilterSize() - Method in class org.apache.hadoop.hbase.io.BloomFilterMapFile.Reader
 
getBoost(String) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
 
getBytes(HStoreKey) - Static method in class org.apache.hadoop.hbase.HStoreKey
Returns row and column bytes out of an HStoreKey.
getBytes(Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
 
getCaching() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
Get the number of rows that will be fetched on next
getCallQueueLen() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
The number of rpc calls in the queue.
getClass(byte) - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
getClientVersion() - Method in exception org.apache.hadoop.hbase.ipc.HBaseRPC.VersionMismatch
 
getClosest(WritableComparable, Writable) - Method in class org.apache.hadoop.hbase.io.BloomFilterMapFile.Reader
 
getClosest(WritableComparable, Writable) - Method in class org.apache.hadoop.hbase.io.HalfMapFileReader
 
getClosest(WritableComparable, Writable) - Method in class org.apache.hadoop.hbase.io.MapFile.Reader
Finds the record that is the closest match to the specified key.
getClosest(WritableComparable, Writable, boolean) - Method in class org.apache.hadoop.hbase.io.MapFile.Reader
Finds the record that is the closest match to the specified key.
getClosestRowBefore(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
 
getClosestRowBefore(byte[], byte[], byte[]) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
Return all the data for the row that matches row exactly, or the one that immediately preceeds it.
getClosestRowBefore(byte[], byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Return all the data for the row that matches row exactly, or the one that immediately preceeds it, at or immediately before ts.
getClosestRowBefore(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getColumn() - Method in class org.apache.hadoop.hbase.HStoreKey.BeforeThisStoreKey
 
getColumn() - Method in class org.apache.hadoop.hbase.HStoreKey
 
getColumn() - Method in class org.apache.hadoop.hbase.io.BatchOperation
 
getColumn() - Method in class org.apache.hadoop.hbase.regionserver.HLogEdit
 
getColumnDescriptors(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
getColumnDescriptors(byte[]) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
List all the column families assoicated with a table.
getColumnDescriptors(byte[]) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
getColumns() - Method in class org.apache.hadoop.hbase.client.HTable.ClientScanner
 
getColumns() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
getColumns() - Method in class org.apache.hadoop.hbase.io.BatchUpdate
Get the current columns
getCompleteCacheFlushSequenceId(long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Get the sequence number to be associated with this cache flush.
getCompleteCacheFlushSequenceId(long) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegion
We need to make sure that we don't complete a cache flush between running transactions.
getCompression() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getCompressionCodec() - Method in class org.apache.hadoop.hbase.io.SequenceFile.Reader
Returns the compression codec of data in this file.
getCompressionCodec() - Method in class org.apache.hadoop.hbase.io.SequenceFile.Writer
Returns the compression codec of data in this file.
getCompressionType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getCompressionType(Configuration) - Static method in class org.apache.hadoop.hbase.io.SequenceFile
Deprecated. Use SequenceFileOutputFormat.getOutputCompressionType(org.apache.hadoop.mapred.JobConf) to get SequenceFile.CompressionType for job-outputs.
getConf() - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
getConf() - Method in class org.apache.hadoop.hbase.io.HbaseObjectWritable
 
getConf() - Method in class org.apache.hadoop.hbase.mapred.RowCounter
 
getConf() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getConfiguration() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getConfiguration() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getConnection(HBaseConfiguration) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Get the connection object for the instance specified by the configuration If no current connection exists, create a new connection for that instance
getConnection() - Method in class org.apache.hadoop.hbase.client.HTable
Used by unit tests and tools to do low-level manipulations.
getConnection(HBaseConfiguration) - Static method in class org.apache.hadoop.hbase.client.ServerConnectionManager
Get the connection object for the instance specified by the configuration If no current connection exists, create a new connection for that instance
getContentType(String) - Static method in enum org.apache.hadoop.hbase.rest.GenericHandler.ContentType
Utility method used looking at Accept header content.
getCopyOfOnlineRegionsSortedBySize() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getCurrentValue(Writable) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Reader
Get the 'value' corresponding to the last read 'key'.
getCurrentValue(Object) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Reader
Get the 'value' corresponding to the last read 'key'.
getData() - Method in class org.apache.hadoop.hbase.io.DataOutputBuffer
Returns the current contents of the buffer.
getDate() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
The date that hbase was compiled.
getDeclaredClass() - Method in class org.apache.hadoop.hbase.io.HbaseObjectWritable
 
getDecodabet(int) - Static method in class org.apache.hadoop.hbase.util.Base64
Returns one of the _SOMETHING_DECODABET byte arrays depending on the options specified.
getDescription() - Method in class org.apache.hadoop.hbase.RegionHistorian.RegionHistoryInformation
 
getEncodedName() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getEncodedRegionName() - Method in class org.apache.hadoop.hbase.io.Reference
 
getEndKey() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getEndKey() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getEndKeys() - Method in class org.apache.hadoop.hbase.client.HTable
Gets the ending row key for every region in the currently open table
getEndRow() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
getEvent() - Method in class org.apache.hadoop.hbase.RegionHistorian.RegionHistoryInformation
 
getFactor() - Method in class org.apache.hadoop.hbase.io.SequenceFile.Sorter
Get the number of streams to merge at once.
getFamilies() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
getFamily(byte[]) - Static method in class org.apache.hadoop.hbase.HStoreKey
 
getFamily(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
getFamilyDelimiterIndex(byte[]) - Static method in class org.apache.hadoop.hbase.HStoreKey
 
getFamilyMapKey(byte[]) - Static method in class org.apache.hadoop.hbase.HStoreKey
 
getFileId() - Method in class org.apache.hadoop.hbase.io.Reference
 
getFilenum() - Method in class org.apache.hadoop.hbase.regionserver.HLog
Accessor for tests.
getFileRegion() - Method in class org.apache.hadoop.hbase.io.Reference
 
getFilesystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getFilter() - Method in class org.apache.hadoop.hbase.client.HTable.ClientScanner
 
getFilter() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
getFilterDir(Path, int, byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.HStoreFile
Deprecated. 
getFilters() - Method in class org.apache.hadoop.hbase.filter.RowFilterSet
Get the filters.
getFirst() - Method in class org.apache.hadoop.hbase.util.Pair
Return the first element stored in the pair.
getFlushRequester() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getFromMETA(byte[], byte[][]) - Method in class org.apache.hadoop.hbase.master.HMaster
Get row from meta table.
getFull(byte[], Set<byte[]>, long, int, Integer) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Fetch all the columns for the indicated row at a specified timestamp.
getFull(long, byte[], Set<byte[]>, long) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegion
Fetch all the columns for the indicated row at a specified timestamp.
getGlobalMemcacheSize() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Return the total size of all memcaches in every region.
getHashType(Configuration) - Static method in class org.apache.hadoop.hbase.util.Hash
This utility method converts the name of the configured hash type to a symbolic constant.
getHLogDirectoryName(HServerInfo) - Static method in class org.apache.hadoop.hbase.regionserver.HLog
Construct the HLog directory name
getHostname() - Method in class org.apache.hadoop.hbase.HServerAddress
 
getHRegionConnection(HServerAddress) - Method in interface org.apache.hadoop.hbase.client.HConnection
Establishes a connection to the region server at the specified address.
getHRegionInfo() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
getHRegionInfo() - Method in class org.apache.hadoop.hbase.HStoreKey.BeforeThisStoreKey
 
getHRegionInfo() - Method in class org.apache.hadoop.hbase.HStoreKey
 
getHRegionInfo(byte[]) - Static method in class org.apache.hadoop.hbase.util.Writables
 
getHRegionInfo(Cell) - Static method in class org.apache.hadoop.hbase.util.Writables
 
getHRegionInfoOrNull(byte[]) - Static method in class org.apache.hadoop.hbase.util.Writables
 
getHTableDescriptor(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
 
getId(Class<?>) - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
getIndex(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
getIndexedColumns() - Method in class org.apache.hadoop.hbase.client.tableindexed.IndexSpecification
Get the indexedColumns.
getIndexedScanner(String, byte[], byte[][], RowFilterInterface, byte[][]) - Method in class org.apache.hadoop.hbase.client.tableindexed.IndexedTable
Open up an indexed scanner.
getIndexedTableName(byte[]) - Method in class org.apache.hadoop.hbase.client.tableindexed.IndexSpecification
 
getIndexes() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
getIndexId() - Method in class org.apache.hadoop.hbase.client.tableindexed.IndexSpecification
Get the indexId.
getIndexInterval() - Method in class org.apache.hadoop.hbase.io.MapFile.Writer
The number of entries that are added before an index entry is added.
getInetSocketAddress() - Method in class org.apache.hadoop.hbase.HServerAddress
 
getInfoDir(Path, int, byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.HStoreFile
 
getInfoPort() - Method in class org.apache.hadoop.hbase.HServerInfo
 
getInfoServer() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getInfoServer() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getInputProtocol() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
getInstance() - Static method in class org.apache.hadoop.hbase.client.transactional.LocalTransactionLogger
Creates singleton if it does not exist
getInstance() - Static method in class org.apache.hadoop.hbase.RegionHistorian
Get the RegionHistorian Singleton instance.
getInstance(int) - Static method in class org.apache.hadoop.hbase.util.Hash
Get a singleton instance of hash function of a given type.
getInstance(Configuration) - Static method in class org.apache.hadoop.hbase.util.Hash
Get a singleton instance of hash function of a type defined in the configuration.
getInstance() - Static method in class org.apache.hadoop.hbase.util.JenkinsHash
 
getInstance() - Static method in class org.apache.hadoop.hbase.util.MurmurHash
 
getInterfaceName() - Method in exception org.apache.hadoop.hbase.ipc.HBaseRPC.VersionMismatch
Get the interface name
getInternalFilter() - Method in class org.apache.hadoop.hbase.filter.WhileMatchRowFilter
Returns the internal filter being wrapped
getKey() - Method in class org.apache.hadoop.hbase.io.RowResult.Entry
 
getKey() - Method in interface org.apache.hadoop.hbase.io.SequenceFile.Sorter.RawKeyValueIterator
Gets the current raw key
getKey() - Method in class org.apache.hadoop.hbase.io.SequenceFile.Sorter.SegmentDescriptor
Returns the stored rawKey
getKeyClass() - Method in class org.apache.hadoop.hbase.io.MapFile.Reader
Returns the class of keys in this file.
getKeyClass() - Method in class org.apache.hadoop.hbase.io.SequenceFile.Reader
Returns the class of keys in this file.
getKeyClass() - Method in class org.apache.hadoop.hbase.io.SequenceFile.Writer
Returns the class of keys in this file.
getKeyClassName() - Method in class org.apache.hadoop.hbase.io.SequenceFile.Reader
Returns the name of the key class.
getKeyGenerator() - Method in class org.apache.hadoop.hbase.client.tableindexed.IndexSpecification
Get the keyGenerator.
getKeys(HStoreKey, int, long, Pattern) - Method in class org.apache.hadoop.hbase.regionserver.HStore
Get versions of keys matching the origin key's row/column/timestamp and those of an older vintage.
getLargestHStoreSize() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getLastFlushTime() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getLeases() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getLength() - Method in class org.apache.hadoop.hbase.io.DataOutputBuffer
Returns the length of the valid data currently in the buffer.
getLength() - Method in class org.apache.hadoop.hbase.io.SequenceFile.Writer
Returns the current length of the output file.
getLength() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
getListenerAddress() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
Return the socket (ip+port) on which the RPC server is listening to.
getLoad() - Method in class org.apache.hadoop.hbase.HServerInfo
 
getLoad() - Method in class org.apache.hadoop.hbase.HServerLoad
Originally, this method factored in the effect of requests going to the server as well.
getLocations() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
getLockId() - Method in class org.apache.hadoop.hbase.client.RowLock
Get the lock id from this RowLock
getLog() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getLog() - Method in class org.apache.hadoop.hbase.util.MetaUtils
 
getLogSeqNum() - Method in class org.apache.hadoop.hbase.regionserver.HLogKey
 
getMapDir(Path, int, byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.HStoreFile
 
getMapFileIndexInterval() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getMaster() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getMaster() - Method in interface org.apache.hadoop.hbase.client.HConnection
 
getMaster() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
getMasterAddress() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getMaxBufferedDeleteTerms() - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
 
getMaxBufferedDocs() - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
 
getMaxFieldLength() - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
 
getMaxFileSize() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
getMaxMergeDocs() - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
 
getMaxValueLength() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getMaxVersions() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getMemcacheFlushSize() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
getMemcacheSizeInMB() - Method in class org.apache.hadoop.hbase.HServerLoad
 
getMemcacheSizeMB() - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
 
getMemory() - Method in class org.apache.hadoop.hbase.io.SequenceFile.Sorter
Get the total amount of buffer memory, in bytes.
getMergeFactor() - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
 
getMessage() - Method in class org.apache.hadoop.hbase.HMsg
 
getMetadata() - Method in class org.apache.hadoop.hbase.io.SequenceFile.Metadata
 
getMetadata() - Method in class org.apache.hadoop.hbase.io.SequenceFile.Reader
Returns the metadata object of the file
getMetaRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.util.MetaUtils
Open or return cached opened meta region
getMETARows(byte[]) - Method in class org.apache.hadoop.hbase.util.MetaUtils
 
getMetrics() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getMetrics() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getMidkey() - Method in class org.apache.hadoop.hbase.io.Reference
 
getMostLoadedRegions() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Get the top N most loaded regions this server is serving so we can tell the master which regions it can reallocate if we're overloaded.
getName() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getName() - Method in class org.apache.hadoop.hbase.HServerInfo
 
getName() - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
 
getName() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
getName() - Method in exception org.apache.hadoop.hbase.Leases.LeaseStillHeldException
 
getNameAsString() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getNameAsString() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
getNameWithColon() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getNumberOfRegions() - Method in class org.apache.hadoop.hbase.HServerLoad
 
getNumberOfRequests() - Method in class org.apache.hadoop.hbase.HServerLoad
 
getNumOpenConnections() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
The number of open RPC conections
getNumValues() - Method in class org.apache.hadoop.hbase.io.Cell
 
getOnlineMetaRegions() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getOnlineRegion(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getOnlineRegions() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getOperation() - Method in class org.apache.hadoop.hbase.regionserver.HLogEdit
Get the operation.
getOperator() - Method in class org.apache.hadoop.hbase.filter.RowFilterSet
Get the operator.
getOutboundMsgs() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getOutputProtocol() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
getPartition(ImmutableBytesWritable, V2, int) - Method in class org.apache.hadoop.hbase.mapred.HRegionPartitioner
 
getPath(Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Return the 'path' component of a Path.
getPort() - Method in class org.apache.hadoop.hbase.HServerAddress
 
getPos() - Method in class org.apache.hadoop.hbase.io.BlockFSInputStream
 
getPos() - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase.TableRecordReader
 
getPosition() - Method in class org.apache.hadoop.hbase.io.SequenceFile.Reader
Return the current byte position in the input file.
getPreviousIntervalValue() - Method in class org.apache.hadoop.hbase.metrics.MetricsRate
 
getProgress() - Method in interface org.apache.hadoop.hbase.io.SequenceFile.Sorter.RawKeyValueIterator
Gets the Progress object; this has a float (0.0 - 1.0) indicating the bytes processed by the iterator so far
getProgress() - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase.TableRecordReader
 
getProtocolVersion(String, long) - Method in class org.apache.hadoop.hbase.master.HMaster
 
getProtocolVersion(String, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getProtocolVersion(String, long) - Method in class org.apache.hadoop.hbase.regionserver.tableindexed.IndexedRegionServer
 
getProtocolVersion(String, long) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegionServer
 
getProxy(Class<?>, long, InetSocketAddress, Configuration, SocketFactory) - Static method in class org.apache.hadoop.hbase.ipc.HBaseRPC
Construct a client-side proxy object that implements the named protocol, talking to a server at the named address.
getProxy(Class<?>, long, InetSocketAddress, UserGroupInformation, Configuration, SocketFactory) - Static method in class org.apache.hadoop.hbase.ipc.HBaseRPC
Construct a client-side proxy object that implements the named protocol, talking to a server at the named address.
getProxy(Class<?>, long, InetSocketAddress, Configuration) - Static method in class org.apache.hadoop.hbase.ipc.HBaseRPC
Construct a client-side proxy object with the default SocketFactory
getQualifier(byte[]) - Static method in class org.apache.hadoop.hbase.HStoreKey
 
getReader(FileSystem, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
Get reader for the store file map file.
getReaders() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Builds a TableRecordReader.
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.hbase.mapred.IndexOutputFormat
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat
 
getRegion(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Protected utility method for safely obtaining an HRegion handle.
getRegionDir() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getRegionDir(Path, int) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Computes the Path of the HRegion
getRegionDir(Path, HRegionInfo) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Computes the Path of the HRegion
getRegionHistory(String) - Method in class org.apache.hadoop.hbase.RegionHistorian
Returns, for a given region name, an ordered list by timestamp of all values in the historian column of the .META.
getRegionId() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getRegionId() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getRegionInfo() - Method in class org.apache.hadoop.hbase.HMsg
 
getRegionInfo() - Method in class org.apache.hadoop.hbase.HRegionLocation
 
getRegionInfo(byte[]) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
Get metainfo about an HRegion
getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getRegionInfo(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getRegionLocation(byte[], byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
Find region location hosting passed row
getRegionLocation(String) - Method in class org.apache.hadoop.hbase.client.HTable
Find region location hosting passed row using cached info
getRegionLocation(byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Find region location hosting passed row using cached info
getRegionLocation() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
getRegionName() - Method in class org.apache.hadoop.hbase.client.ServerCallable
 
getRegionName() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getRegionName() - Method in class org.apache.hadoop.hbase.master.MetaRegion
 
getRegionName() - Method in class org.apache.hadoop.hbase.regionserver.HLogKey
 
getRegionName() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getRegionNameAsString() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getRegionServer(int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
getRegionServer() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster.RegionServerThread
 
getRegionServerForWithoutRetries(ServerCallable<T>) - Method in interface org.apache.hadoop.hbase.client.HConnection
Pass in a ServerCallable with your particular bit of logic defined and this method will pass it to the defined region server.
getRegionServers() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
getRegionServerWithRetries(ServerCallable<T>) - Method in interface org.apache.hadoop.hbase.client.HConnection
Pass in a ServerCallable with your particular bit of logic defined and this method will manage the process of doing retries with timed waits and refinds of missing regions.
getRegionsInfo() - Method in class org.apache.hadoop.hbase.client.HTable
Get all the regions and their address for this table
getRegionsToCheck() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getRemoteAddress() - Static method in class org.apache.hadoop.hbase.ipc.HBaseServer
Returns remote address as a string when invoked inside an RPC.
getRemoteIp() - Static method in class org.apache.hadoop.hbase.ipc.HBaseServer
Returns the remote side ip address when invoked inside an RPC Returns null incase of an error.
getRequestCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getRequests() - Method in class org.apache.hadoop.hbase.master.metrics.MasterMetrics
 
getRequests() - Method in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
 
getRevision() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
Get the subversion revision number for the root directory
getRootDir() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getRootDir() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getRootDir(HBaseConfiguration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
 
getRootRegion() - Method in class org.apache.hadoop.hbase.util.MetaUtils
 
getRootRegionLocation() - Method in interface org.apache.hadoop.hbase.ipc.HMasterRegionInterface
 
getRootRegionLocation() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getRow(String) - Method in class org.apache.hadoop.hbase.client.HTable
Get all the data for the specified row at the latest timestamp
getRow(byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Get all the data for the specified row at the latest timestamp
getRow(String, int) - Method in class org.apache.hadoop.hbase.client.HTable
Get more than one version of all columns for the specified row
getRow(byte[], int) - Method in class org.apache.hadoop.hbase.client.HTable
Get more than one version of all columns for the specified row
getRow(String, long) - Method in class org.apache.hadoop.hbase.client.HTable
Get all the data for the specified row at a specified timestamp
getRow(byte[], long) - Method in class org.apache.hadoop.hbase.client.HTable
Get all the data for the specified row at a specified timestamp
getRow(String, long, int) - Method in class org.apache.hadoop.hbase.client.HTable
 
getRow(byte[], long, int) - Method in class org.apache.hadoop.hbase.client.HTable
Get more than one version of all columns for the specified row at a specified timestamp
getRow(String, String[]) - Method in class org.apache.hadoop.hbase.client.HTable
Get selected columns for the specified row at the latest timestamp
getRow(byte[], byte[][]) - Method in class org.apache.hadoop.hbase.client.HTable
Get selected columns for the specified row at the latest timestamp
getRow(String, String[], int) - Method in class org.apache.hadoop.hbase.client.HTable
Get more than one version of selected columns for the specified row
getRow(byte[], byte[][], int) - Method in class org.apache.hadoop.hbase.client.HTable
Get more than one version of selected columns for the specified row
getRow(String, String[], long) - Method in class org.apache.hadoop.hbase.client.HTable
Get selected columns for the specified row at a specified timestamp
getRow(byte[], byte[][], long) - Method in class org.apache.hadoop.hbase.client.HTable
Get selected columns for the specified row at a specified timestamp
getRow(String, String[], long, int, RowLock) - Method in class org.apache.hadoop.hbase.client.HTable
 
getRow(byte[], byte[][], long, int, RowLock) - Method in class org.apache.hadoop.hbase.client.HTable
Get selected columns for the specified row at a specified timestamp using existing row lock.
getRow() - Method in class org.apache.hadoop.hbase.client.RowLock
Get the row for this RowLock
getRow() - Method in class org.apache.hadoop.hbase.client.ServerCallable
 
getRow(TransactionState, byte[]) - Method in class org.apache.hadoop.hbase.client.transactional.TransactionalTable
Get all the data for the specified row at the latest timestamp
getRow(TransactionState, byte[], long) - Method in class org.apache.hadoop.hbase.client.transactional.TransactionalTable
Get all the data for the specified row at a specified timestamp
getRow(TransactionState, byte[], byte[][]) - Method in class org.apache.hadoop.hbase.client.transactional.TransactionalTable
Get selected columns for the specified row at the latest timestamp
getRow(TransactionState, byte[], byte[][], long) - Method in class org.apache.hadoop.hbase.client.transactional.TransactionalTable
Get selected columns for the specified row at a specified timestamp
getRow() - Method in class org.apache.hadoop.hbase.HStoreKey.BeforeThisStoreKey
 
getRow() - Method in class org.apache.hadoop.hbase.HStoreKey
 
getRow() - Method in class org.apache.hadoop.hbase.io.BatchUpdate
 
getRow() - Method in class org.apache.hadoop.hbase.io.RowResult
Get the row for this RowResult
getRow(byte[], byte[], byte[][], long, int, long) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
Get selected columns for the specified row at a given timestamp.
getRow(long, byte[], byte[], long) - Method in interface org.apache.hadoop.hbase.ipc.TransactionalRegionInterface
Get all the data for the specified row at a given timestamp
getRow(long, byte[], byte[], byte[][], long) - Method in interface org.apache.hadoop.hbase.ipc.TransactionalRegionInterface
Get selected columns for the specified row at a given timestamp.
getRow(long, byte[], byte[], byte[][]) - Method in interface org.apache.hadoop.hbase.ipc.TransactionalRegionInterface
Get selected columns for the specified row at the latest timestamp.
getRow() - Method in class org.apache.hadoop.hbase.regionserver.HLogKey
 
getRow(byte[], byte[], byte[][], long, int, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getRow(long, byte[], byte[], long) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegionServer
 
getRow(long, byte[], byte[], byte[][]) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegionServer
 
getRow(long, byte[], byte[], byte[][], long) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegionServer
 
getRow(byte[], byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
getRow(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Get all the data for the specified table and row at the latest timestamp.
getRow(byte[], byte[]) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
getRowkeyName() - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
 
getRowLock() - Method in class org.apache.hadoop.hbase.io.BatchUpdate
Get the row lock associated with this update
getRowTs(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
getRowTs(byte[], byte[], long) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Get all the data for the specified table and row at the specified timestamp.
getRowTs(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
getRowWithColumns(byte[], byte[], List<byte[]>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
getRowWithColumns(byte[], byte[], List<byte[]>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Get the specified columns for the specified table and row at the latest timestamp.
getRowWithColumns(byte[], byte[], List<byte[]>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
getRowWithColumnsTs(byte[], byte[], List<byte[]>, long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
getRowWithColumnsTs(byte[], byte[], List<byte[]>, long) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Get the specified columns for the specified table and row at the specified timestamp.
getRowWithColumnsTs(byte[], byte[], List<byte[]>, long) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
getScanner(String[]) - Method in class org.apache.hadoop.hbase.client.HTable
Get a scanner on the current table starting at first row.
getScanner(String[], String) - Method in class org.apache.hadoop.hbase.client.HTable
Get a scanner on the current table starting at the specified row.
getScanner(byte[][]) - Method in class org.apache.hadoop.hbase.client.HTable
Get a scanner on the current table starting at first row.
getScanner(byte[][], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Get a scanner on the current table starting at the specified row.
getScanner(byte[][], byte[], long) - Method in class org.apache.hadoop.hbase.client.HTable
Get a scanner on the current table starting at the specified row.
getScanner(byte[][], byte[], RowFilterInterface) - Method in class org.apache.hadoop.hbase.client.HTable
Get a scanner on the current table starting at the specified row.
getScanner(byte[][], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Get a scanner on the current table starting at the specified row and ending just before stopRow.
getScanner(String[], String, String, long) - Method in class org.apache.hadoop.hbase.client.HTable
Get a scanner on the current table starting at the specified row and ending just before stopRow.
getScanner(byte[][], byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.HTable
Get a scanner on the current table starting at the specified row and ending just before stopRow.
getScanner(String[], String, long, RowFilterInterface) - Method in class org.apache.hadoop.hbase.client.HTable
Get a scanner on the current table starting at the specified row.
getScanner(byte[][], byte[], long, RowFilterInterface) - Method in class org.apache.hadoop.hbase.client.HTable
Get a scanner on the current table starting at the specified row.
getScanner(TransactionState, byte[][]) - Method in class org.apache.hadoop.hbase.client.transactional.TransactionalTable
Get a scanner on the current table starting at first row.
getScanner(TransactionState, byte[][], byte[]) - Method in class org.apache.hadoop.hbase.client.transactional.TransactionalTable
Get a scanner on the current table starting at the specified row.
getScanner(TransactionState, byte[][], byte[], long) - Method in class org.apache.hadoop.hbase.client.transactional.TransactionalTable
Get a scanner on the current table starting at the specified row.
getScanner(TransactionState, byte[][], byte[], RowFilterInterface) - Method in class org.apache.hadoop.hbase.client.transactional.TransactionalTable
Get a scanner on the current table starting at the specified row.
getScanner(TransactionState, byte[][], byte[], long, RowFilterInterface) - Method in class org.apache.hadoop.hbase.client.transactional.TransactionalTable
Get a scanner on the current table starting at the specified row.
getScanner(byte[][], byte[], long, RowFilterInterface) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Return an iterator that scans over the HRegion, returning the indicated columns for only the rows that match the data filter.
getScanner(long, byte[][], byte[], RowFilterInterface) - Method in class org.apache.hadoop.hbase.regionserver.HStore
Return a scanner for both the memcache and the HStore files
getScanner(long, byte[][], byte[], long, RowFilterInterface) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegion
Return an iterator that scans over the HRegion, returning the indicated columns for only the rows that match the data filter.
getScanner(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
Returns the scanner associated with the specified ID.
getScannerCaching() - Method in class org.apache.hadoop.hbase.client.HTable
Get the number of rows for caching that will be passed to scanners
getScannerCallable(byte[], int) - Method in class org.apache.hadoop.hbase.client.HTable.ClientScanner
 
getScannerCallable(byte[], int) - Method in class org.apache.hadoop.hbase.client.transactional.TransactionalTable.TransactionalClientScanner
 
getSecond() - Method in class org.apache.hadoop.hbase.util.Pair
Return the second element stored in the pair.
getSequenceNumber() - Method in class org.apache.hadoop.hbase.regionserver.HLog
 
getServer(Object, String, int, Configuration) - Static method in class org.apache.hadoop.hbase.ipc.HBaseRPC
Construct a server for a protocol implementation instance listening on a port and address.
getServer(Object, String, int, int, boolean, Configuration) - Static method in class org.apache.hadoop.hbase.ipc.HBaseRPC
Construct a server for a protocol implementation instance listening on a port and address.
getServer() - Method in class org.apache.hadoop.hbase.master.MetaRegion
 
getServerAddress() - Method in class org.apache.hadoop.hbase.HRegionLocation
 
getServerAddress() - Method in class org.apache.hadoop.hbase.HServerInfo
 
getServerInfo() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getServerName() - Method in class org.apache.hadoop.hbase.client.ServerCallable
 
getServersToLoad() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getServersToServerInfo() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getServerVersion() - Method in exception org.apache.hadoop.hbase.ipc.HBaseRPC.VersionMismatch
 
getSimilarityName() - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
 
getSize() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
getSize() - Method in interface org.apache.hadoop.hbase.io.SequenceFile.ValueBytes
Size of stored data.
getSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getSortedOnlineRegionInfos() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getSplits(JobConf, int) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Calculates the splits that will serve as input for the map tasks.
getStartCode() - Method in class org.apache.hadoop.hbase.HServerInfo
 
getStartEndKeys() - Method in class org.apache.hadoop.hbase.client.HTable
Gets the starting and ending row keys for every region in the currently open table
getStartKey() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getStartKey() - Method in class org.apache.hadoop.hbase.master.MetaRegion
 
getStartKey() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getStartKeys() - Method in class org.apache.hadoop.hbase.client.HTable
Gets the starting row key for every region in the currently open table
getStartRow() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
getStatusForTransaction(long) - Method in class org.apache.hadoop.hbase.client.transactional.LocalTransactionLogger
 
getStatusForTransaction(long) - Method in interface org.apache.hadoop.hbase.client.transactional.TransactionLogger
 
getStopRowKey() - Method in class org.apache.hadoop.hbase.filter.StopRowFilter
An accessor for the stopRowKey
getStore(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Return HStore instance.
getStorefileIndexSizeInMB() - Method in class org.apache.hadoop.hbase.HServerLoad
 
getStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
 
getStorefiles() - Method in class org.apache.hadoop.hbase.HServerLoad
 
getStorefiles() - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
 
getStores() - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
 
getTable(String) - Method in class org.apache.hadoop.hbase.rest.GenericHandler
 
getTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
Creates and returns an HTable instance from a given table name.
getTableDesc() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getTableDesc() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getTableDescriptor(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getTableDescriptor(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getTableDescriptor() - Method in class org.apache.hadoop.hbase.client.HTable
 
getTableDir(Path, byte[]) - Static method in class org.apache.hadoop.hbase.HTableDescriptor
 
getTableName() - Method in class org.apache.hadoop.hbase.client.HTable
 
getTableName() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
getTablename() - Method in class org.apache.hadoop.hbase.regionserver.HLogKey
 
getTableName(String[]) - Method in class org.apache.hadoop.hbase.rest.GenericHandler
 
getTableNames() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
getTableNames() - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
List all the userspace tables.
getTableNames() - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
getTableRegions(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
getTableRegions(byte[]) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
List the regions associated with a table.
getTableRegions(byte[]) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
getTimestamp() - Method in class org.apache.hadoop.hbase.client.HTable.ClientScanner
 
getTimestamp() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
getTimestamp() - Method in class org.apache.hadoop.hbase.HStoreKey.BeforeThisStoreKey
 
getTimestamp() - Method in class org.apache.hadoop.hbase.HStoreKey
 
getTimestamp() - Method in class org.apache.hadoop.hbase.io.BatchUpdate
 
getTimestamp() - Method in class org.apache.hadoop.hbase.io.Cell
 
getTimestamp() - Method in class org.apache.hadoop.hbase.RegionHistorian.RegionHistoryInformation
 
getTimestamp() - Method in class org.apache.hadoop.hbase.regionserver.HLogEdit
 
getTimestampAsString() - Method in class org.apache.hadoop.hbase.RegionHistorian.RegionHistoryInformation
 
getTimeToLive() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getTransactionalRegion(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegionServer
 
getTransactionId() - Method in class org.apache.hadoop.hbase.client.transactional.TransactionState
Get the transactionId.
getTransactionId() - Method in class org.apache.hadoop.hbase.regionserver.HLogEdit
Get the transactionId, or null if this is not a transactional edit.
getType() - Method in class org.apache.hadoop.hbase.HMsg
 
getUrl() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
Get the subversion URL for the root hbase directory.
getUser() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
The user that compiled hbase.
getVal() - Method in class org.apache.hadoop.hbase.regionserver.HLogEdit
 
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
 
getValue(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
getValue() - Method in class org.apache.hadoop.hbase.io.BatchOperation
 
getValue() - Method in class org.apache.hadoop.hbase.io.Cell
 
getValue() - Method in class org.apache.hadoop.hbase.io.RowResult.Entry
 
getValue() - Method in interface org.apache.hadoop.hbase.io.SequenceFile.Sorter.RawKeyValueIterator
Gets the current raw value
getValueClass() - Method in class org.apache.hadoop.hbase.io.MapFile.Reader
Returns the class of values in this file.
getValueClass() - Method in class org.apache.hadoop.hbase.io.SequenceFile.Reader
Returns the class of values in this file.
getValueClass() - Method in class org.apache.hadoop.hbase.io.SequenceFile.Writer
Returns the class of values in this file.
getValueClassName() - Method in class org.apache.hadoop.hbase.io.SequenceFile.Reader
Returns the name of the value class.
getValues() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getValues() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
getVer(byte[], byte[], byte[], int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
getVer(byte[], byte[], byte[], int) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Get the specified number of versions for the specified table, row, and column.
getVer(byte[], byte[], byte[], int) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
getVersion() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getVersion(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Verifies current version of file system
getVersion() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
Get the hbase version.
getVerTs(byte[], byte[], byte[], long, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
getVerTs(byte[], byte[], byte[], long, int) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Get the specified number of versions for the specified table, row, and column.
getVerTs(byte[], byte[], byte[], long, int) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
getWebAppDir(String) - Static method in class org.apache.hadoop.hbase.util.InfoServer
Get the path for this web app
getWebAppsPath() - Method in class org.apache.hadoop.hbase.util.InfoServer
Get the pathname to the path files.
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).
getWriteBuffer() - Method in class org.apache.hadoop.hbase.client.HTable
Get the write buffer
getWriteBufferSize() - Method in class org.apache.hadoop.hbase.client.HTable
Get the maximum size in bytes of the write buffer for this HTable
getWriter(FileSystem, SequenceFile.CompressionType, boolean, int) - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
Get a store file writer.
getXMLOutputter(PrintWriter) - Method in class org.apache.hadoop.hbase.rest.GenericHandler
 
GROUP_COLUMNS - Static variable in class org.apache.hadoop.hbase.mapred.GroupingTableMap
JobConf parameter to specify the columns used to produce the key passed to collect from the map phase
GroupingTableMap - Class in org.apache.hadoop.hbase.mapred
Extract grouping columns from input record
GroupingTableMap() - Constructor for class org.apache.hadoop.hbase.mapred.GroupingTableMap
 
GZIP - Static variable in class org.apache.hadoop.hbase.util.Base64
Specify that data should be gzip-compressed.

H

HAbstractScanner - Class in org.apache.hadoop.hbase.regionserver
Abstract base class that implements the InternalScanner.
HAbstractScanner(long, byte[][]) - Constructor for class org.apache.hadoop.hbase.regionserver.HAbstractScanner
Constructor for abstract base class
HalfMapFileReader - Class in org.apache.hadoop.hbase.io
A facade for a MapFile.Reader that serves up either the top or bottom half of a MapFile where 'bottom' is the first half of the file containing the keys that sort lowest and 'top' is the second half of the file with keys that sort greater than those of the bottom half.
HalfMapFileReader(FileSystem, String, Configuration, Reference.Range, WritableComparable<HStoreKey>, HRegionInfo) - Constructor for class org.apache.hadoop.hbase.io.HalfMapFileReader
 
HalfMapFileReader(FileSystem, String, Configuration, Reference.Range, WritableComparable<HStoreKey>, boolean, boolean, HRegionInfo) - Constructor for class org.apache.hadoop.hbase.io.HalfMapFileReader
 
hasColumn(String) - Method in class org.apache.hadoop.hbase.io.BatchUpdate
Check if the specified column is currently assigned a value
hasColumn(byte[]) - Method in class org.apache.hadoop.hbase.io.BatchUpdate
Check if the specified column is currently assigned a value
hasFamily(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Checks to see if this table contains the given column family
hasFamily(byte[], int) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Checks to see if this table contains the given column family
Hash - Class in org.apache.hadoop.hbase.util
This class represents a common API for hashing functions.
Hash() - Constructor for class org.apache.hadoop.hbase.util.Hash
 
hash(byte[]) - Method in class org.apache.hadoop.hbase.util.Hash
Calculate a hash using all bytes from the input argument, and a seed of -1.
hash(byte[], int) - Method in class org.apache.hadoop.hbase.util.Hash
Calculate a hash using all bytes from the input argument, and a provided seed value.
hash(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.Hash
Calculate a hash using bytes from 0 to length, and the provided seed value
hash(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.JenkinsHash
taken from hashlittle() -- hash a variable-length key into a 32-bit value
hash(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.MurmurHash
 
hashCode() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
hashCode() - Method in class org.apache.hadoop.hbase.HMsg
 
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.HServerAddress
 
hashCode() - Method in class org.apache.hadoop.hbase.HServerInfo
 
hashCode() - Method in class org.apache.hadoop.hbase.HServerLoad
 
hashCode() - Method in class org.apache.hadoop.hbase.HStoreKey.BeforeThisStoreKey
 
hashCode() - Method in class org.apache.hadoop.hbase.HStoreKey
 
hashCode() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
hashCode() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
hashCode() - Method in class org.apache.hadoop.hbase.io.SequenceFile.Metadata
 
hashCode() - Method in class org.apache.hadoop.hbase.io.SequenceFile.Sorter.SegmentDescriptor
 
hashCode() - Method in class org.apache.hadoop.hbase.master.MetaRegion
 
hashCode() - Method in class org.apache.hadoop.hbase.regionserver.HLogKey
 
hashCode() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
hashCode() - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
hashCode() - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
 
hashCode() - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
hashCode() - Method in exception org.apache.hadoop.hbase.thrift.generated.NotFound
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
hashCode(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
hashCode(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
hashCode() - Method in class org.apache.hadoop.hbase.util.Pair
 
Hbase - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase
 
Hbase.atomicIncrement_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.atomicIncrement_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
Hbase.atomicIncrement_args(byte[], byte[], byte[], long) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
Hbase.atomicIncrement_args.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.atomicIncrement_args.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args.Isset
 
Hbase.atomicIncrement_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.atomicIncrement_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
Hbase.atomicIncrement_result(long, IOError, IllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
Hbase.atomicIncrement_result.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.atomicIncrement_result.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result.Isset
 
Hbase.Client - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Client(TProtocol) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
Hbase.Client(TProtocol, TProtocol) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
Hbase.createTable_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.createTable_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
Hbase.createTable_args(byte[], List<ColumnDescriptor>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
Hbase.createTable_args.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.createTable_args.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args.Isset
 
Hbase.createTable_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.createTable_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
Hbase.createTable_result(IOError, IllegalArgument, AlreadyExists) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
Hbase.createTable_result.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.createTable_result.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result.Isset
 
Hbase.deleteAll_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteAll_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
Hbase.deleteAll_args(byte[], byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
Hbase.deleteAll_args.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteAll_args.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args.Isset
 
Hbase.deleteAll_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteAll_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
 
Hbase.deleteAll_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
 
Hbase.deleteAll_result.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteAll_result.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result.Isset
 
Hbase.deleteAllRow_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteAllRow_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
Hbase.deleteAllRow_args(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
Hbase.deleteAllRow_args.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteAllRow_args.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args.Isset
 
Hbase.deleteAllRow_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteAllRow_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
 
Hbase.deleteAllRow_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
 
Hbase.deleteAllRow_result.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteAllRow_result.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result.Isset
 
Hbase.deleteAllRowTs_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteAllRowTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
Hbase.deleteAllRowTs_args(byte[], byte[], long) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
Hbase.deleteAllRowTs_args.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteAllRowTs_args.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args.Isset
 
Hbase.deleteAllRowTs_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteAllRowTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
 
Hbase.deleteAllRowTs_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
 
Hbase.deleteAllRowTs_result.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteAllRowTs_result.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result.Isset
 
Hbase.deleteAllTs_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteAllTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
Hbase.deleteAllTs_args(byte[], byte[], byte[], long) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
Hbase.deleteAllTs_args.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteAllTs_args.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args.Isset
 
Hbase.deleteAllTs_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteAllTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
 
Hbase.deleteAllTs_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
 
Hbase.deleteAllTs_result.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteAllTs_result.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result.Isset
 
Hbase.deleteTable_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteTable_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
 
Hbase.deleteTable_args(byte[]) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
 
Hbase.deleteTable_args.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteTable_args.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args.Isset
 
Hbase.deleteTable_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteTable_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
 
Hbase.deleteTable_result(IOError, NotFound) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
 
Hbase.deleteTable_result.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteTable_result.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result.Isset
 
Hbase.disableTable_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.disableTable_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
 
Hbase.disableTable_args(byte[]) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
 
Hbase.disableTable_args.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.disableTable_args.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args.Isset
 
Hbase.disableTable_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.disableTable_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
 
Hbase.disableTable_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
 
Hbase.disableTable_result.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.disableTable_result.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result.Isset
 
Hbase.enableTable_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.enableTable_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
 
Hbase.enableTable_args(byte[]) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
 
Hbase.enableTable_args.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.enableTable_args.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args.Isset
 
Hbase.enableTable_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.enableTable_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
 
Hbase.enableTable_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
 
Hbase.enableTable_result.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.enableTable_result.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result.Isset
 
Hbase.get_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.get_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
Hbase.get_args(byte[], byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
Hbase.get_args.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.get_args.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args.Isset
 
Hbase.get_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.get_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
Hbase.get_result(TCell, IOError, NotFound) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
Hbase.get_result.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.get_result.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result.Isset
 
Hbase.getColumnDescriptors_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getColumnDescriptors_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
 
Hbase.getColumnDescriptors_args(byte[]) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
 
Hbase.getColumnDescriptors_args.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getColumnDescriptors_args.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args.Isset
 
Hbase.getColumnDescriptors_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getColumnDescriptors_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
Hbase.getColumnDescriptors_result(Map<byte[], ColumnDescriptor>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
Hbase.getColumnDescriptors_result.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getColumnDescriptors_result.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result.Isset
 
Hbase.getRow_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRow_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
Hbase.getRow_args(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
Hbase.getRow_args.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRow_args.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args.Isset
 
Hbase.getRow_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRow_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
Hbase.getRow_result(TRowResult, IOError, NotFound) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
Hbase.getRow_result.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRow_result.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result.Isset
 
Hbase.getRowTs_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
Hbase.getRowTs_args(byte[], byte[], long) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
Hbase.getRowTs_args.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowTs_args.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args.Isset
 
Hbase.getRowTs_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
Hbase.getRowTs_result(TRowResult, IOError, NotFound) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
Hbase.getRowTs_result.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowTs_result.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result.Isset
 
Hbase.getRowWithColumns_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowWithColumns_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
Hbase.getRowWithColumns_args(byte[], byte[], List<byte[]>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
Hbase.getRowWithColumns_args.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowWithColumns_args.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args.Isset
 
Hbase.getRowWithColumns_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowWithColumns_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
Hbase.getRowWithColumns_result(TRowResult, IOError, NotFound) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
Hbase.getRowWithColumns_result.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowWithColumns_result.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result.Isset
 
Hbase.getRowWithColumnsTs_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowWithColumnsTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
Hbase.getRowWithColumnsTs_args(byte[], byte[], List<byte[]>, long) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
Hbase.getRowWithColumnsTs_args.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowWithColumnsTs_args.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args.Isset
 
Hbase.getRowWithColumnsTs_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowWithColumnsTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
Hbase.getRowWithColumnsTs_result(TRowResult, IOError, NotFound) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
Hbase.getRowWithColumnsTs_result.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowWithColumnsTs_result.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result.Isset
 
Hbase.getTableNames_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getTableNames_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
 
Hbase.getTableNames_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getTableNames_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
Hbase.getTableNames_result(List<byte[]>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
Hbase.getTableNames_result.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getTableNames_result.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result.Isset
 
Hbase.getTableRegions_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getTableRegions_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
 
Hbase.getTableRegions_args(byte[]) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
 
Hbase.getTableRegions_args.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getTableRegions_args.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args.Isset
 
Hbase.getTableRegions_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getTableRegions_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
Hbase.getTableRegions_result(List<TRegionInfo>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
Hbase.getTableRegions_result.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getTableRegions_result.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result.Isset
 
Hbase.getVer_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getVer_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
Hbase.getVer_args(byte[], byte[], byte[], int) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
Hbase.getVer_args.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getVer_args.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args.Isset
 
Hbase.getVer_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getVer_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
Hbase.getVer_result(List<TCell>, IOError, NotFound) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
Hbase.getVer_result.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getVer_result.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result.Isset
 
Hbase.getVerTs_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getVerTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
Hbase.getVerTs_args(byte[], byte[], byte[], long, int) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
Hbase.getVerTs_args.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getVerTs_args.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args.Isset
 
Hbase.getVerTs_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getVerTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
Hbase.getVerTs_result(List<TCell>, IOError, NotFound) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
Hbase.getVerTs_result.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getVerTs_result.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result.Isset
 
Hbase.Iface - Interface in org.apache.hadoop.hbase.thrift.generated
 
Hbase.isTableEnabled_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.isTableEnabled_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
 
Hbase.isTableEnabled_args(byte[]) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
 
Hbase.isTableEnabled_args.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.isTableEnabled_args.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args.Isset
 
Hbase.isTableEnabled_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.isTableEnabled_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
Hbase.isTableEnabled_result(boolean, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
Hbase.isTableEnabled_result.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.isTableEnabled_result.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result.Isset
 
Hbase.mutateRow_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.mutateRow_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
Hbase.mutateRow_args(byte[], byte[], List<Mutation>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
Hbase.mutateRow_args.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.mutateRow_args.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args.Isset
 
Hbase.mutateRow_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.mutateRow_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
Hbase.mutateRow_result(IOError, IllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
Hbase.mutateRow_result.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.mutateRow_result.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result.Isset
 
Hbase.mutateRows_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.mutateRows_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
Hbase.mutateRows_args(byte[], List<BatchMutation>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
Hbase.mutateRows_args.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.mutateRows_args.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args.Isset
 
Hbase.mutateRows_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.mutateRows_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
Hbase.mutateRows_result(IOError, IllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
Hbase.mutateRows_result.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.mutateRows_result.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result.Isset
 
Hbase.mutateRowsTs_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.mutateRowsTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
Hbase.mutateRowsTs_args(byte[], List<BatchMutation>, long) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
Hbase.mutateRowsTs_args.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.mutateRowsTs_args.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args.Isset
 
Hbase.mutateRowsTs_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.mutateRowsTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
Hbase.mutateRowsTs_result(IOError, IllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
Hbase.mutateRowsTs_result.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.mutateRowsTs_result.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result.Isset
 
Hbase.mutateRowTs_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.mutateRowTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
Hbase.mutateRowTs_args(byte[], byte[], List<Mutation>, long) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
Hbase.mutateRowTs_args.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.mutateRowTs_args.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args.Isset
 
Hbase.mutateRowTs_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.mutateRowTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
Hbase.mutateRowTs_result(IOError, IllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
Hbase.mutateRowTs_result.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.mutateRowTs_result.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result.Isset
 
Hbase.Processor - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor(Hbase.Iface) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor
 
Hbase.Processor.ProcessFunction - Interface in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerClose_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerClose_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
 
Hbase.scannerClose_args(int) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
 
Hbase.scannerClose_args.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerClose_args.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args.Isset
 
Hbase.scannerClose_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerClose_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
Hbase.scannerClose_result(IOError, IllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
Hbase.scannerClose_result.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerClose_result.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result.Isset
 
Hbase.scannerGet_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerGet_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
 
Hbase.scannerGet_args(int) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
 
Hbase.scannerGet_args.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerGet_args.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args.Isset
 
Hbase.scannerGet_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerGet_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
Hbase.scannerGet_result(TRowResult, IOError, IllegalArgument, NotFound) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
Hbase.scannerGet_result.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerGet_result.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result.Isset
 
Hbase.scannerOpen_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpen_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
Hbase.scannerOpen_args(byte[], byte[], List<byte[]>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
Hbase.scannerOpen_args.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpen_args.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args.Isset
 
Hbase.scannerOpen_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpen_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
Hbase.scannerOpen_result(int, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
Hbase.scannerOpen_result.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpen_result.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result.Isset
 
Hbase.scannerOpenTs_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpenTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
Hbase.scannerOpenTs_args(byte[], byte[], List<byte[]>, long) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
Hbase.scannerOpenTs_args.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpenTs_args.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args.Isset
 
Hbase.scannerOpenTs_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpenTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
Hbase.scannerOpenTs_result(int, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
Hbase.scannerOpenTs_result.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpenTs_result.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result.Isset
 
Hbase.scannerOpenWithStop_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpenWithStop_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
Hbase.scannerOpenWithStop_args(byte[], byte[], byte[], List<byte[]>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
Hbase.scannerOpenWithStop_args.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpenWithStop_args.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args.Isset
 
Hbase.scannerOpenWithStop_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpenWithStop_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
Hbase.scannerOpenWithStop_result(int, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
Hbase.scannerOpenWithStop_result.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpenWithStop_result.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result.Isset
 
Hbase.scannerOpenWithStopTs_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpenWithStopTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
Hbase.scannerOpenWithStopTs_args(byte[], byte[], byte[], List<byte[]>, long) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
Hbase.scannerOpenWithStopTs_args.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpenWithStopTs_args.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args.Isset
 
Hbase.scannerOpenWithStopTs_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpenWithStopTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
Hbase.scannerOpenWithStopTs_result(int, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
Hbase.scannerOpenWithStopTs_result.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpenWithStopTs_result.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result.Isset
 
HBASE_CLIENT_RETRIES_NUMBER_KEY - Static variable in interface org.apache.hadoop.hbase.HConstants
 
HBASE_DIR - Static variable in interface org.apache.hadoop.hbase.HConstants
Parameter name for HBase instance root directory
HBaseAdmin - Class in org.apache.hadoop.hbase.client
Provides administrative functions for HBase
HBaseAdmin(HBaseConfiguration) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin
Constructor
HBaseClient - Class in org.apache.hadoop.hbase.ipc
A client for an IPC service.
HBaseClient(Class<? extends Writable>, Configuration, SocketFactory) - Constructor for class org.apache.hadoop.hbase.ipc.HBaseClient
Construct an IPC client whose values are of the given Writable class.
HBaseClient(Class<? extends Writable>, Configuration) - Constructor for class org.apache.hadoop.hbase.ipc.HBaseClient
Construct an IPC client with the default SocketFactory
HBaseConfiguration - Class in org.apache.hadoop.hbase
Adds HBase configuration files to a Configuration
HBaseConfiguration() - Constructor for class org.apache.hadoop.hbase.HBaseConfiguration
constructor
HBaseConfiguration(Configuration) - Constructor for class org.apache.hadoop.hbase.HBaseConfiguration
Create a clone of passed configuration.
HBaseMapFile - Class in org.apache.hadoop.hbase.io
HBase customizations of MapFile.
HBaseMapFile() - Constructor for class org.apache.hadoop.hbase.io.HBaseMapFile
 
HBaseMapFile.HBaseReader - Class in org.apache.hadoop.hbase.io
A reader capable of reading and caching blocks of the data file.
HBaseMapFile.HBaseReader(FileSystem, String, Configuration, HRegionInfo) - Constructor for class org.apache.hadoop.hbase.io.HBaseMapFile.HBaseReader
 
HBaseMapFile.HBaseReader(FileSystem, String, Configuration, boolean, HRegionInfo) - Constructor for class org.apache.hadoop.hbase.io.HBaseMapFile.HBaseReader
 
HBaseMapFile.HBaseWriter - Class in org.apache.hadoop.hbase.io
 
HBaseMapFile.HBaseWriter(Configuration, FileSystem, String, SequenceFile.CompressionType, HRegionInfo) - Constructor for class org.apache.hadoop.hbase.io.HBaseMapFile.HBaseWriter
 
HbaseMapWritable<K,V> - Class in org.apache.hadoop.hbase.io
A Writable Map.
HbaseMapWritable() - Constructor for class org.apache.hadoop.hbase.io.HbaseMapWritable
 
HbaseObjectWritable - Class in org.apache.hadoop.hbase.io
This is a customized version of the polymorphic hadoop ObjectWritable.
HbaseObjectWritable() - Constructor for class org.apache.hadoop.hbase.io.HbaseObjectWritable
default constructor for writable
HbaseObjectWritable(Object) - Constructor for class org.apache.hadoop.hbase.io.HbaseObjectWritable
 
HbaseObjectWritable(Class<?>, Object) - Constructor for class org.apache.hadoop.hbase.io.HbaseObjectWritable
 
HBaseRPC - Class in org.apache.hadoop.hbase.ipc
A simple RPC mechanism.
HBaseRPC.Server - Class in org.apache.hadoop.hbase.ipc
An RPC Server.
HBaseRPC.Server(Object, Configuration, String, int) - Constructor for class org.apache.hadoop.hbase.ipc.HBaseRPC.Server
Construct an RPC server.
HBaseRPC.Server(Object, Configuration, String, int, int, boolean) - Constructor for class org.apache.hadoop.hbase.ipc.HBaseRPC.Server
Construct an RPC server.
HBaseRPC.VersionMismatch - Exception in org.apache.hadoop.hbase.ipc
A version mismatch for the RPC protocol.
HBaseRPC.VersionMismatch(String, long, long) - Constructor for exception org.apache.hadoop.hbase.ipc.HBaseRPC.VersionMismatch
Create a version mismatch exception
HBaseRPCErrorHandler - Interface in org.apache.hadoop.hbase.ipc
An interface for calling out of RPC for error conditions.
HBaseRpcMetrics - Class in org.apache.hadoop.hbase.ipc
This class is for maintaining the various RPC statistics and publishing them through the metrics interfaces.
HBaseRpcMetrics(String, String, HBaseServer) - Constructor for class org.apache.hadoop.hbase.ipc.HBaseRpcMetrics
 
HBaseRPCProtocolVersion - Interface in org.apache.hadoop.hbase.ipc
There is one version id for all the RPC interfaces.
HBaseServer - Class in org.apache.hadoop.hbase.ipc
An abstract IPC service.
HBaseServer(String, int, Class<? extends Writable>, int, Configuration) - Constructor for class org.apache.hadoop.hbase.ipc.HBaseServer
 
HBaseServer(String, int, Class<? extends Writable>, int, Configuration, String) - Constructor for class org.apache.hadoop.hbase.ipc.HBaseServer
Constructs a server listening on the named port and address.
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
Default constructor.
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, HColumnDescriptor.CompressionType, boolean, boolean, int, int, boolean) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Constructor
HColumnDescriptor.CompressionType - Enum in org.apache.hadoop.hbase
The type of compression.
HConnection - Interface in org.apache.hadoop.hbase.client
Cluster connection.
HConnectionManager - Class in org.apache.hadoop.hbase.client
A non-instantiable class that manages connections to multiple tables in multiple HBase instances.
HConnectionManager() - Constructor for class org.apache.hadoop.hbase.client.HConnectionManager
 
HConstants - Interface in org.apache.hadoop.hbase
HConstants holds a bunch of HBase-related constants
HEADER - Static variable in class org.apache.hadoop.hbase.ipc.HBaseServer
The first four bytes of Hadoop RPC connections
headMap(byte[]) - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
headMap(byte[]) - Method in class org.apache.hadoop.hbase.io.RowResult
 
headMap(K) - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
heapSize() - Method in class org.apache.hadoop.hbase.HStoreKey.BeforeThisStoreKey
 
heapSize() - Method in class org.apache.hadoop.hbase.HStoreKey
 
heapSize() - Method in class org.apache.hadoop.hbase.io.BatchOperation
 
heapSize() - Method in class org.apache.hadoop.hbase.io.BatchUpdate
 
HeapSize - Interface in org.apache.hadoop.hbase.io
Implementations can be asked for an estimate of their size in bytes.
heapSize() - Method in interface org.apache.hadoop.hbase.io.HeapSize
 
HLog - Class in org.apache.hadoop.hbase.regionserver
HLog stores all the edits to the HStore.
HLog(FileSystem, Path, Configuration, LogRollListener) - Constructor for class org.apache.hadoop.hbase.regionserver.HLog
Create an edit log at the given dir location.
HLogEdit - Class in org.apache.hadoop.hbase.regionserver
A log value.
HLogEdit() - Constructor for class org.apache.hadoop.hbase.regionserver.HLogEdit
Default constructor used by Writable
HLogEdit(byte[], byte[], long) - Constructor for class org.apache.hadoop.hbase.regionserver.HLogEdit
Construct a fully initialized HLogEdit
HLogEdit(long, BatchOperation, long) - Constructor for class org.apache.hadoop.hbase.regionserver.HLogEdit
Construct a WRITE transaction.
HLogEdit(long, HLogEdit.TransactionalOperation) - Constructor for class org.apache.hadoop.hbase.regionserver.HLogEdit
Construct a transactional operation (BEGIN, ABORT, or COMMIT).
HLogEdit.TransactionalOperation - Enum in org.apache.hadoop.hbase.regionserver
If transactional log entry, these are the op codes
HLogKey - Class in org.apache.hadoop.hbase.regionserver
A Key for an entry in the change log.
HLogKey() - Constructor for class org.apache.hadoop.hbase.regionserver.HLogKey
Create an empty key useful when deserializing
HLogKey(byte[], byte[], byte[], long) - Constructor for class org.apache.hadoop.hbase.regionserver.HLogKey
Create the log key! We maintain the tablename mainly for debugging purposes.
HMaster - Class in org.apache.hadoop.hbase.master
HMaster is the "master server" for a HBase.
HMaster(HBaseConfiguration) - Constructor for class org.apache.hadoop.hbase.master.HMaster
Build the HMaster out of a raw configuration item.
HMaster(Path, HServerAddress, HBaseConfiguration) - Constructor for class org.apache.hadoop.hbase.master.HMaster
Build the HMaster
HMasterInterface - Interface in org.apache.hadoop.hbase.ipc
Clients interact with the HMasterInterface to gain access to meta-level HBase functionality, like finding an HRegionServer and creating/destroying tables.
HMasterRegionInterface - Interface in org.apache.hadoop.hbase.ipc
HRegionServers interact with the HMasterRegionInterface to report on local goings-on and to obtain data-handling instructions from the HMaster.
HMsg - Class in org.apache.hadoop.hbase
HMsg is for communicating instructions between the HMaster and the HRegionServers.
HMsg() - Constructor for class org.apache.hadoop.hbase.HMsg
Default constructor.
HMsg(HMsg.Type) - Constructor for class org.apache.hadoop.hbase.HMsg
Construct a message with the specified message and empty HRegionInfo
HMsg(HMsg.Type, HRegionInfo) - Constructor for class org.apache.hadoop.hbase.HMsg
Construct a message with the specified message and HRegionInfo
HMsg(HMsg.Type, HRegionInfo, boolean) - Constructor for class org.apache.hadoop.hbase.HMsg
Constructor used by master to inform region servers if we are still in safe mode.
HMsg(HMsg.Type, HRegionInfo, byte[]) - Constructor for class org.apache.hadoop.hbase.HMsg
Construct a message with the specified message and HRegionInfo
HMsg(HMsg.Type, HRegionInfo, byte[], boolean) - Constructor for class org.apache.hadoop.hbase.HMsg
Used by the master to inform region servers if we are still in safe mode
HMsg.Type - Enum in org.apache.hadoop.hbase
Message types sent between master and regionservers
HRegion - Class in org.apache.hadoop.hbase.regionserver
HRegion stores data for a certain region of a table.
HRegion(Path, HLog, FileSystem, HBaseConfiguration, HRegionInfo, FlushRequester) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegion
HRegion constructor.
HREGION_COMPACTIONDIR_NAME - Static variable in interface org.apache.hadoop.hbase.HConstants
Used to construct the name of the compaction directory during compaction
HREGION_LOGDIR_NAME - Static variable in interface org.apache.hadoop.hbase.HConstants
Used to construct the name of the log directory for a region server
HREGION_OLDLOGFILE_NAME - Static variable in interface org.apache.hadoop.hbase.HConstants
Name of old log file for reconstruction
HRegionInfo - Class in org.apache.hadoop.hbase
HRegion information.
HRegionInfo() - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Default constructor - creates empty object
HRegionInfo(HTableDescriptor, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Construct HRegionInfo with explicit parameters
HRegionInfo(HTableDescriptor, byte[], byte[], boolean) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Construct HRegionInfo with explicit parameters
HRegionInfo(HTableDescriptor, byte[], byte[], boolean, long) - 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
HRegionInterface - Interface in org.apache.hadoop.hbase.ipc
Clients interact with HRegionServers using a handle to the HRegionInterface.
HRegionLocation - Class in org.apache.hadoop.hbase
Contains the HRegionInfo for the region and the HServerAddress for the HRegionServer serving the region
HRegionLocation(HRegionInfo, HServerAddress) - Constructor for class org.apache.hadoop.hbase.HRegionLocation
Constructor
HRegionPartitioner<K2,V2> - Class in org.apache.hadoop.hbase.mapred
This is used to partition the output keys into groups of keys.
HRegionPartitioner() - Constructor for class org.apache.hadoop.hbase.mapred.HRegionPartitioner
 
HRegionServer - Class in org.apache.hadoop.hbase.regionserver
HRegionServer makes a set of HRegions available to clients.
HRegionServer(HBaseConfiguration) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegionServer
Starts a HRegionServer at the default location
HRegionServer(HServerAddress, HBaseConfiguration) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegionServer
Starts a HRegionServer at the specified location
HServerAddress - Class in org.apache.hadoop.hbase
HServerAddress is a "label" for a HBase server that combines the host name and port number.
HServerAddress() - Constructor for class org.apache.hadoop.hbase.HServerAddress
Empty constructor, used for Writable
HServerAddress(InetSocketAddress) - Constructor for class org.apache.hadoop.hbase.HServerAddress
Construct a HServerAddress from an InetSocketAddress
HServerAddress(String) - Constructor for class org.apache.hadoop.hbase.HServerAddress
Construct a HServerAddress from a string of the form hostname:port
HServerAddress(String, int) - Constructor for class org.apache.hadoop.hbase.HServerAddress
Construct a HServerAddress from hostname, port number
HServerAddress(HServerAddress) - Constructor for class org.apache.hadoop.hbase.HServerAddress
Construct a HServerAddress from another HServerAddress
HServerInfo - Class in org.apache.hadoop.hbase
HServerInfo contains metainfo about an HRegionServer, Currently it only contains the server start code.
HServerInfo() - Constructor for class org.apache.hadoop.hbase.HServerInfo
default constructor - used by Writable
HServerInfo(HServerAddress, long, int, String) - Constructor for class org.apache.hadoop.hbase.HServerInfo
Constructor
HServerInfo(HServerInfo) - Constructor for class org.apache.hadoop.hbase.HServerInfo
Construct a new object using another as input (like a copy constructor)
HServerLoad - Class in org.apache.hadoop.hbase
This class encapsulates metrics for determining the load on a HRegionServer
HServerLoad() - Constructor for class org.apache.hadoop.hbase.HServerLoad
default constructor (used by Writable)
HServerLoad(int, int, int) - Constructor for class org.apache.hadoop.hbase.HServerLoad
Constructor
HServerLoad(HServerLoad) - Constructor for class org.apache.hadoop.hbase.HServerLoad
Constructor
HServerLoad.RegionLoad - Class in org.apache.hadoop.hbase
Encapsulates per-region loading metrics.
HServerLoad.RegionLoad() - Constructor for class org.apache.hadoop.hbase.HServerLoad.RegionLoad
Constructor, for Writable
HServerLoad.RegionLoad(byte[], int, int, int, int) - Constructor for class org.apache.hadoop.hbase.HServerLoad.RegionLoad
 
HStore - Class in org.apache.hadoop.hbase.regionserver
HStore maintains a bunch of data files.
HStore(Path, HRegionInfo, HColumnDescriptor, FileSystem, Path, HBaseConfiguration, Progressable) - Constructor for class org.apache.hadoop.hbase.regionserver.HStore
An HStore is a set of zero or more MapFiles, which stretch backwards over time.
HStoreFile - Class in org.apache.hadoop.hbase.regionserver
A HStore data file.
HStoreKey - Class in org.apache.hadoop.hbase
A Key for a stored row.
HStoreKey() - Constructor for class org.apache.hadoop.hbase.HStoreKey
Default constructor used in conjunction with Writable interface
HStoreKey(byte[]) - Constructor for class org.apache.hadoop.hbase.HStoreKey
Create an HStoreKey specifying only the row The column defaults to the empty string, the time stamp defaults to Long.MAX_VALUE and the table defaults to empty string
HStoreKey(String) - Constructor for class org.apache.hadoop.hbase.HStoreKey
Create an HStoreKey specifying only the row The column defaults to the empty string, the time stamp defaults to Long.MAX_VALUE and the table defaults to empty string
HStoreKey(byte[], HRegionInfo) - Constructor for class org.apache.hadoop.hbase.HStoreKey
Create an HStoreKey specifying the row and timestamp The column and table names default to the empty string
HStoreKey(byte[], long, HRegionInfo) - Constructor for class org.apache.hadoop.hbase.HStoreKey
Create an HStoreKey specifying the row and timestamp The column and table names default to the empty string
HStoreKey(byte[], long) - Constructor for class org.apache.hadoop.hbase.HStoreKey
Create an HStoreKey specifying the row and timestamp The column and table names default to the empty string
HStoreKey(String, long) - Constructor for class org.apache.hadoop.hbase.HStoreKey
Create an HStoreKey specifying the row and timestamp The column and table names default to the empty string
HStoreKey(String, String) - Constructor for class org.apache.hadoop.hbase.HStoreKey
Create an HStoreKey specifying the row and column names The timestamp defaults to LATEST_TIMESTAMP and table name defaults to the empty string
HStoreKey(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.HStoreKey
Create an HStoreKey specifying the row and column names The timestamp defaults to LATEST_TIMESTAMP and table name defaults to the empty string
HStoreKey(byte[], byte[], HRegionInfo) - Constructor for class org.apache.hadoop.hbase.HStoreKey
Create an HStoreKey specifying the row, column names and table name The timestamp defaults to LATEST_TIMESTAMP
HStoreKey(String, String, long, HRegionInfo) - Constructor for class org.apache.hadoop.hbase.HStoreKey
Create an HStoreKey specifying all the fields Does not make copies of the passed byte arrays.
HStoreKey(byte[], byte[], long) - Constructor for class org.apache.hadoop.hbase.HStoreKey
Create an HStoreKey specifying all the fields with unspecified table Does not make copies of the passed byte arrays.
HStoreKey(byte[], byte[], long, HRegionInfo) - Constructor for class org.apache.hadoop.hbase.HStoreKey
Create an HStoreKey specifying all the fields with specified table Does not make copies of the passed byte arrays.
HStoreKey(HStoreKey) - Constructor for class org.apache.hadoop.hbase.HStoreKey
Constructs a new HStoreKey from another
HStoreKey.BeforeThisStoreKey - Class in org.apache.hadoop.hbase
Pass this class into MapFile.getClosest when searching for the key that comes BEFORE this one but NOT this one.
HStoreKey.BeforeThisStoreKey(HStoreKey) - Constructor for class org.apache.hadoop.hbase.HStoreKey.BeforeThisStoreKey
 
HStoreKey.HStoreKeyWritableComparator - Class in org.apache.hadoop.hbase
Passed as comparator for memcache and for store files.
HStoreKey.HStoreKeyWritableComparator(HRegionInfo) - Constructor for class org.apache.hadoop.hbase.HStoreKey.HStoreKeyWritableComparator
 
HTable - Class in org.apache.hadoop.hbase.client
Used to communicate with a single HBase table
HTable(String) - Constructor for class org.apache.hadoop.hbase.client.HTable
Creates an object to access a HBase table
HTable(byte[]) - Constructor for class org.apache.hadoop.hbase.client.HTable
Creates an object to access a HBase table
HTable(HBaseConfiguration, String) - Constructor for class org.apache.hadoop.hbase.client.HTable
Creates an object to access a HBase table
HTable(HBaseConfiguration, byte[]) - Constructor for class org.apache.hadoop.hbase.client.HTable
Creates an object to access a HBase table
HTable.ClientScanner - Class in org.apache.hadoop.hbase.client
Implements the scanner interface for the HBase client.
HTable.ClientScanner(byte[][], byte[], long, RowFilterInterface) - Constructor for class org.apache.hadoop.hbase.client.HTable.ClientScanner
 
HTableDescriptor - Class in org.apache.hadoop.hbase
HTableDescriptor contains the name of an HTable, and its column families.
HTableDescriptor(byte[], HColumnDescriptor[]) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Private constructor used internally creating table descriptors for catalog tables: e.g.
HTableDescriptor(byte[], HColumnDescriptor[], Collection<IndexSpecification>, Map<ImmutableBytesWritable, ImmutableBytesWritable>) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Private constructor used internally creating table descriptors for catalog tables: e.g.
HTableDescriptor() - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Constructs an empty object.
HTableDescriptor(String) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Constructor.
HTableDescriptor(byte[]) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Constructor.
HTableDescriptor(HTableDescriptor) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Constructor.

I

ia - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
ia - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result.Isset
 
ia - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
ia - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result.Isset
 
ia - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
ia - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result.Isset
 
ia - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
ia - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result.Isset
 
ia - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
ia - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result.Isset
 
ia - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
ia - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result.Isset
 
ia - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
ia - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result.Isset
 
ia - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
ia - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result.Isset
 
id - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
 
id - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args.Isset
 
id - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
 
id - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args.Isset
 
id - Variable in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
id - Variable in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo.Isset
 
IdentityTableMap - Class in org.apache.hadoop.hbase.mapred
Pass the given key and record as-is to reduce
IdentityTableMap() - Constructor for class org.apache.hadoop.hbase.mapred.IdentityTableMap
constructor
IdentityTableReduce - Class in org.apache.hadoop.hbase.mapred
Write to table each key, record pair
IdentityTableReduce() - Constructor for class org.apache.hadoop.hbase.mapred.IdentityTableReduce
 
IllegalArgument - Exception in org.apache.hadoop.hbase.thrift.generated
An IllegalArgument exception indicates an illegal or invalid argument was passed into a procedure.
IllegalArgument() - Constructor for exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
 
IllegalArgument(String) - Constructor for exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
 
IllegalArgument.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
IllegalArgument.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.IllegalArgument.Isset
 
ImmutableBytesWritable - Class in org.apache.hadoop.hbase.io
A byte sequence that is usable as a key or value.
ImmutableBytesWritable() - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable
Create a zero-size sequence.
ImmutableBytesWritable(byte[]) - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable
Create a ImmutableBytesWritable using the byte array as the initial value.
ImmutableBytesWritable(ImmutableBytesWritable) - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable
Set the new ImmutableBytesWritable to a copy of the contents of the passed ibw.
ImmutableBytesWritable(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable
Set the value to a copy of the given byte range
ImmutableBytesWritable.Comparator - Class in org.apache.hadoop.hbase.io
A Comparator optimized for ImmutableBytesWritable.
ImmutableBytesWritable.Comparator() - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable.Comparator
constructor
IN_MEMORY - Static variable in interface org.apache.hadoop.hbase.HConstants
 
inc(int) - Method in class org.apache.hadoop.hbase.metrics.MetricsRate
 
inc() - Method in class org.apache.hadoop.hbase.metrics.MetricsRate
 
InclusiveStopRowFilter - Class in org.apache.hadoop.hbase.filter
Subclass of StopRowFilter that filters rows > the stop row, making it include up to the last row but no further.
InclusiveStopRowFilter() - Constructor for class org.apache.hadoop.hbase.filter.InclusiveStopRowFilter
Default constructor, filters nothing.
InclusiveStopRowFilter(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.InclusiveStopRowFilter
Constructor that takes a stopRowKey on which to filter
incrementBytes(byte[], long) - Static method in class org.apache.hadoop.hbase.util.Bytes
Bytewise binary increment/deincrement of long contained in byte array on given amount.
incrementColumnValue(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.HTable
 
incrementColumnValue(byte[], byte[], byte[], long) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
Atomically increments a column value.
incrementColumnValue(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
incrementColumnValue(byte[], byte[], byte[], long) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Atomically increments a column value.
incrementRequests(int) - Method in class org.apache.hadoop.hbase.master.metrics.MasterMetrics
 
incrementRequests(int) - Method in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
 
INDEX_BASE_ROW_COLUMN - Static variable in class org.apache.hadoop.hbase.client.tableindexed.IndexedTable
 
INDEX_COL_FAMILY - Static variable in class org.apache.hadoop.hbase.client.tableindexed.IndexedTable
 
INDEX_COL_FAMILY_NAME - Static variable in class org.apache.hadoop.hbase.client.tableindexed.IndexedTable
 
INDEX_FILE_NAME - Static variable in class org.apache.hadoop.hbase.io.MapFile
The name of the index file.
IndexConfiguration - Class in org.apache.hadoop.hbase.mapred
Configuration parameters for building a Lucene index
IndexConfiguration() - Constructor for class org.apache.hadoop.hbase.mapred.IndexConfiguration
 
IndexConfiguration.ColumnConf - Class in org.apache.hadoop.hbase.mapred
 
IndexConfiguration.ColumnConf() - Constructor for class org.apache.hadoop.hbase.mapred.IndexConfiguration.ColumnConf
 
IndexedRegionInterface - Interface in org.apache.hadoop.hbase.ipc
Interface for the indexed region server.
IndexedRegionServer - Class in org.apache.hadoop.hbase.regionserver.tableindexed
RegionServer which maintains secondary indexes.
IndexedRegionServer(HBaseConfiguration) - Constructor for class org.apache.hadoop.hbase.regionserver.tableindexed.IndexedRegionServer
 
IndexedRegionServer(HServerAddress, HBaseConfiguration) - Constructor for class org.apache.hadoop.hbase.regionserver.tableindexed.IndexedRegionServer
 
IndexedTable - Class in org.apache.hadoop.hbase.client.tableindexed
HTable extended with indexed support.
IndexedTable(HBaseConfiguration, byte[]) - Constructor for class org.apache.hadoop.hbase.client.tableindexed.IndexedTable
 
IndexedTableAdmin - Class in org.apache.hadoop.hbase.client.tableindexed
Extension of HBaseAdmin that creates indexed tables.
IndexedTableAdmin(HBaseConfiguration) - Constructor for class org.apache.hadoop.hbase.client.tableindexed.IndexedTableAdmin
Constructor
IndexKeyGenerator - Interface in org.apache.hadoop.hbase.client.tableindexed
 
indexLength() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
 
IndexNotFoundException - Exception in org.apache.hadoop.hbase.client.tableindexed
Thrown when asking for an index that does not exist.
IndexNotFoundException() - Constructor for exception org.apache.hadoop.hbase.client.tableindexed.IndexNotFoundException
 
IndexNotFoundException(String) - Constructor for exception org.apache.hadoop.hbase.client.tableindexed.IndexNotFoundException
 
IndexNotFoundException(Throwable) - Constructor for exception org.apache.hadoop.hbase.client.tableindexed.IndexNotFoundException
 
IndexNotFoundException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.client.tableindexed.IndexNotFoundException
 
IndexOutputFormat - Class in org.apache.hadoop.hbase.mapred
Create a local index, unwrap Lucene documents created by reduce, add them to the index, and copy the index to the destination.
IndexOutputFormat() - Constructor for class org.apache.hadoop.hbase.mapred.IndexOutputFormat
 
IndexSpecification - Class in org.apache.hadoop.hbase.client.tableindexed
Holds the specification for a single secondary index.
IndexSpecification(String, byte[]) - Constructor for class org.apache.hadoop.hbase.client.tableindexed.IndexSpecification
Construct an "simple" index spec for a single column.
IndexSpecification(String, byte[][], byte[][], IndexKeyGenerator) - Constructor for class org.apache.hadoop.hbase.client.tableindexed.IndexSpecification
Construct an index spec by specifying everything.
IndexSpecification() - Constructor for class org.apache.hadoop.hbase.client.tableindexed.IndexSpecification
 
IndexTableReduce - Class in org.apache.hadoop.hbase.mapred
Construct a Lucene document per row, which is consumed by IndexOutputFormat to build a Lucene index
IndexTableReduce() - Constructor for class org.apache.hadoop.hbase.mapred.IndexTableReduce
 
InfoServer - Class in org.apache.hadoop.hbase.util
Create a Jetty embedded server to answer http requests.
InfoServer(String, String, int, boolean) - Constructor for class org.apache.hadoop.hbase.util.InfoServer
Create a status server on the given port.
init() - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase.TableRecordReader
Build the scanner.
init(String, ContextFactory) - Method in class org.apache.hadoop.hbase.metrics.file.TimeStampingFileContext
 
init(MapWritable) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
init(MapWritable) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegionServer
 
init() - Method in class org.apache.hadoop.hbase.rest.Dispatcher
 
initialChore() - Method in class org.apache.hadoop.hbase.Chore
Override to run a task before we start looping.
initialize() - Method in class org.apache.hadoop.hbase.client.HTable.ClientScanner
 
initialize(Path, Progressable) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Initialize this region and get it ready to roll.
initJob(String, String, String, Class<? extends TableMap>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
Use this before submitting a TableMap job.
initJob(String, String, Class<? extends TableMap>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.IdentityTableMap
Use this before submitting a TableMap job.
initTableMapJob(String, String, Class<? extends TableMap>, Class<? extends WritableComparable>, Class<? extends Writable>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableReduceJob(String, Class<? extends TableReduce>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Use this before submitting a TableReduce job.
initTableReduceJob(String, Class<? extends TableReduce>, JobConf, Class) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Use this before submitting a TableReduce job.
inMemory - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
inMemory - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor.Isset
 
instantiateHStore(Path, HColumnDescriptor, Path, Progressable) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
instantiateRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
instantiateRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.regionserver.tableindexed.IndexedRegionServer
 
instantiateRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegionServer
 
instantiateServer(boolean) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
instantiateServer(boolean) - Method in class org.apache.hadoop.hbase.client.ServerCallable
 
InternalScanner - Interface in org.apache.hadoop.hbase.regionserver
Internal scanners differ from client-side scanners in that they operate on HStoreKeys and byte[] instead of RowResults.
INVALID_HASH - Static variable in class org.apache.hadoop.hbase.util.Hash
Constant to denote invalid hash type.
InvalidColumnNameException - Exception in org.apache.hadoop.hbase.master
Thrown when an invalid column name is encountered
InvalidColumnNameException() - Constructor for exception org.apache.hadoop.hbase.master.InvalidColumnNameException
default constructor
InvalidColumnNameException(String) - Constructor for exception org.apache.hadoop.hbase.master.InvalidColumnNameException
Constructor
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
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result.Isset
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result.Isset
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result.Isset
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result.Isset
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result.Isset
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result.Isset
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result.Isset
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result.Isset
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result.Isset
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result.Isset
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result.Isset
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result.Isset
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result.Isset
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result.Isset
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result.Isset
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result.Isset
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result.Isset
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result.Isset
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result.Isset
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result.Isset
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result.Isset
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result.Isset
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result.Isset
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result.Isset
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result.Isset
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result.Isset
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result.Isset
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result.Isset
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result.Isset
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result.Isset
 
IOError - Exception in org.apache.hadoop.hbase.thrift.generated
An IOError exception signals that an error occurred communicating to the Hbase master or an Hbase region server.
IOError() - Constructor for exception org.apache.hadoop.hbase.thrift.generated.IOError
 
IOError(String) - Constructor for exception org.apache.hadoop.hbase.thrift.generated.IOError
 
IOError.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
IOError.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.IOError.Isset
 
iprot_ - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
IS_META - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
IS_META_KEY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
IS_ROOT - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
IS_ROOT_KEY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
isAutoFlush() - Method in class org.apache.hadoop.hbase.client.HTable
Get the value of autoFlush.
isBlockCacheEnabled() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
isBlockCompressed() - Method in class org.apache.hadoop.hbase.io.SequenceFile.Reader
Returns true if records are block-compressed.
isBloomfilter() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
isClosed() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
isClosing() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
isCompressed() - Method in class org.apache.hadoop.hbase.io.SequenceFile.Reader
Returns true if values are compressed.
isDelete - Variable in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
isDelete - Variable in class org.apache.hadoop.hbase.thrift.generated.Mutation.Isset
 
isDeleted(byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.HLogEdit
 
isEmpty() - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
isEmpty() - Method in class org.apache.hadoop.hbase.io.RowResult
 
isEmpty() - Method in class org.apache.hadoop.hbase.util.SoftValueMap
 
isEmpty() - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
isIndex(String) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
 
isInMemory() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
isInMemory() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
isInSafeMode() - Method in class org.apache.hadoop.hbase.HMsg
 
isInSafeMode() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
isLegalFamilyName(byte[]) - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
 
isLegalTableName(byte[]) - Static method in class org.apache.hadoop.hbase.HTableDescriptor
Check passed buffer is legal user-space table name.
isLocal(Configuration) - Static method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
isMajorCompaction() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
 
isMasterRunning() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isMasterRunning() - Method in interface org.apache.hadoop.hbase.client.HConnection
 
isMasterRunning() - Method in interface org.apache.hadoop.hbase.ipc.HMasterInterface
 
isMasterRunning() - Method in class org.apache.hadoop.hbase.master.HMaster
 
isMetaColumn(byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.HLog
 
isMetaRegion() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
isMetaRegion() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
isMetaTable() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
isMetaTable() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
isMetaTableName(byte[]) - Static method in class org.apache.hadoop.hbase.util.MetaUtils
 
isMultipleMatchScanner() - Method in class org.apache.hadoop.hbase.regionserver.HAbstractScanner
 
isMultipleMatchScanner() - Method in interface org.apache.hadoop.hbase.regionserver.InternalScanner
 
isOffline() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
isOmitNorms(String) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
 
isOnline() - Method in class org.apache.hadoop.hbase.RegionHistorian
 
isOnline - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
isOnline() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Report the status of the server.
isPut() - Method in class org.apache.hadoop.hbase.io.BatchOperation
 
isReadOnly() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
isReference(Path) - Static method in class org.apache.hadoop.hbase.regionserver.HStore
 
isRootRegion() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
isRootRegion() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
isSplit() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
isStopRequested() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
isStore(String) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
 
isTableDisabled(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableDisabled(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
 
isTableEnabled(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableEnabled(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableEnabled(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
A table that isTableEnabled == false and isTableDisabled == false is possible.
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(HBaseConfiguration, String) - Static method in class org.apache.hadoop.hbase.client.HTable
 
isTableEnabled(HBaseConfiguration, byte[]) - Static method in class org.apache.hadoop.hbase.client.HTable
 
isTableEnabled(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
isTableEnabled(byte[]) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
 
isTableEnabled(byte[]) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
isTokenize(String) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
 
isTopFileRegion(Reference.Range) - Static method in class org.apache.hadoop.hbase.io.Reference
 
isTransactionEntry() - Method in class org.apache.hadoop.hbase.regionserver.HLogEdit
 
isType(HMsg.Type) - Method in class org.apache.hadoop.hbase.HMsg
 
isUseCompoundFile() - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
 
isWildcardScanner() - Method in class org.apache.hadoop.hbase.regionserver.HAbstractScanner
 
isWildcardScanner() - Method in interface org.apache.hadoop.hbase.regionserver.InternalScanner
 
iterator() - Method in class org.apache.hadoop.hbase.client.HTable.ClientScanner
 
iterator() - Method in class org.apache.hadoop.hbase.io.BatchUpdate
 
iterator() - Method in class org.apache.hadoop.hbase.io.Cell
 

J

JENKINS_HASH - Static variable in class org.apache.hadoop.hbase.util.Hash
Constant to denote JenkinsHash.
JenkinsHash - Class in org.apache.hadoop.hbase.util
Produces 32-bit hash for hash table lookup.
JenkinsHash() - Constructor for class org.apache.hadoop.hbase.util.JenkinsHash
 
join() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
Wait for the server to be stopped.
join() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
Wait for Mini HBase Cluster to shut down.

K

Keying - Class in org.apache.hadoop.hbase.util
Utility creating hbase friendly keys.
Keying() - Constructor for class org.apache.hadoop.hbase.util.Keying
 
keySerializer - Variable in class org.apache.hadoop.hbase.io.SequenceFile.Writer
 
keySet() - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
keySet() - Method in class org.apache.hadoop.hbase.io.RowResult
 
keySet() - Method in class org.apache.hadoop.hbase.util.SoftValueMap
 
keySet() - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
keyToUri(String) - Static method in class org.apache.hadoop.hbase.util.Keying
Reverse the Keying.createKey(String) transform.

L

LAST_ROW - Static variable in interface org.apache.hadoop.hbase.HConstants
Used by scanners and others when they're trying to detect the end of a table
lastKey() - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
lastKey() - Method in class org.apache.hadoop.hbase.io.RowResult
 
lastKey() - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
LATEST_TIMESTAMP - Static variable in interface org.apache.hadoop.hbase.HConstants
Timestamp to use when we want to refer to the latest cell.
LeaseException - Exception in org.apache.hadoop.hbase
Reports a problem with a lease
LeaseException() - Constructor for exception org.apache.hadoop.hbase.LeaseException
default constructor
LeaseException(String) - Constructor for exception org.apache.hadoop.hbase.LeaseException
 
leaseExpired() - Method in interface org.apache.hadoop.hbase.LeaseListener
When a lease expires, this method is called.
LeaseListener - Interface in org.apache.hadoop.hbase
LeaseListener is an interface meant to be implemented by users of the Leases class.
Leases - Class in org.apache.hadoop.hbase
Leases There are several server classes in HBase that need to track external clients that occasionally send heartbeats.
Leases(int, int) - Constructor for class org.apache.hadoop.hbase.Leases
Creates a lease monitor
leases - Variable in class org.apache.hadoop.hbase.Leases
 
Leases.LeaseStillHeldException - Exception in org.apache.hadoop.hbase
Thrown if we are asked create a lease but lease on passed name already exists.
Leases.LeaseStillHeldException(String) - Constructor for exception org.apache.hadoop.hbase.Leases.LeaseStillHeldException
 
LENGTH - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
length() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
 
LIMIT - Static variable in class org.apache.hadoop.hbase.rest.GenericHandler
 
limitNumMapTasks(String, JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Ensures that the given number of map tasks for the given job configuration does not exceed the number of regions for the given table.
limitNumReduceTasks(String, JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Ensures that the given number of reduce tasks for the given job configuration does not exceed the number of regions for the given table.
listTables() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
List all the userspace tables.
listTables() - Method in interface org.apache.hadoop.hbase.client.HConnection
List all the userspace tables.
LOCAL - Static variable in class org.apache.hadoop.hbase.LocalHBaseCluster
local mode
LOCAL_COLON - Static variable in class org.apache.hadoop.hbase.LocalHBaseCluster
'local:'
LocalHBaseCluster - Class in org.apache.hadoop.hbase
This class creates a single process HBase cluster.
LocalHBaseCluster(HBaseConfiguration) - Constructor for class org.apache.hadoop.hbase.LocalHBaseCluster
Constructor.
LocalHBaseCluster(HBaseConfiguration, int) - Constructor for class org.apache.hadoop.hbase.LocalHBaseCluster
Constructor.
LocalHBaseCluster.RegionServerThread - Class in org.apache.hadoop.hbase
runs region servers
LocalTransactionLogger - Class in org.apache.hadoop.hbase.client.transactional
A local, in-memory implementation of the transaction logger.
locateRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Find the location of the region of tableName that row lives in.
location - Variable in class org.apache.hadoop.hbase.client.ServerCallable
 
lock - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
lockRow(byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Obtain a row lock
lockRow(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
Opens a remote row lock.
lockRow(byte[], byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
LOG - Static variable in class org.apache.hadoop.hbase.io.HbaseObjectWritable
 
LOG - Static variable in class org.apache.hadoop.hbase.ipc.HBaseClient
 
LOG - Static variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
log - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
LOG - Variable in class org.apache.hadoop.hbase.rest.GenericHandler
 
LOG - Variable in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
LOG - Static variable in class org.apache.hadoop.hbase.util.Threads
 
LogFlusher - Class in org.apache.hadoop.hbase.regionserver
LogFlusher is a Chore that wakes every threadWakeInterval and calls the HLog to do an optional sync if there are unflushed entries, and the optionalFlushInterval has passed since the last flush.
LogRollListener - Interface in org.apache.hadoop.hbase.regionserver
Mechanism by which the HLog requests a log roll
logRollRequested() - Method in interface org.apache.hadoop.hbase.regionserver.LogRollListener
Request that the log be rolled

M

m_columns - Variable in class org.apache.hadoop.hbase.mapred.GroupingTableMap
 
main(String[]) - Static method in class org.apache.hadoop.hbase.io.BatchUpdate
Code to test sizes of BatchUpdate arrays.
main(String[]) - Static method in class org.apache.hadoop.hbase.io.MapFile
 
main(String[]) - Static method in class org.apache.hadoop.hbase.LocalHBaseCluster
Test things basically work.
main(String[]) - Static method in class org.apache.hadoop.hbase.mapred.BuildTableIndex
 
main(String[]) - Static method in class org.apache.hadoop.hbase.mapred.Driver
 
main(String[]) - Static method in class org.apache.hadoop.hbase.mapred.RowCounter
 
main(String[]) - Static method in class org.apache.hadoop.hbase.master.HMaster
Main program
main(String[]) - Static method in class org.apache.hadoop.hbase.regionserver.HLog
Pass one or more log file names and it will either dump out a text version on stdout or split the specified log files.
main(String[]) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
main(String[]) - Static method in class org.apache.hadoop.hbase.rest.Dispatcher
 
main(String[]) - Static method in class org.apache.hadoop.hbase.thrift.ThriftServer
 
main(String[]) - Static method in class org.apache.hadoop.hbase.util.Base64
Main program.
main(String[]) - Static method in class org.apache.hadoop.hbase.util.JenkinsHash
Compute the hash of the specified file
main(String[]) - Static method in class org.apache.hadoop.hbase.util.Merge
Main program
main(String[]) - Static method in class org.apache.hadoop.hbase.util.Migrate
Main program
main(String[]) - Static method in class org.apache.hadoop.hbase.util.VersionInfo
 
MAJOR_COMPACTION_PERIOD - Static variable in interface org.apache.hadoop.hbase.HConstants
Parameter name for how often a region should should perform a major compaction
majorCompact(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Major compact a table or an individual region
majorCompact(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Major compact a table or an individual region
makeColumnFamilyDirs(FileSystem, Path, int, byte[], HTableDescriptor) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Make the directories for a specific column family
makeColumnName(String) - Method in class org.apache.hadoop.hbase.rest.GenericHandler
 
map(ImmutableBytesWritable, RowResult, OutputCollector<ImmutableBytesWritable, RowResult>, Reporter) - Method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
Extract the grouping columns from value to construct a new key.
map(ImmutableBytesWritable, RowResult, OutputCollector<ImmutableBytesWritable, RowResult>, Reporter) - Method in class org.apache.hadoop.hbase.mapred.IdentityTableMap
Pass the key, value to reduce
map(ImmutableBytesWritable, RowResult, OutputCollector<ImmutableBytesWritable, RowResult>, Reporter) - Method in class org.apache.hadoop.hbase.mapred.RowCounter
 
MapFile - Class in org.apache.hadoop.hbase.io
A file-based map from keys to values.
MapFile() - Constructor for class org.apache.hadoop.hbase.io.MapFile
 
MapFile.Reader - Class in org.apache.hadoop.hbase.io
Provide access to an existing map.
MapFile.Reader(FileSystem, String, Configuration) - Constructor for class org.apache.hadoop.hbase.io.MapFile.Reader
Construct a map reader for the named map.
MapFile.Reader(FileSystem, String, WritableComparator, Configuration) - Constructor for class org.apache.hadoop.hbase.io.MapFile.Reader
Construct a map reader for the named map using the named comparator.
MapFile.Reader(FileSystem, String, WritableComparator, Configuration, boolean) - Constructor for class org.apache.hadoop.hbase.io.MapFile.Reader
Hook to allow subclasses to defer opening streams until further initialization is complete.
MapFile.Writer - Class in org.apache.hadoop.hbase.io
Writes a new map.
MapFile.Writer(Configuration, FileSystem, String, Class<? extends WritableComparable>, Class) - Constructor for class org.apache.hadoop.hbase.io.MapFile.Writer
Create the named map for keys of the named class.
MapFile.Writer(Configuration, FileSystem, String, Class<? extends WritableComparable>, Class, SequenceFile.CompressionType, Progressable) - Constructor for class org.apache.hadoop.hbase.io.MapFile.Writer
Create the named map for keys of the named class.
MapFile.Writer(Configuration, FileSystem, String, Class<? extends WritableComparable>, Class, SequenceFile.CompressionType, CompressionCodec, Progressable) - Constructor for class org.apache.hadoop.hbase.io.MapFile.Writer
Create the named map for keys of the named class.
MapFile.Writer(Configuration, FileSystem, String, Class<? extends WritableComparable>, Class, SequenceFile.CompressionType) - Constructor for class org.apache.hadoop.hbase.io.MapFile.Writer
Create the named map for keys of the named class.
MapFile.Writer(Configuration, FileSystem, String, WritableComparator, Class) - Constructor for class org.apache.hadoop.hbase.io.MapFile.Writer
Create the named map using the named key comparator.
MapFile.Writer(Configuration, FileSystem, String, WritableComparator, Class, SequenceFile.CompressionType) - Constructor for class org.apache.hadoop.hbase.io.MapFile.Writer
Create the named map using the named key comparator.
MapFile.Writer(Configuration, FileSystem, String, WritableComparator, Class, SequenceFile.CompressionType, Progressable) - Constructor for class org.apache.hadoop.hbase.io.MapFile.Writer
Create the named map using the named key comparator.
MapFile.Writer(Configuration, FileSystem, String, WritableComparator, Class, SequenceFile.CompressionType, CompressionCodec, Progressable) - Constructor for class org.apache.hadoop.hbase.io.MapFile.Writer
Create the named map using the named key comparator.
MAPFILE_INDEX_INTERVAL - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
mapKey(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
mapKey(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
mark(int) - Method in class org.apache.hadoop.hbase.io.BlockFSInputStream
 
markSupported() - Method in class org.apache.hadoop.hbase.io.BlockFSInputStream
We don't support marks.
MASTER - Static variable in class org.apache.hadoop.hbase.master.HMaster
Name of master server
MASTER_ADDRESS - Static variable in interface org.apache.hadoop.hbase.HConstants
Parameter name for master address
MasterMetrics - Class in org.apache.hadoop.hbase.master.metrics
This class is for maintaining the various master statistics and publishing them through the metrics interfaces.
MasterMetrics() - Constructor for class org.apache.hadoop.hbase.master.metrics.MasterMetrics
 
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
matchesRowCol(HStoreKey) - Method in class org.apache.hadoop.hbase.HStoreKey.BeforeThisStoreKey
 
matchesRowCol(HStoreKey) - Method in class org.apache.hadoop.hbase.HStoreKey
Compares the row and column of two keys
matchesRowFamily(HStoreKey) - Method in class org.apache.hadoop.hbase.HStoreKey.BeforeThisStoreKey
 
matchesRowFamily(HStoreKey) - Method in class org.apache.hadoop.hbase.HStoreKey
Compares the row and column family of two keys
matchesWithoutColumn(HStoreKey) - Method in class org.apache.hadoop.hbase.HStoreKey.BeforeThisStoreKey
 
matchesWithoutColumn(HStoreKey) - Method in class org.apache.hadoop.hbase.HStoreKey
Compares the row and timestamp of two keys
matchingFamily(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.HStoreKey
 
MAX_FILESIZE - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
MAX_FILESIZE_KEY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
MAX_ROW_LENGTH - Static variable in interface org.apache.hadoop.hbase.HConstants
Max length a row can have because of the limitation in TFile.
maxValueLength - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor.Isset
 
maxValueLength - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
maxVersions - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor.Isset
 
maxVersions - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
memcache - Variable in class org.apache.hadoop.hbase.regionserver.HStore
 
MEMCACHE_FLUSHSIZE - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
MEMCACHE_FLUSHSIZE_KEY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
memcacheSizeMB - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
Sum of all the memcache sizes in this regionserver in MB
merge(List<SequenceFile.Sorter.SegmentDescriptor>, Path) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Sorter
Merges the list of segments of type SegmentDescriptor
merge(Path[], boolean, Path) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Sorter
Merges the contents of files passed in Path[] using a max factor value that is already set
merge(Path[], boolean, int, Path) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Sorter
Merges the contents of files passed in Path[]
merge(Path[], Path, boolean) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Sorter
Merges the contents of files passed in Path[]
merge(Path[], Path) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Sorter
Merge the provided files.
merge(HRegion, HRegion) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Merge two regions whether they are adjacent or not.
Merge - Class in org.apache.hadoop.hbase.util
Utility that can merge any two regions in the same table: adjacent, overlapping or disjoint.
Merge() - Constructor for class org.apache.hadoop.hbase.util.Merge
default constructor
Merge(HBaseConfiguration) - Constructor for class org.apache.hadoop.hbase.util.Merge
 
mergeAdjacent(HRegion, HRegion) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Merge two HRegions.
message - Variable in class org.apache.hadoop.hbase.thrift.generated.AlreadyExists.Isset
 
message - Variable in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
 
message - Variable in class org.apache.hadoop.hbase.thrift.generated.IllegalArgument.Isset
 
message - Variable in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
 
message - Variable in class org.apache.hadoop.hbase.thrift.generated.IOError.Isset
 
message - Variable in exception org.apache.hadoop.hbase.thrift.generated.IOError
 
message - Variable in class org.apache.hadoop.hbase.thrift.generated.NotFound.Isset
 
message - Variable in exception org.apache.hadoop.hbase.thrift.generated.NotFound
 
META_ROW_DELIMITER - Static variable in interface org.apache.hadoop.hbase.HConstants
delimiter used between portions of a region name
META_TABLE_NAME - Static variable in interface org.apache.hadoop.hbase.HConstants
The META table's name.
META_TABLEDESC - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Table descriptor for .META. catalog table
MetaHandler - Class in org.apache.hadoop.hbase.rest
MetaHandler fields all requests for metadata at the instance level.
MetaHandler(HBaseConfiguration, HBaseAdmin) - Constructor for class org.apache.hadoop.hbase.rest.MetaHandler
 
MetaRegion - Class in org.apache.hadoop.hbase.master
Describes a meta region and its server
MetaUtils - Class in org.apache.hadoop.hbase.util
Contains utility methods for manipulating HBase meta tables.
MetaUtils() - Constructor for class org.apache.hadoop.hbase.util.MetaUtils
Default constructor
MetaUtils(HBaseConfiguration) - Constructor for class org.apache.hadoop.hbase.util.MetaUtils
 
MetaUtils.ScannerListener - Interface in org.apache.hadoop.hbase.util
Used by scanRootRegion and scanMetaRegion to call back the caller so it can process the data for a row.
metricsList - Variable in class org.apache.hadoop.hbase.ipc.HBaseRpcMetrics
 
MetricsRate - Class in org.apache.hadoop.hbase.metrics
Publishes a rate based on a counter - you increment the counter each time an event occurs (eg: an RPC call) and this publishes a rate.
MetricsRate(String) - Constructor for class org.apache.hadoop.hbase.metrics.MetricsRate
 
midKey() - Method in class org.apache.hadoop.hbase.io.HalfMapFileReader
 
midKey() - Method in class org.apache.hadoop.hbase.io.MapFile.Reader
Get the key at approximately the middle of the file.
Migrate - Class in org.apache.hadoop.hbase.util
Perform a migration.
Migrate() - Constructor for class org.apache.hadoop.hbase.util.Migrate
default constructor
Migrate(HBaseConfiguration) - Constructor for class org.apache.hadoop.hbase.util.Migrate
 
MODIFY_CLOSE_REGION - Static variable in interface org.apache.hadoop.hbase.HConstants
 
MODIFY_TABLE_COMPACT - Static variable in interface org.apache.hadoop.hbase.HConstants
modifyTable op for forcing a compaction
MODIFY_TABLE_FLUSH - Static variable in interface org.apache.hadoop.hbase.HConstants
 
MODIFY_TABLE_MAJOR_COMPACT - Static variable in interface org.apache.hadoop.hbase.HConstants
 
MODIFY_TABLE_SET_HTD - Static variable in interface org.apache.hadoop.hbase.HConstants
modifyTable op for replacing the table descriptor
MODIFY_TABLE_SPLIT - Static variable in interface org.apache.hadoop.hbase.HConstants
modifyTable op for forcing a split
modifyColumn(String, String, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Modify an existing column family on a table
modifyColumn(byte[], byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Modify an existing column family on a table
modifyColumn(byte[], byte[], HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.ipc.HMasterInterface
Modifies an existing column on the specified table
modifyColumn(byte[], byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.HMaster
 
modifyTable(byte[], HTableDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Modify an existing table, more IRB friendly version.
modifyTable(byte[], int, Object...) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Modify an existing table
modifyTable(byte[], int, Writable[]) - Method in interface org.apache.hadoop.hbase.ipc.HMasterInterface
Modify a table's metadata
modifyTable(byte[], int, Writable[]) - Method in class org.apache.hadoop.hbase.master.HMaster
 
MURMUR_HASH - Static variable in class org.apache.hadoop.hbase.util.Hash
Constant to denote MurmurHash.
MurmurHash - Class in org.apache.hadoop.hbase.util
This is a very fast, non-cryptographic hash suitable for general hash-based lookup.
MurmurHash() - Constructor for class org.apache.hadoop.hbase.util.MurmurHash
 
mutateRow(byte[], byte[], List<Mutation>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
mutateRow(byte[], byte[], List<Mutation>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Apply a series of mutations (updates/deletes) to a row in a single transaction.
mutateRow(byte[], byte[], List<Mutation>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
mutateRows(byte[], List<BatchMutation>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
mutateRows(byte[], List<BatchMutation>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Apply a series of batches (each a series of mutations on a single row) in a single transaction.
mutateRows(byte[], List<BatchMutation>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
mutateRowsTs(byte[], List<BatchMutation>, long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
mutateRowsTs(byte[], List<BatchMutation>, long) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Apply a series of batches (each a series of mutations on a single row) in a single transaction.
mutateRowsTs(byte[], List<BatchMutation>, long) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
mutateRowTs(byte[], byte[], List<Mutation>, long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
mutateRowTs(byte[], byte[], List<Mutation>, long) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Apply a series of mutations (updates/deletes) to a row in a single transaction.
mutateRowTs(byte[], byte[], List<Mutation>, long) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
Mutation - Class in org.apache.hadoop.hbase.thrift.generated
A Mutation object is used to either update or delete a column-value.
Mutation() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Mutation
 
Mutation(boolean, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Mutation
 
Mutation.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
Mutation.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Mutation.Isset
 
mutations - Variable in class org.apache.hadoop.hbase.thrift.generated.BatchMutation.Isset
 
mutations - Variable in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
mutations - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args.Isset
 
mutations - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
mutations - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args.Isset
 
mutations - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 

N

NAME - Static variable in interface org.apache.hadoop.hbase.HConstants
 
name - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor.Isset
 
name - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
name - Variable in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo.Isset
 
name - Variable in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
next() - Method in class org.apache.hadoop.hbase.client.HTable.ClientScanner
 
next(int) - Method in class org.apache.hadoop.hbase.client.HTable.ClientScanner
 
next() - Method in interface org.apache.hadoop.hbase.client.Scanner
Grab the next row's worth of values.
next(int) - Method in interface org.apache.hadoop.hbase.client.Scanner
 
next(WritableComparable, Writable) - Method in class org.apache.hadoop.hbase.io.HalfMapFileReader
 
next(WritableComparable, Writable) - Method in class org.apache.hadoop.hbase.io.MapFile.Reader
Read the next key/value pair in the map into key and val.
next(Writable) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Reader
Read the next key in the file into key, skipping its value.
next(Writable, Writable) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Reader
Read the next key/value pair in the file into key and val.
next(DataOutputBuffer) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Reader
Deprecated. Call SequenceFile.Reader.nextRaw(DataOutputBuffer,SequenceFile.ValueBytes).
next(Object) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Reader
Read the next key in the file, skipping its value.
next() - Method in interface org.apache.hadoop.hbase.io.SequenceFile.Sorter.RawKeyValueIterator
Sets up the current key and value (for getKey and getValue)
next(long) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
Get the next set of values
next(long, int) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
Get the next set of values
next(ImmutableBytesWritable, RowResult) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase.TableRecordReader
 
next(HStoreKey, SortedMap<byte[], Cell>) - Method in class org.apache.hadoop.hbase.regionserver.HAbstractScanner
 
next(long) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
next(long, int) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
next(HStoreKey, SortedMap<byte[], Cell>) - Method in interface org.apache.hadoop.hbase.regionserver.InternalScanner
Grab the next row's worth of values.
nextRaw(DataOutputBuffer, SequenceFile.ValueBytes) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Reader
Read 'raw' records.
nextRawKey(DataOutputBuffer) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Reader
Read 'raw' keys.
nextRawKey() - Method in class org.apache.hadoop.hbase.io.SequenceFile.Sorter.SegmentDescriptor
Fills up the rawKey object with the key returned by the Reader
nextRawValue(SequenceFile.ValueBytes) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Reader
Read 'raw' values.
nextRawValue(SequenceFile.ValueBytes) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Sorter.SegmentDescriptor
Fills up the passed rawValue with the value corresponding to the key read earlier
nextScannerId - Variable in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
nf - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result.Isset
 
nf - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
 
nf - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result.Isset
 
nf - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
nf - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result.Isset
 
nf - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
nf - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result.Isset
 
nf - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
nf - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result.Isset
 
nf - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
nf - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result.Isset
 
nf - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
nf - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result.Isset
 
nf - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
nf - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result.Isset
 
nf - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
nf - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result.Isset
 
nf - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
NINES - Static variable in interface org.apache.hadoop.hbase.HConstants
 
NO_HASH - Static variable in class org.apache.hadoop.hbase.HRegionInfo
 
NO_OPTIONS - Static variable in class org.apache.hadoop.hbase.util.Base64
No options specified.
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
 
NotAllMetaRegionsOnlineException - Exception in org.apache.hadoop.hbase.master
Thrown when an operation requires the root and all meta regions to be online
NotAllMetaRegionsOnlineException() - Constructor for exception org.apache.hadoop.hbase.master.NotAllMetaRegionsOnlineException
default constructor
NotAllMetaRegionsOnlineException(String) - Constructor for exception org.apache.hadoop.hbase.master.NotAllMetaRegionsOnlineException
 
NotFound - Exception in org.apache.hadoop.hbase.thrift.generated
A NotFound exception is used to indicate that no value was found for a query, or that a scanner has reached it's end.
NotFound() - Constructor for exception org.apache.hadoop.hbase.thrift.generated.NotFound
 
NotFound(String) - Constructor for exception org.apache.hadoop.hbase.thrift.generated.NotFound
 
NotFound.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
NotFound.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.NotFound.Isset
 
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
numRegionsToReport - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
numVersions - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args.Isset
 
numVersions - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
numVersions - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args.Isset
 
numVersions - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 

O

offline() - Method in class org.apache.hadoop.hbase.RegionHistorian
Offlines the historian.
offlineRegionInMETA(HRegionInterface, byte[], HRegionInfo) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Utility method used by HMaster marking regions offlined.
OFFSET - Static variable in class org.apache.hadoop.hbase.rest.GenericHandler
 
online(HBaseConfiguration) - Method in class org.apache.hadoop.hbase.RegionHistorian
 
onlineRegions - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
open(FileSystem, String, WritableComparator, Configuration) - Method in class org.apache.hadoop.hbase.io.MapFile.Reader
 
openFile(FileSystem, Path, int, long) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Reader
Override this method to specialize the type of FSDataInputStream returned.
openHRegion(HRegionInfo, Path, HLog, HBaseConfiguration) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Convenience method to open a HRegion outside of an HRegionServer context.
openScanner() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
openScanner(byte[], byte[][], byte[], long, RowFilterInterface) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
Opens a remote scanner with a RowFilter.
openScanner(long, byte[], byte[][], byte[], long, RowFilterInterface) - Method in interface org.apache.hadoop.hbase.ipc.TransactionalRegionInterface
Opens a remote scanner with a RowFilter.
openScanner(byte[], byte[][], byte[], long, RowFilterInterface) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
openScanner(long, byte[], byte[][], byte[], long, RowFilterInterface) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegionServer
 
oprot_ - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
ORDERED - Static variable in class org.apache.hadoop.hbase.util.Base64
Encode using the special "ordered" dialect of Base64 described here: http://www.faqs.org/qa/rfcc-1940.html.
org.apache.hadoop.hbase - package org.apache.hadoop.hbase
 
org.apache.hadoop.hbase.client - package org.apache.hadoop.hbase.client
 
org.apache.hadoop.hbase.client.tableindexed - package org.apache.hadoop.hbase.client.tableindexed
This package provides support for secondary indexing by maintaining a separate, "index", table for each index.
org.apache.hadoop.hbase.client.transactional - package org.apache.hadoop.hbase.client.transactional
This package provides support for atomic transactions.
org.apache.hadoop.hbase.filter - package org.apache.hadoop.hbase.filter
Provides row-level filters applied to HRegion scan results during calls to Scanner.next().
org.apache.hadoop.hbase.io - package org.apache.hadoop.hbase.io
 
org.apache.hadoop.hbase.ipc - package org.apache.hadoop.hbase.ipc
Tools to help define network clients and servers.
org.apache.hadoop.hbase.mapred - package org.apache.hadoop.hbase.mapred
Provides HBase MapReduce Input/OutputFormats, a table indexing MapReduce job, and utility
org.apache.hadoop.hbase.master - package org.apache.hadoop.hbase.master
 
org.apache.hadoop.hbase.master.metrics - package org.apache.hadoop.hbase.master.metrics
 
org.apache.hadoop.hbase.metrics - package org.apache.hadoop.hbase.metrics
 
org.apache.hadoop.hbase.metrics.file - package org.apache.hadoop.hbase.metrics.file
 
org.apache.hadoop.hbase.regionserver - package org.apache.hadoop.hbase.regionserver
 
org.apache.hadoop.hbase.regionserver.metrics - package org.apache.hadoop.hbase.regionserver.metrics
 
org.apache.hadoop.hbase.regionserver.tableindexed - package org.apache.hadoop.hbase.regionserver.tableindexed
 
org.apache.hadoop.hbase.regionserver.transactional - package org.apache.hadoop.hbase.regionserver.transactional
 
org.apache.hadoop.hbase.rest - package org.apache.hadoop.hbase.rest
Provides an HBase REST service.
org.apache.hadoop.hbase.thrift - package org.apache.hadoop.hbase.thrift
Provides an HBase Thrift service.
org.apache.hadoop.hbase.thrift.generated - package org.apache.hadoop.hbase.thrift.generated
 
org.apache.hadoop.hbase.util - package org.apache.hadoop.hbase.util
 
OUTPUT_TABLE - Static variable in class org.apache.hadoop.hbase.mapred.TableOutputFormat
JobConf parameter that specifies the output table
outputCellXml(XMLOutputter, Cell) - Method in class org.apache.hadoop.hbase.rest.GenericHandler
 
outputColumnsWithMultiVersionsXml(XMLOutputter, Map<byte[], Cell[]>) - Method in class org.apache.hadoop.hbase.rest.GenericHandler
 
outputColumnsWithMultiVersionsXml(HttpServletRequest, XMLOutputter, Map<byte[], Cell[]>) - Method in class org.apache.hadoop.hbase.rest.GenericHandler
 
outputColumnsXml(XMLOutputter, Map<byte[], Cell>) - Method in class org.apache.hadoop.hbase.rest.GenericHandler
 
outputColumnsXml(HttpServletRequest, XMLOutputter, Map<byte[], Cell>) - Method in class org.apache.hadoop.hbase.rest.GenericHandler
 

P

PageRowFilter - Class in org.apache.hadoop.hbase.filter
Implementation of RowFilterInterface that limits results to a specific page size.
PageRowFilter() - Constructor for class org.apache.hadoop.hbase.filter.PageRowFilter
Default constructor, filters nothing.
PageRowFilter(long) - Constructor for class org.apache.hadoop.hbase.filter.PageRowFilter
Constructor that takes a maximum page size.
Pair<T1,T2> - Class in org.apache.hadoop.hbase.util
A generic class for pairs.
Pair() - Constructor for class org.apache.hadoop.hbase.util.Pair
Default constructor.
Pair(T1, T2) - Constructor for class org.apache.hadoop.hbase.util.Pair
Constructor
parseColumn(byte[]) - Static method in class org.apache.hadoop.hbase.HStoreKey
 
parseHashType(String) - Static method in class org.apache.hadoop.hbase.util.Hash
This utility method converts String representation of hash function name to a symbolic constant.
parseRegionName(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Separate elements of a regionName.
prefix - Variable in class org.apache.hadoop.hbase.filter.PrefixRowFilter
 
PrefixRowFilter - Class in org.apache.hadoop.hbase.filter
RowFilterInterface that filters everything that does not match a prefix
PrefixRowFilter(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.PrefixRowFilter
Constructor that takes a row prefix to filter on
PrefixRowFilter() - Constructor for class org.apache.hadoop.hbase.filter.PrefixRowFilter
Default Constructor, filters nothing.
preserveInput(boolean) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Sorter.SegmentDescriptor
Whether to delete the files when no longer needed
process(TProtocol, TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor
 
process(int, TProtocol, TProtocol) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.ProcessFunction
 
processAlways() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
 
processAlways() - Method in class org.apache.hadoop.hbase.filter.PageRowFilter
 
processAlways() - Method in class org.apache.hadoop.hbase.filter.PrefixRowFilter
 
processAlways() - Method in class org.apache.hadoop.hbase.filter.RegExpRowFilter
 
processAlways() - Method in interface org.apache.hadoop.hbase.filter.RowFilterInterface
Returns whether or not the filter should always be processed in any filtering call.
processAlways() - Method in class org.apache.hadoop.hbase.filter.RowFilterSet
 
processAlways() - Method in class org.apache.hadoop.hbase.filter.StopRowFilter
 
processAlways() - Method in class org.apache.hadoop.hbase.filter.WhileMatchRowFilter
 
processBatchOfRows(ArrayList<BatchUpdate>, byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Process a batch of rows.
processMap_ - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor
 
processRow(HRegionInfo) - Method in interface org.apache.hadoop.hbase.util.MetaUtils.ScannerListener
Callback so client of scanner can process row contents
pushMetric(MetricsRecord) - Method in class org.apache.hadoop.hbase.metrics.MetricsRate
 
put(String, byte[]) - Method in class org.apache.hadoop.hbase.io.BatchUpdate
Change a value for the specified column
put(byte[], byte[]) - Method in class org.apache.hadoop.hbase.io.BatchUpdate
Change a value for the specified column
put(byte[], V) - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
put(byte[], Cell) - Method in class org.apache.hadoop.hbase.io.RowResult
 
put(K, V) - Method in class org.apache.hadoop.hbase.util.SoftValueMap
 
put(K, V) - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
putAll(Map<? extends byte[], ? extends V>) - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
putAll(Map) - Method in class org.apache.hadoop.hbase.io.RowResult
 
putAll(Map) - Method in class org.apache.hadoop.hbase.util.SoftValueMap
 
putAll(Map) - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 

Q

quiesced - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 

R

read() - Method in class org.apache.hadoop.hbase.io.BlockFSInputStream
 
read(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.BlockFSInputStream
 
read(TProtocol) - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
read(TProtocol) - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
 
read(TProtocol) - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
read(TProtocol) - Method in exception org.apache.hadoop.hbase.thrift.generated.NotFound
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
read() - Method in class org.apache.hadoop.hbase.util.Base64.Base64InputStream
Reads enough of the input stream to convert to/from Base64 and returns the next byte.
read(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.Base64.Base64InputStream
Calls Base64.Base64InputStream.read() repeatedly until the end of stream is reached or len bytes are read.
readByteArray(DataInput) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.client.tableindexed.IndexSpecification
readFields(DataInput) - Method in class org.apache.hadoop.hbase.client.tableindexed.ReverseByteArrayComparator
readFields(DataInput) - Method in class org.apache.hadoop.hbase.client.tableindexed.SimpleIndexKeyGenerator
readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.PageRowFilter
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.PrefixRowFilter
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.RegExpRowFilter
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.RowFilterSet
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.StopRowFilter
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.SubstringComparator
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.WhileMatchRowFilter
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.HMsg
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.HRegionInfo
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.HServerAddress
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.HServerInfo
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.HServerLoad
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.HStoreKey.BeforeThisStoreKey
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.HStoreKey
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.io.BatchOperation
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.io.BatchUpdate
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.io.Cell
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.io.HbaseObjectWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.io.Reference
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.io.RowResult
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Metadata
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.regionserver.HLogEdit
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.regionserver.HLogKey
 
readObject(DataInput, Configuration) - Static method in class org.apache.hadoop.hbase.io.HbaseObjectWritable
Read a Writable, String, primitive type, or an array of the preceding.
readObject(DataInput, HbaseObjectWritable, Configuration) - Static method in class org.apache.hadoop.hbase.io.HbaseObjectWritable
Read a Writable, String, primitive type, or an array of the preceding.
READONLY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
READONLY_KEY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
recv_atomicIncrement() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_createTable() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_deleteAll() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_deleteAllRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_deleteAllRowTs() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_deleteAllTs() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_deleteTable() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_disableTable() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_enableTable() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_get() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_getColumnDescriptors() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_getRowTs() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_getRowWithColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_getRowWithColumnsTs() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_getTableNames() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_getTableRegions() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_getVer() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_getVerTs() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_isTableEnabled() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_mutateRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_mutateRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_mutateRowsTs() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_mutateRowTs() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_scannerClose() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_scannerGet() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_scannerOpen() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_scannerOpenTs() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_scannerOpenWithStop() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_scannerOpenWithStopTs() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
reduce(ImmutableBytesWritable, Iterator<BatchUpdate>, OutputCollector<ImmutableBytesWritable, BatchUpdate>, Reporter) - Method in class org.apache.hadoop.hbase.mapred.IdentityTableReduce
No aggregation, output pairs of (key, record)
reduce(ImmutableBytesWritable, Iterator<RowResult>, OutputCollector<ImmutableBytesWritable, LuceneDocumentWrapper>, Reporter) - Method in class org.apache.hadoop.hbase.mapred.IndexTableReduce
 
Reference - Class in org.apache.hadoop.hbase.io
A reference to a part of a store file.
Reference(int, long, HStoreKey, Reference.Range) - Constructor for class org.apache.hadoop.hbase.io.Reference
 
Reference() - Constructor for class org.apache.hadoop.hbase.io.Reference
 
Reference.Range - Enum in org.apache.hadoop.hbase.io
For split HStoreFiles, it specifies if the file covers the lower half or the upper half of the key range
RegExpRowFilter - Class in org.apache.hadoop.hbase.filter
Implementation of RowFilterInterface that can filter by rowkey regular expression and/or individual column values (equals comparison only).
RegExpRowFilter() - Constructor for class org.apache.hadoop.hbase.filter.RegExpRowFilter
Default constructor, filters nothing.
RegExpRowFilter(String) - Constructor for class org.apache.hadoop.hbase.filter.RegExpRowFilter
Constructor that takes a row key regular expression to filter on.
RegExpRowFilter(String, Map<byte[], Cell>) - Constructor for class org.apache.hadoop.hbase.filter.RegExpRowFilter
Deprecated. Column filtering has been replaced by ColumnValueFilter Constructor that takes a row key regular expression to filter on.
RegexStringComparator - Class in org.apache.hadoop.hbase.filter
This comparator is for use with ColumnValueFilter, for filtering based on the value of a given column.
RegexStringComparator() - Constructor for class org.apache.hadoop.hbase.filter.RegexStringComparator
Nullary constructor for Writable
RegexStringComparator(String) - Constructor for class org.apache.hadoop.hbase.filter.RegexStringComparator
Constructor
REGION_SERVER_CLASS - Static variable in interface org.apache.hadoop.hbase.HConstants
Parameter name for what region server interface to use.
REGION_SERVER_IMPL - Static variable in interface org.apache.hadoop.hbase.HConstants
Parameter name for what region server implementation to use.
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
RegionHistorian - Class in org.apache.hadoop.hbase
The Region Historian task is to keep track of every modification a region has to go through.
RegionHistorian.RegionHistoryInformation - Class in org.apache.hadoop.hbase
Inner class that only contains information about an event.
RegionHistorian.RegionHistoryInformation(long, String, String) - Constructor for class org.apache.hadoop.hbase.RegionHistorian.RegionHistoryInformation
 
RegionOfflineException - Exception in org.apache.hadoop.hbase.client
Thrown when a table can not be located
RegionOfflineException() - Constructor for exception org.apache.hadoop.hbase.client.RegionOfflineException
default constructor
RegionOfflineException(String) - Constructor for exception org.apache.hadoop.hbase.client.RegionOfflineException
 
regions - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
Count of regions carried by this regionserver
REGIONS - Static variable in class org.apache.hadoop.hbase.rest.GenericHandler
 
REGIONSERVER - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
region server process name
REGIONSERVER_ADDRESS - Static variable in interface org.apache.hadoop.hbase.HConstants
Parameter name for hbase.regionserver address.
RegionServerMetrics - Class in org.apache.hadoop.hbase.regionserver.metrics
This class is for maintaining the various regionserver statistics and publishing them through the metrics interfaces.
RegionServerMetrics() - Constructor for class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
 
regionServerReport(HServerInfo, HMsg[], HRegionInfo[]) - Method in interface org.apache.hadoop.hbase.ipc.HMasterRegionInterface
Called to renew lease, tell master what the region server is doing and to receive new instructions from the master
regionServerReport(HServerInfo, HMsg[], HRegionInfo[]) - Method in class org.apache.hadoop.hbase.master.HMaster
 
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
regionServerStartup(HServerInfo) - Method in interface org.apache.hadoop.hbase.ipc.HMasterRegionInterface
Called when a region server first starts
regionServerStartup(HServerInfo) - Method in class org.apache.hadoop.hbase.master.HMaster
 
relocateRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Find the location of the region of tableName that row lives in, ignoring any value that might be in the cache.
RemoteExceptionHandler - Class in org.apache.hadoop.hbase
An immutable class which contains a static method for handling org.apache.hadoop.ipc.RemoteException exceptions.
remove(Object) - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
remove(Object) - Method in class org.apache.hadoop.hbase.io.RowResult
 
remove(Object) - Method in class org.apache.hadoop.hbase.util.SoftValueMap
 
remove(Object) - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
removeFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
 
removeFamily(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
removeRegionFromMETA(HRegionInterface, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Delete a region's meta information from the passed meta region.
removeScanner(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
Removes the scanner associated with the specified ID from the internal id->scanner hash-map.
rename(FileSystem, String, String) - Static method in class org.apache.hadoop.hbase.io.MapFile
Renames an existing map directory.
rename(FileSystem, HStoreFile) - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
Renames the mapfiles and info directories under the passed hsf directory.
renewLease(String) - Method in class org.apache.hadoop.hbase.Leases
Renew a lease
request(HRegion) - Method in interface org.apache.hadoop.hbase.regionserver.FlushRequester
Tell the listener the cache needs to be flushed.
reset() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
 
reset() - Method in class org.apache.hadoop.hbase.filter.PageRowFilter
 
reset() - Method in class org.apache.hadoop.hbase.filter.PrefixRowFilter
 
reset() - Method in class org.apache.hadoop.hbase.filter.RegExpRowFilter
 
reset() - Method in interface org.apache.hadoop.hbase.filter.RowFilterInterface
Resets the state of the filter.
reset() - Method in class org.apache.hadoop.hbase.filter.RowFilterSet
 
reset() - Method in class org.apache.hadoop.hbase.filter.StopRowFilter
 
reset() - Method in class org.apache.hadoop.hbase.filter.WhileMatchRowFilter
 
reset() - Method in class org.apache.hadoop.hbase.io.BlockFSInputStream
 
reset() - Method in class org.apache.hadoop.hbase.io.DataOutputBuffer
Resets the buffer to empty.
reset() - Method in class org.apache.hadoop.hbase.io.HalfMapFileReader
 
reset() - Method in class org.apache.hadoop.hbase.io.MapFile.Reader
Re-positions the reader before its first key.
resetAllMinMax() - Method in class org.apache.hadoop.hbase.master.metrics.MasterMetrics
 
resetAllMinMax() - Method in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
 
restart(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase.TableRecordReader
Restart from survivable exceptions by creating a new scanner.
resumeEncoding() - Method in class org.apache.hadoop.hbase.util.Base64.Base64OutputStream
Resumes encoding of the stream.
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, byte[], byte[], int, List<Throwable>) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedException
Create a new RetriesExhaustedException from the list of prior failures.
RETRY_BACKOFF - Static variable in interface org.apache.hadoop.hbase.HConstants
This is a retry backoff multiplier table similar to the BSD TCP syn backoff table, a bit more aggressive than simple exponential backoff.
ReverseByteArrayComparator - Class in org.apache.hadoop.hbase.client.tableindexed
 
ReverseByteArrayComparator() - Constructor for class org.apache.hadoop.hbase.client.tableindexed.ReverseByteArrayComparator
 
rollWriter() - Method in class org.apache.hadoop.hbase.regionserver.HLog
Roll the log writer.
ROOT_REGIONINFO - Static variable in class org.apache.hadoop.hbase.HRegionInfo
HRegionInfo for root region
ROOT_TABLE_NAME - Static variable in interface org.apache.hadoop.hbase.HConstants
The root table's name.
ROOT_TABLEDESC - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Table descriptor for -ROOT- catalog table
row - Variable in class org.apache.hadoop.hbase.client.ServerCallable
 
ROW - Static variable in class org.apache.hadoop.hbase.rest.GenericHandler
 
row - Variable in class org.apache.hadoop.hbase.thrift.generated.BatchMutation.Isset
 
row - Variable in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args.Isset
 
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args.Isset
 
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args.Isset
 
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args.Isset
 
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args.Isset
 
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args.Isset
 
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args.Isset
 
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args.Isset
 
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args.Isset
 
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args.Isset
 
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args.Isset
 
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args.Isset
 
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args.Isset
 
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args.Isset
 
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
row - Variable in class org.apache.hadoop.hbase.thrift.generated.TRowResult.Isset
 
row - Variable in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
rowBatches - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args.Isset
 
rowBatches - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
rowBatches - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args.Isset
 
rowBatches - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
RowCounter - Class in org.apache.hadoop.hbase.mapred
A job with a map to count rows.
RowCounter() - Constructor for class org.apache.hadoop.hbase.mapred.RowCounter
 
RowFilterInterface - Interface in org.apache.hadoop.hbase.filter
Interface used for row-level filters applied to HRegion.HScanner scan results during calls to next().
RowFilterSet - Class in org.apache.hadoop.hbase.filter
Implementation of RowFilterInterface that represents a set of RowFilters which will be evaluated with a specified boolean operator MUST_PASS_ALL (!AND) or MUST_PASS_ONE (!OR).
RowFilterSet() - Constructor for class org.apache.hadoop.hbase.filter.RowFilterSet
Default constructor, filters nothing.
RowFilterSet(Set<RowFilterInterface>) - Constructor for class org.apache.hadoop.hbase.filter.RowFilterSet
Constructor that takes a set of RowFilters.
RowFilterSet(RowFilterSet.Operator, Set<RowFilterInterface>) - Constructor for class org.apache.hadoop.hbase.filter.RowFilterSet
Constructor that takes a set of RowFilters and an operator.
RowFilterSet.Operator - Enum in org.apache.hadoop.hbase.filter
set operator
RowHandler - Class in org.apache.hadoop.hbase.rest
 
RowHandler(HBaseConfiguration, HBaseAdmin) - Constructor for class org.apache.hadoop.hbase.rest.RowHandler
 
rowIsInRange(HRegionInfo, byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Determines if the specified row is within the row range specified by the specified HRegionInfo
RowLock - Class in org.apache.hadoop.hbase.client
Holds row name and lock id.
RowLock(byte[], long) - Constructor for class org.apache.hadoop.hbase.client.RowLock
Creates a RowLock from a row and lock id
RowLock(long) - Constructor for class org.apache.hadoop.hbase.client.RowLock
Creates a RowLock with only a lock id
rowProcessed(boolean, byte[]) - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
 
rowProcessed(boolean, byte[]) - Method in class org.apache.hadoop.hbase.filter.PageRowFilter
 
rowProcessed(boolean, byte[]) - Method in class org.apache.hadoop.hbase.filter.PrefixRowFilter
 
rowProcessed(boolean, byte[]) - Method in class org.apache.hadoop.hbase.filter.RegExpRowFilter
 
rowProcessed(boolean, byte[]) - Method in interface org.apache.hadoop.hbase.filter.RowFilterInterface
Called to let filter know the final decision (to pass or filter) on a given row.
rowProcessed(boolean, byte[]) - Method in class org.apache.hadoop.hbase.filter.RowFilterSet
 
rowProcessed(boolean, byte[]) - Method in class org.apache.hadoop.hbase.filter.StopRowFilter
 
rowProcessed(boolean, byte[]) - Method in class org.apache.hadoop.hbase.filter.WhileMatchRowFilter
 
RowResult - Class in org.apache.hadoop.hbase.io
Holds row name and then a map of columns to cells.
RowResult() - Constructor for class org.apache.hadoop.hbase.io.RowResult
default constructor for writable
RowResult(byte[], HbaseMapWritable<byte[], Cell>) - Constructor for class org.apache.hadoop.hbase.io.RowResult
Create a RowResult from a row and Cell map
RowResult.Entry - Class in org.apache.hadoop.hbase.io
Row entry.
rowResultFromHBase(RowResult) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
This utility method creates a new Thrift TRowResult "struct" based on an Hbase RowResult object.
rpcMetrics - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
rpcProcessingTime - Variable in class org.apache.hadoop.hbase.ipc.HBaseRpcMetrics
 
rpcQueueTime - Variable in class org.apache.hadoop.hbase.ipc.HBaseRpcMetrics
The metrics variables are public: - they can be set directly by calling their set/inc methods -they can also be read directly - e.g.
run() - Method in class org.apache.hadoop.hbase.Chore
 
run() - Method in class org.apache.hadoop.hbase.Leases
 
run(String[]) - Method in class org.apache.hadoop.hbase.mapred.BuildTableIndex
 
run(String[]) - Method in class org.apache.hadoop.hbase.mapred.RowCounter
 
run() - Method in class org.apache.hadoop.hbase.master.HMaster
Main processing loop
run() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
The HRegionServer sticks in this loop until closed.
run(String[]) - Method in class org.apache.hadoop.hbase.util.Merge
 
run(String[]) - Method in class org.apache.hadoop.hbase.util.Migrate
 
runThread(Thread, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Run and wait on passed thread in HRS context.

S

safeMode - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
scanMetaRegion(HRegionInfo, MetaUtils.ScannerListener) - Method in class org.apache.hadoop.hbase.util.MetaUtils
Scans a meta region.
scanMetaRegion(HRegion, MetaUtils.ScannerListener) - Method in class org.apache.hadoop.hbase.util.MetaUtils
Scan the passed in metaregion m invoking the passed listener per row found.
Scanner - Interface in org.apache.hadoop.hbase.client
Interface for client-side scanning.
scannerCaching - Variable in class org.apache.hadoop.hbase.client.HTable
 
ScannerCallable - Class in org.apache.hadoop.hbase.client
Retries scanner operations such as create, next, etc.
ScannerCallable(HConnection, byte[], byte[][], byte[], long, RowFilterInterface) - Constructor for class org.apache.hadoop.hbase.client.ScannerCallable
 
scannerClose(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
scannerClose(int) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Closes the server-state associated with an open scanner.
scannerClose(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
scannerClosed - Variable in class org.apache.hadoop.hbase.regionserver.HAbstractScanner
 
scannerGet(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
scannerGet(int) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Returns the scanner's current row value and advances to the next row in the table.
scannerGet(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
ScannerHandler - Class in org.apache.hadoop.hbase.rest
ScannderHandler fields all scanner related requests.
ScannerHandler(HBaseConfiguration, HBaseAdmin) - Constructor for class org.apache.hadoop.hbase.rest.ScannerHandler
 
scannerMap - Variable in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
scannerOpen(byte[], byte[], List<byte[]>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
scannerOpen(byte[], byte[], List<byte[]>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Get a scanner on the current table starting at the specified row and ending at the last row in the table.
scannerOpen(byte[], byte[], List<byte[]>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
scannerOpenTs(byte[], byte[], List<byte[]>, long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
scannerOpenTs(byte[], byte[], List<byte[]>, long) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Get a scanner on the current table starting at the specified row and ending at the last row in the table.
scannerOpenTs(byte[], byte[], List<byte[]>, long) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
scannerOpenWithStop(byte[], byte[], byte[], List<byte[]>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
scannerOpenWithStop(byte[], byte[], byte[], List<byte[]>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Get a scanner on the current table starting and stopping at the specified rows.
scannerOpenWithStop(byte[], byte[], byte[], List<byte[]>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
scannerOpenWithStopTs(byte[], byte[], byte[], List<byte[]>, long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
scannerOpenWithStopTs(byte[], byte[], byte[], List<byte[]>, long) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Get a scanner on the current table starting and stopping at the specified rows.
scannerOpenWithStopTs(byte[], byte[], byte[], List<byte[]>, long) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
scannerTimeout - Variable in class org.apache.hadoop.hbase.client.HTable
 
ScannerTimeoutException - Exception in org.apache.hadoop.hbase.client
Thrown when a scanner has timed out.
scanRootRegion(MetaUtils.ScannerListener) - Method in class org.apache.hadoop.hbase.util.MetaUtils
Scans the root region.
scanTime - Variable in class org.apache.hadoop.hbase.client.HTable.ClientScanner
 
second - Variable in class org.apache.hadoop.hbase.util.Pair
 
seek(long) - Method in class org.apache.hadoop.hbase.io.BlockFSInputStream
 
seek(WritableComparable) - Method in class org.apache.hadoop.hbase.io.HalfMapFileReader
 
seek(WritableComparable) - Method in class org.apache.hadoop.hbase.io.MapFile.Reader
Positions the reader at the named key, or if none such exists, at the first entry after the named key.
seek(long) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Reader
Set the current byte position in the input file.
seekToNewSource(long) - Method in class org.apache.hadoop.hbase.io.BlockFSInputStream
 
send_atomicIncrement(byte[], byte[], byte[], long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_createTable(byte[], List<ColumnDescriptor>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_deleteAll(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_deleteAllRow(byte[], byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_deleteAllRowTs(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_deleteAllTs(byte[], byte[], byte[], long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_deleteTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_disableTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_enableTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_get(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_getColumnDescriptors(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_getRow(byte[], byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_getRowTs(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_getRowWithColumns(byte[], byte[], List<byte[]>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_getRowWithColumnsTs(byte[], byte[], List<byte[]>, long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_getTableNames() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_getTableRegions(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_getVer(byte[], byte[], byte[], int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_getVerTs(byte[], byte[], byte[], long, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_isTableEnabled(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_mutateRow(byte[], byte[], List<Mutation>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_mutateRows(byte[], List<BatchMutation>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_mutateRowsTs(byte[], List<BatchMutation>, long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_mutateRowTs(byte[], byte[], List<Mutation>, long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_scannerClose(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_scannerGet(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_scannerOpen(byte[], byte[], List<byte[]>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_scannerOpenTs(byte[], byte[], List<byte[]>, long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_scannerOpenWithStop(byte[], byte[], byte[], List<byte[]>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_scannerOpenWithStopTs(byte[], byte[], byte[], List<byte[]>, long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
seqid_ - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
SequenceFile - Class in org.apache.hadoop.hbase.io
SequenceFiles are flat files consisting of binary key/value pairs.
SequenceFile.CompressionType - Enum in org.apache.hadoop.hbase.io
The compression type used to compress key/value pairs in the SequenceFile.
SequenceFile.Metadata - Class in org.apache.hadoop.hbase.io
The class encapsulating with the metadata of a file.
SequenceFile.Metadata() - Constructor for class org.apache.hadoop.hbase.io.SequenceFile.Metadata
 
SequenceFile.Metadata(TreeMap<Text, Text>) - Constructor for class org.apache.hadoop.hbase.io.SequenceFile.Metadata
 
SequenceFile.Reader - Class in org.apache.hadoop.hbase.io
Reads key/value pairs from a sequence-format file.
SequenceFile.Reader(FileSystem, Path, Configuration) - Constructor for class org.apache.hadoop.hbase.io.SequenceFile.Reader
Open the named file.
SequenceFile.Sorter - Class in org.apache.hadoop.hbase.io
Sorts key/value pairs in a sequence-format file.
SequenceFile.Sorter(FileSystem, Class<? extends WritableComparable>, Class, Configuration) - Constructor for class org.apache.hadoop.hbase.io.SequenceFile.Sorter
Sort and merge files containing the named classes.
SequenceFile.Sorter(FileSystem, RawComparator, Class, Class, Configuration) - Constructor for class org.apache.hadoop.hbase.io.SequenceFile.Sorter
Sort and merge using an arbitrary RawComparator.
SequenceFile.Sorter.RawKeyValueIterator - Interface in org.apache.hadoop.hbase.io
The interface to iterate over raw keys/values of SequenceFiles.
SequenceFile.Sorter.SegmentDescriptor - Class in org.apache.hadoop.hbase.io
This class defines a merge segment.
SequenceFile.Sorter.SegmentDescriptor(long, long, Path) - Constructor for class org.apache.hadoop.hbase.io.SequenceFile.Sorter.SegmentDescriptor
Constructs a segment
SequenceFile.ValueBytes - Interface in org.apache.hadoop.hbase.io
The interface to 'raw' values of SequenceFiles.
SequenceFile.Writer - Class in org.apache.hadoop.hbase.io
Write key/value pairs to a sequence-format file.
SequenceFile.Writer(FileSystem, Configuration, Path, Class, Class) - Constructor for class org.apache.hadoop.hbase.io.SequenceFile.Writer
Create the named file.
SequenceFile.Writer(FileSystem, Configuration, Path, Class, Class, Progressable, SequenceFile.Metadata) - Constructor for class org.apache.hadoop.hbase.io.SequenceFile.Writer
Create the named file with write-progress reporter.
SequenceFile.Writer(FileSystem, Configuration, Path, Class, Class, int, short, long, Progressable, SequenceFile.Metadata) - Constructor for class org.apache.hadoop.hbase.io.SequenceFile.Writer
Create the named file with write-progress reporter.
server - Variable in class org.apache.hadoop.hbase.client.ServerCallable
 
ServerCallable<T> - Class in org.apache.hadoop.hbase.client
Abstract class that implemetns Callable, used by retryable actions.
ServerCallable(HConnection, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.client.ServerCallable
 
ServerConnection - Interface in org.apache.hadoop.hbase.client
Used by master and region server, so that they do not need to wait for the cluster to be up to get a connection.
ServerConnectionManager - Class in org.apache.hadoop.hbase.client
Used by server processes to expose HServerConnection method setRootRegionLocation
serverInfo - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
set(HStoreKey) - Method in class org.apache.hadoop.hbase.HStoreKey.BeforeThisStoreKey
 
set(HStoreKey) - Method in class org.apache.hadoop.hbase.HStoreKey
Set the value of this HStoreKey from the supplied key
set(Object) - Method in class org.apache.hadoop.hbase.io.HbaseObjectWritable
Reset the instance.
set(byte[]) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
set(Text, Text) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Metadata
 
setAnalyzerName(String) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
 
setAutoFlush(boolean) - Method in class org.apache.hadoop.hbase.client.HTable
Set if this instanciation of HTable will autoFlush
setBlockCacheEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHColumnDescriptor
 
setBlockCacheEnabled(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setBloomfilter(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setBoost(String, float) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
 
setCaching(int) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
Set the number of rows that will be fetched on next
setClose() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
Call this when the next invocation of call should close the scanner
setColumn(byte[]) - Method in class org.apache.hadoop.hbase.HStoreKey.BeforeThisStoreKey
 
setColumn(byte[]) - Method in class org.apache.hadoop.hbase.HStoreKey
Change the value of the column in this key
setColumnFilter(byte[], byte[]) - Method in class org.apache.hadoop.hbase.filter.RegExpRowFilter
Deprecated. Column filtering has been replaced by ColumnValueFilter Specify a value that must be matched for the given column.
setColumnFilters(Map<byte[], Cell>) - Method in class org.apache.hadoop.hbase.filter.RegExpRowFilter
Deprecated. Column filtering has been replaced by ColumnValueFilter Set column filters for a number of columns.
setCompressionType(HColumnDescriptor.CompressionType) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHColumnDescriptor
 
setCompressionType(HColumnDescriptor.CompressionType) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setCompressionType(Configuration, SequenceFile.CompressionType) - Static method in class org.apache.hadoop.hbase.io.SequenceFile
Deprecated. Use the one of the many SequenceFile.createWriter methods to specify the SequenceFile.CompressionType while creating the SequenceFile or SequenceFileOutputFormat.setOutputCompressionType(org.apache.hadoop.mapred.JobConf, org.apache.hadoop.io.SequenceFile.CompressionType) to specify the SequenceFile.CompressionType for job-outputs. or
setConf(Configuration) - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.io.HbaseObjectWritable
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapred.RowCounter
 
setDaemonThreadRunning(Thread, String) - Static method in class org.apache.hadoop.hbase.util.Threads
Utility method that sets name, daemon status and starts passed thread.
setDaemonThreadRunning(Thread, String, Thread.UncaughtExceptionHandler) - Static method in class org.apache.hadoop.hbase.util.Threads
Utility method that sets name, daemon status and starts passed thread.
setDoOptimize(boolean) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
 
setEndRow(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase.TableRecordReader
 
setErrorHandler(HBaseRPCErrorHandler) - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
Set the handler for calling out of RPC for error conditions.
setFactor(int) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Sorter
Set the number of streams to merge at once.
setFirst(T1) - Method in class org.apache.hadoop.hbase.util.Pair
Replace the first element of the pair.
setHDFSShutdownThreadOnExit(Thread) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Set the hdfs shutdown thread to run on exit.
setHRegionInfo(HRegionInfo) - Method in class org.apache.hadoop.hbase.HStoreKey.BeforeThisStoreKey
 
setHRegionInfo(HRegionInfo) - Method in class org.apache.hadoop.hbase.HStoreKey
 
setHTable(HTable) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Allows subclasses to set the HTable.
setHTable(HTable) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase.TableRecordReader
 
setIndex(String, boolean) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
 
setIndexInterval(int) - Method in class org.apache.hadoop.hbase.io.MapFile.Writer
Sets the index interval.
setIndexInterval(Configuration, int) - Static method in class org.apache.hadoop.hbase.io.MapFile.Writer
Sets the index interval and stores it in conf
setInMemory(boolean) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHColumnDescriptor
 
setInMemory(boolean) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
 
setInMemory(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setInMemory(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
setInputColumns(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
 
setInputColumns(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase.TableRecordReader
 
setLoad(HServerLoad) - Method in class org.apache.hadoop.hbase.HServerInfo
 
setMapFileIndexInterval(int) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHColumnDescriptor
 
setMapFileIndexInterval(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setMaxBufferedDeleteTerms(int) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
 
setMaxBufferedDocs(int) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
 
setMaxFieldLength(int) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
 
setMaxFileSize(long) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
 
setMaxFileSize(long) - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
setMaxHeapMB(int) - Method in class org.apache.hadoop.hbase.HServerLoad
 
setMaxMergeDocs(int) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
 
setMaxValueLength(int) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHColumnDescriptor
 
setMaxValueLength(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setMaxVersions(int) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHColumnDescriptor
 
setMaxVersions(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setMemcacheFlushSize(int) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
 
setMemcacheFlushSize(int) - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
setMemcacheSizeMB(int) - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
 
setMemory(int) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Sorter
Set the total amount of buffer memory, in bytes.
setMergeFactor(int) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
 
setMetaRegion(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
setName(String) - Method in class org.apache.hadoop.hbase.HServerInfo
 
setName(byte[]) - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
 
setNumberOfRegions(int) - Method in class org.apache.hadoop.hbase.HServerLoad
 
setNumberOfRequests(int) - Method in class org.apache.hadoop.hbase.HServerLoad
 
setNumMapTasks(String, JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Sets the number of map tasks for the given job configuration to the number of regions the given table has.
setNumReduceTasks(String, JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Sets the number of reduce tasks for the given job configuration to the number of regions the given table has.
setOffline(boolean) - Method in class org.apache.hadoop.hbase.HRegionInfo
 
setOmitNorms(String, boolean) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
 
setPingInterval(Configuration, int) - Static method in class org.apache.hadoop.hbase.ipc.HBaseClient
set the ping interval value in configuration
setProgressable(Progressable) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Sorter
Set the progressable object in order to report progress.
setReadOnly(boolean) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
 
setReadOnly(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
setResponseHeader(HttpServletResponse, int, String) - Static method in class org.apache.hadoop.hbase.rest.GenericHandler
 
setRootRegion(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
setRootRegionLocation(HRegionLocation) - Method in interface org.apache.hadoop.hbase.client.ServerConnection
Set root region location in connection
setRow(byte[]) - Method in class org.apache.hadoop.hbase.HStoreKey.BeforeThisStoreKey
 
setRow(byte[]) - Method in class org.apache.hadoop.hbase.HStoreKey
Change the value of the row key
setRowFilter(RowFilterInterface) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Allows subclasses to set the RowFilterInterface to be used.
setRowFilter(RowFilterInterface) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase.TableRecordReader
 
setRowkeyName(String) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
 
setRowLock(long) - Method in class org.apache.hadoop.hbase.io.BatchUpdate
Set the lock to be used for this update
setScannerCaching(int) - Method in class org.apache.hadoop.hbase.client.HTable
Set the number of rows for caching that will be passed to scanners
setSecond(T2) - Method in class org.apache.hadoop.hbase.util.Pair
Replace the second element of the pair.
setServerAddress(HServerAddress) - Method in class org.apache.hadoop.hbase.HServerInfo
Change the server address.
setSimilarityName(String) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
 
setSocketSendBufSize(int) - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
Sets the socket buffer size used for responding to RPCs
setSplit(boolean) - Method in class org.apache.hadoop.hbase.HRegionInfo
 
setStartCode(long) - Method in class org.apache.hadoop.hbase.HServerInfo
 
setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase.TableRecordReader
 
setStatusForTransaction(long, TransactionLogger.TransactionStatus) - Method in class org.apache.hadoop.hbase.client.transactional.LocalTransactionLogger
 
setStatusForTransaction(long, TransactionLogger.TransactionStatus) - Method in interface org.apache.hadoop.hbase.client.transactional.TransactionLogger
 
setStore(String, boolean) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
 
setStorefileIndexSizeMB(int) - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
 
setStorefiles(int) - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
 
setStores(int) - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
 
setTableDesc(HTableDescriptor) - Method in class org.apache.hadoop.hbase.HRegionInfo
 
setTableRecordReader(TableInputFormatBase.TableRecordReader) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Allows subclasses to set the TableInputFormatBase.TableRecordReader.
setTimestamp(long) - Method in class org.apache.hadoop.hbase.io.BatchUpdate
Set this BatchUpdate's timestamp.
setTimeToLive(int) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHColumnDescriptor
 
setTimeToLive(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setTokenize(String, boolean) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
 
setUseCompoundFile(boolean) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
 
setUsedHeapMB(int) - Method in class org.apache.hadoop.hbase.HServerLoad
 
setValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHColumnDescriptor
 
setValue(String, String) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHColumnDescriptor
 
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
 
setValue(String, String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
setValue(Cell) - Method in class org.apache.hadoop.hbase.io.RowResult.Entry
 
setVersion(long) - Method in class org.apache.hadoop.hbase.HStoreKey.BeforeThisStoreKey
 
setVersion(long) - Method in class org.apache.hadoop.hbase.HStoreKey
Change the value of the timestamp field
setVersion(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Sets version of file system
setWriteBufferSize(long) - Method in class org.apache.hadoop.hbase.client.HTable
Set the size of the buffer in bytes
shouldPreserveInput() - Method in class org.apache.hadoop.hbase.io.SequenceFile.Sorter.SegmentDescriptor
 
shouldSplit(boolean) - Method in class org.apache.hadoop.hbase.HRegionInfo
For internal use in forcing splits ahead of file size limit.
shutdown() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Shuts down the HBase instance
shutdown() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcMetrics
 
shutdown() - Method in interface org.apache.hadoop.hbase.ipc.HMasterInterface
Shutdown an HBase cluster.
shutdown() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
Shut down the mini HBase cluster
shutdown() - Method in class org.apache.hadoop.hbase.master.HMaster
 
shutdown() - Method in class org.apache.hadoop.hbase.master.metrics.MasterMetrics
 
shutdown() - Method in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
 
shutdown() - Method in class org.apache.hadoop.hbase.util.MetaUtils
Closes catalog regions if open.
shutdown(Thread) - Static method in class org.apache.hadoop.hbase.util.Threads
Shutdown passed thread using isAlive and join.
shutdown(Thread, long) - Static method in class org.apache.hadoop.hbase.util.Threads
Shutdown passed thread using isAlive and join.
SimpleIndexKeyGenerator - Class in org.apache.hadoop.hbase.client.tableindexed
Creates indexed keys for a single column....
SimpleIndexKeyGenerator(byte[]) - Constructor for class org.apache.hadoop.hbase.client.tableindexed.SimpleIndexKeyGenerator
 
SimpleIndexKeyGenerator() - Constructor for class org.apache.hadoop.hbase.client.tableindexed.SimpleIndexKeyGenerator
 
size() - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
size() - Method in class org.apache.hadoop.hbase.io.RowResult
 
size() - Method in class org.apache.hadoop.hbase.util.SoftValueMap
 
size() - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
SIZEOF_DOUBLE - Static variable in class org.apache.hadoop.hbase.util.Bytes
Size of double in bytes
SIZEOF_FLOAT - Static variable in class org.apache.hadoop.hbase.util.Bytes
Size of float in bytes
SIZEOF_INT - Static variable in class org.apache.hadoop.hbase.util.Bytes
Size of int in bytes
SIZEOF_LONG - Static variable in class org.apache.hadoop.hbase.util.Bytes
Size of long in bytes
sleep() - Method in class org.apache.hadoop.hbase.Chore
Sleep for period.
sleep() - Method in class org.apache.hadoop.hbase.util.Sleeper
Sleep for period.
sleep(long) - Method in class org.apache.hadoop.hbase.util.Sleeper
Sleep for period adjusted by passed startTime
Sleeper - Class in org.apache.hadoop.hbase.util
Sleeper for current thread.
Sleeper(int, AtomicBoolean) - Constructor for class org.apache.hadoop.hbase.util.Sleeper
 
SoftValueMap<K,V> - Class in org.apache.hadoop.hbase.util
A Map that uses Soft Reference values internally.
SoftValueMap() - Constructor for class org.apache.hadoop.hbase.util.SoftValueMap
 
SoftValueMap(ReferenceQueue<?>) - Constructor for class org.apache.hadoop.hbase.util.SoftValueMap
 
SoftValueSortedMap<K,V> - Class in org.apache.hadoop.hbase.util
A SortedMap implementation that uses Soft Reference values internally to make it play well with the GC when in a low-memory situation.
SoftValueSortedMap() - Constructor for class org.apache.hadoop.hbase.util.SoftValueSortedMap
Constructor
SoftValueSortedMap(Comparator<K>) - Constructor for class org.apache.hadoop.hbase.util.SoftValueSortedMap
Constructor
sort(Path[], Path, boolean) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Sorter
Perform a file sort from a set of input files into an output file.
sort(Path, Path) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Sorter
The backwards compatible interface to sort.
sortAndIterate(Path[], Path, boolean) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Sorter
Perform a file sort from a set of input files and return an iterator.
split(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Split a table or an individual region
split(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Split a table or an individual region
SPLIT_PREFIX - Static variable in class org.apache.hadoop.hbase.RegionHistorian
 
splitLog(Path, Path, FileSystem, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.HLog
Split up a bunch of regionserver commit log files that are no longer being written to, into new files, one per region for region to replay on startup.
start() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
Starts the service.
START_ROW - Static variable in class org.apache.hadoop.hbase.rest.GenericHandler
 
startKey - Variable in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo.Isset
 
startKey - Variable in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
startMonitoring() - Method in class org.apache.hadoop.hbase.metrics.file.TimeStampingFileContext
 
startRow - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args.Isset
 
startRow - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
startRow - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args.Isset
 
startRow - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
startRow - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args.Isset
 
startRow - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
startRow - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args.Isset
 
startRow - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
startup() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
Start the cluster.
stop - Variable in class org.apache.hadoop.hbase.Chore
 
stop() - Method in class org.apache.hadoop.hbase.ipc.HBaseClient
Stop all threads related to this client.
stop() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
Stops the service.
stop() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Sets a flag that will cause all the HRegionServer threads to shut down in an orderly fashion.
stopMonitoring() - Method in class org.apache.hadoop.hbase.metrics.file.TimeStampingFileContext
 
stopProxy(VersionedProtocol) - Static method in class org.apache.hadoop.hbase.ipc.HBaseRPC
Stop this proxy and release its invoker's resource
stopRequested - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
stopRow - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args.Isset
 
stopRow - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
stopRow - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args.Isset
 
stopRow - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
StopRowFilter - Class in org.apache.hadoop.hbase.filter
Implementation of RowFilterInterface that filters out rows greater than or equal to a specified rowKey.
StopRowFilter() - Constructor for class org.apache.hadoop.hbase.filter.StopRowFilter
Default constructor, filters nothing.
StopRowFilter(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.StopRowFilter
Constructor that takes a stopRowKey on which to filter
storefileIndexSizeMB - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
Sum of all the storefile index sizes in this regionserver in MB
storefiles - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
Count of storefiles open on the regionserver.
stores - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
 
stores - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
Count of stores open on the regionserver.
Strings - Class in org.apache.hadoop.hbase.util
Utillity for Strings.
Strings() - Constructor for class org.apache.hadoop.hbase.util.Strings
 
subMap(byte[], byte[]) - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
subMap(byte[], byte[]) - Method in class org.apache.hadoop.hbase.io.RowResult
 
subMap(K, K) - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
SubstringComparator - Class in org.apache.hadoop.hbase.filter
This comparator is for use with ColumnValueFilter, for filtering based on the value of a given column.
SubstringComparator() - Constructor for class org.apache.hadoop.hbase.filter.SubstringComparator
Nullary constructor for Writable
SubstringComparator(String) - Constructor for class org.apache.hadoop.hbase.filter.SubstringComparator
Constructor
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result.Isset
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result.Isset
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result.Isset
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result.Isset
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result.Isset
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result.Isset
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result.Isset
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result.Isset
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result.Isset
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result.Isset
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result.Isset
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result.Isset
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result.Isset
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result.Isset
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result.Isset
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result.Isset
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result.Isset
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
suspendEncoding() - Method in class org.apache.hadoop.hbase.util.Base64.Base64OutputStream
Suspends encoding of the stream.
sync(long) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Reader
Seek to the next sync mark past a given position.
sync() - Method in class org.apache.hadoop.hbase.io.SequenceFile.Writer
create a sync point
sync() - Method in class org.apache.hadoop.hbase.regionserver.HLog
 
SYNC_INTERVAL - Static variable in class org.apache.hadoop.hbase.io.SequenceFile
The number of bytes between sync points.
syncSeen() - Method in class org.apache.hadoop.hbase.io.SequenceFile.Reader
Returns true iff the previous call to next passed a sync mark.

T

TABLE_DESCRIPTOR_VERSION - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
tableDesc - Variable in class org.apache.hadoop.hbase.HRegionInfo
 
tableExists(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
tableExists(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
tableExists(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Checks if tableName 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
TableHandler - Class in org.apache.hadoop.hbase.rest
TableHandler fields all requests that deal with an individual table.
TableHandler(HBaseConfiguration, HBaseAdmin) - Constructor for class org.apache.hadoop.hbase.rest.TableHandler
 
TableInputFormat - Class in org.apache.hadoop.hbase.mapred
Convert HBase tabular data into a format that is consumable by Map/Reduce.
TableInputFormat() - Constructor for class org.apache.hadoop.hbase.mapred.TableInputFormat
 
TableInputFormatBase - Class in org.apache.hadoop.hbase.mapred
A Base for TableInputFormats.
TableInputFormatBase() - Constructor for class org.apache.hadoop.hbase.mapred.TableInputFormatBase
 
TableInputFormatBase.TableRecordReader - Class in org.apache.hadoop.hbase.mapred
Iterate over an HBase table data, return (Text, RowResult) pairs
TableInputFormatBase.TableRecordReader() - Constructor for class org.apache.hadoop.hbase.mapred.TableInputFormatBase.TableRecordReader
 
TableMap<K extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Interface in org.apache.hadoop.hbase.mapred
Scan an HBase table to sort by a specified sort column.
TableMapReduceUtil - Class in org.apache.hadoop.hbase.mapred
Utility for TableMap and TableReduce
TableMapReduceUtil() - Constructor for class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
 
tableName - Variable in class org.apache.hadoop.hbase.client.ServerCallable
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args.Isset
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args.Isset
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args.Isset
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args.Isset
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args.Isset
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args.Isset
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args.Isset
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args.Isset
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args.Isset
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args.Isset
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args.Isset
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args.Isset
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args.Isset
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args.Isset
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args.Isset
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args.Isset
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args.Isset
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args.Isset
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args.Isset
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args.Isset
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args.Isset
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args.Isset
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args.Isset
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args.Isset
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args.Isset
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args.Isset
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args.Isset
 
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
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
 
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
 
TableOutputFormat - Class in org.apache.hadoop.hbase.mapred
Convert Map/Reduce output and write it to an HBase table
TableOutputFormat() - Constructor for class org.apache.hadoop.hbase.mapred.TableOutputFormat
 
TableOutputFormat.TableRecordWriter - Class in org.apache.hadoop.hbase.mapred
Convert Reduce output (key, value) to (HStoreKey, KeyedDataArrayWritable) and write to an HBase table
TableOutputFormat.TableRecordWriter(HTable) - Constructor for class org.apache.hadoop.hbase.mapred.TableOutputFormat.TableRecordWriter
Instantiate a TableRecordWriter with the HBase HClient for writing.
TableReduce<K extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Interface in org.apache.hadoop.hbase.mapred
Write a table, sorting by the input key
TableSplit - Class in org.apache.hadoop.hbase.mapred
A table split corresponds to a key range [low, high)
TableSplit() - Constructor for class org.apache.hadoop.hbase.mapred.TableSplit
default constructor
TableSplit(byte[], byte[], byte[], String) - Constructor for class org.apache.hadoop.hbase.mapred.TableSplit
Constructor
tailMap(byte[]) - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
tailMap(byte[]) - Method in class org.apache.hadoop.hbase.io.RowResult
 
tailMap(K) - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
TCell - Class in org.apache.hadoop.hbase.thrift.generated
TCell - Used to transport a cell value (byte[]) and the timestamp it was stored with together as a result for get and getRow methods.
TCell() - Constructor for class org.apache.hadoop.hbase.thrift.generated.TCell
 
TCell(byte[], long) - Constructor for class org.apache.hadoop.hbase.thrift.generated.TCell
 
TCell.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
TCell.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.TCell.Isset
 
THREAD_WAKE_FREQUENCY - Static variable in interface org.apache.hadoop.hbase.HConstants
Parameter name for how often threads should wake up
threadDumpingJoin(Thread) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
Threads - Class in org.apache.hadoop.hbase.util
Thread Utility
Threads() - Constructor for class org.apache.hadoop.hbase.util.Threads
 
threadWakeFrequency - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
ThriftServer - Class in org.apache.hadoop.hbase.thrift
ThriftServer - this class starts up a Thrift server which implements the Hbase API specified in the Hbase.thrift IDL file.
ThriftServer() - Constructor for class org.apache.hadoop.hbase.thrift.ThriftServer
 
ThriftServer.HBaseHandler - Class in org.apache.hadoop.hbase.thrift
The HBaseHandler is a glue object that connects Thrift RPC calls to the HBase client API primarily defined in the HBaseAdmin and HTable objects.
ThriftUtilities - Class in org.apache.hadoop.hbase.thrift
 
ThriftUtilities() - Constructor for class org.apache.hadoop.hbase.thrift.ThriftUtilities
 
timestamp - Variable in class org.apache.hadoop.hbase.regionserver.HAbstractScanner
 
TIMESTAMP - Static variable in class org.apache.hadoop.hbase.rest.GenericHandler
 
timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args.Isset
 
timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args.Isset
 
timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args.Isset
 
timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args.Isset
 
timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args.Isset
 
timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args.Isset
 
timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args.Isset
 
timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args.Isset
 
timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args.Isset
 
timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.TCell.Isset
 
timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.TCell
 
TimeStampingFileContext - Class in org.apache.hadoop.hbase.metrics.file
Add timestamp to FileContext.emitRecord(String, String, OutputRecord).
TimeStampingFileContext() - Constructor for class org.apache.hadoop.hbase.metrics.file.TimeStampingFileContext
 
timeToLive - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor.Isset
 
timeToLive - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
toArray(List<byte[]>) - Static method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
toByteArrays(String[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
toByteArrays(String) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
toByteArrays(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
toBytes(String) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a string to a UTF-8 byte array.
toBytes(long) - Static method in class org.apache.hadoop.hbase.util.Bytes
Convert a long value to a byte array
toBytes(int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Convert an int value to a byte array
toBytes(float) - Static method in class org.apache.hadoop.hbase.util.Bytes
Convert an float value to a byte array
toBytes(double) - Static method in class org.apache.hadoop.hbase.util.Bytes
Convert an double value to a byte array
toDouble(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to a double value
toFloat(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to a float value
toInt(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to a long value
toLong(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to a long value
toString() - Method in class org.apache.hadoop.hbase.client.tableindexed.IndexSpecification
toString() - Method in class org.apache.hadoop.hbase.client.transactional.TransactionState
 
toString() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
toString() - Method in class org.apache.hadoop.hbase.HMsg
 
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.HServerAddress
 
toString() - Method in class org.apache.hadoop.hbase.HServerInfo
 
toString() - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
 
toString() - Method in class org.apache.hadoop.hbase.HServerLoad
 
toString(int) - Method in class org.apache.hadoop.hbase.HServerLoad
Returns toString() with the number of requests divided by the message interval in seconds
toString() - Method in class org.apache.hadoop.hbase.HStoreKey.BeforeThisStoreKey
 
toString() - Method in class org.apache.hadoop.hbase.HStoreKey
 
toString() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
toString() - Method in class org.apache.hadoop.hbase.io.BatchOperation
 
toString() - Method in class org.apache.hadoop.hbase.io.BatchUpdate
 
toString() - Method in class org.apache.hadoop.hbase.io.Cell
 
toString() - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
toString() - Method in class org.apache.hadoop.hbase.io.HbaseObjectWritable
 
toString() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
toString() - Method in class org.apache.hadoop.hbase.io.Reference
 
toString() - Method in class org.apache.hadoop.hbase.io.RowResult
 
toString() - Method in class org.apache.hadoop.hbase.io.SequenceFile.Metadata
 
toString() - Method in class org.apache.hadoop.hbase.io.SequenceFile.Reader
Returns the name of the file.
toString() - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
 
toString() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
toString() - Method in class org.apache.hadoop.hbase.master.MetaRegion
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.HLogEdit
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.HLogKey
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
 
toString() - Method in enum org.apache.hadoop.hbase.rest.GenericHandler.ContentType
 
toString() - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
toString() - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
 
toString() - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
toString() - Method in exception org.apache.hadoop.hbase.thrift.generated.NotFound
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
toString(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
toString() - Method in class org.apache.hadoop.hbase.util.Pair
 
TransactionalRegion - Class in org.apache.hadoop.hbase.regionserver.transactional
Regionserver which provides transactional support for atomic transactions.
TransactionalRegion(Path, HLog, FileSystem, HBaseConfiguration, HRegionInfo, FlushRequester) - Constructor for class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegion
 
TransactionalRegionInterface - Interface in org.apache.hadoop.hbase.ipc
Interface for transactional region servers.
TransactionalRegionServer - Class in org.apache.hadoop.hbase.regionserver.transactional
RegionServer with support for transactions.
TransactionalRegionServer(HBaseConfiguration) - Constructor for class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegionServer
 
TransactionalRegionServer(HServerAddress, HBaseConfiguration) - Constructor for class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegionServer
 
TransactionalTable - Class in org.apache.hadoop.hbase.client.transactional
Table with transactional support.
TransactionalTable(HBaseConfiguration, String) - Constructor for class org.apache.hadoop.hbase.client.transactional.TransactionalTable
 
TransactionalTable(HBaseConfiguration, byte[]) - Constructor for class org.apache.hadoop.hbase.client.transactional.TransactionalTable
 
TransactionalTable.TransactionalClientScanner - Class in org.apache.hadoop.hbase.client.transactional
 
TransactionalTable.TransactionalClientScanner(TransactionState, byte[][], byte[], long, RowFilterInterface) - Constructor for class org.apache.hadoop.hbase.client.transactional.TransactionalTable.TransactionalClientScanner
 
TransactionLogger - Interface in org.apache.hadoop.hbase.client.transactional
Simple interface used to provide a log about transaction status.
TransactionLogger.TransactionStatus - Enum in org.apache.hadoop.hbase.client.transactional
Transaction status values
TransactionManager - Class in org.apache.hadoop.hbase.client.transactional
Transaction Manager.
TransactionManager(HBaseConfiguration) - Constructor for class org.apache.hadoop.hbase.client.transactional.TransactionManager
 
TransactionManager(TransactionLogger, HBaseConfiguration) - Constructor for class org.apache.hadoop.hbase.client.transactional.TransactionManager
 
TransactionState - Class in org.apache.hadoop.hbase.client.transactional
Holds client-side transaction information.
TRegionInfo - Class in org.apache.hadoop.hbase.thrift.generated
A TRegionInfo contains information about an HTable region.
TRegionInfo() - Constructor for class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
TRegionInfo(byte[], byte[], long, byte[], byte) - Constructor for class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
TRegionInfo.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
TRegionInfo.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.TRegionInfo.Isset
 
TRowResult - Class in org.apache.hadoop.hbase.thrift.generated
Holds row name and then a map of columns to cells.
TRowResult() - Constructor for class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
TRowResult(byte[], Map<byte[], TCell>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
TRowResult.Isset - Class in org.apache.hadoop.hbase.thrift.generated
 
TRowResult.Isset() - Constructor for class org.apache.hadoop.hbase.thrift.generated.TRowResult.Isset
 
tryCommit(TransactionState) - Method in class org.apache.hadoop.hbase.client.transactional.TransactionManager
Try and commit a transaction.
TTL - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
ttl - Variable in class org.apache.hadoop.hbase.regionserver.HStore
 

U

uncompressedValSerializer - Variable in class org.apache.hadoop.hbase.io.SequenceFile.Writer
 
UnknownRowLockException - Exception in org.apache.hadoop.hbase
Thrown if a region server is passed an unknown row lock id
UnknownRowLockException() - Constructor for exception org.apache.hadoop.hbase.UnknownRowLockException
constructor
UnknownRowLockException(String) - Constructor for exception org.apache.hadoop.hbase.UnknownRowLockException
Constructor
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
UnknownTransactionException - Exception in org.apache.hadoop.hbase.client.transactional
Thrown if a region server is passed an unknown transaction id
UnknownTransactionException() - Constructor for exception org.apache.hadoop.hbase.client.transactional.UnknownTransactionException
constructor
UnknownTransactionException(String) - Constructor for exception org.apache.hadoop.hbase.client.transactional.UnknownTransactionException
Constructor
unlockRow(RowLock) - Method in class org.apache.hadoop.hbase.client.HTable
Release a row lock
unlockRow(byte[], long) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
Releases a remote row lock.
unlockRow(byte[], long) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
UnmodifyableHColumnDescriptor - Class in org.apache.hadoop.hbase.client
Immutable HColumnDescriptor
UnmodifyableHColumnDescriptor(HColumnDescriptor) - Constructor for class org.apache.hadoop.hbase.client.UnmodifyableHColumnDescriptor
 
UnmodifyableHTableDescriptor - Class in org.apache.hadoop.hbase.client
Read-only table descriptor.
UnmodifyableHTableDescriptor() - Constructor for class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
Default constructor
unsetRootRegionLocation() - Method in interface org.apache.hadoop.hbase.client.ServerConnection
Unset the root region location in the connection.
updateMETARegionInfo(HRegion, HRegionInfo) - Method in class org.apache.hadoop.hbase.util.MetaUtils
Update COL_REGIONINFO in meta region r with HRegionInfo hri
updateReaders(long) - Method in interface org.apache.hadoop.hbase.regionserver.ChangedReadersObserver
Notify observers.
URL_SAFE - Static variable in class org.apache.hadoop.hbase.util.Base64
Encode using Base64-like encoding that is URL and Filename safe as described in Section 4 of RFC3548: http://www.faqs.org/rfcs/rfc3548.html.
UTF8_ENCODING - Static variable in interface org.apache.hadoop.hbase.HConstants
When we encode strings, we always specify UTF8 encoding

V

validate(byte[][]) - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
 
validate(byte[][]) - Method in class org.apache.hadoop.hbase.filter.PageRowFilter
 
validate(byte[][]) - Method in class org.apache.hadoop.hbase.filter.PrefixRowFilter
 
validate(byte[][]) - Method in class org.apache.hadoop.hbase.filter.RegExpRowFilter
 
validate(byte[][]) - Method in interface org.apache.hadoop.hbase.filter.RowFilterInterface
Validates that this filter applies only to a subset of the given columns.
validate(byte[][]) - Method in class org.apache.hadoop.hbase.filter.RowFilterSet
 
validate(byte[][]) - Method in class org.apache.hadoop.hbase.filter.StopRowFilter
 
validate(byte[][]) - Method in class org.apache.hadoop.hbase.filter.WhileMatchRowFilter
 
validateInput(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormat
 
validateRootPath(Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Verifies root directory path is a valid URI with a scheme
value - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args.Isset
 
value - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
value - Variable in class org.apache.hadoop.hbase.thrift.generated.Mutation.Isset
 
value - Variable in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
value - Variable in class org.apache.hadoop.hbase.thrift.generated.TCell.Isset
 
value - Variable in class org.apache.hadoop.hbase.thrift.generated.TCell
 
VALUE_CLASS - Static variable in class org.apache.hadoop.hbase.io.HBaseMapFile
Values are instances of this class.
valueMap - Variable in class org.apache.hadoop.hbase.io.Cell
 
valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.transactional.TransactionLogger.TransactionStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.filter.ColumnValueFilter.CompareOp
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.filter.RowFilterSet.Operator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.HColumnDescriptor.CompressionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.HMsg.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.io.Reference.Range
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.io.SequenceFile.CompressionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.HLogEdit.TransactionalOperation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.rest.GenericHandler.ContentType
Returns the enum constant of this type with the specified name.
ValueOverMaxLengthException - Exception in org.apache.hadoop.hbase
Thrown when a value is longer than the specified LENGTH
ValueOverMaxLengthException() - Constructor for exception org.apache.hadoop.hbase.ValueOverMaxLengthException
default constructor
ValueOverMaxLengthException(String) - Constructor for exception org.apache.hadoop.hbase.ValueOverMaxLengthException
 
values() - Static method in enum org.apache.hadoop.hbase.client.transactional.TransactionLogger.TransactionStatus
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.ColumnValueFilter.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.RowFilterSet.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.HColumnDescriptor.CompressionType
Returns an array containing the constants of this enum type, in the order they are declared.
values - Variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
values() - Static method in enum org.apache.hadoop.hbase.HMsg.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values - Variable in class org.apache.hadoop.hbase.HTableDescriptor
 
values() - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
values() - Static method in enum org.apache.hadoop.hbase.io.Reference.Range
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.hadoop.hbase.io.RowResult
 
values() - Static method in enum org.apache.hadoop.hbase.io.SequenceFile.CompressionType
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.HLogEdit.TransactionalOperation
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.rest.GenericHandler.ContentType
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.SoftValueMap
 
values() - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
VERSION - Static variable in class org.apache.hadoop.hbase.rest.GenericHandler
 
version - Variable in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo.Isset
 
version - Variable in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
VERSION_FILE_NAME - Static variable in interface org.apache.hadoop.hbase.HConstants
name of version file
VersionAnnotation - Annotation Type in org.apache.hadoop.hbase
A package attribute that captures the version of hbase that was compiled.
versionID - Static variable in interface org.apache.hadoop.hbase.ipc.HBaseRPCProtocolVersion
Interface version.
VersionInfo - Class in org.apache.hadoop.hbase.util
This class finds the package info for hbase and the VersionAnnotation information.
VersionInfo() - Constructor for class org.apache.hadoop.hbase.util.VersionInfo
 
VERSIONS - Static variable in interface org.apache.hadoop.hbase.HConstants
 

W

waitForProxy(Class, long, InetSocketAddress, Configuration, int) - Static method in class org.apache.hadoop.hbase.ipc.HBaseRPC
 
waitForRootRegionLocation() - Method in class org.apache.hadoop.hbase.master.HMaster
Wait until root region is available
waitForServerOnline() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster.RegionServerThread
Block until the region server has come online, indicating it is ready to be used.
waitOnRegionServer(int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
Wait for the specified region server to stop Removes this thread from list of running threads.
WEEK_IN_SECONDS - Static variable in interface org.apache.hadoop.hbase.HConstants
 
WhileMatchRowFilter - Class in org.apache.hadoop.hbase.filter
WhileMatchRowFilter is a wrapper filter that filters everything after the first filtered row.
WhileMatchRowFilter() - Constructor for class org.apache.hadoop.hbase.filter.WhileMatchRowFilter
Default constructor, filters nothing.
WhileMatchRowFilter(RowFilterInterface) - Constructor for class org.apache.hadoop.hbase.filter.WhileMatchRowFilter
Constructor
WritableByteArrayComparable - Interface in org.apache.hadoop.hbase.filter
Interface for both Comparable and Writable.
WritableComparator<T> - Interface in org.apache.hadoop.hbase
 
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.client.tableindexed.IndexSpecification
write(DataOutput) - Method in class org.apache.hadoop.hbase.client.tableindexed.ReverseByteArrayComparator
write(DataOutput) - Method in class org.apache.hadoop.hbase.client.tableindexed.SimpleIndexKeyGenerator
write(DataOutput) - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.filter.PageRowFilter
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.filter.PrefixRowFilter
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.filter.RegExpRowFilter
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.filter.RowFilterSet
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.filter.StopRowFilter
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.filter.SubstringComparator
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.filter.WhileMatchRowFilter
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.HMsg
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.HRegionInfo
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.HServerAddress
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.HServerInfo
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.HServerLoad
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.HStoreKey.BeforeThisStoreKey
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.HStoreKey
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.io.BatchOperation
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.io.BatchUpdate
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.io.Cell
 
write(DataInput, int) - Method in class org.apache.hadoop.hbase.io.DataOutputBuffer
Writes bytes from a DataInput directly into the buffer.
write(DataOutput) - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.io.HbaseObjectWritable
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.io.Reference
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.io.RowResult
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Metadata
 
write(OutputStream) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
 
write(ImmutableBytesWritable, BatchUpdate) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat.TableRecordWriter
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.regionserver.HLogEdit
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.regionserver.HLogKey
 
write(TProtocol) - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
write(TProtocol) - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
 
write(TProtocol) - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
write(TProtocol) - Method in exception org.apache.hadoop.hbase.thrift.generated.NotFound
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
write(int) - Method in class org.apache.hadoop.hbase.util.Base64.Base64OutputStream
Writes the byte to the output stream after converting to/from Base64 notation.
write(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.Base64.Base64OutputStream
Calls write(int) repeatedly until len bytes are written.
writeByteArray(DataOutput, byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
writeCompressedBytes(DataOutputStream) - Method in interface org.apache.hadoop.hbase.io.SequenceFile.ValueBytes
Write compressed bytes to outStream.
writeFile(SequenceFile.Sorter.RawKeyValueIterator, SequenceFile.Writer) - Method in class org.apache.hadoop.hbase.io.SequenceFile.Sorter
Writes records from RawKeyValueIterator into a file represented by the passed writer
writeObject(DataOutput, Object, Class, Configuration) - Static method in class org.apache.hadoop.hbase.io.HbaseObjectWritable
Write a Writable, String, primitive type, or an array of the preceding.
writeTo(OutputStream) - Method in class org.apache.hadoop.hbase.io.DataOutputBuffer
Write to a file stream
writeUncompressedBytes(DataOutputStream) - Method in interface org.apache.hadoop.hbase.io.SequenceFile.ValueBytes
Writes the uncompressed bytes to the outStream.
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

Z

ZERO_L - Static variable in interface org.apache.hadoop.hbase.HConstants
long constant for zero
ZEROES - Static variable in interface org.apache.hadoop.hbase.HConstants
 

_

__isset - Variable in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
__isset - Variable in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
 
__isset - Variable in exception org.apache.hadoop.hbase.thrift.generated.IOError
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
__isset - Variable in exception org.apache.hadoop.hbase.thrift.generated.NotFound
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.TCell
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
__isset - Variable in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 

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

Copyright © 2008 The Apache Software Foundation