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 | 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
|
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 |
---|---|
static Comparator<StoreFile> |
StoreFile.Comparators.SEQ_ID
Comparator that compares based on the Sequence Ids of the
the StoreFiles.
|
Modifier and Type | Method and Description |
---|---|
com.google.common.collect.ImmutableCollection<StoreFile> |
StripeStoreFileManager.clearFiles() |
com.google.common.collect.ImmutableCollection<StoreFile> |
StoreFileManager.clearFiles()
Clears all the files currently in use and returns them.
|
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.
|
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) |
Iterator<StoreFile> |
StripeStoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue targetKey)
See
StoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue)
for details on this methods. |
Iterator<StoreFile> |
StoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue targetKey)
Gets initial, full list of candidate store files to check for row-key-before.
|
Collection<StoreFile> |
StripeStoreFileManager.getFilesForScanOrGet(boolean isGet,
byte[] startRow,
byte[] stopRow) |
Collection<StoreFile> |
StoreFileManager.getFilesForScanOrGet(boolean isGet,
byte[] startRow,
byte[] stopRow)
Gets the store files to scan for a Scan or Get request.
|
List<StoreFile> |
StripeStoreFileManager.getLevel0Files() |
Collection<StoreFile> |
StripeStoreFileManager.getStorefiles() |
Collection<StoreFile> |
StoreFileManager.getStorefiles()
Gets the snapshot of the store files currently in use.
|
Collection<StoreFile> |
Store.getStorefiles() |
Collection<StoreFile> |
HStore.getStorefiles() |
ArrayList<com.google.common.collect.ImmutableList<StoreFile>> |
StripeStoreFileManager.getStripes() |
Collection<StoreFile> |
StripeStoreFileManager.getUnneededFiles(long maxTs,
List<StoreFile> filesCompacting) |
Collection<StoreFile> |
StoreFileManager.getUnneededFiles(long maxTs,
List<StoreFile> filesCompacting) |
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. |
Iterator<StoreFile> |
StoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator<StoreFile> candidateFiles,
KeyValue targetKey,
Cell candidate)
Updates the candidate list for finding row key before.
|
Modifier and Type | Method and Description |
---|---|
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
|
Modifier and Type | Method and Description |
---|---|
void |
StripeStoreFileManager.addCompactionResults(Collection<StoreFile> compactedFiles,
Collection<StoreFile> results) |
void |
StripeStoreFileManager.addCompactionResults(Collection<StoreFile> compactedFiles,
Collection<StoreFile> results) |
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.
|
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.
|
static Integer |
StoreUtils.getDeterministicRandomSeed(Collection<StoreFile> files)
Creates a deterministic hash code for store file collection.
|
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,
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,
ScanQueryMatcher matcher,
long readPt)
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> |
StripeStoreFileManager.getUnneededFiles(long maxTs,
List<StoreFile> filesCompacting) |
Collection<StoreFile> |
StoreFileManager.getUnneededFiles(long maxTs,
List<StoreFile> filesCompacting) |
static boolean |
StoreUtils.hasReferences(Collection<StoreFile> files)
Determines whether any files in the collection are references.
|
void |
StripeStoreFileManager.insertNewFiles(Collection<StoreFile> sfs) |
void |
StoreFileManager.insertNewFiles(Collection<StoreFile> sfs)
Adds new files, either for from MemStore flush or bulk insert, into the structure.
|
void |
StripeStoreFileManager.loadFiles(List<StoreFile> storeFiles) |
void |
StoreFileManager.loadFiles(List<StoreFile> storeFiles)
Loads the initial store files into empty StoreFileManager.
|
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. |
void |
HRegionFileSystem.removeStoreFiles(String familyName,
Collection<StoreFile> storeFiles)
Closes and archives the specified store files from the specified family.
|
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. |
Iterator<StoreFile> |
StoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator<StoreFile> candidateFiles,
KeyValue targetKey,
Cell candidate)
Updates the candidate list for finding row key before.
|
Constructor and Description |
---|
StoreFile(StoreFile other)
Clone
|
Modifier and Type | Method and Description |
---|---|
List<StoreFile> |
ExploringCompactionPolicy.applyCompactionPolicy(List<StoreFile> candidates,
boolean mightBeStuck,
boolean mayUseOffPeak,
int minFiles,
int maxFiles) |
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) |
Modifier and Type | Method and Description |
---|---|
List<StoreFile> |
ExploringCompactionPolicy.applyCompactionPolicy(List<StoreFile> candidates,
boolean mightBeStuck,
boolean mayUseOffPeak,
int minFiles,
int maxFiles) |
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)
Creates file scanners for compaction.
|
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) |
boolean |
StripeCompactionPolicy.isMajorCompaction(Collection<StoreFile> filesToCompact) |
boolean |
RatioBasedCompactionPolicy.isMajorCompaction(Collection<StoreFile> filesToCompact) |
abstract boolean |
CompactionPolicy.isMajorCompaction(Collection<StoreFile> filesToCompact) |
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) |
abstract boolean |
CompactionContext.select(List<StoreFile> filesCompacting,
boolean isUserCompaction,
boolean mayUseOffPeak,
boolean forceMajor)
Called to select files for compaction.
|
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) |
Constructor and Description |
---|
CompactionRequest(Collection<StoreFile> files) |
Copyright © 2007-2016 The Apache Software Foundation. All Rights Reserved.