Uses of Class
org.apache.hadoop.hbase.filter.Filter

Packages that use org.apache.hadoop.hbase.filter.Filter
Package
Description
 
Provides HBase Client
Table of Contents
Provides row-level filters applied to HRegion scan results during calls to ResultScanner.next().
Provides HBase MapReduce Input/OutputFormats, a table indexing MapReduce job, and utility methods.
Provides HBase MapReduce Input/OutputFormats, a table indexing MapReduce job, and utility methods.
 
 
 
HBase REST
 
  • Uses of org.apache.hadoop.hbase.filter.Filter in org.apache.hadoop.hbase

    Methods in org.apache.hadoop.hbase with parameters of type org.apache.hadoop.hbase.filter.Filter in in
    Modifier and Type
    Method
    Description
    static void
    MetaTableAccessor.scanMeta(org.apache.hadoop.hbase.client.Connection connection, byte[] startRow, byte[] stopRow, org.apache.hadoop.hbase.ClientMetaTableAccessor.QueryType type, org.apache.hadoop.hbase.filter.Filter filter, int maxRows, org.apache.hadoop.hbase.ClientMetaTableAccessor.Visitor visitor)
     
  • Uses of org.apache.hadoop.hbase.filter.Filter in org.apache.hadoop.hbase.client

    Fields in org.apache.hadoop.hbase.client declared as org.apache.hadoop.hbase.filter.Filter in in
    Modifier and Type
    Field
    Description
    protected org.apache.hadoop.hbase.filter.Filter
    Query.filter
     
    Methods in org.apache.hadoop.hbase.client that return org.apache.hadoop.hbase.filter.Filter in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.filter.Filter
    CheckAndMutate.getFilter()
    Returns the filter to check
    org.apache.hadoop.hbase.filter.Filter
    ImmutableScan.getFilter()
     
    org.apache.hadoop.hbase.filter.Filter
    Query.getFilter()
     
    org.apache.hadoop.hbase.filter.Filter
    Scan.getFilter()
    Returns RowFilter
    Methods in org.apache.hadoop.hbase.client with parameters of type org.apache.hadoop.hbase.filter.Filter in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateWithFilterBuilder
    AsyncTable.checkAndMutate(byte[] row, org.apache.hadoop.hbase.filter.Filter filter)
    Deprecated.
    Since 3.0.0, will be removed in 4.0.0.
    default org.apache.hadoop.hbase.client.Table.CheckAndMutateWithFilterBuilder
    Table.checkAndMutate(byte[] row, org.apache.hadoop.hbase.filter.Filter filter)
    Deprecated.
    Since 3.0.0, will be removed in 4.0.0.
    CheckAndMutate.Builder.ifMatches(org.apache.hadoop.hbase.filter.Filter filter)
    Check for match
    org.apache.hadoop.hbase.client.Get
    Get.setFilter(org.apache.hadoop.hbase.filter.Filter filter)
     
    org.apache.hadoop.hbase.client.Scan
    ImmutableScan.setFilter(org.apache.hadoop.hbase.filter.Filter filter)
     
    org.apache.hadoop.hbase.client.Query
    Query.setFilter(org.apache.hadoop.hbase.filter.Filter filter)
    Apply the specified server-side filter when performing the Query.
    org.apache.hadoop.hbase.client.Scan
    Scan.setFilter(org.apache.hadoop.hbase.filter.Filter filter)
     
  • Uses of org.apache.hadoop.hbase.filter.Filter in org.apache.hadoop.hbase.coprocessor

    Methods in org.apache.hadoop.hbase.coprocessor with parameters of type org.apache.hadoop.hbase.filter.Filter in in
    Modifier and Type
    Method
    Description
    default boolean
    RegionObserver.postCheckAndDelete(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, byte[] row, org.apache.hadoop.hbase.filter.Filter filter, org.apache.hadoop.hbase.client.Delete delete, boolean result)
    Deprecated.
    since 3.0.0 and will be removed in 4.0.0.
    default boolean
    RegionObserver.postCheckAndPut(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, byte[] row, org.apache.hadoop.hbase.filter.Filter filter, org.apache.hadoop.hbase.client.Put put, boolean result)
    Deprecated.
    since 3.0.0 and will be removed in 4.0.0.
    default boolean
    RegionObserver.preCheckAndDelete(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, byte[] row, org.apache.hadoop.hbase.filter.Filter filter, org.apache.hadoop.hbase.client.Delete delete, boolean result)
    Deprecated.
    since 3.0.0 and will be removed in 4.0.0.
    default boolean
    RegionObserver.preCheckAndDeleteAfterRowLock(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, byte[] row, org.apache.hadoop.hbase.filter.Filter filter, org.apache.hadoop.hbase.client.Delete delete, boolean result)
    Deprecated.
    since 3.0.0 and will be removed in 4.0.0.
    default boolean
    RegionObserver.preCheckAndPut(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, byte[] row, org.apache.hadoop.hbase.filter.Filter filter, org.apache.hadoop.hbase.client.Put put, boolean result)
    Deprecated.
    since 3.0.0 and will be removed in 4.0.0.
    default boolean
    RegionObserver.preCheckAndPutAfterRowLock(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, byte[] row, org.apache.hadoop.hbase.filter.Filter filter, org.apache.hadoop.hbase.client.Put put, boolean result)
    Deprecated.
    since 3.0.0 and will be removed in 4.0.0.
  • Uses of org.apache.hadoop.hbase.filter.Filter in org.apache.hadoop.hbase.filter

    Subclasses of org.apache.hadoop.hbase.filter.Filter in in org.apache.hadoop.hbase.filter
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.filter.ColumnCountGetFilter
    Simple filter that returns first N columns on row only.
    class 
    org.apache.hadoop.hbase.filter.ColumnPaginationFilter
    A filter, based on the ColumnCountGetFilter, takes two arguments: limit and offset.
    class 
    org.apache.hadoop.hbase.filter.ColumnPrefixFilter
    This filter is used for selecting only those keys with columns that matches a particular prefix.
    class 
    org.apache.hadoop.hbase.filter.ColumnRangeFilter
    This filter is used for selecting only those keys with columns that are between minColumn to maxColumn.
    class 
    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.
    class 
    org.apache.hadoop.hbase.filter.CompareFilter
    This is a generic filter to be used to filter by comparison.
    class 
    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
    class 
    org.apache.hadoop.hbase.filter.FamilyFilter
    This filter is used to filter based on the column family.
    class 
    org.apache.hadoop.hbase.filter.FilterAllFilter
     
    class 
    org.apache.hadoop.hbase.filter.FilterBase
    Abstract base class to help you implement new Filters.
    final class 
    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).
    class 
    org.apache.hadoop.hbase.filter.FilterListBase
    Base class for FilterList.
    class 
    org.apache.hadoop.hbase.filter.FilterListWithAND
    FilterListWithAND represents an ordered list of filters which will be evaluated with an AND operator.
    class 
    org.apache.hadoop.hbase.filter.FilterListWithOR
    FilterListWithOR represents an ordered list of filters which will be evaluated with an OR operator.
    final class 
    org.apache.hadoop.hbase.filter.FilterWrapper
    This is a Filter wrapper class which is used in the server side.
    class 
    org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
    A filter that will only return the first KV from each row.
    class 
    org.apache.hadoop.hbase.filter.FuzzyRowFilter
    This is optimized version of a standard FuzzyRowFilter Filters data based on fuzzy row key.
    class 
    org.apache.hadoop.hbase.filter.InclusiveStopFilter
    A Filter that stops after the given row.
    class 
    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).
    class 
    org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
    This filter is used for selecting only those keys with columns that matches a particular prefix.
    class 
    org.apache.hadoop.hbase.filter.MultiRowRangeFilter
    Filter to support scan multiple row key ranges.
    class 
    org.apache.hadoop.hbase.filter.PageFilter
    Implementation of Filter interface that limits results to a specific page size.
    class 
    org.apache.hadoop.hbase.filter.PrefixFilter
    Pass results that have same row prefix.
    class 
    org.apache.hadoop.hbase.filter.QualifierFilter
    This filter is used to filter based on the column qualifier.
    class 
    org.apache.hadoop.hbase.filter.RandomRowFilter
    A filter that includes rows based on a chance.
    class 
    org.apache.hadoop.hbase.filter.RowFilter
    This filter is used to filter based on the key.
    class 
    org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
    A Filter that checks a single column value, but does not emit the tested column.
    class 
    org.apache.hadoop.hbase.filter.SingleColumnValueFilter
    This filter is used to filter cells based on value.
    class 
    org.apache.hadoop.hbase.filter.SkipFilter
    A wrapper filter that filters an entire row if any of the Cell checks do not pass.
    class 
    org.apache.hadoop.hbase.filter.TimestampsFilter
    Filter that returns only cells whose timestamp (version) is in the specified list of timestamps (versions).
    class 
    org.apache.hadoop.hbase.filter.ValueFilter
    This filter is used to filter based on column value.
    class 
    org.apache.hadoop.hbase.filter.WhileMatchFilter
    A wrapper filter that returns true from WhileMatchFilter.filterAllRemaining() as soon as the wrapped filters filterRowKey(Cell), filterCell(org.apache.hadoop.hbase.Cell), filterRow() or filterAllRemaining() methods returns true.
    Fields in org.apache.hadoop.hbase.filter with type parameters of type org.apache.hadoop.hbase.filter.Filter in in
    Modifier and Type
    Field
    Description
    protected final ArrayList<org.apache.hadoop.hbase.filter.Filter>
    FilterListBase.filters
     
    Methods in org.apache.hadoop.hbase.filter that return org.apache.hadoop.hbase.filter.Filter in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.filter.Filter
    ColumnCountGetFilter.createFilterFromArguments(ArrayList<byte[]> filterArguments)
     
    static org.apache.hadoop.hbase.filter.Filter
    ColumnPaginationFilter.createFilterFromArguments(ArrayList<byte[]> filterArguments)
     
    static org.apache.hadoop.hbase.filter.Filter
    ColumnPrefixFilter.createFilterFromArguments(ArrayList<byte[]> filterArguments)
     
    static org.apache.hadoop.hbase.filter.Filter
    ColumnRangeFilter.createFilterFromArguments(ArrayList<byte[]> filterArguments)
     
    static org.apache.hadoop.hbase.filter.Filter
    ColumnValueFilter.createFilterFromArguments(ArrayList<byte[]> filterArguments)
    Creating this filter by reflection, it is used by ParseFilter,
    static org.apache.hadoop.hbase.filter.Filter
    DependentColumnFilter.createFilterFromArguments(ArrayList<byte[]> filterArguments)
     
    static org.apache.hadoop.hbase.filter.Filter
    FamilyFilter.createFilterFromArguments(ArrayList<byte[]> filterArguments)
     
    static org.apache.hadoop.hbase.filter.Filter
    FilterBase.createFilterFromArguments(ArrayList<byte[]> filterArguments)
    Given the filter's arguments it constructs the filter
    static org.apache.hadoop.hbase.filter.Filter
    FirstKeyOnlyFilter.createFilterFromArguments(ArrayList<byte[]> filterArguments)
     
    static org.apache.hadoop.hbase.filter.Filter
    InclusiveStopFilter.createFilterFromArguments(ArrayList<byte[]> filterArguments)
     
    static org.apache.hadoop.hbase.filter.Filter
    KeyOnlyFilter.createFilterFromArguments(ArrayList<byte[]> filterArguments)
     
    static org.apache.hadoop.hbase.filter.Filter
    MultipleColumnPrefixFilter.createFilterFromArguments(ArrayList<byte[]> filterArguments)
     
    static org.apache.hadoop.hbase.filter.Filter
    PageFilter.createFilterFromArguments(ArrayList<byte[]> filterArguments)
     
    static org.apache.hadoop.hbase.filter.Filter
    PrefixFilter.createFilterFromArguments(ArrayList<byte[]> filterArguments)
     
    static org.apache.hadoop.hbase.filter.Filter
    QualifierFilter.createFilterFromArguments(ArrayList<byte[]> filterArguments)
     
    static org.apache.hadoop.hbase.filter.Filter
    RowFilter.createFilterFromArguments(ArrayList<byte[]> filterArguments)
     
    static org.apache.hadoop.hbase.filter.Filter
    SingleColumnValueExcludeFilter.createFilterFromArguments(ArrayList<byte[]> filterArguments)
     
    static org.apache.hadoop.hbase.filter.Filter
    SingleColumnValueFilter.createFilterFromArguments(ArrayList<byte[]> filterArguments)
     
    static org.apache.hadoop.hbase.filter.Filter
    TimestampsFilter.createFilterFromArguments(ArrayList<byte[]> filterArguments)
     
    static org.apache.hadoop.hbase.filter.Filter
    ValueFilter.createFilterFromArguments(ArrayList<byte[]> filterArguments)
     
    org.apache.hadoop.hbase.filter.Filter
    SkipFilter.getFilter()
     
    org.apache.hadoop.hbase.filter.Filter
    WhileMatchFilter.getFilter()
     
    org.apache.hadoop.hbase.filter.Filter
    ParseFilter.parseFilterString(byte[] filterStringAsByteArray)
    Parses the filterString and constructs a filter using it
    org.apache.hadoop.hbase.filter.Filter
    ParseFilter.parseFilterString(String filterString)
    Parses the filterString and constructs a filter using it
    static org.apache.hadoop.hbase.filter.Filter
    Filter.parseFrom(byte[] pbBytes)
    Concrete implementers can signal a failure condition in their code by throwing an IOException.
    org.apache.hadoop.hbase.filter.Filter
    ParseFilter.parseSimpleFilterExpression(byte[] filterStringAsByteArray)
    Constructs a filter object given a simple filter expression
    static org.apache.hadoop.hbase.filter.Filter
    ParseFilter.popArguments(Stack<ByteBuffer> operatorStack, Stack<org.apache.hadoop.hbase.filter.Filter> filterStack)
    Pops an argument from the operator stack and the number of arguments required by the operator from the filterStack and evaluates them
    Methods in org.apache.hadoop.hbase.filter that return types with arguments of type org.apache.hadoop.hbase.filter.Filter in in
    Modifier and Type
    Method
    Description
    List<org.apache.hadoop.hbase.filter.Filter>
    FilterList.getFilters()
    Get the filters.
    ArrayList<org.apache.hadoop.hbase.filter.Filter>
    FilterListBase.getFilters()
     
    Methods in org.apache.hadoop.hbase.filter with parameters of type org.apache.hadoop.hbase.filter.Filter in in
    Modifier and Type
    Method
    Description
    void
    FilterList.addFilter(org.apache.hadoop.hbase.filter.Filter filter)
    Add a filter.
    Method parameters in org.apache.hadoop.hbase.filter with type arguments of type org.apache.hadoop.hbase.filter.Filter in in
    Modifier and Type
    Method
    Description
    void
    FilterList.addFilter(List<org.apache.hadoop.hbase.filter.Filter> filters)
     
    abstract void
    FilterListBase.addFilterLists(List<org.apache.hadoop.hbase.filter.Filter> filters)
     
    void
    FilterListWithAND.addFilterLists(List<org.apache.hadoop.hbase.filter.Filter> filters)
     
    void
    FilterListWithOR.addFilterLists(List<org.apache.hadoop.hbase.filter.Filter> filters)
     
    protected static boolean
    FilterListBase.checkAndGetReversed(List<org.apache.hadoop.hbase.filter.Filter> rowFilters, boolean defaultValue)
     
    protected abstract String
    FilterListBase.formatLogFilters(List<org.apache.hadoop.hbase.filter.Filter> logFilters)
     
    protected String
    FilterListWithAND.formatLogFilters(List<org.apache.hadoop.hbase.filter.Filter> logFilters)
     
    protected String
    FilterListWithOR.formatLogFilters(List<org.apache.hadoop.hbase.filter.Filter> logFilters)
     
    Constructors in org.apache.hadoop.hbase.filter with parameters of type org.apache.hadoop.hbase.filter.Filter in in
    Modifier
    Constructor
    Description
     
    FilterList(org.apache.hadoop.hbase.filter.Filter... filters)
    Constructor that takes a var arg number of Filters.
     
    FilterList(org.apache.hadoop.hbase.filter.FilterList.Operator operator, org.apache.hadoop.hbase.filter.Filter... filters)
    Constructor that takes a var arg number of Filters and an operator.
     
    FilterWrapper(org.apache.hadoop.hbase.filter.Filter filter)
    Constructor.
     
    SkipFilter(org.apache.hadoop.hbase.filter.Filter filter)
     
     
    WhileMatchFilter(org.apache.hadoop.hbase.filter.Filter filter)
     
    Constructor parameters in org.apache.hadoop.hbase.filter with type arguments of type org.apache.hadoop.hbase.filter.Filter in in
    Modifier
    Constructor
    Description
     
    FilterList(List<org.apache.hadoop.hbase.filter.Filter> filters)
    Constructor that takes a set of Filters.
     
    FilterList(org.apache.hadoop.hbase.filter.FilterList.Operator operator, List<org.apache.hadoop.hbase.filter.Filter> filters)
    Constructor that takes a set of Filters and an operator.
     
    FilterListBase(List<org.apache.hadoop.hbase.filter.Filter> filters)
     
     
    FilterListWithAND(List<org.apache.hadoop.hbase.filter.Filter> filters)
     
     
    FilterListWithOR(List<org.apache.hadoop.hbase.filter.Filter> filters)
     
  • Uses of org.apache.hadoop.hbase.filter.Filter in org.apache.hadoop.hbase.mapred

    Methods in org.apache.hadoop.hbase.mapred with parameters of type org.apache.hadoop.hbase.filter.Filter in in
    Modifier and Type
    Method
    Description
    protected void
    TableInputFormatBase.setRowFilter(org.apache.hadoop.hbase.filter.Filter rowFilter)
    Allows subclasses to set the Filter to be used.
    void
    TableRecordReader.setRowFilter(org.apache.hadoop.hbase.filter.Filter rowFilter)
     
    void
    TableRecordReaderImpl.setRowFilter(org.apache.hadoop.hbase.filter.Filter rowFilter)
     
  • Uses of org.apache.hadoop.hbase.filter.Filter in org.apache.hadoop.hbase.mapreduce

    Methods in org.apache.hadoop.hbase.mapreduce that return org.apache.hadoop.hbase.filter.Filter in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.filter.Filter
    Import.instantiateFilter(org.apache.hadoop.conf.Configuration conf)
    Create a Filter to apply to all incoming keys (KeyValues) to optionally not include in the job output
    Methods in org.apache.hadoop.hbase.mapreduce with parameters of type org.apache.hadoop.hbase.filter.Filter in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.ExtendedCell
    Import.filterKv(org.apache.hadoop.hbase.filter.Filter filter, org.apache.hadoop.hbase.ExtendedCell c)
    Attempt to filter out the keyvalue
    Method parameters in org.apache.hadoop.hbase.mapreduce with type arguments of type org.apache.hadoop.hbase.filter.Filter in in
    Modifier and Type
    Method
    Description
    static void
    Import.addFilterAndArguments(org.apache.hadoop.conf.Configuration conf, Class<? extends org.apache.hadoop.hbase.filter.Filter> clazz, List<String> filterArgs)
    Add a Filter to be instantiated on import
  • Uses of org.apache.hadoop.hbase.filter.Filter in org.apache.hadoop.hbase.quotas

    Methods in org.apache.hadoop.hbase.quotas that return org.apache.hadoop.hbase.filter.Filter in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.filter.Filter
    QuotaTableUtil.makeFilter(org.apache.hadoop.hbase.quotas.QuotaFilter filter)
    converts quotafilter to serializeable filterlists.
  • Uses of org.apache.hadoop.hbase.filter.Filter in org.apache.hadoop.hbase.regionserver

    Methods in org.apache.hadoop.hbase.regionserver with parameters of type org.apache.hadoop.hbase.filter.Filter in in
    Modifier and Type
    Method
    Description
    boolean
    HRegion.checkAndMutate(byte[] row, org.apache.hadoop.hbase.filter.Filter filter, org.apache.hadoop.hbase.io.TimeRange timeRange, org.apache.hadoop.hbase.client.Mutation mutation)
    Deprecated.
    default boolean
    Region.checkAndMutate(byte[] row, org.apache.hadoop.hbase.filter.Filter filter, org.apache.hadoop.hbase.client.Mutation mutation)
    Deprecated.
    since 3.0.0 and will be removed in 4.0.0.
    boolean
    Region.checkAndMutate(byte[] row, org.apache.hadoop.hbase.filter.Filter filter, org.apache.hadoop.hbase.io.TimeRange timeRange, org.apache.hadoop.hbase.client.Mutation mutation)
    Deprecated.
    since 3.0.0 and will be removed in 4.0.0.
    boolean
    HRegion.checkAndRowMutate(byte[] row, org.apache.hadoop.hbase.filter.Filter filter, org.apache.hadoop.hbase.io.TimeRange timeRange, org.apache.hadoop.hbase.client.RowMutations rm)
    Deprecated.
    default boolean
    Region.checkAndRowMutate(byte[] row, org.apache.hadoop.hbase.filter.Filter filter, org.apache.hadoop.hbase.client.RowMutations mutations)
    Deprecated.
    since 3.0.0 and will be removed in 4.0.0.
    boolean
    Region.checkAndRowMutate(byte[] row, org.apache.hadoop.hbase.filter.Filter filter, org.apache.hadoop.hbase.io.TimeRange timeRange, org.apache.hadoop.hbase.client.RowMutations mutations)
    Deprecated.
    since 3.0.0 and will be removed in 4.0.0.
  • Uses of org.apache.hadoop.hbase.filter.Filter in org.apache.hadoop.hbase.regionserver.querymatcher

    Fields in org.apache.hadoop.hbase.regionserver.querymatcher declared as org.apache.hadoop.hbase.filter.Filter in in
    Modifier and Type
    Field
    Description
    protected final org.apache.hadoop.hbase.filter.Filter
    UserScanQueryMatcher.filter
     
    Methods in org.apache.hadoop.hbase.regionserver.querymatcher that return org.apache.hadoop.hbase.filter.Filter in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.filter.Filter
    CompactionScanQueryMatcher.getFilter()
     
    abstract org.apache.hadoop.hbase.filter.Filter
    ScanQueryMatcher.getFilter()
    Returns the Filter
    org.apache.hadoop.hbase.filter.Filter
    UserScanQueryMatcher.getFilter()
     
  • Uses of org.apache.hadoop.hbase.filter.Filter in org.apache.hadoop.hbase.rest

    Methods in org.apache.hadoop.hbase.rest that return org.apache.hadoop.hbase.filter.Filter in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.filter.Filter
    ResultGenerator.buildFilter(String filter)
     
    static org.apache.hadoop.hbase.filter.Filter
    ScannerResultGenerator.buildFilterFromModel(org.apache.hadoop.hbase.rest.model.ScannerModel model)
     
    Methods in org.apache.hadoop.hbase.rest with parameters of type org.apache.hadoop.hbase.filter.Filter in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.rest.ResultGenerator
    ResultGenerator.fromRowSpec(String table, org.apache.hadoop.hbase.rest.RowSpec rowspec, org.apache.hadoop.hbase.filter.Filter filter, boolean cacheBlocks)
     
    Constructors in org.apache.hadoop.hbase.rest with parameters of type org.apache.hadoop.hbase.filter.Filter in in
    Modifier
    Constructor
    Description
     
    MultiRowResultReader(String tableName, Collection<org.apache.hadoop.hbase.rest.RowSpec> rowspecs, org.apache.hadoop.hbase.filter.Filter filter, boolean cacheBlocks)
     
     
    RowResultGenerator(String tableName, org.apache.hadoop.hbase.rest.RowSpec rowspec, org.apache.hadoop.hbase.filter.Filter filter, boolean cacheBlocks)
     
     
    ScannerResultGenerator(String tableName, org.apache.hadoop.hbase.rest.RowSpec rowspec, org.apache.hadoop.hbase.filter.Filter filter, boolean cacheBlocks)
     
     
    ScannerResultGenerator(String tableName, org.apache.hadoop.hbase.rest.RowSpec rowspec, org.apache.hadoop.hbase.filter.Filter filter, int caching, boolean cacheBlocks)
     
     
    ScannerResultGenerator(String tableName, org.apache.hadoop.hbase.rest.RowSpec rowspec, org.apache.hadoop.hbase.filter.Filter filter, int caching, boolean cacheBlocks, int limit, boolean includeStartRow, boolean includeStopRow)
     
  • Uses of org.apache.hadoop.hbase.filter.Filter in org.apache.hadoop.hbase.shaded.protobuf

    Methods in org.apache.hadoop.hbase.shaded.protobuf that return org.apache.hadoop.hbase.filter.Filter in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.filter.Filter
    ProtobufUtil.toFilter(org.apache.hadoop.hbase.shaded.protobuf.generated.FilterProtos.Filter proto)
    Convert a protocol buffer Filter to a client Filter
    Methods in org.apache.hadoop.hbase.shaded.protobuf with parameters of type org.apache.hadoop.hbase.filter.Filter in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MultiRequest
    RequestConverter.buildMultiRequest(byte[] regionName, byte[] row, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.CompareOperator op, byte[] value, org.apache.hadoop.hbase.filter.Filter filter, org.apache.hadoop.hbase.io.TimeRange timeRange, org.apache.hadoop.hbase.client.RowMutations rowMutations, long nonceGroup, long nonce, boolean queryMetricsEnabled)
    Create a protocol buffer MultiRequest for conditioned row mutations
    static org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutateRequest
    RequestConverter.buildMutateRequest(byte[] regionName, byte[] row, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.CompareOperator op, byte[] value, org.apache.hadoop.hbase.filter.Filter filter, org.apache.hadoop.hbase.io.TimeRange timeRange, org.apache.hadoop.hbase.client.Mutation mutation, long nonceGroup, long nonce, boolean queryMetricsEnabled)
    Create a protocol buffer MutateRequest for a conditioned put/delete/increment/append
    static org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Condition
    ProtobufUtil.toCondition(byte[] row, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.CompareOperator op, byte[] value, org.apache.hadoop.hbase.filter.Filter filter, org.apache.hadoop.hbase.io.TimeRange timeRange, boolean queryMetricsEnabled)
     
    static org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Condition
    ProtobufUtil.toCondition(byte[] row, org.apache.hadoop.hbase.filter.Filter filter, org.apache.hadoop.hbase.io.TimeRange timeRange)
     
    static org.apache.hadoop.hbase.shaded.protobuf.generated.FilterProtos.Filter
    ProtobufUtil.toFilter(org.apache.hadoop.hbase.filter.Filter filter)
    Convert a client Filter to a protocol buffer Filter