@InterfaceAudience.LimitedPrivate(value="Coprocesssor")
@InterfaceStability.Evolving
public interface StoreFile
Modifier and Type | Field and Description |
---|---|
static byte[] |
BLOOM_FILTER_TYPE_KEY
Bloom filter Type in FileInfo
|
static byte[] |
BULKLOAD_TASK_KEY
Meta key set when store file is a result of a bulk load
|
static byte[] |
BULKLOAD_TIME_KEY |
static byte[] |
DELETE_FAMILY_COUNT
Delete Family Count in FileInfo
|
static byte[] |
EARLIEST_PUT_TS
Key for timestamp of earliest-put in metadata
|
static byte[] |
EXCLUDE_FROM_MINOR_COMPACTION_KEY
Minor compaction flag in FileInfo
|
static byte[] |
LAST_BLOOM_KEY
Last Bloom filter key in FileInfo
|
static byte[] |
MAJOR_COMPACTION_KEY
Major compaction flag in FileInfo
|
static byte[] |
MAX_SEQ_ID_KEY
Max Sequence ID in FileInfo
|
static byte[] |
MOB_CELLS_COUNT
Key for the number of mob cells in metadata
|
static byte[] |
SKIP_RESET_SEQ_ID
Key for skipping resetting sequence id in metadata.
|
static String |
STORE_FILE_READER_NO_READAHEAD |
static byte[] |
TIMERANGE_KEY
Key for Timerange information in metadata
|
Modifier and Type | Method and Description |
---|---|
void |
closeReader(boolean evictOnClose) |
void |
deleteReader()
Delete this file
|
boolean |
excludeFromMinorCompaction() |
OptionalLong |
getBulkLoadTimestamp()
Return the timestamp at which this bulk load file was generated.
|
CacheConfig |
getCacheConf() |
Comparator<Cell> |
getComparator() |
StoreFileInfo |
getFileInfo() |
Cell |
getFirstKey() |
HDFSBlocksDistribution |
getHDFSBlockDistribution() |
Cell |
getLastKey() |
OptionalLong |
getMaximumTimestamp() |
long |
getMaxMemstoreTS() |
long |
getMaxSequenceId() |
byte[] |
getMetadataValue(byte[] key)
Only used by the Striped Compaction Policy
|
OptionalLong |
getMinimumTimestamp() |
long |
getModificationTimeStamp() |
org.apache.hadoop.fs.Path |
getPath() |
StoreFileScanner |
getPreadScanner(boolean cacheBlocks,
long readPt,
long scannerOrder,
boolean canOptimizeForNonNullColumn)
Must be called after initReader.
|
org.apache.hadoop.fs.Path |
getQualifiedPath() |
StoreFileReader |
getReader() |
StoreFileScanner |
getStreamScanner(boolean canUseDropBehind,
boolean cacheBlocks,
boolean isCompaction,
long readPt,
long scannerOrder,
boolean canOptimizeForNonNullColumn) |
void |
initReader()
Initialize the reader used for pread.
|
boolean |
isBulkLoadResult()
Check if this storefile was created by bulk load.
|
boolean |
isCompactedAway() |
boolean |
isHFile() |
boolean |
isMajorCompactionResult() |
boolean |
isReference() |
boolean |
isReferencedInReads() |
void |
markCompactedAway()
Marks the status of the file as compactedAway.
|
String |
toStringDetailed() |
static final String STORE_FILE_READER_NO_READAHEAD
static final byte[] MAX_SEQ_ID_KEY
static final byte[] MAJOR_COMPACTION_KEY
static final byte[] EXCLUDE_FROM_MINOR_COMPACTION_KEY
static final byte[] BLOOM_FILTER_TYPE_KEY
static final byte[] DELETE_FAMILY_COUNT
static final byte[] LAST_BLOOM_KEY
static final byte[] TIMERANGE_KEY
static final byte[] EARLIEST_PUT_TS
static final byte[] MOB_CELLS_COUNT
static final byte[] BULKLOAD_TASK_KEY
static final byte[] BULKLOAD_TIME_KEY
static final byte[] SKIP_RESET_SEQ_ID
CacheConfig getCacheConf()
Cell getFirstKey()
Cell getLastKey()
Comparator<Cell> getComparator()
long getMaxMemstoreTS()
StoreFileInfo getFileInfo()
org.apache.hadoop.fs.Path getPath()
org.apache.hadoop.fs.Path getQualifiedPath()
boolean isReference()
boolean isHFile()
boolean isMajorCompactionResult()
boolean excludeFromMinorCompaction()
long getMaxSequenceId()
long getModificationTimeStamp() throws IOException
IOException
byte[] getMetadataValue(byte[] key)
key
- boolean isBulkLoadResult()
'_SeqId_<id-when-loaded>'
to the hfile name, unless
"hbase.mapreduce.bulkload.assign.sequenceNumbers" is explicitly turned off. If
"hbase.mapreduce.bulkload.assign.sequenceNumbers" is turned off, fall back to
BULKLOAD_TIME_KEY.boolean isCompactedAway()
boolean isReferencedInReads()
OptionalLong getBulkLoadTimestamp()
HDFSBlocksDistribution getHDFSBlockDistribution()
void initReader() throws IOException
IOException
StoreFileScanner getPreadScanner(boolean cacheBlocks, long readPt, long scannerOrder, boolean canOptimizeForNonNullColumn)
StoreFileScanner getStreamScanner(boolean canUseDropBehind, boolean cacheBlocks, boolean isCompaction, long readPt, long scannerOrder, boolean canOptimizeForNonNullColumn) throws IOException
IOException
StoreFileReader getReader()
initReader()
void closeReader(boolean evictOnClose) throws IOException
evictOnClose
- whether to evict blocks belonging to this fileIOException
void markCompactedAway()
void deleteReader() throws IOException
IOException
String toStringDetailed()
OptionalLong getMinimumTimestamp()
OptionalLong getMaximumTimestamp()
Copyright © 2007–2017 The Apache Software Foundation. All rights reserved.