A B C D E F G H I J K L M N O P Q R S T U V W X 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
 
abortTask(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
 
AbstractController - Class in org.apache.hadoop.hbase.rest
 
AbstractController() - Constructor for class org.apache.hadoop.hbase.rest.AbstractController
 
AbstractModel - Class in org.apache.hadoop.hbase.rest
 
AbstractModel() - Constructor for class org.apache.hadoop.hbase.rest.AbstractModel
 
AbstractModel.Encodings - Class in org.apache.hadoop.hbase.rest
 
AbstractModel.Encodings() - Constructor for class org.apache.hadoop.hbase.rest.AbstractModel.Encodings
 
AbstractModel.Encodings.Encoding - Interface in org.apache.hadoop.hbase.rest
 
AbstractRestSerializer - Class in org.apache.hadoop.hbase.rest.serializer
Abstract object that is used as the base of all serializers in the REST based interface.
AbstractRestSerializer(HttpServletResponse, boolean) - Constructor for class org.apache.hadoop.hbase.rest.serializer.AbstractRestSerializer
Public constructor for AbstractRestSerializer.
accept(Path) - Method in class org.apache.hadoop.hbase.util.FSUtils.DirFilter
 
access(long) - Method in class org.apache.hadoop.hbase.io.hfile.CachedBlock
Block has been accessed.
add(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
Add the specified column and value to this Put operation.
add(byte[], long, byte[]) - Method in class org.apache.hadoop.hbase.client.Put
Add the specified column and value, with the specified timestamp as its version to this Put operation.
add(byte[], byte[], long, byte[]) - Method in class org.apache.hadoop.hbase.client.Put
Add the specified column and value, with the specified timestamp as its version to this Put operation.
add(KeyValue) - Method in class org.apache.hadoop.hbase.client.Put
Add the specified KeyValue to this Put operation.
add(byte[], long) - Method in class org.apache.hadoop.hbase.io.Cell
Deprecated. Add a new timestamp and value to this cell provided timestamp does not already exist
add(CachedBlock) - Method in class org.apache.hadoop.hbase.io.hfile.CachedBlockQueue
Attempt to add the specified cached block to this queue.
add(Key) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.BloomFilter
 
add(Key) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.CountingBloomFilter
 
add(Key) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.DynamicBloomFilter
 
add(Key) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.Filter
Adds a key to this filter.
add(List<Key>) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.Filter
Adds a list of keys to this filter.
add(Collection<Key>) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.Filter
Adds a collection of keys to this filter.
add(Key[]) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.Filter
Adds an array of keys to this filter.
add(Key) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.RetouchedBloomFilter
 
add(byte[], int, int, long, byte) - Method in interface org.apache.hadoop.hbase.regionserver.DeleteTracker
Add the specified KeyValue to the list of deletes to check against for this row operation.
add(byte[], int, int, long, byte) - Method in class org.apache.hadoop.hbase.regionserver.GetDeleteTracker
Add the specified KeyValue to the list of deletes to check against for this row operation.
add(byte[], int, int, long, byte) - Method in class org.apache.hadoop.hbase.regionserver.ScanDeleteTracker
Add the specified KeyValue to the list of deletes to check against for this row operation.
add(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.Store
Adds a value to the memstore
add(long, byte[], byte[]) - Method in class org.apache.hadoop.hbase.rest.descriptors.TimestampsDescriptor
 
add(String) - Method in class org.apache.hadoop.hbase.stargate.client.Cluster
Add a node to the cluster
add(String, int) - Method in class org.apache.hadoop.hbase.stargate.client.Cluster
Add a node to the cluster
add(TableRegionModel) - Method in class org.apache.hadoop.hbase.stargate.model.TableInfoModel
Add a region model to the list
add(TableModel) - Method in class org.apache.hadoop.hbase.stargate.model.TableListModel
Add the table name model to the list
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
 
addAllAttrs(Iterable<? extends ColumnSchemaMessage.ColumnSchema.Attribute>) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
addAllAttrs(Iterable<? extends TableSchemaMessage.TableSchema.Attribute>) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
addAllColumns(Iterable<? extends ByteString>) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
addAllColumns(Iterable<? extends ColumnSchemaMessage.ColumnSchema>) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
addAllDeadNodes(Iterable<? extends String>) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
addAllLiveNodes(Iterable<? extends StorageClusterStatusMessage.StorageClusterStatus.Node>) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
addAllName(Iterable<? extends String>) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList.Builder
 
addAllRegions(Iterable<? extends StorageClusterStatusMessage.StorageClusterStatus.Region>) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
addAllRegions(Iterable<? extends TableInfoMessage.TableInfo.Region>) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
addAllRows(Iterable<? extends CellSetMessage.CellSet.Row>) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Builder
 
addAllValues(Iterable<? extends CellMessage.Cell>) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
addAttribute(String, Object) - Method in class org.apache.hadoop.hbase.stargate.model.ColumnSchemaModel
Add an attribute to the column family schema
addAttribute(String, Object) - Method in class org.apache.hadoop.hbase.stargate.model.TableSchemaModel
Add an attribute to the table descriptor
addAttrs(ColumnSchemaMessage.ColumnSchema.Attribute) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
addAttrs(ColumnSchemaMessage.ColumnSchema.Attribute.Builder) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
addAttrs(TableSchemaMessage.TableSchema.Attribute) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
addAttrs(TableSchemaMessage.TableSchema.Attribute.Builder) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
addCell(CellModel) - Method in class org.apache.hadoop.hbase.stargate.model.RowModel
Adds a cell to the list of cells for this row
addColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Get
Get the column from the specific family with the specified qualifier.
addColumn(byte[]) - Method in class org.apache.hadoop.hbase.client.Get
 
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[], byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
Get the column from the specified family with the specified qualifier.
addColumn(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
Parses a combined family and qualifier and adds either both or just the family in case there is not qualifier.
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[]) - Method in class org.apache.hadoop.hbase.stargate.model.ScannerModel
Add a column to the column set
addColumn(byte[]) - Method in class org.apache.hadoop.hbase.stargate.RowSpec
 
addColumn(byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.util.MetaUtils
Offline version of the online TableOperation, org.apache.hadoop.hbase.master.AddColumn.
addColumnFamily(ColumnSchemaModel) - Method in class org.apache.hadoop.hbase.stargate.model.TableSchemaModel
Add a column family to the table descriptor
addColumns(byte[][]) - Method in class org.apache.hadoop.hbase.client.Get
Adds an array of columns specified the old format, family:qualifier.
addColumns(byte[][]) - Method in class org.apache.hadoop.hbase.client.Scan
Adds an array of columns specified using old format, family:qualifier.
addColumns(String) - Method in class org.apache.hadoop.hbase.client.Scan
Convenience method to help parse old style (or rather user entry on the command line) column definitions, e.g.
addColumns(ByteString) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
addColumns(ColumnSchemaMessage.ColumnSchema) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
addColumns(ColumnSchemaMessage.ColumnSchema.Builder) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
addDeadNode(String) - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel
Add a dead node to the cluster representation.
addDeadNodes(String) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
addDefaultApps(ContextHandlerCollection, String) - Method in class org.apache.hadoop.hbase.util.InfoServer
 
addDelimiter(byte[]) - Static method in class org.apache.hadoop.hbase.HStoreKey
Deprecated.  
addDelimiter(byte[]) - Static method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey
 
addFalsePositive(Key) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.RetouchedBloomFilter
Adds a false positive information to this retouched Bloom filter.
addFalsePositive(Collection<Key>) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.RetouchedBloomFilter
Adds a collection of false positive information to this retouched Bloom filter.
addFalsePositive(List<Key>) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.RetouchedBloomFilter
Adds a list of false positive information to this retouched Bloom filter.
addFalsePositive(Key[]) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.RetouchedBloomFilter
Adds an array of false positive information to this retouched Bloom filter.
addFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.Get
Get all columns from the specified family.
addFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
Get all columns from the specified family.
addFamily(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
Does NOT add a column family.
addFamily(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Adds a column family.
addFilter(Filter) - Method in class org.apache.hadoop.hbase.filter.FilterList
Add a filter.
addFilter(RowFilterInterface) - Method in class org.apache.hadoop.hbase.filter.RowFilterSet
Deprecated. Add a filter.
addFromXML(String) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
Deprecated.  
addFromXML(String) - Method in class org.apache.hadoop.hbase.mapreduce.IndexConfiguration
 
addIndex(byte[], IndexSpecification) - Method in class org.apache.hadoop.hbase.client.tableindexed.IndexedTableAdmin
Add an index to a table.
addIndex(IndexSpecification) - Method in class org.apache.hadoop.hbase.client.tableindexed.IndexedTableDescriptor
 
addLiveNode(String, long, int, int) - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel
Add a live node to the cluster representation.
addLiveNodes(StorageClusterStatusMessage.StorageClusterStatus.Node) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
addLiveNodes(StorageClusterStatusMessage.StorageClusterStatus.Node.Builder) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
addName(String) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList.Builder
 
addProcessingMessage(HRegionInfo) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Add a MSG_REPORT_PROCESS_OPEN to the outbound queue.
addRegion(byte[], int, int, int, int, int) - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel.Node
Add a region name to the list
addRegionInfo(HServerLoad.RegionLoad) - Method in class org.apache.hadoop.hbase.HServerLoad
 
addRegionInfo(byte[], int, int, int, int, int) - Method in class org.apache.hadoop.hbase.HServerLoad
Deprecated. Use HServerLoad.addRegionInfo(RegionLoad)
addRegions(StorageClusterStatusMessage.StorageClusterStatus.Region) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
addRegions(StorageClusterStatusMessage.StorageClusterStatus.Region.Builder) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
addRegions(TableInfoMessage.TableInfo.Region) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
addRegions(TableInfoMessage.TableInfo.Region.Builder) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
addRegionServer() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
Creates a region server.
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.
addRow(RowModel) - Method in class org.apache.hadoop.hbase.stargate.model.CellSetModel
Add a row to this cell set
addRowLock(Integer, HRegion) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
addRows(CellSetMessage.CellSet.Row) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Builder
 
addRows(CellSetMessage.CellSet.Row.Builder) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Builder
 
addScanner(InternalScanner) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
addScanner(ResultScanner) - Method in class org.apache.hadoop.hbase.rest.ScannerModel.ScannerMaster
 
addScanner(ResultScanner) - 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.
addToMap(Class<?>, byte) - Static method in class org.apache.hadoop.hbase.ipc.HBaseRPC
Add a new interface to the ipc map.
addValues(CellMessage.Cell) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
addValues(CellMessage.Cell.Builder) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
admin - Variable in class org.apache.hadoop.hbase.rest.AbstractModel
 
admin - Variable in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
align(int) - Static method in class org.apache.hadoop.hbase.util.ClassSize
Aligns a number to 8.
align(long) - Static method in class org.apache.hadoop.hbase.util.ClassSize
Aligns a number to 8.
ALL_VERSIONS - Static variable in interface org.apache.hadoop.hbase.HConstants
Define for 'return-all-versions'.
and(Filter) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.BloomFilter
 
and(Filter) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.CountingBloomFilter
 
and(Filter) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.DynamicBloomFilter
 
and(Filter) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.Filter
Peforms a logical AND between this filter and a specified filter.
append(KeyValue) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.Writer
Add key/value to file.
append(byte[], byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.Writer
Add key/value to file.
append(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.Writer
Add key/value to file.
append(WritableComparable, Writable) - Method in class org.apache.hadoop.hbase.migration.nineteen.io.BloomFilterMapFile.Writer
 
append(HRegionInfo, KeyValue, long) - Method in class org.apache.hadoop.hbase.regionserver.HLog
Append an entry to the log.
append(HRegionInfo, HLogKey, KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.HLog
Append an entry to the log.
append(byte[], byte[], List<KeyValue>, boolean, long) - Method in class org.apache.hadoop.hbase.regionserver.HLog
Append a set of edits to the log.
appendFileInfo(byte[], byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.Writer
Add to the file info.
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.
appendMetaBlock(String, byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.Writer
Add a meta block to the end of the file.
appendMetadata(HFile.Writer, long, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFile
Writes metadata.
approximateCount(Key) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.CountingBloomFilter
This method calculates an approximate count of the key, i.e.
ARGUMENTS - Static variable in interface org.apache.hadoop.hbase.rest.filter.FilterFactoryConstants
 
ARRAY - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Array overhead
ARRAYLIST - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for ArrayList(0)
ATOMIC_BOOLEAN - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for AtomicBoolean
ATOMIC_INTEGER - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for AtomicInteger
ATOMIC_LONG - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for AtomicLong
atomicIncrement(byte[], byte[], byte[], long) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
Deprecated. 
atomicIncrement(byte[], byte[], byte[], byte[], long) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
atomicIncrementTime - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
 
ATTRS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
ATTRS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
AVERAGELOAD_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 

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.
BATCH_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
BatchOperation - Class in org.apache.hadoop.hbase.io
Deprecated. As of hbase 0.20.0, replaced by new Get/Put/Delete/Result-based API.
BatchOperation() - Constructor for class org.apache.hadoop.hbase.io.BatchOperation
Deprecated. Default constructor
BatchOperation(byte[]) - Constructor for class org.apache.hadoop.hbase.io.BatchOperation
Deprecated. Creates a DELETE batch operation.
BatchOperation(String) - Constructor for class org.apache.hadoop.hbase.io.BatchOperation
Deprecated. Creates a DELETE batch operation.
BatchOperation(String, String) - Constructor for class org.apache.hadoop.hbase.io.BatchOperation
Deprecated. Create a batch operation.
BatchOperation(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.io.BatchOperation
Deprecated. Create a batch operation.
BatchUpdate - Class in org.apache.hadoop.hbase.io
Deprecated. As of hbase 0.20.0, replaced by new Get/Put/Delete/Result-based API.
BatchUpdate() - Constructor for class org.apache.hadoop.hbase.io.BatchUpdate
Deprecated. Default constructor used serializing.
BatchUpdate(String) - Constructor for class org.apache.hadoop.hbase.io.BatchUpdate
Deprecated. Initialize a BatchUpdate operation on a row.
BatchUpdate(byte[]) - Constructor for class org.apache.hadoop.hbase.io.BatchUpdate
Deprecated. Initialize a BatchUpdate operation on a row.
BatchUpdate(String, long) - Constructor for class org.apache.hadoop.hbase.io.BatchUpdate
Deprecated. Initialize a BatchUpdate operation on a row with a specific timestamp.
BatchUpdate(BatchUpdate) - Constructor for class org.apache.hadoop.hbase.io.BatchUpdate
Deprecated. Recopy constructor
BatchUpdate(byte[], long) - Constructor for class org.apache.hadoop.hbase.io.BatchUpdate
Deprecated. Initialize a BatchUpdate operation on a row with a specific timestamp.
BatchUpdate(RowResult) - Constructor for class org.apache.hadoop.hbase.io.BatchUpdate
Deprecated. Create a batch operation.
beginMemstoreInsert() - Method in class org.apache.hadoop.hbase.regionserver.ReadWriteConsistencyControl
 
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
 
BinaryComparator - Class in org.apache.hadoop.hbase.filter
A binary comparator which lexicographically compares against the specified byte array using Bytes.compareTo(byte[], byte[]).
BinaryComparator() - Constructor for class org.apache.hadoop.hbase.filter.BinaryComparator
Nullary constructor for Writable, do not use
BinaryComparator(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.BinaryComparator
Constructor
BinaryPrefixComparator - Class in org.apache.hadoop.hbase.filter
A comparator which compares against a specified byte array, but only compares up to the length of this byte array.
BinaryPrefixComparator() - Constructor for class org.apache.hadoop.hbase.filter.BinaryPrefixComparator
Nullary constructor for Writable, do not use
BinaryPrefixComparator(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.BinaryPrefixComparator
Constructor
binarySearch(byte[][], byte[], int, int, RawComparator<byte[]>) - Static method in class org.apache.hadoop.hbase.util.Bytes
Binary search for keys in indexes.
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.
bindAddress - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
BLOCKCACHE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
BlockCache - Interface in org.apache.hadoop.hbase.io.hfile
Block cache interface.
blockCacheCount - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
Block cache item count.
blockCacheFree - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
Block cache free size.
blockCacheHitRatio - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
Block hit ratio.
blockCacheSize - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
Block cache size.
blockContainingKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
blockLoads - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
BLOCKSIZE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
BLOOMFILTER - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
BloomFilter - Class in org.apache.hadoop.hbase.migration.nineteen.onelab.filter
Implements a Bloom filter, as defined by Bloom in 1970.
BloomFilter() - Constructor for class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.BloomFilter
Default constructor - use with readFields
BloomFilter(int, int, int) - Constructor for class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.BloomFilter
Constructor
BLOOMFILTER_FILE_NAME - Static variable in class org.apache.hadoop.hbase.migration.nineteen.io.BloomFilterMapFile
 
BloomFilterMapFile - Class in org.apache.hadoop.hbase.migration.nineteen.io
On write, all keys are added to a bloom filter.
BloomFilterMapFile() - Constructor for class org.apache.hadoop.hbase.migration.nineteen.io.BloomFilterMapFile
 
BloomFilterMapFile.Reader - Class in org.apache.hadoop.hbase.migration.nineteen.io
 
BloomFilterMapFile.Reader(FileSystem, String, Configuration, boolean, boolean, HRegionInfo) - Constructor for class org.apache.hadoop.hbase.migration.nineteen.io.BloomFilterMapFile.Reader
 
BloomFilterMapFile.Writer - Class in org.apache.hadoop.hbase.migration.nineteen.io
 
BloomFilterMapFile.Writer(Configuration, FileSystem, String, SequenceFile.CompressionType, boolean, int, HRegionInfo) - Constructor for class org.apache.hadoop.hbase.migration.nineteen.io.BloomFilterMapFile.Writer
 
build() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell.Builder
 
build() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Builder
 
build() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
build() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
build() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
build() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
build() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
build() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
build() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
build() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
build() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
build() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList.Builder
 
build() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
build() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
build() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version.Builder
 
buildFilter(String) - Static method in class org.apache.hadoop.hbase.stargate.model.ScannerModel
 
buildFilter(String) - Static method in class org.apache.hadoop.hbase.stargate.ResultGenerator
 
buildFilterFromModel(ScannerModel) - Static method in class org.apache.hadoop.hbase.stargate.ScannerResultGenerator
 
buildModelFromPut(Put) - Method in class org.apache.hadoop.hbase.stargate.client.RemoteHTable
 
buildPartial() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version.Builder
 
buildResultFromModel(CellSetModel) - Method in class org.apache.hadoop.hbase.stargate.client.RemoteHTable
 
buildRowSpec(byte[], Map, long, long, int) - Method in class org.apache.hadoop.hbase.stargate.client.RemoteHTable
 
BuildTableIndex - Class in org.apache.hadoop.hbase.mapred
Deprecated. 
BuildTableIndex() - Constructor for class org.apache.hadoop.hbase.mapred.BuildTableIndex
Deprecated. default constructor
BuildTableIndex - Class in org.apache.hadoop.hbase.mapreduce
Example table column indexing class.
BuildTableIndex() - Constructor for class org.apache.hadoop.hbase.mapreduce.BuildTableIndex
 
BYTE_BUFFER - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for ByteBuffer
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.ByteArrayComparator - Class in org.apache.hadoop.hbase.util
Byte array comparator class.
Bytes.ByteArrayComparator() - Constructor for class org.apache.hadoop.hbase.util.Bytes.ByteArrayComparator
Constructor
BYTES_COMPARATOR - Static variable in class org.apache.hadoop.hbase.util.Bytes
Pass this to TreeMaps where byte [] are keys.
BYTES_RAWCOMPARATOR - Static variable in class org.apache.hadoop.hbase.util.Bytes
Use comparing byte arrays, byte-by-byte
bytesToVint(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
 

C

CACHE_FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
cacheBlock(String, ByteBuffer, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
Add block to cache.
cacheBlock(String, ByteBuffer) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
Add block to cache (defaults to not in-memory).
cacheBlock(String, ByteBuffer, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Cache the block with the specified name and buffer.
cacheBlock(String, ByteBuffer) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Cache the block with the specified name and buffer.
cacheBlock(String, ByteBuffer) - Method in class org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
 
cacheBlock(String, ByteBuffer, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
 
CachedBlock - Class in org.apache.hadoop.hbase.io.hfile
Represents an entry in the LruBlockCache.
CachedBlock(String, ByteBuffer, long) - Constructor for class org.apache.hadoop.hbase.io.hfile.CachedBlock
 
CachedBlock(String, ByteBuffer, long, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.CachedBlock
 
CachedBlockQueue - Class in org.apache.hadoop.hbase.io.hfile
A memory-bound queue that will grow until an element brings total size >= maxSize.
CachedBlockQueue(long, long) - Constructor for class org.apache.hadoop.hbase.io.hfile.CachedBlockQueue
 
cacheHits - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
calculateOverhead(long, long, int) - Static method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
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.
callQueue - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
cancelLease(String) - Method in class org.apache.hadoop.hbase.Leases
Client explicitly cancels a lease.
CATALOG_FAMILY - Static variable in interface org.apache.hadoop.hbase.HConstants
The catalog family
CATALOG_FAMILY_STR - Static variable in interface org.apache.hadoop.hbase.HConstants
The catalog family as a string
CATALOG_HISTORIAN_FAMILY - Static variable in interface org.apache.hadoop.hbase.HConstants
The catalog historian family
Cell - Class in org.apache.hadoop.hbase.io
Deprecated. As of hbase 0.20.0, replaced by new Get/Put/Delete/Result-based API.
Cell() - Constructor for class org.apache.hadoop.hbase.io.Cell
Deprecated. For Writable compatibility
Cell(String, long) - Constructor for class org.apache.hadoop.hbase.io.Cell
Deprecated. Create a new Cell with a given value and timestamp.
Cell(byte[], long) - Constructor for class org.apache.hadoop.hbase.io.Cell
Deprecated. Create a new Cell with a given value and timestamp.
Cell(ByteBuffer, long) - Constructor for class org.apache.hadoop.hbase.io.Cell
Deprecated. Create a new Cell with a given value and timestamp.
Cell(String[], long[]) - Constructor for class org.apache.hadoop.hbase.io.Cell
Deprecated.  
Cell(byte[][], long[]) - Constructor for class org.apache.hadoop.hbase.io.Cell
Deprecated.  
cellFromHBase(Cell) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
This utility method creates a list of Thrift TCell "struct" based on an Hbase Cell object.
cellFromHBase(Cell[]) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
This utility method creates a list of Thrift TCell "struct" based on an Hbase Cell array.
CellMessage - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
CellMessage.Cell - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
CellMessage.Cell.Builder - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
CellModel - Class in org.apache.hadoop.hbase.stargate.model
Representation of a cell.
CellModel() - Constructor for class org.apache.hadoop.hbase.stargate.model.CellModel
Default constructor
CellModel(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.stargate.model.CellModel
Constructor
CellModel(byte[], byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.stargate.model.CellModel
Constructor
CellModel(KeyValue) - Constructor for class org.apache.hadoop.hbase.stargate.model.CellModel
Constructor from KeyValue
CellModel(byte[], long, byte[]) - Constructor for class org.apache.hadoop.hbase.stargate.model.CellModel
Constructor
CellModel(byte[], byte[], long, byte[]) - Constructor for class org.apache.hadoop.hbase.stargate.model.CellModel
Constructor
CellSetMessage - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
CellSetMessage.CellSet - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
CellSetMessage.CellSet.Builder - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
CellSetMessage.CellSet.Row - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
CellSetMessage.CellSet.Row.Builder - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
CellSetModel - Class in org.apache.hadoop.hbase.stargate.model
Representation of a grouping of cells.
CellSetModel() - Constructor for class org.apache.hadoop.hbase.stargate.model.CellSetModel
Constructor
CellSetModel(List<RowModel>) - Constructor for class org.apache.hadoop.hbase.stargate.model.CellSetModel
 
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.
channelRead(ReadableByteChannel, ByteBuffer) - Static method in class org.apache.hadoop.hbase.ipc.HBaseServer
This is a wrapper around ReadableByteChannel.read(ByteBuffer).
channelWrite(WritableByteChannel, ByteBuffer) - Static method in class org.apache.hadoop.hbase.ipc.HBaseServer
This is a wrapper around WritableByteChannel.write(ByteBuffer).
checkAndPut(byte[], byte[], byte[], byte[], Put) - Method in class org.apache.hadoop.hbase.client.HTable
Atomically checks if a row/family/qualifier value match the expectedValue.
checkAndPut(byte[], byte[], byte[], byte[], byte[], Put) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
Atomically checks if a row/family/qualifier value match the expectedValue.
checkAndPut(byte[], byte[], byte[], byte[], Put, Integer, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
checkAndPut(byte[], byte[], byte[], byte[], byte[], Put) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
checkAndPut(byte[], byte[], byte[], byte[], Put) - Method in class org.apache.hadoop.hbase.stargate.client.RemoteHTable
 
checkAndSave(BatchUpdate, HbaseMapWritable<byte[], byte[]>, RowLock) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.checkAndPut(byte[], byte[], byte[], byte[], org.apache.hadoop.hbase.client.Put)
checkColumn(byte[], int, int) - Method in interface org.apache.hadoop.hbase.regionserver.ColumnTracker
Keeps track of the number of versions for the columns asked for
checkColumn(byte[], int, int) - Method in class org.apache.hadoop.hbase.regionserver.ExplicitColumnTracker
Checks against the parameters of the query and the columns which have already been processed by this query.
checkColumn(byte[], int, int) - Method in class org.apache.hadoop.hbase.regionserver.ScanWildcardColumnTracker
Can only return INCLUDE or SKIP, since returning "NEXT" or "DONE" would imply we have finished with this row, when this class can't figure that out.
checkColumn(byte[], int, int) - Method in class org.apache.hadoop.hbase.regionserver.WildcardColumnTracker
Checks against the parameters of the query and the columns which have already been processed by this query.
checkdir(FileSystem, Path) - Method in class org.apache.hadoop.hbase.util.FSUtils
Check if directory exists.
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.
checkOutOfSafeMode() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWrapper
Check if we're out of safe mode.
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat
Deprecated.  
checkOutputSpecs(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
Checks if the output target exists.
checkReadOnly() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
checkReferences() - Method in class org.apache.hadoop.hbase.util.SoftValueMap
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
 
CLASS_TO_CODE - Static variable in interface org.apache.hadoop.hbase.io.CodeToClassAndBack
Static map that contains mapping from class to code
classList - Static variable in interface org.apache.hadoop.hbase.io.CodeToClassAndBack
Class list for supported classes
ClassSize - Class in org.apache.hadoop.hbase.util
Class for determining the "size" of a class, an attempt to calculate the actual bytes that an object of this class will occupy in memory The core of this class is taken from the Derby project
ClassSize() - Constructor for class org.apache.hadoop.hbase.util.ClassSize
 
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.
cleanupJob(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
 
clear() - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
clear() - Method in class org.apache.hadoop.hbase.io.RowResult
Deprecated.  
clear() - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.HashFunction
Clears this hash function.
clear() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Clears all entries from the map.
clear() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell.Builder
 
clear() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Builder
 
clear() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
clear() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
clear() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
clear() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
clear() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
clear() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
clear() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
clear() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
clear() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
clear() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList.Builder
 
clear() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
clear() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
clear() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version.Builder
 
clear() - Method in class org.apache.hadoop.hbase.util.SoftValueMap
 
clear() - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
clearAttrs() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
clearAttrs() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
clearAverageLoad() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
clearBatch() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
clearColumn() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell.Builder
 
clearColumns() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
clearColumns() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
clearCompression() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
clearData() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell.Builder
 
clearDeadNodes() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
clearEndKey() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
clearEndRow() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
clearEndTime() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
clearFilter() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
clearHeapSizeMB() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
clearId() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
clearInMemory() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
clearJerseyVersion() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version.Builder
 
clearJvmVersion() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version.Builder
 
clearKey() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
clearLiveNodes() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
clearLocation() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
clearMaxHeapSizeMB() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
clearMaxVersions() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
clearMaxVersions() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
clearMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
clearName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
clearName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
clearName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
clearName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
clearName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
clearName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
clearName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList.Builder
 
clearName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
clearName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
clearOsVersion() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version.Builder
 
clearReadOnly() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
clearRegionCache() - Method in interface org.apache.hadoop.hbase.client.HConnection
Allows flushing the region cache.
clearRegions() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
clearRegions() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
clearRegions() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
clearRequests() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
clearRequests() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
clearRow() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell.Builder
 
clearRows() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Builder
 
clearRSDirectory() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWrapper
Method used to make sure the region server directory is empty.
clearServerVersion() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version.Builder
 
clearStargateVersion() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version.Builder
 
clearStartCode() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
clearStartKey() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
clearStartRow() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
clearStartTime() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
clearStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
clearStorefiles() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
clearStorefileSizeMB() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
clearStores() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
clearTimestamp() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell.Builder
 
clearTtl() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
clearValue() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
clearValue() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
clearValues() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
Client - Class in org.apache.hadoop.hbase.stargate.client
A wrapper around HttpClient which provides some useful function and semantics for interacting with the Stargate REST gateway.
Client() - Constructor for class org.apache.hadoop.hbase.stargate.client.Client
Default Constructor
Client(Cluster) - Constructor for class org.apache.hadoop.hbase.stargate.client.Client
Constructor
CLIENTS - Static variable in class org.apache.hadoop.hbase.ipc.HBaseRPC
 
clone() - Method in class org.apache.hadoop.hbase.KeyValue
Clones a KeyValue.
clone() - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
clone() - Method in class org.apache.hadoop.hbase.KeyValue.MetaComparator
 
clone() - Method in class org.apache.hadoop.hbase.KeyValue.RootComparator
 
clone() - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.BloomFilter
 
clone() - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.CountingBloomFilter
 
clone() - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.DynamicBloomFilter
 
clone() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell.Builder
 
clone() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Builder
 
clone() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
clone() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
clone() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
clone() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
clone() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
clone() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
clone() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
clone() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
clone() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
clone() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList.Builder
 
clone() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
clone() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
clone() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version.Builder
 
close() - Method in class org.apache.hadoop.hbase.client.HTable.ClientScanner
 
close() - Method in class org.apache.hadoop.hbase.client.HTable
Releases any resources help or pending changes in internal buffers.
close() - Method in class org.apache.hadoop.hbase.client.HTable.OldClientScanner
 
close() - Method in interface org.apache.hadoop.hbase.client.ResultScanner
Closes the scanner and releases any resources it has allocated
close() - Method in interface org.apache.hadoop.hbase.client.Scanner
Deprecated. Closes the scanner and releases any resources it has allocated
close() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
close() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.Writer
 
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
Deprecated.  
close() - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase.TableRecordReader
Deprecated.  
close(Reporter) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat.TableRecordWriter
Deprecated.  
close(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.IndexRecordWriter
Closes the writer.
close() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase.TableRecordReader
Closes the split.
close(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat.TableRecordWriter
Closes the writer, in this case flush table commits.
close() - Method in class org.apache.hadoop.hbase.migration.nineteen.io.BloomFilterMapFile.Writer
 
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(boolean) - 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.regionserver.KeyValueHeap
 
close() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
Close the KeyValue scanner.
close() - Method in class org.apache.hadoop.hbase.regionserver.MemStore.MemStoreScanner
 
close() - Method in class org.apache.hadoop.hbase.regionserver.MinorCompactingStoreScanner
 
close() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
close(boolean) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegion
 
close() - Method in class org.apache.hadoop.hbase.stargate.client.RemoteHTable
 
close() - Method in class org.apache.hadoop.hbase.stargate.ResultGenerator
 
close() - Method in class org.apache.hadoop.hbase.stargate.RowResultGenerator
 
close() - Method in class org.apache.hadoop.hbase.stargate.ScannerResultGenerator
 
close() - Method in class org.apache.hadoop.hbase.util.Base64.Base64OutputStream
Flushes and closes (I think, in the superclass) the stream.
close() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWrapper
Close this ZooKeeper session.
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
closeConnection(HBaseServer.Connection) - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
 
closeConnection(DistributedFileSystem) - Static method in class org.apache.hadoop.hbase.util.CompressionTest
 
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.
closeRegion(HRegionInfo, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
closeRegion(HRegionInfo, boolean) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegionServer
We want to delay the close region for a bit if we have commit pending transactions.
Cluster - Class in org.apache.hadoop.hbase.stargate.client
A list of 'host:port' addresses of HTTP servers operating as a single entity, for example multiple redundant web service gateways.
Cluster() - Constructor for class org.apache.hadoop.hbase.stargate.client.Cluster
Constructor
Cluster(List<String>) - Constructor for class org.apache.hadoop.hbase.stargate.client.Cluster
Constructor
CLUSTER_DISTRIBUTED - Static variable in interface org.apache.hadoop.hbase.HConstants
Cluster is in distributed mode or not
CLUSTER_IS_DISTRIBUTED - Static variable in interface org.apache.hadoop.hbase.HConstants
Cluster is fully-distributed
CLUSTER_IS_LOCAL - Static variable in interface org.apache.hadoop.hbase.HConstants
Cluster is standalone or pseudo-distributed
clusterStateZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWrapper
 
ClusterStatus - Class in org.apache.hadoop.hbase
Status information on the HBase cluster.
ClusterStatus() - Constructor for class org.apache.hadoop.hbase.ClusterStatus
Constructor, for Writable
CODE_TO_CLASS - Static variable in interface org.apache.hadoop.hbase.io.CodeToClassAndBack
Static map that contains mapping from code to class
CodeToClassAndBack - Interface in org.apache.hadoop.hbase.io
A Static Interface.
CodeToClassAndBack.InternalStaticLoader - Class in org.apache.hadoop.hbase.io
Class that loads the static maps with their values.
codeToType(byte) - Static method in enum org.apache.hadoop.hbase.KeyValue.Type
Cannot rely on enum ordinals .
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".
COLON - Static variable in class org.apache.hadoop.hbase.rest.AbstractModel
 
COLUMN - Static variable in interface org.apache.hadoop.hbase.rest.RESTConstants
 
COLUMN_FAMILY_DELIM_ARRAY - Static variable in class org.apache.hadoop.hbase.KeyValue
 
COLUMN_FAMILY_DELIMITER - Static variable in class org.apache.hadoop.hbase.HStoreKey
Deprecated. Colon character in UTF-8
COLUMN_FAMILY_DELIMITER - Static variable in class org.apache.hadoop.hbase.KeyValue
Colon character in UTF-8
COLUMN_FAMILY_DELIMITER - Static variable in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey
Colon character in UTF-8
COLUMN_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell
 
COLUMN_LIST - Static variable in class org.apache.hadoop.hbase.mapred.TableInputFormat
Deprecated. space delimited list of columns
COLUMN_NAME - Static variable in interface org.apache.hadoop.hbase.rest.filter.FilterFactoryConstants
 
ColumnCount - Class in org.apache.hadoop.hbase.regionserver
Simple wrapper for a byte buffer and a counter.
ColumnCount(byte[]) - Constructor for class org.apache.hadoop.hbase.regionserver.ColumnCount
Constructor
ColumnCount(byte[], int) - Constructor for class org.apache.hadoop.hbase.regionserver.ColumnCount
Constructor
ColumnCount(byte[], int, int, int) - Constructor for class org.apache.hadoop.hbase.regionserver.ColumnCount
Constuctor
ColumnCountGetFilter - Class in org.apache.hadoop.hbase.filter
Simple filter that returns first N columns on row only.
ColumnCountGetFilter() - Constructor for class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
Used during serialization.
ColumnCountGetFilter(int) - Constructor for class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
columnNameIterator() - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
Deprecated.  
columnNameIterator() - Method in class org.apache.hadoop.hbase.mapreduce.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.mapreduce.GroupingTableMapper
The grouping columns.
columns - Variable in class org.apache.hadoop.hbase.regionserver.QueryMatcher
Keeps track of columns and versions
columns - Variable in class org.apache.hadoop.hbase.regionserver.WildcardColumnTracker
 
COLUMNS - Static variable in interface org.apache.hadoop.hbase.rest.RESTConstants
 
COLUMNS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
COLUMNS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
ColumnSchemaMessage - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
ColumnSchemaMessage.ColumnSchema - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
ColumnSchemaMessage.ColumnSchema.Attribute - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
ColumnSchemaMessage.ColumnSchema.Attribute.Builder - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
ColumnSchemaMessage.ColumnSchema.Builder - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
ColumnSchemaModel - Class in org.apache.hadoop.hbase.stargate.model
Representation of a column family schema.
ColumnSchemaModel() - Constructor for class org.apache.hadoop.hbase.stargate.model.ColumnSchemaModel
Default constructor
ColumnTracker - Interface in org.apache.hadoop.hbase.regionserver
Implementing classes of this interface will be used for the tracking and enforcement of columns and numbers of versions during the course of a Get or Scan operation.
ColumnValueFilter - Class in org.apache.hadoop.hbase.filter
Deprecated. Use filters that are rooted on @{link Filter} instead.
ColumnValueFilter(byte[], ColumnValueFilter.CompareOp, byte[]) - Constructor for class org.apache.hadoop.hbase.filter.ColumnValueFilter
Deprecated. Constructor.
ColumnValueFilter(byte[], ColumnValueFilter.CompareOp, byte[], boolean) - Constructor for class org.apache.hadoop.hbase.filter.ColumnValueFilter
Deprecated. Constructor.
ColumnValueFilter(byte[], ColumnValueFilter.CompareOp, WritableByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.ColumnValueFilter
Deprecated. Constructor.
ColumnValueFilter(byte[], ColumnValueFilter.CompareOp, WritableByteArrayComparable, boolean) - Constructor for class org.apache.hadoop.hbase.filter.ColumnValueFilter
Deprecated. Constructor.
ColumnValueFilter.CompareOp - Enum in org.apache.hadoop.hbase.filter
Deprecated. Comparison operators.
ColumnValueFilterFactory - Class in org.apache.hadoop.hbase.rest.filter
FilterFactory that constructs a ColumnValueFilter from a JSON arg String.
ColumnValueFilterFactory() - Constructor for class org.apache.hadoop.hbase.rest.filter.ColumnValueFilterFactory
 
commit(BatchUpdate) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.delete(Delete) or HTable.put(Put)
commit(BatchUpdate, RowLock) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.delete(Delete) or HTable.put(Put)
commit(List<BatchUpdate>) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.delete(Delete) or HTable.put(List)
commit(Xid, boolean) - Method in class org.apache.hadoop.hbase.client.transactional.JtaXAResource
 
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
 
COMMIT_OK - Static variable in interface org.apache.hadoop.hbase.ipc.TransactionalRegionInterface
Status code representing a transaction that can be committed.
COMMIT_OK_READ_ONLY - Static variable in interface org.apache.hadoop.hbase.ipc.TransactionalRegionInterface
Status code representing a read-only transaction that can be committed.
COMMIT_UNSUCESSFUL - Static variable in interface org.apache.hadoop.hbase.ipc.TransactionalRegionInterface
Status code representing a transaction that cannot be committed.
commitIfPossible(byte[], long) - Method in interface org.apache.hadoop.hbase.ipc.TransactionalRegionInterface
Try to commit the given transaction.
commitIfPossible(long) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegion
 
commitIfPossible(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
 
commitTask(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
 
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.
compact(byte[]) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
compactionQueueSize - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
Size of the compaction queue.
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 - Variable in class org.apache.hadoop.hbase.filter.CompareFilter
 
comparator() - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
comparator() - Method in class org.apache.hadoop.hbase.io.RowResult
Deprecated.  
COMPARATOR - Static variable in class org.apache.hadoop.hbase.KeyValue
Comparator for plain key/values; i.e.
comparator() - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
compare(WritableComparable, WritableComparable) - Method in class org.apache.hadoop.hbase.HStoreKey.HStoreKeyComparator
Deprecated.  
compare(byte[], byte[]) - Method in class org.apache.hadoop.hbase.HStoreKey.StoreKeyComparator
Deprecated.  
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.HStoreKey.StoreKeyComparator
Deprecated.  
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable.Comparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KeyComparator
 
compare(byte[], byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.KeyComparator
 
compare(KeyValue, KeyValue) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
compare(KeyValue, KeyValue) - Method in class org.apache.hadoop.hbase.KeyValue.RowComparator
 
compare(WritableComparable, WritableComparable) - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey.HStoreKeyWritableComparator
 
compare(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.Bytes.ByteArrayComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.Bytes.ByteArrayComparator
 
COMPARE_OP - Static variable in interface org.apache.hadoop.hbase.rest.filter.FilterFactoryConstants
 
compareColumns(byte[], int, int, int, byte[], int, int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KeyComparator
 
compareColumns(KeyValue, byte[], int, int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
compareDeletes(GetDeleteTracker.Delete, GetDeleteTracker.Delete) - Method in class org.apache.hadoop.hbase.regionserver.GetDeleteTracker
 
CompareFilter - Class in org.apache.hadoop.hbase.filter
This is a generic filter to be used to filter by comparison.
CompareFilter() - Constructor for class org.apache.hadoop.hbase.filter.CompareFilter
Writable constructor, do not use.
CompareFilter(CompareFilter.CompareOp, WritableByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.CompareFilter
Constructor.
CompareFilter.CompareOp - Enum in org.apache.hadoop.hbase.filter
Comparison operators.
compareMetaRows(byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.HStoreKey
Deprecated.  
compareOp - Variable in class org.apache.hadoop.hbase.filter.CompareFilter
 
compareRootRows(byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.HStoreKey
Deprecated.  
compareRowid(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.MetaKeyComparator
 
compareRows(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.HStoreKey.HStoreKeyComparator
Deprecated.  
compareRows(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.HStoreKey.HStoreKeyMetaComparator
Deprecated.  
compareRows(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.HStoreKey.HStoreKeyRootComparator
Deprecated.  
compareRows(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.HStoreKey.MetaStoreKeyComparator
Deprecated.  
compareRows(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.HStoreKey.RootStoreKeyComparator
Deprecated.  
compareRows(byte[], byte[]) - Method in class org.apache.hadoop.hbase.HStoreKey.StoreKeyComparator
Deprecated.  
compareRows(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.HStoreKey.StoreKeyComparator
Deprecated.  
compareRows(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KeyComparator
 
compareRows(KeyValue, KeyValue) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
compareRows(KeyValue, short, KeyValue, short) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
compareRows(KeyValue, byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
compareRows(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
compareRows(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.MetaKeyComparator
 
compareRows(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.RootKeyComparator
 
compareTimestamps(KeyValue, KeyValue) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
compareTo(Row) - Method in class org.apache.hadoop.hbase.client.Delete
 
compareTo(Row) - Method in class org.apache.hadoop.hbase.client.Put
 
compareTo(byte[]) - Method in class org.apache.hadoop.hbase.filter.BinaryPrefixComparator
 
compareTo(byte[]) - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator
 
compareTo(byte[]) - Method in class org.apache.hadoop.hbase.filter.SubstringComparator
 
compareTo(byte[]) - Method in class org.apache.hadoop.hbase.filter.WritableByteArrayComparable
 
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
Deprecated. Use Comparators instead. This can give wrong results.
compareTo(HTableDescriptor) - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
compareTo(BatchUpdate) - Method in class org.apache.hadoop.hbase.io.BatchUpdate
Deprecated.  
compareTo(CachedBlock) - Method in class org.apache.hadoop.hbase.io.hfile.CachedBlock
 
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(RowResult) - Method in class org.apache.hadoop.hbase.io.RowResult
Deprecated. Comparing this RowResult with another one by comparing the row in it.
compareTo(TableSplit) - Method in class org.apache.hadoop.hbase.mapred.TableSplit
Deprecated.  
compareTo(TableSplit) - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Compares this split against the given one.
compareTo(MetaRegion) - Method in class org.apache.hadoop.hbase.master.MetaRegion
 
compareTo(HStoreKey) - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey.BeforeThisStoreKey
 
compareTo(HStoreKey) - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey
 
compareTo(Object) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.Key
 
compareTo(HLogKey) - 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.migration.nineteen.HStoreKey
Utility method to compare two row keys.
completeMemstoreInsert(ReadWriteConsistencyControl.WriteEntry) - Method in class org.apache.hadoop.hbase.regionserver.ReadWriteConsistencyControl
 
COMPRESSION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
Compression - Class in org.apache.hadoop.hbase.io.hfile
Compression related stuff.
Compression.Algorithm - Enum in org.apache.hadoop.hbase.io.hfile
Compression algorithms.
COMPRESSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
CompressionTest - Class in org.apache.hadoop.hbase.util
Compression validation test.
CompressionTest() - Constructor for class org.apache.hadoop.hbase.util.CompressionTest
 
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.
CONCURRENT_HASHMAP - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for ConcurrentHashMap
CONCURRENT_HASHMAP_ENTRY - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for ConcurrentHashMap.Entry
CONCURRENT_HASHMAP_SEGMENT - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for ConcurrentHashMap.Segment
CONCURRENT_SKIPLISTMAP - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for ConcurrentSkipListMap
CONCURRENT_SKIPLISTMAP_ENTRY - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for ConcurrentSkipListMap Entry
conf - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
 
conf - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
conf - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
conf - Variable in class org.apache.hadoop.hbase.rest.AbstractController
 
conf - Variable in class org.apache.hadoop.hbase.rest.AbstractModel
 
conf - Variable in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
Deprecated.  
configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.HRegionPartitioner
Deprecated.  
configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.IndexTableReduce
Deprecated.  
configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormat
Deprecated.  
connection - Variable in class org.apache.hadoop.hbase.client.ServerCallable
 
connectionList - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
connections - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
 
Constants - Interface in org.apache.hadoop.hbase.stargate
Common constants
containsColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
Checks for existence of the specified column.
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
Deprecated.  
containsKey(String) - Method in class org.apache.hadoop.hbase.io.RowResult
Deprecated. Check if the key can be found in this RowResult
containsKey(Object) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Checks whether there is a value in the map for the specified key.
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
Deprecated.  
containsValue(Object) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Checks whether this is a mapping which contains the specified value.
containsValue(Object) - Method in class org.apache.hadoop.hbase.util.SoftValueMap
 
containsValue(Object) - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
COPYONWRITE_ARRAYLIST - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for CopyOnWriteArrayList
COPYONWRITE_ARRAYSET - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for CopyOnWriteArraySet
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.
counter - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
 
CountingBloomFilter - Class in org.apache.hadoop.hbase.migration.nineteen.onelab.filter
Implements a counting Bloom filter, as defined by Fan et al.
CountingBloomFilter() - Constructor for class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.CountingBloomFilter
Default constructor - use with readFields
CountingBloomFilter(int, int, int) - Constructor for class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.CountingBloomFilter
Constructor
countRegionsOnFS() - Method in class org.apache.hadoop.hbase.master.HMaster
 
create(ByteBuffer) - Static method in class org.apache.hadoop.hbase.HStoreKey
Deprecated. Create a store key.
create(byte[]) - Static method in class org.apache.hadoop.hbase.HStoreKey
Deprecated. Create a store key.
create(byte[], int, int) - Static method in class org.apache.hadoop.hbase.HStoreKey
Deprecated. Create a store key.
create(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Create file.
createCells(List<KeyValue>) - Static method in class org.apache.hadoop.hbase.io.Cell
Deprecated.  
createCompressionStream(OutputStream, Compressor, int) - Method in enum org.apache.hadoop.hbase.io.hfile.Compression.Algorithm
 
createConfigurationSubset() - Method in class org.apache.hadoop.hbase.master.HMaster
 
createControllers() - Method in class org.apache.hadoop.hbase.rest.Dispatcher
Deprecated.  
createDecompressionStream(InputStream, Decompressor, int) - Method in enum org.apache.hadoop.hbase.io.hfile.Compression.Algorithm
 
createFirstOnRow(byte[]) - Static method in class org.apache.hadoop.hbase.KeyValue
Create a KeyValue that is smaller than all other possible KeyValues for the given row.
createFirstOnRow(byte[], long) - Static method in class org.apache.hadoop.hbase.KeyValue
Creates a KeyValue that is smaller than all other KeyValues that are older than the passed timestamp.
createFirstOnRow(byte[], byte[], long) - Static method in class org.apache.hadoop.hbase.KeyValue
Deprecated.  
createFirstOnRow(byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.KeyValue
Create a KeyValue for the specified row, family and qualifier that would be smaller than all other possible KeyValues that have the same row,family,qualifier.
createFirstOnRow(byte[], byte[], byte[], long) - Static method in class org.apache.hadoop.hbase.KeyValue
 
createGroupKey(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
Deprecated. Create a key by concatenating multiple column values.
createGroupKey(byte[][]) - Method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
Create a key by concatenating multiple column values.
createHRegion(HRegionInfo, Path, HBaseConfiguration) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Convenience method creating new HRegions.
createIndexedTable(IndexedTableDescriptor) - Method in class org.apache.hadoop.hbase.client.tableindexed.IndexedTableAdmin
Creates a new indexed table
createIndexKey(byte[], Map<byte[], byte[]>) - Method in interface org.apache.hadoop.hbase.client.tableindexed.IndexKeyGenerator
Create an index key from a base row.
createIndexKey(byte[], Map<byte[], byte[]>) - Method in class org.apache.hadoop.hbase.client.tableindexed.SimpleIndexKeyGenerator
Create an index key from a base row.
createIndexUpdate(IndexSpecification, byte[], SortedMap<byte[], byte[]>) - Static method in class org.apache.hadoop.hbase.regionserver.tableindexed.IndexMaintenanceUtils
 
createJob(Configuration, int, int, String, String, String) - Method in class org.apache.hadoop.hbase.mapred.BuildTableIndex
Deprecated.  
createKey() - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase.TableRecordReader
Deprecated.  
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.
createKeyValueFromKey(byte[], int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
 
createLastOnRow(byte[]) - Static method in class org.apache.hadoop.hbase.KeyValue
Creates a KeyValue that is last on the specified row id.
createLease(String, LeaseListener) - Method in class org.apache.hadoop.hbase.Leases
Obtain a lease
createNewTransactionLog() - Method in class org.apache.hadoop.hbase.client.transactional.HBaseBackedTransactionLogger
 
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.
createProtobufOutput() - Method in class org.apache.hadoop.hbase.stargate.model.CellModel
 
createProtobufOutput() - Method in class org.apache.hadoop.hbase.stargate.model.CellSetModel
 
createProtobufOutput() - Method in class org.apache.hadoop.hbase.stargate.model.RowModel
 
createProtobufOutput() - Method in class org.apache.hadoop.hbase.stargate.model.ScannerModel
 
createProtobufOutput() - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel
 
createProtobufOutput() - Method in class org.apache.hadoop.hbase.stargate.model.TableInfoModel
 
createProtobufOutput() - Method in class org.apache.hadoop.hbase.stargate.model.TableListModel
 
createProtobufOutput() - Method in class org.apache.hadoop.hbase.stargate.model.TableSchemaModel
 
createProtobufOutput() - Method in class org.apache.hadoop.hbase.stargate.model.VersionModel
 
createProtobufOutput() - Method in interface org.apache.hadoop.hbase.stargate.ProtobufMessageHandler
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Builds a TableRecordReader.
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.
createRowResult(List<KeyValue>) - Static method in class org.apache.hadoop.hbase.io.RowResult
Deprecated.  
createRowResultArray(List<List<KeyValue>>) - Static method in class org.apache.hadoop.hbase.io.RowResult
Deprecated.  
createScanner(ScannerModel, byte[], ScannerDescriptor) - Method in class org.apache.hadoop.hbase.rest.ScannerController
 
createSingleCellArray(List<KeyValue>) - Static method in class org.apache.hadoop.hbase.io.Cell
Deprecated.  
createStatus(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.rest.Dispatcher
Deprecated.  
createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.mapred.RowCounter
Deprecated.  
createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.BuildTableIndex
Creates a new job.
createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.Export
Sets up the actual job.
createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
Sets up the actual job.
createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.RowCounter
Sets up the actual job.
createTable(HTableDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Creates a new table.
createTable() - Static method in class org.apache.hadoop.hbase.client.transactional.HBaseBackedTransactionLogger
Create the 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(HTableDescriptor) - Method in class org.apache.hadoop.hbase.stargate.client.RemoteAdmin
Creates a new table.
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
Deprecated.  
createWriter(Path) - Method in class org.apache.hadoop.hbase.regionserver.HLog
 
createWriter(Path, Class<? extends HLogKey>, Class<? extends KeyValue>) - Method in class org.apache.hadoop.hbase.regionserver.HLog
 
CurCall - Static variable in class org.apache.hadoop.hbase.ipc.HBaseServer
This is set to Call object before Handler invokes an RPC and reset after the call returns.
CURRENT_VERSION - Static variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 

D

DATA_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell
 
DatabaseController - Class in org.apache.hadoop.hbase.rest
 
DatabaseController() - Constructor for class org.apache.hadoop.hbase.rest.DatabaseController
 
DatabaseModel - Class in org.apache.hadoop.hbase.rest
 
DatabaseModel(HBaseConfiguration, HBaseAdmin) - Constructor for class org.apache.hadoop.hbase.rest.DatabaseModel
 
DatabaseModel.DatabaseMetadata - Class in org.apache.hadoop.hbase.rest
 
DatabaseModel.DatabaseMetadata(HBaseAdmin) - Constructor for class org.apache.hadoop.hbase.rest.DatabaseModel.DatabaseMetadata
 
dbController - Variable in class org.apache.hadoop.hbase.rest.Dispatcher
Deprecated.  
DEADNODES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
DebugPrint - Class in org.apache.hadoop.hbase.regionserver
 
DebugPrint() - Constructor for class org.apache.hadoop.hbase.regionserver.DebugPrint
 
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.
decrement() - Method in class org.apache.hadoop.hbase.regionserver.ColumnCount
Decrement the current version count
DEEP_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
 
DEEP_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.MemStore
 
DEEP_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.Store
 
DEFAULT_BLOCKCACHE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default setting for whether to use a block cache or not.
DEFAULT_BLOCKSIZE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default size of blocks in files store to the filesytem.
DEFAULT_BLOCKSIZE - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
Default blocksize for hfile.
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_COMPRESSION - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
Default compression name: none.
DEFAULT_COMPRESSION_ALGORITHM - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
Default compression: none.
DEFAULT_END_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.stargate.RowSpec
 
DEFAULT_HBASE_CLIENT_SCANNER_MAX_RESULT_SIZE - Static variable in interface org.apache.hadoop.hbase.HConstants
Maximum number of bytes returned when calling a scanner's next method.
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_KEYVALUE_SEPARATOR - Static variable in class org.apache.hadoop.hbase.util.Strings
 
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_AGE - Static variable in interface org.apache.hadoop.hbase.stargate.Constants
 
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_MEMSTORE_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_INFOPORT - Static variable in interface org.apache.hadoop.hbase.HConstants
default port for region server web api
DEFAULT_REGIONSERVER_PORT - Static variable in interface org.apache.hadoop.hbase.HConstants
Default port region server listens on.
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_START_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.stargate.RowSpec
 
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.
DEFAULT_ZOOKEEPER_PAUSE - Static variable in interface org.apache.hadoop.hbase.HConstants
Default ZooKeeper pause value.
DEFAULT_ZOOKEEPER_RETRIES - Static variable in interface org.apache.hadoop.hbase.HConstants
Default number of times to retry writes to ZooKeeper.
Delete - Class in org.apache.hadoop.hbase.client
Used to perform Delete operations on a single row.
Delete() - Constructor for class org.apache.hadoop.hbase.client.Delete
Constructor for Writable.
Delete(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Delete
Create a Delete operation for the specified row.
Delete(byte[], long, RowLock) - Constructor for class org.apache.hadoop.hbase.client.Delete
Create a Delete operation for the specified row and timestamp, using an optional row lock.
Delete(Delete) - Constructor for class org.apache.hadoop.hbase.client.Delete
 
delete(Delete) - Method in class org.apache.hadoop.hbase.client.HTable
Deletes the specified cells/row.
delete(ArrayList<Delete>) - Method in class org.apache.hadoop.hbase.client.HTable
Deletes the specified cells/rows in bulk.
delete(TransactionState, Delete) - Method in class org.apache.hadoop.hbase.client.transactional.TransactionalTable
 
delete(String) - Method in class org.apache.hadoop.hbase.io.BatchUpdate
Deprecated. 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
Deprecated. Delete the value for a column Deletes the cell whose row/column/commit-timestamp match those of the delete.
delete(byte[], Delete) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
Deletes all the KeyValues that match those found in the Delete object, if their ts <= to the Delete.
delete(byte[], Delete[]) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
Put an array of deletes into the specified region
delete(long, byte[], Delete) - Method in interface org.apache.hadoop.hbase.ipc.TransactionalRegionInterface
Deletes all the KeyValues that match those found in the Delete object, if their ts <= to the Delete.
delete(Key) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.CountingBloomFilter
Removes a specified key from this counting Bloom filter.
delete() - Method in class org.apache.hadoop.hbase.migration.nineteen.regionserver.HStoreFile
Delete store map files.
delete(Delete, Integer, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
delete(Map<byte[], List<KeyValue>>, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
delete(byte[], Delete) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
delete(byte[], Delete[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
delete(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.Store
Adds a value to the memstore
delete() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
Delete this file
delete(long, Delete) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegion
Add a delete to the transaction.
delete(long, byte[], Delete) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegionServer
 
delete(Status, byte[][], Map<String, String[]>) - Method in class org.apache.hadoop.hbase.rest.AbstractController
 
delete(Status, byte[][], Map<String, String[]>) - Method in class org.apache.hadoop.hbase.rest.DatabaseController
 
delete(Status, byte[][], Map<String, String[]>) - Method in class org.apache.hadoop.hbase.rest.RowController
 
delete(byte[], byte[]) - Method in class org.apache.hadoop.hbase.rest.RowModel
Deprecated. 
delete(byte[], byte[], byte[][]) - Method in class org.apache.hadoop.hbase.rest.RowModel
Deprecated. 
delete(byte[], Delete) - Method in class org.apache.hadoop.hbase.rest.RowModel
 
delete(Status, byte[][], Map<String, String[]>) - Method in class org.apache.hadoop.hbase.rest.ScannerController
 
delete(Status, byte[][], Map<String, String[]>) - Method in class org.apache.hadoop.hbase.rest.TableController
 
delete(byte[]) - Method in class org.apache.hadoop.hbase.rest.TableModel
Deletes table tableName
delete(Status, byte[][], Map<String, String[]>) - Method in class org.apache.hadoop.hbase.rest.TimestampController
 
delete(byte[], Delete) - Method in class org.apache.hadoop.hbase.rest.TimestampModel
 
delete(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.rest.TimestampModel
Deprecated. 
delete(byte[], byte[], byte[][], long) - Method in class org.apache.hadoop.hbase.rest.TimestampModel
Deprecated. 
delete(String) - Method in class org.apache.hadoop.hbase.stargate.client.Client
Send a DELETE request
delete(Cluster, String) - Method in class org.apache.hadoop.hbase.stargate.client.Client
Send a DELETE request
delete(Delete) - Method in class org.apache.hadoop.hbase.stargate.client.RemoteHTable
 
delete(List<Delete>) - Method in class org.apache.hadoop.hbase.stargate.client.RemoteHTable
 
delete(UriInfo) - Method in class org.apache.hadoop.hbase.stargate.RowResource
 
delete(UriInfo) - Method in class org.apache.hadoop.hbase.stargate.ScannerInstanceResource
 
delete(UriInfo) - Method in class org.apache.hadoop.hbase.stargate.SchemaResource
 
deleteAll(byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.delete(Delete)
deleteAll(String) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.delete(Delete)
deleteAll(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.delete(Delete)
deleteAll(byte[], long) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.delete(Delete)
deleteAll(String, long) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.delete(Delete)
deleteAll(String, String) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.delete(Delete)
deleteAll(String, String, long) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.delete(Delete)
deleteAll(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.delete(Delete)
deleteAll(byte[], byte[], long, RowLock) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.delete(Delete)
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
Deprecated. As of hbase 0.20.0, replaced by HTable.delete(Delete)
deleteAllByRegex(String, String, long) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.delete(Delete)
deleteAllByRegex(byte[], String, long) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.delete(Delete)
deleteAllByRegex(byte[], String, long, RowLock) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.delete(Delete)
deleteAllConnections(boolean) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Delete information for all connections.
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.ThriftServer.HBaseHandler
 
deleteAllTs(byte[], byte[], byte[], long) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
deleteColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
Delete the latest version of the specified column.
deleteColumn(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
Delete the specified version of the specified column.
deleteColumn(byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
Delete the latest version of the specified column, given in family:qualifier notation.
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.
deleteColumns(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
Delete all versions of the specified column.
deleteColumns(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
Delete all versions of the specified column with a timestamp less than or equal to the specified timestamp.
deleteColumns(byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
Delete all versions of the specified column, given in family:qualifier notation, and with a timestamp less than or equal to the specified timestamp.
deleteColumns(byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
 
DeleteCompare - Class in org.apache.hadoop.hbase.regionserver
Class that provides static method needed when putting deletes into memstore
DeleteCompare() - Constructor for class org.apache.hadoop.hbase.regionserver.DeleteCompare
 
deleteCompare(KeyValue, byte[], int, short, int, int, int, byte, KeyValue.KeyComparator) - Static method in class org.apache.hadoop.hbase.regionserver.DeleteCompare
Method used when putting deletes into memstore to remove all the previous entries that are affected by this Delete
deleteConnectionInfo(HBaseConfiguration, boolean) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Delete connection information for the instance specified by configuration
deleteDirectory(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Delete if exists.
deleteEmptyMetaRows(HRegionInterface, byte[], List<byte[]>) - Method in class org.apache.hadoop.hbase.master.HMaster
 
deleteFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
Delete all versions of all columns of the specified family.
deleteFamily(byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
Delete all columns of the specified family with a timestamp less than or equal to the specified timestamp.
deleteFamily(String, String) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.delete(Delete)
deleteFamily(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.delete(Delete)
deleteFamily(String, String, long) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.delete(Delete)
deleteFamily(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.delete(Delete)
deleteFamily(byte[], byte[], long, RowLock) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.delete(Delete)
deleteFamilyByRegex(String, String) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.delete(Delete)
deleteFamilyByRegex(byte[], String) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.delete(Delete)
deleteFamilyByRegex(String, String, long) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.delete(Delete)
deleteFamilyByRegex(byte[], String, long) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.delete(Delete)
deleteFamilyByRegex(byte[], String, long, RowLock) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.delete(Delete)
deleteRegion(FileSystem, Path, HRegionInfo) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Deletes all the files for a HRegion
deleteRootRegionLocation() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWrapper
Delete ZNode containing root region location.
deletes - Variable in class org.apache.hadoop.hbase.regionserver.GetDeleteTracker
 
deletes - Variable in class org.apache.hadoop.hbase.regionserver.QueryMatcher
Keeps track of deletes
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(String) - Method in class org.apache.hadoop.hbase.stargate.client.RemoteAdmin
Deletes a table.
deleteTable(byte[]) - Method in class org.apache.hadoop.hbase.stargate.client.RemoteAdmin
Deletes a table.
deleteTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
DeleteTracker - Interface in org.apache.hadoop.hbase.regionserver
This interface is used for the tracking and enforcement of Deletes during the course of a Get or Scan operation.
DeleteTracker.DeleteCompare - Enum in org.apache.hadoop.hbase.regionserver
Return codes for comparison of two Deletes.
DELIMITER - Static variable in class org.apache.hadoop.hbase.HRegionInfo
delimiter used between portions of a region name
description - Variable in class org.apache.hadoop.hbase.metrics.MetricsMBeanBase
 
disable() - Static method in class org.apache.hadoop.hbase.regionserver.DebugPrint
 
DISABLE - Static variable in interface org.apache.hadoop.hbase.rest.RESTConstants
 
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.rest.TableModel
 
disableTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
Dispatcher - Class in org.apache.hadoop.hbase.rest
Deprecated. Use the org.apache.hadoop.hbase.stargate hbase contrib instead.
Dispatcher() - Constructor for class org.apache.hadoop.hbase.rest.Dispatcher
Deprecated. Default constructor
Dispatcher.ContentType - Enum in org.apache.hadoop.hbase.rest
Deprecated.  
doc - Variable in class org.apache.hadoop.hbase.mapred.LuceneDocumentWrapper
Deprecated.  
doc - Variable in class org.apache.hadoop.hbase.mapreduce.LuceneDocumentWrapper
The document to add to the index.
doCommit(TransactionState) - Method in class org.apache.hadoop.hbase.client.transactional.TransactionManager
Do the commit.
doCompare(CompareFilter.CompareOp, WritableByteArrayComparable, byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
doDelete(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.rest.Dispatcher
Deprecated.  
doesApplyToIndex(IndexSpecification, SortedMap<byte[], byte[]>) - Static method in class org.apache.hadoop.hbase.regionserver.tableindexed.IndexMaintenanceUtils
Ask if this update does apply to the index.
doesTableExist(byte[]) - Method in class org.apache.hadoop.hbase.rest.TableModel
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.rest.Dispatcher
Deprecated.  
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
Deprecated.  
doMain(String[]) - Static method in class org.apache.hadoop.hbase.thrift.ThriftServer
 
doMetrics() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
done() - Method in interface org.apache.hadoop.hbase.regionserver.ColumnTracker
 
done() - Method in class org.apache.hadoop.hbase.regionserver.ExplicitColumnTracker
Done when there are no more columns to match against.
done() - Method in class org.apache.hadoop.hbase.regionserver.ScanWildcardColumnTracker
We can never know a-priori if we are done, so always return false.
done() - Method in class org.apache.hadoop.hbase.regionserver.WildcardColumnTracker
Can never early-out from reading more storefiles in Wildcard case.
DoNotRetryIOException - Exception in org.apache.hadoop.hbase
Subclass if exception is not meant to be retried: e.g.
DoNotRetryIOException() - Constructor for exception org.apache.hadoop.hbase.DoNotRetryIOException
default constructor
DoNotRetryIOException(String) - Constructor for exception org.apache.hadoop.hbase.DoNotRetryIOException
 
DoNotRetryIOException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.DoNotRetryIOException
 
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
Deprecated.  
doOptimize() - Method in class org.apache.hadoop.hbase.mapreduce.IndexConfiguration
 
doPost(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.rest.Dispatcher
Deprecated.  
doPut(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.rest.Dispatcher
Deprecated.  
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
 
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.
doUpdates(MetricsContext) - Method in class org.apache.hadoop.hbase.stargate.metrics.StargateMetrics
Since this object is a registered updater, this method will be called periodically, e.g.
Driver - Class in org.apache.hadoop.hbase.mapred
Deprecated. 
Driver() - Constructor for class org.apache.hadoop.hbase.mapred.Driver
Deprecated.  
Driver - Class in org.apache.hadoop.hbase.mapreduce
Driver for hbase mapreduce jobs.
Driver() - Constructor for class org.apache.hadoop.hbase.mapreduce.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
dump() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWrapper
 
dumps - Variable in class org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
 
dumpToFile(String) - Static method in class org.apache.hadoop.hbase.regionserver.DebugPrint
 
DynamicBloomFilter - Class in org.apache.hadoop.hbase.migration.nineteen.onelab.filter
Implements a dynamic Bloom filter, as defined in the INFOCOM 2006 paper.
DynamicBloomFilter() - Constructor for class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.DynamicBloomFilter
Zero-args constructor for the serialization.
DynamicBloomFilter(int, int, int, int) - Constructor for class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.DynamicBloomFilter
Constructor.

E

EBase64 - Static variable in class org.apache.hadoop.hbase.rest.AbstractModel.Encodings
 
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_HEADER_ARRAY - Static variable in class org.apache.hadoop.hbase.stargate.client.Client
 
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 method in class org.apache.hadoop.hbase.regionserver.DebugPrint
 
ENABLE - Static variable in interface org.apache.hadoop.hbase.rest.RESTConstants
 
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.rest.TableModel
 
enableTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
encode(byte[]) - Method in interface org.apache.hadoop.hbase.rest.AbstractModel.Encodings.Encoding
 
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.
encoding - Static variable in class org.apache.hadoop.hbase.rest.AbstractModel
 
end(Xid, int) - Method in class org.apache.hadoop.hbase.client.transactional.JtaXAResource
 
ENDKEY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
ENDROW_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
ENDTIME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
entryLruList() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Debugging function that returns a List sorted by access time.
entrySet() - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
entrySet() - Method in class org.apache.hadoop.hbase.io.RowResult
Deprecated.  
entrySet() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Intentionally unimplemented.
entrySet() - Method in class org.apache.hadoop.hbase.util.SoftValueMap
 
entrySet() - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
entryTableSet() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Debugging function that returns a Set of all entries in the hash table.
equals(Object) - Method in class org.apache.hadoop.hbase.ClusterStatus
 
equals(Object) - Method in class org.apache.hadoop.hbase.HBaseConfiguration
 
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
Deprecated.  
equals(Object) - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
equals(Object) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
equals(Object) - Method in class org.apache.hadoop.hbase.KeyValue
 
equals(Object) - Method in class org.apache.hadoop.hbase.master.MetaRegion
 
equals(Object) - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey.BeforeThisStoreKey
 
equals(Object) - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey
 
equals(Object) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.Key
 
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 class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
Returns true is the specified entry has the same key and the same value as this entry.
equals(Object) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Intentionally unimplemented.
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(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.HStoreKey
Deprecated. Utility method to check if two row keys are equal.
equalsTwoRowKeys(HRegionInfo, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey
Utility method to check if two row keys are equal.
errorHandler - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
estimateBase(Class, boolean) - Static method in class org.apache.hadoop.hbase.util.ClassSize
Estimate the static space taken up by the fields of a class.
ESTIMATED_HEAP_TAX - Static variable in class org.apache.hadoop.hbase.HStoreKey
Deprecated. Estimated size tax paid for each instance of HSK.
ESTIMATED_HEAP_TAX - Variable in class org.apache.hadoop.hbase.io.BatchOperation
Deprecated. Estimated size of this object.
ESTIMATED_HEAP_TAX - Static variable in class org.apache.hadoop.hbase.io.BatchUpdate
Deprecated. Estimated 'shallow size' of this object not counting payload.
ESTIMATED_HEAP_TAX - Static variable in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey
Estimated size tax paid for each instance of HSK.
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 [].
EUTF8 - Static variable in class org.apache.hadoop.hbase.rest.AbstractModel.Encodings
 
evict() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache.CacheStats
 
evictBlock(CachedBlock) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
evicted() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache.CacheStats
 
evictedPerEviction() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache.CacheStats
 
execute(Cluster, HttpMethod, Header[], String) - Method in class org.apache.hadoop.hbase.stargate.client.Client
Execute a transaction method.
executePathOnly(Cluster, HttpMethod, Header[], String) - Method in class org.apache.hadoop.hbase.stargate.client.Client
Execute a transaction method given only the path.
executeURI(HttpMethod, Header[], String) - Method in class org.apache.hadoop.hbase.stargate.client.Client
Execute a transaction method given a complete URI.
exists(Get) - Method in class org.apache.hadoop.hbase.client.HTable
Test for the existence of columns in the table, as specified in the Get.
exists(byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.exists(Get)
exists(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.exists(Get)
exists(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.exists(Get)
exists(byte[], byte[], long, RowLock) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.exists(Get)
exists(byte[], Get) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
Perform exists operation.
exists(byte[], Get) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
EXISTS - Static variable in interface org.apache.hadoop.hbase.rest.RESTConstants
 
exists(Get) - Method in class org.apache.hadoop.hbase.stargate.client.RemoteHTable
 
ExistsResource - Class in org.apache.hadoop.hbase.stargate
 
ExistsResource(String) - Constructor for class org.apache.hadoop.hbase.stargate.ExistsResource
Constructor
ExplicitColumnTracker - Class in org.apache.hadoop.hbase.regionserver
This class is used for the tracking and enforcement of columns and numbers of versions during the course of a Get or Scan operation, when explicit column qualifiers have been asked for in the query.
ExplicitColumnTracker(NavigableSet<byte[]>, int) - Constructor for class org.apache.hadoop.hbase.regionserver.ExplicitColumnTracker
Default constructor.
Export - Class in org.apache.hadoop.hbase.mapreduce
Export an HBase table.
Export() - Constructor for class org.apache.hadoop.hbase.mapreduce.Export
 
extendedAttributes - Variable in class org.apache.hadoop.hbase.metrics.MetricsMBeanBase
HBase MetricsBase implementations that MetricsDynamicMBeanBase does not understand
extendedInfo - Variable in class org.apache.hadoop.hbase.metrics.MetricsMBeanBase
 
extractKeyValues(RowResult) - Method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
Deprecated. Extract columns values from the current record.
extractKeyValues(Result) - Method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
Extract columns values from the current record.

F

failureSleep - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
 
FALSE - Static variable in interface org.apache.hadoop.hbase.rest.RESTConstants
 
FAMILIES - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
families - Variable in class org.apache.hadoop.hbase.HTableDescriptor
 
FAMILIES_KEY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
familySet() - Method in class org.apache.hadoop.hbase.client.Get
Method for retrieving the keys in the familyMap
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 - Interface in org.apache.hadoop.hbase.filter
Interface for row and column filters directly applied within the regionserver.
Filter - Class in org.apache.hadoop.hbase.migration.nineteen.onelab.filter
Defines the general behavior of a filter.
Filter() - Constructor for class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.Filter
 
Filter(int, int, int) - Constructor for class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.Filter
Constructor.
filter - Variable in class org.apache.hadoop.hbase.regionserver.QueryMatcher
 
FILTER - Static variable in interface org.apache.hadoop.hbase.rest.RESTConstants
 
Filter.ReturnCode - Enum in org.apache.hadoop.hbase.filter
Return codes for filterValue().
FILTER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
FILTER_RANK - Static variable in interface org.apache.hadoop.hbase.rest.RESTConstants
 
FILTER_TYPE - Static variable in interface org.apache.hadoop.hbase.rest.RESTConstants
 
FILTER_VALUE - Static variable in interface org.apache.hadoop.hbase.rest.RESTConstants
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
Deprecated.  
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
filterAllRemaining() - Method in interface org.apache.hadoop.hbase.filter.Filter
If this returns true, the scan will terminate.
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.FilterList
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.PageRowFilter
Deprecated.  
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.PrefixRowFilter
Deprecated.  
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.RegExpRowFilter
Deprecated.  
filterAllRemaining() - Method in interface org.apache.hadoop.hbase.filter.RowFilterInterface
Deprecated. Determines if the filter has decided that all remaining results should be filtered (skipped).
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.RowFilterSet
Deprecated.  
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.StopRowFilter
Deprecated.  
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.WhileMatchRowFilter
Deprecated. 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
Deprecated.  
filterColumn(byte[], int, int, byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
Deprecated.  
filterColumn(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.filter.PageRowFilter
Deprecated.  
filterColumn(byte[], int, int, byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.PageRowFilter
Deprecated.  
filterColumn(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.filter.PrefixRowFilter
Deprecated.  
filterColumn(byte[], int, int, byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.PrefixRowFilter
Deprecated.  
filterColumn(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.filter.RegExpRowFilter
Deprecated.  
filterColumn(byte[], int, int, byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.RegExpRowFilter
Deprecated.  
filterColumn(byte[], byte[], byte[]) - Method in interface org.apache.hadoop.hbase.filter.RowFilterInterface
Deprecated. Use RowFilterInterface.filterColumn(byte[], int, int, byte[], int, int, byte[], int, int) instead.
filterColumn(byte[], int, int, byte[], int, int, byte[], int, int) - Method in interface org.apache.hadoop.hbase.filter.RowFilterInterface
Deprecated. Filters on row key, column name, and column value.
filterColumn(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.filter.RowFilterSet
Deprecated.  
filterColumn(byte[], int, int, byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.RowFilterSet
Deprecated.  
filterColumn(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.filter.StopRowFilter
Deprecated. Because StopRowFilter does not examine column information, this method defaults to calling the rowKey-only version of filter.
filterColumn(byte[], int, int, byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.StopRowFilter
Deprecated.  
filterColumn(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.filter.WhileMatchRowFilter
Deprecated.  
filterColumn(byte[], int, int, byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.WhileMatchRowFilter
Deprecated.  
filterFactories - Static variable in interface org.apache.hadoop.hbase.rest.RESTConstants
 
FilterFactory - Interface in org.apache.hadoop.hbase.rest.filter
Constructs Filters from JSON.
FilterFactoryConstants - Interface in org.apache.hadoop.hbase.rest.filter
 
FilterFactoryConstants.MalformedFilterException - Exception in org.apache.hadoop.hbase.rest.filter
 
FilterFactoryConstants.MalformedFilterException() - Constructor for exception org.apache.hadoop.hbase.rest.filter.FilterFactoryConstants.MalformedFilterException
 
filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
filterKeyValue(KeyValue) - Method in interface org.apache.hadoop.hbase.filter.Filter
A way to filter based on the column family, column qualifier and/or the column value.
filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.QualifierFilter
 
filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.RowFilter
 
filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.ValueFilter
 
filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
FilterList - Class in org.apache.hadoop.hbase.filter
Implementation of Filter that represents an ordered List of Filters which will be evaluated with a specified boolean operator FilterList.Operator.MUST_PASS_ALL (!AND) or FilterList.Operator.MUST_PASS_ONE (!OR).
FilterList() - Constructor for class org.apache.hadoop.hbase.filter.FilterList
Default constructor, filters nothing.
FilterList(List<Filter>) - Constructor for class org.apache.hadoop.hbase.filter.FilterList
Constructor that takes a set of Filters.
FilterList(FilterList.Operator) - Constructor for class org.apache.hadoop.hbase.filter.FilterList
Constructor that takes an operator.
FilterList(FilterList.Operator, List<Filter>) - Constructor for class org.apache.hadoop.hbase.filter.FilterList
Constructor that takes a set of Filters and an operator.
FilterList.Operator - Enum in org.apache.hadoop.hbase.filter
set operator
filterRow() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
filterRow(SortedMap<byte[], Cell>) - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
Deprecated.  
filterRow(List<KeyValue>) - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
Deprecated.  
filterRow() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
filterRow() - Method in interface org.apache.hadoop.hbase.filter.Filter
Last chance to veto row based on previous Filter.filterKeyValue(KeyValue) calls.
filterRow() - Method in class org.apache.hadoop.hbase.filter.FilterList
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
filterRow(SortedMap<byte[], Cell>) - Method in class org.apache.hadoop.hbase.filter.PageRowFilter
Deprecated.  
filterRow(List<KeyValue>) - Method in class org.apache.hadoop.hbase.filter.PageRowFilter
Deprecated.  
filterRow() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
filterRow(SortedMap<byte[], Cell>) - Method in class org.apache.hadoop.hbase.filter.PrefixRowFilter
Deprecated.  
filterRow(List<KeyValue>) - Method in class org.apache.hadoop.hbase.filter.PrefixRowFilter
Deprecated.  
filterRow(SortedMap<byte[], Cell>) - Method in class org.apache.hadoop.hbase.filter.RegExpRowFilter
Deprecated.  
filterRow(List<KeyValue>) - Method in class org.apache.hadoop.hbase.filter.RegExpRowFilter
Deprecated.  
filterRow() - Method in class org.apache.hadoop.hbase.filter.RowFilter
 
filterRow(SortedMap<byte[], Cell>) - Method in interface org.apache.hadoop.hbase.filter.RowFilterInterface
Deprecated. Filter on the fully assembled row.
filterRow(List<KeyValue>) - Method in interface org.apache.hadoop.hbase.filter.RowFilterInterface
Deprecated. Filter on the fully assembled row.
filterRow(SortedMap<byte[], Cell>) - Method in class org.apache.hadoop.hbase.filter.RowFilterSet
Deprecated.  
filterRow(List<KeyValue>) - Method in class org.apache.hadoop.hbase.filter.RowFilterSet
Deprecated.  
filterRow() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
filterRow(SortedMap<byte[], Cell>) - Method in class org.apache.hadoop.hbase.filter.StopRowFilter
Deprecated. Because StopRowFilter does not examine column information, this method defaults to calling filterAllRemaining().
filterRow(List<KeyValue>) - Method in class org.apache.hadoop.hbase.filter.StopRowFilter
Deprecated.  
filterRow() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
filterRow(SortedMap<byte[], Cell>) - Method in class org.apache.hadoop.hbase.filter.WhileMatchRowFilter
Deprecated.  
filterRow(List<KeyValue>) - Method in class org.apache.hadoop.hbase.filter.WhileMatchRowFilter
Deprecated.  
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
filterRowKey(byte[]) - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
Deprecated.  
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
Deprecated.  
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
filterRowKey(byte[], int, int) - Method in interface org.apache.hadoop.hbase.filter.Filter
Filters a row based on the row key.
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
filterRowKey(byte[]) - Method in class org.apache.hadoop.hbase.filter.InclusiveStopRowFilter
Deprecated.  
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.InclusiveStopRowFilter
Deprecated.  
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
filterRowKey(byte[]) - Method in class org.apache.hadoop.hbase.filter.PageRowFilter
Deprecated.  
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.PageRowFilter
Deprecated.  
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
filterRowKey(byte[]) - Method in class org.apache.hadoop.hbase.filter.PrefixRowFilter
Deprecated.  
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.PrefixRowFilter
Deprecated.  
filterRowKey(byte[]) - Method in class org.apache.hadoop.hbase.filter.RegExpRowFilter
Deprecated.  
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.RegExpRowFilter
Deprecated.  
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.RowFilter
 
filterRowKey(byte[]) - Method in interface org.apache.hadoop.hbase.filter.RowFilterInterface
Deprecated. Use RowFilterInterface.filterRowKey(byte[], int, int) instead.
filterRowKey(byte[], int, int) - Method in interface org.apache.hadoop.hbase.filter.RowFilterInterface
Deprecated. Filters on just a row key.
filterRowKey(byte[]) - Method in class org.apache.hadoop.hbase.filter.RowFilterSet
Deprecated.  
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.RowFilterSet
Deprecated.  
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
filterRowKey(byte[]) - Method in class org.apache.hadoop.hbase.filter.StopRowFilter
Deprecated.  
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.StopRowFilter
Deprecated.  
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
filterRowKey(byte[]) - Method in class org.apache.hadoop.hbase.filter.WhileMatchRowFilter
Deprecated.  
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.WhileMatchRowFilter
Deprecated.  
finalKey(WritableComparable) - Method in class org.apache.hadoop.hbase.migration.nineteen.io.HalfMapFileReader
 
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
Deprecated.  
firstKey() - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
FirstKeyOnlyFilter - Class in org.apache.hadoop.hbase.filter
A filter that will only return the first KV from each row.
FirstKeyOnlyFilter() - Constructor for class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.HLog
 
FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
 
FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.MemStore
 
FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.Store
 
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
Executes all the buffered Put operations.
flushCommits() - Method in class org.apache.hadoop.hbase.stargate.client.RemoteHTable
 
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.
forget(Xid) - Method in class org.apache.hadoop.hbase.client.transactional.JtaXAResource
 
forgetTransaction(long) - Method in class org.apache.hadoop.hbase.client.transactional.HBaseBackedTransactionLogger
 
forgetTransaction(long) - Method in class org.apache.hadoop.hbase.client.transactional.LocalTransactionLogger
 
forgetTransaction(long) - Method in interface org.apache.hadoop.hbase.client.transactional.TransactionLogger
This transaction's state is no longer needed.
freeMemory(long) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Free the requested amount of memory from the LRU map.
fromByte(byte) - Static method in enum org.apache.hadoop.hbase.regionserver.transactional.THLogKey.TrxOp
 
fromRowSpec(String, RowSpec, Filter) - Static method in class org.apache.hadoop.hbase.stargate.ResultGenerator
 
fromScan(Scan) - Static method in class org.apache.hadoop.hbase.stargate.model.ScannerModel
 
fsOk - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
fsReadLatency - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
filesystem read latency
fsSyncLatency - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
filesystem sync latency
FSUtils - Class in org.apache.hadoop.hbase.util
Utility methods for interacting with the underlying file system.
FSUtils.DirFilter - Class in org.apache.hadoop.hbase.util
A PathFilter that returns directories.
FSUtils.DirFilter(FileSystem) - Constructor for class org.apache.hadoop.hbase.util.FSUtils.DirFilter
 
fsWriteLatency - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
filesystem write latency

G

generateModel(HBaseConfiguration, HBaseAdmin) - Method in class org.apache.hadoop.hbase.rest.AbstractController
 
generateModel(HBaseConfiguration, HBaseAdmin) - Method in class org.apache.hadoop.hbase.rest.DatabaseController
 
generateModel(HBaseConfiguration, HBaseAdmin) - Method in class org.apache.hadoop.hbase.rest.RowController
 
generateModel(HBaseConfiguration, HBaseAdmin) - Method in class org.apache.hadoop.hbase.rest.ScannerController
 
generateModel(HBaseConfiguration, HBaseAdmin) - Method in class org.apache.hadoop.hbase.rest.TableController
 
generateModel(HBaseConfiguration, HBaseAdmin) - Method in class org.apache.hadoop.hbase.rest.TimestampController
 
Get - Class in org.apache.hadoop.hbase.client
Used to perform Get operations on a single row.
Get() - Constructor for class org.apache.hadoop.hbase.client.Get
Constructor for Writable.
Get(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Get
Create a Get operation for the specified row.
Get(byte[], RowLock) - Constructor for class org.apache.hadoop.hbase.client.Get
Create a Get operation for the specified row, using an existing row lock.
get(Get) - Method in class org.apache.hadoop.hbase.client.HTable
Extracts certain cells from a given row.
get(String, String) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.get(Get)
get(String, String, int) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.get(Get)
get(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.get(Get)
get(byte[], byte[], int) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.get(Get)
get(String, String, long, int) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.get(Get)
get(byte[], byte[], long, int) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.get(Get)
get(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
Returns a list of all KeyValue objects with matching column family and qualifier.
get(TransactionState, Get) - Method in class org.apache.hadoop.hbase.client.transactional.TransactionalTable
Method for getting data from a row
get(String) - Method in class org.apache.hadoop.hbase.io.BatchUpdate
Deprecated. Get the current value of the specified column
get(byte[]) - Method in class org.apache.hadoop.hbase.io.BatchUpdate
Deprecated. Get the current value of the specified column
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.hfile.CachedBlockQueue
Get a sorted List of all elements in this queue, in descending order.
get() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
Get the data from the BytesWritable.
get(Object) - Method in class org.apache.hadoop.hbase.io.RowResult
Deprecated.  
get(byte[]) - Method in class org.apache.hadoop.hbase.io.RowResult
Deprecated. Get the Cell that corresponds to column
get(String) - Method in class org.apache.hadoop.hbase.io.RowResult
Deprecated. Get the Cell that corresponds to column, using a String key
get(byte[], byte[]) - Method in class org.apache.hadoop.hbase.io.RowResult
Deprecated. Get a cell using seperate family, columnQualifier arguments.
get() - Static method in class org.apache.hadoop.hbase.ipc.HBaseServer
Returns the server instance called under or null.
get(byte[], Get) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
Perform Get operation.
get(long, byte[], Get) - Method in interface org.apache.hadoop.hbase.ipc.TransactionalRegionInterface
Perform a transactional Get operation.
get() - Method in class org.apache.hadoop.hbase.mapred.LuceneDocumentWrapper
Deprecated.  
get() - Method in class org.apache.hadoop.hbase.mapreduce.LuceneDocumentWrapper
 
get(WritableComparable, Writable) - Method in class org.apache.hadoop.hbase.migration.nineteen.io.BloomFilterMapFile.Reader
 
get(WritableComparable, Writable) - Method in class org.apache.hadoop.hbase.migration.nineteen.io.HalfMapFileReader
 
get(Get, Integer) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
get(byte[], Get) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Perform Get operation.
get(Object) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Retrieves the value associated with the specified key.
get(QueryMatcher, List<KeyValue>) - Method in class org.apache.hadoop.hbase.regionserver.MemStore
Perform a single-row Get on the and snapshot, placing results into the specified KV list.
get(Get, NavigableSet<byte[]>, List<KeyValue>) - Method in class org.apache.hadoop.hbase.regionserver.Store
Retrieve results from this store given the specified Get parameters.
get(List<KeyValue>) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileGetScan
Performs a GET operation across multiple StoreFiles.
get(long, Get) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegion
 
get(long, byte[], Get) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegionServer
 
get(Status, byte[][], Map<String, String[]>) - Method in class org.apache.hadoop.hbase.rest.AbstractController
 
get(Status, byte[][], Map<String, String[]>) - Method in class org.apache.hadoop.hbase.rest.DatabaseController
 
get(String) - Method in class org.apache.hadoop.hbase.rest.RESTConstants.FactoryMap
 
get(Status, byte[][], Map<String, String[]>) - Method in class org.apache.hadoop.hbase.rest.RowController
 
get(byte[], byte[]) - Method in class org.apache.hadoop.hbase.rest.RowModel
Deprecated. 
get(byte[], Get) - Method in class org.apache.hadoop.hbase.rest.RowModel
 
get(byte[], byte[], byte[][]) - Method in class org.apache.hadoop.hbase.rest.RowModel
Deprecated. 
get(byte[], byte[], byte[][], long) - Method in class org.apache.hadoop.hbase.rest.RowModel
Deprecated. 
get(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.rest.RowModel
Deprecated. 
get(Status, byte[][], Map<String, String[]>) - Method in class org.apache.hadoop.hbase.rest.ScannerController
 
get(Status, byte[][], Map<String, String[]>) - Method in class org.apache.hadoop.hbase.rest.TableController
 
get(byte[]) - Method in class org.apache.hadoop.hbase.rest.TableModel
 
get(byte[], byte[][]) - Method in class org.apache.hadoop.hbase.rest.TableModel
Returns all cells from all rows from the given table in the given columns.
get(Status, byte[][], Map<String, String[]>) - Method in class org.apache.hadoop.hbase.rest.TimestampController
 
get(byte[], Get) - Method in class org.apache.hadoop.hbase.rest.TimestampModel
 
get(byte[], byte[], byte[], long) - Method in class org.apache.hadoop.hbase.rest.TimestampModel
Deprecated. 
get(byte[], byte[], byte[], long, int) - Method in class org.apache.hadoop.hbase.rest.TimestampModel
Deprecated. 
get(byte[], byte[], byte[][], long) - Method in class org.apache.hadoop.hbase.rest.TimestampModel
Deprecated. 
get(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.rest.TimestampModel
 
get(String) - Method in class org.apache.hadoop.hbase.stargate.client.Client
Send a GET request
get(Cluster, String) - Method in class org.apache.hadoop.hbase.stargate.client.Client
Send a GET request
get(String, String) - Method in class org.apache.hadoop.hbase.stargate.client.Client
Send a GET request
get(Cluster, String, String) - Method in class org.apache.hadoop.hbase.stargate.client.Client
Send a GET request
get(String, Header[]) - Method in class org.apache.hadoop.hbase.stargate.client.Client
Send a GET request
get(Cluster, String, Header[]) - Method in class org.apache.hadoop.hbase.stargate.client.Client
Send a GET request
get(Get) - Method in class org.apache.hadoop.hbase.stargate.client.RemoteHTable
 
get(UriInfo) - Method in class org.apache.hadoop.hbase.stargate.ExistsResource
 
get(int) - Method in class org.apache.hadoop.hbase.stargate.model.TableInfoModel
 
get(int) - Method in class org.apache.hadoop.hbase.stargate.model.TableListModel
 
get(UriInfo) - Method in class org.apache.hadoop.hbase.stargate.RegionsResource
 
get(UriInfo) - Method in class org.apache.hadoop.hbase.stargate.RootResource
 
get(UriInfo) - Method in class org.apache.hadoop.hbase.stargate.RowResource
 
get(UriInfo, int, int) - Method in class org.apache.hadoop.hbase.stargate.ScannerInstanceResource
 
get(UriInfo) - Method in class org.apache.hadoop.hbase.stargate.SchemaResource
 
get(UriInfo) - Method in class org.apache.hadoop.hbase.stargate.StorageClusterStatusResource
 
get(UriInfo) - Method in class org.apache.hadoop.hbase.stargate.StorageClusterVersionResource
 
get(ServletContext, UriInfo) - Method in class org.apache.hadoop.hbase.stargate.VersionResource
Build a response for a version request.
get(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
Deprecated. 
get(byte[], 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
Deprecated.  
getAnalyzerName() - Method in class org.apache.hadoop.hbase.mapreduce.IndexConfiguration
 
getAny() - Method in class org.apache.hadoop.hbase.stargate.model.ColumnSchemaModel
 
getAny() - Method in class org.apache.hadoop.hbase.stargate.model.TableSchemaModel
 
getAttribute(String) - Method in class org.apache.hadoop.hbase.metrics.MetricsMBeanBase
 
getAttribute(String) - Method in class org.apache.hadoop.hbase.stargate.model.ColumnSchemaModel
 
getAttribute(String) - Method in class org.apache.hadoop.hbase.stargate.model.TableSchemaModel
Return a table descriptor value as a string.
getAttrs(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
getAttrs(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
getAttrs(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
getAttrs(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
getAttrsCount() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
getAttrsCount() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
getAttrsCount() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
getAttrsCount() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
getAttrsList() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
getAttrsList() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
getAttrsList() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
getAttrsList() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
getAverageLoad() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getAverageLoad() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getAverageLoad() - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel
 
getAverageLoad() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
getAverageLoad() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
getBaseDir() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getBaseTableDescriptor() - Method in class org.apache.hadoop.hbase.client.tableindexed.IndexedTableDescriptor
 
getBatch() - Method in class org.apache.hadoop.hbase.stargate.model.ScannerModel
 
getBatch() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
getBatch() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
getBinary(UriInfo) - Method in class org.apache.hadoop.hbase.stargate.RowResource
 
getBinary(UriInfo) - Method in class org.apache.hadoop.hbase.stargate.ScannerInstanceResource
 
getBindAddress() - Method in class org.apache.hadoop.hbase.HServerAddress
 
getBlock(String) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
Fetch block from cache.
getBlock(String) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Get the buffer of the block with the specified name.
getBlock(String) - Method in class org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
 
getBlockCache(HBaseConfiguration) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFile
Returns the block cache or null in case none should be used.
getBlockCache() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
getBlocksize() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getBloomFilterKey(WritableComparable) - Static method in class org.apache.hadoop.hbase.migration.nineteen.io.BloomFilterMapFile
Custom bloom filter key maker.
getBloomFilterSize() - Method in class org.apache.hadoop.hbase.migration.nineteen.io.BloomFilterMapFile.Reader
 
getBody() - Method in class org.apache.hadoop.hbase.stargate.client.Response
 
getBoost(String) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
Deprecated.  
getBoost(String) - Method in class org.apache.hadoop.hbase.mapreduce.IndexConfiguration
 
getBuffer() - Method in class org.apache.hadoop.hbase.io.hfile.CachedBlock
 
getBuffer() - Method in class org.apache.hadoop.hbase.KeyValue
 
getBuffer() - Method in class org.apache.hadoop.hbase.regionserver.ColumnCount
 
getBytes() - Method in class org.apache.hadoop.hbase.client.Result
Returns the raw binary encoding of this Result.
getBytes() - Method in class org.apache.hadoop.hbase.HStoreKey
Deprecated.  
getBytes(HStoreKey) - Static method in class org.apache.hadoop.hbase.HStoreKey
Deprecated. Return serialize hsk bytes.
getBytes(byte[]) - Static method in class org.apache.hadoop.hbase.HStoreKey
Deprecated.  
getBytes(byte[], byte[], long) - Static method in class org.apache.hadoop.hbase.HStoreKey
Deprecated.  
getBytes(HStoreKey) - Static method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey
Returns row and column bytes out of an HStoreKey.
getBytes() - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.Key
 
getBytes(Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
 
getCacheBlocks() - Method in class org.apache.hadoop.hbase.client.Scan
Get whether blocks should be cached for this Scan.
getCaching() - Method in class org.apache.hadoop.hbase.client.Scan
 
getCaching() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
Get the number of rows that will be fetched on next
getCallQueueLen() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
The number of rpc calls in the queue.
getCells() - Method in class org.apache.hadoop.hbase.io.RowResult
Deprecated. This method used solely for the REST serialization
getCells() - Method in class org.apache.hadoop.hbase.stargate.model.RowModel
 
getCellValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
 
getCellValue() - Method in class org.apache.hadoop.hbase.client.Result
 
getCellValues() - Method in class org.apache.hadoop.hbase.client.Result
 
getClass(byte) - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
getClientVersion() - Method in exception org.apache.hadoop.hbase.ipc.HBaseRPC.VersionMismatch
 
getClientZooKeeperWatcher(HBaseConfiguration) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Get a watcher of a zookeeper connection for a given quorum address.
getClosest(WritableComparable, Writable) - Method in class org.apache.hadoop.hbase.migration.nineteen.io.BloomFilterMapFile.Reader
 
getClosest(WritableComparable, Writable) - Method in class org.apache.hadoop.hbase.migration.nineteen.io.HalfMapFileReader
 
getClosestRowBefore(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.getRowOrBefore(byte[], byte[])
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
 
getCluster() - Method in class org.apache.hadoop.hbase.stargate.client.Client
 
getClusterStatus() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getClusterStatus() - Method in interface org.apache.hadoop.hbase.ipc.HMasterInterface
Return cluster status.
getClusterStatus() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getClusterStatusResource() - Method in class org.apache.hadoop.hbase.stargate.RootResource
 
getClusterVersionResource() - Method in class org.apache.hadoop.hbase.stargate.VersionResource
Dispatch to StorageClusterVersionResource
getCode() - Method in enum org.apache.hadoop.hbase.KeyValue.Type
 
getCode() - Method in class org.apache.hadoop.hbase.stargate.client.Response
 
getColumn() - Method in class org.apache.hadoop.hbase.HStoreKey
Deprecated.  
getColumn(ByteBuffer) - Static method in class org.apache.hadoop.hbase.HStoreKey
Deprecated.  
getColumn() - Method in class org.apache.hadoop.hbase.io.BatchOperation
Deprecated.  
getColumn() - Method in class org.apache.hadoop.hbase.KeyValue
Primarily for use client-side.
getColumn() - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey.BeforeThisStoreKey
 
getColumn() - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey
 
getColumn() - Method in class org.apache.hadoop.hbase.stargate.model.CellModel
 
getColumn() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell.Builder
 
getColumn() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell
 
getColumnDescriptor(Element) - Method in class org.apache.hadoop.hbase.rest.parser.XMLRestParser
 
getColumnDescriptors(byte[]) - Method in interface org.apache.hadoop.hbase.rest.parser.IHBaseRestParser
 
getColumnDescriptors(byte[]) - Method in class org.apache.hadoop.hbase.rest.parser.XMLRestParser
 
getColumnDescriptors(byte[]) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
getColumnFamilies() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
getColumnFamily(int) - Method in class org.apache.hadoop.hbase.stargate.model.TableSchemaModel
Retrieve the column family at the given index from the table descriptor
getColumnHint() - Method in interface org.apache.hadoop.hbase.regionserver.ColumnTracker
Used by matcher and scan/get to get a hint of the next column to seek to after checkColumn() returns SKIP.
getColumnHint() - Method in class org.apache.hadoop.hbase.regionserver.ExplicitColumnTracker
 
getColumnHint() - Method in class org.apache.hadoop.hbase.regionserver.ScanWildcardColumnTracker
Used by matcher and scan/get to get a hint of the next column to seek to after checkColumn() returns SKIP.
getColumnHint() - Method in class org.apache.hadoop.hbase.regionserver.WildcardColumnTracker
 
getColumns() - Method in class org.apache.hadoop.hbase.io.BatchUpdate
Deprecated. Get the current columns
getColumns(byte[]) - Method in class org.apache.hadoop.hbase.rest.AbstractModel
 
getColumns() - Method in class org.apache.hadoop.hbase.rest.descriptors.ScannerDescriptor
 
getColumns() - Method in class org.apache.hadoop.hbase.stargate.model.ScannerModel
 
getColumns() - Method in class org.apache.hadoop.hbase.stargate.model.TableSchemaModel
 
getColumns(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
getColumns(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
getColumns(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
getColumns(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
getColumns() - Method in class org.apache.hadoop.hbase.stargate.RowSpec
 
getColumnsCount() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
getColumnsCount() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
getColumnsCount() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
getColumnsCount() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
getColumnsFromQueryMap(Map<String, String[]>) - Method in class org.apache.hadoop.hbase.rest.AbstractController
 
getColumnsList() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
getColumnsList() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
getColumnsList() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
getColumnsList() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
getColumnTracker() - Method in class org.apache.hadoop.hbase.regionserver.QueryMatcher
 
getColVals() - Method in class org.apache.hadoop.hbase.rest.descriptors.RowUpdateDescriptor
 
getComparator() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
getComparator() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
getComparator() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getComparator(byte[]) - Static method in class org.apache.hadoop.hbase.HStoreKey
Deprecated.  
getComparator() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
getComparatorIgnoringTimestamps() - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
getComparatorIgnoringType() - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
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
 
getCompression() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
getCompression() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
getCompressionAlgorithmByName(String) - Static method in class org.apache.hadoop.hbase.io.hfile.Compression
 
getCompressionType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getCompressor() - Method in enum org.apache.hadoop.hbase.io.hfile.Compression.Algorithm
 
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.mapreduce.GroupingTableMapper
Returns the current configuration.
getConf() - Method in class org.apache.hadoop.hbase.mapreduce.HRegionPartitioner
Returns the current configuration.
getConf() - Method in class org.apache.hadoop.hbase.mapreduce.IndexTableReducer
Returns the current configuration.
getConf() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Returns the current configuration.
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
 
getConfiguration() - Method in class org.apache.hadoop.hbase.stargate.client.RemoteHTable
 
getConnection() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
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
INTERNAL 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.Dispatcher.ContentType
Deprecated. Utility method used looking at Accept header content.
getContext(Class<?>) - Method in class org.apache.hadoop.hbase.stargate.provider.JAXBContextResolver
 
getCopyOfOnlineRegionsSortedBySize() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getCurrentKey() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase.TableRecordReader
Returns the current key.
getCurrentSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Get the current size of this cache.
getCurrentValue() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase.TableRecordReader
Returns the current value.
getData() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell.Builder
 
getData() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell
 
getDatabaseMetadata() - Method in class org.apache.hadoop.hbase.rest.DatabaseModel
 
getDate() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
The date that hbase was compiled.
getDaughterA() - Method in class org.apache.hadoop.hbase.HMsg
 
getDaughterB() - Method in class org.apache.hadoop.hbase.HMsg
 
getDeadNode(int) - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel
 
getDeadNodes() - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel
 
getDeadNodes(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
getDeadNodes(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
getDeadNodesCount() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
getDeadNodesCount() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
getDeadNodesList() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
getDeadNodesList() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
getDeadServerNames() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getDeadServers() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
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.
getDecompressor() - Method in enum org.apache.hadoop.hbase.io.hfile.Compression.Algorithm
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 
GetDeleteTracker - Class in org.apache.hadoop.hbase.regionserver
This class is responsible for the tracking and enforcement of Deletes during the course of a Get operation.
GetDeleteTracker() - Constructor for class org.apache.hadoop.hbase.regionserver.GetDeleteTracker
Constructor
getDeleteTracker() - Method in class org.apache.hadoop.hbase.regionserver.QueryMatcher
 
GetDeleteTracker.Delete - Class in org.apache.hadoop.hbase.regionserver
Internal class used to store the necessary information for a Delete.
GetDeleteTracker.Delete(byte[], int, int, byte, long) - Constructor for class org.apache.hadoop.hbase.regionserver.GetDeleteTracker.Delete
Constructor
getDelimiter(byte[], int, int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
 
getDelimiterInReverse(byte[], int, int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
Find index of passed delimiter walking from end of buffer backwards.
getDescriptor() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version.Builder
 
getEdit() - Method in class org.apache.hadoop.hbase.regionserver.HLog.HLogEntry
Gets the edit
getEncodedName() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getEncodedRegionName() - Method in class org.apache.hadoop.hbase.migration.nineteen.io.Reference
 
getEndKey() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getEndKey() - Method in class org.apache.hadoop.hbase.master.MetaRegion
 
getEndKey() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getEndKey() - Method in class org.apache.hadoop.hbase.stargate.model.TableRegionModel
 
getEndKey() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
getEndKey() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
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
Deprecated.  
getEndRow() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Returns the end row.
getEndRow() - Method in class org.apache.hadoop.hbase.stargate.model.ScannerModel
 
getEndRow() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
getEndRow() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
getEndRow() - Method in class org.apache.hadoop.hbase.stargate.RowSpec
 
getEndTime() - Method in class org.apache.hadoop.hbase.stargate.model.ScannerModel
 
getEndTime() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
getEndTime() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
getEndTime() - Method in class org.apache.hadoop.hbase.stargate.RowSpec
 
getEntries() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
getError() - Method in class org.apache.hadoop.hbase.rest.Status.StatusMessage
 
getEvictedCount() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache.CacheStats
 
getEvictedCount() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Get the number of blocks that have been evicted during the lifetime of this cache.
getEvictionCount() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache.CacheStats
 
getEvictionCount() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Get the number of eviction runs that have occurred
getExistsResource() - Method in class org.apache.hadoop.hbase.stargate.TableResource
 
getFactoryMap() - Static method in class org.apache.hadoop.hbase.rest.RESTConstants.FactoryMap
 
getFamilies() - Method in class org.apache.hadoop.hbase.client.Scan
 
getFamilies() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
getFamiliesKeys() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
getFamily() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
getFamily(byte[]) - Static method in class org.apache.hadoop.hbase.HStoreKey
Deprecated.  
getFamily(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
getFamily() - Method in class org.apache.hadoop.hbase.KeyValue
Primarily for use client-side.
getFamily() - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
 
getFamily(byte[]) - Static method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey
 
getFamilyDelimiterIndex(byte[]) - Static method in class org.apache.hadoop.hbase.HStoreKey
Deprecated.  
getFamilyDelimiterIndex(byte[], int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
 
getFamilyDelimiterIndex(byte[]) - Static method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey
 
getFamilyLength() - Method in class org.apache.hadoop.hbase.KeyValue
 
getFamilyLength(int) - Method in class org.apache.hadoop.hbase.KeyValue
 
getFamilyMap() - Method in class org.apache.hadoop.hbase.client.Delete
Method for retrieving the delete's familyMap
getFamilyMap() - Method in class org.apache.hadoop.hbase.client.Get
Method for retrieving the get's familyMap
getFamilyMap() - Method in class org.apache.hadoop.hbase.client.Put
Method for retrieving the put's familyMap
getFamilyMap(byte[]) - Method in class org.apache.hadoop.hbase.client.Result
Map of qualifiers to values.
getFamilyMap() - Method in class org.apache.hadoop.hbase.client.Scan
Getting the familyMap
getFamilyMapKey(byte[]) - Static method in class org.apache.hadoop.hbase.HStoreKey
Deprecated.  
getFamilyMapKey(byte[]) - Static method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey
 
getFamilyOffset() - Method in class org.apache.hadoop.hbase.KeyValue
 
getFamilyOffset(int) - Method in class org.apache.hadoop.hbase.KeyValue
 
getFileId() - Method in class org.apache.hadoop.hbase.migration.nineteen.io.Reference
 
getFilenum() - Method in class org.apache.hadoop.hbase.regionserver.HLog
 
getFileRegion() - Method in class org.apache.hadoop.hbase.io.Reference
 
getFileRegion() - Method in class org.apache.hadoop.hbase.migration.nineteen.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.Get
 
getFilter() - Method in class org.apache.hadoop.hbase.client.Scan
 
getFilter() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
getFilter() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
getFilter() - Method in class org.apache.hadoop.hbase.stargate.model.ScannerModel
 
getFilter() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
getFilter() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
getFilterDir(Path, int, byte[]) - Static method in class org.apache.hadoop.hbase.migration.nineteen.regionserver.HStoreFile
Deprecated. 
getFilterFromJSON(String) - Method in class org.apache.hadoop.hbase.rest.filter.ColumnValueFilterFactory
 
getFilterFromJSON(String) - Method in interface org.apache.hadoop.hbase.rest.filter.FilterFactory
 
getFilterFromJSON(String) - Method in class org.apache.hadoop.hbase.rest.filter.InclusiveStopRowFilterFactory
 
getFilterFromJSON(String) - Method in class org.apache.hadoop.hbase.rest.filter.PageRowFilterFactory
 
getFilterFromJSON(String) - Method in class org.apache.hadoop.hbase.rest.filter.RegExpRowFilterFactory
 
getFilterFromJSON(String) - Method in class org.apache.hadoop.hbase.rest.filter.RowFilterSetFactory
 
getFilterFromJSON(String) - Method in class org.apache.hadoop.hbase.rest.filter.StopRowFilterFactory
 
getFilterFromJSON(String) - Method in class org.apache.hadoop.hbase.rest.filter.WhileMatchRowFilterFactory
 
getFilterIfMissing() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Get whether entire row should be filtered if column is not found.
getFilters() - Method in class org.apache.hadoop.hbase.filter.FilterList
Get the filters.
getFilters() - Method in class org.apache.hadoop.hbase.filter.RowFilterSet
Deprecated. Get the filters.
getFilters() - Method in class org.apache.hadoop.hbase.rest.descriptors.ScannerDescriptor
 
getFirst() - Method in class org.apache.hadoop.hbase.util.Pair
Return the first element stored in the pair.
getFirstKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
getFlushRequester() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Get the current size of this cache.
getFromMETA(byte[], byte[]) - Method in class org.apache.hadoop.hbase.master.HMaster
Get row from meta table.
getGlobalMemStoreSize() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Return the total size of all memstores 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.
getHBaseVersion() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getHeaders() - Method in class org.apache.hadoop.hbase.stargate.client.Response
 
getHeadPtr() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Get the head of the linked list (least recently used).
getHeap() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
 
getHeapSizeMB() - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel.Node
 
getHeapSizeMB() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
getHeapSizeMB() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
getHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache.CacheStats
 
getHitCount() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Get the number of hits to the map.
getHitRatio() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache.CacheStats
 
getHitRatio() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Get the hit ratio.
getHLogDirectoryName(HServerInfo) - Static method in class org.apache.hadoop.hbase.regionserver.HLog
Construct the HLog directory name
getHLogDirectoryName(String, long) - Static method in class org.apache.hadoop.hbase.regionserver.HLog
Construct the HLog directory name
getHLogDirectoryName(String) - 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.
getHRegionConnection(HServerAddress, boolean) - 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.migration.nineteen.HStoreKey.BeforeThisStoreKey
 
getHRegionInfo() - Method in class org.apache.hadoop.hbase.migration.nineteen.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
 
getHServerInfo() - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
Method used when a master is taking the place of another failed one.
getHServerInfo() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Method used when a master is taking the place of another failed one.
getHTable() - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Deprecated. Allows subclasses to get the HTable.
getHTable() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Allows subclasses to get the HTable.
getHTableDescriptor(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
 
getId(Class<?>) - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
getId() - Method in class org.apache.hadoop.hbase.rest.descriptors.ScannerIdentifier
 
getId() - Method in class org.apache.hadoop.hbase.stargate.model.TableRegionModel
 
getId() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
getId() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
getID() - Method in class org.apache.hadoop.hbase.stargate.ScannerResultGenerator
 
getIndex(String) - Method in class org.apache.hadoop.hbase.client.tableindexed.IndexedTableDescriptor
 
getIndexedColumns() - Method in class org.apache.hadoop.hbase.client.tableindexed.IndexSpecification
Get the indexedColumns.
getIndexedScanner(String, byte[], byte[], byte[][], Filter, byte[][]) - Method in class org.apache.hadoop.hbase.client.tableindexed.IndexedTable
Open up an indexed scanner.
getIndexedTableDescriptor() - Method in class org.apache.hadoop.hbase.client.tableindexed.IndexedTable
 
getIndexedTableName(byte[]) - Method in class org.apache.hadoop.hbase.client.tableindexed.IndexSpecification
 
getIndexes() - Method in class org.apache.hadoop.hbase.client.tableindexed.IndexedTableDescriptor
 
getIndexId() - Method in class org.apache.hadoop.hbase.client.tableindexed.IndexSpecification
Get the indexId.
getIndexSpecifications() - Method in class org.apache.hadoop.hbase.client.tableindexed.IndexSpecificationArray
Get indexSpecifications.
getInetSocketAddress() - Method in class org.apache.hadoop.hbase.HServerAddress
 
getInfoDir(Path, int, byte[]) - Static method in class org.apache.hadoop.hbase.migration.nineteen.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
 
getInMemory() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
getInMemory() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
getInnerClass() - Method in exception org.apache.hadoop.hbase.rest.exception.HBaseRestException
 
getInnerException() - Method in exception org.apache.hadoop.hbase.rest.exception.HBaseRestException
 
getInnerMessage() - Method in exception org.apache.hadoop.hbase.rest.exception.HBaseRestException
 
getInputColumns() - Method in class org.apache.hadoop.hbase.client.Scan
Helps to convert the binary column families and qualifiers to a text representation, e.g.
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.stargate.RESTServlet
 
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
Deprecated. Returns the internal filter being wrapped
getJerseyVersion() - Method in class org.apache.hadoop.hbase.stargate.model.VersionModel
 
getJerseyVersion() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version.Builder
 
getJerseyVersion() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 
getJvmVersion() - Method in class org.apache.hadoop.hbase.stargate.model.VersionModel
 
getJvmVersion() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version.Builder
 
getJvmVersion() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 
getKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
Gets a buffer view to the current key.
getKey() - Method in class org.apache.hadoop.hbase.io.RowResult.Entry
Deprecated.  
getKey() - Method in class org.apache.hadoop.hbase.KeyValue
Do not use unless you have to.
getKey() - Method in class org.apache.hadoop.hbase.regionserver.HLog.HLogEntry
Gets the key
getKey() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
Get the key of this entry.
getKey() - Method in class org.apache.hadoop.hbase.stargate.model.RowModel
 
getKey() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
getKey() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row
 
getKeyGenerator() - Method in class org.apache.hadoop.hbase.client.tableindexed.IndexSpecification
Get the keyGenerator.
getKeyLength() - Method in class org.apache.hadoop.hbase.KeyValue
 
getKeyOffset() - Method in class org.apache.hadoop.hbase.KeyValue
 
getKeyString() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
Convenience method to get a copy of the key as a string - interpreting the bytes as UTF8.
getKeyString() - Method in class org.apache.hadoop.hbase.KeyValue
 
getKeyValue() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
 
getLargestHStoreSize() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getLastFlushTime() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getLastKey() - Method in class org.apache.hadoop.hbase.io.HalfHFileReader
 
getLastKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
getLatestVersionOnly() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Get whether only the latest version of the column value should be compared.
getLeases() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getLength() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
getLength() - Method in class org.apache.hadoop.hbase.KeyValue
 
getLength() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
Deprecated.  
getLength() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Returns the length of the split.
getLength() - Method in class org.apache.hadoop.hbase.regionserver.ColumnCount
 
getLimit() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
getListenerAddress() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
Return the socket (ip+port) on which the RPC server is listening to.
getLiveNode(int) - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel
 
getLiveNodes() - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel
 
getLiveNodes(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
getLiveNodes(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
getLiveNodesCount() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
getLiveNodesCount() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
getLiveNodesList() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
getLiveNodesList() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
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.
getLocation() - Method in class org.apache.hadoop.hbase.stargate.client.Response
 
getLocation() - Method in class org.apache.hadoop.hbase.stargate.model.TableRegionModel
 
getLocation() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
getLocation() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
getLocations() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
Deprecated.  
getLocations() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Returns the region's location as an array.
getLockId() - Method in class org.apache.hadoop.hbase.client.Delete
Method for retrieving the delete's lock ID.
getLockId() - Method in class org.apache.hadoop.hbase.client.Get
Method for retrieving the get's lockId
getLockId() - Method in class org.apache.hadoop.hbase.client.Put
Method for retrieving the put's lockId
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
 
getLogRoller() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getLogSeqNum() - Method in class org.apache.hadoop.hbase.regionserver.HLogKey
 
getLower(KeyValue, KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.MemStore.MemStoreScanner
 
getLowest() - Method in class org.apache.hadoop.hbase.regionserver.MemStore.MemStoreScanner
 
getMap() - Method in class org.apache.hadoop.hbase.client.Result
Map of families to all versions of its qualifiers and values.
getMapDir(Path, int, byte[]) - Static method in class org.apache.hadoop.hbase.migration.nineteen.regionserver.HStoreFile
 
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
 
getMasterElectionZNode() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWrapper
Get the path of the masterElectionZNode
getMax() - Method in class org.apache.hadoop.hbase.io.TimeRange
 
getMaxAge(String) - Method in class org.apache.hadoop.hbase.stargate.RESTServlet
 
getMaxBufferedDeleteTerms() - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
Deprecated.  
getMaxBufferedDeleteTerms() - Method in class org.apache.hadoop.hbase.mapreduce.IndexConfiguration
 
getMaxBufferedDocs() - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
Deprecated.  
getMaxBufferedDocs() - Method in class org.apache.hadoop.hbase.mapreduce.IndexConfiguration
 
getMaxFieldLength() - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
Deprecated.  
getMaxFieldLength() - Method in class org.apache.hadoop.hbase.mapreduce.IndexConfiguration
 
getMaxFileSize() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
getMaxHeapMB() - Method in class org.apache.hadoop.hbase.HServerLoad
 
getMaxHeapSizeMB() - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel.Node
 
getMaxHeapSizeMB() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
getMaxHeapSizeMB() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
getMaxMergeDocs() - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
Deprecated.  
getMaxMergeDocs() - Method in class org.apache.hadoop.hbase.mapreduce.IndexConfiguration
 
getMaxSequenceId() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
getMaxSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Get the maximum size of this cache.
getMaxValues() - Method in class org.apache.hadoop.hbase.stargate.RowSpec
 
getMaxVersions() - Method in class org.apache.hadoop.hbase.client.Get
Method for retrieving the get's maximum number of version
getMaxVersions() - Method in class org.apache.hadoop.hbase.client.Scan
 
getMaxVersions() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getMaxVersions() - Method in class org.apache.hadoop.hbase.stargate.model.ScannerModel
 
getMaxVersions() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
getMaxVersions() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
getMaxVersions() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
getMaxVersions() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
getMaxVersions() - Method in class org.apache.hadoop.hbase.stargate.RowSpec
 
getMBeanInfo() - Method in class org.apache.hadoop.hbase.metrics.MetricsMBeanBase
 
getMemFree() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Get the currently available memory for this LRU in bytes.
getMemMax() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Get the maximum memory allowed for this LRU in bytes.
getMemStoreFlushSize() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
getMemStoreSizeInMB() - Method in class org.apache.hadoop.hbase.HServerLoad
 
getMemStoreSizeMB() - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
 
getMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel.Node.Region
 
getMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
getMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
getMemstoreTS() - Method in class org.apache.hadoop.hbase.KeyValue
Here be dragons
getMemUsed() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Get the currently used memory for this LRU in bytes.
getMergeFactor() - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
Deprecated.  
getMergeFactor() - Method in class org.apache.hadoop.hbase.mapreduce.IndexConfiguration
 
getMessage() - Method in class org.apache.hadoop.hbase.HMsg
 
getMessage() - Method in class org.apache.hadoop.hbase.rest.Status
 
getMessage() - Method in class org.apache.hadoop.hbase.rest.Status.StatusMessage
 
getMetaBlock(String) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
getMetadata() - Method in class org.apache.hadoop.hbase.rest.DatabaseModel
 
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.migration.nineteen.io.Reference
 
getMin() - Method in class org.apache.hadoop.hbase.io.TimeRange
 
getMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache.CacheStats
 
getMissCount() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Get the number of misses to the map.
getMissRatio() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache.CacheStats
 
getModel() - Method in class org.apache.hadoop.hbase.rest.DatabaseController
 
getModel() - Method in class org.apache.hadoop.hbase.rest.RowController
 
getModel() - Method in class org.apache.hadoop.hbase.rest.ScannerController
 
getModel() - Method in class org.apache.hadoop.hbase.rest.TableController
 
getModel() - Method in class org.apache.hadoop.hbase.rest.TimestampController
 
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
Get the hostname of the server
getName() - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
 
getName() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
getName() - Method in class org.apache.hadoop.hbase.io.hfile.CachedBlock
 
getName() - Method in enum org.apache.hadoop.hbase.io.hfile.Compression.Algorithm
 
getName() - Method in exception org.apache.hadoop.hbase.Leases.LeaseStillHeldException
 
getName() - Method in class org.apache.hadoop.hbase.rest.descriptors.RestCell
 
getName() - Method in class org.apache.hadoop.hbase.stargate.model.ColumnSchemaModel
 
getName() - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel.Node
 
getName() - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel.Node.Region
 
getName() - Method in class org.apache.hadoop.hbase.stargate.model.TableInfoModel
 
getName() - Method in class org.apache.hadoop.hbase.stargate.model.TableModel
 
getName() - Method in class org.apache.hadoop.hbase.stargate.model.TableRegionModel
 
getName() - Method in class org.apache.hadoop.hbase.stargate.model.TableSchemaModel
 
getName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
getName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
getName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
getName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
getName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
getName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
getName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
getName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
getName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
getName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo
 
getName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
getName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
getName(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList.Builder
 
getName(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList
 
getName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
getName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
getName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
getName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
getNameAsString() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getNameAsString() - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
 
getNameAsString() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
getNameCount() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList.Builder
 
getNameCount() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList
 
getNameList() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList.Builder
 
getNameList() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList
 
getNameWithColon() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getNext(Iterator<KeyValue>) - Method in class org.apache.hadoop.hbase.regionserver.MemStore.MemStoreScanner
 
getNextPtr() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
Returns the next pointer for the entry in teh LRU.
getNoVersionMap() - Method in class org.apache.hadoop.hbase.client.Result
Map of families to their most recent qualifiers and values.
getNumberOfRegions() - Method in class org.apache.hadoop.hbase.HServerLoad
 
getNumberOfRequests() - Method in class org.apache.hadoop.hbase.HServerLoad
 
getNumberOfstorefiles() - Method in class org.apache.hadoop.hbase.regionserver.Store
 
getNumOpenConnections() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
The number of open RPC conections
getNumRows() - Method in class org.apache.hadoop.hbase.rest.descriptors.ScannerIdentifier
 
getNumValues() - Method in class org.apache.hadoop.hbase.io.Cell
Deprecated.  
getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.stargate.model.CellModel
 
getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.stargate.model.CellSetModel
 
getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.stargate.model.RowModel
 
getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.stargate.model.ScannerModel
 
getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel
 
getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.stargate.model.TableInfoModel
 
getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.stargate.model.TableListModel
 
getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.stargate.model.TableSchemaModel
 
getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.stargate.model.VersionModel
 
getObjectFromMessage(byte[]) - Method in interface org.apache.hadoop.hbase.stargate.ProtobufMessageHandler
Initialize the model from a protobuf representation.
getOffset() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
getOffset() - Method in class org.apache.hadoop.hbase.KeyValue
 
getOffset() - Method in class org.apache.hadoop.hbase.regionserver.ColumnCount
 
getOldestStamp() - Method in class org.apache.hadoop.hbase.regionserver.QueryMatcher
 
getOldFilter() - Method in class org.apache.hadoop.hbase.client.Scan
Deprecated.  
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
 
getOnlineRegionsAsArray() - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
 
getOnlineRegionsAsArray() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getOperator() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
getOperator() - Method in class org.apache.hadoop.hbase.filter.FilterList
Get the operator.
getOperator() - Method in class org.apache.hadoop.hbase.filter.RowFilterSet
Deprecated. Get the operator.
getOperator() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
getOsVersion() - Method in class org.apache.hadoop.hbase.stargate.model.VersionModel
 
getOsVersion() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version.Builder
 
getOsVersion() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 
getOutboundMsgs() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
Returns the output committer.
getPageSize() - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
getParser(HttpServletRequest) - Method in class org.apache.hadoop.hbase.rest.Dispatcher
Deprecated.  
getParser(Dispatcher.ContentType) - Static method in class org.apache.hadoop.hbase.rest.parser.HBaseRestParserFactory
 
getPartition(ImmutableBytesWritable, V2, int) - Method in class org.apache.hadoop.hbase.mapred.HRegionPartitioner
Deprecated.  
getPartition(ImmutableBytesWritable, VALUE, int) - Method in class org.apache.hadoop.hbase.mapreduce.HRegionPartitioner
Gets the partition number for a given key (hence record) given the total number of partitions i.e.
getPath() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.Writer
 
getPath(Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Return the 'path' component of a Path.
getPathSegments(HttpServletRequest) - Method in class org.apache.hadoop.hbase.rest.Dispatcher
Deprecated. This method will get the path segments from the HttpServletRequest.
getPort() - Method in class org.apache.hadoop.hbase.HServerAddress
 
getPos() - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase.TableRecordReader
Deprecated.  
getPrefix() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
getPreviousIntervalValue() - Method in class org.apache.hadoop.hbase.metrics.MetricsRate
 
getPrevPtr() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
Returns the previous pointer for the entry in the LRU.
getPriority() - Method in class org.apache.hadoop.hbase.io.hfile.CachedBlock
 
getProgress() - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase.TableRecordReader
Deprecated.  
getProgress() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase.TableRecordReader
The current progress of the record reader through its data.
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() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
getQualifier(byte[]) - Static method in class org.apache.hadoop.hbase.HStoreKey
Deprecated.  
getQualifier() - Method in class org.apache.hadoop.hbase.KeyValue
Primarily for use client-side.
getQualifier() - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
 
getQualifier(byte[]) - Static method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey
 
getQualifierLength() - Method in class org.apache.hadoop.hbase.KeyValue
 
getQualifierLength(int, int) - Method in class org.apache.hadoop.hbase.KeyValue
 
getQualifierOffset() - Method in class org.apache.hadoop.hbase.KeyValue
 
getQualifierOffset(int) - Method in class org.apache.hadoop.hbase.KeyValue
 
getQuorumServers() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWrapper
 
getRawComparator(HRegionInfo) - Static method in class org.apache.hadoop.hbase.HStoreKey
Deprecated.  
getRawComparator() - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
getRawComparator() - Method in class org.apache.hadoop.hbase.KeyValue.MetaComparator
 
getRawComparator() - Method in class org.apache.hadoop.hbase.KeyValue.RootComparator
 
getReader() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
 
getReader(FileSystem, boolean, boolean) - Method in class org.apache.hadoop.hbase.migration.nineteen.regionserver.HStoreFile
Get reader for the store file map file.
getReader() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
getReadOnly() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
getReadOnly() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
getReadOps() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
 
getReadTime() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Deprecated. Builds a TableRecordReader.
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.hbase.mapred.IndexOutputFormat
Deprecated.  
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat
Deprecated.  
getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.IndexOutputFormat
Returns the record writer.
getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
Creates a new record writer.
getRegion(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Protected utility method for safely obtaining an HRegion handle.
getRegion(int) - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel.Node
 
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
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.master.MetaRegion
 
getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getRegionInfo(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getRegionKey() - Method in class org.apache.hadoop.hbase.rest.TableModel.Regions
 
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
Finds the region on which the given row is being served.
getRegionLocation() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
Deprecated.  
getRegionLocation() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Returns the region location.
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
 
getRegionNameAsString() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getRegions() - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel
 
getRegions() - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel.Node
 
getRegions() - Method in class org.apache.hadoop.hbase.stargate.model.TableInfoModel
 
getRegions() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
getRegions() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
getRegions(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
getRegions(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
getRegions(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
getRegions(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo
 
getRegionsAssignment() - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
Method used when a master is taking the place of another failed one.
getRegionsAssignment() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Method used when a master is taking the place of another failed one.
getRegionsCount() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getRegionsCount() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
getRegionsCount() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
getRegionsCount() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
getRegionsCount() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo
 
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
Gets all the regions and their address for this table.
getRegionsInTransition() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getRegionsList() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
getRegionsList() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
getRegionsList() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
getRegionsList() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo
 
getRegionsLoad() - Method in class org.apache.hadoop.hbase.HServerLoad
 
getRegionsResource() - Method in class org.apache.hadoop.hbase.stargate.TableResource
 
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.io.hfile.LruBlockCache.CacheStats
 
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
 
getRequests() - Method in class org.apache.hadoop.hbase.stargate.metrics.StargateMetrics
 
getRequests() - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel
 
getRequests() - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel.Node
 
getRequests() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
getRequests() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
getRequests() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
getRequests() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
getRequestsCount() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getRESTVersionResource() - Method in class org.apache.hadoop.hbase.stargate.VersionResource
Dispatch /version/rest to self.
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 class org.apache.hadoop.hbase.master.HMaster
 
getRow() - Method in class org.apache.hadoop.hbase.client.Delete
Method for retrieving the delete's row
getRow() - Method in class org.apache.hadoop.hbase.client.Get
Method for retrieving the get's row
getRow(String) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.get(Get)
getRow(byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.get(Get)
getRow(String, int) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.get(Get)
getRow(byte[], int) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.get(Get)
getRow(String, long) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.get(Get)
getRow(byte[], long) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.get(Get)
getRow(String, long, int) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.get(Get)
getRow(byte[], long, int) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.get(Get)
getRow(String, String[]) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.get(Get)
getRow(byte[], byte[][]) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.get(Get)
getRow(String, String[], int) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.get(Get)
getRow(byte[], byte[][], int) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.get(Get)
getRow(String, String[], long) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.get(Get)
getRow(byte[], byte[][], long) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.get(Get)
getRow(String, String[], long, int, RowLock) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.get(Get)
getRow(byte[], byte[][], long, int, RowLock) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.get(Get)
getRow() - Method in class org.apache.hadoop.hbase.client.Put
Method for retrieving the put's row
getRow() - Method in class org.apache.hadoop.hbase.client.Result
Method for retrieving the row that this result is for
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() - Method in class org.apache.hadoop.hbase.HStoreKey
Deprecated.  
getRow(ByteBuffer) - Static method in class org.apache.hadoop.hbase.HStoreKey
Deprecated.  
getRow() - Method in class org.apache.hadoop.hbase.io.BatchUpdate
Deprecated.  
getRow() - Method in class org.apache.hadoop.hbase.io.RowResult
Deprecated. Get the row for this RowResult
getRow() - Method in class org.apache.hadoop.hbase.KeyValue
Primarily for use client-side.
getRow() - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
 
getRow() - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey.BeforeThisStoreKey
 
getRow() - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey
 
getRow() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell.Builder
 
getRow() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell
 
getRow() - Method in class org.apache.hadoop.hbase.stargate.RowSpec
 
getRow(byte[], byte[]) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
getRowComparator(byte[]) - Static method in class org.apache.hadoop.hbase.KeyValue
Get the appropriate row comparator for the specified table.
getRowComparator() - Method in class org.apache.hadoop.hbase.regionserver.QueryMatcher
 
getRowkeyName() - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
Deprecated.  
getRowkeyName() - Method in class org.apache.hadoop.hbase.mapreduce.IndexConfiguration
 
getRowLength() - Method in class org.apache.hadoop.hbase.KeyValue
 
getRowLock() - Method in class org.apache.hadoop.hbase.client.Delete
Method for retrieving the delete's RowLock
getRowLock() - Method in class org.apache.hadoop.hbase.client.Get
Method for retrieving the get's RowLock
getRowLock() - Method in class org.apache.hadoop.hbase.client.Put
Method for retrieving the put's RowLock
getRowLock() - Method in class org.apache.hadoop.hbase.io.BatchUpdate
Deprecated. Get the row lock associated with this update
getRowName() - Method in class org.apache.hadoop.hbase.rest.descriptors.RowUpdateDescriptor
 
getRowOffset() - Method in class org.apache.hadoop.hbase.KeyValue
 
getRowOrBefore(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Return the row that matches row exactly, or the one that immediately precedes it.
getRowOrBefore(byte[], byte[]) - Method in class org.apache.hadoop.hbase.stargate.client.RemoteHTable
 
getRowResource(String, String) - Method in class org.apache.hadoop.hbase.stargate.TableResource
 
getRowResult() - Method in class org.apache.hadoop.hbase.client.Result
Returns this Result in the old return format, RowResult.
getRows() - Method in class org.apache.hadoop.hbase.stargate.model.CellSetModel
 
getRows(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Builder
 
getRows(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet
 
getRowsCount() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Builder
 
getRowsCount() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet
 
getRowsList() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Builder
 
getRowsList() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet
 
getRowTs(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
getRowUpdateDescriptor(byte[], byte[][]) - Method in interface org.apache.hadoop.hbase.rest.parser.IHBaseRestParser
 
getRowUpdateDescriptor(byte[], byte[][]) - Method in class org.apache.hadoop.hbase.rest.parser.XMLRestParser
 
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.ThriftServer.HBaseHandler
 
getScan() - Method in class org.apache.hadoop.hbase.client.HTable.ClientScanner
 
getScan() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
getScan() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Gets the scan defining the actual details like columns etc.
getScanner(Scan) - Method in class org.apache.hadoop.hbase.client.HTable
Returns a scanner on the current table as specified by the Scan object.
getScanner(byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Gets a scanner on the current table for the given family.
getScanner(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Gets a scanner on the current table for the given family and qualifier.
getScanner(String[]) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.getScanner(Scan)
getScanner(String[], String) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.getScanner(Scan)
getScanner(byte[][]) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.getScanner(Scan)
getScanner(byte[][], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.getScanner(Scan)
getScanner(byte[][], byte[], long) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.getScanner(Scan)
getScanner(byte[][], byte[], RowFilterInterface) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.getScanner(Scan)
getScanner(byte[][], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.getScanner(Scan)
getScanner(String[], String, String, long) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.getScanner(Scan)
getScanner(byte[][], byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.getScanner(Scan)
getScanner(String[], String, long, RowFilterInterface) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.getScanner(Scan)
getScanner(byte[][], byte[], long, RowFilterInterface) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. As of hbase 0.20.0, replaced by HTable.getScanner(Scan)
getScanner(TransactionState, Scan) - Method in class org.apache.hadoop.hbase.client.transactional.TransactionalTable
 
getScanner(boolean, boolean) - Method in class org.apache.hadoop.hbase.io.HalfHFileReader
 
getScanner(boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.Reader
Create a Scanner on this file.
getScanner(Scan) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Return an iterator that scans over the HRegion, returning the indicated columns and rows specified by the Scan.
getScanner(Scan, List<KeyValueScanner>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getScanner(Scan, NavigableSet<byte[]>) - Method in class org.apache.hadoop.hbase.regionserver.Store
Return a scanner for both the memstore and the HStore files
getScanner(long, Scan) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegion
Get a transactional scanner.
getScanner(Integer) - Method in class org.apache.hadoop.hbase.rest.ScannerModel.ScannerMaster
 
getScanner(Scan) - Method in class org.apache.hadoop.hbase.stargate.client.RemoteHTable
 
getScanner(byte[]) - Method in class org.apache.hadoop.hbase.stargate.client.RemoteHTable
 
getScanner(byte[], byte[]) - Method in class org.apache.hadoop.hbase.stargate.client.RemoteHTable
 
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
Gets the number of rows that a scanner will fetch at once.
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
 
getScannerDescriptor(byte[]) - Method in interface org.apache.hadoop.hbase.rest.parser.IHBaseRestParser
 
getScannerDescriptor(byte[]) - Method in class org.apache.hadoop.hbase.rest.parser.XMLRestParser
 
getScannerInstanceResource(String) - Method in class org.apache.hadoop.hbase.stargate.ScannerResource
 
getScannerResource() - Method in class org.apache.hadoop.hbase.stargate.TableResource
 
getSchemaResource() - Method in class org.apache.hadoop.hbase.stargate.TableResource
 
getSecond() - Method in class org.apache.hadoop.hbase.util.Pair
Return the second element stored in the pair.
getSeekColumn() - Method in class org.apache.hadoop.hbase.regionserver.QueryMatcher
If matcher returns SEEK_NEXT_COL you may be able to get a hint of the next column to seek to - call this.
getSequenceNumber() - Method in class org.apache.hadoop.hbase.regionserver.HLog
 
getSerializedSize(HStoreKey) - Static method in class org.apache.hadoop.hbase.HStoreKey
Deprecated.  
getSerializedSize() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 
getSerializer(HttpServletRequest, HttpServletResponse) - Static method in class org.apache.hadoop.hbase.rest.serializer.RestSerializerFactory
 
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
 
getServerAddressToServerInfo() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getServerInfo() - Method in class org.apache.hadoop.hbase.ClusterStatus
Returns detailed region server information: A list of HServerInfo, containing server load and resource usage statistics as HServerLoad, containing per-region statistics as HServerLoad.RegionLoad.
getServerManager() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getServerName() - Method in class org.apache.hadoop.hbase.client.ServerCallable
 
getServerName() - Method in class org.apache.hadoop.hbase.HServerInfo
 
getServerName(String, long) - Static method in class org.apache.hadoop.hbase.HServerInfo
 
getServerName(HServerAddress, long) - Static method in class org.apache.hadoop.hbase.HServerInfo
 
getServerNames() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getServers() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getServerStats(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWrapper
Gets the statistics from the given server.
getServerStats(String, int) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWrapper
Gets the statistics from the given server.
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
 
getServerVersion() - Method in class org.apache.hadoop.hbase.stargate.model.VersionModel
 
getServerVersion() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version.Builder
 
getServerVersion() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 
getSessionID() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWrapper
This is for testing KeeperException.SessionExpiredException.
getSessionPassword() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWrapper
This is for testing KeeperException.SessionExpiredException.
getSimilarityName() - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
Deprecated.  
getSimilarityName() - Method in class org.apache.hadoop.hbase.mapreduce.IndexConfiguration
 
getSize() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
getSize() - Method in class org.apache.hadoop.hbase.regionserver.Store
 
getSize(Object, Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.hadoop.hbase.stargate.provider.producer.PlainTextMessageBodyProducer
 
getSize(ProtobufMessageHandler, Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.hadoop.hbase.stargate.provider.producer.ProtobufMessageBodyProducer
 
getSortedOnlineRegionInfos() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getSplitKey() - Method in class org.apache.hadoop.hbase.io.Reference
 
getSplits(JobConf, int) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Deprecated. Calculates the splits that will serve as input for the map tasks.
getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Calculates the splits that will serve as input for the map tasks.
getStargateVersion() - Method in class org.apache.hadoop.hbase.stargate.model.VersionModel
 
getStargateVersion() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version.Builder
 
getStargateVersion() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 
getStargateVersionResource() - Method in class org.apache.hadoop.hbase.stargate.VersionResource
Dispatch /version/stargate to self.
getStartCode() - Method in class org.apache.hadoop.hbase.HServerInfo
 
getStartCode() - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel.Node
 
getStartCode() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
getStartCode() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
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
 
getStartKey() - Method in class org.apache.hadoop.hbase.regionserver.QueryMatcher
 
getStartKey() - Method in class org.apache.hadoop.hbase.stargate.model.TableRegionModel
 
getStartKey() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
getStartKey() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
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.client.Scan
 
getStartRow() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
Deprecated.  
getStartRow() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Returns the start row.
getStartRow() - Method in class org.apache.hadoop.hbase.rest.descriptors.ScannerDescriptor
 
getStartRow() - Method in class org.apache.hadoop.hbase.stargate.model.ScannerModel
 
getStartRow() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
getStartRow() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
getStartRow() - Method in class org.apache.hadoop.hbase.stargate.RowSpec
 
getStartTime() - Method in class org.apache.hadoop.hbase.stargate.model.ScannerModel
 
getStartTime() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
getStartTime() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
getStartTime() - Method in class org.apache.hadoop.hbase.stargate.RowSpec
 
getStats() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Get counter statistics for this cache.
getStatusCode() - Method in class org.apache.hadoop.hbase.rest.Status
 
getStatusCode() - Method in class org.apache.hadoop.hbase.rest.Status.StatusMessage
 
getStatusForTransaction(long) - Method in class org.apache.hadoop.hbase.client.transactional.HBaseBackedTransactionLogger
 
getStatusForTransaction(long) - Method in class org.apache.hadoop.hbase.client.transactional.LocalTransactionLogger
 
getStatusForTransaction(long) - Method in interface org.apache.hadoop.hbase.client.transactional.TransactionLogger
Get the status of a transaction.
getStopRow() - Method in class org.apache.hadoop.hbase.client.Scan
 
getStopRow() - Method in class org.apache.hadoop.hbase.rest.descriptors.ScannerDescriptor
 
getStopRow(byte[]) - Method in class org.apache.hadoop.hbase.rest.ScannerController
 
getStopRowKey() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
getStopRowKey() - Method in class org.apache.hadoop.hbase.filter.StopRowFilter
Deprecated. An accessor for the stopRowKey
getStopRowUnionFilter(byte[], RowFilterInterface) - Method in class org.apache.hadoop.hbase.rest.ScannerController
 
getStore(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Return HStore instance.
getStoreFile(HFileScanner, List<KeyValue>) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileGetScan
Performs a GET operation on a single StoreFile.
getStorefileIndexSizeInMB() - Method in class org.apache.hadoop.hbase.HServerLoad
 
getStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
 
getStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel.Node.Region
 
getStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
getStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
getStorefiles() - Method in class org.apache.hadoop.hbase.HServerLoad
 
getStorefiles() - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
 
getStorefiles() - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel.Node.Region
 
getStorefiles() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
getStorefiles() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
getStorefileSizeInMB() - Method in class org.apache.hadoop.hbase.HServerLoad
 
getStorefileSizeMB() - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
 
getStorefileSizeMB() - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel.Node.Region
 
getStorefileSizeMB() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
getStorefileSizeMB() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
getStoreFlusher(long) - Method in class org.apache.hadoop.hbase.regionserver.Store
 
getStoreHomedir(Path, int, byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.Store
 
getStores() - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
 
getStores() - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel.Node.Region
 
getStores() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
getStores() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
getSupportedCompressionAlgorithms() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
Get names of supported compression algorithms.
getSyncOps() - Static method in class org.apache.hadoop.hbase.regionserver.HLog
 
getSyncTime() - Static method in class org.apache.hadoop.hbase.regionserver.HLog
 
getTable(String) - Method in class org.apache.hadoop.hbase.client.HTablePool
Get a reference to the specified table from the pool.
getTable(byte[]) - Method in class org.apache.hadoop.hbase.client.HTablePool
Get a reference to the specified table from the pool.
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(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Method for getting the tableDescriptor
getTableDescriptor() - Method in class org.apache.hadoop.hbase.client.HTable
Gets the table descriptor for this table.
getTableDescriptor(byte[]) - Method in interface org.apache.hadoop.hbase.rest.parser.IHBaseRestParser
Parses a HTableDescriptor given the input array.
getTableDescriptor(byte[]) - Method in class org.apache.hadoop.hbase.rest.parser.XMLRestParser
 
getTableDescriptor() - Method in class org.apache.hadoop.hbase.stargate.client.RemoteHTable
 
getTableDescriptor() - Method in class org.apache.hadoop.hbase.stargate.model.TableSchemaModel
 
getTableDir(Path, byte[]) - Static method in class org.apache.hadoop.hbase.HTableDescriptor
 
getTableMetadata(String) - Method in class org.apache.hadoop.hbase.rest.TableModel
Get table metadata.
getTableName() - Method in class org.apache.hadoop.hbase.client.HTable
Gets the name of this table.
getTableName() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
Deprecated.  
getTableName() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Returns the table name.
getTablename() - Method in class org.apache.hadoop.hbase.regionserver.HLogKey
 
getTableName() - Method in class org.apache.hadoop.hbase.rest.descriptors.RowUpdateDescriptor
 
getTableName() - Method in class org.apache.hadoop.hbase.stargate.client.RemoteHTable
 
getTableNames() - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
getTableRegions(String) - Method in class org.apache.hadoop.hbase.rest.TableModel
Return region offsets.
getTableRegions(byte[]) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
getTableResource(String) - Method in class org.apache.hadoop.hbase.stargate.RootResource
 
getTables() - Method in class org.apache.hadoop.hbase.rest.DatabaseModel.DatabaseMetadata
 
getTables() - Method in class org.apache.hadoop.hbase.stargate.model.TableListModel
 
getTailPtr() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Get the tail of the linked list (most recently used).
getThreadLocalTransactionState() - Method in class org.apache.hadoop.hbase.client.transactional.JtaXAResource
 
getThreadReadPoint() - Static method in class org.apache.hadoop.hbase.regionserver.ReadWriteConsistencyControl
 
getTimeRange() - Method in class org.apache.hadoop.hbase.client.Get
Method for retrieving the get's TimeRange
getTimeRange() - Method in class org.apache.hadoop.hbase.client.Scan
 
getTimeRange() - Method in class org.apache.hadoop.hbase.regionserver.QueryMatcher
 
getTimeStamp() - Method in class org.apache.hadoop.hbase.client.Delete
Method for retrieving the delete's timestamp
getTimestamp() - Method in class org.apache.hadoop.hbase.client.HTable.ClientScanner
 
getTimeStamp() - Method in class org.apache.hadoop.hbase.client.Put
 
getTimestamp() - Method in class org.apache.hadoop.hbase.HStoreKey
Deprecated.  
getTimestamp(ByteBuffer) - Static method in class org.apache.hadoop.hbase.HStoreKey
Deprecated.  
getTimestamp() - Method in class org.apache.hadoop.hbase.io.BatchUpdate
Deprecated.  
getTimestamp() - Method in class org.apache.hadoop.hbase.io.Cell
Deprecated.  
getTimestamp() - Method in class org.apache.hadoop.hbase.KeyValue
 
getTimestamp() - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
 
getTimestamp() - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey.BeforeThisStoreKey
 
getTimestamp() - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey
 
getTimestamp() - Method in class org.apache.hadoop.hbase.rest.descriptors.ScannerDescriptor
 
getTimestamp() - Method in class org.apache.hadoop.hbase.stargate.model.CellModel
 
getTimestamp() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell.Builder
 
getTimestamp() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell
 
getTimestamp() - Method in class org.apache.hadoop.hbase.stargate.RowSpec
 
getTimestampOffset() - Method in class org.apache.hadoop.hbase.KeyValue
 
getTimestampOffset(int) - Method in class org.apache.hadoop.hbase.KeyValue
 
getTimestamps() - Method in class org.apache.hadoop.hbase.rest.descriptors.TimestampsDescriptor
 
getTimestamps(byte[], byte[]) - Method in class org.apache.hadoop.hbase.rest.RowModel
 
getTimeToLive() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getTotalBytes() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.Writer
 
getTotalColumnLength() - Method in class org.apache.hadoop.hbase.KeyValue
 
getTotalColumnLength(int, int) - Method in class org.apache.hadoop.hbase.KeyValue
 
getTrailerInfo() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
getTransactionalLeases() - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegionServer
 
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.transactional.THLogKey
 
getTransactionState(long) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegion
 
getTransactionTimeout() - Method in class org.apache.hadoop.hbase.client.transactional.JtaXAResource
 
getTrxOp() - Method in class org.apache.hadoop.hbase.regionserver.transactional.THLogKey
 
getTtl() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
getTtl() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
getType() - Method in class org.apache.hadoop.hbase.HMsg
 
getType() - Method in class org.apache.hadoop.hbase.KeyValue
 
getType() - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
 
getUniqueFile(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
getUrl() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
Get the subversion URL for the root hbase directory.
getUsedHeapMB() - Method in class org.apache.hadoop.hbase.HServerLoad
 
getUser() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
The user that compiled hbase.
getValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
Get the latest version of the specified column.
getValue(byte[]) - Method in class org.apache.hadoop.hbase.client.Result
Get the latest version of the specified column, using
getValue(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
 
getValue(String) - Method in class org.apache.hadoop.hbase.client.Scan
 
getValue() - Method in class org.apache.hadoop.hbase.filter.SubstringComparator
 
getValue() - Method in class org.apache.hadoop.hbase.filter.WritableByteArrayComparable
 
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
Deprecated.  
getValue() - Method in class org.apache.hadoop.hbase.io.Cell
Deprecated.  
getValue() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
Gets a buffer view to the current value.
getValue() - Method in class org.apache.hadoop.hbase.io.RowResult.Entry
Deprecated.  
getValue() - Method in class org.apache.hadoop.hbase.KeyValue
Returns value in a new byte array.
getValue() - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
 
getValue() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
Get the value of this entry.
getValue() - Method in class org.apache.hadoop.hbase.stargate.model.CellModel
 
getValue() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
getValue() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
getValue() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
getValue() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
getValueLength() - Method in class org.apache.hadoop.hbase.KeyValue
 
getValueOffset() - Method in class org.apache.hadoop.hbase.KeyValue
 
getValues() - Method in class org.apache.hadoop.hbase.client.Scan
 
getValues() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getValues() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
getValues(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
getValues(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row
 
getValuesCount() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
getValuesCount() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row
 
getValuesList() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
getValuesList() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row
 
getValueString() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
Convenience method to get a copy of the value as a string - interpreting the bytes as UTF8.
getVectorSize() - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.BloomFilter
 
getVer(byte[], byte[], byte[], int) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
Deprecated. 
getVer(byte[], byte[], byte[], byte[], int) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
getVersion() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getVersion() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getVersion() - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterVersionModel
 
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.
getVersionResource() - Method in class org.apache.hadoop.hbase.stargate.RootResource
 
getVerTs(byte[], byte[], byte[], long, int) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
Deprecated. 
getVerTs(byte[], 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.
getWeight() - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.Key
 
getWritable(byte[], Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
Set bytes into the passed Writable by calling its Writable.readFields(java.io.DataInput).
getWritable(byte[], int, int, Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
Set bytes into the passed Writable by calling its Writable.readFields(java.io.DataInput).
getWritableComparator(HRegionInfo) - Static method in class org.apache.hadoop.hbase.HStoreKey
Deprecated.  
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
getWriteOps() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
 
getWriteOps() - Static method in class org.apache.hadoop.hbase.regionserver.HLog
 
getWriter(FileSystem, SequenceFile.CompressionType, boolean, int) - Method in class org.apache.hadoop.hbase.migration.nineteen.regionserver.HStoreFile
Get a store file writer.
getWriter(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFile
Get a store file writer.
getWriter(FileSystem, Path, int, Compression.Algorithm, KeyValue.KeyComparator) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFile
Get a store file writer.
getWriteTime() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
 
getWriteTime() - Static method in class org.apache.hadoop.hbase.regionserver.HLog
 
getWriteTime() - Method in class org.apache.hadoop.hbase.regionserver.HLogKey
 
getWriteToWAL() - Method in class org.apache.hadoop.hbase.client.Put
 
getXAResource() - Method in class org.apache.hadoop.hbase.client.transactional.TransactionManager
 
getZooKeeper() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWrapper
 
getZooKeeperWrapper() - Method in interface org.apache.hadoop.hbase.client.HConnection
Retrieve ZooKeeperWrapper used by the connection.
getZooKeeperWrapper() - Method in class org.apache.hadoop.hbase.client.HConnectionManager.ClientZKWatcher
Get this watcher's ZKW, instanciate it if necessary.
getZooKeeperWrapper() - Method in class org.apache.hadoop.hbase.master.HMaster
Get the ZK wrapper object
getZooKeeperWrapper() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
GROUP_COLUMNS - Static variable in class org.apache.hadoop.hbase.mapred.GroupingTableMap
Deprecated. JobConf parameter to specify the columns used to produce the key passed to collect from the map phase
GROUP_COLUMNS - Static variable in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
JobConf parameter to specify the columns used to produce the key passed to collect from the map phase.
GroupingTableMap - Class in org.apache.hadoop.hbase.mapred
Deprecated. 
GroupingTableMap() - Constructor for class org.apache.hadoop.hbase.mapred.GroupingTableMap
Deprecated.  
GroupingTableMapper - Class in org.apache.hadoop.hbase.mapreduce
Extract grouping columns from input record.
GroupingTableMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
 
GZIP - Static variable in class org.apache.hadoop.hbase.util.Base64
Specify that data should be gzip-compressed.

H

HalfHFileReader - Class in org.apache.hadoop.hbase.io
A facade for a HFile.Reader that serves up either the top or bottom half of a HFile 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.
HalfHFileReader(FileSystem, Path, BlockCache, Reference) - Constructor for class org.apache.hadoop.hbase.io.HalfHFileReader
 
HalfMapFileReader - Class in org.apache.hadoop.hbase.migration.nineteen.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.migration.nineteen.io.HalfMapFileReader
 
HalfMapFileReader(FileSystem, String, Configuration, Reference.Range, WritableComparable<HStoreKey>, boolean, boolean, HRegionInfo) - Constructor for class org.apache.hadoop.hbase.migration.nineteen.io.HalfMapFileReader
 
has(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
A convenience method to determine if this object's familyMap contains a value assigned to the given family & qualifier.
has(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Put
A convenience method to determine if this object's familyMap contains a value assigned to the given family, qualifier and timestamp.
has(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
A convenience method to determine if this object's familyMap contains a value assigned to the given family, qualifier and timestamp.
has(byte[], byte[], long, byte[]) - Method in class org.apache.hadoop.hbase.client.Put
A convenience method to determine if this object's familyMap contains the given value assigned to the given family, qualifier and timestamp.
hasAverageLoad() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
hasAverageLoad() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
hasBatch() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
hasBatch() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
hasBody() - Method in class org.apache.hadoop.hbase.stargate.client.Response
 
hasColumn(String) - Method in class org.apache.hadoop.hbase.io.BatchUpdate
Deprecated. Check if the specified column is currently assigned a value
hasColumn(byte[]) - Method in class org.apache.hadoop.hbase.io.BatchUpdate
Deprecated. Check if the specified column is currently assigned a value
hasColumn() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell.Builder
 
hasColumn() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell
 
hasColumns() - Method in class org.apache.hadoop.hbase.stargate.RowSpec
 
hasCompression() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
hasCompression() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
hasData() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell.Builder
 
hasData() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell
 
hasEndKey() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
hasEndKey() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
hasEndRow() - Method in class org.apache.hadoop.hbase.stargate.model.ScannerModel
 
hasEndRow() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
hasEndRow() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
hasEndRow() - Method in class org.apache.hadoop.hbase.stargate.RowSpec
 
hasEndTime() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
hasEndTime() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
hasFamilies() - Method in class org.apache.hadoop.hbase.client.Get
Method for checking if any families have been inserted into this Get
hasFamilies() - Method in class org.apache.hadoop.hbase.client.Scan
 
hasFamily(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Checks to see if this table contains the given column family
hasFilter() - Method in class org.apache.hadoop.hbase.client.Scan
 
hasFilter() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
hasFilter() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
hash - Variable in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.Filter
The hash function used to map a key to several positions in the vector.
hash(Key) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.HashFunction
Hashes a specified key into several integers.
hash - Variable in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
The hash value for this entries key
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.ClusterStatus
 
hashCode() - Method in class org.apache.hadoop.hbase.HBaseConfiguration
Returns the hash code value for this HBaseConfiguration.
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
Deprecated.  
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.master.MetaRegion
 
hashCode() - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey.BeforeThisStoreKey
 
hashCode() - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey
 
hashCode() - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.Key
 
hashCode() - Method in class org.apache.hadoop.hbase.regionserver.HLogKey
 
hashCode() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
hashCode() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
Returns the hash code of the entry by xor'ing the hash values of the key and value of this entry.
hashCode() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Intentionally unimplemented.
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
 
hasHeapSizeMB() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
hasHeapSizeMB() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
HashFunction - Class in org.apache.hadoop.hbase.migration.nineteen.onelab.filter
Implements a hash object that returns a certain number of hashed values.
HashFunction(int, int, int) - Constructor for class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.HashFunction
Constructor.
hashType - Variable in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.Filter
Type of hashing function to use.
hasId() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
hasId() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
hasInMemory() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
hasInMemory() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
hasJerseyVersion() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version.Builder
 
hasJerseyVersion() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 
hasJvmVersion() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version.Builder
 
hasJvmVersion() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 
hasKey() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
hasKey() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row
 
hasLocation() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
hasLocation() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
hasMaxHeapSizeMB() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
hasMaxHeapSizeMB() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
hasMaxVersions() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
hasMaxVersions() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
hasMaxVersions() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
hasMaxVersions() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
hasMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
hasMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
hasName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
hasName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
hasName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
hasName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
hasName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
hasName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
hasName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
hasName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
hasName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
hasName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo
 
hasName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
hasName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
hasName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
hasName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
hasName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
hasName() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
hasNext() - Method in class org.apache.hadoop.hbase.stargate.RowResultGenerator
 
hasNext() - Method in class org.apache.hadoop.hbase.stargate.ScannerResultGenerator
 
hasOsVersion() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version.Builder
 
hasOsVersion() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 
hasReadOnly() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
hasReadOnly() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
hasRegions() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
hasRegions() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
hasRequests() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
hasRequests() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
hasRequests() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
hasRequests() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
hasRow() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell.Builder
 
hasRow() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell
 
hasServerVersion() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version.Builder
 
hasServerVersion() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 
hasStargateVersion() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version.Builder
 
hasStargateVersion() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 
hasStartCode() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
hasStartCode() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
hasStartKey() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
hasStartKey() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
hasStartRow() - Method in class org.apache.hadoop.hbase.stargate.model.ScannerModel
 
hasStartRow() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
hasStartRow() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
hasStartTime() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
hasStartTime() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
hasStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
hasStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
hasStorefiles() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
hasStorefiles() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
hasStorefileSizeMB() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
hasStorefileSizeMB() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
hasStores() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
hasStores() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
hasTimestamp() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell.Builder
 
hasTimestamp() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell
 
hasTimestamp() - Method in class org.apache.hadoop.hbase.stargate.RowSpec
 
hasTooManyStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Checks every store to see if one has too many store files
hasTooManyStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.Store
See if there's too much store files in this store
hasTtl() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
hasTtl() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
hasUserTimestamp() - Method in class org.apache.hadoop.hbase.stargate.model.CellModel
 
hasValue() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
hasValue() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
hasValue() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
hasValue() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
haveRootRegion - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
HBASE_CLIENT_RETRIES_NUMBER_KEY - Static variable in interface org.apache.hadoop.hbase.HConstants
The key used to store the number of times a client should retry before giving up.
HBASE_CLIENT_SCANNER_MAX_RESULT_SIZE_KEY - Static variable in interface org.apache.hadoop.hbase.HConstants
Parameter name for maximum number of bytes returned when calling a scanner's next method.
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
HBaseBackedTransactionLogger - Class in org.apache.hadoop.hbase.client.transactional
 
HBaseBackedTransactionLogger() - Constructor for class org.apache.hadoop.hbase.client.transactional.HBaseBackedTransactionLogger
 
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.migration.nineteen.io
HBase customizations of MapFile.
HBaseMapFile() - Constructor for class org.apache.hadoop.hbase.migration.nineteen.io.HBaseMapFile
 
HBaseMapFile.HBaseReader - Class in org.apache.hadoop.hbase.migration.nineteen.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.migration.nineteen.io.HBaseMapFile.HBaseReader
 
HBaseMapFile.HBaseReader(FileSystem, String, Configuration, boolean, HRegionInfo) - Constructor for class org.apache.hadoop.hbase.migration.nineteen.io.HBaseMapFile.HBaseReader
 
HBaseMapFile.HBaseWriter - Class in org.apache.hadoop.hbase.migration.nineteen.io
 
HBaseMapFile.HBaseWriter(Configuration, FileSystem, String, SequenceFile.CompressionType, HRegionInfo) - Constructor for class org.apache.hadoop.hbase.migration.nineteen.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
The default contructor where a TreeMap is used
HbaseMapWritable(SortedMap<byte[], V>) - Constructor for class org.apache.hadoop.hbase.io.HbaseMapWritable
Contructor where another SortedMap can be used
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
 
HBaseRestException - Exception in org.apache.hadoop.hbase.rest.exception
 
HBaseRestException() - Constructor for exception org.apache.hadoop.hbase.rest.exception.HBaseRestException
 
HBaseRestException(Exception) - Constructor for exception org.apache.hadoop.hbase.rest.exception.HBaseRestException
 
HBaseRestException(String) - Constructor for exception org.apache.hadoop.hbase.rest.exception.HBaseRestException
 
HBaseRestException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.rest.exception.HBaseRestException
 
HBaseRestParserFactory - Class in org.apache.hadoop.hbase.rest.parser
 
HBaseRestParserFactory() - Constructor for class org.apache.hadoop.hbase.rest.parser.HBaseRestParserFactory
 
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) - 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.
HBaseRPCStatistics - Class in org.apache.hadoop.hbase.ipc
Exports HBase RPC statistics recorded in HBaseRpcMetrics as an MBean for JMX monitoring.
HBaseRPCStatistics(MetricsRegistry, String, String) - Constructor for class org.apache.hadoop.hbase.ipc.HBaseRPCStatistics
 
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, String, boolean, boolean, int, boolean) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Constructor
HColumnDescriptor(byte[], int, String, boolean, boolean, int, int, boolean) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Constructor
HColumnDescriptor.CompressionType - Enum in org.apache.hadoop.hbase
Deprecated. Compression now means which compression library rather than 'what' to compress.
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
 
HConnectionManager.ClientZKWatcher - Class in org.apache.hadoop.hbase.client
This class is responsible to handle connection and reconnection to a zookeeper quorum.
HConnectionManager.ClientZKWatcher(HBaseConfiguration) - Constructor for class org.apache.hadoop.hbase.client.HConnectionManager.ClientZKWatcher
Takes a configuration to pass it to ZKW but won't instanciate it
HConstants - Interface in org.apache.hadoop.hbase
HConstants holds a bunch of HBase-related constants
HConstants.Modify - Enum in org.apache.hadoop.hbase
modifyTable op for replacing the table descriptor
head(String) - Method in class org.apache.hadoop.hbase.stargate.client.Client
Send a HEAD request
head(Cluster, String, Header[]) - Method in class org.apache.hadoop.hbase.stargate.client.Client
Send a HEAD request
head(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
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
Deprecated.  
headMap(K) - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
heapSize() - Method in class org.apache.hadoop.hbase.client.Put
 
heapSize() - Method in class org.apache.hadoop.hbase.HStoreKey
Deprecated.  
heapSize() - Method in class org.apache.hadoop.hbase.io.BatchOperation
Deprecated.  
heapSize() - Method in class org.apache.hadoop.hbase.io.BatchUpdate
Deprecated.  
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
 
heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.CachedBlock
 
heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.CachedBlockQueue
Total size of all elements in this queue.
heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
heapSize() - Method in class org.apache.hadoop.hbase.KeyValue
 
heapSize() - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey.BeforeThisStoreKey
 
heapSize() - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey
 
heapSize() - Method in class org.apache.hadoop.hbase.regionserver.HLogKey
 
heapSize() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
heapSize - Variable in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
The precomputed heap size of this entry
heapSize() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
Returns the pre-computed and "deep" size of the Entry
heapSize() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
The total memory usage of this map
heapSize() - Method in class org.apache.hadoop.hbase.regionserver.MemStore
Get the entire heap usage for this MemStore not including keys in the snapshot.
heapSize() - Method in class org.apache.hadoop.hbase.regionserver.Store
 
HEAPSIZEMB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
HFile - Class in org.apache.hadoop.hbase.io.hfile
File format for hbase.
HFile() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFile
 
HFile.Reader - Class in org.apache.hadoop.hbase.io.hfile
HFile Reader.
HFile.Reader(FileSystem, Path, BlockCache, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFile.Reader
Opens a HFile.
HFile.Reader(FSDataInputStream, long, BlockCache, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFile.Reader
Opens a HFile.
HFile.Writer - Class in org.apache.hadoop.hbase.io.hfile
HFile Writer.
HFile.Writer(FileSystem, Path) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFile.Writer
Constructor that uses all defaults for compression and block size.
HFile.Writer(FileSystem, Path, int, String, RawComparator<byte[]>) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFile.Writer
Constructor that takes a Path.
HFile.Writer(FileSystem, Path, int, Compression.Algorithm, RawComparator<byte[]>) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFile.Writer
Constructor that takes a Path.
HFile.Writer(FSDataOutputStream, int, String, RawComparator<byte[]>) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFile.Writer
Constructor that takes a stream.
HFile.Writer(FSDataOutputStream, int, Compression.Algorithm, RawComparator<byte[]>) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFile.Writer
Constructor that takes a stream.
HFileOutputFormat - Class in org.apache.hadoop.hbase.mapreduce
Writes HFiles.
HFileOutputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat
 
HFileScanner - Interface in org.apache.hadoop.hbase.io.hfile
A scanner allows you to position yourself within a HFile and scan through it.
hit() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache.CacheStats
 
HLog - Class in org.apache.hadoop.hbase.regionserver
HLog stores all the edits to the HStore.
HLog(FileSystem, Path, HBaseConfiguration, LogRollListener) - Constructor for class org.apache.hadoop.hbase.regionserver.HLog
Create an edit log at the given dir location.
hlog - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
HLog.HLogEntry - Class in org.apache.hadoop.hbase.regionserver
Utility class that lets us keep track of the edit with it's key Only used when splitting logs
HLog.HLogEntry(KeyValue, HLogKey) - Constructor for class org.apache.hadoop.hbase.regionserver.HLog.HLogEntry
Constructor for both params
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
Writable Consructor -- Do not use.
HLogKey(byte[], byte[], long, 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.
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, byte[]) - Constructor for class org.apache.hadoop.hbase.HMsg
Construct a message with the specified message and HRegionInfo
HMsg(HMsg.Type, HRegionInfo, HRegionInfo, HRegionInfo, byte[]) - Constructor for class org.apache.hadoop.hbase.HMsg
Construct a message with the specified message and HRegionInfo
HMsg.Type - Enum in org.apache.hadoop.hbase
Message types sent between master and regionservers
HQuorumPeer - Class in org.apache.hadoop.hbase.zookeeper
HBase's version of ZooKeeper's QuorumPeer.
HQuorumPeer() - Constructor for class org.apache.hadoop.hbase.zookeeper.HQuorumPeer
 
HRegion - Class in org.apache.hadoop.hbase.regionserver
HRegion stores data for a certain region of a table.
HRegion() - Constructor for class org.apache.hadoop.hbase.regionserver.HRegion
Should only be used for testing purposes
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 Use '.' as a special character to seperate the log files from table data
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
Deprecated. 
HRegionPartitioner() - Constructor for class org.apache.hadoop.hbase.mapred.HRegionPartitioner
Deprecated.  
HRegionPartitioner<KEY,VALUE> - Class in org.apache.hadoop.hbase.mapreduce
This is used to partition the output keys into groups of keys.
HRegionPartitioner() - Constructor for class org.apache.hadoop.hbase.mapreduce.HRegionPartitioner
 
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
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, int) - Constructor for class org.apache.hadoop.hbase.HServerLoad.RegionLoad
 
HStoreFile - Class in org.apache.hadoop.hbase.migration.nineteen.regionserver
A HStore data file.
HStoreFile(HBaseConfiguration, FileSystem, Path, int, byte[], long, Reference) - Constructor for class org.apache.hadoop.hbase.migration.nineteen.regionserver.HStoreFile
Constructor that fully initializes the object
HStoreFileToStoreFile - Class in org.apache.hadoop.hbase.migration.nineteen
Mapper that rewrites hbase 0.19 HStoreFiles as 0.20 StoreFiles.
HStoreFileToStoreFile.Map - Class in org.apache.hadoop.hbase.migration.nineteen
 
HStoreFileToStoreFile.Map() - Constructor for class org.apache.hadoop.hbase.migration.nineteen.HStoreFileToStoreFile.Map
 
HStoreKey - Class in org.apache.hadoop.hbase
Deprecated. Replaced by KeyValue.
HStoreKey() - Constructor for class org.apache.hadoop.hbase.HStoreKey
Deprecated. Default constructor used in conjunction with Writable interface
HStoreKey(byte[]) - Constructor for class org.apache.hadoop.hbase.HStoreKey
Deprecated. 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
Deprecated. 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[], long) - Constructor for class org.apache.hadoop.hbase.HStoreKey
Deprecated. 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
Deprecated. 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
Deprecated. Create an HStoreKey specifying the row and column names The timestamp defaults to LATEST_TIMESTAMP and table name defaults to the empty string
HStoreKey(String, String, long) - Constructor for class org.apache.hadoop.hbase.HStoreKey
Deprecated. 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
Deprecated. 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
Deprecated. Constructs a new HStoreKey from another
HStoreKey(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.HStoreKey
Deprecated.  
HStoreKey - Class in org.apache.hadoop.hbase.migration.nineteen
A Key for a stored row.
HStoreKey() - Constructor for class org.apache.hadoop.hbase.migration.nineteen.HStoreKey
Default constructor used in conjunction with Writable interface
HStoreKey(byte[]) - Constructor for class org.apache.hadoop.hbase.migration.nineteen.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.migration.nineteen.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.migration.nineteen.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.migration.nineteen.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.migration.nineteen.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.migration.nineteen.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.migration.nineteen.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.migration.nineteen.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.migration.nineteen.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.migration.nineteen.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.migration.nineteen.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.migration.nineteen.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.migration.nineteen.HStoreKey
Constructs a new HStoreKey from another
HStoreKey.BeforeThisStoreKey - Class in org.apache.hadoop.hbase.migration.nineteen
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.migration.nineteen.HStoreKey.BeforeThisStoreKey
 
HStoreKey.HStoreKeyComparator - Class in org.apache.hadoop.hbase
Deprecated. Passed as comparator for memcache and for store files.
HStoreKey.HStoreKeyComparator() - Constructor for class org.apache.hadoop.hbase.HStoreKey.HStoreKeyComparator
Deprecated.  
HStoreKey.HStoreKeyMetaComparator - Class in org.apache.hadoop.hbase
Deprecated. Passed as comparator for memcache and for store files.
HStoreKey.HStoreKeyMetaComparator() - Constructor for class org.apache.hadoop.hbase.HStoreKey.HStoreKeyMetaComparator
Deprecated.  
HStoreKey.HStoreKeyRootComparator - Class in org.apache.hadoop.hbase
Deprecated. Passed as comparator for memcache and for store files.
HStoreKey.HStoreKeyRootComparator() - Constructor for class org.apache.hadoop.hbase.HStoreKey.HStoreKeyRootComparator
Deprecated.  
HStoreKey.HStoreKeyWritableComparator - Class in org.apache.hadoop.hbase.migration.nineteen
Passed as comparator for memcache and for store files.
HStoreKey.HStoreKeyWritableComparator(HRegionInfo) - Constructor for class org.apache.hadoop.hbase.migration.nineteen.HStoreKey.HStoreKeyWritableComparator
 
HStoreKey.MetaStoreKeyComparator - Class in org.apache.hadoop.hbase
Deprecated. StoreKeyComparator for the .META.
HStoreKey.MetaStoreKeyComparator() - Constructor for class org.apache.hadoop.hbase.HStoreKey.MetaStoreKeyComparator
Deprecated.  
HStoreKey.RootStoreKeyComparator - Class in org.apache.hadoop.hbase
Deprecated. StoreKeyComparator for the -ROOT- table.
HStoreKey.RootStoreKeyComparator() - Constructor for class org.apache.hadoop.hbase.HStoreKey.RootStoreKeyComparator
Deprecated.  
HStoreKey.StoreKeyComparator - Class in org.apache.hadoop.hbase
Deprecated. RawComparator for plain -- i.e.
HStoreKey.StoreKeyComparator() - Constructor for class org.apache.hadoop.hbase.HStoreKey.StoreKeyComparator
Deprecated.  
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(Scan) - Constructor for class org.apache.hadoop.hbase.client.HTable.ClientScanner
 
HTable.OldClientScanner - Class in org.apache.hadoop.hbase.client
Scanner implementation made on top of a ResultScanner.
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[], 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.
HTablePool - Class in org.apache.hadoop.hbase.client
A simple pool of HTable instances.
HTablePool() - Constructor for class org.apache.hadoop.hbase.client.HTablePool
Default Constructor.
HTablePool(HBaseConfiguration, int) - Constructor for class org.apache.hadoop.hbase.client.HTablePool
Constructor to set maximum versions and use the specified configuration.

I

ID_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
IdentityTableMap - Class in org.apache.hadoop.hbase.mapred
Deprecated. 
IdentityTableMap() - Constructor for class org.apache.hadoop.hbase.mapred.IdentityTableMap
Deprecated. constructor
IdentityTableMapper - Class in org.apache.hadoop.hbase.mapreduce
Pass the given key and record as-is to the reduce phase.
IdentityTableMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.IdentityTableMapper
 
IdentityTableReduce - Class in org.apache.hadoop.hbase.mapred
Deprecated. 
IdentityTableReduce() - Constructor for class org.apache.hadoop.hbase.mapred.IdentityTableReduce
Deprecated.  
IdentityTableReducer - Class in org.apache.hadoop.hbase.mapreduce
Convenience class that simply writes all values (which must be Put or Delete instances) passed to it out to the configured HBase table.
IdentityTableReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.IdentityTableReducer
 
IHBaseRestParser - Interface in org.apache.hadoop.hbase.rest.parser
 
ImmutableBytesWritable - Class in org.apache.hadoop.hbase.io
A byte sequence that is usable as a key or value.
ImmutableBytesWritable() - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable
Create a zero-size sequence.
ImmutableBytesWritable(byte[]) - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable
Create a ImmutableBytesWritable using the byte array as the initial value.
ImmutableBytesWritable(ImmutableBytesWritable) - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable
Set the new ImmutableBytesWritable to the contents of the passed ibw.
ImmutableBytesWritable(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable
Set the value to a given byte range
ImmutableBytesWritable.Comparator - Class in org.apache.hadoop.hbase.io
A Comparator optimized for ImmutableBytesWritable.
ImmutableBytesWritable.Comparator() - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable.Comparator
constructor
Import - Class in org.apache.hadoop.hbase.mapreduce
Import data written by Export.
Import() - Constructor for class org.apache.hadoop.hbase.mapreduce.Import
 
IN_MEMORY - Static variable in interface org.apache.hadoop.hbase.HConstants
 
inc(String, int) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcMetrics
 
inc(int) - Method in class org.apache.hadoop.hbase.metrics.MetricsRate
 
inc() - Method in class org.apache.hadoop.hbase.metrics.MetricsRate
 
InclusiveStopFilter - Class in org.apache.hadoop.hbase.filter
A Filter that stops after the given row.
InclusiveStopFilter() - Constructor for class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
InclusiveStopFilter(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
InclusiveStopRowFilter - Class in org.apache.hadoop.hbase.filter
Deprecated. Use filters that are rooted on @{link Filter} instead
InclusiveStopRowFilter() - Constructor for class org.apache.hadoop.hbase.filter.InclusiveStopRowFilter
Deprecated. Default constructor, filters nothing.
InclusiveStopRowFilter(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.InclusiveStopRowFilter
Deprecated. Constructor that takes a stopRowKey on which to filter
InclusiveStopRowFilterFactory - Class in org.apache.hadoop.hbase.rest.filter
FilterFactory that construct a InclusiveStopRowFilter from a JSON argument String.
InclusiveStopRowFilterFactory() - Constructor for class org.apache.hadoop.hbase.rest.filter.InclusiveStopRowFilterFactory
 
increment() - Method in class org.apache.hadoop.hbase.regionserver.ColumnCount
Increment the current version count
incrementBytes(byte[], long) - Static method in class org.apache.hadoop.hbase.util.Bytes
Bytewise binary increment/deincrement of long contained in byte array on given amount.
incrementColumnValue(byte[], byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.HTable
Atomically increments a column value.
incrementColumnValue(byte[], byte[], byte[], long, boolean) - Method in class org.apache.hadoop.hbase.client.HTable
Atomically increments a column value.
incrementColumnValue(byte[], byte[], byte[], byte[], long, boolean) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
Atomically increments a column value.
incrementColumnValue(byte[], byte[], byte[], long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
incrementColumnValue(byte[], byte[], byte[], byte[], long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Atomically increments a column value.
incrementColumnValue(byte[], byte[], byte[], long) - Method in class org.apache.hadoop.hbase.stargate.client.RemoteHTable
 
incrementColumnValue(byte[], byte[], byte[], long, boolean) - Method in class org.apache.hadoop.hbase.stargate.client.RemoteHTable
 
incrementRequests(int) - Method in class org.apache.hadoop.hbase.master.metrics.MasterMetrics
 
incrementRequests(int) - Method in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
 
incrementRequests(int) - Method in class org.apache.hadoop.hbase.stargate.metrics.StargateMetrics
 
incrementWeight(double) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.Key
Increments the weight of this key with a specified value.
incrementWeight() - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.Key
Increments the weight of this key by one.
INDEX_BASE_ROW - Static variable in class org.apache.hadoop.hbase.client.tableindexed.IndexedTable
 
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
 
IndexConfiguration - Class in org.apache.hadoop.hbase.mapred
Deprecated. 
IndexConfiguration() - Constructor for class org.apache.hadoop.hbase.mapred.IndexConfiguration
Deprecated.  
IndexConfiguration - Class in org.apache.hadoop.hbase.mapreduce
Configuration parameters for building a Lucene index.
IndexConfiguration() - Constructor for class org.apache.hadoop.hbase.mapreduce.IndexConfiguration
 
IndexConfiguration.ColumnConf - Class in org.apache.hadoop.hbase.mapred
Deprecated.  
IndexConfiguration.ColumnConf() - Constructor for class org.apache.hadoop.hbase.mapred.IndexConfiguration.ColumnConf
Deprecated.  
IndexConfiguration.ColumnConf - Class in org.apache.hadoop.hbase.mapreduce
 
IndexConfiguration.ColumnConf() - Constructor for class org.apache.hadoop.hbase.mapreduce.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
 
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
IndexedTableDescriptor - Class in org.apache.hadoop.hbase.client.tableindexed
 
IndexedTableDescriptor(HTableDescriptor) - Constructor for class org.apache.hadoop.hbase.client.tableindexed.IndexedTableDescriptor
 
IndexKeyGenerator - Interface in org.apache.hadoop.hbase.client.tableindexed
Interface for generating an index-row-key from a row in the base table.
indexLength() - Method in class org.apache.hadoop.hbase.migration.nineteen.regionserver.HStoreFile
 
IndexMaintenanceUtils - Class in org.apache.hadoop.hbase.regionserver.tableindexed
Singleton class for index maintence logic.
IndexMaintenanceUtils() - Constructor for class org.apache.hadoop.hbase.regionserver.tableindexed.IndexMaintenanceUtils
 
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
Deprecated. 
IndexOutputFormat() - Constructor for class org.apache.hadoop.hbase.mapred.IndexOutputFormat
Deprecated.  
IndexOutputFormat - Class in org.apache.hadoop.hbase.mapreduce
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.mapreduce.IndexOutputFormat
 
IndexRecordWriter - Class in org.apache.hadoop.hbase.mapreduce
Writes the records into a Lucene index writer.
IndexRecordWriter(TaskAttemptContext, FileSystem, IndexWriter, IndexConfiguration, Path, Path) - Constructor for class org.apache.hadoop.hbase.mapreduce.IndexRecordWriter
Creates a new instance.
indexSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
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
 
IndexSpecificationArray - Class in org.apache.hadoop.hbase.client.tableindexed
Holds an array of index specifications.
IndexSpecificationArray() - Constructor for class org.apache.hadoop.hbase.client.tableindexed.IndexSpecificationArray
 
IndexSpecificationArray(IndexSpecification[]) - Constructor for class org.apache.hadoop.hbase.client.tableindexed.IndexSpecificationArray
 
IndexTableReduce - Class in org.apache.hadoop.hbase.mapred
Deprecated. 
IndexTableReduce() - Constructor for class org.apache.hadoop.hbase.mapred.IndexTableReduce
Deprecated.  
IndexTableReducer - Class in org.apache.hadoop.hbase.mapreduce
Construct a Lucene document per row, which is consumed by IndexOutputFormat to build a Lucene index
IndexTableReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.IndexTableReducer
 
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
Deprecated. Build the scanner.
init() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase.TableRecordReader
Build the scanner.
init(String, ContextFactory) - Method in class org.apache.hadoop.hbase.metrics.file.TimeStampingFileContext
 
init() - Method in class org.apache.hadoop.hbase.metrics.MetricsMBeanBase
 
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
Deprecated.  
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() - Method in class org.apache.hadoop.hbase.client.HTable.OldClientScanner
 
initialize() - Static method in class org.apache.hadoop.hbase.client.transactional.TransactionalRPC
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase.TableRecordReader
Initializes the reader.
initialize(Path, Progressable) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Initialize this region and get it ready to roll.
initialize(HBaseConfiguration, HBaseAdmin) - Method in class org.apache.hadoop.hbase.rest.AbstractController
 
initialize(HBaseConfiguration, HBaseAdmin) - Method in class org.apache.hadoop.hbase.rest.AbstractModel
 
initialize() - Method in class org.apache.hadoop.hbase.rest.RESTConstants.FactoryMap
 
initJob(String, String, String, Class<? extends TableMap>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
Deprecated. Use this before submitting a TableMap job.
initJob(String, String, Class<? extends TableMap>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.IdentityTableMap
Deprecated. Use this before submitting a TableMap job.
initJob(String, Scan, String, Class<? extends TableMapper>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
Use this before submitting a TableMap job.
initJob(String, Scan, Class<? extends TableMapper>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.IdentityTableMapper
Use this before submitting a TableMap job.
initTableMapJob(String, String, Class<? extends TableMap>, Class<? extends WritableComparable>, Class<? extends Writable>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Deprecated. Use this before submitting a TableMap job.
initTableMapperJob(String, Scan, Class<? extends TableMapper>, Class<? extends WritableComparable>, Class<? extends Writable>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableReduceJob(String, Class<? extends TableReduce>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Deprecated. Use this before submitting a TableReduce job.
initTableReduceJob(String, Class<? extends TableReduce>, JobConf, Class) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Deprecated. Use this before submitting a TableReduce job.
initTableReducerJob(String, Class<? extends TableReducer>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableReduce job.
initTableReducerJob(String, Class<? extends TableReducer>, Job, Class) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableReduce job.
inMemory() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
INMEMORY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
INPUT_TABLE - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Job parameter that specifies the input table.
instance - Variable in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
instantiateHLog(Path) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
instantiateHLog(Path) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegionServer
 
instantiateHStore(Path, HColumnDescriptor, Path, Progressable) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
instantiateInternalScanner(Scan, List<KeyValueScanner>) - 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
 
INTEGER - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for an Integer
internalFlushcache() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Flushing the cache is a little tricky.
internalForceInit() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage
 
internalForceInit() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage
 
internalForceInit() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage
 
internalForceInit() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage
 
internalForceInit() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage
 
internalForceInit() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage
 
internalForceInit() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage
 
internalForceInit() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage
 
internalForceInit() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 
internalGetResult() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell.Builder
 
internalGetResult() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Builder
 
internalGetResult() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
internalGetResult() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
internalGetResult() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
internalGetResult() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
internalGetResult() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
internalGetResult() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
internalGetResult() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
internalGetResult() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
internalGetResult() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
internalGetResult() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList.Builder
 
internalGetResult() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
internalGetResult() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
internalGetResult() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version.Builder
 
internalPreFlushcacheCommit() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
A hook for sub classed wishing to perform operations prior to the cache flush commit stage.
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.
invalidateMaxAge(String) - Method in class org.apache.hadoop.hbase.stargate.RESTServlet
Signal that a previously calculated maximum cache age has been invalidated by a schema change.
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
IRestSerializer - Interface in org.apache.hadoop.hbase.rest.serializer
Interface that is implemented to return serialized objects back to the output stream.
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
Tells whether or not 'auto-flush' is turned on.
isAutoFlush() - Method in class org.apache.hadoop.hbase.stargate.client.RemoteHTable
 
isBadJvmVersion() - Static method in class org.apache.hadoop.hbase.util.JvmVersion
Return true if the current JVM is known to be unstable.
isBlockCacheEnabled() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
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
 
isColumnFamily(byte[]) - Method in class org.apache.hadoop.hbase.rest.AbstractModel
 
isConnected() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWrapper
 
isDelete() - Method in class org.apache.hadoop.hbase.KeyValue
 
isDelete(byte) - Method in class org.apache.hadoop.hbase.regionserver.QueryMatcher
 
isDeleted(byte[], int, int, long) - Method in interface org.apache.hadoop.hbase.regionserver.DeleteTracker
Check if the specified KeyValue buffer has been deleted by a previously seen delete.
isDeleted(byte[], int, int, long) - Method in class org.apache.hadoop.hbase.regionserver.GetDeleteTracker
Check if the specified KeyValue buffer has been deleted by a previously seen delete.
isDeleted(byte[], int, int, long) - Method in class org.apache.hadoop.hbase.regionserver.ScanDeleteTracker
Check if the specified KeyValue buffer has been deleted by a previously seen delete.
isDeleteFamily() - Method in class org.apache.hadoop.hbase.KeyValue
 
isDeleteType() - Method in class org.apache.hadoop.hbase.KeyValue
 
isDone() - Method in class org.apache.hadoop.hbase.regionserver.QueryMatcher
 
isEmpty() - Method in class org.apache.hadoop.hbase.client.Delete
Method to check if the familyMap is empty
isEmpty() - Method in class org.apache.hadoop.hbase.client.Put
Method to check if the familyMap is empty
isEmpty() - Method in class org.apache.hadoop.hbase.client.Result
Check if the underlying KeyValue [] is empty or not
isEmpty() - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
isEmpty() - Method in class org.apache.hadoop.hbase.io.RowResult
Deprecated.  
isEmpty() - Method in interface org.apache.hadoop.hbase.regionserver.DeleteTracker
 
isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.GetDeleteTracker
 
isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Checks whether the map is currently empty.
isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.ScanDeleteTracker
 
isEmpty() - Method in class org.apache.hadoop.hbase.stargate.client.Cluster
 
isEmpty() - Method in class org.apache.hadoop.hbase.util.SoftValueMap
 
isEmpty() - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
isEmptyColumn() - Method in class org.apache.hadoop.hbase.KeyValue
 
ISerializable - Interface in org.apache.hadoop.hbase.rest.serializer
Interface for objects that wish to write back to the REST based interface output stream.
isExpired(long) - Method in class org.apache.hadoop.hbase.regionserver.QueryMatcher
 
isGetScan() - Method in class org.apache.hadoop.hbase.client.Scan
 
isIndex(String) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
Deprecated.  
isIndex(String) - Method in class org.apache.hadoop.hbase.mapreduce.IndexConfiguration
 
isInitialized() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell
 
isInitialized() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet
 
isInitialized() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row
 
isInitialized() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
isInitialized() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
isInitialized() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
isInitialized() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
isInitialized() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
isInitialized() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
isInitialized() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo
 
isInitialized() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
isInitialized() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList
 
isInitialized() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
isInitialized() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
isInitialized() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 
isInMemory() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
isInSafeMode() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
isLatestTimestamp() - Method in class org.apache.hadoop.hbase.KeyValue
 
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
 
isMajorCompacted(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Runs through the hbase rootdir and checks all stores have only one file in them -- that is, they've been major compacted.
isMajorCompactedPre020(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Runs through the hbase rootdir and checks all stores have only one file in them -- that is, they've been major compacted.
isMajorCompaction() - Method in class org.apache.hadoop.hbase.migration.nineteen.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
 
isMasterRunning() - Method in class org.apache.hadoop.hbase.rest.DatabaseModel.DatabaseMetadata
 
isMetaFamily(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
 
isOffline() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
isOmitNorms(String) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
Deprecated.  
isOmitNorms(String) - Method in class org.apache.hadoop.hbase.mapreduce.IndexConfiguration
 
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.
isPre020FileLayout(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Expects to find -ROOT- directory.
isPut() - Method in class org.apache.hadoop.hbase.io.BatchOperation
Deprecated.  
isReadable(Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.hadoop.hbase.stargate.provider.consumer.ProtobufMessageBodyConsumer
 
isReadOnly() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
isReference(Path) - Static method in class org.apache.hadoop.hbase.migration.nineteen.regionserver.HStoreFile
 
isReference(Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
isReference(Path, Matcher) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
isRootRegion() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
isRootRegion() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
isSameRM(XAResource) - Method in class org.apache.hadoop.hbase.client.transactional.JtaXAResource
 
isSeeked() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
 
isSingleRow() - Method in class org.apache.hadoop.hbase.stargate.RowSpec
 
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
Deprecated.  
isStore(String) - Method in class org.apache.hadoop.hbase.mapreduce.IndexConfiguration
 
isTableAvailable(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableAvailable(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableAvailable(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
 
isTableAvailable(String) - Method in class org.apache.hadoop.hbase.stargate.client.RemoteAdmin
 
isTableAvailable(byte[]) - Method in class org.apache.hadoop.hbase.stargate.client.RemoteAdmin
 
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
Tells whether or not a table is enabled or not.
isTableEnabled(byte[]) - Static method in class org.apache.hadoop.hbase.client.HTable
Tells whether or not a table is enabled or not.
isTableEnabled(HBaseConfiguration, String) - Static method in class org.apache.hadoop.hbase.client.HTable
Tells whether or not a table is enabled or not.
isTableEnabled(HBaseConfiguration, byte[]) - Static method in class org.apache.hadoop.hbase.client.HTable
Tells whether or not a table is enabled or not.
isTableEnabled(byte[]) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
isTokenize(String) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
Deprecated.  
isTokenize(String) - Method in class org.apache.hadoop.hbase.mapreduce.IndexConfiguration
 
isTop() - Method in class org.apache.hadoop.hbase.io.HalfHFileReader
 
isTopFileRegion(Reference.Range) - Static method in class org.apache.hadoop.hbase.io.Reference
 
isTopFileRegion(Reference.Range) - Static method in class org.apache.hadoop.hbase.migration.nineteen.io.Reference
 
isType(HMsg.Type) - Method in class org.apache.hadoop.hbase.HMsg
 
isUseCompoundFile() - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
Deprecated.  
isUseCompoundFile() - Method in class org.apache.hadoop.hbase.mapreduce.IndexConfiguration
 
isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.hadoop.hbase.stargate.provider.producer.PlainTextMessageBodyProducer
 
isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.hadoop.hbase.stargate.provider.producer.ProtobufMessageBodyProducer
 
iterator() - Method in class org.apache.hadoop.hbase.client.HTable.ClientScanner
 
iterator() - Method in class org.apache.hadoop.hbase.client.HTable.OldClientScanner
 
iterator() - Method in class org.apache.hadoop.hbase.io.BatchUpdate
Deprecated.  
iterator() - Method in class org.apache.hadoop.hbase.io.Cell
Deprecated.  

J

JAXBContextResolver - Class in org.apache.hadoop.hbase.stargate.provider
Plumbing for hooking up Jersey's JSON entity body encoding and decoding support to JAXB.
JAXBContextResolver() - Constructor for class org.apache.hadoop.hbase.stargate.provider.JAXBContextResolver
 
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
 
JERSEYVERSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 
JOBNAME - Static variable in class org.apache.hadoop.hbase.migration.nineteen.HStoreFileToStoreFile
 
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.
JtaXAResource - Class in org.apache.hadoop.hbase.client.transactional
View hbase as a JTA transactional resource.
JtaXAResource(TransactionManager) - Constructor for class org.apache.hadoop.hbase.client.transactional.JtaXAResource
 
JvmVersion - Class in org.apache.hadoop.hbase.util
Certain JVM versions are known to be unstable with HBase.
JvmVersion() - Constructor for class org.apache.hadoop.hbase.util.JvmVersion
 
JVMVERSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 

K

Key - Class in org.apache.hadoop.hbase.migration.nineteen.onelab.filter
The general behavior of a key that must be stored in a filter.
Key() - Constructor for class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.Key
default constructor - use with readFields
Key(byte[]) - Constructor for class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.Key
Constructor.
Key(byte[], double) - Constructor for class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.Key
Constructor.
key - Variable in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
The key
KEY_COMPARATOR - Static variable in class org.apache.hadoop.hbase.KeyValue
Comparator for plain key; i.e.
KEY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row
 
KEY_INFRASTRUCTURE_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
 
Keying - Class in org.apache.hadoop.hbase.util
Utility creating hbase friendly keys.
Keying() - Constructor for class org.apache.hadoop.hbase.util.Keying
 
keySet() - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
keySet() - Method in class org.apache.hadoop.hbase.io.RowResult
Deprecated.  
keySet() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Intentionally unimplemented.
keySet() - Method in class org.apache.hadoop.hbase.util.SoftValueMap
 
keySet() - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
keySize() - Method in class org.apache.hadoop.hbase.regionserver.MemStore
Get the heap usage of KVs in this MemStore.
keyToString(byte[]) - Static method in class org.apache.hadoop.hbase.KeyValue
 
keyToString(byte[], int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
Use for logging.
keyToUri(String) - Static method in class org.apache.hadoop.hbase.util.Keying
Reverse the Keying.createKey(String) transform.
KeyValue - Class in org.apache.hadoop.hbase
An HBase Key/Value.
KeyValue() - Constructor for class org.apache.hadoop.hbase.KeyValue
Writable Constructor -- DO NOT USE
KeyValue(byte[]) - Constructor for class org.apache.hadoop.hbase.KeyValue
Creates a KeyValue from the start of the specified byte array.
KeyValue(byte[], int) - Constructor for class org.apache.hadoop.hbase.KeyValue
Creates a KeyValue from the specified byte array and offset.
KeyValue(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.KeyValue
Creates a KeyValue from the specified byte array, starting at offset, and for length length.
KeyValue(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.KeyValue
Temporary.
KeyValue(byte[], byte[], long) - Constructor for class org.apache.hadoop.hbase.KeyValue
 
KeyValue(byte[], byte[], long, byte[]) - Constructor for class org.apache.hadoop.hbase.KeyValue
 
KeyValue(byte[], byte[], long, KeyValue.Type, byte[]) - Constructor for class org.apache.hadoop.hbase.KeyValue
 
KeyValue(byte[], long) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with null value.
KeyValue(byte[], long, KeyValue.Type) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with null value.
KeyValue(byte[], byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with null value.
KeyValue(byte[], byte[], byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with null value.
KeyValue(byte[], byte[], byte[], long, KeyValue.Type) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with specified values.
KeyValue(byte[], byte[], byte[], long, byte[]) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with specified values.
KeyValue(byte[], byte[], byte[], long, KeyValue.Type, byte[]) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with specified values.
KeyValue(byte[], byte[], byte[], int, int, long, KeyValue.Type, byte[], int, int) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with specified values.
KeyValue(byte[], int, int, byte[], int, int, byte[], int, int, long, KeyValue.Type, byte[], int, int) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with specified values.
KeyValue.KeyComparator - Class in org.apache.hadoop.hbase
Compare key portion of a KeyValue.
KeyValue.KeyComparator() - Constructor for class org.apache.hadoop.hbase.KeyValue.KeyComparator
 
KeyValue.KVComparator - Class in org.apache.hadoop.hbase
Compare KeyValues.
KeyValue.KVComparator() - Constructor for class org.apache.hadoop.hbase.KeyValue.KVComparator
 
KeyValue.MetaComparator - Class in org.apache.hadoop.hbase
A KeyValue.KVComparator for .META. catalog table KeyValues.
KeyValue.MetaComparator() - Constructor for class org.apache.hadoop.hbase.KeyValue.MetaComparator
 
KeyValue.MetaKeyComparator - Class in org.apache.hadoop.hbase
Compare key portion of a KeyValue for keys in .META. table.
KeyValue.MetaKeyComparator() - Constructor for class org.apache.hadoop.hbase.KeyValue.MetaKeyComparator
 
KeyValue.RootComparator - Class in org.apache.hadoop.hbase
A KeyValue.KVComparator for -ROOT- catalog table KeyValues.
KeyValue.RootComparator() - Constructor for class org.apache.hadoop.hbase.KeyValue.RootComparator
 
KeyValue.RootKeyComparator - Class in org.apache.hadoop.hbase
Compare key portion of a KeyValue for keys in -ROOT- table.
KeyValue.RootKeyComparator() - Constructor for class org.apache.hadoop.hbase.KeyValue.RootKeyComparator
 
KeyValue.RowComparator - Class in org.apache.hadoop.hbase
Comparator that compares row component only of a KeyValue.
KeyValue.RowComparator(KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.KeyValue.RowComparator
 
KeyValue.SplitKeyValue - Class in org.apache.hadoop.hbase
Utility class that splits a KeyValue buffer into separate byte arrays.
KeyValue.Type - Enum in org.apache.hadoop.hbase
Key type.
KEYVALUE_INFRASTRUCTURE_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
 
KeyValueHeap - Class in org.apache.hadoop.hbase.regionserver
Implements a heap merge across any number of KeyValueScanners.
KeyValueHeap(KeyValueScanner[], KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.KeyValueHeap
Constructor.
KeyValueScanner - Interface in org.apache.hadoop.hbase.regionserver
Scanner that returns the next KeyValue.
KeyValueSortReducer - Class in org.apache.hadoop.hbase.mapreduce
Emits sorted KeyValues.
KeyValueSortReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.KeyValueSortReducer
 

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
lastHost - Variable in class org.apache.hadoop.hbase.stargate.client.Cluster
 
lastKey() - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
lastKey() - Method in class org.apache.hadoop.hbase.io.RowResult
Deprecated.  
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.
LATEST_TIMESTAMP_BYTES - Static variable in interface org.apache.hadoop.hbase.HConstants
LATEST_TIMESTAMP in bytes form
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.io.hfile.HFile.Reader
 
length() - Method in class org.apache.hadoop.hbase.migration.nineteen.regionserver.HStoreFile
 
LIMIT - Static variable in interface org.apache.hadoop.hbase.rest.RESTConstants
 
limitNumMapTasks(String, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Deprecated. Ensures that the given number of map tasks for the given job configuration does not exceed the number of regions for the given table.
limitNumReduceTasks(String, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Deprecated. Ensures that the given number of reduce tasks for the given job configuration does not exceed the number of regions for the given table.
limitNumReduceTasks(String, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Ensures that the given number of reduce tasks for the given job configuration does not exceed the number of regions for the given table.
list() - Method in class org.apache.hadoop.hbase.client.Result
Create a sorted list of the KeyValue's in this result.
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.
LIVENODES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
loadFileInfo() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.Reader
Read in the index and file info.
loadInfo(FileSystem) - Method in class org.apache.hadoop.hbase.migration.nineteen.regionserver.HStoreFile
Reads in an info file
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
 
LOCATION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
lock - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
lockRow(byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Obtains a lock on a row.
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
 
lockRow(byte[]) - Method in class org.apache.hadoop.hbase.stargate.client.RemoteHTable
 
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.HBaseRPC
 
log(String) - Static method in class org.apache.hadoop.hbase.ipc.HBaseRPC
 
LOG - Static variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
LOG - Variable in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
LOG - Static variable in class org.apache.hadoop.hbase.util.Threads
 
LOG - Static variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWrapper
 
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
logStats() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
LOWESTKEY - Static variable in class org.apache.hadoop.hbase.KeyValue
Lowest possible key.
LruBlockCache - Class in org.apache.hadoop.hbase.io.hfile
A block cache implementation that is memory-aware using HeapSize, memory-bound using an LRU eviction algorithm, and concurrent: backed by a ConcurrentHashMap and with a non-blocking eviction thread giving constant-time LruBlockCache.cacheBlock(java.lang.String, java.nio.ByteBuffer, boolean) and LruBlockCache.getBlock(java.lang.String) operations.
LruBlockCache(long, long) - Constructor for class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Default constructor.
LruBlockCache(long, long, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Constructor used for testing.
LruBlockCache(long, long, boolean, int, float, int, float, float, float, float, float) - Constructor for class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Configurable constructor.
LruBlockCache.CacheStats - Class in org.apache.hadoop.hbase.io.hfile
 
LruBlockCache.CacheStats() - Constructor for class org.apache.hadoop.hbase.io.hfile.LruBlockCache.CacheStats
 
LruHashMap<K extends HeapSize,V extends HeapSize> - Class in org.apache.hadoop.hbase.regionserver
The LruHashMap is a memory-aware HashMap with a configurable maximum memory footprint.
LruHashMap(int, float, long) - Constructor for class org.apache.hadoop.hbase.regionserver.LruHashMap
Constructs a new, empty map with the specified initial capacity, load factor, and maximum memory usage.
LruHashMap(int, float) - Constructor for class org.apache.hadoop.hbase.regionserver.LruHashMap
Constructs a new, empty map with the specified initial capacity and load factor, and default maximum memory usage.
LruHashMap(int) - Constructor for class org.apache.hadoop.hbase.regionserver.LruHashMap
Constructs a new, empty map with the specified initial capacity and with the default load factor and maximum memory usage.
LruHashMap(long) - Constructor for class org.apache.hadoop.hbase.regionserver.LruHashMap
Constructs a new, empty map with the specified maximum memory usage and with default initial capacity and load factor.
LruHashMap() - Constructor for class org.apache.hadoop.hbase.regionserver.LruHashMap
Constructs a new, empty map with the default initial capacity, load factor and maximum memory usage.
LruHashMap.Entry<K extends HeapSize,V extends HeapSize> - Class in org.apache.hadoop.hbase.regionserver
Entry to store key/value mappings.
LuceneDocumentWrapper - Class in org.apache.hadoop.hbase.mapred
Deprecated. 
LuceneDocumentWrapper(Document) - Constructor for class org.apache.hadoop.hbase.mapred.LuceneDocumentWrapper
Deprecated.  
LuceneDocumentWrapper - Class in org.apache.hadoop.hbase.mapreduce
A utility class used to pass a lucene document from reduce to OutputFormat.
LuceneDocumentWrapper(Document) - Constructor for class org.apache.hadoop.hbase.mapreduce.LuceneDocumentWrapper
 

M

m_columns - Variable in class org.apache.hadoop.hbase.mapred.GroupingTableMap
Deprecated.  
main(String[]) - Static method in class org.apache.hadoop.hbase.io.BatchUpdate
Deprecated. Code to test sizes of BatchUpdate arrays.
main(String[]) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
 
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
Deprecated.  
main(String[]) - Static method in class org.apache.hadoop.hbase.mapred.Driver
Deprecated.  
main(String[]) - Static method in class org.apache.hadoop.hbase.mapred.RowCounter
Deprecated.  
main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.BuildTableIndex
The main entry point.
main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.Driver
 
main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.Export
Main entry point.
main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
Main entry point.
main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.RowCounter
Main entry point.
main(String[]) - Static method in class org.apache.hadoop.hbase.master.HMaster
Main program
main(String[]) - Static method in class org.apache.hadoop.hbase.migration.nineteen.HStoreFileToStoreFile
 
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.HRegion
Facility for dumping and compacting catalog tables.
main(String[]) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
main(String[]) - Static method in class org.apache.hadoop.hbase.regionserver.MemStore
Code to help figure if our approximation of object heap sizes is close enough.
main(String[]) - Static method in class org.apache.hadoop.hbase.rest.Dispatcher
Deprecated.  
Main - Class in org.apache.hadoop.hbase.stargate
Main class for launching REST gateway as a servlet hosted by Jetty.
Main() - Constructor for class org.apache.hadoop.hbase.stargate.Main
 
main(String[]) - Static method in class org.apache.hadoop.hbase.stargate.Main
 
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.CompressionTest
 
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
 
main(String[]) - Static method in class org.apache.hadoop.hbase.zookeeper.HQuorumPeer
Parse ZooKeeper configuration from HBase XML config and run a QuorumPeer.
main(String[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKServerTool
Run the tool.
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.
majorCompact(byte[]) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
makeColumnFamilyDirs(FileSystem, Path, HRegionInfo, byte[]) - 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.parser.XMLRestParser
 
makeKey(byte[], byte[], long, long) - Method in class org.apache.hadoop.hbase.regionserver.HLog
 
makeZKProps(HBaseConfiguration) - Static method in class org.apache.hadoop.hbase.zookeeper.HQuorumPeer
Make a Properties object holding ZooKeeper config equivalent to zoo.cfg.
map(ImmutableBytesWritable, RowResult, OutputCollector<ImmutableBytesWritable, RowResult>, Reporter) - Method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
Deprecated. 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
Deprecated. Pass the key, value to reduce
map(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Result>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
Extract the grouping columns from value to construct a new key.
map(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Result>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.IdentityTableMapper
Pass the key, value to reduce.
map(LongWritable, Text, Mapper<LongWritable, Text, LongWritable, LongWritable>.Context) - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreFileToStoreFile.Map
 
map - Variable in class org.apache.hadoop.hbase.rest.RESTConstants.FactoryMap
 
MAP_ENTRY - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for entry in map
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
 
MASTER - Static variable in class org.apache.hadoop.hbase.master.HMaster
Name of master server
MASTER_PORT - Static variable in interface org.apache.hadoop.hbase.HConstants
Parameter name for port master listens on.
master_running - Variable in class org.apache.hadoop.hbase.rest.DatabaseModel.DatabaseMetadata
 
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
MasterNotRunningException(Exception) - Constructor for exception org.apache.hadoop.hbase.MasterNotRunningException
Constructor taking another exception.
MasterStatistics - Class in org.apache.hadoop.hbase.master.metrics
Exports the MasterMetrics statistics as an MBean for JMX.
MasterStatistics(MetricsRegistry) - Constructor for class org.apache.hadoop.hbase.master.metrics.MasterStatistics
 
match(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.QueryMatcher
Main method for ColumnMatcher.
match(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
Determines if the caller should do one of several things: - seek/skip to the next row (MatchCode.SEEK_NEXT_ROW) - seek/skip to the next column (MatchCode.SEEK_NEXT_COL) - include the current KeyValue (MatchCode.INCLUDE) - ignore the current KeyValue (MatchCode.SKIP) - got to the next row (MatchCode.DONE)
matchesRowCol(HStoreKey) - Method in class org.apache.hadoop.hbase.HStoreKey
Deprecated. Compares the row and column of two keys
matchesRowCol(HStoreKey) - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey.BeforeThisStoreKey
 
matchesRowCol(HStoreKey) - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey
Compares the row and column of two keys
matchesRowFamily(HStoreKey) - Method in class org.apache.hadoop.hbase.HStoreKey
Deprecated. Compares the row and column family of two keys
matchesRowFamily(HStoreKey) - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey.BeforeThisStoreKey
 
matchesRowFamily(HStoreKey) - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey
Compares the row and column family of two keys
matchesWithoutColumn(HStoreKey) - Method in class org.apache.hadoop.hbase.HStoreKey
Deprecated. Compares the row and timestamp of two keys
matchesWithoutColumn(HStoreKey) - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey.BeforeThisStoreKey
 
matchesWithoutColumn(HStoreKey) - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey
Compares the row and timestamp of two keys
matchingColumn(byte[]) - Method in class org.apache.hadoop.hbase.KeyValue
 
matchingColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.KeyValue
 
matchingColumnNoDelimiter(byte[]) - Method in class org.apache.hadoop.hbase.KeyValue
 
matchingFamily(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.HStoreKey
Deprecated.  
matchingFamily(byte[]) - Method in class org.apache.hadoop.hbase.KeyValue
 
matchingFamily(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey
 
matchingQualifier(byte[]) - Method in class org.apache.hadoop.hbase.KeyValue
 
matchingRowColumn(KeyValue, KeyValue) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
Compares the row and column of two keyvalues
matchingRows(KeyValue, byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
matchingRows(KeyValue, KeyValue) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
matchingRows(KeyValue, short, KeyValue, short) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
matchingRows(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
matchingRowsGreaterTimestamp(KeyValue, KeyValue) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
Compares the row and timestamp of two keys Was called matchesWithoutColumn in 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.
MAXHEAPSIZEMB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
maxIdleTime - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
 
maxIdleTime - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
MAXIMUM_FP - Static variable in interface org.apache.hadoop.hbase.migration.nineteen.onelab.filter.RemoveScheme
MaximumFP Selection.
MAXIMUM_KEY_LENGTH - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
Maximum length of key in HFile.
MAXIMUM_VALUE_LENGTH - Static variable in interface org.apache.hadoop.hbase.HConstants
Maximum value length, enforced on KeyValue construction
maxRetries - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
 
MAXVERSIONS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
MAXVERSIONS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
membershipTest(Key) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.BloomFilter
 
membershipTest(Key) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.CountingBloomFilter
 
membershipTest(Key) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.DynamicBloomFilter
 
membershipTest(Key) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.Filter
Determines wether a specified key belongs to this filter.
MemStore - Class in org.apache.hadoop.hbase.regionserver
The MemStore holds in-memory modifications to the Store.
MemStore() - Constructor for class org.apache.hadoop.hbase.regionserver.MemStore
Default constructor.
MemStore(KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.MemStore
Constructor.
memstore - Variable in class org.apache.hadoop.hbase.regionserver.Store
Comparator that looks at columns and compares their family portions.
MemStore.MemStoreScanner - Class in org.apache.hadoop.hbase.regionserver
 
MEMSTORE_FLUSHSIZE - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
MEMSTORE_FLUSHSIZE_KEY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
memstoreReadPoint() - Method in class org.apache.hadoop.hbase.regionserver.ReadWriteConsistencyControl
 
memstoreSizeMB - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
Sum of all the memstore sizes in this regionserver in MB
MEMSTORESIZEMB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
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.
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell.Builder
 
mergeFrom(CellMessage.Cell) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Builder
 
mergeFrom(CellSetMessage.CellSet) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
mergeFrom(CellSetMessage.CellSet.Row) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
mergeFrom(ColumnSchemaMessage.ColumnSchema.Attribute) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
mergeFrom(ColumnSchemaMessage.ColumnSchema) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
mergeFrom(ScannerMessage.Scanner) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
mergeFrom(StorageClusterStatusMessage.StorageClusterStatus) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
mergeFrom(StorageClusterStatusMessage.StorageClusterStatus.Node) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
mergeFrom(StorageClusterStatusMessage.StorageClusterStatus.Region) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
mergeFrom(TableInfoMessage.TableInfo) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
mergeFrom(TableInfoMessage.TableInfo.Region) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList.Builder
 
mergeFrom(TableListMessage.TableList) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
mergeFrom(TableSchemaMessage.TableSchema.Attribute) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
mergeFrom(TableSchemaMessage.TableSchema) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version.Builder
 
mergeFrom(VersionMessage.Version) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version.Builder
 
message - Variable in class org.apache.hadoop.hbase.rest.Status
 
META_COMPARATOR - Static variable in class org.apache.hadoop.hbase.KeyValue
A KeyValue.KVComparator for .META. catalog table KeyValues.
META_KEY_COMPARATOR - Static variable in class org.apache.hadoop.hbase.KeyValue
A KeyValue.KVComparator for .META. catalog table KeyValue keys.
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
METADATA - Static variable in interface org.apache.hadoop.hbase.rest.RESTConstants
 
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.
metrics() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
MetricsMBeanBase - Class in org.apache.hadoop.hbase.metrics
Extends the Hadoop MetricsDynamicMBeanBase class to provide JMX support for custom HBase MetricsBase implementations.
MetricsMBeanBase(MetricsRegistry, String) - Constructor for class org.apache.hadoop.hbase.metrics.MetricsMBeanBase
 
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, MetricsRegistry, String) - Constructor for class org.apache.hadoop.hbase.metrics.MetricsRate
 
MetricsRate(String, MetricsRegistry) - Constructor for class org.apache.hadoop.hbase.metrics.MetricsRate
 
midkey() - Method in class org.apache.hadoop.hbase.io.HalfHFileReader
 
midkey() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
midKey() - Method in class org.apache.hadoop.hbase.migration.nineteen.io.HalfMapFileReader
 
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
 
MIMETYPE_BINARY - Static variable in interface org.apache.hadoop.hbase.stargate.Constants
 
MIMETYPE_HTML - Static variable in interface org.apache.hadoop.hbase.stargate.Constants
 
MIMETYPE_JSON - Static variable in interface org.apache.hadoop.hbase.stargate.Constants
 
MIMETYPE_PROTOBUF - Static variable in interface org.apache.hadoop.hbase.stargate.Constants
 
MIMETYPE_TEXT - Static variable in interface org.apache.hadoop.hbase.stargate.Constants
 
MIMETYPE_XML - Static variable in interface org.apache.hadoop.hbase.stargate.Constants
 
MINIMUM_FN - Static variable in interface org.apache.hadoop.hbase.migration.nineteen.onelab.filter.RemoveScheme
MinimumFN Selection.
MinorCompactingStoreScanner - Class in org.apache.hadoop.hbase.regionserver
A scanner that does a minor compaction at the same time.
miss() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache.CacheStats
 
model - Variable in class org.apache.hadoop.hbase.rest.AbstractController
 
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[], HConstants.Modify, Object...) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Modify an existing table.
modifyTable(byte[], HConstants.Modify, Writable[]) - Method in interface org.apache.hadoop.hbase.ipc.HMasterInterface
Modify a table's metadata
modifyTable(byte[], HConstants.Modify, 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.ThriftServer.HBaseHandler
 
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.ThriftServer.HBaseHandler
 
mutateRowTs(byte[], byte[], List<Mutation>, long) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 

N

NAME - Static variable in interface org.apache.hadoop.hbase.HConstants
 
name - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.Writer
 
NAME - Static variable in interface org.apache.hadoop.hbase.rest.RESTConstants
 
NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo
 
NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList
 
NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
nbHash - Variable in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.Filter
The number of hash function to consider.
needMore(int) - Method in class org.apache.hadoop.hbase.regionserver.ColumnCount
Check to see if needed to fetch more versions
needsTaskCommit(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
 
newBuilder() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell
 
newBuilder(CellMessage.Cell) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell
 
newBuilder() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet
 
newBuilder(CellSetMessage.CellSet) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet
 
newBuilder() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row
 
newBuilder(CellSetMessage.CellSet.Row) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row
 
newBuilder() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
newBuilder(ColumnSchemaMessage.ColumnSchema.Attribute) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
newBuilder() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
newBuilder(ColumnSchemaMessage.ColumnSchema) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
newBuilder() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
newBuilder(ScannerMessage.Scanner) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
newBuilder() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
newBuilder(StorageClusterStatusMessage.StorageClusterStatus) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
newBuilder() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
newBuilder(StorageClusterStatusMessage.StorageClusterStatus.Node) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
newBuilder() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
newBuilder(StorageClusterStatusMessage.StorageClusterStatus.Region) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
newBuilder() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo
 
newBuilder(TableInfoMessage.TableInfo) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo
 
newBuilder() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
newBuilder(TableInfoMessage.TableInfo.Region) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
newBuilder() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList
 
newBuilder(TableListMessage.TableList) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList
 
newBuilder() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
newBuilder(TableSchemaMessage.TableSchema.Attribute) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
newBuilder() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
newBuilder(TableSchemaMessage.TableSchema) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
newBuilder() - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 
newBuilder(VersionMessage.Version) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 
newHRegion(Path, HLog, FileSystem, HBaseConfiguration, HRegionInfo, FlushRequester) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
A utility method to create new instances of HRegion based on the HConstants.REGION_IMPL configuration property.
newHTable(String) - Method in class org.apache.hadoop.hbase.client.HTablePool
Deprecated. Use createHTable
next() - Method in class org.apache.hadoop.hbase.client.HTable.ClientScanner
 
next(int) - Method in class org.apache.hadoop.hbase.client.HTable.ClientScanner
Get nbRows rows.
next() - Method in class org.apache.hadoop.hbase.client.HTable.OldClientScanner
 
next(int) - Method in class org.apache.hadoop.hbase.client.HTable.OldClientScanner
 
next() - Method in interface org.apache.hadoop.hbase.client.ResultScanner
Grab the next row's worth of values.
next(int) - Method in interface org.apache.hadoop.hbase.client.ResultScanner
 
next() - Method in interface org.apache.hadoop.hbase.client.Scanner
Deprecated. Grab the next row's worth of values.
next(int) - Method in interface org.apache.hadoop.hbase.client.Scanner
Deprecated.  
next() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
Scans to the next entry in the file.
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
Deprecated.  
next(WritableComparable, Writable) - Method in class org.apache.hadoop.hbase.migration.nineteen.io.HalfMapFileReader
 
next(long) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
next(long, int) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
next(List<KeyValue>) - Method in interface org.apache.hadoop.hbase.regionserver.InternalScanner
Grab the next row's worth of values.
next() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
 
next(List<KeyValue>) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
Gets the next row of keys from the top-most scanner.
next() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
Return the next KeyValue in this scanner, iterating the scanner
next - Variable in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
The next entry in the hash chain (for collisions)
next() - Method in class org.apache.hadoop.hbase.regionserver.MemStore.MemStoreScanner
 
next() - Method in class org.apache.hadoop.hbase.regionserver.MinorCompactingStoreScanner
 
next(HFile.Writer) - Method in class org.apache.hadoop.hbase.regionserver.MinorCompactingStoreScanner
High performance merge scan.
next(List<KeyValue>) - Method in class org.apache.hadoop.hbase.regionserver.MinorCompactingStoreScanner
 
next() - Method in class org.apache.hadoop.hbase.stargate.RowResultGenerator
 
next() - Method in class org.apache.hadoop.hbase.stargate.ScannerResultGenerator
 
nextKeyValue() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase.TableRecordReader
Positions the record reader to the next record.
nextPtr - Variable in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
The next entry in the LRU list (towards MRU)
nextScannerId - Static variable in class org.apache.hadoop.hbase.rest.ScannerModel.ScannerMaster
 
nextScannerId - Variable in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
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.
nodes - Variable in class org.apache.hadoop.hbase.stargate.client.Cluster
 
nonNullRowAndColumn() - Method in class org.apache.hadoop.hbase.KeyValue
 
NoServerForRegionException - Exception in org.apache.hadoop.hbase.client
Thrown when no region server can be found for a region
NoServerForRegionException() - Constructor for exception org.apache.hadoop.hbase.client.NoServerForRegionException
default constructor
NoServerForRegionException(String) - Constructor for exception org.apache.hadoop.hbase.client.NoServerForRegionException
Constructor
NoSuchColumnFamilyException - Exception in org.apache.hadoop.hbase.regionserver
Thrown if request for nonexistent column family.
NoSuchColumnFamilyException() - Constructor for exception org.apache.hadoop.hbase.regionserver.NoSuchColumnFamilyException
default constructor
NoSuchColumnFamilyException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.NoSuchColumnFamilyException
 
not() - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.BloomFilter
 
not() - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.CountingBloomFilter
 
not() - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.DynamicBloomFilter
 
not() - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.Filter
Performs a logical NOT on this filter.
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
 
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
NUM_VERSIONS - Static variable in interface org.apache.hadoop.hbase.rest.RESTConstants
 
numConnections - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
numFamilies() - Method in class org.apache.hadoop.hbase.client.Get
Method for retrieving the number of families to get from
numFamilies() - Method in class org.apache.hadoop.hbase.client.Put
 
numFamilies() - Method in class org.apache.hadoop.hbase.client.Scan
 
numKeyValues() - Method in class org.apache.hadoop.hbase.regionserver.MemStore
Get an estimate of the number of key values stored in this store.
numRegionsToReport - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 

O

OBJECT - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Object overhead is minimum 2 * reference size (8 bytes on 64-bit)
obtainRowLock(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Obtain a lock on the given row.
of(T1, T2) - Static method in class org.apache.hadoop.hbase.util.Pair
Creates a new instance of the pair encapsulating the supplied values.
offlineRegionInMETA(HRegionInterface, byte[], HRegionInfo) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Utility method used by HMaster marking regions offlined.
oldestStamp - Variable in class org.apache.hadoop.hbase.regionserver.QueryMatcher
Oldest allowed version stamp for TTL enforcement
onlineRegions - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
open() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
Opens reader on this store file.
openConnection(String) - Static method in class org.apache.hadoop.hbase.util.CompressionTest
 
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[], Scan) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
Opens a remote scanner with a RowFilter.
openScanner(long, byte[], Scan) - Method in interface org.apache.hadoop.hbase.ipc.TransactionalRegionInterface
Opens a remote transactional scanner with a RowFilter.
openScanner(byte[], Scan) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
openScanner(long, byte[], Scan) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegionServer
 
or(Filter) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.BloomFilter
 
or(Filter) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.CountingBloomFilter
 
or(Filter) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.DynamicBloomFilter
 
or(Filter) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.Filter
Peforms a logical OR between this filter and a specified filter.
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
Provides 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 ResultScanner.next().
org.apache.hadoop.hbase.io - package org.apache.hadoop.hbase.io
 
org.apache.hadoop.hbase.io.hfile - package org.apache.hadoop.hbase.io.hfile
Provides the hbase data+index+metadata file.
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.mapreduce - package org.apache.hadoop.hbase.mapreduce
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.migration - package org.apache.hadoop.hbase.migration
Provides classes from old hbase versions used migrating data.
org.apache.hadoop.hbase.migration.nineteen - package org.apache.hadoop.hbase.migration.nineteen
 
org.apache.hadoop.hbase.migration.nineteen.io - package org.apache.hadoop.hbase.migration.nineteen.io
 
org.apache.hadoop.hbase.migration.nineteen.onelab.filter - package org.apache.hadoop.hbase.migration.nineteen.onelab.filter
 
org.apache.hadoop.hbase.migration.nineteen.regionserver - package org.apache.hadoop.hbase.migration.nineteen.regionserver
 
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.rest.descriptors - package org.apache.hadoop.hbase.rest.descriptors
 
org.apache.hadoop.hbase.rest.exception - package org.apache.hadoop.hbase.rest.exception
 
org.apache.hadoop.hbase.rest.filter - package org.apache.hadoop.hbase.rest.filter
 
org.apache.hadoop.hbase.rest.parser - package org.apache.hadoop.hbase.rest.parser
 
org.apache.hadoop.hbase.rest.serializer - package org.apache.hadoop.hbase.rest.serializer
 
org.apache.hadoop.hbase.stargate - package org.apache.hadoop.hbase.stargate
Stargate
org.apache.hadoop.hbase.stargate.client - package org.apache.hadoop.hbase.stargate.client
 
org.apache.hadoop.hbase.stargate.metrics - package org.apache.hadoop.hbase.stargate.metrics
 
org.apache.hadoop.hbase.stargate.model - package org.apache.hadoop.hbase.stargate.model
 
org.apache.hadoop.hbase.stargate.protobuf.generated - package org.apache.hadoop.hbase.stargate.protobuf.generated
 
org.apache.hadoop.hbase.stargate.provider - package org.apache.hadoop.hbase.stargate.provider
 
org.apache.hadoop.hbase.stargate.provider.consumer - package org.apache.hadoop.hbase.stargate.provider.consumer
 
org.apache.hadoop.hbase.stargate.provider.producer - package org.apache.hadoop.hbase.stargate.provider.producer
 
org.apache.hadoop.hbase.thrift - package org.apache.hadoop.hbase.thrift
Provides an HBase Thrift service.
org.apache.hadoop.hbase.util - package org.apache.hadoop.hbase.util
 
org.apache.hadoop.hbase.zookeeper - package org.apache.hadoop.hbase.zookeeper
 
OSVERSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 
out - Static variable in class org.apache.hadoop.hbase.regionserver.DebugPrint
 
OUTPUT_TABLE - Static variable in class org.apache.hadoop.hbase.mapred.TableOutputFormat
Deprecated. JobConf parameter that specifies the output table
OUTPUT_TABLE - Static variable in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
Job parameter that specifies the output table.

P

padHead(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
padTail(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
PageFilter - Class in org.apache.hadoop.hbase.filter
Implementation of Filter interface that limits results to a specific page size.
PageFilter() - Constructor for class org.apache.hadoop.hbase.filter.PageFilter
Default constructor, filters nothing.
PageFilter(long) - Constructor for class org.apache.hadoop.hbase.filter.PageFilter
Constructor that takes a maximum page size.
PageRowFilter - Class in org.apache.hadoop.hbase.filter
Deprecated. Use filters that are rooted on @{link Filter} instead
PageRowFilter() - Constructor for class org.apache.hadoop.hbase.filter.PageRowFilter
Deprecated. Default constructor, filters nothing.
PageRowFilter(long) - Constructor for class org.apache.hadoop.hbase.filter.PageRowFilter
Deprecated. Constructor that takes a maximum page size.
PageRowFilterFactory - Class in org.apache.hadoop.hbase.rest.filter
Constructs a PageRowFilter from a JSON argument String.
PageRowFilterFactory() - Constructor for class org.apache.hadoop.hbase.rest.filter.PageRowFilterFactory
 
Pair<T1,T2> - Class in org.apache.hadoop.hbase.util
A generic class for immutable pairs.
Pair(T1, T2) - Constructor for class org.apache.hadoop.hbase.util.Pair
Constructor
paramClass - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
parseColumn(byte[]) - Static method in class org.apache.hadoop.hbase.HStoreKey
Deprecated.  
parseColumn(byte[]) - Static method in class org.apache.hadoop.hbase.KeyValue
Splits a column in family:qualifier form into separate byte arrays.
parseColumn(byte[]) - Static method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 
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.
parseZooCfg(HBaseConfiguration, InputStream) - Static method in class org.apache.hadoop.hbase.zookeeper.HQuorumPeer
Parse ZooKeeper's zoo.cfg, injecting HBase Configuration variables in.
passedPrefix - Variable in class org.apache.hadoop.hbase.filter.PrefixFilter
 
path - Static variable in class org.apache.hadoop.hbase.util.CompressionTest
 
pathSegments - Variable in class org.apache.hadoop.hbase.rest.Status
 
peek() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
 
peek() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
Look at the next KeyValue in this scanner, but do not iterate scanner.
peek() - Method in class org.apache.hadoop.hbase.regionserver.MemStore.MemStoreScanner
 
peek() - Method in class org.apache.hadoop.hbase.regionserver.MinorCompactingStoreScanner
 
PER_BLOCK_OVERHEAD - Static variable in class org.apache.hadoop.hbase.io.hfile.CachedBlock
 
pingInterval - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
 
PlainTextMessageBodyProducer - Class in org.apache.hadoop.hbase.stargate.provider.producer
An adapter between Jersey and Object.toString().
PlainTextMessageBodyProducer() - Constructor for class org.apache.hadoop.hbase.stargate.provider.producer.PlainTextMessageBodyProducer
 
port - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
post(Status, byte[][], Map<String, String[]>, byte[], IHBaseRestParser) - Method in class org.apache.hadoop.hbase.rest.AbstractController
 
post(Status, byte[][], Map<String, String[]>, byte[], IHBaseRestParser) - Method in class org.apache.hadoop.hbase.rest.DatabaseController
 
post(Status, byte[][], Map<String, String[]>, byte[], IHBaseRestParser) - Method in class org.apache.hadoop.hbase.rest.RowController
 
post(byte[], Put) - Method in class org.apache.hadoop.hbase.rest.RowModel
 
post(byte[], List<Put>) - Method in class org.apache.hadoop.hbase.rest.RowModel
 
post(Status, byte[][], Map<String, String[]>, byte[], IHBaseRestParser) - Method in class org.apache.hadoop.hbase.rest.ScannerController
 
post(Status, byte[][], Map<String, String[]>, byte[], IHBaseRestParser) - Method in class org.apache.hadoop.hbase.rest.TableController
 
post(byte[], HTableDescriptor) - Method in class org.apache.hadoop.hbase.rest.TableModel
Creates table tableName described by the json in input.
post(Status, byte[][], Map<String, String[]>, byte[], IHBaseRestParser) - Method in class org.apache.hadoop.hbase.rest.TimestampController
 
post(byte[], byte[], byte[], long, byte[]) - Method in class org.apache.hadoop.hbase.rest.TimestampModel
 
post(String, String, byte[]) - Method in class org.apache.hadoop.hbase.stargate.client.Client
Send a POST request
post(Cluster, String, String, byte[]) - Method in class org.apache.hadoop.hbase.stargate.client.Client
Send a POST request
post(String, Header[], byte[]) - Method in class org.apache.hadoop.hbase.stargate.client.Client
Send a POST request
post(Cluster, String, Header[], byte[]) - Method in class org.apache.hadoop.hbase.stargate.client.Client
Send a POST request
post(CellSetModel, UriInfo) - Method in class org.apache.hadoop.hbase.stargate.RowResource
 
post(ScannerModel, UriInfo) - Method in class org.apache.hadoop.hbase.stargate.ScannerResource
 
post(TableSchemaModel, UriInfo) - Method in class org.apache.hadoop.hbase.stargate.SchemaResource
 
postBinary(byte[], UriInfo, HttpHeaders) - Method in class org.apache.hadoop.hbase.stargate.RowResource
 
prefix - Variable in class org.apache.hadoop.hbase.filter.PrefixFilter
 
prefix - Variable in class org.apache.hadoop.hbase.filter.PrefixRowFilter
Deprecated.  
PrefixFilter - Class in org.apache.hadoop.hbase.filter
Pass results that have same row prefix.
PrefixFilter(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.PrefixFilter
 
PrefixFilter() - Constructor for class org.apache.hadoop.hbase.filter.PrefixFilter
 
PrefixRowFilter - Class in org.apache.hadoop.hbase.filter
Deprecated. Use filters that are rooted on @{link Filter} instead
PrefixRowFilter(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.PrefixRowFilter
Deprecated. Constructor that takes a row prefix to filter on
PrefixRowFilter() - Constructor for class org.apache.hadoop.hbase.filter.PrefixRowFilter
Deprecated. Default Constructor, filters nothing.
prepare(Xid) - Method in class org.apache.hadoop.hbase.client.transactional.JtaXAResource
 
prepareCommit(TransactionState) - Method in class org.apache.hadoop.hbase.client.transactional.TransactionManager
Prepare to commit a transaction.
prepareToSplit() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
prepareToSplit() - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegion
 
prettyPrint - Variable in class org.apache.hadoop.hbase.rest.serializer.AbstractRestSerializer
 
prevPtr - Variable in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
The previous entry in the LRU list (towards LRU)
println(String) - Static method in class org.apache.hadoop.hbase.regionserver.DebugPrint
 
printUsageAndExit() - Static method in class org.apache.hadoop.hbase.rest.Dispatcher
Deprecated.  
printUsageAndExit(String) - Static method in class org.apache.hadoop.hbase.rest.Dispatcher
Deprecated.  
process(WatchedEvent) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.ClientZKWatcher
Called by ZooKeeper when an event occurs on our connection.
process(WatchedEvent) - Method in class org.apache.hadoop.hbase.master.HMaster
 
process(WatchedEvent) - Method in class org.apache.hadoop.hbase.master.ZKMasterAddressWatcher
 
process(WatchedEvent) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
We register ourselves as a watcher on the master address ZNode.
processAlways() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
Deprecated.  
processAlways() - Method in class org.apache.hadoop.hbase.filter.PageRowFilter
Deprecated.  
processAlways() - Method in class org.apache.hadoop.hbase.filter.PrefixRowFilter
Deprecated.  
processAlways() - Method in class org.apache.hadoop.hbase.filter.RegExpRowFilter
Deprecated.  
processAlways() - Method in interface org.apache.hadoop.hbase.filter.RowFilterInterface
Deprecated. Returns whether or not the filter should always be processed in any filtering call.
processAlways() - Method in class org.apache.hadoop.hbase.filter.RowFilterSet
Deprecated.  
processAlways() - Method in class org.apache.hadoop.hbase.filter.StopRowFilter
Deprecated.  
processAlways() - Method in class org.apache.hadoop.hbase.filter.WhileMatchRowFilter
Deprecated.  
processBatchOfDeletes(ArrayList<Delete>, byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Process a batch of Deletes.
processBatchOfRows(ArrayList<Put>, byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Process a batch of Puts.
processRow(HRegionInfo) - Method in interface org.apache.hadoop.hbase.util.MetaUtils.ScannerListener
Callback so client of scanner can process row contents
ProtobufMessageBodyConsumer - Class in org.apache.hadoop.hbase.stargate.provider.consumer
Adapter for hooking up Jersey content processing dispatch to ProtobufMessageHandler interface capable handlers for decoding protobuf input.
ProtobufMessageBodyConsumer() - Constructor for class org.apache.hadoop.hbase.stargate.provider.consumer.ProtobufMessageBodyConsumer
 
ProtobufMessageBodyProducer - Class in org.apache.hadoop.hbase.stargate.provider.producer
An adapter between Jersey and ProtobufMessageHandler implementors.
ProtobufMessageBodyProducer() - Constructor for class org.apache.hadoop.hbase.stargate.provider.producer.ProtobufMessageBodyProducer
 
ProtobufMessageHandler - Interface in org.apache.hadoop.hbase.stargate
Common interface for models capable of supporting protobuf marshalling and unmarshalling.
pushMetric(MetricsRecord) - Method in class org.apache.hadoop.hbase.metrics.MetricsRate
 
put(Put) - Method in class org.apache.hadoop.hbase.client.HTable
Puts some data in the table.
put(List<Put>) - Method in class org.apache.hadoop.hbase.client.HTable
Puts some data in the table, in batch.
Put - Class in org.apache.hadoop.hbase.client
Used to perform Put operations for a single row.
Put() - Constructor for class org.apache.hadoop.hbase.client.Put
Constructor for Writable.
Put(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Put
Create a Put operation for the specified row.
Put(byte[], RowLock) - Constructor for class org.apache.hadoop.hbase.client.Put
Create a Put operation for the specified row, using an existing row lock.
Put(Put) - Constructor for class org.apache.hadoop.hbase.client.Put
Copy constructor.
put(TransactionState, Put) - Method in class org.apache.hadoop.hbase.client.transactional.TransactionalTable
Commit a Put to the table.
put(String, byte[]) - Method in class org.apache.hadoop.hbase.io.BatchUpdate
Deprecated. Change a value for the specified column
put(byte[], byte[]) - Method in class org.apache.hadoop.hbase.io.BatchUpdate
Deprecated. 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
Deprecated.  
put(byte[], Put) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
Put data into the specified region
put(byte[], Put[]) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
Put an array of puts into the specified region
put(long, byte[], Put) - Method in interface org.apache.hadoop.hbase.ipc.TransactionalRegionInterface
Transactional put data into the specified region
put(long, byte[], Put[]) - Method in interface org.apache.hadoop.hbase.ipc.TransactionalRegionInterface
Put an array of puts into the specified region
put(Put) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
put(Put, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
put(Put, Integer) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
put(Put, Integer, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
put(byte[], Put) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
put(byte[], Put[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
put(K, V) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Insert a key-value mapping into the map.
put(long, Put) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegion
Add a write to the transaction.
put(long, Put[]) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegion
Add multiple writes to the transaction.
put(long, byte[], Put) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegionServer
 
put(long, byte[], Put[]) - Method in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegionServer
 
put(Status, byte[][], Map<String, String[]>, byte[], IHBaseRestParser) - Method in class org.apache.hadoop.hbase.rest.AbstractController
 
put(Status, byte[][], Map<String, String[]>, byte[], IHBaseRestParser) - Method in class org.apache.hadoop.hbase.rest.DatabaseController
 
put(Status, byte[][], Map<String, String[]>, byte[], IHBaseRestParser) - Method in class org.apache.hadoop.hbase.rest.RowController
 
put(Status, byte[][], Map<String, String[]>, byte[], IHBaseRestParser) - Method in class org.apache.hadoop.hbase.rest.ScannerController
 
put(Status, byte[][], Map<String, String[]>, byte[], IHBaseRestParser) - Method in class org.apache.hadoop.hbase.rest.TableController
 
put(Status, byte[][], Map<String, String[]>, byte[], IHBaseRestParser) - Method in class org.apache.hadoop.hbase.rest.TimestampController
 
put(String, String, byte[]) - Method in class org.apache.hadoop.hbase.stargate.client.Client
Send a PUT request
put(Cluster, String, String, byte[]) - Method in class org.apache.hadoop.hbase.stargate.client.Client
Send a PUT request
put(String, Header[], byte[]) - Method in class org.apache.hadoop.hbase.stargate.client.Client
Send a PUT request
put(Cluster, String, Header[], byte[]) - Method in class org.apache.hadoop.hbase.stargate.client.Client
Send a PUT request
put(Put) - Method in class org.apache.hadoop.hbase.stargate.client.RemoteHTable
 
put(List<Put>) - Method in class org.apache.hadoop.hbase.stargate.client.RemoteHTable
 
put(CellSetModel, UriInfo) - Method in class org.apache.hadoop.hbase.stargate.RowResource
 
put(ScannerModel, UriInfo) - Method in class org.apache.hadoop.hbase.stargate.ScannerResource
 
put(TableSchemaModel, UriInfo) - Method in class org.apache.hadoop.hbase.stargate.SchemaResource
 
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
Deprecated.  
putAll(Map<? extends K, ? extends V>) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Intentionally unimplemented.
putAll(Map) - Method in class org.apache.hadoop.hbase.util.SoftValueMap
 
putAll(Map) - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
putBack(KeyValue) - Method in class org.apache.hadoop.hbase.stargate.ResultGenerator
 
putBack(KeyValue) - Method in class org.apache.hadoop.hbase.stargate.RowResultGenerator
 
putBack(KeyValue) - Method in class org.apache.hadoop.hbase.stargate.ScannerResultGenerator
 
putBigDecimal(byte[], int, BigDecimal) - Static method in class org.apache.hadoop.hbase.util.Bytes
Put a BigDecimal value out to the specified byte array position.
putBinary(byte[], UriInfo, HttpHeaders) - Method in class org.apache.hadoop.hbase.stargate.RowResource
 
putByte(byte[], int, byte) - Static method in class org.apache.hadoop.hbase.util.Bytes
Write a single byte out to the specified byte array position.
putBytes(byte[], int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Put bytes at the specified byte array position.
putChar(byte[], int, char) - Static method in class org.apache.hadoop.hbase.util.Bytes
Put a char value out to the specified byte array position.
putChars(byte[], int, char[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Put a char array value out to the specified byte array position.
putDouble(byte[], int, double) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
putFloat(byte[], int, float) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
putInt(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Put an int value out to the specified byte array position.
putLong(byte[], int, long) - Static method in class org.apache.hadoop.hbase.util.Bytes
Put a long value out to the specified byte array position.
putShort(byte[], int, short) - Static method in class org.apache.hadoop.hbase.util.Bytes
Put a short value out to the specified byte array position.
putTable(HTable) - Method in class org.apache.hadoop.hbase.client.HTablePool
Puts the specified HTable back into the pool.

Q

QualifierFilter - Class in org.apache.hadoop.hbase.filter
This filter is used to filter based on the column qualifier.
QualifierFilter() - Constructor for class org.apache.hadoop.hbase.filter.QualifierFilter
Writable constructor, do not use.
QualifierFilter(CompareFilter.CompareOp, WritableByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.QualifierFilter
Constructor.
QueryMatcher - Class in org.apache.hadoop.hbase.regionserver
This is the primary class used to process KeyValues during a Get or Scan operation.
QueryMatcher(Get, byte[], NavigableSet<byte[]>, long, KeyValue.KeyComparator, int) - Constructor for class org.apache.hadoop.hbase.regionserver.QueryMatcher
Constructs a QueryMatcher for a Get.
QueryMatcher() - Constructor for class org.apache.hadoop.hbase.regionserver.QueryMatcher
 
QueryMatcher(QueryMatcher, byte[]) - Constructor for class org.apache.hadoop.hbase.regionserver.QueryMatcher
Constructs a copy of an existing QueryMatcher with a new row.
quiesced - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 

R

RANDOM - Static variable in interface org.apache.hadoop.hbase.migration.nineteen.onelab.filter.RemoveScheme
Random selection.
RATIO - Static variable in interface org.apache.hadoop.hbase.migration.nineteen.onelab.filter.RemoveScheme
Ratio Selection.
raw() - Method in class org.apache.hadoop.hbase.client.Result
Return the unsorted array of KeyValues backing this Result instance.
read(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.io.Reference
Read a Reference from FileSystem.
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.
readArray(DataInput) - Static method in class org.apache.hadoop.hbase.client.Result
 
readByteArray(DataInput) - Static method in class org.apache.hadoop.hbase.util.Bytes
Read byte-array written with a WritableableUtils.vint prefix.
readByteArray(DataInput, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Read byte-array from data input.
readByteArrayThrowsRuntime(DataInput) - Static method in class org.apache.hadoop.hbase.util.Bytes
Read byte-array written with a WritableableUtils.vint prefix.
readFields(DataInput) - Method in class org.apache.hadoop.hbase.client.Delete
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.client.Get
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.client.Put
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.client.Result
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.client.Scan
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.client.tableindexed.IndexSpecification
readFields(DataInput) - Method in class org.apache.hadoop.hbase.client.tableindexed.IndexSpecificationArray
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.client.tableindexed.SimpleIndexKeyGenerator
readFields(DataInput) - Method in class org.apache.hadoop.hbase.ClusterStatus
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
Deprecated.  
readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.PageRowFilter
Deprecated.  
readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.PrefixRowFilter
Deprecated.  
readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.RegExpRowFilter
Deprecated.  
readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.RowFilterSet
Deprecated.  
readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.StopRowFilter
Deprecated.  
readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.SubstringComparator
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.WhileMatchRowFilter
Deprecated.  
readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.WritableByteArrayComparable
 
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
Deprecated.  
readFields(DataInput) - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.io.BatchOperation
Deprecated.  
readFields(DataInput) - Method in class org.apache.hadoop.hbase.io.BatchUpdate
Deprecated.  
readFields(DataInput) - Method in class org.apache.hadoop.hbase.io.Cell
Deprecated.  
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
Deprecated.  
readFields(DataInput) - Method in class org.apache.hadoop.hbase.io.TimeRange
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.KeyValue
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.mapred.LuceneDocumentWrapper
Deprecated.  
readFields(DataInput) - Method in class org.apache.hadoop.hbase.mapred.TableSplit
Deprecated.  
readFields(DataInput) - Method in class org.apache.hadoop.hbase.mapreduce.LuceneDocumentWrapper
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Reads the values of each field.
readFields(DataInput) - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey.BeforeThisStoreKey
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.migration.nineteen.io.Reference
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.BloomFilter
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.CountingBloomFilter
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.DynamicBloomFilter
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.Filter
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.Key
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.RetouchedBloomFilter
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.regionserver.HLogKey
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.regionserver.transactional.THLogKey
 
readFrom(Class<ProtobufMessageHandler>, Type, Annotation[], MediaType, MultivaluedMap<String, String>, InputStream) - Method in class org.apache.hadoop.hbase.stargate.provider.consumer.ProtobufMessageBodyConsumer
 
readInputBuffer(HttpServletRequest) - Method in class org.apache.hadoop.hbase.rest.Dispatcher
Deprecated.  
readMasterAddress(Watcher) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWrapper
Read master address and set a watch on it.
readMasterAddressOrThrow() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWrapper
Read address of master server.
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_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
READONLY_KEY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
readRootRegionLocation() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWrapper
Read location of server storing root region.
readVLong(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Reads a zero-compressed encoded long from input stream and returns it.
readVLong(DataInput, byte) - Static method in class org.apache.hadoop.hbase.util.Writables
Reads a zero-compressed encoded long from input stream and returns it.
ReadWriteConsistencyControl - Class in org.apache.hadoop.hbase.regionserver
Manages the read/write consistency within memstore.
ReadWriteConsistencyControl() - Constructor for class org.apache.hadoop.hbase.regionserver.ReadWriteConsistencyControl
 
ReadWriteConsistencyControl.WriteEntry - Class in org.apache.hadoop.hbase.regionserver
 
recover(int) - Method in class org.apache.hadoop.hbase.client.transactional.JtaXAResource
 
reduce(ImmutableBytesWritable, Iterator<BatchUpdate>, OutputCollector<ImmutableBytesWritable, BatchUpdate>, Reporter) - Method in class org.apache.hadoop.hbase.mapred.IdentityTableReduce
Deprecated. No aggregation, output pairs of (key, record)
reduce(ImmutableBytesWritable, Iterator<RowResult>, OutputCollector<ImmutableBytesWritable, LuceneDocumentWrapper>, Reporter) - Method in class org.apache.hadoop.hbase.mapred.IndexTableReduce
Deprecated.  
reduce(Writable, Iterable<Writable>, Reducer<Writable, Writable, Writable, Writable>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.IdentityTableReducer
Writes each given record, consisting of the row key and the given values, to the configured OutputFormat.
reduce(ImmutableBytesWritable, Iterable<Result>, Reducer<ImmutableBytesWritable, Result, ImmutableBytesWritable, LuceneDocumentWrapper>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.IndexTableReducer
Writes each given record, consisting of the key and the given values, to the index.
reduce(ImmutableBytesWritable, Iterable<KeyValue>, Reducer<ImmutableBytesWritable, KeyValue, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSortReducer
 
REENTRANT_LOCK - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for ReentrantReadWriteLock
Reference - Class in org.apache.hadoop.hbase.io
A reference to the top or bottom half of a store file.
Reference(byte[], Reference.Range) - Constructor for class org.apache.hadoop.hbase.io.Reference
Constructor
Reference() - Constructor for class org.apache.hadoop.hbase.io.Reference
Used by serializations.
Reference - Class in org.apache.hadoop.hbase.migration.nineteen.io
A reference to a part of a store file.
Reference(int, long, HStoreKey, Reference.Range) - Constructor for class org.apache.hadoop.hbase.migration.nineteen.io.Reference
 
Reference() - Constructor for class org.apache.hadoop.hbase.migration.nineteen.io.Reference
 
REFERENCE - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Reference size is 8 bytes on 64-bit, 4 bytes on 32-bit
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
Reference.Range - Enum in org.apache.hadoop.hbase.migration.nineteen.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
Deprecated. This interface doesn't work well in new KeyValue world. Use filters based on new Filter instead.
RegExpRowFilter() - Constructor for class org.apache.hadoop.hbase.filter.RegExpRowFilter
Deprecated. Default constructor, filters nothing.
RegExpRowFilter(String) - Constructor for class org.apache.hadoop.hbase.filter.RegExpRowFilter
Deprecated. 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.
RegExpRowFilterFactory - Class in org.apache.hadoop.hbase.rest.filter
Constructs a RegExpRowFilter from a JSON argument string.
RegExpRowFilterFactory() - Constructor for class org.apache.hadoop.hbase.rest.filter.RegExpRowFilterFactory
 
RegexStringComparator - Class in org.apache.hadoop.hbase.filter
This comparator is for use with CompareFilter implementations, such as RowFilter, QualifierFilter, and ValueFilter, for filtering based on the value of a given column.
RegexStringComparator() - Constructor for class org.apache.hadoop.hbase.filter.RegexStringComparator
Nullary constructor for Writable, do not use
RegexStringComparator(String) - Constructor for class org.apache.hadoop.hbase.filter.RegexStringComparator
Constructor
REGION_IMPL - Static variable in interface org.apache.hadoop.hbase.HConstants
Parameter name for what region implementation to use.
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
REGIONINFO_FILE - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
Name of the region info file that resides just under the region directory.
REGIONINFO_FILE_BYTES - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
REGIONINFO_FILE as byte array.
REGIONINFO_QUALIFIER - Static variable in interface org.apache.hadoop.hbase.HConstants
The regioninfo column qualifier
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 interface org.apache.hadoop.hbase.rest.RESTConstants
 
REGIONS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
REGIONS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
REGIONS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo
 
REGIONSERVER - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
region server process name
REGIONSERVER_PORT - Static variable in interface org.apache.hadoop.hbase.HConstants
Parameter name for port region server listens on.
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
 
RegionServerStatistics - Class in org.apache.hadoop.hbase.regionserver.metrics
Exports metrics recorded by RegionServerMetrics as an MBean for JMX monitoring.
RegionServerStatistics(MetricsRegistry, String) - Constructor for class org.apache.hadoop.hbase.regionserver.metrics.RegionServerStatistics
 
RegionsResource - Class in org.apache.hadoop.hbase.stargate
 
RegionsResource(String) - Constructor for class org.apache.hadoop.hbase.stargate.RegionsResource
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage
 
registry - 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.
registry - Variable in class org.apache.hadoop.hbase.metrics.MetricsMBeanBase
 
registryLength - Variable in class org.apache.hadoop.hbase.metrics.MetricsMBeanBase
 
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.
RemoteAdmin - Class in org.apache.hadoop.hbase.stargate.client
 
RemoteAdmin(Client, HBaseConfiguration) - Constructor for class org.apache.hadoop.hbase.stargate.client.RemoteAdmin
Constructor
RemoteAdmin(Client, HBaseConfiguration, String) - Constructor for class org.apache.hadoop.hbase.stargate.client.RemoteAdmin
Constructor
RemoteExceptionHandler - Class in org.apache.hadoop.hbase
An immutable class which contains a static method for handling org.apache.hadoop.ipc.RemoteException exceptions.
RemoteHTable - Class in org.apache.hadoop.hbase.stargate.client
HTable interface to remote tables accessed via Stargate
RemoteHTable(Client, String) - Constructor for class org.apache.hadoop.hbase.stargate.client.RemoteHTable
Constructor
RemoteHTable(Client, String, String) - Constructor for class org.apache.hadoop.hbase.stargate.client.RemoteHTable
Constructor
RemoteHTable(Client, HBaseConfiguration, String, String) - Constructor for class org.apache.hadoop.hbase.stargate.client.RemoteHTable
Constructor
RemoteHTable(Client, HBaseConfiguration, byte[], String) - Constructor for class org.apache.hadoop.hbase.stargate.client.RemoteHTable
Constructor
remove(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
 
remove(byte[]) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
remove(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
remove(Object) - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
remove(Object) - Method in class org.apache.hadoop.hbase.io.RowResult
Deprecated.  
remove(Object) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Deletes the mapping for the specified key if it exists.
remove(String) - Method in class org.apache.hadoop.hbase.stargate.client.Cluster
Remove a node from the cluster
remove(String, int) - Method in class org.apache.hadoop.hbase.stargate.client.Cluster
Remove a node from the cluster
remove() - Method in class org.apache.hadoop.hbase.stargate.RowResultGenerator
 
remove() - Method in class org.apache.hadoop.hbase.stargate.ScannerResultGenerator
 
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
 
removeIndex(byte[], String) - Method in class org.apache.hadoop.hbase.client.tableindexed.IndexedTableAdmin
Remove an index for a table.
removeIndex(String) - Method in class org.apache.hadoop.hbase.client.tableindexed.IndexedTableDescriptor
 
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(Integer) - Method in class org.apache.hadoop.hbase.rest.ScannerModel.ScannerMaster
 
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.
RemoveScheme - Interface in org.apache.hadoop.hbase.migration.nineteen.onelab.filter
Defines the different remove scheme for retouched Bloom filters.
rename(FileSystem, HStoreFile) - Method in class org.apache.hadoop.hbase.migration.nineteen.regionserver.HStoreFile
Renames the mapfiles and info directories under the passed hsf directory.
rename(FileSystem, Path, Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFile
Utility to help with rename.
renewLease(String) - Method in class org.apache.hadoop.hbase.Leases
Renew a lease
replaceValue(V) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
Replace the value of this entry.
request(HRegion) - Method in interface org.apache.hadoop.hbase.regionserver.FlushRequester
Tell the listener the cache needs to be flushed.
REQUESTS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
REQUESTS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
reset() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
reset() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
Deprecated.  
reset() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
reset() - Method in interface org.apache.hadoop.hbase.filter.Filter
Reset the state of the filter between rows.
reset() - Method in class org.apache.hadoop.hbase.filter.FilterList
 
reset() - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
reset() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
reset() - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
reset() - Method in class org.apache.hadoop.hbase.filter.PageRowFilter
Deprecated.  
reset() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
reset() - Method in class org.apache.hadoop.hbase.filter.PrefixRowFilter
Deprecated.  
reset() - Method in class org.apache.hadoop.hbase.filter.RegExpRowFilter
Deprecated.  
reset() - Method in class org.apache.hadoop.hbase.filter.RowFilter
 
reset() - Method in interface org.apache.hadoop.hbase.filter.RowFilterInterface
Deprecated. Resets the state of the filter.
reset() - Method in class org.apache.hadoop.hbase.filter.RowFilterSet
Deprecated.  
reset() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
reset() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
reset() - Method in class org.apache.hadoop.hbase.filter.StopRowFilter
Deprecated.  
reset() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
reset() - Method in class org.apache.hadoop.hbase.filter.WhileMatchRowFilter
Deprecated.  
reset() - Method in class org.apache.hadoop.hbase.migration.nineteen.io.HalfMapFileReader
 
reset() - Method in interface org.apache.hadoop.hbase.regionserver.ColumnTracker
Resets the Matcher
reset() - Static method in class org.apache.hadoop.hbase.regionserver.DebugPrint
 
reset() - Method in interface org.apache.hadoop.hbase.regionserver.DeleteTracker
Called between rows.
reset() - Method in class org.apache.hadoop.hbase.regionserver.ExplicitColumnTracker
 
reset() - Method in class org.apache.hadoop.hbase.regionserver.GetDeleteTracker
 
reset() - Method in class org.apache.hadoop.hbase.regionserver.QueryMatcher
Resets the current columns and deletes
reset() - Method in class org.apache.hadoop.hbase.regionserver.ScanDeleteTracker
 
reset() - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
 
reset() - Method in class org.apache.hadoop.hbase.regionserver.ScanWildcardColumnTracker
 
reset() - Method in class org.apache.hadoop.hbase.regionserver.WildcardColumnTracker
 
resetAllMinMax() - Method in class org.apache.hadoop.hbase.master.metrics.MasterMetrics
 
resetAllMinMax() - Method in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
 
resetAllMinMax() - Method in class org.apache.hadoop.hbase.stargate.metrics.StargateMetrics
 
resetThreadReadPoint(ReadWriteConsistencyControl) - Static method in class org.apache.hadoop.hbase.regionserver.ReadWriteConsistencyControl
 
ResourceBase - Class in org.apache.hadoop.hbase.stargate
 
ResourceBase() - Constructor for class org.apache.hadoop.hbase.stargate.ResourceBase
 
ResourceConfig - Class in org.apache.hadoop.hbase.stargate
 
ResourceConfig() - Constructor for class org.apache.hadoop.hbase.stargate.ResourceConfig
 
respond() - Method in class org.apache.hadoop.hbase.rest.Status
 
responder - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
response - Variable in class org.apache.hadoop.hbase.rest.serializer.AbstractRestSerializer
 
response - Variable in class org.apache.hadoop.hbase.rest.Status
 
Response - Class in org.apache.hadoop.hbase.stargate.client
The HTTP result code, response headers, and body of a HTTP response.
Response(int) - Constructor for class org.apache.hadoop.hbase.stargate.client.Response
Constructor
Response(int, Header[]) - Constructor for class org.apache.hadoop.hbase.stargate.client.Response
Constructor
Response(int, Header[], byte[]) - Constructor for class org.apache.hadoop.hbase.stargate.client.Response
Constructor
restart(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase.TableRecordReader
Deprecated. Restart from survivable exceptions by creating a new scanner.
restart(byte[]) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase.TableRecordReader
Restart from survivable exceptions by creating a new scanner.
RestCell - Class in org.apache.hadoop.hbase.rest.descriptors
 
RestCell() - Constructor for class org.apache.hadoop.hbase.rest.descriptors.RestCell
 
RestCell(byte[], Cell) - Constructor for class org.apache.hadoop.hbase.rest.descriptors.RestCell
 
RestCell(byte[], long) - Constructor for class org.apache.hadoop.hbase.rest.descriptors.RestCell
 
RestCell(byte[][], long[]) - Constructor for class org.apache.hadoop.hbase.rest.descriptors.RestCell
 
RestCell(String, long) - Constructor for class org.apache.hadoop.hbase.rest.descriptors.RestCell
 
RestCell(String[], long[]) - Constructor for class org.apache.hadoop.hbase.rest.descriptors.RestCell
 
RESTConstants - Interface in org.apache.hadoop.hbase.rest
 
RESTConstants.FactoryMap - Class in org.apache.hadoop.hbase.rest
 
RESTConstants.FactoryMap() - Constructor for class org.apache.hadoop.hbase.rest.RESTConstants.FactoryMap
 
restSerialize(IRestSerializer) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
restSerialize(IRestSerializer) - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
restSerialize(IRestSerializer) - Method in class org.apache.hadoop.hbase.io.Cell
Deprecated.  
restSerialize(IRestSerializer) - Method in class org.apache.hadoop.hbase.io.RowResult
Deprecated.  
restSerialize(IRestSerializer) - Method in class org.apache.hadoop.hbase.rest.DatabaseModel.DatabaseMetadata
 
restSerialize(IRestSerializer) - Method in class org.apache.hadoop.hbase.rest.descriptors.ScannerIdentifier
 
restSerialize(IRestSerializer) - Method in class org.apache.hadoop.hbase.rest.descriptors.TimestampsDescriptor
 
restSerialize(IRestSerializer) - Method in interface org.apache.hadoop.hbase.rest.serializer.ISerializable
visitor pattern method where the object implementing this interface will call back on the IRestSerializer with the correct method to run to serialize the output of the object to the stream.
restSerialize(IRestSerializer) - Method in class org.apache.hadoop.hbase.rest.Status.StatusMessage
 
restSerialize(IRestSerializer) - Method in class org.apache.hadoop.hbase.rest.TableModel.Regions
 
RestSerializerFactory - Class in org.apache.hadoop.hbase.rest.serializer
Factory used to return a Rest Serializer tailored to the HTTP Requesters accept type in the header.
RestSerializerFactory() - Constructor for class org.apache.hadoop.hbase.rest.serializer.RestSerializerFactory
 
RESTServlet - Class in org.apache.hadoop.hbase.stargate
Singleton class encapsulating global REST servlet state and functions.
RESTServlet() - Constructor for class org.apache.hadoop.hbase.stargate.RESTServlet
Constructor
Result - Class in org.apache.hadoop.hbase.client
Single row result of a Get or Scan query.
Result() - Constructor for class org.apache.hadoop.hbase.client.Result
Constructor used for Writable.
Result(KeyValue[]) - Constructor for class org.apache.hadoop.hbase.client.Result
Instantiate a Result with the specified array of KeyValues.
Result(List<KeyValue>) - Constructor for class org.apache.hadoop.hbase.client.Result
Instantiate a Result with the specified List of KeyValues.
Result(ImmutableBytesWritable) - Constructor for class org.apache.hadoop.hbase.client.Result
Instantiate a Result from the specified raw binary format.
ResultGenerator - Class in org.apache.hadoop.hbase.stargate
 
ResultGenerator() - Constructor for class org.apache.hadoop.hbase.stargate.ResultGenerator
 
ResultScanner - Interface in org.apache.hadoop.hbase.client
Interface for client-side scanning.
resumeEncoding() - Method in class org.apache.hadoop.hbase.util.Base64.Base64OutputStream
Resumes encoding of the stream.
RetouchedBloomFilter - Class in org.apache.hadoop.hbase.migration.nineteen.onelab.filter
Implements a retouched Bloom filter, as defined in the CoNEXT 2006 paper.
RetouchedBloomFilter() - Constructor for class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.RetouchedBloomFilter
Default constructor - use with readFields
RetouchedBloomFilter(int, int, int) - Constructor for class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.RetouchedBloomFilter
Constructor
RetriesExhaustedException - Exception in org.apache.hadoop.hbase.client
Exception thrown by HTable methods when an attempt to do something (like commit changes) fails after a bunch of retries.
RetriesExhaustedException(String) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedException
 
RetriesExhaustedException(String, 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.
returnCompressor(Compressor) - Method in enum org.apache.hadoop.hbase.io.hfile.Compression.Algorithm
 
returnDecompressor(Decompressor) - Method in enum org.apache.hadoop.hbase.io.hfile.Compression.Algorithm
 
rewrite(HBaseConfiguration, FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.Migrate
Rewrite the passed 0.19 mapfile as a 0.20 file.
rollback(Xid) - Method in class org.apache.hadoop.hbase.client.transactional.JtaXAResource
 
rollWriter() - Method in class org.apache.hadoop.hbase.regionserver.HLog
Roll the log writer.
ROOT_COMPARATOR - Static variable in class org.apache.hadoop.hbase.KeyValue
A KeyValue.KVComparator for -ROOT- catalog table KeyValues.
ROOT_KEY_COMPARATOR - Static variable in class org.apache.hadoop.hbase.KeyValue
A KeyValue.KVComparator for -ROOT- catalog table KeyValue keys.
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
rootRegionExists(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Checks if root region exists
RootResource - Class in org.apache.hadoop.hbase.stargate
 
RootResource() - Constructor for class org.apache.hadoop.hbase.stargate.RootResource
Constructor
row - Variable in class org.apache.hadoop.hbase.client.ServerCallable
 
row - Variable in class org.apache.hadoop.hbase.regionserver.QueryMatcher
Row the query is on
ROW - Static variable in interface org.apache.hadoop.hbase.rest.RESTConstants
 
ROW_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell
 
ROW_OFFSET - Static variable in class org.apache.hadoop.hbase.KeyValue
 
rowController - Variable in class org.apache.hadoop.hbase.rest.Dispatcher
Deprecated.  
RowController - Class in org.apache.hadoop.hbase.rest
 
RowController() - Constructor for class org.apache.hadoop.hbase.rest.RowController
 
RowCounter - Class in org.apache.hadoop.hbase.mapred
Deprecated. 
RowCounter() - Constructor for class org.apache.hadoop.hbase.mapred.RowCounter
Deprecated.  
RowCounter - Class in org.apache.hadoop.hbase.mapreduce
A job with a just a map phase to count rows.
RowCounter() - Constructor for class org.apache.hadoop.hbase.mapreduce.RowCounter
 
RowFilter - Class in org.apache.hadoop.hbase.filter
This filter is used to filter based on the key.
RowFilter() - Constructor for class org.apache.hadoop.hbase.filter.RowFilter
Writable constructor, do not use.
RowFilter(CompareFilter.CompareOp, WritableByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.RowFilter
Constructor.
RowFilterInterface - Interface in org.apache.hadoop.hbase.filter
Deprecated. Use filters that are rooted on @{link Filter} instead
RowFilterSet - Class in org.apache.hadoop.hbase.filter
Deprecated. Use filters that are rooted on @{link Filter} instead
RowFilterSet() - Constructor for class org.apache.hadoop.hbase.filter.RowFilterSet
Deprecated. Default constructor, filters nothing.
RowFilterSet(Set<RowFilterInterface>) - Constructor for class org.apache.hadoop.hbase.filter.RowFilterSet
Deprecated. Constructor that takes a set of RowFilters.
RowFilterSet(RowFilterSet.Operator, Set<RowFilterInterface>) - Constructor for class org.apache.hadoop.hbase.filter.RowFilterSet
Deprecated. Constructor that takes a set of RowFilters and an operator.
RowFilterSet.Operator - Enum in org.apache.hadoop.hbase.filter
Deprecated. set operator
RowFilterSetFactory - Class in org.apache.hadoop.hbase.rest.filter
Constructs a RowFilterSet from a JSON argument String.
RowFilterSetFactory() - Constructor for class org.apache.hadoop.hbase.rest.filter.RowFilterSetFactory
 
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
RowModel - Class in org.apache.hadoop.hbase.rest
 
RowModel(HBaseConfiguration, HBaseAdmin) - Constructor for class org.apache.hadoop.hbase.rest.RowModel
 
RowModel - Class in org.apache.hadoop.hbase.stargate.model
Representation of a row.
RowModel() - Constructor for class org.apache.hadoop.hbase.stargate.model.RowModel
Default constructor
RowModel(String) - Constructor for class org.apache.hadoop.hbase.stargate.model.RowModel
Constructor
RowModel(byte[]) - Constructor for class org.apache.hadoop.hbase.stargate.model.RowModel
Constructor
RowModel(String, List<CellModel>) - Constructor for class org.apache.hadoop.hbase.stargate.model.RowModel
Constructor
RowModel(byte[], List<CellModel>) - Constructor for class org.apache.hadoop.hbase.stargate.model.RowModel
Constructor
rowProcessed(boolean, byte[]) - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
Deprecated.  
rowProcessed(boolean, byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
Deprecated.  
rowProcessed(boolean, byte[]) - Method in class org.apache.hadoop.hbase.filter.PageRowFilter
Deprecated.  
rowProcessed(boolean, byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.PageRowFilter
Deprecated.  
rowProcessed(boolean, byte[]) - Method in class org.apache.hadoop.hbase.filter.PrefixRowFilter
Deprecated.  
rowProcessed(boolean, byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.PrefixRowFilter
Deprecated.  
rowProcessed(boolean, byte[]) - Method in class org.apache.hadoop.hbase.filter.RegExpRowFilter
Deprecated.  
rowProcessed(boolean, byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.RegExpRowFilter
Deprecated.  
rowProcessed(boolean, byte[]) - Method in interface org.apache.hadoop.hbase.filter.RowFilterInterface
Deprecated. Use RowFilterInterface.rowProcessed(boolean, byte[], int, int) instead.
rowProcessed(boolean, byte[], int, int) - Method in interface org.apache.hadoop.hbase.filter.RowFilterInterface
Deprecated. 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
Deprecated.  
rowProcessed(boolean, byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.RowFilterSet
Deprecated.  
rowProcessed(boolean, byte[]) - Method in class org.apache.hadoop.hbase.filter.StopRowFilter
Deprecated.  
rowProcessed(boolean, byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.StopRowFilter
Deprecated.  
rowProcessed(boolean, byte[]) - Method in class org.apache.hadoop.hbase.filter.WhileMatchRowFilter
Deprecated.  
rowProcessed(boolean, byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.WhileMatchRowFilter
Deprecated.  
RowResource - Class in org.apache.hadoop.hbase.stargate
 
RowResource(String, String, String) - Constructor for class org.apache.hadoop.hbase.stargate.RowResource
Constructor
RowResult - Class in org.apache.hadoop.hbase.io
Deprecated. As of hbase 0.20.0, replaced by new Get/Put/Delete/Result-based API.
RowResult() - Constructor for class org.apache.hadoop.hbase.io.RowResult
Deprecated. default constructor for writable
RowResult(byte[], HbaseMapWritable<byte[], Cell>) - Constructor for class org.apache.hadoop.hbase.io.RowResult
Deprecated. Create a RowResult from a row and Cell map
RowResult.Entry - Class in org.apache.hadoop.hbase.io
Deprecated. Row entry.
rowResultFromHBase(RowResult[]) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
This utility method creates a list of Thrift TRowResult "struct" based on an Hbase RowResult object.
rowResultFromHBase(RowResult) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
 
rowResultFromHBase(Result[]) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
This utility method creates a list of Thrift TRowResult "struct" based on an Hbase RowResult object.
rowResultFromHBase(Result) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
 
RowResultGenerator - Class in org.apache.hadoop.hbase.stargate
 
RowResultGenerator(String, RowSpec, Filter) - Constructor for class org.apache.hadoop.hbase.stargate.RowResultGenerator
 
ROWS - Static variable in interface org.apache.hadoop.hbase.rest.RESTConstants
 
ROWS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet
 
RowSpec - Class in org.apache.hadoop.hbase.stargate
Parses a path based row/column/timestamp specification into its component elements.
RowSpec(String) - Constructor for class org.apache.hadoop.hbase.stargate.RowSpec
 
RowSpec(byte[], byte[], byte[][], long, long, int) - Constructor for class org.apache.hadoop.hbase.stargate.RowSpec
 
RowSpec(byte[], byte[], Collection<byte[]>, long, long, int) - Constructor for class org.apache.hadoop.hbase.stargate.RowSpec
 
RowUpdateDescriptor - Class in org.apache.hadoop.hbase.rest.descriptors
 
RowUpdateDescriptor(String, String) - Constructor for class org.apache.hadoop.hbase.rest.descriptors.RowUpdateDescriptor
 
RowUpdateDescriptor() - Constructor for class org.apache.hadoop.hbase.rest.descriptors.RowUpdateDescriptor
 
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
 
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
Deprecated.  
run(String[]) - Method in class org.apache.hadoop.hbase.mapred.RowCounter
Deprecated.  
run() - Method in class org.apache.hadoop.hbase.master.HMaster
Main processing loop
run(String[]) - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreFileToStoreFile
 
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
 
running - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
 
running - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
runThread(Thread, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Run and wait on passed thread in HRS context.
rwcc - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
 

S

safeMode - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
Scan - Class in org.apache.hadoop.hbase.client
Used to perform Scan operations.
Scan() - Constructor for class org.apache.hadoop.hbase.client.Scan
Create a Scan operation across all rows.
Scan(byte[], Filter) - Constructor for class org.apache.hadoop.hbase.client.Scan
 
Scan(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Scan
Create a Scan operation starting at the specified row.
Scan(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.client.Scan
Create a Scan operation for the range of rows specified.
Scan(Scan) - Constructor for class org.apache.hadoop.hbase.client.Scan
Creates a new instance of this class while copying all values.
Scan(Get) - Constructor for class org.apache.hadoop.hbase.client.Scan
Builds a scan object with the same specs as get.
SCAN - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Base-64 encoded scanner.
SCAN_CACHEBLOCKS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Set to false to disable server-side caching of blocks for this scan.
SCAN_CACHEDROWS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
The number of rows for caching that will be passed to scanners.
SCAN_COLUMNS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Space delimited list of columns to scan.
SCAN_MAXVERSIONS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
The maximum number of version to return.
SCAN_TIMERANGE_END - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
The ending timestamp used to filter columns with a specific range of versions.
SCAN_TIMERANGE_START - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
The starting timestamp used to filter columns with a specific range of versions.
SCAN_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
The timestamp used to filter columns with a specific timestamp.
ScanDeleteTracker - Class in org.apache.hadoop.hbase.regionserver
This class is responsible for the tracking and enforcement of Deletes during the course of a Scan operation.
ScanDeleteTracker() - Constructor for class org.apache.hadoop.hbase.regionserver.ScanDeleteTracker
Constructor for ScanDeleteTracker
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.
scanMetaRegion(HRegionInfo, MetaUtils.ScannerListener) - Method in class org.apache.hadoop.hbase.util.MetaUtils
Scans a meta region.
Scanner - Interface in org.apache.hadoop.hbase.client
Deprecated. See ResultScanner
SCANNER - Static variable in interface org.apache.hadoop.hbase.rest.RESTConstants
 
SCANNER_COLUMN - Static variable in interface org.apache.hadoop.hbase.rest.RESTConstants
 
SCANNER_FILTER - Static variable in interface org.apache.hadoop.hbase.rest.RESTConstants
 
SCANNER_RESULT_SIZE - Static variable in interface org.apache.hadoop.hbase.rest.RESTConstants
 
SCANNER_START_ROW - Static variable in interface org.apache.hadoop.hbase.rest.RESTConstants
 
SCANNER_STOP_ROW - Static variable in interface org.apache.hadoop.hbase.rest.RESTConstants
 
SCANNER_TIMESTAMP - Static variable in interface org.apache.hadoop.hbase.rest.RESTConstants
 
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[], Scan) - Constructor for class org.apache.hadoop.hbase.client.ScannerCallable
 
scannerClose(Integer) - Method in class org.apache.hadoop.hbase.rest.ScannerModel
 
scannerClose(Integer) - Method in class org.apache.hadoop.hbase.rest.ScannerModel.ScannerMaster
 
scannerClose(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
scannercontroller - Variable in class org.apache.hadoop.hbase.rest.Dispatcher
Deprecated.  
ScannerController - Class in org.apache.hadoop.hbase.rest
 
ScannerController() - Constructor for class org.apache.hadoop.hbase.rest.ScannerController
 
ScannerDescriptor - Class in org.apache.hadoop.hbase.rest.descriptors
 
ScannerDescriptor(byte[][], long, byte[], byte[], String) - Constructor for class org.apache.hadoop.hbase.rest.descriptors.ScannerDescriptor
 
scannerGet(Integer, Long) - Method in class org.apache.hadoop.hbase.rest.ScannerModel
returns the next numResults Results from the Scaner mapped to Integer id.
scannerGet(Integer) - Method in class org.apache.hadoop.hbase.rest.ScannerModel
Returns all rows inbetween the scanners current position and the end of the table.
scannerGet(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
scannerGetList(int, int) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
ScannerIdentifier - Class in org.apache.hadoop.hbase.rest.descriptors
 
ScannerIdentifier(Integer) - Constructor for class org.apache.hadoop.hbase.rest.descriptors.ScannerIdentifier
 
ScannerIdentifier(Integer, Long) - Constructor for class org.apache.hadoop.hbase.rest.descriptors.ScannerIdentifier
 
ScannerInstanceResource - Class in org.apache.hadoop.hbase.stargate
 
ScannerInstanceResource(String, String, ResultGenerator, int) - Constructor for class org.apache.hadoop.hbase.stargate.ScannerInstanceResource
 
scannerMap - Static variable in class org.apache.hadoop.hbase.rest.ScannerModel.ScannerMaster
 
scannerMap - Variable in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
scannerMaster - Static variable in class org.apache.hadoop.hbase.rest.ScannerModel
 
ScannerMessage - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
ScannerMessage.Scanner - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
ScannerMessage.Scanner.Builder - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
ScannerModel - Class in org.apache.hadoop.hbase.rest
 
ScannerModel(HBaseConfiguration, HBaseAdmin) - Constructor for class org.apache.hadoop.hbase.rest.ScannerModel
 
ScannerModel - Class in org.apache.hadoop.hbase.stargate.model
A representation of Scanner parameters.
ScannerModel() - Constructor for class org.apache.hadoop.hbase.stargate.model.ScannerModel
Default constructor
ScannerModel(byte[], byte[], List<byte[]>, int, long, int, String) - Constructor for class org.apache.hadoop.hbase.stargate.model.ScannerModel
Constructor
ScannerModel(byte[], byte[], List<byte[]>, int, long, long, String) - Constructor for class org.apache.hadoop.hbase.stargate.model.ScannerModel
Constructor
ScannerModel.ScannerMaster - Class in org.apache.hadoop.hbase.rest
 
ScannerModel.ScannerMaster() - Constructor for class org.apache.hadoop.hbase.rest.ScannerModel.ScannerMaster
 
scannerOpen(byte[]) - Method in class org.apache.hadoop.hbase.rest.ScannerModel
 
scannerOpen(byte[], long) - Method in class org.apache.hadoop.hbase.rest.ScannerModel
 
scannerOpen(byte[], byte[]) - Method in class org.apache.hadoop.hbase.rest.ScannerModel
 
scannerOpen(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.rest.ScannerModel
 
scannerOpen(byte[], RowFilterInterface) - Method in class org.apache.hadoop.hbase.rest.ScannerModel
 
scannerOpen(byte[], long, RowFilterInterface) - Method in class org.apache.hadoop.hbase.rest.ScannerModel
 
scannerOpen(byte[], byte[], RowFilterInterface) - Method in class org.apache.hadoop.hbase.rest.ScannerModel
 
scannerOpen(byte[], byte[], long, RowFilterInterface) - Method in class org.apache.hadoop.hbase.rest.ScannerModel
 
scannerOpen(byte[], byte[][], long) - Method in class org.apache.hadoop.hbase.rest.ScannerModel
 
scannerOpen(byte[], byte[][]) - Method in class org.apache.hadoop.hbase.rest.ScannerModel
 
scannerOpen(byte[], byte[][], byte[], long) - Method in class org.apache.hadoop.hbase.rest.ScannerModel
 
scannerOpen(byte[], byte[][], byte[]) - Method in class org.apache.hadoop.hbase.rest.ScannerModel
 
scannerOpen(byte[], byte[][], long, RowFilterInterface) - Method in class org.apache.hadoop.hbase.rest.ScannerModel
 
scannerOpen(byte[], byte[][], RowFilterInterface) - Method in class org.apache.hadoop.hbase.rest.ScannerModel
 
scannerOpen(byte[], byte[][], byte[], long, RowFilterInterface) - Method in class org.apache.hadoop.hbase.rest.ScannerModel
 
scannerOpen(byte[], byte[][], byte[], RowFilterInterface) - Method in class org.apache.hadoop.hbase.rest.ScannerModel
 
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.ThriftServer.HBaseHandler
 
scannerOpenWithPrefix(byte[], byte[], List<byte[]>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer.HBaseHandler
 
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.ThriftServer.HBaseHandler
 
ScannerResource - Class in org.apache.hadoop.hbase.stargate
 
ScannerResource(String) - Constructor for class org.apache.hadoop.hbase.stargate.ScannerResource
Constructor
ScannerResultGenerator - Class in org.apache.hadoop.hbase.stargate
 
ScannerResultGenerator(String, RowSpec, Filter) - Constructor for class org.apache.hadoop.hbase.stargate.ScannerResultGenerator
 
scannerSwitch(int, ScannerModel, byte[], byte[][], long, byte[], byte[], RowFilterInterface) - Method in class org.apache.hadoop.hbase.rest.ScannerController
 
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.
ScanQueryMatcher - Class in org.apache.hadoop.hbase.regionserver
A query matcher that is specifically designed for the scan case.
ScanQueryMatcher(Scan, byte[], NavigableSet<byte[]>, long, KeyValue.KeyComparator, int) - Constructor for class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
Constructs a QueryMatcher for a Scan.
scanRootRegion(MetaUtils.ScannerListener) - Method in class org.apache.hadoop.hbase.util.MetaUtils
Scans the root region.
scanRSDirectory() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWrapper
Scans the regions servers directory
ScanWildcardColumnTracker - Class in org.apache.hadoop.hbase.regionserver
Keeps track of the columns for a scan if they are not explicitly specified
ScanWildcardColumnTracker(int) - Constructor for class org.apache.hadoop.hbase.regionserver.ScanWildcardColumnTracker
Return maxVersions of every row.
SchemaResource - Class in org.apache.hadoop.hbase.stargate
 
SchemaResource(String) - Constructor for class org.apache.hadoop.hbase.stargate.SchemaResource
Constructor
second - Variable in class org.apache.hadoop.hbase.util.Pair
 
seek(WritableComparable) - Method in class org.apache.hadoop.hbase.migration.nineteen.io.HalfMapFileReader
 
seek(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
Seeks all scanners at or below the specified seek key.
seek(KeyValue) - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
Seek the scanner at or after the specified KeyValue.
seek(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.MemStore.MemStoreScanner
 
seek(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.MinorCompactingStoreScanner
 
seekBefore(byte[]) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
Consider the key stream of all the keys in the file, k[0] ..
seekBefore(byte[], int, int) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
 
seekTo(byte[]) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
SeekTo or just before the passed key.
seekTo(byte[], int, int) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
 
seekTo() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
Positions this scanner at the start of the file.
selectiveClearing(Key, short) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.RetouchedBloomFilter
Performs the selective clearing for a given key.
serializeCell(Cell) - Method in interface org.apache.hadoop.hbase.rest.serializer.IRestSerializer
serialize a cell object to the output stream Implementation of this method is optional, IF all the work is done in the writeOutput(Object o) method
serializeCell(Cell) - Method in class org.apache.hadoop.hbase.rest.serializer.SimpleXMLSerializer
 
serializeCellArray(Cell[]) - Method in interface org.apache.hadoop.hbase.rest.serializer.IRestSerializer
serialize a Cell array to the output stream
serializeCellArray(Cell[]) - Method in class org.apache.hadoop.hbase.rest.serializer.SimpleXMLSerializer
 
serializeColumnDescriptor(HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.rest.serializer.IRestSerializer
serialize an HColumnDescriptor to the output stream.
serializeColumnDescriptor(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.rest.serializer.SimpleXMLSerializer
 
serializeDatabaseMetadata(DatabaseModel.DatabaseMetadata) - Method in interface org.apache.hadoop.hbase.rest.serializer.IRestSerializer
serialize the database metadata Implementation of this method is optional, IF all the work is done in the writeOutput(Object o) method
serializeDatabaseMetadata(DatabaseModel.DatabaseMetadata) - Method in class org.apache.hadoop.hbase.rest.serializer.SimpleXMLSerializer
 
serializer - Variable in class org.apache.hadoop.hbase.rest.Status
 
serializeRegionData(TableModel.Regions) - Method in interface org.apache.hadoop.hbase.rest.serializer.IRestSerializer
serialize the region data for a table to the output stream Implementation of this method is optional, IF all the work is done in the writeOutput(Object o) method
serializeRegionData(TableModel.Regions) - Method in class org.apache.hadoop.hbase.rest.serializer.SimpleXMLSerializer
 
serializeRowResult(RowResult) - Method in interface org.apache.hadoop.hbase.rest.serializer.IRestSerializer
serialize a RowResult object to the output stream Implementation of this method is optional, IF all the work is done in the writeOutput(Object o) method
serializeRowResult(RowResult) - Method in class org.apache.hadoop.hbase.rest.serializer.SimpleXMLSerializer
 
serializeRowResultArray(RowResult[]) - Method in interface org.apache.hadoop.hbase.rest.serializer.IRestSerializer
serialize a RowResult array to the output stream Implementation of this method is optional, IF all the work is done in the writeOutput(Object o) method
serializeRowResultArray(RowResult[]) - Method in class org.apache.hadoop.hbase.rest.serializer.SimpleXMLSerializer
 
serializeScannerIdentifier(ScannerIdentifier) - Method in interface org.apache.hadoop.hbase.rest.serializer.IRestSerializer
serialize the ScannerIdentifier object to the output stream Implementation of this method is optional, IF all the work is done in the writeOutput(Object o) method
serializeScannerIdentifier(ScannerIdentifier) - Method in class org.apache.hadoop.hbase.rest.serializer.SimpleXMLSerializer
 
serializeStatusMessage(Status.StatusMessage) - Method in interface org.apache.hadoop.hbase.rest.serializer.IRestSerializer
serialize the status message object to the output stream Implementation of this method is optional, IF all the work is done in the writeOutput(Object o) method
serializeStatusMessage(Status.StatusMessage) - Method in class org.apache.hadoop.hbase.rest.serializer.SimpleXMLSerializer
 
serializeTableDescriptor(HTableDescriptor) - Method in interface org.apache.hadoop.hbase.rest.serializer.IRestSerializer
serialize the HTableDescriptor object Implementation of this method is optional, IF all the work is done in the writeOutput(Object o) method
serializeTableDescriptor(HTableDescriptor) - Method in class org.apache.hadoop.hbase.rest.serializer.SimpleXMLSerializer
 
serializeTimestamps(TimestampsDescriptor) - Method in interface org.apache.hadoop.hbase.rest.serializer.IRestSerializer
serialize a description of the timestamps available for a row to the output stream.
serializeTimestamps(TimestampsDescriptor) - Method in class org.apache.hadoop.hbase.rest.serializer.SimpleXMLSerializer
 
server - Variable in class org.apache.hadoop.hbase.client.ServerCallable
 
SERVER - Static variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
SERVER_QUALIFIER - Static variable in interface org.apache.hadoop.hbase.HConstants
The server column qualifier
ServerCallable<T> - Class in org.apache.hadoop.hbase.client
Abstract class that implements 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 do can call HConnectionManager#setRootRegionLocation
serverInfo - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
SERVERVERSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 
set(HStoreKey) - Method in class org.apache.hadoop.hbase.HStoreKey
Deprecated. 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(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
set(HStoreKey) - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey.BeforeThisStoreKey
 
set(HStoreKey) - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey
Set the value of this HStoreKey from the supplied key
set(byte[], double) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.Key
 
setAccepted() - Method in class org.apache.hadoop.hbase.rest.Status
 
setAnalyzerName(String) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
Deprecated.  
setAnalyzerName(String) - Method in class org.apache.hadoop.hbase.mapreduce.IndexConfiguration
 
setAttrs(int, ColumnSchemaMessage.ColumnSchema.Attribute) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
setAttrs(int, ColumnSchemaMessage.ColumnSchema.Attribute.Builder) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
setAttrs(int, TableSchemaMessage.TableSchema.Attribute) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
setAttrs(int, TableSchemaMessage.TableSchema.Attribute.Builder) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
setAutoFlush(boolean) - Method in class org.apache.hadoop.hbase.client.HTable
Turns on or off 'auto-flush' on this instance.
setAverageLoad(double) - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel
 
setAverageLoad(double) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
setBadRequest(Object) - Method in class org.apache.hadoop.hbase.rest.Status
 
setBatch(int) - Method in class org.apache.hadoop.hbase.stargate.model.ScannerModel
 
setBatch(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
setBlockCacheEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHColumnDescriptor
 
setBlockCacheEnabled(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setBlocksize(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setBloomfilter(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setBody(byte[]) - Method in class org.apache.hadoop.hbase.stargate.client.Response
 
setBoost(String, float) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
Deprecated.  
setBoost(String, float) - Method in class org.apache.hadoop.hbase.mapreduce.IndexConfiguration
 
setCacheBlocks(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
Set whether blocks should be cached for this Scan.
setCaching(int) - Method in class org.apache.hadoop.hbase.client.Scan
Set the number of rows for caching that will be passed to scanners.
setCaching(int) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
Set the number of rows that will be fetched on next
setClose() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
Call this when the next invocation of call should close the scanner
setCluster(Cluster) - Method in class org.apache.hadoop.hbase.stargate.client.Client
 
setClusterState(boolean) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWrapper
Set the cluster state, up or down
setClusterStateWatch(Watcher) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWrapper
Watch the state of the cluster, up or down
setCode(int) - Method in class org.apache.hadoop.hbase.stargate.client.Response
 
setColumn(byte[]) - Method in class org.apache.hadoop.hbase.HStoreKey
Deprecated. Change the value of the column in this key
setColumn(byte[]) - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey.BeforeThisStoreKey
 
setColumn(byte[]) - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey
Change the value of the column in this key
setColumn(byte[]) - Method in class org.apache.hadoop.hbase.stargate.model.CellModel
 
setColumn(ByteString) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell.Builder
 
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.
setColumns(byte[][]) - Method in class org.apache.hadoop.hbase.rest.descriptors.ScannerDescriptor
 
setColumns(List<byte[]>) - Method in class org.apache.hadoop.hbase.stargate.model.ScannerModel
 
setColumns(List<ColumnSchemaModel>) - Method in class org.apache.hadoop.hbase.stargate.model.TableSchemaModel
 
setColumns(int, ByteString) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
setColumns(int, ColumnSchemaMessage.ColumnSchema) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
setColumns(int, ColumnSchemaMessage.ColumnSchema.Builder) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
setCompression(String) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
setCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHColumnDescriptor
 
setCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Compression types supported in hbase.
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.mapreduce.GroupingTableMapper
Sets the configuration.
setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.HRegionPartitioner
Sets the configuration.
setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.IndexTableReducer
Sets the configuration.
setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Sets the configuration.
setConflict(Object) - Method in class org.apache.hadoop.hbase.rest.Status
 
setCreated() - Method in class org.apache.hadoop.hbase.rest.Status
 
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.
setData(ByteString) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell.Builder
 
setDeadNodes(List<String>) - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel
 
setDeadNodes(int, String) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
setDeadServers(Collection<String>) - Method in class org.apache.hadoop.hbase.ClusterStatus
 
setDoOptimize(boolean) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
Deprecated.  
setDoOptimize(boolean) - Method in class org.apache.hadoop.hbase.mapreduce.IndexConfiguration
 
setEndKey(byte[]) - Method in class org.apache.hadoop.hbase.stargate.model.TableRegionModel
 
setEndKey(ByteString) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
setEndRow(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase.TableRecordReader
Deprecated.  
setEndRow(byte[]) - Method in class org.apache.hadoop.hbase.stargate.model.ScannerModel
 
setEndRow(ByteString) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
setEndTime(long) - Method in class org.apache.hadoop.hbase.stargate.model.ScannerModel
 
setEndTime(long) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
setEndTime(long) - Method in class org.apache.hadoop.hbase.stargate.RowSpec
 
setErrorHandler(HBaseRPCErrorHandler) - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
Set the handler for calling out of RPC for error conditions.
setExists(boolean) - Method in class org.apache.hadoop.hbase.rest.Status
 
setFamily(byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
 
setFamilyMap(Map<byte[], NavigableSet<byte[]>>) - Method in class org.apache.hadoop.hbase.client.Scan
Setting the familyMap
setFilter(Filter) - Method in class org.apache.hadoop.hbase.client.Get
Apply the specified server-side filter when performing the Get.
setFilter(Filter) - Method in class org.apache.hadoop.hbase.client.Scan
Apply the specified server-side filter when performing the Scan.
setFilter(String) - Method in class org.apache.hadoop.hbase.stargate.model.ScannerModel
 
setFilter(String) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
setFilterIfMissing(boolean) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Set whether entire row should be filtered if column is not found.
setFilters(String) - Method in class org.apache.hadoop.hbase.rest.descriptors.ScannerDescriptor
 
setGone() - Method in class org.apache.hadoop.hbase.rest.Status
 
setHBaseVersion(String) - Method in class org.apache.hadoop.hbase.ClusterStatus
 
setHDFSShutdownThreadOnExit(Thread) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Set the hdfs shutdown thread to run on exit.
setHeaders(Header[]) - Method in class org.apache.hadoop.hbase.stargate.client.Response
 
setHeapSizeMB(int) - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel.Node
 
setHeapSizeMB(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
setHRegionInfo(HRegionInfo) - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey.BeforeThisStoreKey
 
setHRegionInfo(HRegionInfo) - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey
 
setHTable(HTable) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Deprecated. Allows subclasses to set the HTable.
setHTable(HTable) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase.TableRecordReader
Deprecated.  
setHTable(HTable) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Allows subclasses to set the HTable.
setHTable(HTable) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase.TableRecordReader
Sets the HBase table.
setId(Integer) - Method in class org.apache.hadoop.hbase.rest.descriptors.ScannerIdentifier
 
setId(long) - Method in class org.apache.hadoop.hbase.stargate.model.TableRegionModel
 
setId(long) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
setIndex(String, boolean) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
Deprecated.  
setIndex(String, boolean) - Method in class org.apache.hadoop.hbase.mapreduce.IndexConfiguration
 
setInfoPort(int) - Method in class org.apache.hadoop.hbase.HServerInfo
 
setInMemory(boolean) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHColumnDescriptor
 
setInMemory(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setInMemory(boolean) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
setInnerException(Exception) - Method in exception org.apache.hadoop.hbase.rest.exception.HBaseRestException
 
setInputColumns(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Deprecated.  
setInputColumns(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase.TableRecordReader
Deprecated.  
setInternalError(Exception) - Method in class org.apache.hadoop.hbase.rest.Status
 
setInvalidURI() - Method in class org.apache.hadoop.hbase.rest.Status
 
setInvalidURI(Object) - Method in class org.apache.hadoop.hbase.rest.Status
 
setJerseyVersion(String) - Method in class org.apache.hadoop.hbase.stargate.model.VersionModel
 
setJerseyVersion(String) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version.Builder
 
setJvmVersion(String) - Method in class org.apache.hadoop.hbase.stargate.model.VersionModel
 
setJvmVersion(String) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version.Builder
 
setKey(byte[]) - Method in class org.apache.hadoop.hbase.stargate.model.RowModel
 
setKey(ByteString) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
setLatestVersionOnly(boolean) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Set whether only the latest version of the column value should be compared.
setLiveNodes(List<StorageClusterStatusModel.Node>) - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel
 
setLiveNodes(int, StorageClusterStatusMessage.StorageClusterStatus.Node) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
setLiveNodes(int, StorageClusterStatusMessage.StorageClusterStatus.Node.Builder) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
setLoad(HServerLoad) - Method in class org.apache.hadoop.hbase.HServerInfo
 
setLocation(String) - Method in class org.apache.hadoop.hbase.stargate.model.TableRegionModel
 
setLocation(String) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
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
Deprecated.  
setMaxBufferedDeleteTerms(int) - Method in class org.apache.hadoop.hbase.mapreduce.IndexConfiguration
 
setMaxBufferedDocs(int) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
Deprecated.  
setMaxBufferedDocs(int) - Method in class org.apache.hadoop.hbase.mapreduce.IndexConfiguration
 
setMaxFieldLength(int) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
Deprecated.  
setMaxFieldLength(int) - Method in class org.apache.hadoop.hbase.mapreduce.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
 
setMaxHeapSizeMB(int) - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel.Node
 
setMaxHeapSizeMB(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
setMaxMergeDocs(int) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
Deprecated.  
setMaxMergeDocs(int) - Method in class org.apache.hadoop.hbase.mapreduce.IndexConfiguration
 
setMaxSize(long) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
setMaxValues(int) - Method in class org.apache.hadoop.hbase.stargate.RowSpec
 
setMaxVersions() - Method in class org.apache.hadoop.hbase.client.Get
Get all available versions.
setMaxVersions(int) - Method in class org.apache.hadoop.hbase.client.Get
Get up to the specified number of versions of each column.
setMaxVersions() - Method in class org.apache.hadoop.hbase.client.Scan
Get all available versions.
setMaxVersions(int) - Method in class org.apache.hadoop.hbase.client.Scan
Get up to the specified number of versions of each column.
setMaxVersions(int) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHColumnDescriptor
 
setMaxVersions(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setMaxVersions(int) - Method in class org.apache.hadoop.hbase.stargate.model.ScannerModel
 
setMaxVersions(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
setMaxVersions(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
setMaxVersions(int) - Method in class org.apache.hadoop.hbase.stargate.RowSpec
 
setMemStoreFlushSize(long) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
 
setMemStoreFlushSize(long) - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
setMemStoreSizeMB(int) - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
 
setMemstoreSizeMB(int) - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel.Node.Region
 
setMemstoreSizeMB(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
setMemstoreTS(long) - Method in class org.apache.hadoop.hbase.KeyValue
 
setMergeFactor(int) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
Deprecated.  
setMergeFactor(int) - Method in class org.apache.hadoop.hbase.mapreduce.IndexConfiguration
 
setMetaRegion(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
setMethodNotImplemented() - Method in class org.apache.hadoop.hbase.rest.Status
 
setName(String) - Method in class org.apache.hadoop.hbase.HServerInfo
Set the hostname of the server
setName(byte[]) - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
 
setName(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
setName(byte[]) - Method in class org.apache.hadoop.hbase.rest.descriptors.RestCell
 
setName(String) - Method in class org.apache.hadoop.hbase.stargate.model.ColumnSchemaModel
 
setName(byte[]) - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel.Node.Region
 
setName(String) - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel.Node
 
setName(String) - Method in class org.apache.hadoop.hbase.stargate.model.TableInfoModel
 
setName(String) - Method in class org.apache.hadoop.hbase.stargate.model.TableModel
 
setName(String) - Method in class org.apache.hadoop.hbase.stargate.model.TableRegionModel
 
setName(String) - Method in class org.apache.hadoop.hbase.stargate.model.TableSchemaModel
 
setName(String) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
setName(String) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
setName(String) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
setName(ByteString) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
setName(String) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
setName(String) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
setName(int, String) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList.Builder
 
setName(String) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
setName(String) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
setNextPtr(LruHashMap.Entry<K, V>) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
Sets the next pointer for the entry in the LRU.
setNoQueryResults() - Method in class org.apache.hadoop.hbase.rest.Status
 
setNotFound(Object) - Method in class org.apache.hadoop.hbase.rest.Status
 
setNotFound() - Method in class org.apache.hadoop.hbase.rest.Status
 
setNumberOfRegions(int) - Method in class org.apache.hadoop.hbase.HServerLoad
 
setNumberOfRequests(int) - Method in class org.apache.hadoop.hbase.HServerLoad
 
setNumMapTasks(String, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Deprecated. Sets the number of map tasks for the given job configuration to the number of regions the given table has.
setNumReduceTasks(String, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Deprecated. Sets the number of reduce tasks for the given job configuration to the number of regions the given table has.
setNumReduceTasks(String, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Sets the number of reduce tasks for the given job configuration to the number of regions the given table has.
setNumRows(Long) - Method in class org.apache.hadoop.hbase.rest.descriptors.ScannerIdentifier
 
setOffline(boolean) - Method in class org.apache.hadoop.hbase.HRegionInfo
 
setOK() - Method in class org.apache.hadoop.hbase.rest.Status
 
setOK(Object) - Method in class org.apache.hadoop.hbase.rest.Status
 
setOldFilter(RowFilterInterface) - Method in class org.apache.hadoop.hbase.client.Scan
Deprecated.  
setOmitNorms(String, boolean) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
Deprecated.  
setOmitNorms(String, boolean) - Method in class org.apache.hadoop.hbase.mapreduce.IndexConfiguration
 
setOsVersion(String) - Method in class org.apache.hadoop.hbase.stargate.model.VersionModel
 
setOsVersion(String) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version.Builder
 
setPingInterval(Configuration, int) - Static method in class org.apache.hadoop.hbase.ipc.HBaseClient
set the ping interval value in configuration
setPrevPtr(LruHashMap.Entry<K, V>) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
Sets the previous pointer for the entry in the LRU.
setQualifier(byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
 
setReadOnly(boolean) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
 
setReadOnly(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
setReadOnly(boolean) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
setRegionKey(byte[][]) - Method in class org.apache.hadoop.hbase.rest.TableModel.Regions
 
setRegions(List<StorageClusterStatusModel.Node.Region>) - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel.Node
 
setRegions(int) - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel
 
setRegions(List<TableRegionModel>) - Method in class org.apache.hadoop.hbase.stargate.model.TableInfoModel
 
setRegions(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
setRegions(int, StorageClusterStatusMessage.StorageClusterStatus.Region) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
setRegions(int, StorageClusterStatusMessage.StorageClusterStatus.Region.Builder) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
setRegions(int, TableInfoMessage.TableInfo.Region) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
setRegions(int, TableInfoMessage.TableInfo.Region.Builder) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
setRegionsInTransition(NavigableMap<String, String>) - Method in class org.apache.hadoop.hbase.ClusterStatus
 
setRequests(int) - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel.Node
 
setRequests(int) - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel
 
setRequests(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
setRequests(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
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
Deprecated. Change the value of the row key
setRow(byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
 
setRow(byte[]) - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey.BeforeThisStoreKey
 
setRow(byte[]) - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey
Change the value of the row key
setRow(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.QueryMatcher
Set current row
setRow(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
Set current row
setRow(ByteString) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell.Builder
 
setRowFilter(RowFilterInterface) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Deprecated. Allows subclasses to set the RowFilterInterface to be used.
setRowFilter(RowFilterInterface) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase.TableRecordReader
Deprecated.  
setRowkeyName(String) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
Deprecated.  
setRowkeyName(String) - Method in class org.apache.hadoop.hbase.mapreduce.IndexConfiguration
 
setRowLock(long) - Method in class org.apache.hadoop.hbase.io.BatchUpdate
Deprecated. Set the lock to be used for this update
setRowName(String) - Method in class org.apache.hadoop.hbase.rest.descriptors.RowUpdateDescriptor
 
setRows(int, CellSetMessage.CellSet.Row) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Builder
 
setRows(int, CellSetMessage.CellSet.Row.Builder) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Builder
 
setScan(Scan) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Sets the scan defining the actual details like columns etc.
setScan(Scan) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase.TableRecordReader
Sets the scan defining the actual details like columns etc.
setScannerCaching(int) - Method in class org.apache.hadoop.hbase.client.HTable
Sets the number of rows that a scanner will fetch at once.
setScannerCaching(JobConf, int) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Deprecated. Sets the number of rows to return and cache with each scanner iteration.
setScannerCaching(Job, int) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Sets the number of rows to return and cache with each scanner iteration.
setScannerCreated(ScannerIdentifier) - Method in class org.apache.hadoop.hbase.rest.Status
 
setServerAddress(HServerAddress) - Method in class org.apache.hadoop.hbase.HServerInfo
Change the server address.
setServerInfo(Collection<HServerInfo>) - Method in class org.apache.hadoop.hbase.ClusterStatus
 
setServerVersion(String) - Method in class org.apache.hadoop.hbase.stargate.model.VersionModel
 
setServerVersion(String) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version.Builder
 
setSimilarityName(String) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
Deprecated.  
setSimilarityName(String) - Method in class org.apache.hadoop.hbase.mapreduce.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
 
setStargateVersion(String) - Method in class org.apache.hadoop.hbase.stargate.model.VersionModel
 
setStargateVersion(String) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version.Builder
 
setStartCode(long) - Method in class org.apache.hadoop.hbase.HServerInfo
 
setStartCode(long) - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel.Node
 
setStartCode(long) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
setStartKey(byte[]) - Method in class org.apache.hadoop.hbase.stargate.model.TableRegionModel
 
setStartKey(ByteString) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
Set the start row.
setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase.TableRecordReader
Deprecated.  
setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.rest.descriptors.ScannerDescriptor
 
setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.stargate.model.ScannerModel
 
setStartRow(ByteString) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
setStartTime(long) - Method in class org.apache.hadoop.hbase.stargate.model.ScannerModel
 
setStartTime(long) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner.Builder
 
setStartTime(long) - Method in class org.apache.hadoop.hbase.stargate.RowSpec
 
setStatusForTransaction(long, TransactionLogger.TransactionStatus) - Method in class org.apache.hadoop.hbase.client.transactional.HBaseBackedTransactionLogger
 
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
Set the status for a transaction.
setStopRow(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
Set the stop row.
setStopRow(byte[]) - Method in class org.apache.hadoop.hbase.rest.descriptors.ScannerDescriptor
 
setStore(String, boolean) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
Deprecated.  
setStore(String, boolean) - Method in class org.apache.hadoop.hbase.mapreduce.IndexConfiguration
 
setStorefileIndexSizeMB(int) - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
 
setStorefileIndexSizeMB(int) - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel.Node.Region
 
setStorefileIndexSizeMB(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
setStorefiles(int) - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
 
setStorefiles(int) - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel.Node.Region
 
setStorefiles(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
setStorefileSizeMB(int) - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel.Node.Region
 
setStorefileSizeMB(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
setStores(int) - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
 
setStores(int) - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel.Node.Region
 
setStores(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
setTableDesc(HTableDescriptor) - Method in class org.apache.hadoop.hbase.HRegionInfo
 
setTableName(String) - Method in class org.apache.hadoop.hbase.rest.descriptors.RowUpdateDescriptor
 
setTableRecordReader(TableInputFormatBase.TableRecordReader) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Deprecated. Allows subclasses to set the TableInputFormatBase.TableRecordReader.
setTableRecordReader(TableInputFormatBase.TableRecordReader) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Allows subclasses to set the TableInputFormatBase.TableRecordReader.
setTables(List<TableModel>) - Method in class org.apache.hadoop.hbase.stargate.model.TableListModel
 
setThreadReadPoint(long) - Static method in class org.apache.hadoop.hbase.regionserver.ReadWriteConsistencyControl
 
setTimeRange(long, long) - Method in class org.apache.hadoop.hbase.client.Get
Get versions of columns only within the specified timestamp range, [minStamp, maxStamp).
setTimeRange(long, long) - Method in class org.apache.hadoop.hbase.client.Scan
Get versions of columns only within the specified timestamp range, [minStamp, maxStamp).
setTimeStamp(long) - Method in class org.apache.hadoop.hbase.client.Get
Get versions of columns with the specified timestamp.
setTimeStamp(long) - Method in class org.apache.hadoop.hbase.client.Put
Method for setting the timestamp NOTE - This does not affect the timestamp for values previously added to this Put.
setTimeStamp(long) - Method in class org.apache.hadoop.hbase.client.Scan
Get versions of columns with the specified timestamp.
setTimestamp(long) - Method in class org.apache.hadoop.hbase.io.BatchUpdate
Deprecated. Set this BatchUpdate's timestamp.
setTimestamp(byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
 
setTimestamp(long) - Method in class org.apache.hadoop.hbase.rest.descriptors.ScannerDescriptor
 
setTimestamp(long) - Method in class org.apache.hadoop.hbase.stargate.model.CellModel
 
setTimestamp(long) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell.Builder
 
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
Deprecated.  
setTokenize(String, boolean) - Method in class org.apache.hadoop.hbase.mapreduce.IndexConfiguration
 
setTransactionTimeout(int) - Method in class org.apache.hadoop.hbase.client.transactional.JtaXAResource
 
setTtl(int) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
setType(byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
 
setUnsupportedMediaType(Object) - Method in class org.apache.hadoop.hbase.rest.Status
 
setupJob(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
 
setupTask(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
 
setUseCompoundFile(boolean) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
Deprecated.  
setUseCompoundFile(boolean) - Method in class org.apache.hadoop.hbase.mapreduce.IndexConfiguration
 
setUsedHeapMB(int) - Method in class org.apache.hadoop.hbase.HServerLoad
 
setValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
 
setValue(String, String) - Method in class org.apache.hadoop.hbase.client.Scan
 
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
Deprecated.  
setValue(byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
 
setValue(V) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
Set the value of this entry.
setValue(byte[]) - Method in class org.apache.hadoop.hbase.stargate.model.CellModel
 
setValue(String) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
setValue(String) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
setValues(int, CellMessage.Cell) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
setValues(int, CellMessage.Cell.Builder) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
setVersion(long) - Method in class org.apache.hadoop.hbase.HStoreKey
Deprecated. Change the value of the timestamp field
setVersion(long) - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey.BeforeThisStoreKey
 
setVersion(long) - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey
Change the value of the timestamp field
setVersion(String) - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterVersionModel
 
setVersion(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Sets version of file system
setVersion(FileSystem, Path, String) - 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.
setWriteToWAL(boolean) - Method in class org.apache.hadoop.hbase.client.Put
Set whether this Put should be written to the WAL or not.
shouldSplit(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
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 interface org.apache.hadoop.hbase.io.hfile.BlockCache
Shutdown the cache.
shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
 
shutdown() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcMetrics
 
shutdown() - Method in class org.apache.hadoop.hbase.ipc.HBaseRPCStatistics
 
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.master.metrics.MasterStatistics
 
shutdown() - Method in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
 
shutdown() - Method in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerStatistics
 
shutdown() - Method in class org.apache.hadoop.hbase.stargate.client.Client
Shut down the client.
shutdown() - Method in class org.apache.hadoop.hbase.stargate.metrics.StargateMetrics
 
shutdown() - Method in class org.apache.hadoop.hbase.stargate.metrics.StargateStatistics
 
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.
SimpleBlockCache - Class in org.apache.hadoop.hbase.io.hfile
Simple one RFile soft reference cache.
SimpleBlockCache() - Constructor for class org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
Constructor
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
 
SimpleXMLSerializer - Class in org.apache.hadoop.hbase.rest.serializer
Basic first pass at implementing an XML serializer for the REST interface.
SimpleXMLSerializer(HttpServletResponse) - Constructor for class org.apache.hadoop.hbase.rest.serializer.SimpleXMLSerializer
 
SimpleXMLSerializer(HttpServletResponse, boolean) - Constructor for class org.apache.hadoop.hbase.rest.serializer.SimpleXMLSerializer
 
SingleColumnValueFilter - Class in org.apache.hadoop.hbase.filter
This filter is used to filter cells based on value.
SingleColumnValueFilter() - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Writable constructor, do not use.
SingleColumnValueFilter(byte[], byte[], CompareFilter.CompareOp, byte[]) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Constructor for binary compare of the value of a single column.
SingleColumnValueFilter(byte[], byte[], CompareFilter.CompareOp, WritableByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Constructor for binary compare of the value of a single column.
size() - Method in class org.apache.hadoop.hbase.client.Put
 
size() - Method in class org.apache.hadoop.hbase.client.Result
 
size() - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
size() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Get the size of this cache (number of cached blocks)
size() - Method in class org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
 
size() - Method in class org.apache.hadoop.hbase.io.RowResult
Deprecated.  
size() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Gets the size (number of entries) of the map.
size() - Method in class org.apache.hadoop.hbase.util.SoftValueMap
 
size() - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
SIZEOF_BOOLEAN - Static variable in class org.apache.hadoop.hbase.util.Bytes
Size of boolean in bytes
SIZEOF_BYTE - Static variable in class org.apache.hadoop.hbase.util.Bytes
Size of byte in bytes
SIZEOF_CHAR - Static variable in class org.apache.hadoop.hbase.util.Bytes
Size of char in bytes
SIZEOF_DOUBLE - Static variable in class org.apache.hadoop.hbase.util.Bytes
Size of double in bytes
SIZEOF_FLOAT - Static variable in class org.apache.hadoop.hbase.util.Bytes
Size of float in bytes
SIZEOF_INT - Static variable in class org.apache.hadoop.hbase.util.Bytes
Size of int in bytes
SIZEOF_LONG - Static variable in class org.apache.hadoop.hbase.util.Bytes
Size of long in bytes
SIZEOF_SHORT - Static variable in class org.apache.hadoop.hbase.util.Bytes
Size of short in bytes
SkipFilter - Class in org.apache.hadoop.hbase.filter
A wrapper filter that filters an entire row if any of the KeyValue checks do not pass.
SkipFilter() - Constructor for class org.apache.hadoop.hbase.filter.SkipFilter
 
SkipFilter(Filter) - Constructor for class org.apache.hadoop.hbase.filter.SkipFilter
 
skipSleepCycle() - Method in class org.apache.hadoop.hbase.util.Sleeper
If currently asleep, stops sleeping; if not asleep, will skip the next sleep cycle.
sl - Static variable in interface org.apache.hadoop.hbase.io.CodeToClassAndBack
The static loader that is used instead of the static constructor in HbaseMapWritable.
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
 
socketFactory - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
 
socketSendBufferSize - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
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
sorted() - Method in class org.apache.hadoop.hbase.client.Result
Returns a sorted array of KeyValues in this Result.
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() - Method in class org.apache.hadoop.hbase.KeyValue
 
split(byte[], byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Split passed range.
SPLITA_QUALIFIER - Static variable in interface org.apache.hadoop.hbase.HConstants
The lower-half split region column qualifier
SPLITB_QUALIFIER - Static variable in interface org.apache.hadoop.hbase.HConstants
The upper-half split region column qualifier
splitkey - Variable in class org.apache.hadoop.hbase.io.HalfHFileReader
 
splitLog(Path, Path, FileSystem, HBaseConfiguration) - 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.
StargateMetrics - Class in org.apache.hadoop.hbase.stargate.metrics
 
StargateMetrics() - Constructor for class org.apache.hadoop.hbase.stargate.metrics.StargateMetrics
 
StargateStatistics - Class in org.apache.hadoop.hbase.stargate.metrics
 
StargateStatistics(MetricsRegistry) - Constructor for class org.apache.hadoop.hbase.stargate.metrics.StargateStatistics
 
STARGATEVERSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 
start(Xid, int) - Method in class org.apache.hadoop.hbase.client.transactional.JtaXAResource
 
start() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
Starts the service.
STARTCODE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
STARTCODE_QUALIFIER - Static variable in interface org.apache.hadoop.hbase.HConstants
The startcode column qualifier
startKey - Variable in class org.apache.hadoop.hbase.regionserver.QueryMatcher
Key to seek to in memstore and StoreFiles
STARTKEY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
startMonitoring() - Method in class org.apache.hadoop.hbase.metrics.file.TimeStampingFileContext
 
STARTROW_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
STARTTIME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
startup() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
Start the cluster.
statNames - Static variable in class org.apache.hadoop.hbase.rest.Status
 
Status - Class in org.apache.hadoop.hbase.rest
 
Status(HttpServletResponse, IRestSerializer, byte[][]) - Constructor for class org.apache.hadoop.hbase.rest.Status
 
Status.StatusMessage - Class in org.apache.hadoop.hbase.rest
 
Status.StatusMessage(int, boolean, Object) - Constructor for class org.apache.hadoop.hbase.rest.Status.StatusMessage
 
statusCode - Variable in class org.apache.hadoop.hbase.rest.Status
 
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
 
StopRowFilter - Class in org.apache.hadoop.hbase.filter
Deprecated. Use filters that are rooted on @{link Filter} instead
StopRowFilter() - Constructor for class org.apache.hadoop.hbase.filter.StopRowFilter
Deprecated. Default constructor, filters nothing.
StopRowFilter(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.StopRowFilter
Deprecated. Constructor that takes a stopRowKey on which to filter
StopRowFilterFactory - Class in org.apache.hadoop.hbase.rest.filter
FilterFactory that construct a StopRowFilter from an Argument String.
StopRowFilterFactory() - Constructor for class org.apache.hadoop.hbase.rest.filter.StopRowFilterFactory
 
StorageClusterStatusMessage - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
StorageClusterStatusMessage.StorageClusterStatus - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
StorageClusterStatusMessage.StorageClusterStatus.Builder - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
StorageClusterStatusMessage.StorageClusterStatus.Node - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
StorageClusterStatusMessage.StorageClusterStatus.Node.Builder - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
StorageClusterStatusMessage.StorageClusterStatus.Region - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
StorageClusterStatusMessage.StorageClusterStatus.Region.Builder - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
StorageClusterStatusModel - Class in org.apache.hadoop.hbase.stargate.model
Representation of the status of a storage cluster:
StorageClusterStatusModel() - Constructor for class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel
Default constructor
StorageClusterStatusModel.Node - Class in org.apache.hadoop.hbase.stargate.model
Represents a region server.
StorageClusterStatusModel.Node() - Constructor for class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel.Node
Default constructor
StorageClusterStatusModel.Node(String, long) - Constructor for class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel.Node
Constructor
StorageClusterStatusModel.Node.Region - Class in org.apache.hadoop.hbase.stargate.model
Represents a region hosted on a region server.
StorageClusterStatusModel.Node.Region() - Constructor for class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel.Node.Region
Default constructor
StorageClusterStatusModel.Node.Region(byte[]) - Constructor for class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel.Node.Region
Constructor
StorageClusterStatusModel.Node.Region(byte[], int, int, int, int, int) - Constructor for class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel.Node.Region
Constructor
StorageClusterStatusResource - Class in org.apache.hadoop.hbase.stargate
 
StorageClusterStatusResource() - Constructor for class org.apache.hadoop.hbase.stargate.StorageClusterStatusResource
Constructor
StorageClusterVersionModel - Class in org.apache.hadoop.hbase.stargate.model
Simple representation of the version of the storage cluster
StorageClusterVersionModel() - Constructor for class org.apache.hadoop.hbase.stargate.model.StorageClusterVersionModel
 
StorageClusterVersionResource - Class in org.apache.hadoop.hbase.stargate
 
StorageClusterVersionResource() - Constructor for class org.apache.hadoop.hbase.stargate.StorageClusterVersionResource
Constructor
Store - Class in org.apache.hadoop.hbase.regionserver
A Store holds a column family in a Region.
Store(Path, HRegion, HColumnDescriptor, FileSystem, Path, HBaseConfiguration, Progressable) - Constructor for class org.apache.hadoop.hbase.regionserver.Store
Constructor
StoreFile - Class in org.apache.hadoop.hbase.regionserver
A Store data file.
StoreFileGetScan - Class in org.apache.hadoop.hbase.regionserver
Use to execute a get by scanning all the store files in order.
StoreFileGetScan(List<HFileScanner>, QueryMatcher) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileGetScan
Constructor
storefileIndexSizeMB - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
Sum of all the storefile index sizes in this regionserver in MB
STOREFILEINDEXSIZEMB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
storefiles - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
Count of storefiles open on the regionserver.
STOREFILES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
STOREFILESIZEMB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
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.
STORES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
STRING - Static variable in class org.apache.hadoop.hbase.util.ClassSize
String overhead
stringifyFilter(Filter) - Static method in class org.apache.hadoop.hbase.stargate.model.ScannerModel
 
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
Deprecated.  
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, do not use
SubstringComparator(String) - Constructor for class org.apache.hadoop.hbase.filter.SubstringComparator
Constructor
suspendEncoding() - Method in class org.apache.hadoop.hbase.util.Base64.Base64OutputStream
Suspends encoding of the stream.
sync() - Method in class org.apache.hadoop.hbase.regionserver.HLog
 

T

TABLE_DESCRIPTOR_VERSION - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
TABLE_NAME - Static variable in class org.apache.hadoop.hbase.client.transactional.HBaseBackedTransactionLogger
The name of the transaction status table.
tableController - Variable in class org.apache.hadoop.hbase.rest.Dispatcher
Deprecated.  
TableController - Class in org.apache.hadoop.hbase.rest
 
TableController() - Constructor for class org.apache.hadoop.hbase.rest.TableController
 
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
TableInfoMessage - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
TableInfoMessage.TableInfo - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
TableInfoMessage.TableInfo.Builder - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
TableInfoMessage.TableInfo.Region - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
TableInfoMessage.TableInfo.Region.Builder - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
TableInfoModel - Class in org.apache.hadoop.hbase.stargate.model
Representation of a list of table regions.
TableInfoModel() - Constructor for class org.apache.hadoop.hbase.stargate.model.TableInfoModel
Default constructor
TableInfoModel(String) - Constructor for class org.apache.hadoop.hbase.stargate.model.TableInfoModel
Constructor
TableInputFormat - Class in org.apache.hadoop.hbase.mapred
Deprecated. 
TableInputFormat() - Constructor for class org.apache.hadoop.hbase.mapred.TableInputFormat
Deprecated.  
TableInputFormat - Class in org.apache.hadoop.hbase.mapreduce
Convert HBase tabular data into a format that is consumable by Map/Reduce.
TableInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableInputFormat
 
TableInputFormatBase - Class in org.apache.hadoop.hbase.mapred
Deprecated. 
TableInputFormatBase() - Constructor for class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Deprecated.  
TableInputFormatBase - Class in org.apache.hadoop.hbase.mapreduce
A base for TableInputFormats.
TableInputFormatBase() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
 
TableInputFormatBase.TableRecordReader - Class in org.apache.hadoop.hbase.mapred
Deprecated. Iterate over an HBase table data, return (Text, RowResult) pairs
TableInputFormatBase.TableRecordReader() - Constructor for class org.apache.hadoop.hbase.mapred.TableInputFormatBase.TableRecordReader
Deprecated.  
TableInputFormatBase.TableRecordReader - Class in org.apache.hadoop.hbase.mapreduce
Iterate over an HBase table data, return (ImmutableBytesWritable, Result) pairs.
TableInputFormatBase.TableRecordReader() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase.TableRecordReader
 
TableListMessage - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
TableListMessage.TableList - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
TableListMessage.TableList.Builder - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
TableListModel - Class in org.apache.hadoop.hbase.stargate.model
Simple representation of a list of table names.
TableListModel() - Constructor for class org.apache.hadoop.hbase.stargate.model.TableListModel
Default constructor
TableMap<K extends org.apache.hadoop.io.WritableComparable<? super K>,V extends org.apache.hadoop.io.Writable> - Interface in org.apache.hadoop.hbase.mapred
Deprecated. 
TableMapper<KEYOUT,VALUEOUT> - Class in org.apache.hadoop.hbase.mapreduce
Extends the base Mapper class to add the required input key and value classes.
TableMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableMapper
 
TableMapReduceUtil - Class in org.apache.hadoop.hbase.mapred
Deprecated. 
TableMapReduceUtil() - Constructor for class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Deprecated.  
TableMapReduceUtil - Class in org.apache.hadoop.hbase.mapreduce
Utility for TableMapper and TableReducer
TableMapReduceUtil() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
 
TableModel - Class in org.apache.hadoop.hbase.rest
 
TableModel(HBaseConfiguration, HBaseAdmin) - Constructor for class org.apache.hadoop.hbase.rest.TableModel
 
TableModel - Class in org.apache.hadoop.hbase.stargate.model
Simple representation of a table name.
TableModel() - Constructor for class org.apache.hadoop.hbase.stargate.model.TableModel
Default constructor
TableModel(String) - Constructor for class org.apache.hadoop.hbase.stargate.model.TableModel
Constructor
TableModel.Regions - Class in org.apache.hadoop.hbase.rest
 
TableModel.Regions(byte[][]) - Constructor for class org.apache.hadoop.hbase.rest.TableModel.Regions
 
tableName - Variable in class org.apache.hadoop.hbase.client.ServerCallable
 
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
 
TableOutputCommitter - Class in org.apache.hadoop.hbase.mapreduce
Small committer class that does not do anything.
TableOutputCommitter() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
 
TableOutputFormat - Class in org.apache.hadoop.hbase.mapred
Deprecated. 
TableOutputFormat() - Constructor for class org.apache.hadoop.hbase.mapred.TableOutputFormat
Deprecated.  
TableOutputFormat<KEY> - Class in org.apache.hadoop.hbase.mapreduce
Convert Map/Reduce output and write it to an HBase table.
TableOutputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
 
TableOutputFormat.TableRecordWriter - Class in org.apache.hadoop.hbase.mapred
Deprecated. 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
Deprecated. Instantiate a TableRecordWriter with the HBase HClient for writing.
TableOutputFormat.TableRecordWriter<KEY> - Class in org.apache.hadoop.hbase.mapreduce
Writes the reducer output to an HBase table.
TableOutputFormat.TableRecordWriter(HTable) - Constructor for class org.apache.hadoop.hbase.mapreduce.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
Deprecated. 
TableReducer<KEYIN,VALUEIN,KEYOUT> - Class in org.apache.hadoop.hbase.mapreduce
Extends the basic Reducer class to add the required key and value input/output classes.
TableReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableReducer
 
TableRegionModel - Class in org.apache.hadoop.hbase.stargate.model
Representation of a region of a table and its current location on the storage cluster.
TableRegionModel() - Constructor for class org.apache.hadoop.hbase.stargate.model.TableRegionModel
Constructor
TableRegionModel(String, long, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.stargate.model.TableRegionModel
Constructor
TableRegionModel(String, long, byte[], byte[], String) - Constructor for class org.apache.hadoop.hbase.stargate.model.TableRegionModel
Constructor
TableResource - Class in org.apache.hadoop.hbase.stargate
 
TableResource(String) - Constructor for class org.apache.hadoop.hbase.stargate.TableResource
Constructor
tables - Variable in class org.apache.hadoop.hbase.rest.DatabaseModel.DatabaseMetadata
 
TableSchemaMessage - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
TableSchemaMessage.TableSchema - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
TableSchemaMessage.TableSchema.Attribute - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
TableSchemaMessage.TableSchema.Attribute.Builder - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
TableSchemaMessage.TableSchema.Builder - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
TableSchemaModel - Class in org.apache.hadoop.hbase.stargate.model
A representation of HBase table descriptors.
TableSchemaModel() - Constructor for class org.apache.hadoop.hbase.stargate.model.TableSchemaModel
Default constructor.
TableSchemaModel(HTableDescriptor) - Constructor for class org.apache.hadoop.hbase.stargate.model.TableSchemaModel
Constructor
TableSplit - Class in org.apache.hadoop.hbase.mapred
Deprecated. 
TableSplit() - Constructor for class org.apache.hadoop.hbase.mapred.TableSplit
Deprecated. default constructor
TableSplit(byte[], byte[], byte[], String) - Constructor for class org.apache.hadoop.hbase.mapred.TableSplit
Deprecated. Constructor
TableSplit - Class in org.apache.hadoop.hbase.mapreduce
A table split corresponds to a key range (low, high).
TableSplit() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSplit
Default constructor.
TableSplit(byte[], byte[], byte[], String) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSplit
Creates a new instance while assigning all variables.
tail(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
tailMap(byte[]) - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
 
tailMap(byte[]) - Method in class org.apache.hadoop.hbase.io.RowResult
Deprecated.  
tailMap(K) - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
tcpKeepAlive - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
 
tcpKeepAlive - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
tcpNoDelay - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
 
tcpNoDelay - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
THLogKey - Class in org.apache.hadoop.hbase.regionserver.transactional
 
THLogKey() - Constructor for class org.apache.hadoop.hbase.regionserver.transactional.THLogKey
 
THLogKey(byte[], byte[], long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.transactional.THLogKey
 
THLogKey(byte[], byte[], long, long, THLogKey.TrxOp, long) - Constructor for class org.apache.hadoop.hbase.regionserver.transactional.THLogKey
 
THLogKey.TrxOp - Enum in org.apache.hadoop.hbase.regionserver.transactional
Type of Transactional op going into the HLot
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
 
thresholdIdleConnections - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
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
 
TIME_STAMPS - Static variable in interface org.apache.hadoop.hbase.rest.RESTConstants
 
TimeRange - Class in org.apache.hadoop.hbase.io
Represents an interval of version timestamps.
TimeRange() - Constructor for class org.apache.hadoop.hbase.io.TimeRange
Default constructor.
TimeRange(long) - Constructor for class org.apache.hadoop.hbase.io.TimeRange
Represents interval [minStamp, Long.MAX_VALUE)
TimeRange(byte[]) - Constructor for class org.apache.hadoop.hbase.io.TimeRange
Represents interval [minStamp, Long.MAX_VALUE)
TimeRange(long, long) - Constructor for class org.apache.hadoop.hbase.io.TimeRange
Represents interval [minStamp, maxStamp)
TimeRange(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.io.TimeRange
Represents interval [minStamp, maxStamp)
TIMESTAMP_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell
 
TIMESTAMP_TYPE_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
 
TimestampController - Class in org.apache.hadoop.hbase.rest
 
TimestampController() - Constructor for class org.apache.hadoop.hbase.rest.TimestampController
 
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
 
TimestampModel - Class in org.apache.hadoop.hbase.rest
 
TimestampModel(HBaseConfiguration, HBaseAdmin) - Constructor for class org.apache.hadoop.hbase.rest.TimestampModel
 
TimestampsDescriptor - Class in org.apache.hadoop.hbase.rest.descriptors
 
TimestampsDescriptor() - Constructor for class org.apache.hadoop.hbase.rest.descriptors.TimestampsDescriptor
 
toArray(List<byte[]>) - Static method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
toBigDecimal(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to a BigDecimal
toBigDecimal(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to a BigDecimal value
toBigDecimal(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to a BigDecimal value
toBinaryFromHex(byte) - Static method in class org.apache.hadoop.hbase.util.Bytes
Takes a ASCII digit in the range A-F0-9 and returns the corresponding integer/ordinal value.
toBoolean(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
toBuilder() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell
 
toBuilder() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row
 
toBuilder() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet
 
toBuilder() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
toBuilder() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
toBuilder() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
toBuilder() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
toBuilder() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
toBuilder() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
toBuilder() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
toBuilder() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo
 
toBuilder() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList
 
toBuilder() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
toBuilder() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
toBuilder() - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 
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(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.Bytes
Returns a new byte array, copied from the passed ByteBuffer.
toBytes(String) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a string to a UTF-8 byte array.
toBytes(boolean) - Static method in class org.apache.hadoop.hbase.util.Bytes
Convert a boolean to a byte array.
toBytes(long) - Static method in class org.apache.hadoop.hbase.util.Bytes
Convert a long value to a byte array
toBytes(float) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
toBytes(double) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
toBytes(int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Convert an int value to a byte array
toBytes(short) - Static method in class org.apache.hadoop.hbase.util.Bytes
Convert a short value to a byte array
toBytes(char) - Static method in class org.apache.hadoop.hbase.util.Bytes
Convert a char value to a byte array
toBytes(char[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Convert a char array value to a byte array
toBytes(BigDecimal) - Static method in class org.apache.hadoop.hbase.util.Bytes
Convert a BigDecimal value to a byte array
toBytesBinary(String) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
toChar(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to a char value
toChar(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to a char value
toChar(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to a char value
toChars(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to a char array value
toChars(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to a char array value
toChars(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to a char array value
toDouble(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
toDouble(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
toFloat(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Presumes float encoded as IEEE 754 floating-point "single format"
toFloat(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Presumes float encoded as IEEE 754 floating-point "single format"
toInt(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to an int value
toInt(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to an int value
toInt(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to an int value
toLong(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to a long value
toLong(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to a long value
toLong(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to a long value
toShort(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to a short value
toShort(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to a short value
toShort(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to a short value
toString() - Method in class org.apache.hadoop.hbase.client.Delete
 
toString() - Method in class org.apache.hadoop.hbase.client.Get
 
toString() - Method in class org.apache.hadoop.hbase.client.Put
 
toString() - Method in class org.apache.hadoop.hbase.client.Result
 
toString() - Method in class org.apache.hadoop.hbase.client.Scan
 
toString() - Method in class org.apache.hadoop.hbase.client.tableindexed.IndexedTableDescriptor
 
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
Deprecated.  
toString() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
toString() - Method in class org.apache.hadoop.hbase.io.BatchOperation
Deprecated.  
toString() - Method in class org.apache.hadoop.hbase.io.BatchUpdate
Deprecated.  
toString() - Method in class org.apache.hadoop.hbase.io.Cell
Deprecated.  
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.hfile.HFile.Reader
 
toString() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.Writer
 
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
Deprecated.  
toString() - Method in class org.apache.hadoop.hbase.io.TimeRange
 
toString() - Method in class org.apache.hadoop.hbase.KeyValue
 
toString() - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
Deprecated.  
toString() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
Deprecated.  
toString() - Method in class org.apache.hadoop.hbase.mapreduce.IndexConfiguration
 
toString() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Returns the details about this instance as a string.
toString() - Method in class org.apache.hadoop.hbase.master.MetaRegion
 
toString() - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey.BeforeThisStoreKey
 
toString() - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey
 
toString() - Method in class org.apache.hadoop.hbase.migration.nineteen.io.Reference
 
toString() - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.BloomFilter
 
toString() - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.CountingBloomFilter
 
toString() - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.DynamicBloomFilter
 
toString() - Method in class org.apache.hadoop.hbase.migration.nineteen.regionserver.HStoreFile
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.HLog.HLogEntry
 
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.LruHashMap.Entry
Returns String representation of the entry in form "key=value"
toString() - Method in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.Store
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
toString() - Method in enum org.apache.hadoop.hbase.rest.Dispatcher.ContentType
Deprecated.  
toString() - Method in exception org.apache.hadoop.hbase.rest.filter.FilterFactoryConstants.MalformedFilterException
 
toString() - Method in class org.apache.hadoop.hbase.stargate.model.ColumnSchemaModel
 
toString() - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterStatusModel
 
toString() - Method in class org.apache.hadoop.hbase.stargate.model.StorageClusterVersionModel
 
toString() - Method in class org.apache.hadoop.hbase.stargate.model.TableInfoModel
 
toString() - Method in class org.apache.hadoop.hbase.stargate.model.TableListModel
 
toString() - Method in class org.apache.hadoop.hbase.stargate.model.TableModel
 
toString() - Method in class org.apache.hadoop.hbase.stargate.model.TableRegionModel
 
toString() - Method in class org.apache.hadoop.hbase.stargate.model.TableSchemaModel
 
toString() - Method in class org.apache.hadoop.hbase.stargate.model.VersionModel
 
toString() - Method in class org.apache.hadoop.hbase.stargate.RowSpec
 
toString(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
toString(byte[], String, byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
toString(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
toString() - Method in class org.apache.hadoop.hbase.util.Pair
 
toStringBinary(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
toStringBinary(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
toStringFirstKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
toStringLastKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
tr - Variable in class org.apache.hadoop.hbase.regionserver.QueryMatcher
TimeRange the query is for
TRANSACTION - Static variable in interface org.apache.hadoop.hbase.rest.RESTConstants
 
TRANSACTION_OPERATION - Static variable in interface org.apache.hadoop.hbase.rest.RESTConstants
 
TRANSACTION_OPERATION_ABORT - Static variable in interface org.apache.hadoop.hbase.rest.RESTConstants
 
TRANSACTION_OPERATION_COMMIT - Static variable in interface org.apache.hadoop.hbase.rest.RESTConstants
 
TRANSACTION_OPERATION_CREATE - Static variable in interface org.apache.hadoop.hbase.rest.RESTConstants
 
TransactionalRegion - Class in org.apache.hadoop.hbase.regionserver.transactional
Regionserver which provides transactional support for atomic transactions.
TransactionalRegion(Path, HLog, FileSystem, HBaseConfiguration, HRegionInfo, FlushRequester, Leases) - 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
 
TransactionalRPC - Class in org.apache.hadoop.hbase.client.transactional
Simple class for registering the transactional RPC codes.
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, Scan) - 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
 
transactionsById - Variable in class org.apache.hadoop.hbase.regionserver.transactional.TransactionalRegion
 
TransactionState - Class in org.apache.hadoop.hbase.client.transactional
Holds client-side transaction information.
TREEMAP - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for TreeMap
triggerNow() - Method in class org.apache.hadoop.hbase.Chore
If the thread is currently sleeping, trigger the core to happen immediately.
TRUE - Static variable in interface org.apache.hadoop.hbase.rest.RESTConstants
 
tryCommit(TransactionState) - Method in class org.apache.hadoop.hbase.client.transactional.TransactionManager
Try and commit a transaction.
tsController - Variable in class org.apache.hadoop.hbase.rest.Dispatcher
Deprecated.  
TTL - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
ttl - Variable in class org.apache.hadoop.hbase.regionserver.Store
 
TTL_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
TYPE - Static variable in interface org.apache.hadoop.hbase.rest.filter.FilterFactoryConstants
 

U

unionFilters(String) - Method in class org.apache.hadoop.hbase.rest.ScannerController
Given a list of filters in JSON string form, returns a RowSetFilter that returns true if all input filters return true on a Row (aka an AND statement).
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
Releases 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
 
unlockRow(RowLock) - Method in class org.apache.hadoop.hbase.stargate.client.RemoteHTable
 
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.
update() - Method in interface org.apache.hadoop.hbase.regionserver.ColumnTracker
Updates internal variables in between files
update() - Method in interface org.apache.hadoop.hbase.regionserver.DeleteTracker
Called at the end of every StoreFile.
update() - Method in class org.apache.hadoop.hbase.regionserver.ExplicitColumnTracker
Called at the end of every StoreFile or memstore.
update() - Method in class org.apache.hadoop.hbase.regionserver.GetDeleteTracker
Called at the end of every StoreFile.
update() - Method in class org.apache.hadoop.hbase.regionserver.QueryMatcher
Called after reading each section (memstore, snapshot, storefiles).
update() - Method in class org.apache.hadoop.hbase.regionserver.ScanDeleteTracker
 
update() - Method in class org.apache.hadoop.hbase.regionserver.ScanWildcardColumnTracker
 
update() - Method in class org.apache.hadoop.hbase.regionserver.WildcardColumnTracker
Called at the end of every StoreFile or memstore.
updateColumnValue(byte[], byte[], byte[], long) - Method in class org.apache.hadoop.hbase.regionserver.Store
Increments the value for the given row/family/qualifier.
updateLatestStamp(byte[]) - Method in class org.apache.hadoop.hbase.KeyValue
 
updateMETARegionInfo(HRegion, HRegionInfo) - Method in class org.apache.hadoop.hbase.util.MetaUtils
Update COL_REGIONINFO in meta region r with HRegionInfo hri
updateReaders() - Method in interface org.apache.hadoop.hbase.regionserver.ChangedReadersObserver
Notify observers.
updateRSLocationGetWatch(HServerInfo, Watcher) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWrapper
Update the RS address and set a watcher on the znode
updateTable(String, ArrayList<HColumnDescriptor>) - Method in class org.apache.hadoop.hbase.rest.TableModel
 
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.
usage() - Static method in class org.apache.hadoop.hbase.util.CompressionTest
 
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
Deprecated.  
validate(byte[][]) - Method in class org.apache.hadoop.hbase.filter.PageRowFilter
Deprecated.  
validate(byte[][]) - Method in class org.apache.hadoop.hbase.filter.PrefixRowFilter
Deprecated.  
validate(byte[][]) - Method in class org.apache.hadoop.hbase.filter.RegExpRowFilter
Deprecated.  
validate(byte[][]) - Method in interface org.apache.hadoop.hbase.filter.RowFilterInterface
Deprecated. Validates that this filter applies only to a subset of the given columns.
validate(byte[][]) - Method in class org.apache.hadoop.hbase.filter.RowFilterSet
Deprecated.  
validate(byte[][]) - Method in class org.apache.hadoop.hbase.filter.StopRowFilter
Deprecated.  
validate(byte[][]) - Method in class org.apache.hadoop.hbase.filter.WhileMatchRowFilter
Deprecated.  
validateInput(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormat
Deprecated.  
validateRootPath(Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Verifies root directory path is a valid URI with a scheme
value() - Method in class org.apache.hadoop.hbase.client.Result
Returns the value of the first column in the Result.
value - Variable in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
The value
VALUE - Static variable in interface org.apache.hadoop.hbase.rest.filter.FilterFactoryConstants
 
VALUE - Static variable in interface org.apache.hadoop.hbase.rest.RESTConstants
 
VALUE_CLASS - Static variable in class org.apache.hadoop.hbase.migration.nineteen.io.HBaseMapFile
Values are instances of this class.
VALUE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
VALUE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
valueClass - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
 
ValueFilter - Class in org.apache.hadoop.hbase.filter
This filter is used to filter based on column value.
ValueFilter() - Constructor for class org.apache.hadoop.hbase.filter.ValueFilter
Writable constructor, do not use.
ValueFilter(CompareFilter.CompareOp, WritableByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.ValueFilter
Constructor.
valueMap - Variable in class org.apache.hadoop.hbase.io.Cell
Deprecated.  
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
Deprecated. Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.filter.CompareFilter.CompareOp
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.filter.Filter.ReturnCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.filter.FilterList.Operator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.filter.RowFilterSet.Operator
Deprecated. Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.HColumnDescriptor.CompressionType
Deprecated. Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.HConstants.Modify
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.hfile.Compression.Algorithm
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.KeyValue.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.migration.nineteen.io.Reference.Range
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.DeleteTracker.DeleteCompare
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.transactional.THLogKey.TrxOp
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.rest.Dispatcher.ContentType
Deprecated. 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 - Variable in class org.apache.hadoop.hbase.client.Scan
 
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
Deprecated. Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.filter.CompareFilter.CompareOp
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.filter.Filter.ReturnCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.filter.FilterList.Operator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.filter.RowFilterSet.Operator
Deprecated. Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.HColumnDescriptor.CompressionType
Deprecated. 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.HConstants.Modify
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.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.hfile.Compression.Algorithm
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.io.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
Deprecated.  
values() - Static method in enum org.apache.hadoop.hbase.KeyValue.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.migration.nineteen.io.Reference.Range
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.DeleteTracker.DeleteCompare
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Intentionally unimplemented.
values() - Static method in enum org.apache.hadoop.hbase.regionserver.transactional.THLogKey.TrxOp
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.Dispatcher.ContentType
Deprecated. 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
 
VALUES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row
 
vectorSize - Variable in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.Filter
The vector size of this filter.
VERSION_FILE_NAME - Static variable in interface org.apache.hadoop.hbase.HConstants
name of version file
VERSION_STRING - Static variable in interface org.apache.hadoop.hbase.stargate.Constants
 
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
 
VersionMessage - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
VersionMessage.Version - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
VersionMessage.Version.Builder - Class in org.apache.hadoop.hbase.stargate.protobuf.generated
 
VersionModel - Class in org.apache.hadoop.hbase.stargate.model
A representation of the collection of versions of the Stargate software components.
VersionModel() - Constructor for class org.apache.hadoop.hbase.stargate.model.VersionModel
Default constructor.
VersionModel(ServletContext) - Constructor for class org.apache.hadoop.hbase.stargate.model.VersionModel
Constructor
VersionResource - Class in org.apache.hadoop.hbase.stargate
Implements REST software version reporting
VersionResource() - Constructor for class org.apache.hadoop.hbase.stargate.VersionResource
Constructor
VERSIONS - Static variable in interface org.apache.hadoop.hbase.HConstants
 
vintToBytes(long) - Static method in class org.apache.hadoop.hbase.util.Bytes
 

W

waitForMasterAddressAvailability() - Method in class org.apache.hadoop.hbase.master.ZKMasterAddressWatcher
Wait for master address to be available.
waitForProxy(Class, long, InetSocketAddress, Configuration, int, long) - 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.
waitOnSafeMode(HBaseConfiguration, long) - Static method in class org.apache.hadoop.hbase.util.FSUtils
If DFS, check safe mode and if so, wait until we clear it.
watchMasterAddress(Watcher) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWrapper
Set a watcher on the master address ZNode.
WEEK_IN_SECONDS - Static variable in interface org.apache.hadoop.hbase.HConstants
Seconds in a week
WhileMatchFilter - Class in org.apache.hadoop.hbase.filter
A wrapper filter that filters everything after the first time false is returned from any wrapped filters Filter.filterRowKey(byte[], int, int), Filter.filterKeyValue(org.apache.hadoop.hbase.KeyValue), Filter.filterRow() or Filter.filterAllRemaining().
WhileMatchFilter() - Constructor for class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
WhileMatchFilter(Filter) - Constructor for class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
WhileMatchRowFilter - Class in org.apache.hadoop.hbase.filter
Deprecated. Use filters that are rooted on @{link Filter} instead
WhileMatchRowFilter() - Constructor for class org.apache.hadoop.hbase.filter.WhileMatchRowFilter
Deprecated. Default constructor, filters nothing.
WhileMatchRowFilter(RowFilterInterface) - Constructor for class org.apache.hadoop.hbase.filter.WhileMatchRowFilter
Deprecated. Constructor
WhileMatchRowFilterFactory - Class in org.apache.hadoop.hbase.rest.filter
Factory to produce WhileMatchRowFilters from JSON Expects as an arguement a valid JSON Object in String form of another RowFilterInterface.
WhileMatchRowFilterFactory() - Constructor for class org.apache.hadoop.hbase.rest.filter.WhileMatchRowFilterFactory
 
WildcardColumnTracker - Class in org.apache.hadoop.hbase.regionserver
This class is used for the tracking and enforcement of columns and numbers of versions during the course of a Get or Scan operation, when all available column qualifiers have been asked for in the query.
WildcardColumnTracker(int) - Constructor for class org.apache.hadoop.hbase.regionserver.WildcardColumnTracker
Default constructor.
withinOrAfterTimeRange(long) - Method in class org.apache.hadoop.hbase.io.TimeRange
Check if the specified timestamp is within this TimeRange.
withinTimeRange(byte[], int) - Method in class org.apache.hadoop.hbase.io.TimeRange
Check if the specified timestamp is within this TimeRange.
withinTimeRange(long) - Method in class org.apache.hadoop.hbase.io.TimeRange
Check if the specified timestamp is within this TimeRange.
WritableByteArrayComparable - Class in org.apache.hadoop.hbase.filter
Base class, combines Comparable and Writable.
WritableByteArrayComparable() - Constructor for class org.apache.hadoop.hbase.filter.WritableByteArrayComparable
Nullary constructor, for Writable
WritableByteArrayComparable(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.WritableByteArrayComparable
Constructor.
WritableComparator<T> - Interface in org.apache.hadoop.hbase
Interface that brings writable and comparable together
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.Delete
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.client.Get
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.client.Put
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.client.Result
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.client.Scan
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.client.tableindexed.IndexSpecification
write(DataOutput) - Method in class org.apache.hadoop.hbase.client.tableindexed.IndexSpecificationArray
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.client.tableindexed.SimpleIndexKeyGenerator
write(DataOutput) - Method in class org.apache.hadoop.hbase.ClusterStatus
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
Deprecated.  
write(DataOutput) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.filter.PageRowFilter
Deprecated.  
write(DataOutput) - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.filter.PrefixRowFilter
Deprecated.  
write(DataOutput) - Method in class org.apache.hadoop.hbase.filter.RegExpRowFilter
Deprecated.  
write(DataOutput) - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.filter.RowFilterSet
Deprecated.  
write(DataOutput) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.filter.StopRowFilter
Deprecated.  
write(DataOutput) - Method in class org.apache.hadoop.hbase.filter.SubstringComparator
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.filter.WhileMatchRowFilter
Deprecated.  
write(DataOutput) - Method in class org.apache.hadoop.hbase.filter.WritableByteArrayComparable
 
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
Deprecated.  
write(DataOutput) - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.io.BatchOperation
Deprecated.  
write(DataOutput) - Method in class org.apache.hadoop.hbase.io.BatchUpdate
Deprecated.  
write(DataOutput) - Method in class org.apache.hadoop.hbase.io.Cell
Deprecated.  
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(FileSystem, Path) - Method in class org.apache.hadoop.hbase.io.Reference
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.io.RowResult
Deprecated.  
write(DataOutput) - Method in class org.apache.hadoop.hbase.io.TimeRange
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.KeyValue
 
write(OutputStream) - Method in class org.apache.hadoop.hbase.mapred.IndexConfiguration
Deprecated.  
write(DataOutput) - Method in class org.apache.hadoop.hbase.mapred.LuceneDocumentWrapper
Deprecated.  
write(ImmutableBytesWritable, BatchUpdate) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat.TableRecordWriter
Deprecated.  
write(DataOutput) - Method in class org.apache.hadoop.hbase.mapred.TableSplit
Deprecated.  
write(OutputStream) - Method in class org.apache.hadoop.hbase.mapreduce.IndexConfiguration
 
write(ImmutableBytesWritable, LuceneDocumentWrapper) - Method in class org.apache.hadoop.hbase.mapreduce.IndexRecordWriter
Writes the record into an index.
write(DataOutput) - Method in class org.apache.hadoop.hbase.mapreduce.LuceneDocumentWrapper
 
write(KEY, Writable) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat.TableRecordWriter
Writes a key/value pair into the table.
write(DataOutput) - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Writes the field values to the output.
write(DataOutput) - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey.BeforeThisStoreKey
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.migration.nineteen.HStoreKey
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.migration.nineteen.io.Reference
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.BloomFilter
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.CountingBloomFilter
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.DynamicBloomFilter
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.Filter
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.Key
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.RetouchedBloomFilter
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.regionserver.HLogKey
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.regionserver.transactional.THLogKey
 
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 Base64.Base64OutputStream.write(int) repeatedly until len bytes are written.
writeArray(DataOutput, Result[]) - Static method in class org.apache.hadoop.hbase.client.Result
 
writeByteArray(DataOutput, byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Write byte-array with a WritableableUtils.vint prefix.
writeByteArray(DataOutput, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Write byte-array to out with a vint length prefix.
writeByteArray(byte[], int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Write byte-array from src to tgt with a vint length prefix.
writeMasterAddress(HServerAddress) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWrapper
Write address of master to ZooKeeper.
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.
writeOutOfSafeMode() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWrapper
Create ephemeral ZNode signifying that we're out of safe mode.
writeOutput(Object) - Method in interface org.apache.hadoop.hbase.rest.serializer.IRestSerializer
Serializes an object into the appropriate format and writes it to the output stream.
writeOutput(Object) - Method in class org.apache.hadoop.hbase.rest.serializer.SimpleXMLSerializer
 
writeRootRegionLocation(HServerAddress) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWrapper
Write root region location to ZooKeeper.
writeRSLocation(HServerInfo) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWrapper
Write in ZK this RS startCode and address.
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellMessage.Cell
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet.Row
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.CellSetMessage.CellSet
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.ScannerMessage.Scanner
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo.Region
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableInfoMessage.TableInfo
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableListMessage.TableList
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.TableSchemaMessage.TableSchema
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.stargate.protobuf.generated.VersionMessage.Version
 
writeTo(Object, Class<?>, Type, Annotation[], MediaType, MultivaluedMap<String, Object>, OutputStream) - Method in class org.apache.hadoop.hbase.stargate.provider.producer.PlainTextMessageBodyProducer
 
writeTo(ProtobufMessageHandler, Class<?>, Type, Annotation[], MediaType, MultivaluedMap<String, Object>, OutputStream) - Method in class org.apache.hadoop.hbase.stargate.provider.producer.ProtobufMessageBodyProducer
 
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

X

XMLRestParser - Class in org.apache.hadoop.hbase.rest.parser
 
XMLRestParser() - Constructor for class org.apache.hadoop.hbase.rest.parser.XMLRestParser
 
xor(Filter) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.BloomFilter
 
xor(Filter) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.CountingBloomFilter
 
xor(Filter) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.DynamicBloomFilter
 
xor(Filter) - Method in class org.apache.hadoop.hbase.migration.nineteen.onelab.filter.Filter
Peforms a logical XOR between this filter and a specified filter.

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
 
ZKMasterAddressWatcher - Class in org.apache.hadoop.hbase.master
ZooKeeper watcher for the master address.
ZKMasterAddressWatcher(HMaster) - Constructor for class org.apache.hadoop.hbase.master.ZKMasterAddressWatcher
Create a watcher with a ZooKeeperWrapper instance.
ZKServerTool - Class in org.apache.hadoop.hbase.zookeeper
Tool for reading ZooKeeper servers from HBase XML configuation and producing a line-by-line list for use by bash scripts.
ZKServerTool() - Constructor for class org.apache.hadoop.hbase.zookeeper.ZKServerTool
 
ZOOKEEPER_CONFIG_NAME - Static variable in interface org.apache.hadoop.hbase.HConstants
Name of ZooKeeper config file in conf/ directory.
ZOOKEEPER_PAUSE - Static variable in interface org.apache.hadoop.hbase.HConstants
Parameter name for ZooKeeper pause between retries.
ZOOKEEPER_QUORUM - Static variable in interface org.apache.hadoop.hbase.HConstants
Name of ZooKeeper quorum configuration parameter.
ZOOKEEPER_RETRIES - Static variable in interface org.apache.hadoop.hbase.HConstants
Parameter name for number of times to retry writes to ZooKeeper.
ZooKeeperWrapper - Class in org.apache.hadoop.hbase.zookeeper
Wraps a ZooKeeper instance and adds HBase specific functionality.
ZooKeeperWrapper(HBaseConfiguration, Watcher) - Constructor for class org.apache.hadoop.hbase.zookeeper.ZooKeeperWrapper
Create a ZooKeeperWrapper.

_

__getBlockcache() - Method in class org.apache.hadoop.hbase.stargate.model.ColumnSchemaModel
 
__getBlocksize() - Method in class org.apache.hadoop.hbase.stargate.model.ColumnSchemaModel
 
__getBloomfilter() - Method in class org.apache.hadoop.hbase.stargate.model.ColumnSchemaModel
 
__getCompression() - Method in class org.apache.hadoop.hbase.stargate.model.ColumnSchemaModel
 
__getInMemory() - Method in class org.apache.hadoop.hbase.stargate.model.ColumnSchemaModel
 
__getIsMeta() - Method in class org.apache.hadoop.hbase.stargate.model.TableSchemaModel
 
__getIsRoot() - Method in class org.apache.hadoop.hbase.stargate.model.TableSchemaModel
 
__getReadOnly() - Method in class org.apache.hadoop.hbase.stargate.model.TableSchemaModel
 
__getTTL() - Method in class org.apache.hadoop.hbase.stargate.model.ColumnSchemaModel
 
__getVersions() - Method in class org.apache.hadoop.hbase.stargate.model.ColumnSchemaModel
 
__setBlockcache(boolean) - Method in class org.apache.hadoop.hbase.stargate.model.ColumnSchemaModel
 
__setBlocksize(int) - Method in class org.apache.hadoop.hbase.stargate.model.ColumnSchemaModel
 
__setBloomfilter(boolean) - Method in class org.apache.hadoop.hbase.stargate.model.ColumnSchemaModel
 
__setCompression(String) - Method in class org.apache.hadoop.hbase.stargate.model.ColumnSchemaModel
 
__setInMemory(boolean) - Method in class org.apache.hadoop.hbase.stargate.model.ColumnSchemaModel
 
__setIsMeta(boolean) - Method in class org.apache.hadoop.hbase.stargate.model.TableSchemaModel
 
__setIsRoot(boolean) - Method in class org.apache.hadoop.hbase.stargate.model.TableSchemaModel
 
__setReadOnly(boolean) - Method in class org.apache.hadoop.hbase.stargate.model.TableSchemaModel
 
__setTTL(int) - Method in class org.apache.hadoop.hbase.stargate.model.ColumnSchemaModel
 
__setVersions(int) - Method in class org.apache.hadoop.hbase.stargate.model.ColumnSchemaModel
 

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

Copyright © 2010 The Apache Software Foundation