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

A

A - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'A'
abort(String, Throwable) - Method in interface org.apache.hadoop.hbase.client.Admin
 
abortProcedure(long, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
abort a procedure
abortProcedureAsync(long, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Abort a procedure but does not block and wait for it be completely removed.
abortTask(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
 
accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization
 
accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.MutationSerialization
 
accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.ResultSerialization
 
AccessDeniedException - Exception in org.apache.hadoop.hbase.security
Exception thrown by access-related methods.
AccessDeniedException() - Constructor for exception org.apache.hadoop.hbase.security.AccessDeniedException
 
AccessDeniedException(Class<?>, String) - Constructor for exception org.apache.hadoop.hbase.security.AccessDeniedException
 
AccessDeniedException(String) - Constructor for exception org.apache.hadoop.hbase.security.AccessDeniedException
 
AccessDeniedException(Throwable) - Constructor for exception org.apache.hadoop.hbase.security.AccessDeniedException
 
add(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Append
Add the specified column and value to this Append operation.
add(Cell) - Method in class org.apache.hadoop.hbase.client.Append
Add column and value to this Append operation.
add(Cell) - Method in class org.apache.hadoop.hbase.client.Increment
Add the specified KeyValue to this operation.
add(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
Deprecated.
add(byte[], byte[], long, byte[]) - Method in class org.apache.hadoop.hbase.client.Put
Deprecated.
add(byte[], ByteBuffer, long, ByteBuffer) - Method in class org.apache.hadoop.hbase.client.Put
add(Cell) - Method in class org.apache.hadoop.hbase.client.Put
Add the specified KeyValue to this Put operation.
add(Put) - Method in class org.apache.hadoop.hbase.client.RowMutations
Add a Put operation to the list of mutations
add(Delete) - Method in class org.apache.hadoop.hbase.client.RowMutations
Add a Delete operation to the list of mutations
add(String) - Method in class org.apache.hadoop.hbase.rest.client.Cluster
Add a node to the cluster
add(String, int) - Method in class org.apache.hadoop.hbase.rest.client.Cluster
Add a node to the cluster
add(DataType<?>) - Method in class org.apache.hadoop.hbase.types.StructBuilder
Append field to the sequence of accumulated fields.
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
 
add(byte[][]) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
add(long) - Method in class org.apache.hadoop.hbase.util.Counter
 
add(long, long) - Method in class org.apache.hadoop.hbase.util.FastLongHistogram
Deprecated.
Adds a value to the histogram.
add(long) - Method in class org.apache.hadoop.hbase.util.LongAdder
Adds the given value.
addAllServers(Collection<Address>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
Adds a group of servers.
addAllTables(Collection<TableName>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
 
addClientPort(int) - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
Add a client port to the list.
addColumn(TableName, HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Add a column to an existing table.
addColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
Delete the latest version of the specified column.
addColumn(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
Delete the specified version of the specified column.
addColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Get
Get the column from the specific family with the specified qualifier.
addColumn(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Increment
Increment the column from the specific family with the specified qualifier by the specified amount.
addColumn(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
Add the specified column and value to this Put operation.
addColumn(byte[], byte[], long, byte[]) - Method in class org.apache.hadoop.hbase.client.Put
Add the specified column and value, with the specified timestamp as its version to this Put operation.
addColumn(byte[], ByteBuffer, long, ByteBuffer) - Method in class org.apache.hadoop.hbase.client.Put
Add the specified column and value, with the specified timestamp as its version to this Put operation.
addColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
Get the column from the specified family with the specified qualifier.
addColumns(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
Delete all versions of the specified column.
addColumns(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
Delete all versions of the specified column with a timestamp less than or equal to the specified timestamp.
addColumns(Scan, byte[][]) - Static method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Adds an array of columns specified using old format, family:qualifier.
addConfiguration(Map<String, String>) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor.Builder
 
addConfiguration(String, String) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor.Builder
 
addCoprocessor(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Add a table coprocessor to this table.
addCoprocessor(String, Path, int, Map<String, String>) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Add a table coprocessor to this table.
addCoprocessorWithSpec(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Add a table coprocessor to this table.
addDeleteMarker(Cell) - Method in class org.apache.hadoop.hbase.client.Delete
Advanced use only.
addDependencyJars(JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
 
addDependencyJars(Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Add the HBase dependency jars as well as jars for any of the configured job classes to the job configuration, so that JobClient will ship them to the cluster and add them to the DistributedCache.
addDependencyJars(Configuration, Class<?>...) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Deprecated.
addDependencyJarsForClasses(Configuration, Class<?>...) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Add the jars containing the given classes to the job's configuration such that JobClient will ship them to the cluster and add them to the DistributedCache.
addExtraHeader(String, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Add extra headers.
addFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
Delete all versions of all columns of the specified family.
addFamily(byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
Delete all columns of the specified family with a timestamp less than or equal to the specified timestamp.
addFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.Get
Get all columns from the specified family.
addFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
Get all columns from the specified family.
addFamily(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
Does NOT add a column family.
addFamily(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Adds a column family.
addFamilyVersion(byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
Delete all columns of the specified family with a timestamp equal to the specified timestamp.
addFilter(List<Filter>) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
addFilter(Filter) - Method in class org.apache.hadoop.hbase.filter.FilterList
Add a filter.
addFilterAndArguments(Configuration, Class<? extends Filter>, List<String>) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
Add a Filter to be instantiated on import
addHBaseDependencyJars(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Add HBase and its dependencies (only) to the job configuration.
addHbaseResources(Configuration) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
 
addImmutable(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
addImmutable(byte[], byte[], byte[], Tag[]) - Method in class org.apache.hadoop.hbase.client.Put
This expects that the underlying arrays won't change.
addImmutable(byte[], byte[], long, byte[]) - Method in class org.apache.hadoop.hbase.client.Put
addImmutable(byte[], byte[], long, byte[], Tag[]) - Method in class org.apache.hadoop.hbase.client.Put
This expects that the underlying arrays won't change.
addImmutable(byte[], ByteBuffer, long, ByteBuffer, Tag[]) - Method in class org.apache.hadoop.hbase.client.Put
This expects that the underlying arrays won't change.
addImmutable(byte[], ByteBuffer, long, ByteBuffer) - Method in class org.apache.hadoop.hbase.client.Put
addMaster() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
addMaster(Configuration, int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
addMaster(Configuration, int, User) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
addPeer(String, String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
Use addPeer(String, ReplicationPeerConfig, Map) instead.
addPeer(String, String, String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
addPeer(String, ReplicationPeerConfig, Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Add a new remote slave cluster for replication.
addPeer(String, ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Add a new remote slave cluster for replication.
addRegionServer() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
addRegionServer(Configuration, int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
addRegionServer(Configuration, int, User) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
Address - Class in org.apache.hadoop.hbase.net
An immutable type to hold a hostname and port combo, like an Endpoint or java.net.InetSocketAddress (but without danger of our calling resolve -- we do NOT want a resolve happening every time we want to hold a hostname and port combo).
addResults(ClientProtos.RegionLoadStats) - Method in class org.apache.hadoop.hbase.client.Result
addServer(Address) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
Adds the server to the group.
addTable(TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
 
addToken(Token<? extends TokenIdentifier>) - Method in class org.apache.hadoop.hbase.security.User
Adds the given Token to the user's credentials.
addTypeFilter(QuotaType) - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
Add a type to the filter list
Admin - Interface in org.apache.hadoop.hbase.client
The administrative API for HBase.
Admin.MasterSwitchType - Enum in org.apache.hadoop.hbase.client
Deprecated.
ADMIN_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
 
advance() - Method in class org.apache.hadoop.hbase.client.Result
 
ALL_VERSIONS - Static variable in class org.apache.hadoop.hbase.HConstants
Define for 'return-all-versions'.
AND - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
AND Byte Array
AND_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
AND Array
AND_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
 
Append - Class in org.apache.hadoop.hbase.client
Performs Append operations on a single row.
Append(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Append
Create a Append operation for the specified row.
Append(Append) - Constructor for class org.apache.hadoop.hbase.client.Append
Copy constructor
Append(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.client.Append
Create a Append operation for the specified row.
append(Append) - Method in interface org.apache.hadoop.hbase.client.Table
Appends values to one or more columns within a single row.
append(Append) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
appendPeerTableCFs(String, String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Append the replicable table-cf config of the specified peer
appendPeerTableCFs(String, Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Append the replicable table-cf config of the specified peer
apply(byte) - Method in enum org.apache.hadoop.hbase.util.Order
Apply order to the byte val.
apply(byte[]) - Method in enum org.apache.hadoop.hbase.util.Order
Apply order to the byte array val.
apply(byte[], int, int) - Method in enum org.apache.hadoop.hbase.util.Order
Apply order to a range within the byte array val.
areAdjacent(HRegionInfo, HRegionInfo) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Check whether two regions are adjacent
arePartsEqual(ByteBuffer, int, int, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Check whether two parts in the same buffer are equal.
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedBlob
 
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedBlobVar
 
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedFloat32
 
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedFloat64
 
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt16
 
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt32
 
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt64
 
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt8
 
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedNumeric
 
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedString
 
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.RawBytes
 
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.RawString
 
assign(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
 
ASSIGN_RANDOM_PORTS - Static variable in class org.apache.hadoop.hbase.LocalHBaseCluster
 
ATTRIBUTE_SEPERATOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
Attributes - Interface in org.apache.hadoop.hbase.client
 
AuthUtil - Class in org.apache.hadoop.hbase
Utility methods for helping with security tasks.

B

BACKOFF_POLICY_CLASS - Static variable in interface org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicy
 
BACKSLASH - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for Backslash
BadAuthException - Exception in org.apache.hadoop.hbase.ipc
 
BadAuthException() - Constructor for exception org.apache.hadoop.hbase.ipc.BadAuthException
 
BadAuthException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.BadAuthException
 
BadAuthException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.ipc.BadAuthException
 
balancer() - Method in interface org.apache.hadoop.hbase.client.Admin
Invoke the balancer.
balancer(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Invoke the balancer.
base - Variable in class org.apache.hadoop.hbase.types.FixedLengthWrapper
 
BASE_NAMESPACE_DIR - Static variable in class org.apache.hadoop.hbase.HConstants
 
batch(List<? extends Row>, Object[]) - Method in interface org.apache.hadoop.hbase.client.Table
Method that does a batch call on Deletes, Gets, Puts, Increments, Appends, RowMutations The ordering of execution of the actions is not defined.
batch(List<? extends Row>) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
If any exception is thrown by one of the actions, there is no way to retrieve the partially executed results. Use Table.batch(List, Object[]) instead.
batch(List<? extends Row>, Object[]) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
batch(List<? extends Row>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
batchCallback(List<? extends Row>, Object[], Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.Table
Same as Table.batch(List, Object[]), but with a callback.
batchCallback(List<? extends Row>, Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
If any exception is thrown by one of the actions, there is no way to retrieve the partially executed results. Use Table.batchCallback(List, Object[], org.apache.hadoop.hbase.client.coprocessor.Batch.Callback) instead.
batchCallback(List<? extends Row>, Object[], Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
batchCallback(List<? extends Row>, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R) - Method in interface org.apache.hadoop.hbase.client.Table
Creates an instance of the given Service subclass for each table region spanning the range from the startKey row to endKey row (inclusive), all the invocations to the same region server will be batched into one call.
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R, Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.Table
Creates an instance of the given Service subclass for each table region spanning the range from the startKey row to endKey row (inclusive), all the invocations to the same region server will be batched into one call.
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
BinaryComparator - Class in org.apache.hadoop.hbase.filter
A binary comparator which lexicographically compares against the specified byte array using Bytes.compareTo(byte[], byte[]).
BinaryComparator(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.BinaryComparator
Constructor
BinaryPrefixComparator - Class in org.apache.hadoop.hbase.filter
A comparator which compares against a specified byte array, but only compares up to the length of this byte array.
BinaryPrefixComparator(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.BinaryPrefixComparator
Constructor
binaryPrefixType - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
BinaryPrefixType byte array
binarySearch(Cell[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
 
binarySearch(Cell[], byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
Searches for the latest value for the specified column.
binarySearch(byte[][], byte[], int, int, RawComparator<?>) - Static method in class org.apache.hadoop.hbase.util.Bytes
Binary search for keys in indexes.
binarySearch(byte[][], Cell, RawComparator<Cell>) - Static method in class org.apache.hadoop.hbase.util.Bytes
Binary search for keys in indexes.
binaryType - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
BinaryType byte array
BitComparator - Class in org.apache.hadoop.hbase.filter
A bit comparator which performs the specified bitwise operation on each of the bytes with the specified byte array.
BitComparator(byte[], BitComparator.BitwiseOp) - Constructor for class org.apache.hadoop.hbase.filter.BitComparator
Constructor
BitComparator.BitwiseOp - Enum in org.apache.hadoop.hbase.filter
Bit operators.
bitOperator - Variable in class org.apache.hadoop.hbase.filter.BitComparator
 
blobVarEncodedLength(int) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Calculate the expected BlobVar encoded length based on unencoded length.
BLOCKCACHE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Key for the BLOCKCACHE attribute.
BLOCKSIZE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Size of storefile/hfile 'blocks'.
BLOOMFILTER - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
BloomType - Enum in org.apache.hadoop.hbase.regionserver
 
BUCKET_CACHE_IOENGINE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Current ioengine options in include: heap, offheap and file:PATH (where PATH is the path to the file that will host the file-based cache.
BUCKET_CACHE_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
When using bucket cache, this is a float that EITHER represents a percentage of total heap memory size to give to the cache (if < 1.0) OR, it is the capacity in megabytes of the cache.
buf - Variable in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
BufferedMutator - Interface in org.apache.hadoop.hbase.client
Used to communicate with a single HBase table similar to Table but meant for batched, asynchronous puts.
BufferedMutator.ExceptionListener - Interface in org.apache.hadoop.hbase.client
Listens for asynchronous exceptions on a BufferedMutator.
BufferedMutatorParams - Class in org.apache.hadoop.hbase.client
Parameters for instantiating a BufferedMutator.
BufferedMutatorParams(TableName) - Constructor for class org.apache.hadoop.hbase.client.BufferedMutatorParams
 
build() - Method in class org.apache.hadoop.hbase.NamespaceDescriptor.Builder
 
buildDependencyClasspath(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Returns a classpath string built from the content of the "tmpjars" value in conf.
buildModelFromPut(Put) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
buildMultiRowSpec(byte[][], int) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
buildResultFromModel(CellSetModel) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
buildRowSpec(byte[], Map, long, long, int) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
buildSetQuotaRequestProto(QuotaSettings) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettings
Deprecated.
Removed in HBase 2.0+ as a part of removing protobuf from our API
BULK_OUTPUT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.Import
 
BULK_OUTPUT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
BULKLOAD_MAX_RETRIES_NUMBER - Static variable in class org.apache.hadoop.hbase.HConstants
Maximum time to retry for a failed bulk load request
bulkLoadPhase(Table, Connection, ExecutorService, Deque<LoadIncrementalHFiles.LoadQueueItem>, Multimap<ByteBuffer, LoadIncrementalHFiles.LoadQueueItem>) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
This takes the LQI's grouped by likely regions and attempts to bulk load them.
bypassGlobals(String, boolean) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Set the "bypass global settings" for the specified user
ByteArrayComparable - Class in org.apache.hadoop.hbase.filter
Base class for byte array comparators
ByteArrayComparable(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.ByteArrayComparable
Constructor.
ByteBufferOutputStream - Class in org.apache.hadoop.hbase.io
Not thread safe!
ByteBufferOutputStream(int) - Constructor for class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
ByteBufferOutputStream(int, boolean) - Constructor for class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
ByteBufferOutputStream(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
ByteBufferUtils - Class in org.apache.hadoop.hbase.util
Utility functions for working with byte buffers, such as reading/writing variable-length long numbers.
ByteRange - Interface in org.apache.hadoop.hbase.util
Lightweight, reusable class for specifying ranges of byte[]'s.
ByteRangeUtils - Class in org.apache.hadoop.hbase.util
Utility methods for working with ByteRange.
ByteRangeUtils() - Constructor for class org.apache.hadoop.hbase.util.ByteRangeUtils
 
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
Create a zero-size sequence.
Bytes(byte[]) - Constructor for class org.apache.hadoop.hbase.util.Bytes
Create a Bytes using the byte array as the initial value.
Bytes(Bytes) - Constructor for class org.apache.hadoop.hbase.util.Bytes
Set the new Bytes to the contents of the passed ibw.
Bytes(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.util.Bytes
Set the value to a given byte range
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.RowEndKeyComparator - Class in org.apache.hadoop.hbase.util
A Bytes.ByteArrayComparator that treats the empty array as the largest value.
Bytes.RowEndKeyComparator() - Constructor for class org.apache.hadoop.hbase.util.Bytes.RowEndKeyComparator
 
BYTES_COMPARATOR - Static variable in class org.apache.hadoop.hbase.util.Bytes
Pass this to TreeMaps where byte [] are keys.
BYTES_PER_CHECKSUM - Static variable in class org.apache.hadoop.hbase.HConstants
The name of the configuration parameter that specifies the number of bytes in a newly created checksum chunk.
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_BLOOMS_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
CACHE_DATA_IN_L1 - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Key for cache data into L1 if cache is set up with more than one tier.
CACHE_DATA_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
CACHE_INDEX_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
calculateAutoBalancedSplits(List<InputSplit>, long) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Calculates the number of MapReduce input splits for the map tasks.
calculateRebalancedSplits(List<InputSplit>, JobContext, long) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Deprecated. 
callBlockingMethod(Descriptors.MethodDescriptor, RpcController, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
 
CallCancelledException - Exception in org.apache.hadoop.hbase.ipc
Client side call cancelled.
CallCancelledException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.CallCancelledException
 
CallDroppedException - Exception in org.apache.hadoop.hbase
Returned to the clients when their request was discarded due to server being overloaded.
CallDroppedException() - Constructor for exception org.apache.hadoop.hbase.CallDroppedException
 
CallDroppedException(String) - Constructor for exception org.apache.hadoop.hbase.CallDroppedException
 
CallerDisconnectedException - Exception in org.apache.hadoop.hbase.ipc
Exception indicating that the remote host making this IPC lost its IPC connection.
CallerDisconnectedException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.CallerDisconnectedException
 
callExecService(RpcController, Descriptors.MethodDescriptor, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
 
callMethod(Descriptors.MethodDescriptor, RpcController, Message, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
 
CallQueueTooBigException - Exception in org.apache.hadoop.hbase
 
CallQueueTooBigException() - Constructor for exception org.apache.hadoop.hbase.CallQueueTooBigException
 
CallQueueTooBigException(String) - Constructor for exception org.apache.hadoop.hbase.CallQueueTooBigException
 
CallTimeoutException - Exception in org.apache.hadoop.hbase.ipc
Client-side call timeout
CallTimeoutException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.CallTimeoutException
 
cancel() - Method in class org.apache.hadoop.hbase.ScheduledChore
 
cancel(boolean) - Method in class org.apache.hadoop.hbase.ScheduledChore
 
cancelChore(ScheduledChore) - Method in class org.apache.hadoop.hbase.ChoreService
 
cancelChore(ScheduledChore, boolean) - Method in class org.apache.hadoop.hbase.ChoreService
 
CATALOG_FAMILY - Static variable in class org.apache.hadoop.hbase.HConstants
The catalog family
CATALOG_FAMILY_STR - Static variable in class org.apache.hadoop.hbase.HConstants
The catalog family as a string
Cell - Interface in org.apache.hadoop.hbase
The unit of storage in HBase consisting of the following fields:
CellCounter - Class in org.apache.hadoop.hbase.mapreduce
A job with a a map and reduce phase to count cells in a table.
CellCounter() - Constructor for class org.apache.hadoop.hbase.mapreduce.CellCounter
 
CellCreator - Class in org.apache.hadoop.hbase.mapreduce
Facade to create Cells for HFileOutputFormat.
CellCreator(Configuration) - Constructor for class org.apache.hadoop.hbase.mapreduce.CellCreator
 
cellScanner() - Method in class org.apache.hadoop.hbase.client.Mutation
 
cellScanner() - Method in class org.apache.hadoop.hbase.client.Result
 
CellScannerButNoCodecException - Exception in org.apache.hadoop.hbase.ipc
Thrown if a cellscanner but no codec to encode it with.
CellScannerButNoCodecException() - Constructor for exception org.apache.hadoop.hbase.ipc.CellScannerButNoCodecException
 
CellUtil - Class in org.apache.hadoop.hbase
Utility methods helpful slinging Cell instances.
CellUtil() - Constructor for class org.apache.hadoop.hbase.CellUtil
 
cellVisibilityExpr - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
 
CF_RENAME_PROP - Static variable in class org.apache.hadoop.hbase.mapreduce.Import
 
CFNAME - Static variable in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
 
chance - Variable in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
checkAndDelete(byte[], byte[], byte[], byte[], Delete) - Method in interface org.apache.hadoop.hbase.client.Table
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndDelete(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Delete) - Method in interface org.apache.hadoop.hbase.client.Table
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndDelete(byte[], byte[], byte[], byte[], Delete) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
checkAndDelete(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Delete) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], RowMutations) - Method in interface org.apache.hadoop.hbase.client.Table
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], RowMutations) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
checkAndPut(byte[], byte[], byte[], byte[], Put) - Method in interface org.apache.hadoop.hbase.client.Table
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndPut(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Put) - Method in interface org.apache.hadoop.hbase.client.Table
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndPut(byte[], byte[], byte[], byte[], Put) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
checkAndPut(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Put) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
checkForAnd(byte[], int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Checks if the current index of filter string we are on is the beginning of the keyword 'AND'
checkForOr(byte[], int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Checks if the current index of filter string we are on is the beginning of the keyword 'OR'
checkForSkip(byte[], int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Checks if the current index of filter string we are on is the beginning of the keyword 'SKIP'
checkForWhile(byte[], int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Checks if the current index of filter string we are on is the beginning of the keyword 'WHILE'
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat
 
checkOutputSpecs(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
 
checkOutputSpecs(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
Checks if the output table exists and is enabled.
CHECKSUM_TYPE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
The name of the configuration parameter that specifies the name of an algorithm that is used to compute checksums for newly created blocks.
chore() - Method in class org.apache.hadoop.hbase.ScheduledChore
The task to execute on each scheduled execution of the Chore
choreForTesting() - Method in class org.apache.hadoop.hbase.ScheduledChore
 
ChoreService - Class in org.apache.hadoop.hbase
ChoreService is a service that can be used to schedule instances of ScheduledChore to run periodically while sharing threads.
ChoreService(String) - Constructor for class org.apache.hadoop.hbase.ChoreService
 
ChoreService(String, boolean) - Constructor for class org.apache.hadoop.hbase.ChoreService
 
ChoreService(String, int, boolean) - Constructor for class org.apache.hadoop.hbase.ChoreService
 
Cipher - Class in org.apache.hadoop.hbase.io.crypto
A common interface for a cryptographic algorithm.
Cipher(CipherProvider) - Constructor for class org.apache.hadoop.hbase.io.crypto.Cipher
 
CIPHER_AES - Static variable in class org.apache.hadoop.hbase.HConstants
Default cipher for encryption
CipherProvider - Interface in org.apache.hadoop.hbase.io.crypto
An CipherProvider contributes support for various cryptographic Ciphers.
classifyExs(List<Throwable>) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
cleanup() - Method in class org.apache.hadoop.hbase.ScheduledChore
Override to run cleanup tasks when the Chore encounters an error and must stop running
cleanupJob(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
 
clearCaches(ServerName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
clearDeadServers(List<ServerName>) - Method in interface org.apache.hadoop.hbase.client.Admin
Clear dead region servers from master.
clearRegionCache() - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
clearRegionCache(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
clearRegionCache(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Client - Class in org.apache.hadoop.hbase.rest.client
A wrapper around HttpClient which provides some useful function and semantics for interacting with the REST gateway.
Client() - Constructor for class org.apache.hadoop.hbase.rest.client.Client
Default Constructor
Client(Cluster) - Constructor for class org.apache.hadoop.hbase.rest.client.Client
Constructor
Client(Cluster, boolean) - Constructor for class org.apache.hadoop.hbase.rest.client.Client
Constructor
CLIENT_PORT_STR - Static variable in class org.apache.hadoop.hbase.HConstants
The ZK client port key in the ZK properties map.
ClientBackoffPolicy - Interface in org.apache.hadoop.hbase.client.backoff
Configurable policy for the amount of time a client should wait for a new request to the server when given the server load statistics.
ClockOutOfSyncException - Exception in org.apache.hadoop.hbase
This exception is thrown by the master when a region server clock skew is too high.
ClockOutOfSyncException(String) - Constructor for exception org.apache.hadoop.hbase.ClockOutOfSyncException
 
clone() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
cloneFamily(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
cloneQualifier(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
cloneRow(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
get individual arrays for tests
cloneSnapshot(byte[], TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Create a new table by cloning the snapshot content.
cloneSnapshot(String, TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Create a new table by cloning the snapshot content.
cloneSnapshot(String, TableName, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Create a new table by cloning the snapshot content.
cloneValue(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
close() - Method in interface org.apache.hadoop.hbase.client.Admin
 
close() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
Performs a BufferedMutator.flush() and releases any resources held.
close() - Method in interface org.apache.hadoop.hbase.client.Connection
 
close() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
Closes the internal Connection.
close() - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
 
close() - Method in interface org.apache.hadoop.hbase.client.ResultScanner
Closes the scanner and releases any resources it has allocated
close() - Method in interface org.apache.hadoop.hbase.client.Table
Releases any resources held or pending changes in internal buffers.
close() - Method in class org.apache.hadoop.hbase.client.TableSnapshotScanner
 
close() - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
close() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
 
close() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
 
close() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
Closes the split.
close() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
Closes the split.
close() - Method in class org.apache.hadoop.hbase.quotas.QuotaRetriever
 
close() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
closeRegion(String, String) - Method in interface org.apache.hadoop.hbase.client.Admin
Close a region.
closeRegion(byte[], String) - Method in interface org.apache.hadoop.hbase.client.Admin
Close a region.
closeRegion(ServerName, HRegionInfo) - Method in interface org.apache.hadoop.hbase.client.Admin
Close a region.
closeRegionWithEncodedRegionName(String, String) - Method in interface org.apache.hadoop.hbase.client.Admin
For expert-admins.
closeTable() - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Close the Table and related objects that were initialized via TableInputFormatBase.initializeTable(Connection, TableName).
closeTable() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Close the Table and related objects that were initialized via TableInputFormatBase.initializeTable(Connection, TableName).
Cluster - Class in org.apache.hadoop.hbase.rest.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.rest.client.Cluster
Constructor
Cluster(List<String>) - Constructor for class org.apache.hadoop.hbase.rest.client.Cluster
Constructor
CLUSTER_DISTRIBUTED - Static variable in class org.apache.hadoop.hbase.HConstants
Cluster is in distributed mode or not
CLUSTER_ID_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
Default value for cluster ID
CLUSTER_ID_FILE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
name of the file for unique cluster ID
CLUSTER_IS_DISTRIBUTED - Static variable in class org.apache.hadoop.hbase.HConstants
Cluster is fully-distributed
CLUSTER_IS_LOCAL - Static variable in class org.apache.hadoop.hbase.HConstants
Cluster is standalone or pseudo-distributed
ClusterStatus - Class in org.apache.hadoop.hbase
Status information on the HBase cluster.
ClusterStatus() - Constructor for class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
As of release 0.96 (HBASE-6038). This will be removed in HBase 2.0.0. Used by Writables and Writables are going away.
ClusterStatus(String, String, List<ServerName>, ServerName) - Constructor for class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
ClusterStatus(String, String, Map<ServerName, ServerLoad>, Collection<ServerName>, ServerName, Collection<ServerName>, Map<String, RegionState>, String[], Boolean) - Constructor for class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
ClusterStatus(String, String, Map<ServerName, ServerLoad>, Collection<ServerName>, ServerName, Collection<ServerName>, Set<RegionState>, String[], Boolean) - Constructor for class org.apache.hadoop.hbase.ClusterStatus
 
cmp(int) - Method in enum org.apache.hadoop.hbase.util.Order
Returns the adjusted trichotomous value according to the ordering imposed by this Order.
colFamTimeRangeMap - Variable in class org.apache.hadoop.hbase.client.Query
 
COLON - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for colon (:)
COLUMN_LIST - Static variable in class org.apache.hadoop.hbase.mapred.TableInputFormat
space delimited list of columns
ColumnCountGetFilter - Class in org.apache.hadoop.hbase.filter
Simple filter that returns first N columns on row only.
ColumnCountGetFilter(int) - Constructor for class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
columnFamily - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
columnFamily - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
ColumnPaginationFilter - Class in org.apache.hadoop.hbase.filter
A filter, based on the ColumnCountGetFilter, takes two arguments: limit and offset.
ColumnPaginationFilter(int, int) - Constructor for class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
Initializes filter with an integer offset and limit.
ColumnPaginationFilter(int, byte[]) - Constructor for class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
Initializes filter with a string/bookmark based offset and limit.
ColumnPrefixFilter - Class in org.apache.hadoop.hbase.filter
This filter is used for selecting only those keys with columns that matches a particular prefix.
ColumnPrefixFilter(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
columnQualifier - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
columnQualifier - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
ColumnRangeFilter - Class in org.apache.hadoop.hbase.filter
This filter is used for selecting only those keys with columns that are between minColumn to maxColumn.
ColumnRangeFilter(byte[], boolean, byte[], boolean) - Constructor for class org.apache.hadoop.hbase.filter.ColumnRangeFilter
Create a filter to select those keys with columns that are between minColumn and maxColumn.
columns - Variable in class org.apache.hadoop.hbase.mapred.GroupingTableMap
 
columns - Variable in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
The grouping columns.
COLUMNS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
com.google.protobuf - package com.google.protobuf
 
COMMA - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for a comma
commitTask(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
 
compact(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Compact a table.
compact(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Compact a column family within a table.
COMPACTION_ENABLED - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Used by HBase Shell interface to access this metadata attribute which denotes if the table is compaction enabled
COMPACTION_KV_MAX - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for the maximum batch of KVs to be used in flushes and compactions
COMPACTION_KV_MAX_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
compactRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Compact an individual region.
compactRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Compact a column family within a region.
compactRegionServer(ServerName, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Compact all regions on the region server
comparator - Variable in class org.apache.hadoop.hbase.filter.CompareFilter
 
comparator - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable.Comparator
 
compare(long) - Method in class org.apache.hadoop.hbase.io.TimeRange
Compare the timestamp to timerange.
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(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.Bytes.RowEndKeyComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.Bytes.RowEndKeyComparator
 
CompareFilter - Class in org.apache.hadoop.hbase.filter
This is a generic filter to be used to filter by comparison.
CompareFilter(CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.CompareFilter
Constructor.
CompareFilter.CompareOp - Enum in org.apache.hadoop.hbase.filter
Comparison operators.
compareOp - Variable in class org.apache.hadoop.hbase.filter.CompareFilter
 
compareOp - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
compareResults(Result, Result) - Static method in class org.apache.hadoop.hbase.client.Result
Does a deep comparison of two Results, down to the byte arrays.
compareTo(Row) - Method in class org.apache.hadoop.hbase.client.Get
 
compareTo(Row) - Method in class org.apache.hadoop.hbase.client.Increment
 
compareTo(Row) - Method in class org.apache.hadoop.hbase.client.Mutation
 
compareTo(Row) - Method in class org.apache.hadoop.hbase.client.RowMutations
 
compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.BinaryComparator
 
compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.BinaryPrefixComparator
 
compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.BitComparator
 
compareTo(byte[]) - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
 
compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
Special compareTo method for subclasses, to avoid copying byte[] unnecessarily.
compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.LongComparator
 
compareTo(MultiRowRangeFilter.RowRange) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
 
compareTo(byte[]) - Method in class org.apache.hadoop.hbase.filter.NullComparator
 
compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.NullComparator
 
compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator
 
compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.SubstringComparator
 
compareTo(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
compareTo(HRegionInfo) - Method in class org.apache.hadoop.hbase.HRegionInfo
 
compareTo(HRegionLocation) - Method in class org.apache.hadoop.hbase.HRegionLocation
 
compareTo(HTableDescriptor) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Compares the descriptor with another descriptor which is passed as a parameter.
compareTo(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(TableSplit) - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
compareTo(TableSplit) - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Compares this split against the given one.
compareTo(Address) - Method in class org.apache.hadoop.hbase.net.Address
 
compareTo(ServerName) - Method in class org.apache.hadoop.hbase.ServerName
 
compareTo(TableName) - Method in class org.apache.hadoop.hbase.TableName
For performance reasons, the ordering is not lexicographic.
compareTo(ByteBuffer, int, int, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
 
compareTo(Bytes) - Method in class org.apache.hadoop.hbase.util.Bytes
Define the sort order of the Bytes.
compareTo(byte[]) - Method in class org.apache.hadoop.hbase.util.Bytes
Compares the bytes in this object to the specified byte array
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
Lexicographically compare two arrays.
compareVersion(String, String) - Static method in class org.apache.hadoop.hbase.util.VersionInfo
 
COMPRESS_TAGS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
COMPRESSION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
Compression.Algorithm - Enum in org.apache.hadoop.hbase.io.compress
Compression algorithms.
COMPRESSION_COMPACT - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
conf - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
 
CONF_DEST_PREFIX - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
Configuration prefix for overrides for the destination filesystem
CONF_SKIP_TMP - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
 
CONF_SOURCE_PREFIX - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
Configuration prefix for overrides for the source filesystem
CONFIG - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
Denotes class names that appear in user facing configuration files.
CONFIGURATION - Static variable in class org.apache.hadoop.hbase.HConstants
 
ConfigurationUtil - Class in org.apache.hadoop.hbase.util
Utilities for storing more complex collection types in Configuration instances.
configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
 
configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.HRegionPartitioner
 
configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormat
 
configureCfRenaming(Configuration, Map<String, String>) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
Sets a configuration property with key Import.CF_RENAME_PROP in conf that tells the mapper how to rename column families.
configureIncrementalLoad(Job, HTable) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat
Deprecated.
Configure a MapReduce Job to perform an incremental load into the given table.
configureIncrementalLoad(Job, HTable) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
configureIncrementalLoad(Job, Table, RegionLocator) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
Configure a MapReduce Job to perform an incremental load into the given table.
configureIncrementalLoad(Job, HTableDescriptor, RegionLocator) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
Configure a MapReduce Job to perform an incremental load into the given table.
configureIncrementalLoadMap(Job, Table) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
 
configureSplitTable(Job, TableName) - Static method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Sets split table in map-reduce job.
Connection - Interface in org.apache.hadoop.hbase.client
A cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.
ConnectionClosingException - Exception in org.apache.hadoop.hbase.exceptions
Thrown when the client believes that we are trying to communicate to has been repeatedly unresponsive for a while.
ConnectionClosingException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.ConnectionClosingException
 
ConnectionFactory - Class in org.apache.hadoop.hbase.client
A non-instantiable class that manages creation of Connections.
ConnectionFactory() - Constructor for class org.apache.hadoop.hbase.client.ConnectionFactory
No public c.tors
Consistency - Enum in org.apache.hadoop.hbase.client
Consistency defines the expected consistency level for an operation.
consistency - Variable in class org.apache.hadoop.hbase.client.Query
 
Constants - Interface in org.apache.hadoop.hbase.rest
Common constants for org.apache.hadoop.hbase.rest
contains(byte[], byte) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
contains(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
containsColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
Checks for existence of a value for the specified column (empty or not).
containsColumn(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
Checks for existence of a value for the specified column (empty or not).
containsEmptyColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
Checks if the specified column contains an empty value (a zero-length byte array).
containsEmptyColumn(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
Checks if the specified column contains an empty value (a zero-length byte array).
containsNonEmptyColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
Checks if the specified column contains a non-empty value (not a zero-length byte array).
containsNonEmptyColumn(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
Checks if the specified column contains a non-empty value (not a zero-length byte array).
containsRange(byte[], byte[]) - Method in class org.apache.hadoop.hbase.HRegionInfo
Returns true if the given inclusive range of rows is fully contained by this region.
containsRow(byte[]) - Method in class org.apache.hadoop.hbase.HRegionInfo
Return true if the given row falls in this region.
containsServer(Address) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
 
containsTable(TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
 
Context - Class in org.apache.hadoop.hbase.io.crypto
Crypto context.
convert() - Method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
convert(ClusterStatusProtos.ClusterStatus) - Static method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
convert(HBaseProtos.ColumnFamilySchema) - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
convert() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
convert(HRegionInfo) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Convert a HRegionInfo to a RegionInfo
convert(HBaseProtos.RegionInfo) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Convert a RegionInfo to a HRegionInfo
convert() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
convert(HBaseProtos.TableSchema) - Static method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
convert(ProcedureProtos.Procedure) - Static method in class org.apache.hadoop.hbase.ProcedureInfo
Deprecated.
convertByteArrayToBoolean(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Converts a boolean expressed in a byte array to an actual boolean
convertByteArrayToInt(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Converts an int expressed in a byte array to an actual int
convertByteArrayToLong(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Converts a long expressed in a byte array to an actual long
convertScanToString(Scan) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Writes the given scan into a Base64 encoded string.
convertStringToScan(String) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Converts the given Base64 string back into a Scan instance.
convertToProcedureProto(ProcedureInfo) - Static method in class org.apache.hadoop.hbase.ProcedureInfo
Deprecated.
COPROC - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
 
CoprocessorException - Exception in org.apache.hadoop.hbase.coprocessor
Thrown if a coprocessor encounters any exception.
CoprocessorException() - Constructor for exception org.apache.hadoop.hbase.coprocessor.CoprocessorException
Default Constructor
CoprocessorException(Class<?>, String) - Constructor for exception org.apache.hadoop.hbase.coprocessor.CoprocessorException
Constructor with a Class object and exception message.
CoprocessorException(String) - Constructor for exception org.apache.hadoop.hbase.coprocessor.CoprocessorException
Constructs the exception and supplies a string as the message
CoprocessorRpcChannel - Class in org.apache.hadoop.hbase.ipc
Base class which provides clients with an RPC connection to call coprocessor endpoint Services.
CoprocessorRpcChannel() - Constructor for class org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
 
coprocessorService() - Method in interface org.apache.hadoop.hbase.client.Admin
Creates and returns a RpcChannel instance connected to the active master.
coprocessorService(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
Creates and returns a RpcChannel instance connected to the passed region server.
coprocessorService(byte[]) - Method in interface org.apache.hadoop.hbase.client.Table
Creates and returns a RpcChannel instance connected to the table region containing the specified row.
coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>) - Method in interface org.apache.hadoop.hbase.client.Table
Creates an instance of the given Service subclass for each table region spanning the range from the startKey row to endKey row (inclusive), and invokes the passed Batch.Call.call(T) method with each Service instance.
coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>, Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.Table
Creates an instance of the given Service subclass for each table region spanning the range from the startKey row to endKey row (inclusive), and invokes the passed Batch.Call.call(T) method with each Service instance.
coprocessorService(byte[]) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
copy(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Copy the byte array given in parameter and return an instance of a new byte array with the same length and the same content.
copy(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Copy the byte array given in parameter and return an instance of a new byte array with the same length and the same content.
copyBufferToStream(OutputStream, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Copy data from a buffer to an output stream.
copyBytes() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
Returns a copy of the bytes referred to by this writable
copyBytes() - Method in class org.apache.hadoop.hbase.util.Bytes
Returns a copy of the bytes referred to by this writable
copyFamilyTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
 
copyFrom(Result) - Method in class org.apache.hadoop.hbase.client.Result
Copy another Result into this one.
copyFromBufferToArray(byte[], ByteBuffer, int, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Copies specified number of bytes from given offset of 'in' ByteBuffer to the array.
copyFromBufferToBuffer(ByteBuffer, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Copy from one buffer to another from given offset.
copyFromBufferToBuffer(ByteBuffer, ByteBuffer, int, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Copy from one buffer to another from given offset.
copyFromStreamToBuffer(ByteBuffer, DataInputStream, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Copy the given number of bytes from the given stream and put it at the current position of the given buffer, updating the position in the buffer.
copyQualifierTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
 
copyRowTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
copyTo
CopyTable - Class in org.apache.hadoop.hbase.mapreduce
Tool used to copy a table to another one which can be on a different setup.
CopyTable(Configuration) - Constructor for class org.apache.hadoop.hbase.mapreduce.CopyTable
 
copyTagTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
Copies the tags info into the tag portion of the cell
copyToNewArrays(Collection<ByteRange>) - Static method in class org.apache.hadoop.hbase.util.ByteRangeUtils
 
copyValueTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
 
CORRUPT_DIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
 
CorruptedSnapshotException - Exception in org.apache.hadoop.hbase.snapshot
Exception thrown when the found snapshot info from the filesystem is not valid.
CorruptedSnapshotException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.snapshot.CorruptedSnapshotException
Snapshot was corrupt for some reason.
CorruptedSnapshotException(String, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.CorruptedSnapshotException
Deprecated.
since 1.3.0, will be removed in 3.0.0
CorruptedSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.CorruptedSnapshotException
Snapshot was corrupt for some reason.
Counter - Class in org.apache.hadoop.hbase.util
High scalable counter.
Counter() - Constructor for class org.apache.hadoop.hbase.util.Counter
 
Counter(long) - Constructor for class org.apache.hadoop.hbase.util.Counter
 
CP_HTD_ATTR_INCLUSION_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
CP_HTD_ATTR_KEY_PATTERN - Static variable in class org.apache.hadoop.hbase.HConstants
 
CP_HTD_ATTR_VALUE_PARAM_KEY_PATTERN - Static variable in class org.apache.hadoop.hbase.HConstants
 
CP_HTD_ATTR_VALUE_PARAM_PATTERN - Static variable in class org.apache.hadoop.hbase.HConstants
 
CP_HTD_ATTR_VALUE_PARAM_VALUE_PATTERN - Static variable in class org.apache.hadoop.hbase.HConstants
 
CP_HTD_ATTR_VALUE_PATTERN - Static variable in class org.apache.hadoop.hbase.HConstants
Pattern that matches a coprocessor specification.
create(List<Cell>) - Static method in class org.apache.hadoop.hbase.client.Result
Instantiate a Result with the specified List of KeyValues.
create(List<Cell>, Boolean) - Static method in class org.apache.hadoop.hbase.client.Result
 
create(List<Cell>, Boolean, boolean) - Static method in class org.apache.hadoop.hbase.client.Result
 
create(List<Cell>, Boolean, boolean, boolean) - Static method in class org.apache.hadoop.hbase.client.Result
 
create(Cell[]) - Static method in class org.apache.hadoop.hbase.client.Result
Instantiate a Result with the specified array of KeyValues.
create(Cell[], Boolean, boolean) - Static method in class org.apache.hadoop.hbase.client.Result
 
create(Cell[], Boolean, boolean, boolean) - Static method in class org.apache.hadoop.hbase.client.Result
 
create() - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
Creates a Configuration with HBase resources
create(Configuration) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
 
create(byte[], int, int, byte[], int, int, byte[], int, int, long, byte[], int, int) - Method in class org.apache.hadoop.hbase.mapreduce.CellCreator
 
create(byte[], int, int, byte[], int, int, byte[], int, int, long, byte[], int, int, String) - Method in class org.apache.hadoop.hbase.mapreduce.CellCreator
Deprecated.
create(byte[], int, int, byte[], int, int, byte[], int, int, long, byte[], int, int, List<Tag>) - Method in class org.apache.hadoop.hbase.mapreduce.CellCreator
 
create(String) - Static method in class org.apache.hadoop.hbase.NamespaceDescriptor
 
create(NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.NamespaceDescriptor
 
create(UserGroupInformation) - Static method in class org.apache.hadoop.hbase.security.User
Wraps an underlying UserGroupInformation instance.
CREATE_TABLE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
CREATE_TABLE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
 
createCell(byte[], byte[], byte[], long, byte, byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
 
createCell(byte[], int, int, byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.CellUtil
 
createCell(byte[], byte[], byte[], long, byte, byte[], long) - Static method in class org.apache.hadoop.hbase.CellUtil
Marked as audience Private as of 1.2.0.
createCell(byte[], byte[], byte[], long, byte, byte[], byte[], long) - Static method in class org.apache.hadoop.hbase.CellUtil
Marked as audience Private as of 1.2.0.
createCell(byte[], byte[], byte[], long, KeyValue.Type, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
Marked as audience Private as of 1.2.0.
createCell(byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
Create a Cell with specific row.
createCell(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
Create a Cell with specific row and value.
createCell(byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
Create a Cell with specific row.
createCellScanner(List<? extends CellScannable>) - Static method in class org.apache.hadoop.hbase.CellUtil
 
createCellScanner(Iterable<Cell>) - Static method in class org.apache.hadoop.hbase.CellUtil
 
createCellScanner(Iterator<Cell>) - Static method in class org.apache.hadoop.hbase.CellUtil
 
createCellScanner(Cell[]) - Static method in class org.apache.hadoop.hbase.CellUtil
 
createCellScanner(NavigableMap<byte[], List<Cell>>) - Static method in class org.apache.hadoop.hbase.CellUtil
Flatten the map of cells out under the CellScanner
createClusterConf(Configuration, String) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
Generates a Configuration instance by applying the ZooKeeper cluster key to the base Configuration.
createClusterConf(Configuration, String, String) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
Generates a Configuration instance by applying property overrides prefixed by a cluster profile key to the base Configuration.
createComparator(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Parses a comparator of the form comparatorType:comparatorValue form and returns a comparator
createCompareOp(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Takes a compareOperator symbol as a byte array and returns the corresponding CompareOperator
createCompleteResult(List<Result>) - Static method in class org.apache.hadoop.hbase.client.Result
Deprecated. 
createCompleteResult(Iterable<Result>) - Static method in class org.apache.hadoop.hbase.client.Result
Forms a single result from the partial results in the partialResults list.
createCompressionStream(OutputStream, Compressor, int) - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
 
createConnection() - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
Create a new Connection instance using default HBaseConfiguration.
createConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
Create a new Connection instance using the passed conf instance.
createConnection(Configuration, ExecutorService) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
Create a new Connection instance using the passed conf instance.
createConnection(Configuration, User) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
Create a new Connection instance using the passed conf instance.
createConnection(Configuration, ExecutorService, User) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
Create a new Connection instance using the passed conf instance.
createConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated.
createConnection(Configuration, ExecutorService) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated.
createConnection(Configuration, User) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated.
createConnection(Configuration, ExecutorService, User) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated.
createCursorResult(Cursor) - Static method in class org.apache.hadoop.hbase.client.Result
 
createDecompressionStream(InputStream, Decompressor, int) - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
 
createDecryptionStream(InputStream, Context, byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
Create a decrypting input stream given a context and IV
createDecryptionStream(InputStream, Decryptor) - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
Create a decrypting output stream given an initialized decryptor
createDecryptionStream(InputStream) - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
Create a stream for decryption
createEncoder(String) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
 
createEncryptionStream(OutputStream, Context, byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
Create an encrypting output stream given a context and IV
createEncryptionStream(OutputStream, Encryptor) - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
Create an encrypting output stream given an initialized encryptor
createEncryptionStream(OutputStream) - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
Create a stream for encryption
createEventLoopPerClient(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.NettyRpcClientConfigHelper
The AsyncRpcClient will create its own NioEventLoopGroup.
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.FamilyFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.PageFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.QualifierFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.RowFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.TimestampsFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ValueFilter
 
createGroupKey(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
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.
createHTableInterface(Configuration, byte[]) - Method in class org.apache.hadoop.hbase.client.HTableFactory
Deprecated.
 
createHTableInterface(Configuration, byte[]) - Method in interface org.apache.hadoop.hbase.client.HTableInterfaceFactory
Deprecated.
Creates a new HTableInterface.
createKey() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
 
createKey() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
 
createMaxByteArray(int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Create a max byte array with the specified max byte count
createNamespace(NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Create a new namespace
createNInputSplitsUniform(InputSplit, int) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Create n splits for one InputSplit, For now only support uniform distribution
createPlainCompressionStream(OutputStream, Compressor) - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
Creates a compression stream without any additional wrapping into buffering streams.
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.HLogInputFormat
Deprecated.
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
Builds a TableRecordReader.
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.WALInputFormat
 
createRegionName(TableName, byte[], long, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Make a region name of passed parameters.
createRegionName(TableName, byte[], String, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Make a region name of passed parameters.
createRegionName(TableName, byte[], long, int, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Make a region name of passed parameters.
createRegionName(TableName, byte[], byte[], boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Make a region name of passed parameters.
createRegionName(TableName, byte[], byte[], int, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Make a region name of passed parameters.
createScanFromConfiguration(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Sets up a Scan instance, applying settings from the configuration property constants defined in TableInputFormat.
createScanFromCursor(Cursor) - Static method in class org.apache.hadoop.hbase.client.Scan
Create a new Scan with a cursor.
createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.mapred.RowCounter
 
createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.CellCounter
Sets up the actual job.
createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.CopyTable
Sets up the actual 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.ImportTsv
Sets up the actual job.
createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.RowCounter
Sets up the actual job.
createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.WALPlayer
Sets up the actual job.
createTable(HTableDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Creates a new table.
createTable(HTableDescriptor, byte[], byte[], int) - Method in interface org.apache.hadoop.hbase.client.Admin
Creates a new table with the specified number of regions.
createTable(HTableDescriptor, byte[][]) - Method in interface org.apache.hadoop.hbase.client.Admin
Creates a new table with an initial set of empty regions defined by the specified split keys.
createTable(HTableDescriptor) - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
Creates a new table.
createTableAsync(HTableDescriptor, byte[][]) - Method in interface org.apache.hadoop.hbase.client.Admin
Creates a new table but does not block and wait for it to come online.
createTreeSet() - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
createUnescapdArgument(byte[], int, int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Removes the single quote escaping a single quote - thus it returns an unescaped argument
createUserForTesting(Configuration, String, String[]) - Static method in class org.apache.hadoop.hbase.security.User
Generates a new User instance specifically for use in test code.
createValue() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
 
createValue() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
 
createVisibilityExpTags(String) - Method in interface org.apache.hadoop.hbase.mapreduce.VisibilityExpressionResolver
Convert visibility expression into tags to be serialized.
CREDENTIALS_LOCATION - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
CRLF - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
CRYPTO_ALTERNATE_KEY_ALGORITHM_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for the name of the alternate cipher algorithm for the cluster, a string
CRYPTO_CIPHERPROVIDER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for the crypto algorithm provider, a class name
CRYPTO_KEY_ALGORITHM_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for the algorithm used for creating jks key, a string
CRYPTO_KEYPROVIDER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for the crypto key provider, a class name
CRYPTO_KEYPROVIDER_PARAMETERS_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for the crypto key provider parameters
CRYPTO_MASTERKEY_ALTERNATE_NAME_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for the name of the alternate master key for the cluster, a string
CRYPTO_MASTERKEY_NAME_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for the name of the master key for the cluster, a string
CRYPTO_WAL_ALGORITHM_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for the algorithm to use when encrypting the WAL, a string
CRYPTO_WAL_KEY_NAME_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for the name of the master WAL encryption key for the cluster, a string
current() - Method in class org.apache.hadoop.hbase.client.Result
 
Cursor - Class in org.apache.hadoop.hbase.client
Scan cursor to tell client where server is scanning Scan.setNeedCursorResult(boolean) Result.isCursor() Result.getCursor()
CUSTOM_FILTERS - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 

D

D - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'D'
DATA_BLOCK_ENCODING - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
DATA_FILE_UMASK_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
File permission umask to use when creating hbase data files
DATABLOCK_ENCODING_OVERRIDE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat
Deprecated.
 
DATABLOCK_ENCODING_OVERRIDE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
 
DataBlockEncoding - Enum in org.apache.hadoop.hbase.io.encoding
Provide access to all data block encoding algorithms.
DataType<T> - Interface in org.apache.hadoop.hbase.types
DataType is the base class for all HBase data types.
DAY_IN_SECONDS - Static variable in class org.apache.hadoop.hbase.HConstants
Seconds in a day, hour and minute
decode(PositionedByteRange) - Method in interface org.apache.hadoop.hbase.types.DataType
Read an instance of T from the buffer src.
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedBlob
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedBlobVar
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt16
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt32
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt64
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt8
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedString
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawByte
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawBytes
 
decode(PositionedByteRange, int) - Method in class org.apache.hadoop.hbase.types.RawBytes
Read a byte[] from the buffer src.
decode(PositionedByteRange, int) - Method in class org.apache.hadoop.hbase.types.RawBytesFixedLength
Read a byte[] from the buffer src.
decode(PositionedByteRange, int) - Method in class org.apache.hadoop.hbase.types.RawBytesTerminated
Read a byte[] from the buffer src.
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawDouble
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawFloat
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawInteger
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawLong
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawShort
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawString
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Struct
 
decode(PositionedByteRange, int) - Method in class org.apache.hadoop.hbase.types.Struct
Read the field at index.
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
 
decodeA(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Union2
Read an instance of the first type parameter from buffer src.
decodeB(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Union2
Read an instance of the second type parameter from buffer src.
decodeBlobCopy(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode a Blob value, byte-for-byte copy.
decodeBlobVar(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode a blob value that was encoded using BlobVar encoding.
decodeByte(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt8
Read a byte value from the buffer src.
decodeByte(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawByte
Read a byte value from the buffer buff.
decodeC(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Union3
Read an instance of the third type parameter from buffer src.
decodeD(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Union4
Read an instance of the fourth type parameter from buffer src.
decodeDouble(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
Read a double value from the buffer src.
decodeDouble(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
Read a double value from the buffer src.
decodeDouble(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawDouble
Read a double value from the buffer buff.
decodeFloat(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
Read a float value from the buffer dst.
decodeFloat(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawFloat
Read a float value from the buffer buff.
decodeFloat32(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode a 32-bit floating point value using the fixed-length encoding.
decodeFloat64(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode a 64-bit floating point value using the fixed-length encoding.
decodeInt(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt32
Read an int value from the buffer src.
decodeInt(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawInteger
Read an int value from the buffer buff.
decodeInt16(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode an int16 value.
decodeInt32(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode an int32 value.
decodeInt64(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode an int64 value.
decodeInt8(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode an int8 value.
decodeLong(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt64
Read a long value from the buffer src.
decodeLong(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
Read a long value from the buffer src.
decodeLong(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawLong
Read a long value from the buffer buff.
decodeNumericAsBigDecimal(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode a BigDecimal value from the variable-length encoding.
decodeNumericAsDouble(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode a primitive double value from the Numeric encoding.
decodeNumericAsLong(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode a primitive long value from the Numeric encoding.
decodeShort(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt16
Read a short value from the buffer src.
decodeShort(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawShort
Read a short value from the buffer buff.
decodeString(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode a String value.
decrement() - Method in class org.apache.hadoop.hbase.util.Counter
 
decrement() - Method in class org.apache.hadoop.hbase.util.LongAdder
Equivalent to add(-1).
decrypt(byte[], int, InputStream, int, Decryptor) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Decrypt a block of ciphertext read in from a stream with the given cipher and context
decrypt(byte[], int, InputStream, int, Encryption.Context, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Decrypt a block of ciphertext from a stream given a context and IV
decrypt(OutputStream, InputStream, int, Decryptor) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Decrypt a stream of ciphertext given a decryptor
decrypt(OutputStream, InputStream, int, Encryption.Context, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Decrypt a stream of ciphertext given a context and IV
Decryptor - Interface in org.apache.hadoop.hbase.io.crypto
Decryptors apply a cipher to an InputStream to recover plaintext.
decryptWithSubjectKey(OutputStream, InputStream, int, String, Configuration, Cipher, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Decrypts a block of ciphertext with the symmetric key resolved for the given subject
deepCopy() - Method in interface org.apache.hadoop.hbase.util.ByteRange
Create a new ByteRange with new backing byte[] containing a copy of the content from this range's window.
deepCopy() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
 
deepCopy() - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
 
deepCopy() - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
 
deepCopy() - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
deepCopy() - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
deepCopySubRangeTo(int, int, byte[], int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Wrapper for System.arraycopy.
deepCopyTo(byte[], int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Wrapper for System.arraycopy.
deepCopyToNewArray() - Method in interface org.apache.hadoop.hbase.util.ByteRange
Instantiate a new byte[] with exact length, which is at least 24 bytes + length.
DEFAULT_BLOCKCACHE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default setting for whether to use a block cache or not.
DEFAULT_BLOCKSIZE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default size of blocks in files stored to the filesytem (hfiles).
DEFAULT_BLOCKSIZE - Static variable in class org.apache.hadoop.hbase.HConstants
Default block size for an HFile.
DEFAULT_BLOOMFILTER - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default setting for whether or not to use bloomfilters.
DEFAULT_CACHE_BLOOMS_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default setting for whether to cache bloom filter blocks on write if block caching is enabled.
DEFAULT_CACHE_DATA_IN_L1 - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default setting for whether to cache data blocks in L1 tier.
DEFAULT_CACHE_DATA_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default setting for whether to cache data blocks on write if block caching is enabled.
DEFAULT_CACHE_INDEX_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default setting for whether to cache index blocks on write if block caching is enabled.
DEFAULT_CLUSTER_DISTRIBUTED - Static variable in class org.apache.hadoop.hbase.HConstants
Default value for cluster distributed mode
DEFAULT_CLUSTER_ID - Static variable in class org.apache.hadoop.hbase.HConstants
Default cluster ID, cannot be used to identify a cluster so a key with this value means it wasn't meant for replication.
DEFAULT_COMPACTION_ENABLED - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Constant that denotes whether the table is compaction enabled by default
DEFAULT_COMPRESS_TAGS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default compress tags along with any type of DataBlockEncoding.
DEFAULT_COMPRESSION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default compression type.
DEFAULT_DATA_BLOCK_ENCODING - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default data block encoding algorithm.
DEFAULT_DFS_REPLICATION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
DEFAULT_DISALLOW_WRITES_IN_RECOVERING_CONFIG - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_DISTRIBUTED_LOG_REPLAY_CONFIG - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_ENABLE_CLIENT_BACKPRESSURE - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_ENCODE_ON_DISK - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default value of the flag that enables data block encoding on disk, as opposed to encoding in cache only.
DEFAULT_EVICT_BLOCKS_ON_CLOSE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default setting for whether to evict cached blocks from the blockcache on close.
DEFAULT_GROUP - Static variable in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
 
DEFAULT_HBASE_BALANCER_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
Default value for the balancer period
DEFAULT_HBASE_CLIENT_MAX_PERREGION_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
DEFAULT_HBASE_CLIENT_MAX_PERSERVER_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
DEFAULT_HBASE_CLIENT_MAX_TOTAL_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
DEFAULT_HBASE_CLIENT_OPERATION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
Default HBase client operation timeout, which is tantamount to a blocking call
DEFAULT_HBASE_CLIENT_PAUSE - Static variable in class org.apache.hadoop.hbase.HConstants
DEFAULT_HBASE_CLIENT_PERSERVER_REQUESTS_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
DEFAULT_HBASE_CLIENT_RETRIES_NUMBER - Static variable in class org.apache.hadoop.hbase.HConstants
DEFAULT_HBASE_CLIENT_SCANNER_CACHING - Static variable in class org.apache.hadoop.hbase.HConstants
DEFAULT_HBASE_CLIENT_SCANNER_MAX_RESULT_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
Maximum number of bytes returned when calling a scanner's next method.
DEFAULT_HBASE_CLIENT_SCANNER_TIMEOUT_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
DEFAULT_HBASE_CONFIG_READ_ZOOKEEPER_CONFIG - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_HBASE_MASTER_BALANCER_MAX_RIT_PERCENT - Static variable in class org.apache.hadoop.hbase.HConstants
Default value for the max percent of regions in transition
DEFAULT_HBASE_META_BLOCK_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
DEFAULT_HBASE_META_SCANNER_CACHING - Static variable in class org.apache.hadoop.hbase.HConstants
DEFAULT_HBASE_META_VERSIONS - Static variable in class org.apache.hadoop.hbase.HConstants
DEFAULT_HBASE_RPC_SHORTOPERATION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
DEFAULT_HBASE_RPC_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
DEFAULT_HBASE_SERVER_PAUSE - Static variable in class org.apache.hadoop.hbase.HConstants
DEFAULT_HBASE_SERVER_SCANNER_MAX_RESULT_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
Maximum number of bytes returned when calling a scanner's next method.
DEFAULT_HEALTH_FAILURE_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_HEALTH_SCRIPT_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_HEAP_OCCUPANCY_HIGH_WATERMARK - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_HEAP_OCCUPANCY_LOW_WATERMARK - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_HOST - Static variable in class org.apache.hadoop.hbase.HConstants
default host address
DEFAULT_HREGION_EDITS_REPLAY_SKIP_ERRORS - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_HREGION_MEMSTORE_BLOCK_MULTIPLIER - Static variable in class org.apache.hadoop.hbase.HConstants
Default value for hbase.hregion.memstore.block.multiplier
DEFAULT_HSTORE_OPEN_AND_CLOSE_THREADS_MAX - Static variable in class org.apache.hadoop.hbase.HConstants
The default number for the max number of threads used for opening and closing stores or store files in parallel
DEFAULT_IN_MEMORY - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default setting for whether to try and serve this column family from memory or not.
DEFAULT_KEEP_DELETED - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default setting for preventing deleted from being collected immediately.
DEFAULT_LISTEN_PORT - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
DEFAULT_LOSSY_COUNTING_ERROR_RATE - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_MASTER_HANLDER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_MASTER_INFOPORT - Static variable in class org.apache.hadoop.hbase.HConstants
default port for master web api
DEFAULT_MASTER_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
default port that the master listens on
DEFAULT_MASTER_TYPE_BACKUP - Static variable in class org.apache.hadoop.hbase.HConstants
by default every master is a possible primary master unless the conf explicitly overrides it
DEFAULT_MATH_CONTEXT - Static variable in class org.apache.hadoop.hbase.util.OrderedBytes
The context used to normalize BigDecimal values.
DEFAULT_MAX_AGE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
DEFAULT_MAX_BACKOFF - Static variable in class org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
 
DEFAULT_MAX_FILE_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
Default maximum file size
DEFAULT_MEMSTORE_FLUSH_SIZE - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Constant that denotes the maximum default size of the memstore after which the contents are flushed to the store files
DEFAULT_META_REPLICA_NUM - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_MIN_VERSIONS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default is not to keep a minimum of versions.
DEFAULT_NAMESPACE - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
 
DEFAULT_NAMESPACE_NAME - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
Default namespace name.
DEFAULT_NAMESPACE_NAME_STR - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
 
DEFAULT_NBINS - Static variable in class org.apache.hadoop.hbase.util.FastLongHistogram
Deprecated.
Default number of bins.
DEFAULT_NORMALIZATION_ENABLED - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Constant that denotes whether the table is normalized by default.
DEFAULT_PREFETCH_BLOCKS_ON_OPEN - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
DEFAULT_QUANTILES - Static variable in class org.apache.hadoop.hbase.util.FastLongHistogram
Deprecated.
 
DEFAULT_READONLY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Constant that denotes whether the table is READONLY by default and is false
DEFAULT_REGION_MEMSTORE_REPLICATION - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
DEFAULT_REGION_REPLICATION - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
DEFAULT_REGION_SERVER_HANDLER_ABORT_ON_ERROR_PERCENT - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_REGION_SERVER_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_REGION_SERVER_HIGH_PRIORITY_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_REGION_SERVER_REPLICATION_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_REGIONSERVER_INFOPORT - Static variable in class org.apache.hadoop.hbase.HConstants
default port for region server web api
DEFAULT_REGIONSERVER_METRICS_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_REGIONSERVER_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
Default port region server listens on.
DEFAULT_REPLICA_ID - Static variable in class org.apache.hadoop.hbase.HRegionInfo
 
DEFAULT_REPLICATION_SCOPE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default scope.
DEFAULT_SNAPSHOT_TTL - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_SNAPSHOT_TTL_CONFIG_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_STATUS_MULTICAST_ADDRESS - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_STATUS_MULTICAST_BIND_ADDRESS - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_STATUS_MULTICAST_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_TEMPORARY_HDFS_DIRECTORY - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_THREAD_WAKE_FREQUENCY - Static variable in class org.apache.hadoop.hbase.HConstants
Default value for thread wake frequency
DEFAULT_TTL - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default time to live of cell contents.
DEFAULT_USE_META_REPLICAS - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_VERSION_FILE_WRITE_ATTEMPTS - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for how often we should try to write a version file, before failing
DEFAULT_VERSIONS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default number of versions of a record to keep.
DEFAULT_WAL_STORAGE_POLICY - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_ZK_SESSION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
Default value for ZooKeeper session timeout
DEFAULT_ZOOKEEPER_ZNODE_PARENT - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_ZOOKEPER_CLIENT_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
Default client port that the zookeeper listens on
DEFAULT_ZOOKEPER_MAX_CLIENT_CNXNS - Static variable in class org.apache.hadoop.hbase.HConstants
Default limit on concurrent client-side zookeeper connections
DEFAULT_ZOOKEPER_RECOVERABLE_WAITIME - Static variable in class org.apache.hadoop.hbase.HConstants
Default wait time for the recoverable zookeeper
DefaultCipherProvider - Class in org.apache.hadoop.hbase.io.crypto
The default cipher provider.
DEFERRED_LOG_FLUSH - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Delete - Class in org.apache.hadoop.hbase.client
Used to perform Delete operations on a single row.
Delete(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Delete
Create a Delete operation for the specified row.
Delete(byte[], long) - Constructor for class org.apache.hadoop.hbase.client.Delete
Create a Delete operation for the specified row and timestamp.
Delete(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.client.Delete
Create a Delete operation for the specified row and timestamp.
Delete(byte[], int, int, long) - Constructor for class org.apache.hadoop.hbase.client.Delete
Create a Delete operation for the specified row and timestamp.
Delete(Delete) - Constructor for class org.apache.hadoop.hbase.client.Delete
 
delete(Delete) - Method in interface org.apache.hadoop.hbase.client.Table
Deletes the specified cells/row.
delete(List<Delete>) - Method in interface org.apache.hadoop.hbase.client.Table
Deletes the specified cells/rows in bulk.
delete(String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a DELETE request
delete(String, Header) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a DELETE request
delete(Cluster, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a DELETE request
delete(Cluster, String, Header) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a DELETE request
delete(Delete) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
delete(List<Delete>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
deleteAllConnections(boolean) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated. 
deleteAllConnections() - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated.
kept for backward compatibility, but the behavior is broken. HBASE-8983
deleteCachedRegionLocation(HRegionLocation) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
deleteColumn(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Delete a column from a table.
deleteColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
Deprecated.
Since hbase-1.0.0. Use Delete.addColumn(byte[], byte[])
deleteColumn(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
Deprecated.
deleteColumns(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
Deprecated.
Since hbase-1.0.0. Use Delete.addColumns(byte[], byte[])
deleteColumns(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
Deprecated.
deleteConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated. 
deleteFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
Deprecated.
Since 1.0.0. Use Delete.addFamily(byte[])
deleteFamily(byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
Deprecated.
deleteFamilyVersion(byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
Deprecated.
deleteNamespace(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Delete an existing namespace.
deleteSnapshot(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Delete an existing snapshot.
deleteSnapshot(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Delete an existing snapshot.
deleteSnapshots(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Delete existing snapshots whose names match the pattern passed.
deleteSnapshots(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
Delete existing snapshots whose names match the pattern passed.
deleteStaleConnection(HConnection) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated. 
deleteTable(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Deletes a table.
deleteTable(String) - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
Deletes a table.
deleteTable(byte[]) - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
Deletes a table.
deleteTables(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Deletes tables matching the passed in pattern and wait on completion.
deleteTables(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
Delete tables matching the passed in pattern and wait on completion.
deleteTableSnapshots(String, String) - Method in interface org.apache.hadoop.hbase.client.Admin
Delete all existing snapshots matching the given table name regular expression and snapshot name regular expression.
deleteTableSnapshots(Pattern, Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
Delete all existing snapshots matching the given table name regular expression and snapshot name regular expression.
DELIMITER - Static variable in class org.apache.hadoop.hbase.HConstants
delimiter used between portions of a region name
DependentColumnFilter - Class in org.apache.hadoop.hbase.filter
A filter for adding inter-column timestamp matching Only cells with a correspondingly timestamped entry in the target column will be retained Not compatible with Scan.setBatch as operations need full rows for correct filtering
DependentColumnFilter(byte[], byte[], boolean, CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.DependentColumnFilter
Build a dependent column filter with value checking dependent column varies will be compared using the supplied compareOp and comparator, for usage of which refer to CompareFilter
DependentColumnFilter(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.filter.DependentColumnFilter
Constructor for DependentColumn filter.
DependentColumnFilter(byte[], byte[], boolean) - Constructor for class org.apache.hadoop.hbase.filter.DependentColumnFilter
Constructor for DependentColumn filter.
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedBlob
 
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedBlobVar
 
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedFloat32
 
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedFloat64
 
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt16
 
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt32
 
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt64
 
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt8
 
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedNumeric
 
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedString
 
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.RawBytes
 
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.RawString
 
deserialize(byte[]) - Static method in exception org.apache.hadoop.hbase.errorhandling.ForeignException
Takes a series of bytes and tries to generate an ForeignException instance for it.
DFS_REPLICATION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
disablePeer(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Stop the replication stream to the specified peer.
disableTable(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Disable table and wait on completion.
disableTableAsync(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Starts the disable of a table.
disableTableRep(TableName) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Disable a table's replication switch.
disableTables(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Disable tables matching the passed in pattern and wait on completion.
disableTables(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
Disable tables matching the passed in pattern and wait on completion.
DISALLOW_WRITES_IN_RECOVERING - Static variable in class org.apache.hadoop.hbase.HConstants
 
DISTRIBUTED_LOG_REPLAY_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Conf key that enables unflushed WAL edits directly being replayed to region servers
doBulkLoad(Path, HTable) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
Deprecated.
since hbase-1.3.0, hbase-1.2.2, and hbase-1.1.6; replaced by LoadIncrementalHFiles.doBulkLoad(Path, Admin, Table, RegionLocator).
doBulkLoad(Path, Admin, Table, RegionLocator) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
Perform a bulk load of the given directory into the given pre-existing table.
doCompare(CompareFilter.CompareOp, ByteArrayComparable, byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
doLoadColumnFamiliesOnDemand() - Method in class org.apache.hadoop.hbase.client.Query
Get the logical value indicating whether on-demand CF loading should be allowed.
DoNotRetryIOException - Exception in org.apache.hadoop.hbase
Subclass if exception is not meant to be retried: e.g.
DoNotRetryIOException() - Constructor for exception org.apache.hadoop.hbase.DoNotRetryIOException
 
DoNotRetryIOException(String) - Constructor for exception org.apache.hadoop.hbase.DoNotRetryIOException
 
DoNotRetryIOException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.DoNotRetryIOException
 
DoNotRetryIOException(Throwable) - Constructor for exception org.apache.hadoop.hbase.DoNotRetryIOException
 
DoNotRetryRegionException - Exception in org.apache.hadoop.hbase.client
Similar to RegionException, but disables retries.
DoNotRetryRegionException() - Constructor for exception org.apache.hadoop.hbase.client.DoNotRetryRegionException
 
DoNotRetryRegionException(String) - Constructor for exception org.apache.hadoop.hbase.client.DoNotRetryRegionException
 
doSetup(Reducer<ImmutableBytesWritable, Text, ImmutableBytesWritable, KeyValue>.Context, Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
Handles common parameter initialization that a subclass might want to leverage.
doSetup(Mapper<LongWritable, Text, ImmutableBytesWritable, Put>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
Handles common parameter initialization that a subclass might want to leverage.
doSetup(Mapper<LongWritable, Text, ImmutableBytesWritable, Text>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
Handles common parameter initialization that a subclass might want to leverage.
doubleValue() - Method in class org.apache.hadoop.hbase.util.LongAdder
Returns the LongAdder.sum() as a double after a widening primitive conversion.
drainInputStreamToBuffer(InputStream) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Copy from the InputStream to a new heap ByteBuffer until the InputStream is exhausted.
dropDependentColumn - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
dropDependentColumn() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
DroppedSnapshotException - Exception in org.apache.hadoop.hbase
Thrown during flush if the possibility snapshot content was not properly persisted into store files.
DroppedSnapshotException() - Constructor for exception org.apache.hadoop.hbase.DroppedSnapshotException
 
DroppedSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.DroppedSnapshotException
 
DRY_RUN_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
Durability - Enum in org.apache.hadoop.hbase.client
Enum describing the durability guarantees for tables and Mutations Note that the items must be sorted in order of increasing durability
durability - Variable in class org.apache.hadoop.hbase.client.Mutation
 
DURABILITY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Durability setting for the table.

E

E - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'E'
EMPTY_BYTE_ARRAY - Static variable in class org.apache.hadoop.hbase.HConstants
An empty instance.
EMPTY_END_ROW - Static variable in class org.apache.hadoop.hbase.HConstants
Last row in a table.
EMPTY_HEADER_ARRAY - Static variable in class org.apache.hadoop.hbase.rest.client.Client
 
EMPTY_RESULT - Static variable in class org.apache.hadoop.hbase.client.Result
 
EMPTY_SERVER_LIST - Static variable in class org.apache.hadoop.hbase.ServerName
 
EMPTY_SERVERLOAD - Static variable in class org.apache.hadoop.hbase.ServerLoad
 
EMPTY_START_ROW - Static variable in class org.apache.hadoop.hbase.HConstants
Used by scanners, etc when they want to start at the beginning of a region
ENABLE_CLIENT_BACKPRESSURE - Static variable in class org.apache.hadoop.hbase.HConstants
Config key for if the server should send backpressure and if the client should listen to that backpressure from the server
ENABLE_DATA_FILE_UMASK - Static variable in class org.apache.hadoop.hbase.HConstants
Enable file permission modification from standard hbase
ENABLE_WAL_COMPRESSION - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration name of WAL Compression
ENABLE_WAL_ENCRYPTION - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for enabling WAL encryption, a boolean
enableCatalogJanitor(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Enable/Disable the catalog janitor
enablePeer(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Restart the replication stream to the specified peer.
enableTable(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Enable a table.
enableTableAsync(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Brings a table on-line (enables it).
enableTableRep(TableName) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Enable a table's replication switch.
enableTables(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Enable tables matching the passed in pattern and wait on completion.
enableTables(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
Enable tables matching the passed in pattern and wait on completion.
encode(PositionedByteRange, T) - Method in interface org.apache.hadoop.hbase.types.DataType
Write instance val into buffer dst.
encode(PositionedByteRange, T) - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
 
encode(PositionedByteRange, byte[]) - Method in class org.apache.hadoop.hbase.types.OrderedBlob
 
encode(PositionedByteRange, byte[], int, int) - Method in class org.apache.hadoop.hbase.types.OrderedBlob
Write a subset of val to dst.
encode(PositionedByteRange, byte[]) - Method in class org.apache.hadoop.hbase.types.OrderedBlobVar
 
encode(PositionedByteRange, byte[], int, int) - Method in class org.apache.hadoop.hbase.types.OrderedBlobVar
Write a subset of val to buff.
encode(PositionedByteRange, Float) - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
 
encode(PositionedByteRange, Double) - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
 
encode(PositionedByteRange, Short) - Method in class org.apache.hadoop.hbase.types.OrderedInt16
 
encode(PositionedByteRange, Integer) - Method in class org.apache.hadoop.hbase.types.OrderedInt32
 
encode(PositionedByteRange, Long) - Method in class org.apache.hadoop.hbase.types.OrderedInt64
 
encode(PositionedByteRange, Byte) - Method in class org.apache.hadoop.hbase.types.OrderedInt8
 
encode(PositionedByteRange, Number) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
 
encode(PositionedByteRange, String) - Method in class org.apache.hadoop.hbase.types.OrderedString
 
encode(PositionedByteRange, Byte) - Method in class org.apache.hadoop.hbase.types.RawByte
 
encode(PositionedByteRange, byte[]) - Method in class org.apache.hadoop.hbase.types.RawBytes
 
encode(PositionedByteRange, byte[], int, int) - Method in class org.apache.hadoop.hbase.types.RawBytes
Write val into dst, respecting voff and vlen.
encode(PositionedByteRange, byte[], int, int) - Method in class org.apache.hadoop.hbase.types.RawBytesFixedLength
Write val into buff, respecting offset and length.
encode(PositionedByteRange, byte[], int, int) - Method in class org.apache.hadoop.hbase.types.RawBytesTerminated
Write val into dst, respecting offset and length.
encode(PositionedByteRange, Double) - Method in class org.apache.hadoop.hbase.types.RawDouble
 
encode(PositionedByteRange, Float) - Method in class org.apache.hadoop.hbase.types.RawFloat
 
encode(PositionedByteRange, Integer) - Method in class org.apache.hadoop.hbase.types.RawInteger
 
encode(PositionedByteRange, Long) - Method in class org.apache.hadoop.hbase.types.RawLong
 
encode(PositionedByteRange, Short) - Method in class org.apache.hadoop.hbase.types.RawShort
 
encode(PositionedByteRange, String) - Method in class org.apache.hadoop.hbase.types.RawString
 
encode(PositionedByteRange, Object[]) - Method in class org.apache.hadoop.hbase.types.Struct
 
encode(PositionedByteRange, T) - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
Write instance val into buffer dst.
ENCODE_ON_DISK - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
encodeBlobCopy(PositionedByteRange, byte[], int, int, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a Blob value as a byte-for-byte copy.
encodeBlobCopy(PositionedByteRange, byte[], Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a Blob value as a byte-for-byte copy.
encodeBlobVar(PositionedByteRange, byte[], int, int, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a Blob value using a modified varint encoding scheme.
encodeBlobVar(PositionedByteRange, byte[], Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a blob value using a modified varint encoding scheme.
encodeByte(PositionedByteRange, byte) - Method in class org.apache.hadoop.hbase.types.OrderedInt8
Write instance val into buffer dst.
encodeByte(byte[], int, byte) - Method in class org.apache.hadoop.hbase.types.RawByte
Write instance val into buffer buff.
ENCODED_REGION_NAME_REGEX - Static variable in class org.apache.hadoop.hbase.HRegionInfo
A non-capture group so that this can be embedded.
encodedClass() - Method in interface org.apache.hadoop.hbase.types.DataType
Inform consumers over what type this DataType operates.
encodedClass() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedBlob
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedBlobVar
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedInt16
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedInt32
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedInt64
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedInt8
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedString
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.RawByte
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.RawBytes
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.RawDouble
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.RawFloat
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.RawInteger
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.RawLong
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.RawShort
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.RawString
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.Struct
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.Union2
 
encodedLength(T) - Method in interface org.apache.hadoop.hbase.types.DataType
Inform consumers how long the encoded byte[] will be.
encodedLength(T) - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
 
encodedLength(byte[]) - Method in class org.apache.hadoop.hbase.types.OrderedBlob
 
encodedLength(byte[]) - Method in class org.apache.hadoop.hbase.types.OrderedBlobVar
 
encodedLength(Float) - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
 
encodedLength(Double) - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
 
encodedLength(Short) - Method in class org.apache.hadoop.hbase.types.OrderedInt16
 
encodedLength(Integer) - Method in class org.apache.hadoop.hbase.types.OrderedInt32
 
encodedLength(Long) - Method in class org.apache.hadoop.hbase.types.OrderedInt64
 
encodedLength(Byte) - Method in class org.apache.hadoop.hbase.types.OrderedInt8
 
encodedLength(Number) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
 
encodedLength(String) - Method in class org.apache.hadoop.hbase.types.OrderedString
 
encodedLength(T) - Method in class org.apache.hadoop.hbase.types.PBType
 
encodedLength(Byte) - Method in class org.apache.hadoop.hbase.types.RawByte
 
encodedLength(byte[]) - Method in class org.apache.hadoop.hbase.types.RawBytes
 
encodedLength(Double) - Method in class org.apache.hadoop.hbase.types.RawDouble
 
encodedLength(Float) - Method in class org.apache.hadoop.hbase.types.RawFloat
 
encodedLength(Integer) - Method in class org.apache.hadoop.hbase.types.RawInteger
 
encodedLength(Long) - Method in class org.apache.hadoop.hbase.types.RawLong
 
encodedLength(Short) - Method in class org.apache.hadoop.hbase.types.RawShort
 
encodedLength(String) - Method in class org.apache.hadoop.hbase.types.RawString
 
encodedLength(Object[]) - Method in class org.apache.hadoop.hbase.types.Struct
 
encodedLength(T) - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
 
encodeDouble(PositionedByteRange, double) - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
Write instance val into buffer dst.
encodeDouble(PositionedByteRange, double) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
Write instance val into buffer dst.
encodeDouble(byte[], int, double) - Method in class org.apache.hadoop.hbase.types.RawDouble
Write instance val into buffer buff.
encodeFloat(PositionedByteRange, float) - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
Write instance val into buffer buff.
encodeFloat(byte[], int, float) - Method in class org.apache.hadoop.hbase.types.RawFloat
Write instance val into buffer buff.
encodeFloat32(PositionedByteRange, float, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a 32-bit floating point value using the fixed-length encoding.
encodeFloat64(PositionedByteRange, double, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a 64-bit floating point value using the fixed-length encoding.
encodeInt(PositionedByteRange, int) - Method in class org.apache.hadoop.hbase.types.OrderedInt32
Write instance val into buffer dst.
encodeInt(byte[], int, int) - Method in class org.apache.hadoop.hbase.types.RawInteger
Write instance val into buffer buff.
encodeInt16(PositionedByteRange, short, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode an int16 value using the fixed-length encoding.
encodeInt32(PositionedByteRange, int, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode an int32 value using the fixed-length encoding.
encodeInt64(PositionedByteRange, long, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode an int64 value using the fixed-length encoding.
encodeInt8(PositionedByteRange, byte, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode an int8 value using the fixed-length encoding.
encodeLong(PositionedByteRange, long) - Method in class org.apache.hadoop.hbase.types.OrderedInt64
Write instance val into buffer dst.
encodeLong(PositionedByteRange, long) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
Write instance val into buffer dst.
encodeLong(byte[], int, long) - Method in class org.apache.hadoop.hbase.types.RawLong
Write instance val into buffer buff.
encodeNull(PositionedByteRange, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a null value.
encodeNumeric(PositionedByteRange, long, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a numerical value using the variable-length encoding.
encodeNumeric(PositionedByteRange, double, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a numerical value using the variable-length encoding.
encodeNumeric(PositionedByteRange, BigDecimal, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a numerical value using the variable-length encoding.
encodeRegionName(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
 
encodeShort(PositionedByteRange, short) - Method in class org.apache.hadoop.hbase.types.OrderedInt16
Write instance val into buffer dst.
encodeShort(byte[], int, short) - Method in class org.apache.hadoop.hbase.types.RawShort
Write instance val into buffer buff.
encodeString(PositionedByteRange, String, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a String value.
encrypt(OutputStream, byte[], int, int, Encryptor) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Encrypt a block of plaintext
encrypt(OutputStream, byte[], int, int, Encryption.Context, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Encrypt a block of plaintext
encrypt(OutputStream, InputStream, Encryptor) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Encrypt a stream of plaintext given an encryptor
encrypt(OutputStream, InputStream, Encryption.Context, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Encrypt a stream of plaintext given a context and IV
ENCRYPTION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
Encryption - Class in org.apache.hadoop.hbase.io.crypto
A facade for encryption algorithms and related support.
Encryption.Context - Class in org.apache.hadoop.hbase.io.crypto
Crypto context
ENCRYPTION_KEY - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
EncryptionTest - Class in org.apache.hadoop.hbase.util
 
Encryptor - Interface in org.apache.hadoop.hbase.io.crypto
Encryptors apply a cipher to an OutputStream to produce ciphertext.
encryptWithSubjectKey(OutputStream, InputStream, String, Configuration, Cipher, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Encrypts a block of plaintext with the symmetric key resolved for the given subject
END - Static variable in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
Deprecated.
END_TIME_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HLogInputFormat
Deprecated.
 
END_TIME_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.WALInputFormat
 
ENSEMBLE_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
The name of the ensemble table
EQUAL_TO - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for equal to (=)
EQUAL_TO_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
EQUAL_TO Array
EQUAL_TO_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
 
equals(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
equals
equals(Object) - Method in class org.apache.hadoop.hbase.client.Get
 
equals(Object) - Method in class org.apache.hadoop.hbase.client.Increment
 
equals(Object) - Method in class org.apache.hadoop.hbase.client.RowMutations
 
equals(Object) - Method in class org.apache.hadoop.hbase.ClusterStatus
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.FamilyFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.NullComparator
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.QualifierFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.RowFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.ValueFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
equals(Object) - Method in class org.apache.hadoop.hbase.HRegionInfo
 
equals(Object) - Method in class org.apache.hadoop.hbase.HRegionLocation
 
equals(Object) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Compare the contents of the descriptor with another one passed as a parameter.
equals(Object) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
equals(Object) - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
equals(Object) - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
 
equals(Object) - Method in class org.apache.hadoop.hbase.net.Address
 
equals(Object) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
 
equals(Object) - Method in class org.apache.hadoop.hbase.security.User
 
equals(Object) - Method in class org.apache.hadoop.hbase.ServerLoad
 
equals(Object) - Method in class org.apache.hadoop.hbase.ServerName
 
equals(Object) - Method in class org.apache.hadoop.hbase.TableName
 
equals(Object) - Method in class org.apache.hadoop.hbase.util.Bytes
 
equals(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
equals(byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
equals(byte[], ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
equals(List<byte[]>, List<byte[]>) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
equals(Object) - Method in class org.apache.hadoop.hbase.util.Pair
 
equals(Object) - Method in class org.apache.hadoop.hbase.util.PairOfSameType
 
equals(Object) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
 
equals(Object) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
 
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 [].
estimatedHeapSizeOf(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
This is an estimate of the heap space occupied by a cell.
estimatedHeapSizeOfWithoutTags(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
Deprecated.
estimatedSerializedSizeOf(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
estimatedSerializedSizeOfKey(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
Calculates the serialized key size.
estimatedSizeOf(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
Deprecated.
please use estimatedSerializedSizeOf(Cell)
EVENT_LOOP_CONFIG - Static variable in class org.apache.hadoop.hbase.ipc.NettyRpcClientConfigHelper
 
EVICT_BLOCKS_ON_CLOSE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
execProcedure(String, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.client.Admin
Execute a distributed procedure on a cluster.
execProcedureWithRet(String, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.client.Admin
Execute a distributed procedure on a cluster.
execute(HConnectable<T>) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated.
Internal method, do not use thru HConnectionManager.
execute(Cluster, HttpMethod, Header[], String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Execute a transaction method.
executePathOnly(Cluster, HttpMethod, Header[], String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Execute a transaction method given only the path.
executeURI(HttpMethod, Header[], String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Execute a transaction method given a complete URI.
executionTime() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
exists(Get) - Method in interface org.apache.hadoop.hbase.client.Table
Test for the existence of columns in the table, as specified by the Get.
exists(Get) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
exists(List<Get>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
Deprecated.
existsAll(List<Get>) - Method in interface org.apache.hadoop.hbase.client.Table
Test for the existence of columns in the table, as specified by the Gets.
existsAll(List<Get>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
exists(List) is really a list of get() calls.
ExponentialClientBackoffPolicy - Class in org.apache.hadoop.hbase.client.backoff
Simple exponential backoff policy on for the client that uses a percent^4 times the max backoff to generate the backoff time.
ExponentialClientBackoffPolicy(Configuration) - Constructor for class org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
 
Export - Class in org.apache.hadoop.hbase.mapreduce
Export an HBase table.
Export() - Constructor for class org.apache.hadoop.hbase.mapreduce.Export
 
ExportSnapshot - Class in org.apache.hadoop.hbase.snapshot
Export the specified snapshot to a given FileSystem.
ExportSnapshot() - Constructor for class org.apache.hadoop.hbase.snapshot.ExportSnapshot
 
ExportSnapshotException - Exception in org.apache.hadoop.hbase.snapshot
Thrown when a snapshot could not be exported due to an error during the operation.
ExportSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.ExportSnapshotException
 
ExportSnapshotException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.snapshot.ExportSnapshotException
 
extendLimit(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
 
extractArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.CompareFilter
 
extractFilterSimpleExpression(byte[], int) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
Extracts a simple filter expression from the filter string given by the user
extractKeyValues(Result) - Method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
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.
extraHeapSize() - Method in class org.apache.hadoop.hbase.client.Increment
 
extraHeapSize() - Method in class org.apache.hadoop.hbase.client.Mutation
Subclasses should override this method to add the heap size of their own fields.

F

FailedLogCloseException - Exception in org.apache.hadoop.hbase.regionserver.wal
Thrown when we fail close of the write-ahead-log file.
FailedLogCloseException() - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.FailedLogCloseException
 
FailedLogCloseException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.FailedLogCloseException
 
FailedLogCloseException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.FailedLogCloseException
 
FailedLogCloseException(Throwable) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.FailedLogCloseException
 
FailedSanityCheckException - Exception in org.apache.hadoop.hbase.exceptions
Exception thrown if a mutation fails sanity checks.
FailedSanityCheckException() - Constructor for exception org.apache.hadoop.hbase.exceptions.FailedSanityCheckException
default constructor
FailedSanityCheckException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.FailedSanityCheckException
 
FailedSanityCheckException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.FailedSanityCheckException
 
FailedServerException - Exception in org.apache.hadoop.hbase.ipc
Indicates that we're trying to connect to a already known as dead server.
FailedServerException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.FailedServerException
 
FailedSyncBeforeLogCloseException - Exception in org.apache.hadoop.hbase.regionserver.wal
Thrown when we fail close of the write-ahead-log file.
FailedSyncBeforeLogCloseException() - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.FailedSyncBeforeLogCloseException
 
FailedSyncBeforeLogCloseException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.FailedSyncBeforeLogCloseException
 
FailedSyncBeforeLogCloseException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.FailedSyncBeforeLogCloseException
 
FailedSyncBeforeLogCloseException(Throwable) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.FailedSyncBeforeLogCloseException
 
FallbackDisallowedException - Exception in org.apache.hadoop.hbase.ipc
Indicate that the rpc server tells client to fallback to simple auth but client is disabled to do so.
FallbackDisallowedException() - Constructor for exception org.apache.hadoop.hbase.ipc.FallbackDisallowedException
 
FamilyFilter - Class in org.apache.hadoop.hbase.filter
This filter is used to filter based on the column family.
FamilyFilter(CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.FamilyFilter
Constructor.
familyMap - Variable in class org.apache.hadoop.hbase.client.Mutation
 
familySet() - Method in class org.apache.hadoop.hbase.client.Get
Method for retrieving the keys in the familyMap
FastLongHistogram - Class in org.apache.hadoop.hbase.util
Deprecated.
FastLongHistogram() - Constructor for class org.apache.hadoop.hbase.util.FastLongHistogram
Deprecated.
Constructor.
FastLongHistogram(int) - Constructor for class org.apache.hadoop.hbase.util.FastLongHistogram
Deprecated.
Constructor.
FastLongHistogram(int, long, long) - Constructor for class org.apache.hadoop.hbase.util.FastLongHistogram
Deprecated.
Constructor setting the bins assuming a uniform distribution within a range.
FatalConnectionException - Exception in org.apache.hadoop.hbase.ipc
Thrown when server finds fatal issue w/ connection setup: e.g.
FatalConnectionException() - Constructor for exception org.apache.hadoop.hbase.ipc.FatalConnectionException
 
FatalConnectionException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.FatalConnectionException
 
FatalConnectionException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.ipc.FatalConnectionException
 
fields - Variable in class org.apache.hadoop.hbase.types.Struct
 
fields - Variable in class org.apache.hadoop.hbase.types.StructBuilder
 
FILE_SYSTEM_VERSION - Static variable in class 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
 
fillFamilyRange(Cell, ByteRange) - Static method in class org.apache.hadoop.hbase.CellUtil
 
fillQualifierRange(Cell, ByteRange) - Static method in class org.apache.hadoop.hbase.CellUtil
 
fillRowRange(Cell, ByteRange) - Static method in class org.apache.hadoop.hbase.CellUtil
ByteRange
fillTagRange(Cell, ByteRange) - Static method in class org.apache.hadoop.hbase.CellUtil
 
fillValueRange(Cell, ByteRange) - Static method in class org.apache.hadoop.hbase.CellUtil
 
filter - Variable in class org.apache.hadoop.hbase.client.Query
 
Filter - Class in org.apache.hadoop.hbase.filter
Interface for row and column filters directly applied within the regionserver.
Filter() - Constructor for class org.apache.hadoop.hbase.filter.Filter
 
Filter.ReturnCode - Enum in org.apache.hadoop.hbase.filter
Return codes for filterValue().
FILTER_ARGS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.Import
 
FILTER_CLASS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.Import
 
FILTER_CLASSES - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
FILTER_PACKAGE - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
Package containing filters
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.Filter
If this returns true, the scan will terminate.
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.FilterList
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
filterColumn(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
filterColumn(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
filterIfMissing - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.FamilyFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.Filter
A way to filter based on the column family, column qualifier and/or the column value.
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.QualifierFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.RowFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.ValueFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
filterKv(Filter, Cell) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
Attempt to filter out the keyvalue
FilterList - Class in org.apache.hadoop.hbase.filter
Implementation of Filter that represents an ordered List of Filters which will be evaluated with a specified boolean operator FilterList.Operator.MUST_PASS_ALL (AND) or FilterList.Operator.MUST_PASS_ONE (OR).
FilterList(FilterList.Operator, List<Filter>) - Constructor for class org.apache.hadoop.hbase.filter.FilterList
Constructor that takes a set of Filters and an operator.
FilterList(List<Filter>) - Constructor for class org.apache.hadoop.hbase.filter.FilterList
Constructor that takes a set of Filters.
FilterList(Filter...) - Constructor for class org.apache.hadoop.hbase.filter.FilterList
Constructor that takes a var arg number of Filters.
FilterList(FilterList.Operator) - Constructor for class org.apache.hadoop.hbase.filter.FilterList
Constructor that takes an operator.
FilterList(FilterList.Operator, Filter...) - Constructor for class org.apache.hadoop.hbase.filter.FilterList
Constructor that takes a var arg number of Filters and an operator.
FilterList.Operator - Enum in org.apache.hadoop.hbase.filter
set operator
filterOutRow - Variable in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.Filter
Last chance to veto row based on previous Filter.filterKeyValue(Cell) calls.
filterRow() - Method in class org.apache.hadoop.hbase.filter.FilterList
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
filterRow - Variable in class org.apache.hadoop.hbase.filter.PrefixFilter
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.RowFilter
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
filterRowCells(List<Cell>) - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
filterRowCells(List<Cell>) - Method in class org.apache.hadoop.hbase.filter.Filter
Chance to alter the list of Cells to be submitted.
filterRowCells(List<Cell>) - Method in class org.apache.hadoop.hbase.filter.FilterList
Filters that never filter by modifying the returned List of Cells can inherit this implementation that does nothing.
filterRowCells(List<Cell>) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
 
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.Filter
Filters a row based on the row key.
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.RowFilter
 
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
findCommonPrefix(ByteBuffer, int, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Find length of common prefix of two parts in the buffer
findCommonPrefix(byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Find length of common prefix in two arrays.
findCommonPrefixInFlatKey(Cell, Cell, boolean, boolean) - Static method in class org.apache.hadoop.hbase.CellUtil
Find length of common prefix in keys of the cells, considering key as byte[] if serialized in KeyValue.
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
FirstKeyOnlyFilter - Class in org.apache.hadoop.hbase.filter
A filter that will only return the first KV from each row.
FirstKeyOnlyFilter() - Constructor for class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
FirstKeyValueMatchingQualifiersFilter - Class in org.apache.hadoop.hbase.filter
The filter looks for the given columns in KeyValue.
FirstKeyValueMatchingQualifiersFilter(Set<byte[]>) - Constructor for class org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
Constructor which takes a set of columns.
FixedLengthWrapper<T> - Class in org.apache.hadoop.hbase.types
Wraps an existing DataType implementation as a fixed-length version of itself.
FixedLengthWrapper(DataType<T>, int) - Constructor for class org.apache.hadoop.hbase.types.FixedLengthWrapper
Create a fixed-length version of the wrapped.
floatValue() - Method in class org.apache.hadoop.hbase.util.LongAdder
Returns the LongAdder.sum() as a float after a widening primitive conversion.
flush(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Flush a table.
flush() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
Executes all the buffered, asynchronous Mutation operations and waits until they are done.
flush() - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
FLUSH_POLICY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
flushCommits() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
flushRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Flush an individual region.
flushRegionsIfNecessary(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
If the durability is set to Durability.SKIP_WAL and the data is imported to hbase, we need to flush all the regions of the table as the data is held in memory and is also not present in the Write Ahead Log to replay in scenarios of a crash.
ForeignException - Exception in org.apache.hadoop.hbase.errorhandling
A ForeignException is an exception from another thread or process.
ForeignException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.errorhandling.ForeignException
Create a new ForeignException that can be serialized.
ForeignException(String, String) - Constructor for exception org.apache.hadoop.hbase.errorhandling.ForeignException
Create a new ForeignException that can be serialized.
FOREVER - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
FOREVER - Static variable in class org.apache.hadoop.hbase.HConstants
Unlimited time-to-live.
formatTime(long) - Static method in exception org.apache.hadoop.hbase.quotas.ThrottlingException
 
foundColumn - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
fromArrays(Collection<byte[]>) - Static method in class org.apache.hadoop.hbase.util.ByteRangeUtils
 
fromByte(byte) - Static method in enum org.apache.hadoop.hbase.client.IsolationLevel
 
fromBytes(byte[]) - Static method in enum org.apache.hadoop.hbase.client.IsolationLevel
 
fromHex(String) - Static method in class org.apache.hadoop.hbase.util.Bytes
Create a byte array from a string of hash digits.
fromParts(String, int) - Static method in class org.apache.hadoop.hbase.net.Address
 
fromString(String) - Static method in class org.apache.hadoop.hbase.net.Address
 
FuzzyRowFilter - Class in org.apache.hadoop.hbase.filter
This is optimized version of a standard FuzzyRowFilter Filters data based on fuzzy row key.
FuzzyRowFilter(List<Pair<byte[], byte[]>>) - Constructor for class org.apache.hadoop.hbase.filter.FuzzyRowFilter
 

G

Get - Class in org.apache.hadoop.hbase.client
Used to perform Get operations on a single row.
Get(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Get
Create a Get operation for the specified row.
Get(Get) - Constructor for class org.apache.hadoop.hbase.client.Get
Copy-constructor
get(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(Get) - Method in interface org.apache.hadoop.hbase.client.Table
Extracts certain cells from a given row.
get(List<Get>) - Method in interface org.apache.hadoop.hbase.client.Table
Extracts certain cells from the given rows, in batch.
get() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
Get the data from the BytesWritable.
get(String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a GET request
get(Cluster, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a GET request
get(String, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a GET request
get(Cluster, String, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a GET request
get(String, Header[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a GET request
get(Cluster, String, Header[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a GET request
get(Get) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
get(List<Get>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
get(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Retrieve the byte at index.
get(int, byte[]) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Fill dst with bytes from the range, starting from index.
get(int, byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Fill dst with bytes from the range, starting from index.
get() - Method in class org.apache.hadoop.hbase.util.Bytes
Get the data from the Bytes.
get() - Method in class org.apache.hadoop.hbase.util.Counter
 
get() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Retrieve the next byte from this range.
get(byte[]) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Fill dst with bytes from the range, starting from position.
get(byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Fill dst with bytes from the range, starting from the current position.
get(int, byte[]) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
 
get(int, byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
 
get(int, byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
get(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
get(int, byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
get(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
getACL() - Method in class org.apache.hadoop.hbase.client.Mutation
 
getACL() - Method in class org.apache.hadoop.hbase.client.Query
 
getActiveMaster() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
Gets the current active master, if available.
getAddress() - Method in class org.apache.hadoop.hbase.ServerName
 
getAdmin() - Method in interface org.apache.hadoop.hbase.client.Connection
Retrieve an Admin implementation to administer an HBase cluster.
getAdmin() - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Retrieve an Admin implementation to administer an HBase cluster.
getAdmin(ServerName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
getAdmin(ServerName, boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
You can pass master flag but nothing special is done.
getAdmin() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Allows subclasses to get the Admin.
getAliasPassword(String) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
 
getAllFilters() - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Returns all known filters
getAllowPartialResults() - Method in class org.apache.hadoop.hbase.client.Scan
 
getAllRegionLocations() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
Retrieves all of the regions associated with this table.
getAlterStatus(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Get the status of alter command - indicates how many regions have received the updated schema Asynchronous operation.
getAlterStatus(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Get the status of alter command - indicates how many regions have received the updated schema Asynchronous operation.
getAttribute(String) - Method in interface org.apache.hadoop.hbase.client.Attributes
Gets an attribute
getAttribute(String) - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
 
getAttributeSize() - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
 
getAttributesMap() - Method in interface org.apache.hadoop.hbase.client.Attributes
Gets all attributes
getAttributesMap() - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
 
getAuthChore(Configuration) - Static method in class org.apache.hadoop.hbase.AuthUtil
Checks if security is enabled and if so, launches chore for refreshing kerberos ticket.
getAuthorizations() - Method in class org.apache.hadoop.hbase.client.Query
 
getAverageLatencyForEachRegionServer() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
getAverageLoad() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getBackoffTime(ServerName, byte[], ServerStatistics) - Method in interface org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicy
 
getBackoffTime(ServerName, byte[], ServerStatistics) - Method in class org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
 
getBackupMasters() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getBackupMastersSize() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getBackupZooKeeperServerNum() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
 
getBadLineCount() - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
 
getBadLineCount() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
 
getBadLineCount() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
 
getBalancerOn() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getBandwidth() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
getBatch() - Method in class org.apache.hadoop.hbase.client.Scan
 
getBlocksize() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getBlockSize() - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
Get the cipher's internal block size
getBlockSize() - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
Get the cipher's internal block size
getBloomFilterType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getBody() - Method in class org.apache.hadoop.hbase.rest.client.Response
 
getBufferedCounterForEachRegionServer() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
getBufferedMutator(TableName) - Method in interface org.apache.hadoop.hbase.client.Connection
Retrieve a BufferedMutator for performing client-side buffering of writes.
getBufferedMutator(BufferedMutatorParams) - Method in interface org.apache.hadoop.hbase.client.Connection
Retrieve a BufferedMutator for performing client-side buffering of writes.
getByteBuffer() - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
This flips the underlying BB so be sure to use it _last_!
getBytes() - Method in interface org.apache.hadoop.hbase.util.ByteRange
The underlying byte[].
getBytes(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.Bytes
Returns a new byte array, copied from the given buf, from the position (inclusive) to the limit (exclusive).
getCacheBlocks() - Method in class org.apache.hadoop.hbase.client.Get
Get whether blocks should be cached for this Get.
getCacheBlocks() - Method in class org.apache.hadoop.hbase.client.Scan
Get whether blocks should be cached for this Scan.
getCaching() - Method in class org.apache.hadoop.hbase.client.Scan
 
getCause(int) - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
getCauses() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
getCellKeyAsString(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
getCellKeySerializedAsKeyValueKey(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
This method exists just to encapsulate how we serialize keys.
getCellVisibility() - Method in class org.apache.hadoop.hbase.client.Mutation
 
getChance() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
getCipher(String) - Method in interface org.apache.hadoop.hbase.io.crypto.CipherProvider
Get an Cipher
getCipher() - Method in class org.apache.hadoop.hbase.io.crypto.Context
 
getCipher(String) - Method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
 
getCipher(Configuration, String) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Get an cipher given a name
getCipherProvider(Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
 
getClient(ServerName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
getClientAckTime() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
getClientPort() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
 
getClientPortList() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
Get the list of client ports.
getCluster() - Method in class org.apache.hadoop.hbase.rest.client.Client
 
getClusterId() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getClusterIds() - Method in class org.apache.hadoop.hbase.client.Mutation
 
getClusterKey() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
getClusterStatus() - Method in interface org.apache.hadoop.hbase.client.Admin
 
getClusterStatus() - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
 
getClusterVersion() - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
 
getCode() - Method in class org.apache.hadoop.hbase.rest.client.Response
 
getColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
Deprecated.
getColumnCells(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
Return the Cells for the specific column.
getColumnFamilies() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Returns an array all the HColumnDescriptor of the column families of the table.
getColumnFamilyTimeRange() - Method in class org.apache.hadoop.hbase.client.Query
 
getColumnLatest(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
getColumnLatest(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
getColumnLatestCell(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
The Cell for the most recent timestamp for a given column.
getColumnLatestCell(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
The Cell for the most recent timestamp for a given column.
getColumnOffset() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
getCompactionCompression() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getCompactionCompressionType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getCompactionState(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Get the current compaction state of a table.
getCompactionStateForRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
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
 
getComparisonData() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
 
getCompleteSequenceId() - Method in class org.apache.hadoop.hbase.RegionLoad
This does not really belong inside RegionLoad but its being done in the name of expediency.
getCompression() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getCompressionType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getCompressor() - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
 
getConf() - Method in class org.apache.hadoop.hbase.io.crypto.Context
 
getConf() - Method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
 
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.MultiTableInputFormat
Returns the current configuration.
getConf() - Method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
 
getConf() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Returns the current configuration.
getConf() - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
 
getConfiguration() - Method in interface org.apache.hadoop.hbase.client.Admin
 
getConfiguration() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
Returns the Configuration object used by this instance.
getConfiguration() - Method in interface org.apache.hadoop.hbase.client.Connection
 
getConfiguration() - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
 
getConfiguration() - Method in interface org.apache.hadoop.hbase.client.Table
Returns the Configuration object used by this instance.
getConfiguration() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Getter for fetching an unmodifiable HColumnDescriptor.configuration map.
getConfiguration() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Getter for fetching an unmodifiable HTableDescriptor.configuration map.
getConfiguration() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
getConfiguration() - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
Getter for fetching an unmodifiable NamespaceDescriptor.configuration map.
getConfiguration() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
getConfiguration() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
getConfigurationValue(String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Getter for accessing the configuration value by key.
getConfigurationValue(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Getter for accessing the configuration value by key
getConfigurationValue(String) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
Getter for accessing the configuration value by key
getConnection() - Method in interface org.apache.hadoop.hbase.client.Admin
 
getConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated.
getConsistency() - Method in class org.apache.hadoop.hbase.client.Query
Returns the consistency level for this operation
getCoprocessors() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Return the list of attached co-processor represented by their name className
getCount() - Method in class org.apache.hadoop.hbase.util.FastLongHistogram
Deprecated.
 
getCurrent() - Static method in class org.apache.hadoop.hbase.security.User
Returns the User instance within current execution context.
getCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getCurrentKey() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
Returns the current key.
getCurrentKey() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
Returns the current key.
getCurrentNrHRS() - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
This method will be changed from public to package protected.
getCurrentValue() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
Returns the current value.
getCurrentValue() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
Returns the current value.
getCursor() - Method in class org.apache.hadoop.hbase.client.Result
Return the cursor if this Result is a cursor result.
getDataBlockEncoderById(short) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
Find and create data block encoder for given id;
getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getDataBlockEncodingOnDisk() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 0.98 (HBASE-9870). This will be removed in HBase 2.0.0. See HColumnDescriptor.getDataBlockEncoding()}
getDataLocality() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getDate() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
The date that hbase was compiled.
getDaughterRegions(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
use MetaTableAccessor methods for interacting with meta layouts
getDeadServerNames() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getDeadServers() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getDecompressor() - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
 
getDecryptor() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
Return a decryptor for decrypting data.
getDefaultValues() - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getDesc(List<Throwable>, List<? extends Row>, List<String>) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
getDesc(Map<String, Integer>) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
getDeserializer(Class<KeyValue>) - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization
 
getDeserializer(Class<Mutation>) - Method in class org.apache.hadoop.hbase.mapreduce.MutationSerialization
 
getDeserializer(Class<Result>) - Method in class org.apache.hadoop.hbase.mapreduce.ResultSerialization
 
getDFSReplication() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getDropDependentColumn() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
getDurability() - Method in class org.apache.hadoop.hbase.client.Mutation
Get the current durability
getDurability() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Returns the durability setting for the table.
getEncodedName() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getEncodedNameAsBytes() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getEncodedRegionName() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Returns the region's encoded name.
getEncoder() - Method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
Return new data block encoder for given algorithm type.
getEncodingById(short) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
 
getEncryptionKey() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Return the raw crypto key attribute for the family, or null if not set
getEncryptionType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Return the encryption algorithm in use by this family
getEncryptor() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
Get an encryptor for encrypting data.
getEnd() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
 
getEndKey() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getEndKeys() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
Gets the ending row key for every region in the currently open table.
getEndRow() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
getEndRow() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Returns the end row.
getException() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
getExceptionCause() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
getExceptionFullMessage() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
getExceptionMessage() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
getExhaustiveDescription() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
getExists() - Method in class org.apache.hadoop.hbase.client.Result
 
getExtraHeader(String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Get an extra header value.
getExtraHeaders() - Method in class org.apache.hadoop.hbase.rest.client.Client
Get all extra headers (read-only).
getFailedCounterForEachRegionServer() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
getFailureCount() - Method in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
 
getFamilies() - Method in class org.apache.hadoop.hbase.client.Scan
 
getFamilies() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Returns an unmodifiable collection of all the HColumnDescriptor of all the column families of the table.
getFamiliesKeys() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Returns all the column family names of the current table.
getFamily() - Method in interface org.apache.hadoop.hbase.Cell
Deprecated.
getFamily() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
getFamily() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
getFamily(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Returns the HColumnDescriptor for a specific column family with name as specified by the parameter column.
getFamilyArray() - Method in interface org.apache.hadoop.hbase.Cell
Contiguous bytes composed of legal HDFS filename characters which may start at any index in the containing array.
getFamilyCellMap() - Method in class org.apache.hadoop.hbase.client.Mutation
Method for retrieving the put's familyMap
getFamilyLength() - Method in interface org.apache.hadoop.hbase.Cell
 
getFamilyMap() - Method in class org.apache.hadoop.hbase.client.Get
Method for retrieving the get's familyMap
getFamilyMap() - Method in class org.apache.hadoop.hbase.client.Mutation
Deprecated.
getFamilyMap(byte[]) - Method in class org.apache.hadoop.hbase.client.Result
Map of qualifiers to values.
getFamilyMap() - Method in class org.apache.hadoop.hbase.client.Scan
Getting the familyMap
getFamilyMapOfLongs() - Method in class org.apache.hadoop.hbase.client.Increment
Before 0.95, when you called Increment#getFamilyMap(), you got back a map of families to a list of Longs.
getFamilyOffset() - Method in interface org.apache.hadoop.hbase.Cell
 
getFilter() - Method in class org.apache.hadoop.hbase.client.Query
 
getFilter() - Method in class org.apache.hadoop.hbase.client.Scan
 
getFilter() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
getFilter() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
getFilterArguments(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Returns the arguments of the filter from the filter string
getFilterIfMissing() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Get whether entire row should be filtered if column is not found.
getFilterName(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Returns the filter name given a simple filter expression
getFilters() - Method in class org.apache.hadoop.hbase.filter.FilterList
Get the filters.
getFingerprint() - Method in class org.apache.hadoop.hbase.client.Get
Compile the table and column family (i.e.
getFingerprint() - Method in class org.apache.hadoop.hbase.client.Mutation
Compile the column family (i.e.
getFingerprint() - Method in class org.apache.hadoop.hbase.client.Operation
Produces a Map containing a fingerprint which identifies the type and the static schema components of a query (i.e.
getFingerprint() - Method in class org.apache.hadoop.hbase.client.Scan
Compile the table and column family (i.e.
getFirst() - Method in class org.apache.hadoop.hbase.util.Pair
Return the first element stored in the pair.
getFirst() - Method in class org.apache.hadoop.hbase.util.PairOfSameType
Return the first element stored in the pair.
getFirstFailureAt() - Method in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
 
getFlushPolicyClassName() - Method in class org.apache.hadoop.hbase.HTableDescriptor
This gets the class associated with the flush policy which determines the stores need to be flushed when flushing a region.
getForeignExceptionMessage() - Method in class org.apache.hadoop.hbase.ProcedureInfo
Deprecated.
getGroupName(String) - Static method in class org.apache.hadoop.hbase.AuthUtil
Returns the actual name for a group principal (stripped of the group prefix).
getGroupNames() - Method in class org.apache.hadoop.hbase.security.User
Returns the list of groups of which this user is a member.
getHBaseVersion() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getHeader(String) - Method in class org.apache.hadoop.hbase.rest.client.Response
 
getHeaders() - Method in class org.apache.hadoop.hbase.rest.client.Response
 
getHostAndPort() - Method in class org.apache.hadoop.hbase.ServerName
 
getHostname() - Method in class org.apache.hadoop.hbase.HRegionLocation
 
getHostname() - Method in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
 
getHostname() - Method in class org.apache.hadoop.hbase.net.Address
 
getHostname() - Method in class org.apache.hadoop.hbase.ServerName
 
getHostnamePort(int) - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
getHostnamePort() - Method in class org.apache.hadoop.hbase.HRegionLocation
 
getHRegionInfo(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
use MetaTableAccessor methods for interacting with meta layouts
getHRegionInfo(Result, byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
use MetaTableAccessor methods for interacting with meta layouts
getHRegionInfoAndServerName(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
use MetaTableAccessor methods for interacting with meta layouts
getHTable() - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
getHTable() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
getHTableDescriptor(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
getHTableDescriptor(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
getHTableDescriptors(List<String>) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
getHTableDescriptorsByTableName(List<TableName>) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
getHTableMultiplexerStatus() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
 
getHttpClient() - Method in class org.apache.hadoop.hbase.rest.client.Client
 
getId() - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
This method allows you to retrieve the identifier for the operation if one was set.
getId() - Method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
 
getInfoServerPort() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getInitialDelay() - Method in class org.apache.hadoop.hbase.ScheduledChore
 
getInstance() - Static method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
 
getInt(Configuration, String, String, int) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
Get the value of the name property as an int, possibly referring to the deprecated name of the configuration property.
getInt(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Retrieve the int value at index
getInt() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Retrieve the next int value from this range.
getIsolationLevel() - Method in class org.apache.hadoop.hbase.client.Query
 
getIv() - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
Get the initialization vector
getIvLength() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
Return the expected initialization vector length, in bytes, or 0 if not applicable
getIvLength() - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
Get the expected length for the initialization vector
getIvLength() - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
Get the expected length for the initialization vector
getKeepAliveMasterService() - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Since 0.96.0
getKeepDeletedCells() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getKey() - Method in class org.apache.hadoop.hbase.io.crypto.Context
 
getKey(String) - Method in interface org.apache.hadoop.hbase.io.crypto.KeyProvider
Retrieve the key for a given key aliase
getKey(String) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
 
getKeyBytes() - Method in class org.apache.hadoop.hbase.io.crypto.Context
 
getKeyBytesHash() - Method in class org.apache.hadoop.hbase.io.crypto.Context
 
getKeyFormat() - Method in class org.apache.hadoop.hbase.io.crypto.Context
 
getKeyLength() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
Return the key length required by this cipher, in bytes
getKeyProvider(Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
 
getKeys(String[]) - Method in interface org.apache.hadoop.hbase.io.crypto.KeyProvider
Retrieve keys for a given set of key aliases
getKeys(String[]) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
 
getKeyValues(Configuration, String) - Static method in class org.apache.hadoop.hbase.util.ConfigurationUtil
Retrieve a list of key value pairs from configuration, stored under the provided key
getKeyValues(Configuration, String, char) - Static method in class org.apache.hadoop.hbase.util.ConfigurationUtil
Retrieve a list of key value pairs from configuration, stored under the provided key
getLastAttemptAt() - Method in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
 
getLastMajorCompactionTimestamp(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Get the timestamp of the last major compaction for the passed table The timestamp of the oldest HFile resulting from a major compaction of that table, or 0 if no such HFile could be found.
getLastMajorCompactionTimestampForRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Get the timestamp of the last major compaction for the passed region.
getLastMajorCompactionTs() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getLastMajorCompactionTsForRegion(byte[]) - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getLastMajorCompactionTsForTable(TableName) - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getLastUpdate() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
getLatestVersionOnly() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Get whether only the latest version of the column value should be compared.
getLength() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
getLength() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
getLength() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Returns the length of the split.
getLength() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
Retrieve the maximum length (in bytes) of encoded values.
getLength() - Method in interface org.apache.hadoop.hbase.util.ByteRange
The length of the range.
getLength() - Method in class org.apache.hadoop.hbase.util.Bytes
 
getLimit() - Method in class org.apache.hadoop.hbase.client.Scan
 
getLimit() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
getLimit() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
getLimit() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Return the current limit
getListener() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
 
getLiveMasters() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
getLiveRegionServers() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
getLoad(ServerName) - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getLoad() - Method in class org.apache.hadoop.hbase.ServerLoad
Originally, this method factored in the effect of requests going to the server as well.
getLoadColumnFamiliesOnDemandValue() - Method in class org.apache.hadoop.hbase.client.Query
Get the raw loadColumnFamiliesOnDemand setting; if it's not set, can be null.
getLocation() - Method in class org.apache.hadoop.hbase.rest.client.Response
 
getLocations() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
getLocations() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Returns the region's location as an array.
getLong(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Retrieve the long value at index
getLong() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Retrieve the next long value from this range.
getMap() - Method in class org.apache.hadoop.hbase.client.Result
Map of families to all versions of its qualifiers and values.
getMaster() - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
getMaster() - Method in class org.apache.hadoop.hbase.ClusterStatus
Returns detailed information about the current master ServerName.
getMaster(int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
getMasterCoprocessors() - Method in interface org.apache.hadoop.hbase.client.Admin
Helper delegage to getClusterStatus().getMasterCoprocessors().
getMasterCoprocessors() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getMasterInfoPort() - Method in interface org.apache.hadoop.hbase.client.Admin
Get the info port of the current master if one is available.
getMasters() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
getMax() - Method in class org.apache.hadoop.hbase.io.TimeRange
 
getMax() - Method in class org.apache.hadoop.hbase.util.FastLongHistogram
Deprecated.
 
getMaxAllowedOperationTime() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
 
getMaxColumn() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
getMaxColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
getMaxFileSize() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Returns the maximum size upto which a region can grow to after which a region split is triggered.
getMaxHeapMB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getMaxKeyValueSize() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
 
getMaxLatency() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
getMaxLatencyForEachRegionServer() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
getMaxPriority() - Method in class org.apache.hadoop.hbase.client.RowMutations
 
getMaxResultSize() - Method in class org.apache.hadoop.hbase.client.Scan
 
getMaxResultsPerColumnFamily() - Method in class org.apache.hadoop.hbase.client.Get
Method for retrieving the get's maximum number of values to return per Column Family
getMaxResultsPerColumnFamily() - Method in class org.apache.hadoop.hbase.client.Scan
 
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
 
getMD5AsHex(byte[]) - Static method in class org.apache.hadoop.hbase.util.MD5Hash
Given a byte array, returns in MD5 hash as a hex string.
getMD5AsHex(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.MD5Hash
Given a byte array, returns its MD5 hash as a hex string.
getMean() - Method in class org.apache.hadoop.hbase.util.FastLongHistogram
Deprecated.
 
getMemStoreFlushSize() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Returns the size of the memstore after which a flush to filesystem is triggered.
getMemstoreSizeInMB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getMemStoreSizeMB() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getMergeRegions(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
use MetaTableAccessor methods for interacting with meta layouts
getMin() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
Gets the minimum timestamp requested by filter.
getMin() - Method in class org.apache.hadoop.hbase.io.TimeRange
 
getMin() - Method in class org.apache.hadoop.hbase.util.FastLongHistogram
Deprecated.
 
getMinColumn() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
getMinColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
getMinVersions() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getMutations() - Method in class org.apache.hadoop.hbase.client.RowMutations
 
getMvccVersion() - Method in interface org.apache.hadoop.hbase.Cell
Deprecated.
as of 1.0, use Cell.getSequenceId() Internal use only. A region-specific sequence ID given to each operation. It always exists for cells in the memstore but is not retained forever. It may survive several flushes, but generally becomes irrelevant after the cell's row is no longer involved in any operations that require strict consistency.
getName() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
Gets the fully qualified table name instance of the table that this BufferedMutator writes to.
getName() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
Gets the fully qualified table name instance of this table.
getName() - Method in enum org.apache.hadoop.hbase.client.security.SecurityCapability
 
getName() - Method in interface org.apache.hadoop.hbase.client.Table
Gets the fully qualified table name instance of this table.
getName() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getName() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
getName() - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
 
getName() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
Return this Cipher's name
getName() - Method in interface org.apache.hadoop.hbase.io.crypto.CipherProvider
Return the provider's name
getName() - Method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
 
getName() - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
 
getName() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getName() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
getName() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
Get group name.
getName() - Method in class org.apache.hadoop.hbase.ScheduledChore
 
getName() - Method in class org.apache.hadoop.hbase.security.User
Returns the full user name.
getName() - Method in class org.apache.hadoop.hbase.TableName
 
getNameAsString() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getNameAsString() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Get the name of the table as a String
getNameAsString() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getNameAsString() - Method in class org.apache.hadoop.hbase.TableName
 
getNameFromId(short) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
Find and return the name of data block encoder for the given id.
getNameInBytes() - Method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
 
getNamespace() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
 
getNamespace() - Method in class org.apache.hadoop.hbase.TableName
 
getNamespaceAsString() - Method in class org.apache.hadoop.hbase.TableName
 
getNamespaceDescriptor(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Get a namespace descriptor by name
getNamespaceFilter() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
 
getNameWithNamespaceInclAsString() - Method in class org.apache.hadoop.hbase.TableName
Ideally, getNameAsString should contain namespace within it, but if the namespace is default, it just returns the name.
getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.Filter
If the filter returns the match code SEEK_NEXT_USING_HINT, then it should also tell which is the next key it must seek to.
getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
 
getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
Pick the next cell that the scanner should seek to.
getNextKeyHint(KeyValue) - Method in class org.apache.hadoop.hbase.filter.Filter
Deprecated.
getNextKeyHint(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterList
Deprecated.
getNonceGenerator() - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
getNonceKey() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
getNoVersionMap() - Method in class org.apache.hadoop.hbase.client.Result
Map of families to their most recent qualifiers and values.
getNumAtOrBelow(long) - Method in class org.apache.hadoop.hbase.util.FastLongHistogram
Deprecated.
 
getNumberOfRegions() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getNumberOfRequests() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getNumExceptions() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
getOffset() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
getOffset() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
getOffset() - Method in interface org.apache.hadoop.hbase.util.ByteRange
The offset, the index into the underlying byte[] at which this range begins.
getOffset() - Method in class org.apache.hadoop.hbase.util.Bytes
 
getOnlineRegions(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
Get all the online regions on a region server.
getOperationTimeout() - Method in interface org.apache.hadoop.hbase.client.Admin
 
getOperationTimeout() - Method in interface org.apache.hadoop.hbase.client.Table
Get timeout (millisecond) of each operation for in Table instance.
getOperationTimeout() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
getOperator() - Method in class org.apache.hadoop.hbase.filter.BitComparator
 
getOperator() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
getOperator() - Method in class org.apache.hadoop.hbase.filter.FilterList
Get the operator.
getOperator() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
getOrder() - Method in interface org.apache.hadoop.hbase.types.DataType
Retrieve the sort Order imposed by this data type, or null when natural ordering is not preserved.
getOrder() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
 
getOrder() - Method in class org.apache.hadoop.hbase.types.OrderedBytesBase
 
getOrder() - Method in class org.apache.hadoop.hbase.types.PBType
 
getOrder() - Method in class org.apache.hadoop.hbase.types.RawByte
 
getOrder() - Method in class org.apache.hadoop.hbase.types.RawBytes
 
getOrder() - Method in class org.apache.hadoop.hbase.types.RawDouble
 
getOrder() - Method in class org.apache.hadoop.hbase.types.RawFloat
 
getOrder() - Method in class org.apache.hadoop.hbase.types.RawInteger
 
getOrder() - Method in class org.apache.hadoop.hbase.types.RawLong
 
getOrder() - Method in class org.apache.hadoop.hbase.types.RawShort
 
getOrder() - Method in class org.apache.hadoop.hbase.types.RawString
 
getOrder() - Method in class org.apache.hadoop.hbase.types.Struct
 
getOrder() - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
 
getOrder() - Method in class org.apache.hadoop.hbase.types.Union2
 
getOrder() - Method in class org.apache.hadoop.hbase.types.Union3
 
getOrder() - Method in class org.apache.hadoop.hbase.types.Union4
 
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
 
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
Returns the output committer.
getOverallAverageLatency() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
getOwnerString() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
since 0.94.1
getPageSize() - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
getParentId() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
getPartition(ImmutableBytesWritable, V2, int) - Method in class org.apache.hadoop.hbase.mapred.HRegionPartitioner
 
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.
getPartition(ImmutableBytesWritable, VALUE, int) - Method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
 
getPassword(Configuration, String, String) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
Get the password from the Configuration instance using the getPassword method if it exists.
getPeerConfig(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
 
getPeerData() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
getPeersCount() - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Get the number of slave clusters the local cluster has.
getPeerState(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Get the state of the specified peer cluster
getPeerTableCFs(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Get the replicable table-cf config of the specified peer.
getPeriod() - Method in class org.apache.hadoop.hbase.ScheduledChore
 
getPool() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
 
getPort() - Method in class org.apache.hadoop.hbase.HRegionLocation
 
getPort() - Method in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
 
getPort() - Method in class org.apache.hadoop.hbase.net.Address
 
getPort() - Method in class org.apache.hadoop.hbase.ServerName
 
getPos() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
 
getPos() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
 
getPosition() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
The current position marker.
getPrefix() - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
getPrefix() - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
getPrefix() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
getPriority() - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
 
getPriority() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
getProcId() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
getProcName() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
getProcOwner() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
getProcState() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
getProgress() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
 
getProgress() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
 
getProgress() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
The current progress of the record reader through its data.
getProgress() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
The current progress of the record reader through its data.
getProtocol() - Method in exception org.apache.hadoop.hbase.exceptions.UnknownProtocolException
 
getProvider() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
Return the provider for this Cipher
getQualifier() - Method in interface org.apache.hadoop.hbase.Cell
Deprecated.
getQualifier() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
getQualifier() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
getQualifier() - Method in class org.apache.hadoop.hbase.TableName
 
getQualifierArray() - Method in interface org.apache.hadoop.hbase.Cell
Contiguous raw bytes that may start at any index in the containing array.
getQualifierAsString() - Method in class org.apache.hadoop.hbase.TableName
 
getQualifierBufferShallowCopy(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
getQualifierLength() - Method in interface org.apache.hadoop.hbase.Cell
 
getQualifierOffset() - Method in interface org.apache.hadoop.hbase.Cell
 
getQuantiles(double[]) - Method in class org.apache.hadoop.hbase.util.FastLongHistogram
Deprecated.
Computes the quantiles give the ratios.
getQuantiles() - Method in class org.apache.hadoop.hbase.util.FastLongHistogram
Deprecated.
 
getQuotaRetriever(QuotaFilter) - Method in interface org.apache.hadoop.hbase.client.Admin
Return a QuotaRetriever to list the quotas based on the filter.
getQuotaType() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
 
getRandomKey() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
Create a random symmetric key
getReadRequestsCount() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getReadRequestsCount() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getReadRpcTimeout() - Method in interface org.apache.hadoop.hbase.client.Table
Get timeout (millisecond) of each rpc read request in this Table instance.
getReadRpcTimeout() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
getReadType() - Method in class org.apache.hadoop.hbase.client.Scan
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hbase.mapred.MultiTableSnapshotInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Builds a TableRecordReader.
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat
Deprecated.
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
Creates a new record writer.
getRegionCachePrefetch(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
always return false since 0.99
getRegionCachePrefetch(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
always return false since 0.99
getRegionId() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getRegionInfo() - Method in class org.apache.hadoop.hbase.HRegionLocation
 
getRegionLocation(TableName, byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
getRegionLocation(byte[], byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
getRegionLocation(byte[]) - Method in interface org.apache.hadoop.hbase.client.RegionLocator
Finds the region on which the given row is being served.
getRegionLocation(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.RegionLocator
Finds the region on which the given row is being served.
getRegionLocation() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
getRegionLocation() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Returns the region location.
getRegionLocator(TableName) - Method in interface org.apache.hadoop.hbase.client.Connection
Retrieve a RegionLocator implementation to inspect region information on a table.
getRegionLocator(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Retrieve a RegionLocator implementation to inspect region information on a table.
getRegionLocator() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Allows subclasses to get the RegionLocator.
getRegionName() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getRegionNameAsString(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
 
getRegionNameAsString(HRegionInfo, byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
 
getRegionNameAsString() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getRegionReplication() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Returns the configured replicas per region
getRegionsCount() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getRegionServer(int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
getRegionServerCoprocessors() - Method in class org.apache.hadoop.hbase.ServerLoad
Return the RegionServer-level coprocessors
getRegionServers() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
getRegionsInTransition() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getRegionsLoad() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getRegionSplitPolicyClassName() - Method in class org.apache.hadoop.hbase.HTableDescriptor
This gets the class associated with the region split policy which determines when a region split should occur.
getRemaining() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
The number of bytes remaining between position and the end of the range.
getReplicaId() - Method in class org.apache.hadoop.hbase.client.Query
Returns region replica id where Query will fetch data from.
getReplicaId() - Method in class org.apache.hadoop.hbase.HRegionInfo
Returns the region replica id
getReplicationEndpointImpl() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
getReplicationLoadSink() - Method in class org.apache.hadoop.hbase.ServerLoad
Call directly from client such as hbase shell
getReplicationLoadSourceList() - Method in class org.apache.hadoop.hbase.ServerLoad
Call directly from client such as hbase shell
getReportTime() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getRequestsCount() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getRequestsCount() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getRequestsPerSecond() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getRestVersion() - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
 
getResult() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
getRevision() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
Get the subversion revision number for the root directory
getRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getRow() - Method in interface org.apache.hadoop.hbase.Cell
Deprecated.
getRow() - Method in class org.apache.hadoop.hbase.client.Cursor
 
getRow() - Method in class org.apache.hadoop.hbase.client.Get
Method for retrieving the get's row
getRow() - Method in class org.apache.hadoop.hbase.client.Mutation
Method for retrieving the delete's row
getRow() - Method in class org.apache.hadoop.hbase.client.Result
Method for retrieving the row key that corresponds to the row from which this Result was created.
getRow(int) - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
getRow() - Method in interface org.apache.hadoop.hbase.client.Row
 
getRow() - Method in class org.apache.hadoop.hbase.client.RowMutations
 
getRowArray() - Method in interface org.apache.hadoop.hbase.Cell
Contiguous raw bytes that may start at any index in the containing array.
getRowByte(Cell, int) - Static method in class org.apache.hadoop.hbase.CellUtil
misc
getRowComparator() - Method in class org.apache.hadoop.hbase.TableName
Deprecated.
The comparator is an internal property of the table. Should not have been exposed here
getRowLength() - Method in interface org.apache.hadoop.hbase.Cell
 
getRowOffset() - Method in interface org.apache.hadoop.hbase.Cell
 
getRowOffsetPerColumnFamily() - Method in class org.apache.hadoop.hbase.client.Get
Method for retrieving the get's offset per row per column family (#kvs to be skipped)
getRowOffsetPerColumnFamily() - Method in class org.apache.hadoop.hbase.client.Scan
Method for retrieving the scan's offset per row per column family (#kvs to be skipped)
getRowOrBefore(byte[], byte[]) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
getRowRanges() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
getRpcTimeout() - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
Use getReadRpcTimeout or getWriteRpcTimeout instead
getRpcTimeout() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
Deprecated.
getRsCoprocessors() - Method in class org.apache.hadoop.hbase.ServerLoad
Return the RegionServer-level and Region-level coprocessors
getScan() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Gets the scan defining the actual details like columns etc.
getScan() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Returns a Scan object from the stored string representation.
getScanMetrics() - Method in interface org.apache.hadoop.hbase.client.ResultScanner
 
getScanMetrics() - Method in class org.apache.hadoop.hbase.client.Scan
Deprecated.
Use ResultScanner.getScanMetrics() instead. And notice that, please do not use this method and ResultScanner.getScanMetrics() together, the metrics will be messed up.
getScanner(Scan) - Method in interface org.apache.hadoop.hbase.client.Table
Returns a scanner on the current table as specified by the Scan object.
getScanner(byte[]) - Method in interface org.apache.hadoop.hbase.client.Table
Gets a scanner on the current table for the given family.
getScanner(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Table
Gets a scanner on the current table for the given family and qualifier.
getScanner(Scan) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
getScanner(byte[]) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
getScanner(byte[], byte[]) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
getScans() - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
Allows subclasses to get the list of Scan objects.
getScope() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getSecond() - Method in class org.apache.hadoop.hbase.util.Pair
Return the second element stored in the pair.
getSecond() - Method in class org.apache.hadoop.hbase.util.PairOfSameType
Return the second element stored in the pair.
getSecretKeyForSubject(String, Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Resolves a key for the given subject
getSecurityCapabilities() - Method in interface org.apache.hadoop.hbase.client.Admin
Return the set of supported security capabilities.
getSeqNum() - Method in class org.apache.hadoop.hbase.HRegionLocation
 
getSeqNumDuringOpen(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
use MetaTableAccessor methods for interacting with meta layouts
getSequenceId() - Method in interface org.apache.hadoop.hbase.Cell
A region-specific unique monotonically increasing sequence ID given to each Cell.
getSerializer(Class<KeyValue>) - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization
 
getSerializer(Class<Mutation>) - Method in class org.apache.hadoop.hbase.mapreduce.MutationSerialization
 
getSerializer(Class<Result>) - Method in class org.apache.hadoop.hbase.mapreduce.ResultSerialization
 
getServerInfo() - Method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
As of release 0.92 (HBASE-1502). This will be removed in HBase 2.0.0. Use ClusterStatus.getServers().
getServerName(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
use MetaTableAccessor methods for interacting with meta layouts
getServerName() - Method in class org.apache.hadoop.hbase.HRegionLocation
 
getServerName() - Method in class org.apache.hadoop.hbase.ServerName
 
getServerName(String, long) - Static method in class org.apache.hadoop.hbase.ServerName
 
getServerNameLessStartCode(String) - Static method in class org.apache.hadoop.hbase.ServerName
Utility method to excise the start code from a server name
getServers() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getServers() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
Get list of servers.
getServersSize() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getServerStartcodeFromServerName(String) - Static method in class org.apache.hadoop.hbase.ServerName
 
getShort(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Retrieve the short value at index
getShort() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Retrieve the next short value from this range.
getShortName() - Method in class org.apache.hadoop.hbase.security.User
Returns the shortened version of the user name -- the portion that maps to an operating system user name.
getShortNameToLog() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getSize() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
Deprecated.
since 0.98.5. Use ImmutableBytesWritable.getLength() instead
getSkipBadLines() - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
 
getSkipBadLines() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
 
getSkipBadLines() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
 
getSnapshotDescription() - Method in exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
Deprecated.
since 1.3.0, will be removed in 3.0.0
getSnapshotList(Configuration) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
Deprecated.
Returns the list of available snapshots in the specified location
getSnapshotsFilesMap(Configuration, AtomicLong, AtomicLong) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
Deprecated.
Returns the map of store files based on path for all snapshots
getSnapshotStats(Configuration, HBaseProtos.SnapshotDescription) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
Deprecated.
Returns the snapshot stats
getSnapshotStats(Configuration, HBaseProtos.SnapshotDescription, Map<Path, Integer>) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
Deprecated.
Returns the snapshot stats
getSource() - Method in exception org.apache.hadoop.hbase.errorhandling.ForeignException
 
getSourceName() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
 
getSplitKey(byte[], byte[], boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Deprecated.
getSplits(JobConf, int) - Method in class org.apache.hadoop.hbase.mapred.MultiTableSnapshotInputFormat
 
getSplits(JobConf, int) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Calculates the splits that will serve as input for the map tasks.
getSplits(JobConf, int) - Method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat
 
getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.HLogInputFormat
Deprecated.
 
getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
Calculates the splits that will serve as input for the map tasks.
getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormat
 
getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
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.
getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat
 
getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.WALInputFormat
 
getSrcChecksum() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
Get the checksum of the source files from which Hadoop was compiled.
getStart() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
 
getStartcode() - Method in class org.apache.hadoop.hbase.ServerName
 
getStartEndKeys() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
Gets the starting and ending row keys for every region in the currently open table.
getStartEndKeys() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
 
getStartEndKeys() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
 
getStartKey(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Gets the start key from the specified region name.
getStartKey() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getStartKeys() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
Gets the starting row key for every region in the currently open table.
getStartRow() - Method in class org.apache.hadoop.hbase.client.Scan
 
getStartRow() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
getStartRow() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Returns the start row.
getStartTime() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
getStats() - Method in class org.apache.hadoop.hbase.client.Result
Deprecated.
getStopper() - Method in class org.apache.hadoop.hbase.ScheduledChore
 
getStopRow() - Method in class org.apache.hadoop.hbase.client.Scan
 
getStopRowKey() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
getStoreCompleteSequenceId() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getStorefileIndexSizeInMB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getStorefiles() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getStorefiles() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getStorefileSizeInMB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getStorefileSizeMB() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getStores() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getStores() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getStoreUncompressedSizeMB() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getStoreUncompressedSizeMB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getStream() - Method in class org.apache.hadoop.hbase.rest.client.Response
Gets the input stream instance.
getSupportedCiphers() - Method in interface org.apache.hadoop.hbase.io.crypto.CipherProvider
Return the set of Ciphers supported by this provider
getSupportedCiphers() - Method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
 
getSupportedCiphers() - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Get names of supported encryption algorithms
getSupportedCiphers(Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Get names of supported encryption algorithms
getSupportedFilters() - Method in class org.apache.hadoop.hbase.filter.ParseFilter
Return a Set of filters supported by the Filter Language
getTable(TableName) - Method in interface org.apache.hadoop.hbase.client.Connection
Retrieve a Table implementation for accessing a table.
getTable(TableName, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.Connection
Retrieve a Table implementation for accessing a table.
getTable(String) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Retrieve an HTableInterface implementation for access to a table.
getTable(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Retrieve an HTableInterface implementation for access to a table.
getTable(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Retrieve an HTableInterface implementation for access to a table.
getTable(String, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Retrieve an HTableInterface implementation for access to a table.
getTable(byte[], ExecutorService) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Retrieve an HTableInterface implementation for access to a table.
getTable(TableName, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Retrieve an HTableInterface implementation for access to a table.
getTable(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Gets the table name from the specified region name.
getTable() - Method in class org.apache.hadoop.hbase.HRegionInfo
Get current table name of the region
getTable() - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Allows subclasses to get the Table.
getTable() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
getTable() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Allows subclasses to get the Table.
getTable() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Returns the table name.
getTableCFsMap() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
getTableDescriptor(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Method for getting the tableDescriptor
getTableDescriptor() - Method in interface org.apache.hadoop.hbase.client.Table
Gets the table descriptor for this table.
getTableDescriptor() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
getTableDescriptors(List<String>) - Method in interface org.apache.hadoop.hbase.client.Admin
Get tableDescriptors
getTableDescriptorsByTableName(List<TableName>) - Method in interface org.apache.hadoop.hbase.client.Admin
Get tableDescriptors
getTableDir(Path, byte[]) - Static method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
getTableFilter() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
 
getTableList() - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
 
getTableName() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
 
getTableName(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 0.96 (HBASE-9508). This will be removed in HBase 2.0.0. Use HRegionInfo.getTable(byte[]).
getTableName() - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 0.96 (HBASE-9508). This will be removed in HBase 2.0.0. Use HRegionInfo.getTable().
getTableName() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Get the name of the table
getTableName() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
getTableName() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Returns the table name converted to a byte array.
getTableName() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
 
getTableName() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
getTableNames() - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
getTableRegions(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Get the regions of a given table.
getTables() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
Set of tables that are members of this group
getTagArray(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
Returns tag value in a new byte array.
getTagsArray() - Method in interface org.apache.hadoop.hbase.Cell
 
getTagsLength() - Method in interface org.apache.hadoop.hbase.Cell
 
getTagsOffset() - Method in interface org.apache.hadoop.hbase.Cell
 
getTimeRange() - Method in class org.apache.hadoop.hbase.client.Get
Method for retrieving the get's TimeRange
getTimeRange() - Method in class org.apache.hadoop.hbase.client.Increment
Gets the TimeRange used for this increment.
getTimeRange() - Method in class org.apache.hadoop.hbase.client.Scan
 
getTimestamp() - Method in interface org.apache.hadoop.hbase.Cell
 
getTimeStamp() - Method in class org.apache.hadoop.hbase.client.Mutation
Method for retrieving the timestamp
getTimestamps() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
 
getTimeToLive() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getTimeUnit() - Method in class org.apache.hadoop.hbase.ScheduledChore
 
getToken(String, String) - Method in class org.apache.hadoop.hbase.security.User
Returns the Token of the specified kind associated with this user, or null if the Token is not present.
getTokens() - Method in class org.apache.hadoop.hbase.security.User
Returns all the tokens stored in the user's credentials.
getTotalBufferedCounter() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
getTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getTotalFailedCounter() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
getTotalNumberOfRequests() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getTotalSizeOfCells(Result) - Static method in class org.apache.hadoop.hbase.client.Result
Get total size of raw cells
getTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getTs() - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
 
getTs() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
 
getTTL() - Method in class org.apache.hadoop.hbase.client.Mutation
Return the TTL requested for the result of the mutation, in milliseconds.
getType() - Method in exception org.apache.hadoop.hbase.quotas.ThrottlingException
 
getTypeByte() - Method in interface org.apache.hadoop.hbase.Cell
 
getTypeFilters() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
 
getUGI() - Method in class org.apache.hadoop.hbase.security.User
 
getUnit(String) - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
 
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.ServerLoad
 
getUser() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
The user that compiled hbase.
getUserFilter() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
 
getUserName() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
 
getUtf8ByteArrays(List<String>) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
getValue() - Method in interface org.apache.hadoop.hbase.Cell
Deprecated.
getValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
Get the latest version of the specified column.
getValue() - Method in enum org.apache.hadoop.hbase.client.security.SecurityCapability
 
getValue() - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
 
getValue() - Method in class org.apache.hadoop.hbase.filter.SubstringComparator
 
getValue(byte[]) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getValue(String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getValue(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Getter for accessing the metadata associated with the key
getValue(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Getter for accessing the metadata associated with the key
getValueArray() - Method in interface org.apache.hadoop.hbase.Cell
Contiguous raw bytes that may start at any index in the containing array.
getValueAsByteBuffer(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
Returns the value wrapped in a new ByteBuffer.
getValueAsByteBuffer(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
Returns the value wrapped in a new ByteBuffer.
getValueBufferShallowCopy(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
getValueLength() - Method in interface org.apache.hadoop.hbase.Cell
 
getValueOffset() - Method in interface org.apache.hadoop.hbase.Cell
 
getValues() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getValues() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Getter for fetching an unmodifiable HTableDescriptor.values map.
getVersion() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getVersion() - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
HRI is no longer a VersionedWritable
getVersion() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
Get the hbase version.
getVersionedBytes() - Method in class org.apache.hadoop.hbase.ServerName
 
getVisibilityExpressionResolver() - Method in class org.apache.hadoop.hbase.mapreduce.CellCreator
 
getVLong(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Retrieve the long value at index which is stored as VLong
getVLong() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Retrieve the next long value, which is stored as VLong, from this range
getWaitInterval() - Method in exception org.apache.hadoop.hbase.quotas.ThrottlingException
 
getWriteBufferSize() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
Returns the maximum size in bytes of the write buffer for this HTable.
getWriteBufferSize() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
 
getWriteBufferSize() - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
as of 1.0.1 (should not have been in 1.0.0). Replaced by BufferedMutator.getWriteBufferSize()
getWriteBufferSize() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getWriteRpcTimeout() - Method in interface org.apache.hadoop.hbase.client.Table
Get timeout (millisecond) of each rpc write request in this Table instance.
getWriteRpcTimeout() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
getWriteToWAL() - Method in class org.apache.hadoop.hbase.client.Mutation
Deprecated.
getZooKeeperServerNum() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
 
GREATER_THAN_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
GREATER_THAN Array
GREATER_THAN_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
 
GREATER_THAN_OR_EQUAL_TO_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
GREATER_THAN_OR_EQUAL_TO Array
GREATER_THAN_OR_EQUAL_TO_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
 
GROUP_COLUMNS - Static variable in class org.apache.hadoop.hbase.mapred.GroupingTableMap
JobConf parameter to specify the columns used to produce the key passed to collect from the map phase
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
Extract grouping columns from input record
GroupingTableMap() - Constructor for class org.apache.hadoop.hbase.mapred.GroupingTableMap
 
GroupingTableMapper - Class in org.apache.hadoop.hbase.mapreduce
Extract grouping columns from input record.
GroupingTableMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
 
groupOrSplit(Multimap<ByteBuffer, LoadIncrementalHFiles.LoadQueueItem>, LoadIncrementalHFiles.LoadQueueItem, Table, Pair<byte[][], byte[][]>) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
Attempt to assign the given load queue item into its target region group.

H

H - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'H'
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.
HAS_LARGE_RESULT - Static variable in class org.apache.hadoop.hbase.mapreduce.Import
 
hasBody() - Method in class org.apache.hadoop.hbase.rest.client.Response
 
hasClientAckTime() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
hasCoprocessor(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Check if the table has an attached co-processor represented by the name className
hasFamilies() - Method in class org.apache.hadoop.hbase.client.Get
Method for checking if any families have been inserted into this Get
hasFamilies() - Method in class org.apache.hadoop.hbase.client.Increment
Method for checking if any families have been inserted into this Increment
hasFamilies() - Method in class org.apache.hadoop.hbase.client.Scan
 
hasFamily(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Checks to see if this table contains the given column family
hasFilter() - Method in class org.apache.hadoop.hbase.client.Scan
 
hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.Filter
Primarily used to check for conflicts with scans(such as scans that do not read a full row at a time).
hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.FilterList
 
hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
 
hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
hasFoundKV() - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
hash128(String...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Return the MD5 digest of the concatenation of the supplied arguments.
hash128(byte[]...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Return the MD5 digest of the concatenation of the supplied arguments.
hash256(String...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Return the SHA-256 digest of the concatenation of the supplied arguments.
hash256(byte[]...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Return the SHA-256 digest of the concatenation of the supplied arguments.
hashCode() - Method in class org.apache.hadoop.hbase.client.Get
 
hashCode() - Method in class org.apache.hadoop.hbase.client.Increment
 
hashCode() - Method in class org.apache.hadoop.hbase.client.RowMutations
 
hashCode() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.FamilyFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.FilterList
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.NullComparator
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.QualifierFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.RowFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.ValueFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
hashCode() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
hashCode() - Method in class org.apache.hadoop.hbase.HRegionLocation
 
hashCode() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
hashCode() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
hashCode() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
hashCode() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
 
hashCode() - Method in class org.apache.hadoop.hbase.net.Address
 
hashCode() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
 
hashCode() - Method in class org.apache.hadoop.hbase.security.User
 
hashCode() - Method in class org.apache.hadoop.hbase.ServerLoad
 
hashCode() - Method in class org.apache.hadoop.hbase.ServerName
 
hashCode() - Method in class org.apache.hadoop.hbase.TableName
 
hashCode() - Method in class org.apache.hadoop.hbase.util.Bytes
 
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(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
hashCode() - Method in class org.apache.hadoop.hbase.util.Pair
 
hashCode() - Method in class org.apache.hadoop.hbase.util.PairOfSameType
 
hasHigherPriority(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
Returns which operator has higher precedence
hasMaxHeapMB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
hasNext() - Method in class org.apache.hadoop.hbase.types.StructIterator
 
hasNumberOfRequests() - Method in class org.apache.hadoop.hbase.ServerLoad
 
hasParentId() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
hasRegionMemstoreReplication() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
hasResultData() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
hasTotalNumberOfRequests() - Method in class org.apache.hadoop.hbase.ServerLoad
 
hasUsedHeapMB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
HBASE_BALANCER_MAX_BALANCING - Static variable in class org.apache.hadoop.hbase.HConstants
Config for the max balancing time
HBASE_BALANCER_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
Config for the balancer period
HBASE_CANARY_READ_RAW_SCAN_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CANARY_WRITE_DATA_TTL_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Canary config keys
HBASE_CANARY_WRITE_PERSERVER_REGIONS_LOWERLIMIT_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CANARY_WRITE_PERSERVER_REGIONS_UPPERLIMIT_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CANARY_WRITE_TABLE_CHECK_PERIOD_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CANARY_WRITE_VALUE_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CHECKSUM_VERIFICATION - Static variable in class org.apache.hadoop.hbase.HConstants
If this parameter is set to true, then hbase will read data and then verify checksums.
HBASE_CLIENT_CONNECTION_IMPL - Static variable in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Key for configuration in Configuration whose value is the class we implement making a new HConnection instance.
HBASE_CLIENT_ENABLE_FAST_FAIL_MODE_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CLIENT_FAST_FAIL_CLEANUP_DURATION_MS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CLIENT_FAST_FAIL_CLEANUP_MS_DURATION_MS - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CLIENT_FAST_FAIL_INTERCEPTOR_IMPL - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CLIENT_FAST_FAIL_MODE_ENABLED - Static variable in class org.apache.hadoop.hbase.HConstants
Config for enabling/disabling the fast fail mode.
HBASE_CLIENT_FAST_FAIL_THREASHOLD_MS - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CLIENT_FAST_FAIL_THREASHOLD_MS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CLIENT_INSTANCE_ID - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for unique identifier for this Configuration instance.
HBASE_CLIENT_IPC_POOL_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for HBase client IPC pool size
HBASE_CLIENT_IPC_POOL_TYPE - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for HBase client IPC pool type
HBASE_CLIENT_MAX_PERREGION_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
The maximum number of concurrent connections the client will maintain to a single Region.
HBASE_CLIENT_MAX_PERSERVER_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
The maximum number of concurrent connections the client will maintain to a single RegionServer.
HBASE_CLIENT_MAX_TOTAL_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
The maximum number of concurrent connections the client will maintain.
HBASE_CLIENT_META_OPERATION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for HBase client operation timeout.
HBASE_CLIENT_META_REPLICA_SCAN_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for HBase client meta replica scan call timeout.
HBASE_CLIENT_META_REPLICA_SCAN_TIMEOUT_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
Default HBase client meta replica scan call timeout, 1 second
HBASE_CLIENT_OPERATION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for HBase client operation timeout.
HBASE_CLIENT_PAUSE - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for client pause value, used mostly as value to wait before running a retry of a failed get, region lookup, etc.
HBASE_CLIENT_PAUSE_FOR_CQTBE - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CLIENT_PERSERVER_REQUESTS_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
The maximum number of concurrent pending RPC requests for one server in process level.
HBASE_CLIENT_RETRIES_NUMBER - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for maximum retries, used as maximum for all retryable operations such as fetching of the root region from root region server, getting a cell's value, starting a row update, etc.
HBASE_CLIENT_SCANNER_CACHING - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name to set the default scanner caching for all clients.
HBASE_CLIENT_SCANNER_MAX_RESULT_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for maximum number of bytes returned when calling a scanner's next method.
HBASE_CLIENT_SCANNER_TIMEOUT_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
The client scanner timeout period in milliseconds.
HBASE_CLUSTER_MINIMUM_MEMORY_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CONFIG_READ_ZOOKEEPER_CONFIG - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_COORDINATED_STATE_MANAGER_CLASS - Static variable in class org.apache.hadoop.hbase.HConstants
Config for pluggable consensus provider
HBASE_DIR - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for HBase instance root directory
HBASE_MASTER_BALANCER_MAX_RIT_PERCENT - Static variable in class org.apache.hadoop.hbase.HConstants
Config for the max percent of regions in transition
HBASE_MASTER_LOADBALANCE_BYTABLE - Static variable in class org.apache.hadoop.hbase.HConstants
Config for balancing the cluster by table
HBASE_MASTER_LOADBALANCER_CLASS - Static variable in class org.apache.hadoop.hbase.HConstants
Config for pluggable load balancers
HBASE_MASTER_LOGCLEANER_PLUGINS - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_MASTER_NORMALIZER_CLASS - Static variable in class org.apache.hadoop.hbase.HConstants
Config for pluggable region normalizer
HBASE_META_BLOCK_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for number of versions, kept by meta table.
HBASE_META_SCANNER_CACHING - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for number of rows that will be fetched when calling next on a scanner if it is not served from memory.
HBASE_META_VERSIONS - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for number of versions, kept by meta table.
HBASE_NON_TABLE_DIRS - Static variable in class org.apache.hadoop.hbase.HConstants
Directories that are not HBase table directories
HBASE_NON_USER_TABLE_DIRS - Static variable in class org.apache.hadoop.hbase.HConstants
Directories that are not HBase user table directories
HBASE_REGION_SPLIT_POLICY_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_REGIONSERVER_LEASE_PERIOD_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Deprecated.
This config option is deprecated. Will be removed at later releases after 0.96.
HBASE_RPC_READ_TIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
timeout for each read RPC
HBASE_RPC_SHORTOPERATION_TIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
timeout for short operation RPC
HBASE_RPC_TIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
HBASE_RPC_WRITE_TIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
timeout for each write RPC
HBASE_RS_NONCES_ENABLED - Static variable in class org.apache.hadoop.hbase.HConstants
Whether nonces are enabled; default is true.
HBASE_SECURITY_AUTHORIZATION_CONF_KEY - Static variable in class org.apache.hadoop.hbase.security.User
 
HBASE_SECURITY_CONF_KEY - Static variable in class org.apache.hadoop.hbase.security.User
 
HBASE_SERVER_PAUSE - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for server pause value, used mostly as value to wait before running a retry of a failed operation.
HBASE_SERVER_SCANNER_MAX_RESULT_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for maximum number of bytes returned when calling a scanner's next method.
HBASE_SPLITLOG_MANAGER_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for SplitLog manager timeout
HBASE_TEMP_DIRECTORY - Static variable in class org.apache.hadoop.hbase.HConstants
Temporary directory used for table creation and deletion
HBASECLIENT_IMPL - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for what hbase client implementation to use.
HBaseConfiguration - Class in org.apache.hadoop.hbase
Adds HBase configuration files to a Configuration
HBaseConfiguration() - Constructor for class org.apache.hadoop.hbase.HBaseConfiguration
Deprecated.
since 0.90.0. Please use HBaseConfiguration.create() instead.
HBaseConfiguration(Configuration) - Constructor for class org.apache.hadoop.hbase.HBaseConfiguration
Deprecated.
since 0.90.0. Please use HBaseConfiguration.create(Configuration) instead.
HBaseInterfaceAudience - Class in org.apache.hadoop.hbase
This class defines constants for different classes of hbase limited private apis
HBaseInterfaceAudience() - Constructor for class org.apache.hadoop.hbase.HBaseInterfaceAudience
 
HBaseIOException - Exception in org.apache.hadoop.hbase
All hbase specific IOExceptions should be subclasses of HBaseIOException
HBaseIOException() - Constructor for exception org.apache.hadoop.hbase.HBaseIOException
 
HBaseIOException(String) - Constructor for exception org.apache.hadoop.hbase.HBaseIOException
 
HBaseIOException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.HBaseIOException
 
HBaseIOException(Throwable) - Constructor for exception org.apache.hadoop.hbase.HBaseIOException
 
HBaseSnapshotException - Exception in org.apache.hadoop.hbase.snapshot
General exception base class for when a snapshot fails.
HBaseSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
Some exception happened for a snapshot and don't even know the snapshot that it was about.
HBaseSnapshotException(String, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
Deprecated.
since 1.3.0, will be removed in 3.0.0
HBaseSnapshotException(String, Throwable, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
Deprecated.
since 1.3.0, will be removed in 3.0.0
HBaseSnapshotException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
Exception when the description of the snapshot cannot be determined, due to some root other root cause.
HBCK_CODE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
HBCK special code name used as server name when manipulating ZK nodes
HBCK_SIDELINEDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
Used by HBCK to sideline backup data
HColumnDescriptor - Class in org.apache.hadoop.hbase
An HColumnDescriptor contains information about a column family such as the number of versions, compression settings, etc.
HColumnDescriptor() - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 0.96 (HBASE-5453). This will be made private in HBase 2.0.0. Used by Writables and Writables are going away.
HColumnDescriptor(String) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Construct a column descriptor specifying only the family name The other attributes are defaulted.
HColumnDescriptor(byte[]) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Construct a column descriptor specifying only the family name The other attributes are defaulted.
HColumnDescriptor(HColumnDescriptor) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Constructor.
HColumnDescriptor(byte[], int, String, boolean, boolean, int, String) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 0.96 (HBASE-). This will be removed in HBase 2.0.0. Use HColumnDescriptor.HColumnDescriptor(String) and setters.
HColumnDescriptor(byte[], int, String, boolean, boolean, int, int, String, int) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 0.96 (HBASE-). This will be removed in HBase 2.0.0. Use HColumnDescriptor.HColumnDescriptor(String) and setters.
HColumnDescriptor(byte[], int, int, KeepDeletedCells, String, boolean, String, boolean, boolean, int, int, String, int) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 0.96 (HBASE-). This will be removed in HBase 2.0.0. Use HColumnDescriptor.HColumnDescriptor(String) and setters.
HConnection - Interface in org.apache.hadoop.hbase.client
Deprecated.
HConnectionManager - Class in org.apache.hadoop.hbase.client
Deprecated.
Please use ConnectionFactory instead
HConstants - Class in org.apache.hadoop.hbase
HConstants holds a bunch of HBase-related constants
head(String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a HEAD request
head(Cluster, String, Header[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a HEAD request
head(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
HEALTH_CHORE_WAKE_FREQ - Static variable in class org.apache.hadoop.hbase.HConstants
 
HEALTH_FAILURE_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
The maximum number of health check failures a server can encounter consecutively.
HEALTH_SCRIPT_LOC - Static variable in class org.apache.hadoop.hbase.HConstants
Health script related settings.
HEALTH_SCRIPT_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
 
HEAP_OCCUPANCY_HIGH_WATERMARK_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
HEAP_OCCUPANCY_LOW_WATERMARK_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
heapSize() - Method in class org.apache.hadoop.hbase.client.Mutation
 
HFILE_ARCHIVE_DIRECTORY - Static variable in class org.apache.hadoop.hbase.HConstants
Directory under /hbase where archived hfiles are stored
HFILE_BLOCK_CACHE_SIZE_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
HFILE_BLOCK_CACHE_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for the size of the block cache
HFILEBLOCK_DUMMY_HEADER - Static variable in class org.apache.hadoop.hbase.HConstants
Just an array of bytes of the right size.
HFILEBLOCK_HEADER_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
The size of a version 2 HFile block header, minor version 1.
HFILEBLOCK_HEADER_SIZE_NO_CHECKSUM - Static variable in class org.apache.hadoop.hbase.HConstants
The size data structures with minor version is 0
HFileOutputFormat - Class in org.apache.hadoop.hbase.mapreduce
Deprecated.
use HFileOutputFormat2 instead.
HFileOutputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat
Deprecated.
 
HFileOutputFormat2 - Class in org.apache.hadoop.hbase.mapreduce
Writes HFiles.
HFileOutputFormat2() - Constructor for class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
 
HIGH_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
 
hint - Variable in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
HINT_LOOKAHEAD - Static variable in class org.apache.hadoop.hbase.client.Scan
Deprecated.
without replacement This is now a no-op, SEEKs and SKIPs are optimizated automatically. Will be removed in 2.0+
HLogInputFormat - Class in org.apache.hadoop.hbase.mapreduce
Deprecated.
HLogInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.HLogInputFormat
Deprecated.
 
HOUR_IN_SECONDS - Static variable in class org.apache.hadoop.hbase.HConstants
 
HREGION_COMPACTIONDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
Used to construct the name of the compaction directory during compaction
HREGION_EDITS_REPLAY_SKIP_ERRORS - Static variable in class org.apache.hadoop.hbase.HConstants
 
HREGION_LOGDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
Used to construct the name of the log directory for a region server
HREGION_MAX_FILESIZE - Static variable in class org.apache.hadoop.hbase.HConstants
Conf key for the max file size after which we split the region
HREGION_MEMSTORE_BLOCK_MULTIPLIER - Static variable in class org.apache.hadoop.hbase.HConstants
Block updates if memstore has hbase.hregion.memstore.block.multiplier times hbase.hregion.memstore.flush.size bytes.
HREGION_MEMSTORE_FLUSH_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
Conf key for the memstore size at which we flush the memstore
HREGION_OLDLOGDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
Like the previous, but for old logs that are about to be deleted
HRegionInfo - Class in org.apache.hadoop.hbase
Information about a region.
HRegionInfo(long, TableName, int) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
 
HRegionInfo() - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 0.96 (HBASE-5453). This will be removed in HBase 2.0.0. Used by Writables and Writables are going away.
HRegionInfo(TableName) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
 
HRegionInfo(TableName, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Construct HRegionInfo with explicit parameters
HRegionInfo(TableName, byte[], byte[], boolean) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Construct HRegionInfo with explicit parameters
HRegionInfo(TableName, byte[], byte[], boolean, long) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Construct HRegionInfo with explicit parameters
HRegionInfo(TableName, byte[], byte[], boolean, long, int) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Construct HRegionInfo with explicit parameters
HRegionInfo(HRegionInfo) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Costruct a copy of another HRegionInfo
HRegionInfo(HRegionInfo, int) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
 
HRegionLocation - Class in org.apache.hadoop.hbase
Data structure to hold HRegionInfo and the address for the hosting HRegionServer.
HRegionLocation(HRegionInfo, ServerName) - Constructor for class org.apache.hadoop.hbase.HRegionLocation
 
HRegionLocation(HRegionInfo, ServerName, long) - Constructor for class org.apache.hadoop.hbase.HRegionLocation
 
HRegionPartitioner<K2,V2> - Class in org.apache.hadoop.hbase.mapred
This is used to partition the output keys into groups of keys.
HRegionPartitioner() - Constructor for class org.apache.hadoop.hbase.mapred.HRegionPartitioner
 
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
 
HSTORE_OPEN_AND_CLOSE_THREADS_MAX - Static variable in class org.apache.hadoop.hbase.HConstants
The max number of threads used for opening and closing stores or store files in parallel
HTableDescriptor - Class in org.apache.hadoop.hbase
HTableDescriptor contains the details about an HBase table such as the descriptors of all the column families, is the table a catalog table, -ROOT- or hbase:meta , if the table is read only, the maximum size of the memstore, when the region split should occur, coprocessors associated with it etc...
HTableDescriptor(TableName, HColumnDescriptor[]) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Private constructor used internally creating table descriptors for catalog tables, hbase:meta and -ROOT-.
HTableDescriptor(TableName, HColumnDescriptor[], Map<ImmutableBytesWritable, ImmutableBytesWritable>) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Private constructor used internally creating table descriptors for catalog tables, hbase:meta and -ROOT-.
HTableDescriptor() - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
As of release 0.96 (HBASE-5453). This will be removed in HBase 2.0.0. Used by Writables and Writables are going away.
HTableDescriptor(TableName) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Construct a table descriptor specifying a TableName object
HTableDescriptor(byte[]) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
HTableDescriptor(String) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
HTableDescriptor(HTableDescriptor) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Construct a table descriptor by cloning the descriptor passed as a parameter.
HTableDescriptor(TableName, HTableDescriptor) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Construct a table descriptor by cloning the descriptor passed as a parameter but using a different table name.
HTableFactory - Class in org.apache.hadoop.hbase.client
HTableFactory() - Constructor for class org.apache.hadoop.hbase.client.HTableFactory
Deprecated.
 
HTableInterfaceFactory - Interface in org.apache.hadoop.hbase.client
Deprecated.
in favor of ConnectionFactory and Connection.
HTableMultiplexer - Class in org.apache.hadoop.hbase.client
HTableMultiplexer provides a thread-safe non blocking PUT API across all the tables.
HTableMultiplexer(Configuration, int) - Constructor for class org.apache.hadoop.hbase.client.HTableMultiplexer
 
HTableMultiplexer(Connection, Configuration, int) - Constructor for class org.apache.hadoop.hbase.client.HTableMultiplexer
 
HTableMultiplexer.HTableMultiplexerStatus - Class in org.apache.hadoop.hbase.client
HTableMultiplexerStatus keeps track of the current status of the HTableMultiplexer.
HTableMultiplexer.HTableMultiplexerStatus(Map<HRegionLocation, HTableMultiplexer.FlushWorker>) - Constructor for class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 

I

I - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'I'
ID_ATRIBUTE - Static variable in class org.apache.hadoop.hbase.client.OperationWithAttributes
 
ID_SIZE - Static variable in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
 
IdentityTableMap - Class in org.apache.hadoop.hbase.mapred
Pass the given key and record as-is to reduce
IdentityTableMap() - Constructor for class org.apache.hadoop.hbase.mapred.IdentityTableMap
constructor
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
Write to table each key, record pair
IdentityTableReduce() - Constructor for class org.apache.hadoop.hbase.mapred.IdentityTableReduce
 
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
 
idx - Variable in class org.apache.hadoop.hbase.types.StructIterator
 
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
 
IMPORT_FORMAT_VER - Static variable in class org.apache.hadoop.hbase.mapreduce.ResultSerialization
 
ImportTsv - Class in org.apache.hadoop.hbase.mapreduce
Tool to import data from a TSV file.
ImportTsv() - Constructor for class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
IN_MEMORY - Static variable in class org.apache.hadoop.hbase.HConstants
 
includeRegionInSplit(byte[], byte[]) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
Test if the given region is to be included in the InputSplit while splitting the regions of a table.
includeRegionInSplit(byte[], byte[]) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Test if the given region is to be included in the InputSplit while splitting the regions of a table.
includeStartRow() - Method in class org.apache.hadoop.hbase.client.Scan
 
includesTimeRange(TimeRange) - Method in class org.apache.hadoop.hbase.io.TimeRange
Check if the range has any overlap with TimeRange
includeStopRow() - Method in class org.apache.hadoop.hbase.client.Scan
 
InclusiveStopFilter - Class in org.apache.hadoop.hbase.filter
A Filter that stops after the given row.
InclusiveStopFilter(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
IncompatibleFilterException - Exception in org.apache.hadoop.hbase.filter
Used to indicate a filter incompatibility
IncompatibleFilterException() - Constructor for exception org.apache.hadoop.hbase.filter.IncompatibleFilterException
constructor
IncompatibleFilterException(String) - Constructor for exception org.apache.hadoop.hbase.filter.IncompatibleFilterException
constructor
Increment - Class in org.apache.hadoop.hbase.client
Used to perform Increment operations on a single row.
Increment(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Increment
Create a Increment operation for the specified row.
Increment(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.client.Increment
Create a Increment operation for the specified row.
Increment(Increment) - Constructor for class org.apache.hadoop.hbase.client.Increment
Copy constructor
increment(Increment) - Method in interface org.apache.hadoop.hbase.client.Table
Increments one or more columns within a single row.
increment(Increment) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
increment() - Method in class org.apache.hadoop.hbase.util.Counter
 
increment() - Method in class org.apache.hadoop.hbase.util.LongAdder
Equivalent to add(1).
incrementBadLineCount(int) - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
 
incrementBadLineCount(int) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
 
incrementBadLineCount(int) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
 
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 interface org.apache.hadoop.hbase.client.Table
incrementColumnValue(byte[], byte[], byte[], long, Durability) - Method in interface org.apache.hadoop.hbase.client.Table
Atomically increments a column value.
incrementColumnValue(byte[], byte[], byte[], long) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
incrementColumnValue(byte[], byte[], byte[], long, Durability) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
incrementIv(byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
 
incrementIv(byte[], int) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
 
INDEX_KEY_MAGIC - Static variable in class org.apache.hadoop.hbase.HConstants
Used as a magic return value while optimized index key feature enabled(HBASE-7845)
indexOf(byte[], byte) - Static method in class org.apache.hadoop.hbase.util.Bytes
Returns the index of the first appearance of the value target in array.
indexOf(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Returns the start position of the first occurrence of the specified target within array, or -1 if there is no such occurrence.
inferBoundaries(TreeMap<byte[], Integer>) - Static method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
 
init(String) - Method in interface org.apache.hadoop.hbase.io.crypto.KeyProvider
Initialize the key provider
init(String) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
 
init() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
Build the scanner.
init() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
Build the scanner.
init() - Method in interface org.apache.hadoop.hbase.mapreduce.VisibilityExpressionResolver
Giving a chance for the initialization.
initCredentials(JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
 
initCredentials(Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
 
initCredentialsForCluster(Job, String) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
initCredentialsForCluster(Job, Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Obtain an authentication token, for the specified cluster, on behalf of the current user and add it to the credentials for the given map reduce job.
INITIAL_MAX_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.io.TimeRange
 
INITIAL_MIN_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.io.TimeRange
 
initialChore() - Method in class org.apache.hadoop.hbase.ScheduledChore
Override to run a task before we start looping.
initialize(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormat
 
initialize(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Handle subclass specific set up.
initialize(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
 
initialize(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Handle subclass specific set up.
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
Initializes the reader.
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
Build the scanner.
initializeTable(Connection, TableName) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Allows subclasses to initialize the table information.
initializeTable(Connection, TableName) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Allows subclasses to initialize the table information.
initJob(String, String, String, Class<? extends TableMap>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
Use this before submitting a TableMap job.
initJob(String, String, Class<? extends TableMap>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.IdentityTableMap
Use this before submitting a TableMap job.
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.
initMultiTableSnapshotMapperJob(Map<String, Collection<Scan>>, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean, Path) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Sets up the job for reading from one or more multiple table snapshots, with one or more scans per snapshot.
initMultiTableSnapshotMapperJob(Map<String, Collection<Scan>>, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Path) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Sets up the job for reading from one or more table snapshots, with one or more scans per snapshot.
initTableMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
 
initTableMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(TableName, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(byte[], Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, boolean, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(byte[], Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(byte[], Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(List<Scan>, Class<? extends TableMapper>, Class<?>, Class<?>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a Multi TableMap job.
initTableMapperJob(List<Scan>, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a Multi TableMap job.
initTableMapperJob(List<Scan>, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a Multi TableMap job.
initTableReduceJob(String, Class<? extends TableReduce>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Use this before submitting a TableReduce job.
initTableReduceJob(String, Class<? extends TableReduce>, JobConf, Class) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Use this before submitting a TableReduce job.
initTableReduceJob(String, Class<? extends TableReduce>, JobConf, Class, boolean) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
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.
initTableReducerJob(String, Class<? extends TableReducer>, Job, Class, String, String, String) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableReduce job.
initTableReducerJob(String, Class<? extends TableReducer>, Job, Class, String, String, String, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableReduce job.
initTableSnapshotMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean, Path) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Sets up the job for reading from a table snapshot.
initTableSnapshotMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean, Path, RegionSplitter.SplitAlgorithm, int) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Sets up the job for reading from a table snapshot.
initTableSnapshotMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Path) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Sets up the job for reading from a table snapshot.
initTableSnapshotMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Path, RegionSplitter.SplitAlgorithm, int) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Sets up the job for reading from a table snapshot.
INPUT_AUTOBALANCE_MAXSKEWRATIO - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Deprecated.
INPUT_TABLE - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Job parameter that specifies the input table.
inputStreamFromByteRange(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.types.PBType
Create a CodedInputStream from a PositionedByteRange.
instantiateFilter(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
Create a Filter to apply to all incoming keys (KeyValues) to optionally not include in the job output
InterfaceAudience - Class in org.apache.hadoop.hbase.classification
Annotation to inform users of a package, class or method's intended audience.
InterfaceStability - Class in org.apache.hadoop.hbase.classification
Annotation to inform users of how much to rely on a particular package, class or method not changing over time.
InterfaceStability() - Constructor for class org.apache.hadoop.hbase.classification.InterfaceStability
 
intFitsIn(int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Check how many bytes is required to store value.
intValue() - Method in class org.apache.hadoop.hbase.util.LongAdder
Returns the LongAdder.sum() as an int after a narrowing primitive conversion.
INVALID_REGION_NAME_FORMAT_MESSAGE - Static variable in class org.apache.hadoop.hbase.HRegionInfo
 
InvalidFamilyOperationException - Exception in org.apache.hadoop.hbase
Thrown if a request is table schema modification is requested but made for an invalid family name.
InvalidFamilyOperationException() - Constructor for exception org.apache.hadoop.hbase.InvalidFamilyOperationException
default constructor
InvalidFamilyOperationException(String) - Constructor for exception org.apache.hadoop.hbase.InvalidFamilyOperationException
Constructor
InvalidFamilyOperationException(Exception) - Constructor for exception org.apache.hadoop.hbase.InvalidFamilyOperationException
Constructor taking another exception.
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
IS_META - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Used by rest interface to access this metadata attribute which denotes if it is a catalog table, either hbase:meta or -ROOT-
IS_ROOT - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Used by rest interface to access this metadata attribute which denotes if the table is a -ROOT- region or not
isAborted() - Method in interface org.apache.hadoop.hbase.client.Admin
 
isAllTime() - Method in class org.apache.hadoop.hbase.io.TimeRange
Check if it is for all time
isAscendingOrder() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
 
isAutoFlush() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
isBalancerEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
Query the current state of the balancer
isBalancerOn() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
isBlobCopy(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses BlobCopy encoding, false otherwise.
isBlobVar(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses BlobVar encoding, false otherwise.
isBlockCacheEnabled() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
isCacheBloomsOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
isCacheDataInL1() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
isCacheDataOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
isCacheIndexesOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
isCatalogJanitorEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
Query on the catalog janitor state (Enabled/Disabled?)
isCheckExistenceOnly() - Method in class org.apache.hadoop.hbase.client.Get
 
isChoreScheduled(ScheduledChore) - Method in class org.apache.hadoop.hbase.ChoreService
 
isCleanerChoreEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
Query on the cleaner chore state (Enabled/Disabled?)
isClosed() - Method in interface org.apache.hadoop.hbase.client.Connection
Returns whether the connection is closed or not.
isClosed() - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
 
isClosestRowBefore() - Method in class org.apache.hadoop.hbase.client.Get
 
isCompactionEnabled() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Check if the compaction enable flag of the table is true.
isCompressTags() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
isCorrectEncoder(DataBlockEncoder, short) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
Check if given encoder has this id.
isCursor() - Method in class org.apache.hadoop.hbase.client.Result
Return true if this Result is a cursor to tell users where the server has scanned.
isDeadServer(ServerName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
isDelete(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
isDelete(byte) - Static method in class org.apache.hadoop.hbase.CellUtil
 
isDeleteColumnOrFamily(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
isDeleteColumns(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
isDeleteColumnVersion(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
isDeleteFamily(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
isDeleteFamilyVersion(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
isDeleteType(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
isDoNotRetry() - Method in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
 
isEmpty() - Method in class org.apache.hadoop.hbase.client.Mutation
Method to check if the familyMap is empty
isEmpty() - Method in class org.apache.hadoop.hbase.client.Result
Check if the underlying Cell [] is empty or not
isEmpty() - Method in class org.apache.hadoop.hbase.rest.client.Cluster
 
isEmpty() - Method in interface org.apache.hadoop.hbase.util.ByteRange
 
isEncodedValue(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Returns true when src appears to be positioned an encoded value, false otherwise.
isEvictBlocksOnClose() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
isFailed() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.Filter
Check that given column family is essential for filter to check row.
isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
The only CF this filter needs is given column family.
isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
isFixedFloat32(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses fixed-width Float32 encoding, false otherwise.
isFixedFloat64(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses fixed-width Float64 encoding, false otherwise.
isFixedInt16(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses fixed-width Int16 encoding, false otherwise.
isFixedInt32(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses fixed-width Int32 encoding, false otherwise.
isFixedInt64(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses fixed-width Int64 encoding, false otherwise.
isFixedInt8(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses fixed-width Int8 encoding, false otherwise.
isFullServerName(String) - Static method in class org.apache.hadoop.hbase.ServerName
 
isGetScan() - Method in class org.apache.hadoop.hbase.client.Scan
 
isGroupPrincipal(String) - Static method in class org.apache.hadoop.hbase.AuthUtil
Returns whether or not the given name should be interpreted as a group principal.
isGuaranteedClientSideOnly() - Method in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
 
isHBaseSecurityEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.security.User
Returns whether or not secure authentication is enabled for HBase.
isInitialChoreComplete() - Method in class org.apache.hadoop.hbase.ScheduledChore
 
isInMemory() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
isLegalFamilyName(byte[]) - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
 
isLegalFullyQualifiedTableName(byte[]) - Static method in class org.apache.hadoop.hbase.TableName
Check passed byte array, "tableName", is legal user-space table name.
isLegalNamespaceName(byte[]) - Static method in class org.apache.hadoop.hbase.TableName
 
isLegalNamespaceName(byte[], int, int) - Static method in class org.apache.hadoop.hbase.TableName
Valid namespace characters are [a-zA-Z_0-9]
isLegalTableQualifierName(byte[]) - Static method in class org.apache.hadoop.hbase.TableName
 
isLegalTableQualifierName(byte[], boolean) - Static method in class org.apache.hadoop.hbase.TableName
 
isLegalTableQualifierName(byte[], int, int) - Static method in class org.apache.hadoop.hbase.TableName
Qualifier names can only contain 'word' characters [a-zA-Z_0-9] or '_', '.' or '-'.
isLegalTableQualifierName(byte[], int, int, boolean) - Static method in class org.apache.hadoop.hbase.TableName
 
isLocal(Configuration) - Static method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
isMasterInMaintenanceMode() - Method in interface org.apache.hadoop.hbase.client.Admin
Check whether Master is in maintenance mode
isMasterRunning() - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
isMaxColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
isMetaRegion() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
isMetaRegion() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Checks if this table is hbase:meta region.
isMetaTable() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
isMetaTable() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Checks if the table is a hbase:meta table
isMinColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
isNeedCursorResult() - Method in class org.apache.hadoop.hbase.client.Scan
 
isNormalizationEnabled() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Check if normalization enable flag of the table is true.
isNormalizerEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
Query the current state of the region normalizer
isNull() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
 
isNull(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src is null, false otherwise.
isNullable() - Method in interface org.apache.hadoop.hbase.types.DataType
Indicates whether this instance supports encoding null values.
isNullable() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
 
isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedBytesBase
 
isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
 
isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
 
isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedInt16
 
isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedInt32
 
isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedInt64
 
isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedInt8
 
isNullable() - Method in class org.apache.hadoop.hbase.types.PBType
 
isNullable() - Method in class org.apache.hadoop.hbase.types.RawByte
 
isNullable() - Method in class org.apache.hadoop.hbase.types.RawBytes
 
isNullable() - Method in class org.apache.hadoop.hbase.types.RawDouble
 
isNullable() - Method in class org.apache.hadoop.hbase.types.RawFloat
 
isNullable() - Method in class org.apache.hadoop.hbase.types.RawInteger
 
isNullable() - Method in class org.apache.hadoop.hbase.types.RawLong
 
isNullable() - Method in class org.apache.hadoop.hbase.types.RawShort
 
isNullable() - Method in class org.apache.hadoop.hbase.types.RawString
 
isNullable() - Method in class org.apache.hadoop.hbase.types.Struct
 
isNullable() - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
 
isNullable() - Method in class org.apache.hadoop.hbase.types.Union2
 
isNullable() - Method in class org.apache.hadoop.hbase.types.Union3
 
isNullable() - Method in class org.apache.hadoop.hbase.types.Union4
 
isNumeric(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses Numeric encoding, false otherwise.
isNumericInfinite(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses Numeric encoding and is Infinite, false otherwise.
isNumericNaN(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses Numeric encoding and is NaN, false otherwise.
isNumericZero(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses Numeric encoding and is 0, false otherwise.
isOffline() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
IsolationLevel - Enum in org.apache.hadoop.hbase.client
Specify Isolation levels in Scan operations.
isOrderPreserving() - Method in interface org.apache.hadoop.hbase.types.DataType
Indicates whether this instance writes encoded byte[]'s which preserve the natural sort order of the unencoded value.
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.OrderedBytesBase
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.PBType
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawByte
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawBytes
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawDouble
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawFloat
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawInteger
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawLong
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawShort
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawString
 
isOrderPreserving - Variable in class org.apache.hadoop.hbase.types.Struct
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.Struct
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.Union2
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.Union3
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.Union4
 
isPartial() - Method in class org.apache.hadoop.hbase.client.Result
Deprecated.
the word 'partial' ambiguous, use Result.mayHaveMoreCellsInRow() instead. Deprecated since 1.4.0.
isPrefetchBlocksOnOpen() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
isProcedureFinished(String, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.client.Admin
Check the current state of the specified procedure.
isProcedureOwner(ProcedureInfo, User) - Static method in class org.apache.hadoop.hbase.ProcedureInfo
Check if the user is this procedure's owner
isQuoteUnescaped(byte[], int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Returns a boolean indicating whether the quote