public static interface SegmentedBytesStore.KeySchema
Modifier and Type | Method and Description |
---|---|
org.apache.kafka.streams.state.internals.HasNextCondition |
hasNextCondition(org.apache.kafka.common.utils.Bytes binaryKeyFrom,
org.apache.kafka.common.utils.Bytes binaryKeyTo,
long from,
long to)
Create an implementation of
HasNextCondition that knows when
to stop iterating over the Segments. |
org.apache.kafka.common.utils.Bytes |
lowerRange(org.apache.kafka.common.utils.Bytes key,
long from)
Given a range of record keys and a time, construct a Segmented key that represents
the lower range of keys to search when performing range queries.
|
org.apache.kafka.common.utils.Bytes |
lowerRangeFixedSize(org.apache.kafka.common.utils.Bytes key,
long from)
Given a range of fixed size record keys and a time, construct a Segmented key that represents
the lower range of keys to search when performing range queries.
|
java.util.List<org.apache.kafka.streams.state.internals.Segment> |
segmentsToSearch(org.apache.kafka.streams.state.internals.Segments segments,
long from,
long to)
Used during
SegmentedBytesStore.fetch(Bytes, long, long) operations to determine
which segments should be scanned. |
long |
segmentTimestamp(org.apache.kafka.common.utils.Bytes key)
Extract the timestamp of the segment from the key.
|
org.apache.kafka.common.utils.Bytes |
upperRange(org.apache.kafka.common.utils.Bytes key,
long to)
Given a range of record keys and a time, construct a Segmented key that represents
the upper range of keys to search when performing range queries.
|
org.apache.kafka.common.utils.Bytes |
upperRangeFixedSize(org.apache.kafka.common.utils.Bytes key,
long to)
Given a range of fixed size record keys and a time, construct a Segmented key that represents
the upper range of keys to search when performing range queries.
|
org.apache.kafka.common.utils.Bytes upperRange(org.apache.kafka.common.utils.Bytes key, long to)
key
- to
- SessionKeySchema.upperRange(org.apache.kafka.common.utils.Bytes, long)
,
WindowKeySchema.upperRange(org.apache.kafka.common.utils.Bytes, long)
org.apache.kafka.common.utils.Bytes lowerRange(org.apache.kafka.common.utils.Bytes key, long from)
key
- from
- SessionKeySchema.lowerRange(org.apache.kafka.common.utils.Bytes, long)
,
WindowKeySchema.lowerRange(org.apache.kafka.common.utils.Bytes, long)
org.apache.kafka.common.utils.Bytes upperRangeFixedSize(org.apache.kafka.common.utils.Bytes key, long to)
key
- the last key in the rangeto
- the last timestamp in the rangeSessionKeySchema.upperRange(org.apache.kafka.common.utils.Bytes, long)
,
WindowKeySchema.upperRange(org.apache.kafka.common.utils.Bytes, long)
org.apache.kafka.common.utils.Bytes lowerRangeFixedSize(org.apache.kafka.common.utils.Bytes key, long from)
key
- the first key in the rangefrom
- the first timestamp in the rangeSessionKeySchema.lowerRange(org.apache.kafka.common.utils.Bytes, long)
,
WindowKeySchema.lowerRange(org.apache.kafka.common.utils.Bytes, long)
long segmentTimestamp(org.apache.kafka.common.utils.Bytes key)
key
- SessionKeySchema.lowerRange(org.apache.kafka.common.utils.Bytes, long)
,
WindowKeySchema.lowerRange(org.apache.kafka.common.utils.Bytes, long)
org.apache.kafka.streams.state.internals.HasNextCondition hasNextCondition(org.apache.kafka.common.utils.Bytes binaryKeyFrom, org.apache.kafka.common.utils.Bytes binaryKeyTo, long from, long to)
HasNextCondition
that knows when
to stop iterating over the Segments. Used during SegmentedBytesStore.fetch(Bytes, Bytes, long, long)
operationsbinaryKeyFrom
- the first key in the rangebinaryKeyTo
- the last key in the rangefrom
- starting time rangeto
- ending time rangejava.util.List<org.apache.kafka.streams.state.internals.Segment> segmentsToSearch(org.apache.kafka.streams.state.internals.Segments segments, long from, long to)
SegmentedBytesStore.fetch(Bytes, long, long)
operations to determine
which segments should be scanned.segments
- from
- to
-