| Package | Description | 
|---|---|
| org.apache.hadoop.hbase | |
| org.apache.hadoop.hbase.client | Provides HBase Client | 
| org.apache.hadoop.hbase.client.coprocessor | Provides client classes for invoking Coprocessor RPC protocols | 
| org.apache.hadoop.hbase.exceptions | |
| org.apache.hadoop.hbase.filter | Provides row-level filters applied to HRegion scan results during calls to
  ResultScanner.next(). | 
| org.apache.hadoop.hbase.io | |
| org.apache.hadoop.hbase.mapred | Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility | 
| org.apache.hadoop.hbase.mapreduce | Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility | 
| org.apache.hadoop.hbase.regionserver | |
| org.apache.hadoop.hbase.rest | HBase REST | 
| org.apache.hadoop.hbase.rest.client | |
| org.apache.hadoop.hbase.util | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ClockOutOfSyncExceptionThis exception is thrown by the master when a region server clock skew is
 too high. | 
| class  | DoNotRetryIOExceptionSubclass if exception is not meant to be retried: e.g. | 
| class  | DroppedSnapshotExceptionThrown during flush if the possibility snapshot content was not properly
 persisted into store files. | 
| class  | HBaseConfigurationAdds HBase configuration files to a Configuration | 
| class  | HConstantsHConstants holds a bunch of HBase-related constants | 
| class  | MasterNotRunningExceptionThrown if the master is not running | 
| class  | NamespaceExistExceptionThrown when a namespace exists but should not | 
| class  | NamespaceNotFoundExceptionThrown when a namespace can not be located | 
| class  | NotAllMetaRegionsOnlineExceptionThrown when an operation requires the root and all meta regions to be online | 
| class  | NotServingRegionExceptionThrown by a region server if it is sent a request for a region it is not
 serving. | 
| class  | PleaseHoldExceptionThis exception is thrown by the master when a region server was shut down and
 restarted so fast that the master still hasn't processed the server shutdown
 of the first instance, or when master is initializing and client call admin
 operations, or when an operation is performed on a region server that is still starting. | 
| class  | RegionExceptionThrown when something happens related to region handling. | 
| class  | TableExistsExceptionThrown when a table exists but should not | 
| class  | TableNotDisabledExceptionThrown if a table should be offline but is not | 
| class  | TableNotEnabledExceptionThrown if a table should be enabled but is not | 
| class  | TableNotFoundExceptionThrown when a table can not be located | 
| class  | UnknownRegionExceptionThrown when we are asked to operate on a region we know nothing about. | 
| class  | UnknownScannerExceptionThrown if a region server is passed an unknown scanner id. | 
| class  | YouAreDeadExceptionThis exception is thrown by the master when a region server reports and is
 already being processed as dead. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AppendPerforms Append operations on a single row. | 
| interface  | Attributes | 
| class  | ClientScannerImplements the scanner interface for the HBase client. | 
| class  | DeleteUsed to perform Delete operations on a single row. | 
| class  | GetUsed to perform Get operations on a single row. | 
| interface  | HConnectionA cluster connection. | 
| class  | HTableUsed to communicate with a single HBase table. | 
| class  | HTableFactoryDeprecated. 
 as of 0.98.1. See  HConnectionManager.createConnection(Configuration). | 
| interface  | HTableInterfaceUsed to communicate with a single HBase table. | 
| interface  | HTableInterfaceFactoryDefines methods to create new HTableInterface. | 
| class  | IncrementUsed to perform Increment operations on a single row. | 
| class  | IsolationLevelSpecify Isolation levels in Scan operations. | 
| class  | NoServerForRegionExceptionThrown when no region server can be found for a region | 
| class  | PutUsed to perform Put operations for a single row. | 
| class  | Result | 
| interface  | ResultScannerInterface for client-side scanning. | 
| class  | RetriesExhaustedExceptionException thrown by HTable methods when an attempt to do something (like
 commit changes) fails after a bunch of retries. | 
| class  | RetriesExhaustedWithDetailsExceptionThis subclass of  RetriesExhaustedExceptionis thrown when we have more information about which rows were causing which
 exceptions on what servers. | 
| interface  | RowHas a row. | 
| class  | ScanUsed to perform Scan operations. | 
| class  | ScannerTimeoutExceptionThrown when a scanner has timed out. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | BatchA collection of interfaces and utilities used for interacting with custom RPC
 interfaces exposed by Coprocessors. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | MergeRegionExceptionThrown when something is wrong in trying to merge two regions. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | BinaryComparatorA binary comparator which lexicographically compares against the specified
 byte array using  Bytes.compareTo(byte[], byte[]). | 
| class  | BinaryPrefixComparatorA comparator which compares against a specified byte array, but only compares
 up to the length of this byte array. | 
| class  | BitComparatorA bit comparator which performs the specified bitwise operation on each of the bytes
 with the specified byte array. | 
| static class  | BitComparator.BitwiseOpBit operators. | 
| class  | ByteArrayComparableBase class for byte array comparators | 
| class  | ColumnCountGetFilterSimple filter that returns first N columns on row only. | 
| class  | ColumnPaginationFilterA filter, based on the ColumnCountGetFilter, takes two arguments: limit and offset. | 
| class  | ColumnPrefixFilterThis filter is used for selecting only those keys with columns that matches
 a particular prefix. | 
| class  | ColumnRangeFilterThis filter is used for selecting only those keys with columns that are
 between minColumn to maxColumn. | 
| class  | CompareFilterThis is a generic filter to be used to filter by comparison. | 
| static class  | CompareFilter.CompareOpComparison operators. | 
| class  | DependentColumnFilterA 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 | 
| class  | FamilyFilterThis filter is used to filter based on the column family. | 
| class  | FilterInterface for row and column filters directly applied within the regionserver. | 
| static class  | Filter.ReturnCodeReturn codes for filterValue(). | 
| class  | FilterListImplementation of  Filterthat represents an ordered List of Filters
 which will be evaluated with a specified boolean operatorFilterList.Operator.MUST_PASS_ALL(AND) orFilterList.Operator.MUST_PASS_ONE(OR). | 
| static class  | FilterList.Operatorset operator | 
| class  | FirstKeyOnlyFilterA filter that will only return the first KV from each row. | 
| class  | FirstKeyValueMatchingQualifiersFilterThe filter looks for the given columns in KeyValue. | 
| class  | InclusiveStopFilterA Filter that stops after the given row. | 
| class  | IncompatibleFilterExceptionUsed to indicate a filter incompatibility | 
| class  | InvalidRowFilterExceptionUsed to indicate an invalid RowFilter. | 
| class  | KeyOnlyFilterA filter that will only return the key component of each KV (the value will
 be rewritten as empty). | 
| class  | MultipleColumnPrefixFilterThis filter is used for selecting only those keys with columns that matches
 a particular prefix. | 
| class  | NullComparatorA binary comparator which lexicographically compares against the specified
 byte array using  Bytes.compareTo(byte[], byte[]). | 
| class  | PageFilterImplementation of Filter interface that limits results to a specific page
 size. | 
| class  | ParseConstantsParseConstants holds a bunch of constants related to parsing Filter Strings
 Used by  ParseFilter | 
| class  | ParseFilterThis class allows a user to specify a filter via a string
 The string is parsed using the methods of this class and
 a filter object is constructed. | 
| class  | PrefixFilterPass results that have same row prefix. | 
| class  | QualifierFilterThis filter is used to filter based on the column qualifier. | 
| class  | RandomRowFilterA filter that includes rows based on a chance. | 
| class  | RegexStringComparatorThis comparator is for use with  CompareFilterimplementations, such
 asRowFilter,QualifierFilter, andValueFilter, for
 filtering based on the value of a given column. | 
| class  | RowFilterThis filter is used to filter based on the key. | 
| class  | SingleColumnValueExcludeFilterA  Filterthat checks a single column value, but does not emit the
 tested column. | 
| class  | SingleColumnValueFilterThis filter is used to filter cells based on value. | 
| class  | SkipFilterA wrapper filter that filters an entire row if any of the Cell checks do
 not pass. | 
| class  | SubstringComparatorThis comparator is for use with SingleColumnValueFilter, for filtering based on
 the value of a given column. | 
| class  | TimestampsFilterFilter that returns only cells whose timestamp (version) is
 in the specified list of timestamps (versions). | 
| class  | ValueFilterThis filter is used to filter based on column value. | 
| class  | WhileMatchFilterA wrapper filter that returns true from  WhileMatchFilter.filterAllRemaining()as soon
 as the wrapped filtersFilter.filterRowKey(byte[], int, int),Filter.filterKeyValue(org.apache.hadoop.hbase.Cell),Filter.filterRow()orFilter.filterAllRemaining()methods
 returns true. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ImmutableBytesWritableA byte sequence that is usable as a key or value. | 
| class  | TimeRangeRepresents an interval of version timestamps. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | DriverDeprecated.  | 
| class  | GroupingTableMapDeprecated.  | 
| class  | HRegionPartitioner<K2,V2>Deprecated.  | 
| class  | IdentityTableMapDeprecated.  | 
| class  | IdentityTableReduceDeprecated.  | 
| class  | RowCounterDeprecated.  | 
| class  | TableInputFormatDeprecated.  | 
| class  | TableInputFormatBaseDeprecated.  | 
| interface  | TableMap<K extends org.apache.hadoop.io.WritableComparable<? super K>,V>Deprecated.  | 
| class  | TableMapReduceUtilDeprecated.  | 
| class  | TableOutputFormatDeprecated.  | 
| class  | TableRecordReaderDeprecated.  | 
| class  | TableRecordReaderImplDeprecated.  | 
| interface  | TableReduce<K extends org.apache.hadoop.io.WritableComparable,V>Deprecated.  | 
| class  | TableSplitDeprecated.  | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CellCounterA job with a a map and reduce phase to count cells in a table. | 
| class  | CopyTableTool used to copy a table to another one which can be on a different setup. | 
| class  | DriverDriver for hbase mapreduce jobs. | 
| class  | ExportExport an HBase table. | 
| class  | GroupingTableMapperExtract grouping columns from input record. | 
| class  | HFileOutputFormatDeprecated. 
 use  HFileOutputFormat2instead. | 
| class  | HRegionPartitioner<KEY,VALUE>This is used to partition the output keys into groups of keys. | 
| class  | IdentityTableMapperPass the given key and record as-is to the reduce phase. | 
| class  | IdentityTableReducer | 
| class  | ImportImport data written by  Export. | 
| class  | ImportTsvTool to import data from a TSV file. | 
| class  | KeyValueSortReducerEmits sorted KeyValues. | 
| class  | LoadIncrementalHFilesTool to load the output of HFileOutputFormat into an existing table. | 
| class  | MultiTableOutputFormat
 Hadoop output format that writes to one or more HBase tables. | 
| class  | PutSortReducerEmits sorted Puts. | 
| class  | RowCounterA job with a just a map phase to count rows. | 
| class  | SimpleTotalOrderPartitioner<VALUE>A partitioner that takes start and end keys and uses bigdecimal to figure
 which reduce a key belongs to. | 
| class  | TableInputFormatConvert HBase tabular data into a format that is consumable by Map/Reduce. | 
| class  | TableInputFormatBaseA base for  TableInputFormats. | 
| class  | TableMapper<KEYOUT,VALUEOUT>Extends the base  Mapperclass to add the required input key
 and value classes. | 
| class  | TableMapReduceUtilUtility for  TableMapperandTableReducer | 
| class  | TableOutputCommitterSmall committer class that does not do anything. | 
| class  | TableOutputFormat<KEY>Convert Map/Reduce output and write it to an HBase table. | 
| class  | TableRecordReaderIterate over an HBase table data, return (ImmutableBytesWritable, Result)
 pairs. | 
| class  | TableRecordReaderImplIterate over an HBase table data, return (ImmutableBytesWritable, Result)
 pairs. | 
| class  | TableReducer<KEYIN,VALUEIN,KEYOUT>Extends the basic  Reducerclass to add the required key and
 value input/output classes. | 
| class  | TsvImporterMapperWrite table content out to files in hdfs. | 
| class  | WALPlayerA tool to replay WAL files as a M/R job. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | RegionAlreadyInTransitionExceptionThis exception is thrown when a region server is asked to open or close
 a region but it's already processing it | 
| class  | WrongRegionExceptionThrown when a request contains a key which is not part of this region | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | ConstantsCommon constants for org.apache.hadoop.hbase.rest | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ClientA wrapper around HttpClient which provides some useful function and
 semantics for interacting with the REST gateway. | 
| class  | ClusterA list of 'host:port' addresses of HTTP servers operating as a single
 entity, for example multiple redundant web service gateways. | 
| class  | RemoteAdmin | 
| class  | RemoteHTableHTable interface to remote tables accessed via REST gateway | 
| class  | ResponseThe HTTP result code, response headers, and body of a HTTP response. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | Base64Encodes and decodes to and from Base64 notation. | 
| static class  | Base64.Base64InputStreamA  Base64.Base64InputStreamwill read data from another
 InputStream, given in the constructor, and
 encode/decode to/from Base64 notation on the fly. | 
| class  | BytesUtility class that handles byte arrays, conversions to/from other types,
 comparisons, hash code generation, manufacturing keys for HashMaps or
 HashSets, etc. | 
| static class  | Bytes.ByteArrayComparatorByte array comparator class. | 
| static class  | Bytes.RowEndKeyComparatorA  Bytes.ByteArrayComparatorthat treats the empty array as the largest value. | 
| class  | HashThis class represents a common API for hashing functions. | 
| class  | HashedBytesThis class encapsulates a byte array and overrides hashCode and equals so
 that it's identity is based on the data rather than the array instance. | 
| class  | JenkinsHashProduces 32-bit hash for hash table lookup. | 
| class  | JvmVersionCertain JVM versions are known to be unstable with HBase. | 
| class  | MD5HashUtility class for MD5
 MD5 hash produces a 128-bit digest. | 
| class  | MurmurHashThis is a very fast, non-cryptographic hash suitable for general hash-based
 lookup. | 
| class  | Pair<T1,T2>A generic class for pairs. | 
| class  | PairOfSameType<T>A generic, immutable class for pairs of objects both of type  T. | 
| Constructor and Description | 
|---|
| Base64.Base64OutputStream(OutputStream out,
                         int options)Constructs a  Base64.Base64OutputStreamin either ENCODE or DECODE mode. | 
Copyright © 2014 The Apache Software Foundation. All rights reserved.