Package | Description |
---|---|
org.apache.hadoop.hbase.backup | |
org.apache.hadoop.hbase.coprocessor |
Table of Contents
|
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.regionserver.compactions |
Modifier and Type | Field and Description |
---|---|
(package private) StoreFile |
HFileArchiver.FileableStoreFile.file |
Modifier and Type | Method and Description |
---|---|
HFileArchiver.File |
HFileArchiver.StoreToFile.apply(StoreFile input) |
Modifier and Type | Method and Description |
---|---|
static void |
HFileArchiver.archiveStoreFiles(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
HRegionInfo regionInfo,
org.apache.hadoop.fs.Path tableDir,
byte[] family,
Collection<StoreFile> compactedFiles)
Remove the store files, either by archiving them or outright deletion
|
private static void |
HFileArchiver.deleteStoreFilesWithoutArchiving(Collection<StoreFile> compactedFiles)
Just do a simple delete of the given store files
|
Constructor and Description |
---|
HFileArchiver.FileableStoreFile(org.apache.hadoop.fs.FileSystem fs,
StoreFile store) |
Modifier and Type | Method and Description |
---|---|
void |
RegionObserver.postCompact(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
StoreFile resultFile)
Deprecated.
|
void |
BaseRegionObserver.postCompact(ObserverContext<RegionCoprocessorEnvironment> e,
Store store,
StoreFile resultFile) |
void |
RegionObserver.postCompact(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
StoreFile resultFile,
CompactionRequest request)
Called after compaction has completed and the new store file has been moved in to place.
|
void |
BaseRegionObserver.postCompact(ObserverContext<RegionCoprocessorEnvironment> e,
Store store,
StoreFile resultFile,
CompactionRequest request) |
void |
RegionObserver.postFlush(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
StoreFile resultFile)
Called after a Store's memstore is flushed to disk.
|
void |
BaseRegionObserver.postFlush(ObserverContext<RegionCoprocessorEnvironment> e,
Store store,
StoreFile resultFile) |
Modifier and Type | Method and Description |
---|---|
void |
RegionObserver.postCompactSelection(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
com.google.common.collect.ImmutableList<StoreFile> selected)
Deprecated.
|
void |
BaseRegionObserver.postCompactSelection(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
com.google.common.collect.ImmutableList<StoreFile> selected) |
void |
RegionObserver.postCompactSelection(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
com.google.common.collect.ImmutableList<StoreFile> selected,
CompactionRequest request)
Called after the
StoreFile s to compact have been selected from the available
candidates. |
void |
BaseRegionObserver.postCompactSelection(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
com.google.common.collect.ImmutableList<StoreFile> selected,
CompactionRequest request) |
void |
RegionObserver.preCompactSelection(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
List<StoreFile> candidates)
Deprecated.
|
void |
BaseRegionObserver.preCompactSelection(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
List<StoreFile> candidates) |
void |
RegionObserver.preCompactSelection(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
List<StoreFile> candidates,
CompactionRequest request)
Called prior to selecting the
StoreFiles to compact from the list of
available candidates. |
void |
BaseRegionObserver.preCompactSelection(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
List<StoreFile> candidates,
CompactionRequest request) |
Modifier and Type | Field and Description |
---|---|
private StoreFile |
SplitTransactionImpl.StoreFileSplitter.sf |
Modifier and Type | Field and Description |
---|---|
com.google.common.collect.ImmutableList<StoreFile> |
StripeStoreFileManager.State.allFilesCached
Cached list of all files in the structure, to return from some calls
|
private Collection<StoreFile> |
StripeStoreFileManager.CompactionOrFlushMergeCopy.compactedFiles |
private HashMap<StoreFile,byte[]> |
StripeStoreFileManager.fileEnds |
private List<StoreFile> |
HStore.filesCompacting |
private HashMap<StoreFile,byte[]> |
StripeStoreFileManager.fileStarts
Cached file metadata (or overrides as the case may be)
|
private List<StoreFile> |
StripeStoreFileManager.CompactionOrFlushMergeCopy.l0Results |
com.google.common.collect.ImmutableList<StoreFile> |
StripeStoreFileManager.State.level0Files
Level 0.
|
private ArrayList<StoreFile> |
StripeStoreFileManager.CompactionOrFlushMergeCopy.level0Files |
private Collection<StoreFile> |
StripeStoreFileManager.CompactionOrFlushMergeCopy.results |
static Comparator<StoreFile> |
StoreFile.Comparators.SEQ_ID
Comparator that compares based on the Sequence Ids of the
the StoreFiles.
|
private com.google.common.collect.ImmutableList<StoreFile> |
DefaultStoreFileManager.storefiles
List of store files inside this store.
|
ArrayList<com.google.common.collect.ImmutableList<StoreFile>> |
StripeStoreFileManager.State.stripeFiles
Files by stripe.
|
private ArrayList<List<StoreFile>> |
StripeStoreFileManager.CompactionOrFlushMergeCopy.stripeFiles |
Modifier and Type | Method and Description |
---|---|
private StoreFile |
HStore.commitFile(org.apache.hadoop.fs.Path path,
long logCacheFlushId,
MonitoredTask status) |
private StoreFile |
HStore.createStoreFileAndReader(org.apache.hadoop.fs.Path p) |
private StoreFile |
HStore.createStoreFileAndReader(StoreFileInfo info) |
(package private) static StoreFile |
StoreUtils.getLargestFile(Collection<StoreFile> candidates)
Gets the largest file (with reader) out of the list of files.
|
(package private) StoreFile |
HStore.moveFileIntoPlace(org.apache.hadoop.fs.Path newFile) |
Modifier and Type | Method and Description |
---|---|
com.google.common.collect.ImmutableCollection<StoreFile> |
StoreFileManager.clearFiles()
Clears all the files currently in use and returns them.
|
com.google.common.collect.ImmutableCollection<StoreFile> |
DefaultStoreFileManager.clearFiles() |
com.google.common.collect.ImmutableCollection<StoreFile> |
StripeStoreFileManager.clearFiles() |
Collection<StoreFile> |
Store.close()
Close all the readers We don't need to worry about subsequent requests because the Region
holds a write lock that will prevent any more reads or writes.
|
com.google.common.collect.ImmutableCollection<StoreFile> |
HStore.close() |
Map<byte[],List<StoreFile>> |
HRegion.close()
Close down this HRegion.
|
Map<byte[],List<StoreFile>> |
HRegion.close(boolean abort)
Close down this HRegion.
|
private Map<byte[],List<StoreFile>> |
RegionMergeTransactionImpl.closeAndOfflineRegion(RegionServerServices services,
HRegion region,
boolean isRegionA,
boolean testing)
Close the merging region and offline it in regionserver
|
List<StoreFile> |
Store.compact(CompactionContext compaction,
CompactionThroughputController throughputController)
Deprecated.
see compact(CompactionContext, CompactionThroughputController, User)
|
List<StoreFile> |
HStore.compact(CompactionContext compaction,
CompactionThroughputController throughputController)
Compact the StoreFiles.
|
List<StoreFile> |
Store.compact(CompactionContext compaction,
CompactionThroughputController throughputController,
User user) |
List<StoreFile> |
HStore.compact(CompactionContext compaction,
CompactionThroughputController throughputController,
User user) |
private Map<byte[],List<StoreFile>> |
HRegion.doClose(boolean abort,
MonitoredTask status) |
private Collection<StoreFile> |
StripeStoreFileManager.findExpiredFiles(com.google.common.collect.ImmutableList<StoreFile> stripe,
long maxTs,
List<StoreFile> filesCompacting,
Collection<StoreFile> expiredStoreFiles) |
Iterator<StoreFile> |
StoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue targetKey)
Gets initial, full list of candidate store files to check for row-key-before.
|
Iterator<StoreFile> |
DefaultStoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue targetKey) |
Iterator<StoreFile> |
StripeStoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue targetKey)
See
StoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue)
for details on this methods. |
ArrayList<List<StoreFile>> |
StripeStoreFileManager.KeyBeforeConcatenatedLists.Iterator.getComponents() |
Collection<StoreFile> |
StoreFileManager.getFilesForScanOrGet(boolean isGet,
byte[] startRow,
byte[] stopRow)
Gets the store files to scan for a Scan or Get request.
|
Collection<StoreFile> |
DefaultStoreFileManager.getFilesForScanOrGet(boolean isGet,
byte[] startRow,
byte[] stopRow) |
Collection<StoreFile> |
StripeStoreFileManager.getFilesForScanOrGet(boolean isGet,
byte[] startRow,
byte[] stopRow) |
private ArrayList<StoreFile> |
StripeStoreFileManager.CompactionOrFlushMergeCopy.getLevel0Copy() |
List<StoreFile> |
StripeStoreFileManager.getLevel0Files() |
Collection<StoreFile> |
StoreFileManager.getStorefiles()
Gets the snapshot of the store files currently in use.
|
Collection<StoreFile> |
DefaultStoreFileManager.getStorefiles() |
Collection<StoreFile> |
Store.getStorefiles() |
Collection<StoreFile> |
StripeStoreFileManager.getStorefiles() |
Collection<StoreFile> |
HStore.getStorefiles() |
private ArrayList<StoreFile> |
StripeStoreFileManager.CompactionOrFlushMergeCopy.getStripeCopy(int index) |
ArrayList<com.google.common.collect.ImmutableList<StoreFile>> |
StripeStoreFileManager.getStripes() |
Collection<StoreFile> |
StoreFileManager.getUnneededFiles(long maxTs,
List<StoreFile> filesCompacting) |
Collection<StoreFile> |
DefaultStoreFileManager.getUnneededFiles(long maxTs,
List<StoreFile> filesCompacting) |
Collection<StoreFile> |
StripeStoreFileManager.getUnneededFiles(long maxTs,
List<StoreFile> filesCompacting) |
Iterator<StoreFile> |
StripeStoreFileManager.KeyBeforeConcatenatedLists.iterator() |
private List<StoreFile> |
HStore.loadStoreFiles()
Creates an unsorted list of StoreFile loaded in parallel
from the given directory.
|
private List<StoreFile> |
HStore.moveCompatedFilesIntoPlace(CompactionRequest cr,
List<org.apache.hadoop.fs.Path> newFiles,
User user) |
private List<StoreFile> |
HStore.openStoreFiles(Collection<StoreFileInfo> files) |
List<StoreFile> |
StripeStoreEngine.StripeCompaction.preSelect(List<StoreFile> filesCompacting) |
List<StoreFile> |
DefaultStoreEngine.DefaultCompactionContext.preSelect(List<StoreFile> filesCompacting) |
private TreeMap<byte[],StoreFile> |
StripeStoreFileManager.CompactionOrFlushMergeCopy.processResults()
Process new files, and add them either to the structure of existing stripes,
or to the list of new candidate stripes.
|
Iterator<StoreFile> |
StoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator<StoreFile> candidateFiles,
KeyValue targetKey,
Cell candidate)
Updates the candidate list for finding row key before.
|
Iterator<StoreFile> |
DefaultStoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator<StoreFile> candidateFiles,
KeyValue targetKey,
Cell candidate) |
Iterator<StoreFile> |
StripeStoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator<StoreFile> candidateFiles,
KeyValue targetKey,
Cell candidate)
See
StoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue) and
StoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator, KeyValue, Cell)
for details on this methods. |
Modifier and Type | Method and Description |
---|---|
Long |
StoreFile.Comparators.GetSeqId.apply(StoreFile sf) |
Long |
StoreFile.Comparators.GetFileSize.apply(StoreFile sf) |
Long |
StoreFile.Comparators.GetBulkTime.apply(StoreFile sf) |
String |
StoreFile.Comparators.GetPathName.apply(StoreFile sf) |
private void |
HStore.bulkLoadHFile(StoreFile sf) |
private byte[] |
StripeStoreFileManager.endOf(StoreFile sf) |
private void |
StripeStoreFileManager.ensureLevel0Metadata(StoreFile sf) |
private static void |
StripeStoreFileManager.insertFileIntoStripe(ArrayList<StoreFile> stripe,
StoreFile sf)
Inserts a file in the correct place (by seqnum) in a stripe copy.
|
(package private) org.apache.hadoop.fs.Path |
HRegionFileSystem.mergeStoreFile(HRegionInfo mergedRegion,
String familyName,
StoreFile f,
org.apache.hadoop.fs.Path mergedDir)
Write out a merge reference under the given merges directory.
|
void |
RegionCoprocessorHost.postCompact(Store store,
StoreFile resultFile,
CompactionRequest request)
Called after the store compaction has completed.
|
void |
RegionCoprocessorHost.postFlush(Store store,
StoreFile storeFile)
Invoked after a memstore flush
|
private boolean |
HStore.rowAtOrBeforeFromStoreFile(StoreFile f,
GetClosestRowBeforeTracker state) |
private Pair<org.apache.hadoop.fs.Path,org.apache.hadoop.fs.Path> |
SplitTransactionImpl.splitStoreFile(byte[] family,
StoreFile sf) |
(package private) org.apache.hadoop.fs.Path |
HRegionFileSystem.splitStoreFile(HRegionInfo hri,
String familyName,
StoreFile f,
byte[] splitRow,
boolean top,
RegionSplitPolicy splitPolicy)
Write out a split reference.
|
private byte[] |
StripeStoreFileManager.startOf(StoreFile sf) |
Modifier and Type | Method and Description |
---|---|
void |
StoreFileManager.addCompactionResults(Collection<StoreFile> compactedFiles,
Collection<StoreFile> results)
Adds compaction results into the structure.
|
void |
StoreFileManager.addCompactionResults(Collection<StoreFile> compactedFiles,
Collection<StoreFile> results)
Adds compaction results into the structure.
|
void |
DefaultStoreFileManager.addCompactionResults(Collection<StoreFile> compactedFiles,
Collection<StoreFile> results) |
void |
DefaultStoreFileManager.addCompactionResults(Collection<StoreFile> compactedFiles,
Collection<StoreFile> results) |
void |
StripeStoreFileManager.addCompactionResults(Collection<StoreFile> compactedFiles,
Collection<StoreFile> results) |
void |
StripeStoreFileManager.addCompactionResults(Collection<StoreFile> compactedFiles,
Collection<StoreFile> results) |
private void |
HStore.addToCompactingFiles(Collection<StoreFile> filesToAdd)
Adds the files to compacting files.
|
(package private) void |
HRegionFileSystem.commitStoreFiles(Map<byte[],List<StoreFile>> storeFiles)
Moves multiple store files to the relative region's family store directory.
|
protected void |
HStore.completeCompaction(Collection<StoreFile> compactedFiles)
It works by processing a compaction that's been written to disk.
|
protected void |
HStore.completeCompaction(Collection<StoreFile> compactedFiles,
boolean removeFiles)
It works by processing a compaction that's been written to disk.
|
private void |
StripeStoreFileManager.ensureEdgeStripeMetadata(ArrayList<StoreFile> stripe,
boolean isFirst) |
private Collection<StoreFile> |
StripeStoreFileManager.findExpiredFiles(com.google.common.collect.ImmutableList<StoreFile> stripe,
long maxTs,
List<StoreFile> filesCompacting,
Collection<StoreFile> expiredStoreFiles) |
private Collection<StoreFile> |
StripeStoreFileManager.findExpiredFiles(com.google.common.collect.ImmutableList<StoreFile> stripe,
long maxTs,
List<StoreFile> filesCompacting,
Collection<StoreFile> expiredStoreFiles) |
private Collection<StoreFile> |
StripeStoreFileManager.findExpiredFiles(com.google.common.collect.ImmutableList<StoreFile> stripe,
long maxTs,
List<StoreFile> filesCompacting,
Collection<StoreFile> expiredStoreFiles) |
static Integer |
StoreUtils.getDeterministicRandomSeed(Collection<StoreFile> files)
Creates a deterministic hash code for store file collection.
|
(package private) static StoreFile |
StoreUtils.getLargestFile(Collection<StoreFile> candidates)
Gets the largest file (with reader) out of the list of files.
|
static long |
StoreUtils.getLowestTimestamp(Collection<StoreFile> candidates)
Gets lowest timestamp from candidate StoreFiles
|
static long |
StoreFile.getMaxMemstoreTSInList(Collection<StoreFile> sfs)
Return the largest memstoreTS found across all storefiles in
the given list.
|
static long |
StoreFile.getMaxSequenceIdInList(Collection<StoreFile> sfs)
Return the highest sequence ID found across all storefiles in
the given list.
|
static List<StoreFileScanner> |
StoreFileScanner.getScannersForStoreFiles(Collection<StoreFile> files,
boolean cacheBlocks,
boolean usePread,
boolean isCompaction,
boolean useDropBehind,
long readPt)
Return an array of scanners corresponding to the given set of store files.
|
static List<StoreFileScanner> |
StoreFileScanner.getScannersForStoreFiles(Collection<StoreFile> files,
boolean cacheBlocks,
boolean usePread,
boolean isCompaction,
boolean canUseDrop,
ScanQueryMatcher matcher,
long readPt) |
static List<StoreFileScanner> |
StoreFileScanner.getScannersForStoreFiles(Collection<StoreFile> files,
boolean cacheBlocks,
boolean usePread,
boolean isCompaction,
boolean canUseDrop,
ScanQueryMatcher matcher,
long readPt,
boolean isPrimaryReplica)
Return an array of scanners corresponding to the given set of store files,
And set the ScanQueryMatcher for each store file scanner for further
optimization
|
static List<StoreFileScanner> |
StoreFileScanner.getScannersForStoreFiles(Collection<StoreFile> files,
boolean cacheBlocks,
boolean usePread,
long readPt)
Return an array of scanners corresponding to the given
set of store files.
|
Collection<StoreFile> |
StoreFileManager.getUnneededFiles(long maxTs,
List<StoreFile> filesCompacting) |
Collection<StoreFile> |
DefaultStoreFileManager.getUnneededFiles(long maxTs,
List<StoreFile> filesCompacting) |
Collection<StoreFile> |
StripeStoreFileManager.getUnneededFiles(long maxTs,
List<StoreFile> filesCompacting) |
static boolean |
StoreUtils.hasReferences(Collection<StoreFile> files)
Determines whether any files in the collection are references.
|
private static void |
StripeStoreFileManager.insertFileIntoStripe(ArrayList<StoreFile> stripe,
StoreFile sf)
Inserts a file in the correct place (by seqnum) in a stripe copy.
|
void |
StoreFileManager.insertNewFiles(Collection<StoreFile> sfs)
Adds new files, either for from MemStore flush or bulk insert, into the structure.
|
void |
DefaultStoreFileManager.insertNewFiles(Collection<StoreFile> sfs) |
void |
StripeStoreFileManager.insertNewFiles(Collection<StoreFile> sfs) |
void |
StoreFileManager.loadFiles(List<StoreFile> storeFiles)
Loads the initial store files into empty StoreFileManager.
|
void |
DefaultStoreFileManager.loadFiles(List<StoreFile> storeFiles) |
void |
StripeStoreFileManager.loadFiles(List<StoreFile> storeFiles) |
private void |
StripeStoreFileManager.loadUnclassifiedStoreFiles(List<StoreFile> storeFiles)
Loads initial store files that were picked up from some physical location pertaining to
this store (presumably).
|
private void |
HStore.logCompactionEndMessage(CompactionRequest cr,
List<StoreFile> sfs,
long compactionStartTime)
Log a very elaborate compaction completion message.
|
void |
StripeStoreFileManager.CompactionOrFlushMergeCopy.mergeResults(Collection<StoreFile> compactedFiles,
Collection<StoreFile> results) |
void |
StripeStoreFileManager.CompactionOrFlushMergeCopy.mergeResults(Collection<StoreFile> compactedFiles,
Collection<StoreFile> results) |
private void |
RegionMergeTransactionImpl.mergeStoreFiles(Map<byte[],List<StoreFile>> hstoreFilesOfRegionA,
Map<byte[],List<StoreFile>> hstoreFilesOfRegionB)
Create reference file(s) of merging regions under the region_a merges dir
|
private void |
RegionMergeTransactionImpl.mergeStoreFiles(Map<byte[],List<StoreFile>> hstoreFilesOfRegionA,
Map<byte[],List<StoreFile>> hstoreFilesOfRegionB)
Create reference file(s) of merging regions under the region_a merges dir
|
boolean |
StripeStoreEngine.needsCompaction(List<StoreFile> filesCompacting) |
abstract boolean |
StoreEngine.needsCompaction(List<StoreFile> filesCompacting) |
boolean |
DefaultStoreEngine.needsCompaction(List<StoreFile> filesCompacting) |
void |
RegionCoprocessorHost.postCompactSelection(Store store,
com.google.common.collect.ImmutableList<StoreFile> selected,
CompactionRequest request)
Called after the
StoreFile s to be compacted have been selected from the available
candidates. |
boolean |
RegionCoprocessorHost.preCompactSelection(Store store,
List<StoreFile> candidates,
CompactionRequest request)
Called prior to selecting the
StoreFile s for compaction from the list of currently
available candidates. |
List<StoreFile> |
StripeStoreEngine.StripeCompaction.preSelect(List<StoreFile> filesCompacting) |
List<StoreFile> |
DefaultStoreEngine.DefaultCompactionContext.preSelect(List<StoreFile> filesCompacting) |
private void |
StripeStoreFileManager.CompactionOrFlushMergeCopy.processNewCandidateStripes(TreeMap<byte[],StoreFile> newStripes)
See
StripeStoreFileManager.addCompactionResults(Collection, Collection) - updates the stripe list with
new candidate stripes/removes old stripes; produces new set of stripe end rows. |
void |
HRegionFileSystem.removeStoreFiles(String familyName,
Collection<StoreFile> storeFiles)
Closes and archives the specified store files from the specified family.
|
(package private) void |
HStore.replaceStoreFiles(Collection<StoreFile> compactedFiles,
Collection<StoreFile> result) |
(package private) void |
HStore.replaceStoreFiles(Collection<StoreFile> compactedFiles,
Collection<StoreFile> result) |
boolean |
StripeStoreEngine.StripeCompaction.select(List<StoreFile> filesCompacting,
boolean isUserCompaction,
boolean mayUseOffPeak,
boolean forceMajor) |
boolean |
DefaultStoreEngine.DefaultCompactionContext.select(List<StoreFile> filesCompacting,
boolean isUserCompaction,
boolean mayUseOffPeak,
boolean forceMajor) |
private void |
DefaultStoreFileManager.sortAndSetStoreFiles(List<StoreFile> storeFiles) |
private Pair<Integer,Integer> |
SplitTransactionImpl.splitStoreFiles(Map<byte[],List<StoreFile>> hstoreFilesToSplit)
Creates reference files for top and bottom half of the
|
Iterator<StoreFile> |
StoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator<StoreFile> candidateFiles,
KeyValue targetKey,
Cell candidate)
Updates the candidate list for finding row key before.
|
Iterator<StoreFile> |
DefaultStoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator<StoreFile> candidateFiles,
KeyValue targetKey,
Cell candidate) |
Iterator<StoreFile> |
StripeStoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator<StoreFile> candidateFiles,
KeyValue targetKey,
Cell candidate)
See
StoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue) and
StoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator, KeyValue, Cell)
for details on this methods. |
private boolean |
HStore.updateStorefiles(List<StoreFile> sfs,
long snapshotId) |
private void |
HStore.writeCompactionWalRecord(Collection<StoreFile> filesCompacted,
Collection<StoreFile> newFiles)
Writes the compaction WAL record.
|
private void |
HStore.writeCompactionWalRecord(Collection<StoreFile> filesCompacted,
Collection<StoreFile> newFiles)
Writes the compaction WAL record.
|
Constructor and Description |
---|
SplitTransactionImpl.StoreFileSplitter(byte[] family,
StoreFile sf)
Constructor that takes what it needs to split
|
StoreFile(StoreFile other)
Clone
|
Modifier and Type | Field and Description |
---|---|
private Collection<StoreFile> |
CompactionRequest.filesToCompact |
Modifier and Type | Method and Description |
---|---|
(package private) ArrayList<StoreFile> |
ExploringCompactionPolicy.applyCompactionPolicy(ArrayList<StoreFile> candidates,
boolean mayUseOffPeak,
boolean mightBeStuck) |
(package private) ArrayList<StoreFile> |
RatioBasedCompactionPolicy.applyCompactionPolicy(ArrayList<StoreFile> candidates,
boolean mayUseOffPeak,
boolean mayBeStuck) |
List<StoreFile> |
ExploringCompactionPolicy.applyCompactionPolicy(List<StoreFile> candidates,
boolean mightBeStuck,
boolean mayUseOffPeak,
int minFiles,
int maxFiles) |
private ArrayList<StoreFile> |
RatioBasedCompactionPolicy.checkMinFilesCriteria(ArrayList<StoreFile> candidates) |
private ArrayList<StoreFile> |
RatioBasedCompactionPolicy.filterBulk(ArrayList<StoreFile> candidates) |
private ArrayList<StoreFile> |
RatioBasedCompactionPolicy.getCurrentEligibleFiles(ArrayList<StoreFile> candidateFiles,
List<StoreFile> filesCompacting) |
private Collection<StoreFile> |
FIFOCompactionPolicy.getExpiredStores(Collection<StoreFile> files,
Collection<StoreFile> filesCompacting) |
Collection<StoreFile> |
CompactionRequest.getFiles() |
List<StoreFile> |
StripeCompactionPolicy.StripeInformationProvider.getLevel0Files() |
Collection<StoreFile> |
StripeCompactionPolicy.StripeInformationProvider.getStorefiles() |
ArrayList<com.google.common.collect.ImmutableList<StoreFile>> |
StripeCompactionPolicy.StripeInformationProvider.getStripes() |
abstract List<StoreFile> |
CompactionContext.preSelect(List<StoreFile> filesCompacting)
Called before coprocessor preCompactSelection and should filter the candidates
for coprocessor; i.e.
|
List<StoreFile> |
RatioBasedCompactionPolicy.preSelectCompactionForCoprocessor(Collection<StoreFile> candidates,
List<StoreFile> filesCompacting) |
List<StoreFile> |
StripeCompactionPolicy.preSelectFilesForCoprocessor(StripeCompactionPolicy.StripeInformationProvider si,
List<StoreFile> filesCompacting) |
private ArrayList<StoreFile> |
RatioBasedCompactionPolicy.removeExcessFiles(ArrayList<StoreFile> candidates,
boolean isUserCompaction,
boolean isMajorCompaction) |
private List<StoreFile> |
StripeCompactionPolicy.selectSimpleCompaction(List<StoreFile> sfs,
boolean allFilesOnly,
boolean isOffpeak)
Selects the compaction of a single stripe using default policy.
|
private ArrayList<StoreFile> |
RatioBasedCompactionPolicy.skipLargeFiles(ArrayList<StoreFile> candidates,
boolean mayUseOffpeak) |
Modifier and Type | Method and Description |
---|---|
private boolean |
FIFOCompactionPolicy.isEmptyStoreFile(StoreFile sf)
The FIFOCompactionPolicy only choose those TTL expired HFiles as the compaction candidates.
|
Modifier and Type | Method and Description |
---|---|
(package private) ArrayList<StoreFile> |
ExploringCompactionPolicy.applyCompactionPolicy(ArrayList<StoreFile> candidates,
boolean mayUseOffPeak,
boolean mightBeStuck) |
(package private) ArrayList<StoreFile> |
RatioBasedCompactionPolicy.applyCompactionPolicy(ArrayList<StoreFile> candidates,
boolean mayUseOffPeak,
boolean mayBeStuck) |
List<StoreFile> |
ExploringCompactionPolicy.applyCompactionPolicy(List<StoreFile> candidates,
boolean mightBeStuck,
boolean mayUseOffPeak,
int minFiles,
int maxFiles) |
private ArrayList<StoreFile> |
RatioBasedCompactionPolicy.checkMinFilesCriteria(ArrayList<StoreFile> candidates) |
List<org.apache.hadoop.fs.Path> |
DefaultCompactor.compactForTesting(Collection<StoreFile> filesToCompact,
boolean isMajor)
Compact a list of files for testing.
|
protected List<StoreFileScanner> |
Compactor.createFileScanners(Collection<StoreFile> filesToCompact,
long smallestReadPoint,
boolean useDropBehind)
Creates file scanners for compaction.
|
private Pair<Long,Integer> |
StripeCompactionPolicy.estimateTargetKvs(Collection<StoreFile> files,
double splitCount) |
private boolean |
ExploringCompactionPolicy.filesInRatio(List<StoreFile> files,
double currentRatio)
Check that all files satisfy the constraint
FileSize(i) <= ( Sum(0,N,FileSize(_)) - FileSize(i) ) * Ratio.
|
private ArrayList<StoreFile> |
RatioBasedCompactionPolicy.filterBulk(ArrayList<StoreFile> candidates) |
private ArrayList<StoreFile> |
RatioBasedCompactionPolicy.getCurrentEligibleFiles(ArrayList<StoreFile> candidateFiles,
List<StoreFile> filesCompacting) |
private ArrayList<StoreFile> |
RatioBasedCompactionPolicy.getCurrentEligibleFiles(ArrayList<StoreFile> candidateFiles,
List<StoreFile> filesCompacting) |
private Collection<StoreFile> |
FIFOCompactionPolicy.getExpiredStores(Collection<StoreFile> files,
Collection<StoreFile> filesCompacting) |
private Collection<StoreFile> |
FIFOCompactionPolicy.getExpiredStores(Collection<StoreFile> files,
Collection<StoreFile> filesCompacting) |
protected Compactor.FileDetails |
Compactor.getFileDetails(Collection<StoreFile> filesToCompact,
boolean allFiles)
Extracts some details about the files to compact that are commonly needed by compactors.
|
long |
RatioBasedCompactionPolicy.getNextMajorCompactTime(Collection<StoreFile> filesToCompact) |
static long |
StripeCompactionPolicy.getTotalFileSize(Collection<StoreFile> candidates) |
private static long |
StripeCompactionPolicy.getTotalKvCount(Collection<StoreFile> candidates) |
private long |
ExploringCompactionPolicy.getTotalStoreSize(List<StoreFile> potentialMatchFiles)
Find the total size of a list of store files.
|
private boolean |
FIFOCompactionPolicy.hasExpiredStores(Collection<StoreFile> files) |
private boolean |
ExploringCompactionPolicy.isBetterSelection(List<StoreFile> bestSelection,
long bestSize,
List<StoreFile> selection,
long size,
boolean mightBeStuck) |
private boolean |
ExploringCompactionPolicy.isBetterSelection(List<StoreFile> bestSelection,
long bestSize,
List<StoreFile> selection,
long size,
boolean mightBeStuck) |
boolean |
StripeCompactionPolicy.isMajorCompaction(Collection<StoreFile> filesToCompact) |
boolean |
FIFOCompactionPolicy.isMajorCompaction(Collection<StoreFile> filesToCompact) |
abstract boolean |
CompactionPolicy.isMajorCompaction(Collection<StoreFile> filesToCompact) |
boolean |
RatioBasedCompactionPolicy.isMajorCompaction(Collection<StoreFile> filesToCompact) |
boolean |
FIFOCompactionPolicy.needsCompaction(Collection<StoreFile> storeFiles,
List<StoreFile> filesCompacting) |
boolean |
FIFOCompactionPolicy.needsCompaction(Collection<StoreFile> storeFiles,
List<StoreFile> filesCompacting) |
boolean |
RatioBasedCompactionPolicy.needsCompaction(Collection<StoreFile> storeFiles,
List<StoreFile> filesCompacting) |
boolean |
RatioBasedCompactionPolicy.needsCompaction(Collection<StoreFile> storeFiles,
List<StoreFile> filesCompacting) |
boolean |
StripeCompactionPolicy.needsCompactions(StripeCompactionPolicy.StripeInformationProvider si,
List<StoreFile> filesCompacting) |
abstract List<StoreFile> |
CompactionContext.preSelect(List<StoreFile> filesCompacting)
Called before coprocessor preCompactSelection and should filter the candidates
for coprocessor; i.e.
|
List<StoreFile> |
RatioBasedCompactionPolicy.preSelectCompactionForCoprocessor(Collection<StoreFile> candidates,
List<StoreFile> filesCompacting) |
List<StoreFile> |
RatioBasedCompactionPolicy.preSelectCompactionForCoprocessor(Collection<StoreFile> candidates,
List<StoreFile> filesCompacting) |
List<StoreFile> |
StripeCompactionPolicy.preSelectFilesForCoprocessor(StripeCompactionPolicy.StripeInformationProvider si,
List<StoreFile> filesCompacting) |
private ArrayList<StoreFile> |
RatioBasedCompactionPolicy.removeExcessFiles(ArrayList<StoreFile> candidates,
boolean isUserCompaction,
boolean isMajorCompaction) |
abstract boolean |
CompactionContext.select(List<StoreFile> filesCompacting,
boolean isUserCompaction,
boolean mayUseOffPeak,
boolean forceMajor)
Called to select files for compaction.
|
CompactionRequest |
FIFOCompactionPolicy.selectCompaction(Collection<StoreFile> candidateFiles,
List<StoreFile> filesCompacting,
boolean isUserCompaction,
boolean mayUseOffPeak,
boolean forceMajor) |
CompactionRequest |
FIFOCompactionPolicy.selectCompaction(Collection<StoreFile> candidateFiles,
List<StoreFile> filesCompacting,
boolean isUserCompaction,
boolean mayUseOffPeak,
boolean forceMajor) |
CompactionRequest |
RatioBasedCompactionPolicy.selectCompaction(Collection<StoreFile> candidateFiles,
List<StoreFile> filesCompacting,
boolean isUserCompaction,
boolean mayUseOffPeak,
boolean forceMajor) |
CompactionRequest |
RatioBasedCompactionPolicy.selectCompaction(Collection<StoreFile> candidateFiles,
List<StoreFile> filesCompacting,
boolean isUserCompaction,
boolean mayUseOffPeak,
boolean forceMajor) |
StripeCompactionPolicy.StripeCompactionRequest |
StripeCompactionPolicy.selectCompaction(StripeCompactionPolicy.StripeInformationProvider si,
List<StoreFile> filesCompacting,
boolean isOffpeak) |
private List<StoreFile> |
StripeCompactionPolicy.selectSimpleCompaction(List<StoreFile> sfs,
boolean allFilesOnly,
boolean isOffpeak)
Selects the compaction of a single stripe using default policy.
|
private ArrayList<StoreFile> |
RatioBasedCompactionPolicy.skipLargeFiles(ArrayList<StoreFile> candidates,
boolean mayUseOffpeak) |
Constructor and Description |
---|
CompactionRequest(Collection<StoreFile> files) |
StripeCompactionPolicy.BoundaryStripeCompactionRequest(Collection<StoreFile> files,
List<byte[]> targetBoundaries) |
StripeCompactionPolicy.SplitStripeCompactionRequest(Collection<StoreFile> files,
byte[] startRow,
byte[] endRow,
int targetCount,
long targetKvs) |
StripeCompactionPolicy.SplitStripeCompactionRequest(Collection<StoreFile> files,
byte[] startRow,
byte[] endRow,
long targetKvs) |
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.