Uses of Class
org.apache.hadoop.hbase.regionserver.HStoreFile
Package
Description
-
Uses of org.apache.hadoop.hbase.regionserver.HStoreFile in org.apache.hadoop.hbase.backup
Modifier and TypeMethodDescriptionstatic void
HFileArchiver.archiveRecoveredEdits
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.hbase.client.RegionInfo regionInfo, byte[] family, Collection<org.apache.hadoop.hbase.regionserver.HStoreFile> replayedEdits) Archive recovered edits using existing logic for archiving store files.static void
HFileArchiver.archiveStoreFiles
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.hbase.client.RegionInfo regionInfo, org.apache.hadoop.fs.Path tableDir, byte[] family, Collection<org.apache.hadoop.hbase.regionserver.HStoreFile> compactedFiles) Remove the store files, either by archiving them or outright deletion -
Uses of org.apache.hadoop.hbase.regionserver.HStoreFile in org.apache.hadoop.hbase.mob
Modifier and TypeMethodDescriptionstatic boolean
MobUtils.removeMobFiles
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.fs.Path tableDir, byte[] family, Collection<org.apache.hadoop.hbase.regionserver.HStoreFile> storeFiles) Archives the mob files.ModifierConstructorDescriptionCachedMobFile
(org.apache.hadoop.hbase.regionserver.HStoreFile sf) protected
MobFile
(org.apache.hadoop.hbase.regionserver.HStoreFile sf) -
Uses of org.apache.hadoop.hbase.regionserver.HStoreFile in org.apache.hadoop.hbase.regionserver
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.regionserver.HStoreFile
StoreEngine.createStoreFileAndReader
(org.apache.hadoop.fs.Path p) org.apache.hadoop.hbase.regionserver.HStoreFile
StoreEngine.createStoreFileAndReader
(org.apache.hadoop.hbase.regionserver.StoreFileInfo info) org.apache.hadoop.hbase.regionserver.HStoreFile
HStore.tryCommitRecoveredHFile
(org.apache.hadoop.fs.Path path) Modifier and TypeMethodDescriptionCollection<org.apache.hadoop.hbase.regionserver.HStoreFile>
StoreFileManager.clearCompactedFiles()
Clears all the compacted files and returns them.org.apache.hbase.thirdparty.com.google.common.collect.ImmutableCollection<org.apache.hadoop.hbase.regionserver.HStoreFile>
StripeStoreFileManager.clearCompactedFiles()
org.apache.hbase.thirdparty.com.google.common.collect.ImmutableCollection<org.apache.hadoop.hbase.regionserver.HStoreFile>
StoreFileManager.clearFiles()
Clears all the files currently in use and returns them.org.apache.hbase.thirdparty.com.google.common.collect.ImmutableCollection<org.apache.hadoop.hbase.regionserver.HStoreFile>
StripeStoreFileManager.clearFiles()
HRegion.close()
Close down this HRegion.HRegion.close
(boolean abort) HRegion.close
(boolean abort, boolean ignoreStatus) Close this HRegion.HRegion.close
(boolean abort, boolean ignoreStatus, boolean isGracefulStop) Close down this HRegion.org.apache.hbase.thirdparty.com.google.common.collect.ImmutableCollection<org.apache.hadoop.hbase.regionserver.HStoreFile>
HStore.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.List<org.apache.hadoop.hbase.regionserver.HStoreFile>
StoreEngine.commitStoreFiles
(List<org.apache.hadoop.fs.Path> files, boolean validate) Commit the givenfiles
.List<org.apache.hadoop.hbase.regionserver.HStoreFile>
HStore.compact
(org.apache.hadoop.hbase.regionserver.compactions.CompactionContext compaction, org.apache.hadoop.hbase.regionserver.throttle.ThroughputController throughputController, org.apache.hadoop.hbase.security.User user) Compact the StoreFiles.protected List<org.apache.hadoop.hbase.regionserver.HStoreFile>
HStore.doCompaction
(org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl cr, Collection<org.apache.hadoop.hbase.regionserver.HStoreFile> filesToCompact, org.apache.hadoop.hbase.security.User user, long compactionStartTime, List<org.apache.hadoop.fs.Path> newFiles) Iterator<org.apache.hadoop.hbase.regionserver.HStoreFile>
StoreFileManager.getCandidateFilesForRowKeyBefore
(org.apache.hadoop.hbase.KeyValue targetKey) Gets initial, full list of candidate store files to check for row-key-before.Iterator<org.apache.hadoop.hbase.regionserver.HStoreFile>
StripeStoreFileManager.getCandidateFilesForRowKeyBefore
(org.apache.hadoop.hbase.KeyValue targetKey) SeeStoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue)
for details on this methods.Collection<org.apache.hadoop.hbase.regionserver.HStoreFile>
StoreFileManager.getCompactedfiles()
List of compacted files inside this store that needs to be excluded in reads because further new reads will be using only the newly created files out of compaction.Collection<org.apache.hadoop.hbase.regionserver.HStoreFile>
StripeStoreFileManager.getCompactedfiles()
Collection<org.apache.hadoop.hbase.regionserver.HStoreFile>
HStore.getCompactedFiles()
Supplier<Collection<org.apache.hadoop.hbase.regionserver.HStoreFile>>
StoreContext.getCompactedFilesSupplier()
Collection<org.apache.hadoop.hbase.regionserver.HStoreFile>
StoreFileManager.getFilesForScan
(byte[] startRow, boolean includeStartRow, byte[] stopRow, boolean includeStopRow, boolean onlyLatestVersion) Gets the store files to scan for a Scan or Get request.Collection<org.apache.hadoop.hbase.regionserver.HStoreFile>
StripeStoreFileManager.getFilesForScan
(byte[] startRow, boolean includeStartRow, byte[] stopRow, boolean includeStopRow, boolean onlyLatestVersion) List<org.apache.hadoop.hbase.regionserver.HStoreFile>
StripeStoreFileManager.getLevel0Files()
Comparator<org.apache.hadoop.hbase.regionserver.HStoreFile>
StoreFileManager.getStoreFileComparator()
Comparator<org.apache.hadoop.hbase.regionserver.HStoreFile>
StripeStoreFileManager.getStoreFileComparator()
Collection<org.apache.hadoop.hbase.regionserver.HStoreFile>
HStore.getStorefiles()
Returns All store files.Collection<org.apache.hadoop.hbase.regionserver.HStoreFile>
StoreFileManager.getStoreFiles()
Gets the snapshot of the store files currently in use.Collection<org.apache.hadoop.hbase.regionserver.HStoreFile>
StripeStoreFileManager.getStoreFiles()
ArrayList<org.apache.hbase.thirdparty.com.google.common.collect.ImmutableList<org.apache.hadoop.hbase.regionserver.HStoreFile>>
StripeStoreFileManager.getStripes()
Collection<org.apache.hadoop.hbase.regionserver.HStoreFile>
StoreFileManager.getUnneededFiles
(long maxTs, List<org.apache.hadoop.hbase.regionserver.HStoreFile> filesCompacting) Collection<org.apache.hadoop.hbase.regionserver.HStoreFile>
StripeStoreFileManager.getUnneededFiles
(long maxTs, List<org.apache.hadoop.hbase.regionserver.HStoreFile> filesCompacting) Iterator<org.apache.hadoop.hbase.regionserver.HStoreFile>
StoreFileManager.updateCandidateFilesForRowKeyBefore
(Iterator<org.apache.hadoop.hbase.regionserver.HStoreFile> candidateFiles, org.apache.hadoop.hbase.KeyValue targetKey, org.apache.hadoop.hbase.Cell candidate) Updates the candidate list for finding row key before.Iterator<org.apache.hadoop.hbase.regionserver.HStoreFile>
StripeStoreFileManager.updateCandidateFilesForRowKeyBefore
(Iterator<org.apache.hadoop.hbase.regionserver.HStoreFile> candidateFiles, org.apache.hadoop.hbase.KeyValue targetKey, org.apache.hadoop.hbase.Cell candidate) SeeStoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue)
andStoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator, KeyValue, Cell)
for details on this methods.Modifier and TypeMethodDescriptionstatic long
StoreUtils.getStorefileFieldSize
(org.apache.hadoop.hbase.regionserver.HStoreFile file, ToLongFunction<org.apache.hadoop.hbase.regionserver.StoreFileReader> f) org.apache.hadoop.fs.Path
HRegionFileSystem.mergeStoreFile
(org.apache.hadoop.hbase.client.RegionInfo mergingRegion, String familyName, org.apache.hadoop.hbase.regionserver.HStoreFile f, org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTracker tracker) Write out a merge reference under the given merges directory.void
RegionCoprocessorHost.postCompact
(org.apache.hadoop.hbase.regionserver.HStore store, org.apache.hadoop.hbase.regionserver.HStoreFile resultFile, org.apache.hadoop.hbase.regionserver.compactions.CompactionLifeCycleTracker tracker, org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest request, org.apache.hadoop.hbase.security.User user) Called after the store compaction has completed.void
RegionCoprocessorHost.postFlush
(org.apache.hadoop.hbase.regionserver.HStore store, org.apache.hadoop.hbase.regionserver.HStoreFile storeFile, org.apache.hadoop.hbase.regionserver.FlushLifeCycleTracker tracker) Invoked after a memstore flushorg.apache.hadoop.fs.Path
HRegionFileSystem.splitStoreFile
(org.apache.hadoop.hbase.client.RegionInfo hri, String familyName, org.apache.hadoop.hbase.regionserver.HStoreFile f, byte[] splitRow, boolean top, org.apache.hadoop.hbase.regionserver.RegionSplitPolicy splitPolicy, org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTracker tracker) Write out a split reference.Modifier and TypeMethodDescriptionvoid
StoreFileManager.addCompactionResults
(Collection<org.apache.hadoop.hbase.regionserver.HStoreFile> compactedFiles, Collection<org.apache.hadoop.hbase.regionserver.HStoreFile> results) Adds only the new compaction results into the structure.void
StripeStoreFileManager.addCompactionResults
(Collection<org.apache.hadoop.hbase.regionserver.HStoreFile> compactedFiles, Collection<org.apache.hadoop.hbase.regionserver.HStoreFile> results) void
StoreEngine.addStoreFiles
(Collection<org.apache.hadoop.hbase.regionserver.HStoreFile> storeFiles, org.apache.hadoop.hbase.util.IOExceptionRunnable actionAfterAdding) Add the store files to store file manager, and also record it in the store file tracker.void
StoreFileWriter.appendMetadata
(long maxSequenceId, boolean majorCompaction, Collection<org.apache.hadoop.hbase.regionserver.HStoreFile> storeFiles) Writes meta data.void
HRegionWALFileSystem.archiveRecoveredEdits
(String familyName, Collection<org.apache.hadoop.hbase.regionserver.HStoreFile> storeFiles) Closes and archives the specified store files from the specified family.List<org.apache.hadoop.fs.Path>
AbstractMultiFileWriter.commitWriters
(long maxSeqId, boolean majorCompaction, Collection<org.apache.hadoop.hbase.regionserver.HStoreFile> storeFiles) protected List<org.apache.hadoop.hbase.regionserver.HStoreFile>
HStore.doCompaction
(org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl cr, Collection<org.apache.hadoop.hbase.regionserver.HStoreFile> filesToCompact, org.apache.hadoop.hbase.security.User user, long compactionStartTime, List<org.apache.hadoop.fs.Path> newFiles) static OptionalInt
StoreUtils.getDeterministicRandomSeed
(Collection<org.apache.hadoop.hbase.regionserver.HStoreFile> files) Creates a deterministic hash code for store file collection.static long
StoreUtils.getLowestTimestamp
(Collection<org.apache.hadoop.hbase.regionserver.HStoreFile> candidates) Gets lowest timestamp from candidate StoreFilesstatic OptionalLong
StoreUtils.getMaxMemStoreTSInList
(Collection<org.apache.hadoop.hbase.regionserver.HStoreFile> sfs) Return the largest memstoreTS found across all storefiles in the given list.static OptionalLong
StoreUtils.getMaxSequenceIdInList
(Collection<org.apache.hadoop.hbase.regionserver.HStoreFile> sfs) Return the highest sequence ID found across all storefiles in the given list.List<org.apache.hadoop.hbase.regionserver.KeyValueScanner>
HStore.getScanners
(List<org.apache.hadoop.hbase.regionserver.HStoreFile> files, boolean cacheBlocks, boolean isGet, boolean usePread, boolean isCompaction, org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher matcher, byte[] startRow, byte[] stopRow, long readPt, boolean includeMemstoreScanner, boolean onlyLatestVersion) Create scanners on the given files and if needed on the memstore with no filtering based on TTL (that happens further down the line).List<org.apache.hadoop.hbase.regionserver.KeyValueScanner>
HStore.getScanners
(List<org.apache.hadoop.hbase.regionserver.HStoreFile> files, boolean cacheBlocks, boolean usePread, boolean isCompaction, org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher matcher, byte[] startRow, boolean includeStartRow, byte[] stopRow, boolean includeStopRow, long readPt, boolean includeMemstoreScanner, boolean onlyLatestVersion) Create scanners on the given files and if needed on the memstore with no filtering based on TTL (that happens further down the line).static List<org.apache.hadoop.hbase.regionserver.StoreFileScanner>
StoreFileScanner.getScannersForCompaction
(Collection<org.apache.hadoop.hbase.regionserver.HStoreFile> files, boolean canUseDropBehind, long readPt) Get scanners for compaction.static List<org.apache.hadoop.hbase.regionserver.StoreFileScanner>
StoreFileScanner.getScannersForStoreFiles
(Collection<org.apache.hadoop.hbase.regionserver.HStoreFile> 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<org.apache.hadoop.hbase.regionserver.StoreFileScanner>
StoreFileScanner.getScannersForStoreFiles
(Collection<org.apache.hadoop.hbase.regionserver.HStoreFile> files, boolean cacheBlocks, boolean usePread, boolean isCompaction, boolean canUseDrop, org.apache.hadoop.hbase.regionserver.querymatcher.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 optimizationstatic long
StoreUtils.getStorefilesSize
(Collection<org.apache.hadoop.hbase.regionserver.HStoreFile> files, Predicate<org.apache.hadoop.hbase.regionserver.HStoreFile> predicate) static long
StoreUtils.getStorefilesSize
(Collection<org.apache.hadoop.hbase.regionserver.HStoreFile> files, Predicate<org.apache.hadoop.hbase.regionserver.HStoreFile> predicate) static long
StoreUtils.getTotalUncompressedBytes
(List<org.apache.hadoop.hbase.regionserver.HStoreFile> files) Collection<org.apache.hadoop.hbase.regionserver.HStoreFile>
StoreFileManager.getUnneededFiles
(long maxTs, List<org.apache.hadoop.hbase.regionserver.HStoreFile> filesCompacting) Collection<org.apache.hadoop.hbase.regionserver.HStoreFile>
StripeStoreFileManager.getUnneededFiles
(long maxTs, List<org.apache.hadoop.hbase.regionserver.HStoreFile> filesCompacting) static boolean
StoreUtils.hasReferences
(Collection<org.apache.hadoop.hbase.regionserver.HStoreFile> files) Determines whether any files in the collection are references.void
StoreFileManager.insertNewFiles
(Collection<org.apache.hadoop.hbase.regionserver.HStoreFile> sfs) Adds new files, either for from MemStore flush or bulk insert, into the structure.void
StripeStoreFileManager.insertNewFiles
(Collection<org.apache.hadoop.hbase.regionserver.HStoreFile> sfs) void
StoreFileManager.loadFiles
(List<org.apache.hadoop.hbase.regionserver.HStoreFile> storeFiles) Loads the initial store files into empty StoreFileManager.void
StripeStoreFileManager.loadFiles
(List<org.apache.hadoop.hbase.regionserver.HStoreFile> storeFiles) boolean
DateTieredStoreEngine.needsCompaction
(List<org.apache.hadoop.hbase.regionserver.HStoreFile> filesCompacting) boolean
DefaultStoreEngine.needsCompaction
(List<org.apache.hadoop.hbase.regionserver.HStoreFile> filesCompacting) abstract boolean
StoreEngine.needsCompaction
(List<org.apache.hadoop.hbase.regionserver.HStoreFile> filesCompacting) boolean
StripeStoreEngine.needsCompaction
(List<org.apache.hadoop.hbase.regionserver.HStoreFile> filesCompacting) void
RegionCoprocessorHost.postCompactSelection
(org.apache.hadoop.hbase.regionserver.HStore store, List<org.apache.hadoop.hbase.regionserver.HStoreFile> selected, org.apache.hadoop.hbase.regionserver.compactions.CompactionLifeCycleTracker tracker, org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest request, org.apache.hadoop.hbase.security.User user) Called after theHStoreFile
s to be compacted have been selected from the available candidates.boolean
RegionCoprocessorHost.preCompactSelection
(org.apache.hadoop.hbase.regionserver.HStore store, List<org.apache.hadoop.hbase.regionserver.HStoreFile> candidates, org.apache.hadoop.hbase.regionserver.compactions.CompactionLifeCycleTracker tracker, org.apache.hadoop.hbase.security.User user) Called prior to selecting theHStoreFile
s for compaction from the list of currently available candidates.void
StoreEngine.removeCompactedFiles
(Collection<org.apache.hadoop.hbase.regionserver.HStoreFile> compactedFiles) void
StoreFileManager.removeCompactedFiles
(Collection<org.apache.hadoop.hbase.regionserver.HStoreFile> compactedFiles) Remove the compacted filesvoid
StripeStoreFileManager.removeCompactedFiles
(Collection<org.apache.hadoop.hbase.regionserver.HStoreFile> compactedFiles) void
HRegionFileSystem.removeStoreFiles
(String familyName, Collection<org.apache.hadoop.hbase.regionserver.HStoreFile> storeFiles) Closes and archives the specified store files from the specified family.void
StoreEngine.replaceStoreFiles
(Collection<org.apache.hadoop.hbase.regionserver.HStoreFile> compactedFiles, Collection<org.apache.hadoop.hbase.regionserver.HStoreFile> newFiles, org.apache.hadoop.hbase.util.IOExceptionRunnable walMarkerWriter, Runnable actionUnderLock) static List<org.apache.hadoop.hbase.regionserver.StoreFileInfo>
StoreUtils.toStoreFileInfo
(Collection<org.apache.hadoop.hbase.regionserver.HStoreFile> storefiles) Iterator<org.apache.hadoop.hbase.regionserver.HStoreFile>
StoreFileManager.updateCandidateFilesForRowKeyBefore
(Iterator<org.apache.hadoop.hbase.regionserver.HStoreFile> candidateFiles, org.apache.hadoop.hbase.KeyValue targetKey, org.apache.hadoop.hbase.Cell candidate) Updates the candidate list for finding row key before.Iterator<org.apache.hadoop.hbase.regionserver.HStoreFile>
StripeStoreFileManager.updateCandidateFilesForRowKeyBefore
(Iterator<org.apache.hadoop.hbase.regionserver.HStoreFile> candidateFiles, org.apache.hadoop.hbase.KeyValue targetKey, org.apache.hadoop.hbase.Cell candidate) SeeStoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue)
andStoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator, KeyValue, Cell)
for details on this methods.void
ChangedReadersObserver.updateReaders
(List<org.apache.hadoop.hbase.regionserver.HStoreFile> sfs, List<org.apache.hadoop.hbase.regionserver.KeyValueScanner> memStoreScanners) Notify observers.void
StoreScanner.updateReaders
(List<org.apache.hadoop.hbase.regionserver.HStoreFile> sfs, List<org.apache.hadoop.hbase.regionserver.KeyValueScanner> memStoreScanners) org.apache.hadoop.hbase.regionserver.StoreContext.Builder
StoreContext.Builder.withCompactedFilesSupplier
(Supplier<Collection<org.apache.hadoop.hbase.regionserver.HStoreFile>> compactedFilesSupplier) org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
StoreFileWriter.Builder.withCompactedFilesSupplier
(Supplier<Collection<org.apache.hadoop.hbase.regionserver.HStoreFile>> compactedFilesSupplier)