Uses of Class
org.apache.hadoop.hbase.io.TimeRange

Packages that use org.apache.hadoop.hbase.io.TimeRange
  • Uses of org.apache.hadoop.hbase.io.TimeRange in org.apache.hadoop.hbase.client

    Fields in org.apache.hadoop.hbase.client with type parameters of type org.apache.hadoop.hbase.io.TimeRange in in
    Modifier and Type
    Field
    Description
    protected Map<byte[],org.apache.hadoop.hbase.io.TimeRange>
    Query.colFamTimeRangeMap
     
    Methods in org.apache.hadoop.hbase.client that return org.apache.hadoop.hbase.io.TimeRange in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.io.TimeRange
    Append.getTimeRange()
    Gets the TimeRange used for this append.
    org.apache.hadoop.hbase.io.TimeRange
    CheckAndMutate.getTimeRange()
    Returns the time range to check
    org.apache.hadoop.hbase.io.TimeRange
    Get.getTimeRange()
    Method for retrieving the get's TimeRange
    org.apache.hadoop.hbase.io.TimeRange
    ImmutableScan.getTimeRange()
     
    org.apache.hadoop.hbase.io.TimeRange
    Increment.getTimeRange()
    Gets the TimeRange used for this increment.
    org.apache.hadoop.hbase.io.TimeRange
    Scan.getTimeRange()
    Returns TimeRange
    Methods in org.apache.hadoop.hbase.client that return types with arguments of type org.apache.hadoop.hbase.io.TimeRange in in
    Modifier and Type
    Method
    Description
    Map<byte[],org.apache.hadoop.hbase.io.TimeRange>
    ImmutableScan.getColumnFamilyTimeRange()
     
    Map<byte[],org.apache.hadoop.hbase.io.TimeRange>
    Query.getColumnFamilyTimeRange()
    Returns A map of column families to time ranges
    Methods in org.apache.hadoop.hbase.client with parameters of type org.apache.hadoop.hbase.io.TimeRange in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateBuilder
    AsyncTable.CheckAndMutateBuilder.timeRange(org.apache.hadoop.hbase.io.TimeRange timeRange)
    Deprecated.
    Match a timerange.
    org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateWithFilterBuilder
    AsyncTable.CheckAndMutateWithFilterBuilder.timeRange(org.apache.hadoop.hbase.io.TimeRange timeRange)
    Deprecated.
    Match a timerange.
    CheckAndMutate.Builder.timeRange(org.apache.hadoop.hbase.io.TimeRange timeRange)
    Specify a timerange
    org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder
    Table.CheckAndMutateBuilder.timeRange(org.apache.hadoop.hbase.io.TimeRange timeRange)
    Deprecated.
    Specify a timerange
    org.apache.hadoop.hbase.client.Table.CheckAndMutateWithFilterBuilder
    Table.CheckAndMutateWithFilterBuilder.timeRange(org.apache.hadoop.hbase.io.TimeRange timeRange)
    Deprecated.
    Specify a timerange.
  • Uses of org.apache.hadoop.hbase.io.TimeRange in org.apache.hadoop.hbase.io

    Methods in org.apache.hadoop.hbase.io that return org.apache.hadoop.hbase.io.TimeRange in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.io.TimeRange
    TimeRange.allTime()
     
    static org.apache.hadoop.hbase.io.TimeRange
    TimeRange.at(long ts)
     
    static org.apache.hadoop.hbase.io.TimeRange
    TimeRange.between(long minStamp, long maxStamp)
    Represents the time interval [minStamp, maxStamp)
    static org.apache.hadoop.hbase.io.TimeRange
    TimeRange.from(long minStamp)
    Represents the time interval [minStamp, Long.MAX_VALUE)
    static org.apache.hadoop.hbase.io.TimeRange
    TimeRange.until(long maxStamp)
    Represents the time interval [0, maxStamp)
    Methods in org.apache.hadoop.hbase.io with parameters of type org.apache.hadoop.hbase.io.TimeRange in in
    Modifier and Type
    Method
    Description
    boolean
    TimeRange.includesTimeRange(org.apache.hadoop.hbase.io.TimeRange tr)
    Check if the range has any overlap with TimeRange
  • Uses of org.apache.hadoop.hbase.io.TimeRange in org.apache.hadoop.hbase.regionserver

    Fields in org.apache.hadoop.hbase.regionserver declared as org.apache.hadoop.hbase.io.TimeRange in in
    Modifier and Type
    Field
    Description
    protected org.apache.hadoop.hbase.io.TimeRange
    StoreFileReader.timeRange
     
    Methods in org.apache.hadoop.hbase.regionserver with parameters of type org.apache.hadoop.hbase.io.TimeRange in in
    Modifier and Type
    Method
    Description
    boolean
    HRegion.checkAndMutate(byte[] row, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.CompareOperator op, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.io.TimeRange timeRange, org.apache.hadoop.hbase.client.Mutation mutation)
    Deprecated.
    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.
    boolean
    Region.checkAndMutate(byte[] row, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.CompareOperator op, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.io.TimeRange timeRange, org.apache.hadoop.hbase.client.Mutation mutation)
    Deprecated.
    since 2.4.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 2.4.0 and will be removed in 4.0.0.
    boolean
    HRegion.checkAndRowMutate(byte[] row, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.CompareOperator op, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.io.TimeRange timeRange, org.apache.hadoop.hbase.client.RowMutations rm)
    Deprecated.
    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.
    boolean
    Region.checkAndRowMutate(byte[] row, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.CompareOperator op, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.io.TimeRange timeRange, org.apache.hadoop.hbase.client.RowMutations mutations)
    Deprecated.
    since 2.4.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 2.4.0 and will be removed in 4.0.0.
    boolean
    TimeRangeTracker.includesTimeRange(org.apache.hadoop.hbase.io.TimeRange tr)
    Check if the range has ANY overlap with TimeRange
    boolean
    CompositeImmutableSegment.shouldSeek(org.apache.hadoop.hbase.io.TimeRange tr, long oldestUnexpiredTS)
     
    boolean
    Segment.shouldSeek(org.apache.hadoop.hbase.io.TimeRange tr, long oldestUnexpiredTS)
     
  • Uses of org.apache.hadoop.hbase.io.TimeRange in org.apache.hadoop.hbase.regionserver.querymatcher

    Fields in org.apache.hadoop.hbase.regionserver.querymatcher declared as org.apache.hadoop.hbase.io.TimeRange in in
    Modifier and Type
    Field
    Description
    protected final org.apache.hadoop.hbase.io.TimeRange
    UserScanQueryMatcher.tr
     
  • Uses of org.apache.hadoop.hbase.io.TimeRange in org.apache.hadoop.hbase.shaded.protobuf

    Methods in org.apache.hadoop.hbase.shaded.protobuf that return org.apache.hadoop.hbase.io.TimeRange in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.io.TimeRange
    ProtobufUtil.toTimeRange(org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.TimeRange timeRange)
     
    Methods in org.apache.hadoop.hbase.shaded.protobuf with parameters of type org.apache.hadoop.hbase.io.TimeRange 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)
    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)
    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)
     
    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.io.TimeRange timeRange)
     
    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.HBaseProtos.TimeRange
    ProtobufUtil.toTimeRange(org.apache.hadoop.hbase.io.TimeRange timeRange)