Package org.apache.hadoop.hbase.filter


package org.apache.hadoop.hbase.filter
Provides row-level filters applied to HRegion scan results during calls to ResultScanner.next().

Filters run the extent of a table unless you wrap your filter in a WhileMatchFilter. The latter returns as soon as the filter stops matching.

Do not rely on filters carrying state across rows; its not reliable in current hbase as we have no handlers in place for when regions split, close or server crashes.

  • Class
    Description
    org.apache.hadoop.hbase.filter.BigDecimalComparator
    A BigDecimal comparator which numerical compares against the specified byte array
    org.apache.hadoop.hbase.filter.BinaryComparator
    A binary comparator which lexicographically compares against the specified byte array using Bytes.compareTo(byte[], byte[]).
    org.apache.hadoop.hbase.filter.BinaryComponentComparator
    A comparator which compares against a specified byte array, but only compares specific portion of the byte array.
    org.apache.hadoop.hbase.filter.BinaryPrefixComparator
    A comparator which compares against a specified byte array, but only compares up to the length of this byte array.
    org.apache.hadoop.hbase.filter.BitComparator
    A bit comparator which performs the specified bitwise operation on each of the bytes with the specified byte array.
    org.apache.hadoop.hbase.filter.BitComparator.BitwiseOp
    Bit operators.
    org.apache.hadoop.hbase.filter.ByteArrayComparable
    Base class for byte array comparators
    org.apache.hadoop.hbase.filter.ColumnCountGetFilter
    Simple filter that returns first N columns on row only.
    org.apache.hadoop.hbase.filter.ColumnPaginationFilter
    A filter, based on the ColumnCountGetFilter, takes two arguments: limit and offset.
    org.apache.hadoop.hbase.filter.ColumnPrefixFilter
    This filter is used for selecting only those keys with columns that matches a particular prefix.
    org.apache.hadoop.hbase.filter.ColumnRangeFilter
    This filter is used for selecting only those keys with columns that are between minColumn to maxColumn.
    org.apache.hadoop.hbase.filter.ColumnValueFilter
    Different from SingleColumnValueFilter which returns an entire row when specified condition is matched, ColumnValueFilter return the matched cell only.
    org.apache.hadoop.hbase.filter.CompareFilter
    This is a generic filter to be used to filter by comparison.
    org.apache.hadoop.hbase.filter.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
    org.apache.hadoop.hbase.filter.FamilyFilter
    This filter is used to filter based on the column family.
    org.apache.hadoop.hbase.filter.Filter
    Interface for row and column filters directly applied within the regionserver.
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    Return codes for filterValue().
    org.apache.hadoop.hbase.filter.FilterAllFilter
     
    org.apache.hadoop.hbase.filter.FilterBase
    Abstract base class to help you implement new Filters.
    org.apache.hadoop.hbase.filter.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).
    org.apache.hadoop.hbase.filter.FilterList.Operator
    set operator
    org.apache.hadoop.hbase.filter.FilterListBase
    Base class for FilterList.
    org.apache.hadoop.hbase.filter.FilterListWithAND
    FilterListWithAND represents an ordered list of filters which will be evaluated with an AND operator.
    org.apache.hadoop.hbase.filter.FilterListWithOR
    FilterListWithOR represents an ordered list of filters which will be evaluated with an OR operator.
    org.apache.hadoop.hbase.filter.FilterWrapper
    This is a Filter wrapper class which is used in the server side.
    org.apache.hadoop.hbase.filter.FilterWrapper.FilterRowRetCode
     
    org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
    A filter that will only return the first KV from each row.
    org.apache.hadoop.hbase.filter.FuzzyRowFilter
    This is optimized version of a standard FuzzyRowFilter Filters data based on fuzzy row key.
    org.apache.hadoop.hbase.filter.HintingFilter
    Marker interface for filters that may return SEEK_NEXT_USING_HINT.
    org.apache.hadoop.hbase.filter.InclusiveStopFilter
    A Filter that stops after the given row.
    org.apache.hadoop.hbase.filter.IncompatibleFilterException
    Used to indicate a filter incompatibility
    org.apache.hadoop.hbase.filter.InvalidRowFilterException
    Used to indicate an invalid RowFilter.
    org.apache.hadoop.hbase.filter.KeyOnlyFilter
    A filter that will only return the key component of each KV (the value will be rewritten as empty).
    org.apache.hadoop.hbase.filter.LongComparator
    A long comparator which numerical compares against the specified byte array
    org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
    This filter is used for selecting only those keys with columns that matches a particular prefix.
    org.apache.hadoop.hbase.filter.MultiRowRangeFilter
    Filter to support scan multiple row key ranges.
    org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
     
    org.apache.hadoop.hbase.filter.NullComparator
    A binary comparator which lexicographically compares against the specified byte array using Bytes.compareTo(byte[], byte[]).
    org.apache.hadoop.hbase.filter.PageFilter
    Implementation of Filter interface that limits results to a specific page size.
    org.apache.hadoop.hbase.filter.ParseConstants
    ParseConstants holds a bunch of constants related to parsing Filter Strings Used by ParseFilter
    org.apache.hadoop.hbase.filter.ParseFilter
    This 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.
    org.apache.hadoop.hbase.filter.PrefixFilter
    Pass results that have same row prefix.
    org.apache.hadoop.hbase.filter.QualifierFilter
    This filter is used to filter based on the column qualifier.
    org.apache.hadoop.hbase.filter.RandomRowFilter
    A filter that includes rows based on a chance.
    org.apache.hadoop.hbase.filter.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.
    org.apache.hadoop.hbase.filter.RegexStringComparator.EngineType
    Engine implementation type (default=JAVA)
    org.apache.hadoop.hbase.filter.RowFilter
    This filter is used to filter based on the key.
    org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
    A Filter that checks a single column value, but does not emit the tested column.
    org.apache.hadoop.hbase.filter.SingleColumnValueFilter
    This filter is used to filter cells based on value.
    org.apache.hadoop.hbase.filter.SkipFilter
    A wrapper filter that filters an entire row if any of the Cell checks do not pass.
    org.apache.hadoop.hbase.filter.SubstringComparator
    This comparator is for use with SingleColumnValueFilter, for filtering based on the value of a given column.
    org.apache.hadoop.hbase.filter.TimestampsFilter
    Filter that returns only cells whose timestamp (version) is in the specified list of timestamps (versions).
    org.apache.hadoop.hbase.filter.ValueFilter
    This filter is used to filter based on column value.
    org.apache.hadoop.hbase.filter.WhileMatchFilter
    A wrapper filter that returns true from WhileMatchFilter.filterAllRemaining() as soon as the wrapped filters Filter.filterRowKey(Cell), Filter.filterCell(org.apache.hadoop.hbase.Cell), Filter.filterRow() or Filter.filterAllRemaining() methods returns true.