Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.codec.prefixtree | |
org.apache.hadoop.hbase.coprocessor |
Table of Contents
|
org.apache.hadoop.hbase.filter |
Provides row-level filters applied to HRegion scan results during calls to
ResultScanner.next() . |
org.apache.hadoop.hbase.io.encoding | |
org.apache.hadoop.hbase.io.hfile |
Provides the hbase data+index+metadata file.
|
org.apache.hadoop.hbase.mapreduce |
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility
|
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.regionserver.compactions | |
org.apache.hadoop.hbase.regionserver.handler | |
org.apache.hadoop.hbase.regionserver.wal | |
org.apache.hadoop.hbase.rest.model | |
org.apache.hadoop.hbase.security.access | |
org.apache.hadoop.hbase.util | |
org.apache.hadoop.hbase.util.test |
Modifier and Type | Field and Description |
---|---|
static KeyValue |
KeyValue.LOWESTKEY
Lowest possible key.
|
Modifier and Type | Method and Description |
---|---|
KeyValue |
KeyValue.clone()
Clones a KeyValue.
|
static KeyValue |
KeyValue.cloneAndAddTags(Cell c,
List<Tag> newTags)
Create a new KeyValue by copying existing cell and adding new tags
|
static KeyValue |
KeyValueUtil.copyToNewKeyValue(Cell cell)
copy key only
|
static KeyValue |
KeyValue.create(DataInput in) |
static KeyValue |
KeyValue.create(int length,
DataInput in)
Create a KeyValue reading
length from in |
static KeyValue |
KeyValueTestUtil.create(String row,
String family,
String qualifier,
long timestamp,
KeyValue.Type type,
String value) |
static KeyValue |
KeyValueTestUtil.create(String row,
String family,
String qualifier,
long timestamp,
String value) |
static KeyValue |
KeyValue.createFirstDeleteFamilyOnRow(byte[] row,
byte[] family)
Create a Delete Family KeyValue for the specified row and family that would
be smaller than all other possible Delete Family KeyValues that have the
same row and family.
|
static KeyValue |
KeyValueUtil.createFirstKeyInIncrementedRow(Cell in)
Increment the row bytes and clear the other fields
|
static KeyValue |
KeyValueUtil.createFirstKeyInNextRow(Cell in)
Append single byte 0x00 to the end of the input row key
|
static KeyValue |
KeyValue.createFirstOnRow(byte[] row)
Create a KeyValue that is smaller than all other possible KeyValues
for the given row.
|
static KeyValue |
KeyValue.createFirstOnRow(byte[] row,
byte[] family,
byte[] qualifier)
Create a KeyValue for the specified row, family and qualifier that would be
smaller than all other possible KeyValues that have the same row,family,qualifier.
|
static KeyValue |
KeyValue.createFirstOnRow(byte[] buffer,
byte[] row,
byte[] family,
byte[] qualifier)
Create a KeyValue for the specified row, family and qualifier that would be
smaller than all other possible KeyValues that have the same row,
family, qualifier.
|
static KeyValue |
KeyValue.createFirstOnRow(byte[] row,
byte[] f,
byte[] q,
long ts) |
static KeyValue |
KeyValue.createFirstOnRow(byte[] buffer,
int boffset,
byte[] row,
int roffset,
int rlength,
byte[] family,
int foffset,
int flength,
byte[] qualifier,
int qoffset,
int qlength)
Create a KeyValue for the specified row, family and qualifier that would be
smaller than all other possible KeyValues that have the same row,
family, qualifier.
|
static KeyValue |
KeyValue.createFirstOnRow(byte[] row,
int roffset,
int rlength,
byte[] family,
int foffset,
int flength,
byte[] qualifier,
int qoffset,
int qlength)
Create a KeyValue for the specified row, family and qualifier that would be
smaller than all other possible KeyValues that have the same row,
family, qualifier.
|
static KeyValue |
KeyValue.createFirstOnRow(byte[] row,
int roffset,
short rlength)
Create a KeyValue that is smaller than all other possible KeyValues
for the given row.
|
static KeyValue |
KeyValue.createFirstOnRow(byte[] row,
long ts)
Creates a KeyValue that is smaller than all other KeyValues that
are older than the passed timestamp.
|
KeyValue |
KeyValue.createFirstOnRowColTS(long ts)
Creates the first KV with the row/family/qualifier of this KV and the
given timestamp.
|
KeyValue |
KeyValue.createKeyOnly(boolean lenAsVal)
Creates a new KeyValue that only contains the key portion (the value is
set to be null).
|
static KeyValue |
KeyValue.createKeyValueFromKey(byte[] b) |
static KeyValue |
KeyValue.createKeyValueFromKey(byte[] b,
int o,
int l) |
static KeyValue |
KeyValue.createKeyValueFromKey(ByteBuffer bb) |
static KeyValue |
KeyValue.createLastOnRow(byte[] row)
Creates a KeyValue that is last on the specified row id.
|
static KeyValue |
KeyValue.createLastOnRow(byte[] row,
int roffset,
int rlength,
byte[] family,
int foffset,
int flength,
byte[] qualifier,
int qoffset,
int qlength)
Create a KeyValue for the specified row, family and qualifier that would be
larger than or equal to all other possible KeyValues that have the same
row, family, qualifier.
|
KeyValue |
KeyValue.createLastOnRowCol()
Similar to
createLastOnRow(byte[], int, int, byte[], int, int,
byte[], int, int) but creates the last key on the row/column of this KV
(the value part of the returned KV is always empty). |
static KeyValue |
KeyValueUtil.ensureKeyValue(Cell cell) |
static KeyValue |
KeyValue.iscreate(InputStream in)
Create a KeyValue reading from the raw InputStream.
|
static KeyValue |
KeyValueUtil.nextShallowCopy(ByteBuffer bb,
boolean includesMvccVersion,
boolean includesTags)
Creates a new KeyValue object positioned in the supplied ByteBuffer and sets the ByteBuffer's
position to the start of the next KeyValue.
|
static KeyValue |
KeyValueUtil.previousKey(KeyValue in)
Decrement the timestamp.
|
KeyValue |
KeyValue.shallowCopy()
Creates a shallow copy of this KeyValue, reusing the data byte buffer.
|
Modifier and Type | Method and Description |
---|---|
static List<KeyValue> |
KeyValueUtil.ensureKeyValues(List<Cell> cells) |
static List<KeyValue> |
KeyValueTestUtil.rewindThenToList(ByteBuffer bb,
boolean includesMemstoreTS,
boolean useTags) |
Modifier and Type | Method and Description |
---|---|
static void |
KeyValueUtil.appendToByteBuffer(ByteBuffer bb,
KeyValue kv,
boolean includeMvccVersion) |
int |
KeyValue.RowOnlyComparator.compare(KeyValue left,
KeyValue right) |
int |
KeyValue.KVComparator.compareRows(KeyValue left,
KeyValue right) |
int |
KeyValue.KVComparator.compareTimestamps(KeyValue left,
KeyValue right) |
protected static String |
KeyValueTestUtil.getFamilyString(KeyValue kv) |
protected static String |
KeyValueTestUtil.getQualifierString(KeyValue kv) |
protected static String |
KeyValueTestUtil.getRowString(KeyValue kv) |
protected static String |
KeyValueTestUtil.getTimestampString(KeyValue kv) |
protected static String |
KeyValueTestUtil.getTypeString(KeyValue kv) |
protected static String |
KeyValueTestUtil.getValueString(KeyValue kv) |
static int |
KeyValueUtil.lengthWithMvccVersion(KeyValue kv,
boolean includeMvccVersion) |
boolean |
KeyValue.matchingQualifier(KeyValue other) |
boolean |
KeyValue.matchingRow(KeyValue other) |
boolean |
KeyValue.KVComparator.matchingRowColumn(KeyValue left,
KeyValue right)
Compares the row and column of two keyvalues for equality
|
boolean |
KeyValue.KVComparator.matchingRows(KeyValue left,
KeyValue right)
Compares the row of two keyvalues for equality
|
static long |
KeyValue.oswrite(KeyValue kv,
OutputStream out)
Deprecated.
|
static long |
KeyValue.oswrite(KeyValue kv,
OutputStream out,
boolean withTags)
Write out a KeyValue in the manner in which we used to when KeyValue was a Writable but do
not require a
DataOutput , just take plain OutputStream
Named oswrite so does not clash with write(KeyValue, DataOutput) |
static KeyValue |
KeyValueUtil.previousKey(KeyValue in)
Decrement the timestamp.
|
protected static String |
KeyValueTestUtil.toStringWithPadding(KeyValue kv,
int maxRowLength,
int maxFamilyLength,
int maxQualifierLength,
int maxTimestampLength,
boolean includeMeta) |
static long |
KeyValue.write(KeyValue kv,
DataOutput out)
Write out a KeyValue in the manner in which we used to when KeyValue was a Writable.
|
Modifier and Type | Method and Description |
---|---|
static ByteBuffer |
KeyValueTestUtil.toByteBufferAndRewind(Iterable<? extends KeyValue> kvs,
boolean includeMemstoreTS) |
static String |
KeyValueTestUtil.toStringWithPadding(Collection<? extends KeyValue> kvs,
boolean includeMeta)
toString
|
static int |
KeyValueUtil.totalLengthWithMvccVersion(Iterable<? extends KeyValue> kvs,
boolean includeMvccVersion) |
Modifier and Type | Method and Description |
---|---|
KeyValue |
Result.getColumnLatest(byte[] family,
byte[] qualifier)
Deprecated.
Use
Result.getColumnLatestCell(byte[], byte[]) instead. |
KeyValue |
Result.getColumnLatest(byte[] family,
int foffset,
int flength,
byte[] qualifier,
int qoffset,
int qlength)
Deprecated.
|
KeyValue[] |
Result.raw()
Deprecated.
as of 0.96, use
Result.rawCells() |
Modifier and Type | Method and Description |
---|---|
List<KeyValue> |
Result.getColumn(byte[] family,
byte[] qualifier)
Deprecated.
Use
Result.getColumnCells(byte[], byte[]) instead. |
NavigableMap<byte[],List<KeyValue>> |
Mutation.getFamilyMap()
Deprecated.
use
Mutation.getFamilyCellMap() instead. |
List<KeyValue> |
Result.list()
Deprecated.
as of 0.96, use
Result.listCells() |
Modifier and Type | Method and Description |
---|---|
void |
Mutation.setFamilyMap(NavigableMap<byte[],List<KeyValue>> map)
Deprecated.
use
Mutation.setFamilyCellMap(NavigableMap) instead. |
Constructor and Description |
---|
Result(KeyValue[] cells)
Deprecated.
Use
Result.create(List) instead. |
Constructor and Description |
---|
Result(List<KeyValue> kvs)
Deprecated.
Use
Result.create(List) instead. |
Modifier and Type | Method and Description |
---|---|
KeyValue |
PrefixTreeSeeker.getKeyValue()
currently must do deep copy into new array
|
Modifier and Type | Method and Description |
---|---|
T |
ColumnInterpreter.getValue(byte[] colFamily,
byte[] colQualifier,
KeyValue kv)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
void |
BaseRegionObserver.postGet(ObserverContext<RegionCoprocessorEnvironment> c,
Get get,
List<KeyValue> result)
Deprecated.
|
void |
RegionObserver.postGet(ObserverContext<RegionCoprocessorEnvironment> c,
Get get,
List<KeyValue> result)
Deprecated.
|
void |
BaseRegionObserver.preGet(ObserverContext<RegionCoprocessorEnvironment> c,
Get get,
List<KeyValue> result)
Deprecated.
|
void |
RegionObserver.preGet(ObserverContext<RegionCoprocessorEnvironment> c,
Get get,
List<KeyValue> result)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
KeyValue |
FilterBase.getNextKeyHint(KeyValue currentKV)
Deprecated.
|
abstract KeyValue |
Filter.getNextKeyHint(KeyValue currentKV)
Deprecated.
|
KeyValue |
FilterList.getNextKeyHint(KeyValue currentKV)
Deprecated.
|
KeyValue |
FilterWrapper.getNextKeyHint(KeyValue currentKV)
Deprecated.
|
KeyValue |
FilterBase.transform(KeyValue currentKV)
Deprecated.
|
abstract KeyValue |
Filter.transform(KeyValue currentKV)
Deprecated.
|
KeyValue |
FilterList.transform(KeyValue v)
Deprecated.
|
KeyValue |
FilterWrapper.transform(KeyValue currentKV)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
KeyValue |
FilterBase.getNextKeyHint(KeyValue currentKV)
Deprecated.
|
abstract KeyValue |
Filter.getNextKeyHint(KeyValue currentKV)
Deprecated.
|
KeyValue |
FilterList.getNextKeyHint(KeyValue currentKV)
Deprecated.
|
KeyValue |
FilterWrapper.getNextKeyHint(KeyValue currentKV)
Deprecated.
|
KeyValue |
FilterBase.transform(KeyValue currentKV)
Deprecated.
|
abstract KeyValue |
Filter.transform(KeyValue currentKV)
Deprecated.
|
KeyValue |
FilterList.transform(KeyValue v)
Deprecated.
|
KeyValue |
FilterWrapper.transform(KeyValue currentKV)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
void |
FilterBase.filterRow(List<KeyValue> kvs)
Deprecated.
|
abstract void |
Filter.filterRow(List<KeyValue> kvs)
Deprecated.
|
void |
FilterList.filterRow(List<KeyValue> kvs)
Deprecated.
|
void |
FilterWrapper.filterRow(List<KeyValue> kvs)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
KeyValue |
DataBlockEncoder.EncodedSeeker.getKeyValue() |
Modifier and Type | Method and Description |
---|---|
KeyValue |
HFileReaderV2.ScannerV2.getKeyValue() |
KeyValue |
HFileReaderV2.EncodedScannerV2.getKeyValue() |
KeyValue |
HFileScanner.getKeyValue() |
Modifier and Type | Method and Description |
---|---|
void |
HFileWriterV2.append(KeyValue kv)
Add key/value to file.
|
void |
HFile.Writer.append(KeyValue kv) |
void |
HFileWriterV3.append(KeyValue kv)
Add key/value to file.
|
Modifier and Type | Method and Description |
---|---|
KeyValue |
KeyValueSerialization.KeyValueDeserializer.deserialize(KeyValue ignore) |
Modifier and Type | Method and Description |
---|---|
org.apache.hadoop.mapreduce.RecordWriter<ImmutableBytesWritable,KeyValue> |
HFileOutputFormat.getRecordWriter(org.apache.hadoop.mapreduce.TaskAttemptContext context)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
KeyValue |
KeyValueSerialization.KeyValueDeserializer.deserialize(KeyValue ignore) |
void |
KeyValueSerialization.KeyValueSerializer.serialize(KeyValue kv) |
Modifier and Type | Method and Description |
---|---|
KeyValueSerialization.KeyValueDeserializer |
KeyValueSerialization.getDeserializer(Class<KeyValue> t) |
KeyValueSerialization.KeyValueSerializer |
KeyValueSerialization.getSerializer(Class<KeyValue> c) |
protected void |
KeyValueSortReducer.reduce(ImmutableBytesWritable row,
Iterable<KeyValue> kvs,
org.apache.hadoop.mapreduce.Reducer.Context context) |
Modifier and Type | Field and Description |
---|---|
protected KeyValue |
StoreScanner.lastTop |
Modifier and Type | Method and Description |
---|---|
KeyValue |
KeyValueSkipListSet.ceiling(KeyValue e) |
KeyValue |
KeyValueSkipListSet.first() |
KeyValue |
KeyValueSkipListSet.floor(KeyValue e) |
KeyValue |
KeyValueSkipListSet.get(KeyValue kv) |
KeyValue |
ScanQueryMatcher.getKeyForNextColumn(KeyValue kv) |
KeyValue |
ScanQueryMatcher.getKeyForNextRow(KeyValue kv) |
KeyValue |
Store.getRowKeyAtOrBefore(byte[] row)
Find the key that matches row exactly, or the one that immediately precedes it.
|
KeyValue |
HStore.getRowKeyAtOrBefore(byte[] row) |
KeyValue |
ScanQueryMatcher.getStartKey() |
KeyValue |
KeyValueSkipListSet.higher(KeyValue e) |
KeyValue |
KeyValueSkipListSet.last() |
KeyValue |
KeyValueSkipListSet.lower(KeyValue e) |
KeyValue |
StoreScanner.next() |
KeyValue |
ReversedKeyValueHeap.next() |
KeyValue |
StoreFileScanner.next() |
KeyValue |
KeyValueHeap.next() |
KeyValue |
KeyValueScanner.next()
Return the next KeyValue in this scanner, iterating the scanner
|
KeyValue |
MemStore.MemStoreScanner.next() |
KeyValue |
StoreScanner.peek() |
KeyValue |
StoreFileScanner.peek() |
KeyValue |
KeyValueHeap.peek() |
KeyValue |
KeyValueScanner.peek()
Look at the next KeyValue in this scanner, but do not iterate scanner.
|
KeyValue |
MemStore.MemStoreScanner.peek() |
KeyValue |
KeyValueSkipListSet.pollFirst() |
KeyValue |
KeyValueSkipListSet.pollLast() |
Modifier and Type | Method and Description |
---|---|
Comparator<? super KeyValue> |
KeyValueSkipListSet.comparator() |
Iterator<KeyValue> |
KeyValueSkipListSet.descendingIterator() |
NavigableSet<KeyValue> |
KeyValueSkipListSet.descendingSet() |
SortedSet<KeyValue> |
KeyValueSkipListSet.headSet(KeyValue toElement) |
NavigableSet<KeyValue> |
KeyValueSkipListSet.headSet(KeyValue toElement,
boolean inclusive) |
Iterator<KeyValue> |
KeyValueSkipListSet.iterator() |
NavigableSet<KeyValue> |
KeyValueSkipListSet.subSet(KeyValue fromElement,
boolean fromInclusive,
KeyValue toElement,
boolean toInclusive) |
SortedSet<KeyValue> |
KeyValueSkipListSet.subSet(KeyValue fromElement,
KeyValue toElement) |
SortedSet<KeyValue> |
KeyValueSkipListSet.tailSet(KeyValue fromElement) |
NavigableSet<KeyValue> |
KeyValueSkipListSet.tailSet(KeyValue fromElement,
boolean inclusive) |
Modifier and Type | Method and Description |
---|---|
long |
Store.add(KeyValue kv)
Adds a value to the memstore
|
long |
HStore.add(KeyValue kv) |
boolean |
KeyValueSkipListSet.add(KeyValue e) |
void |
StripeMultiFileWriter.BoundaryMultiWriter.append(KeyValue kv) |
void |
StripeMultiFileWriter.SizeMultiWriter.append(KeyValue kv) |
void |
StoreFile.Writer.append(KeyValue kv) |
boolean |
NonReversedNonLazyKeyValueScanner.backwardSeek(KeyValue key) |
boolean |
ReversedKeyValueHeap.backwardSeek(KeyValue seekKey) |
boolean |
StoreFileScanner.backwardSeek(KeyValue key) |
boolean |
KeyValueScanner.backwardSeek(KeyValue key)
Seek the scanner at or before the row of specified KeyValue, it firstly
tries to seek the scanner at or after the specified KeyValue, return if
peek KeyValue of scanner has the same row with specified KeyValue,
otherwise seek the scanner at the first KeyValue of the row which is the
previous row of specified KeyValue
|
boolean |
MemStore.MemStoreScanner.backwardSeek(KeyValue key)
Seek scanner to the given key first.
|
KeyValue |
KeyValueSkipListSet.ceiling(KeyValue e) |
protected void |
StoreScanner.checkScanOrder(KeyValue prevKV,
KeyValue kv,
KeyValue.KVComparator comparator)
Check whether scan as expected order
|
int |
KeyValueHeap.KVScannerComparator.compare(KeyValue left,
KeyValue right)
Compares two KeyValue
|
protected long |
HStore.delete(KeyValue kv)
Adds a value to the memstore
|
static boolean |
NonLazyKeyValueScanner.doRealSeek(KeyValueScanner scanner,
KeyValue kv,
boolean forward) |
KeyValue |
KeyValueSkipListSet.floor(KeyValue e) |
KeyValue |
KeyValueSkipListSet.get(KeyValue kv) |
Iterator<StoreFile> |
StoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue targetKey)
Gets initial, full list of candidate store files to check for row-key-before.
|
Iterator<StoreFile> |
StripeStoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue targetKey)
See
StoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue)
for details on this methods. |
KeyValue |
ScanQueryMatcher.getKeyForNextColumn(KeyValue kv) |
KeyValue |
ScanQueryMatcher.getKeyForNextRow(KeyValue kv) |
SortedSet<KeyValue> |
KeyValueSkipListSet.headSet(KeyValue toElement) |
NavigableSet<KeyValue> |
KeyValueSkipListSet.headSet(KeyValue toElement,
boolean inclusive) |
KeyValue |
KeyValueSkipListSet.higher(KeyValue e) |
void |
TimeRangeTracker.includeTimestamp(KeyValue kv)
Update the current TimestampRange to include the timestamp from KeyValue
If the Key is of type DeleteColumn or DeleteFamily, it includes the
entire time range from 0 to timestamp of the key.
|
KeyValue |
KeyValueSkipListSet.lower(KeyValue e) |
ScanQueryMatcher.MatchCode |
ScanQueryMatcher.match(KeyValue kv)
Determines if the caller should do one of several things:
- seek/skip to the next row (MatchCode.SEEK_NEXT_ROW)
- seek/skip to the next column (MatchCode.SEEK_NEXT_COL)
- include the current KeyValue (MatchCode.INCLUDE)
- ignore the current KeyValue (MatchCode.SKIP)
- got to the next row (MatchCode.DONE)
|
boolean |
ScanQueryMatcher.moreRowsMayExistAfter(KeyValue kv) |
boolean |
NonLazyKeyValueScanner.requestSeek(KeyValue kv,
boolean forward,
boolean useBloom) |
boolean |
ReversedKeyValueHeap.requestSeek(KeyValue key,
boolean forward,
boolean useBloom) |
boolean |
StoreFileScanner.requestSeek(KeyValue kv,
boolean forward,
boolean useBloom)
Pretend we have done a seek but don't do it yet, if possible.
|
boolean |
KeyValueHeap.requestSeek(KeyValue key,
boolean forward,
boolean useBloom)
Similar to
KeyValueScanner.seek(org.apache.hadoop.hbase.KeyValue) (or KeyValueScanner.reseek(org.apache.hadoop.hbase.KeyValue) if forward is true) but only
does a seek operation after checking that it is really necessary for the
row/column combination specified by the kv parameter. |
boolean |
KeyValueScanner.requestSeek(KeyValue kv,
boolean forward,
boolean useBloom)
Similar to
KeyValueScanner.seek(org.apache.hadoop.hbase.KeyValue) (or KeyValueScanner.reseek(org.apache.hadoop.hbase.KeyValue) if forward is true) but only
does a seek operation after checking that it is really necessary for the
row/column combination specified by the kv parameter. |
boolean |
StoreScanner.reseek(KeyValue kv) |
boolean |
ReversedKeyValueHeap.reseek(KeyValue seekKey) |
boolean |
StoreFileScanner.reseek(KeyValue key) |
boolean |
KeyValueHeap.reseek(KeyValue seekKey)
This function is identical to the
KeyValueHeap.seek(KeyValue) function except
that scanner.seek(seekKey) is changed to scanner.reseek(seekKey). |
boolean |
KeyValueScanner.reseek(KeyValue key)
Reseek the scanner at or after the specified KeyValue.
|
boolean |
MemStore.MemStoreScanner.reseek(KeyValue key)
Move forward on the sub-lists set previously by seek.
|
protected void |
StoreScanner.resetScannerStack(KeyValue lastTopKey) |
protected boolean |
HRegion.restoreEdit(Store s,
KeyValue kv)
Used by tests
|
void |
Store.rollback(KeyValue kv)
Removes a kv from the memstore.
|
void |
HStore.rollback(KeyValue kv) |
boolean |
StoreScanner.seek(KeyValue key) |
boolean |
ReversedKeyValueHeap.seek(KeyValue seekKey) |
boolean |
StoreFileScanner.seek(KeyValue key) |
boolean |
KeyValueHeap.seek(KeyValue seekKey)
Seeks all scanners at or below the specified seek key.
|
boolean |
KeyValueScanner.seek(KeyValue key)
Seek the scanner at or after the specified KeyValue.
|
boolean |
MemStore.MemStoreScanner.seek(KeyValue key)
Set the scanner at the seek key.
|
protected boolean |
StoreScanner.seekAsDirection(KeyValue kv)
Do a reseek in a normal StoreScanner(scan forward)
|
static boolean |
StoreFileScanner.seekAtOrAfter(HFileScanner s,
KeyValue k) |
protected void |
StoreScanner.seekScanners(List<? extends KeyValueScanner> scanners,
KeyValue seekKey,
boolean isLazy,
boolean isParallelSeek)
Seek the specified scanners with the given key
|
protected boolean |
StoreScanner.seekToNextRow(KeyValue kv) |
boolean |
NonReversedNonLazyKeyValueScanner.seekToPreviousRow(KeyValue key) |
boolean |
ReversedKeyValueHeap.seekToPreviousRow(KeyValue seekKey) |
boolean |
StoreFileScanner.seekToPreviousRow(KeyValue key) |
boolean |
KeyValueScanner.seekToPreviousRow(KeyValue key)
Seek the scanner at the first KeyValue of the row which is the previous row
of specified key
|
boolean |
MemStore.MemStoreScanner.seekToPreviousRow(KeyValue key)
Separately get the KeyValue before the specified key from kvset and
snapshotset, and use the row of higher one as the previous row of
specified key, then seek to the first KeyValue of previous row
|
NavigableSet<KeyValue> |
KeyValueSkipListSet.subSet(KeyValue fromElement,
boolean fromInclusive,
KeyValue toElement,
boolean toInclusive) |
SortedSet<KeyValue> |
KeyValueSkipListSet.subSet(KeyValue fromElement,
KeyValue toElement) |
SortedSet<KeyValue> |
KeyValueSkipListSet.tailSet(KeyValue fromElement) |
NavigableSet<KeyValue> |
KeyValueSkipListSet.tailSet(KeyValue fromElement,
boolean inclusive) |
void |
StoreFile.Writer.trackTimestamps(KeyValue kv)
Record the earlest Put timestamp.
|
Iterator<StoreFile> |
StoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator<StoreFile> candidateFiles,
KeyValue targetKey,
KeyValue candidate)
Updates the candidate list for finding row key before.
|
Iterator<StoreFile> |
StripeStoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator<StoreFile> candidateFiles,
KeyValue targetKey,
KeyValue candidate)
See
StoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue) and
StoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator, KeyValue, KeyValue)
for details on this methods. |
Modifier and Type | Method and Description |
---|---|
boolean |
KeyValueSkipListSet.addAll(Collection<? extends KeyValue> c) |
protected List<org.apache.hadoop.fs.Path> |
HStore.flushCache(long logCacheFlushId,
SortedSet<KeyValue> snapshot,
TimeRangeTracker snapshotTimeRangeTracker,
AtomicLong flushedSize,
MonitoredTask status)
Write out current snapshot.
|
List<org.apache.hadoop.fs.Path> |
DefaultStoreFlusher.flushSnapshot(SortedSet<KeyValue> snapshot,
long cacheFlushId,
TimeRangeTracker snapshotTimeRangeTracker,
AtomicLong flushedSize,
MonitoredTask status) |
List<org.apache.hadoop.fs.Path> |
StripeStoreFlusher.flushSnapshot(SortedSet<KeyValue> snapshot,
long cacheFlushSeqNum,
TimeRangeTracker tracker,
AtomicLong flushedSize,
MonitoredTask status) |
Modifier and Type | Method and Description |
---|---|
void |
Compactor.CellSink.append(KeyValue kv) |
Constructor and Description |
---|
ParallelSeekHandler(KeyValueScanner scanner,
KeyValue keyValue,
long readPoint,
CountDownLatch latch) |
Modifier and Type | Method and Description |
---|---|
ArrayList<KeyValue> |
WALEdit.getKeyValues()
Deprecated.
Use
WALEdit.getCells() instead |
Modifier and Type | Method and Description |
---|---|
WALEdit |
WALEdit.add(KeyValue kv)
Deprecated.
Use
WALEdit.add(Cell) instead |
Constructor and Description |
---|
CellModel(KeyValue kv)
Constructor from KeyValue
|
Modifier and Type | Method and Description |
---|---|
boolean |
TablePermission.implies(TableName table,
KeyValue kv,
Permission.Action action)
Checks if this permission grants access to perform the given action on
the given table and key value.
|
Modifier and Type | Method and Description |
---|---|
KeyValue |
CollectionBackedScanner.next() |
KeyValue |
CollectionBackedScanner.peek() |
Modifier and Type | Method and Description |
---|---|
boolean |
CollectionBackedScanner.reseek(KeyValue seekKv) |
boolean |
CollectionBackedScanner.seek(KeyValue seekKv) |
Constructor and Description |
---|
CollectionBackedScanner(KeyValue.KVComparator comparator,
KeyValue... array) |
Constructor and Description |
---|
CollectionBackedScanner(List<KeyValue> list) |
CollectionBackedScanner(List<KeyValue> list,
KeyValue.KVComparator comparator) |
CollectionBackedScanner(SortedSet<KeyValue> set) |
CollectionBackedScanner(SortedSet<KeyValue> set,
KeyValue.KVComparator comparator) |
Modifier and Type | Method and Description |
---|---|
List<KeyValue> |
RedundantKVGenerator.generateTestKeyValues(int howMany)
Generate test data useful to test encoders.
|
List<KeyValue> |
RedundantKVGenerator.generateTestKeyValues(int howMany,
boolean useTags)
Generate test data useful to test encoders.
|
Modifier and Type | Method and Description |
---|---|
static ByteBuffer |
RedundantKVGenerator.convertKvToByteBuffer(List<KeyValue> keyValues,
boolean includesMemstoreTS)
Convert list of KeyValues to byte buffer.
|
Copyright © 2014 The Apache Software Foundation. All rights reserved.