| Package | Description | 
|---|---|
| org.apache.hadoop.hbase.client | 
 Provides HBase Client 
 | 
| org.apache.hadoop.hbase.filter | 
 Provides row-level filters applied to HRegion scan results during calls to
  
ResultScanner.next(). | 
| org.apache.hadoop.hbase.mapred | 
 Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods. 
 | 
| org.apache.hadoop.hbase.mapreduce | 
 Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods. 
 | 
| Class and Description | 
|---|
| CompareFilter.CompareOp
 Deprecated. 
 
since 2.0.0. Will be removed in 3.0.0. Use  
CompareOperator instead. | 
| Filter
 Interface for row and column filters directly applied within the regionserver. 
 | 
| Class and Description | 
|---|
| BigDecimalComparator
 A BigDecimal comparator which numerical compares against the specified byte array 
 | 
| BinaryComparator
 A binary comparator which lexicographically compares against the specified
 byte array using  
Bytes.compareTo(byte[], byte[]). | 
| BinaryComponentComparator
 A comparator which compares against a specified byte array, but only
 compares specific portion of the byte array. 
 | 
| BinaryPrefixComparator
 A comparator which compares against a specified byte array, but only compares
 up to the length of this byte array. 
 | 
| BitComparator
 A bit comparator which performs the specified bitwise operation on each of the bytes
 with the specified byte array. 
 | 
| BitComparator.BitwiseOp
 Bit operators. 
 | 
| ByteArrayComparable
 Base class for byte array comparators 
 | 
| ColumnCountGetFilter
 Simple filter that returns first N columns on row only. 
 | 
| ColumnPaginationFilter
 A filter, based on the ColumnCountGetFilter, takes two arguments: limit and offset. 
 | 
| ColumnPrefixFilter
 This filter is used for selecting only those keys with columns that matches
 a particular prefix. 
 | 
| ColumnRangeFilter
 This filter is used for selecting only those keys with columns that are
 between minColumn to maxColumn. 
 | 
| ColumnValueFilter
 Different from  
SingleColumnValueFilter which returns an entire row
 when specified condition is matched, ColumnValueFilter return the matched cell only. | 
| CompareFilter
 This is a generic filter to be used to filter by comparison. 
 | 
| CompareFilter.CompareOp
 Deprecated. 
 
since 2.0.0. Will be removed in 3.0.0. Use  
CompareOperator instead. | 
| DependentColumnFilter
 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 
 | 
| FamilyFilter
 
 This filter is used to filter based on the column family. 
 | 
| Filter
 Interface for row and column filters directly applied within the regionserver. 
 | 
| Filter.ReturnCode
 Return codes for filterValue(). 
 | 
| FilterList
 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.Operator
 set operator 
 | 
| FirstKeyOnlyFilter
 A filter that will only return the first KV from each row. 
 | 
| FirstKeyValueMatchingQualifiersFilter
 Deprecated. 
 
Deprecated in 2.0.0 and will be removed in 3.0.0. 
 | 
| FuzzyRowFilter
 This is optimized version of a standard FuzzyRowFilter Filters data based on fuzzy row key. 
 | 
| InclusiveStopFilter
 A Filter that stops after the given row. 
 | 
| KeyOnlyFilter
 A filter that will only return the key component of each KV (the value will
 be rewritten as empty). 
 | 
| LongComparator
 A long comparator which numerical compares against the specified byte array 
 | 
| MultipleColumnPrefixFilter
 This filter is used for selecting only those keys with columns that matches
 a particular prefix. 
 | 
| MultiRowRangeFilter
 Filter to support scan multiple row key ranges. 
 | 
| MultiRowRangeFilter.RowRange | 
| NullComparator
 A binary comparator which lexicographically compares against the specified
 byte array using  
Bytes.compareTo(byte[], byte[]). | 
| PageFilter
 Implementation of Filter interface that limits results to a specific page
 size. 
 | 
| PrefixFilter
 Pass results that have same row prefix. 
 | 
| QualifierFilter
 This filter is used to filter based on the column qualifier. 
 | 
| RandomRowFilter
 A filter that includes rows based on a chance. 
 | 
| RegexStringComparator
 This comparator is for use with  
CompareFilter implementations, such
 as RowFilter, QualifierFilter, and ValueFilter, for
 filtering based on the value of a given column. | 
| RegexStringComparator.EngineType
 Engine implementation type (default=JAVA) 
 | 
| RowFilter
 This filter is used to filter based on the key. 
 | 
| SingleColumnValueExcludeFilter
 A  
Filter that checks a single column value, but does not emit the
 tested column. | 
| SingleColumnValueFilter
 This filter is used to filter cells based on value. 
 | 
| SkipFilter
 A wrapper filter that filters an entire row if any of the Cell checks do
 not pass. 
 | 
| SubstringComparator
 This comparator is for use with SingleColumnValueFilter, for filtering based on
 the value of a given column. 
 | 
| TimestampsFilter
 Filter that returns only cells whose timestamp (version) is
 in the specified list of timestamps (versions). 
 | 
| ValueFilter
 This filter is used to filter based on column value. 
 | 
| WhileMatchFilter
 A wrapper filter that returns true from  
WhileMatchFilter.filterAllRemaining() as soon
 as the wrapped filters Filter.filterRowKey(byte[], int, int),
 Filter.filterCell(org.apache.hadoop.hbase.Cell),
 Filter.filterRow() or
 Filter.filterAllRemaining() methods
 returns true. | 
| Class and Description | 
|---|
| Filter
 Interface for row and column filters directly applied within the regionserver. 
 | 
| Class and Description | 
|---|
| Filter
 Interface for row and column filters directly applied within the regionserver. 
 | 
Copyright © 2007–2021 The Apache Software Foundation. All rights reserved.