Modifier and Type | Field and Description |
---|---|
private StoreFileInfo |
HStoreFile.fileInfo |
private StoreFileInfo |
InputStreamBlockDistribution.fileInfo |
Modifier and Type | Method and Description |
---|---|
StoreFileInfo |
HStoreFile.getFileInfo() |
(package private) StoreFileInfo |
HRegionFileSystem.getStoreFileInfo(String familyName,
String fileName)
Return the store file information of the specified family/file.
|
Modifier and Type | Method and Description |
---|---|
List<StoreFileInfo> |
HRegionFileSystem.getStoreFiles(String familyName)
Returns the store files available for the family.
|
List<StoreFileInfo> |
HRegionFileSystem.getStoreFiles(String familyName,
boolean validate)
Returns the store files available for the family.
|
static List<StoreFileInfo> |
StoreUtils.toStoreFileInfo(Collection<HStoreFile> storefiles) |
Modifier and Type | Method and Description |
---|---|
void |
HStore.bulkLoadHFile(StoreFileInfo fileInfo) |
HStoreFile |
StoreEngine.createStoreFileAndReader(StoreFileInfo info) |
Modifier and Type | Method and Description |
---|---|
private List<HStoreFile> |
StoreEngine.openStoreFiles(Collection<StoreFileInfo> files,
boolean warmup) |
private void |
StoreEngine.refreshStoreFilesInternal(Collection<StoreFileInfo> newFiles)
Checks the underlying store files, and opens the files that have not been opened, and removes
the store file readers for store files no longer available.
|
Constructor and Description |
---|
HStoreFile(StoreFileInfo fileInfo,
BloomType cfBloomType,
CacheConfig cacheConf)
Constructor, loads a reader and it's indices, etc.
|
HStoreFile(StoreFileInfo fileInfo,
BloomType cfBloomType,
CacheConfig cacheConf,
BloomFilterMetrics metrics)
Constructor, loads a reader and it's indices, etc.
|
InputStreamBlockDistribution(org.apache.hadoop.fs.FSDataInputStream stream,
StoreFileInfo fileInfo)
This should only be called for the first FSDataInputStream of a StoreFile, in
HStoreFile.open() . |
Modifier and Type | Field and Description |
---|---|
private Map<String,StoreFileInfo> |
FileBasedStoreFileTracker.storefiles |
Modifier and Type | Method and Description |
---|---|
List<StoreFileInfo> |
DefaultStoreFileTracker.load() |
List<StoreFileInfo> |
MigrationStoreFileTracker.load() |
List<StoreFileInfo> |
FileBasedStoreFileTracker.load() |
List<StoreFileInfo> |
StoreFileTracker.load()
Load the store files list when opening a region.
|
Modifier and Type | Method and Description |
---|---|
private org.apache.hadoop.hbase.shaded.protobuf.generated.StoreFileTrackerProtos.StoreFileEntry |
FileBasedStoreFileTracker.toStoreFileEntry(StoreFileInfo info) |
Modifier and Type | Method and Description |
---|---|
void |
StoreFileTrackerBase.add(Collection<StoreFileInfo> newFiles) |
void |
StoreFileTracker.add(Collection<StoreFileInfo> newFiles)
Add new store files.
|
protected void |
DefaultStoreFileTracker.doAddCompactionResults(Collection<StoreFileInfo> compactedFiles,
Collection<StoreFileInfo> newFiles) |
protected void |
DefaultStoreFileTracker.doAddCompactionResults(Collection<StoreFileInfo> compactedFiles,
Collection<StoreFileInfo> newFiles) |
protected abstract void |
StoreFileTrackerBase.doAddCompactionResults(Collection<StoreFileInfo> compactedFiles,
Collection<StoreFileInfo> newFiles) |
protected abstract void |
StoreFileTrackerBase.doAddCompactionResults(Collection<StoreFileInfo> compactedFiles,
Collection<StoreFileInfo> newFiles) |
protected void |
MigrationStoreFileTracker.doAddCompactionResults(Collection<StoreFileInfo> compactedFiles,
Collection<StoreFileInfo> newFiles) |
protected void |
MigrationStoreFileTracker.doAddCompactionResults(Collection<StoreFileInfo> compactedFiles,
Collection<StoreFileInfo> newFiles) |
protected void |
FileBasedStoreFileTracker.doAddCompactionResults(Collection<StoreFileInfo> compactedFiles,
Collection<StoreFileInfo> newFiles) |
protected void |
FileBasedStoreFileTracker.doAddCompactionResults(Collection<StoreFileInfo> compactedFiles,
Collection<StoreFileInfo> newFiles) |
protected void |
DefaultStoreFileTracker.doAddNewStoreFiles(Collection<StoreFileInfo> newFiles) |
protected abstract void |
StoreFileTrackerBase.doAddNewStoreFiles(Collection<StoreFileInfo> newFiles) |
protected void |
MigrationStoreFileTracker.doAddNewStoreFiles(Collection<StoreFileInfo> newFiles) |
protected void |
FileBasedStoreFileTracker.doAddNewStoreFiles(Collection<StoreFileInfo> newFiles) |
void |
StoreFileTrackerBase.replace(Collection<StoreFileInfo> compactedFiles,
Collection<StoreFileInfo> newFiles) |
void |
StoreFileTrackerBase.replace(Collection<StoreFileInfo> compactedFiles,
Collection<StoreFileInfo> newFiles) |
void |
StoreFileTracker.replace(Collection<StoreFileInfo> compactedFiles,
Collection<StoreFileInfo> newFiles)
Add new store files and remove compacted store files after compaction.
|
void |
StoreFileTracker.replace(Collection<StoreFileInfo> compactedFiles,
Collection<StoreFileInfo> newFiles)
Add new store files and remove compacted store files after compaction.
|
void |
DefaultStoreFileTracker.set(List<StoreFileInfo> files) |
void |
MigrationStoreFileTracker.set(List<StoreFileInfo> files) |
void |
FileBasedStoreFileTracker.set(List<StoreFileInfo> files) |
void |
StoreFileTracker.set(List<StoreFileInfo> files)
Set the store files.
|
Modifier and Type | Method and Description |
---|---|
private List<StoreFileInfo> |
SnapshotManifest.getStoreFiles(org.apache.hadoop.fs.Path storeDir) |
Modifier and Type | Method and Description |
---|---|
void |
SnapshotManifestV1.ManifestBuilder.storeFile(HRegionFileSystem region,
org.apache.hadoop.fs.Path familyDir,
StoreFileInfo storeFile) |
void |
SnapshotManifestV2.ManifestBuilder.storeFile(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder region,
org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder family,
StoreFileInfo storeFile) |
void |
SnapshotManifest.RegionVisitor.storeFile(TRegion region,
TFamily family,
StoreFileInfo storeFile) |
Modifier and Type | Method and Description |
---|---|
private void |
SnapshotManifest.addReferenceFiles(SnapshotManifest.RegionVisitor visitor,
Object regionData,
Object familyData,
Collection<StoreFileInfo> storeFiles,
boolean isMob) |
Modifier and Type | Method and Description |
---|---|
static StoreFileInfo |
ServerRegionReplicaUtil.getStoreFileInfo(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
RegionInfo regionInfo,
RegionInfo regionInfoForFs,
String familyName,
org.apache.hadoop.fs.Path path)
Returns a StoreFileInfo from the given FileStatus.
|
Modifier and Type | Method and Description |
---|---|
protected boolean |
MajorCompactionRequest.shouldIncludeStore(HRegionFileSystem fileSystem,
String family,
Collection<StoreFileInfo> storeFiles,
long ts) |
protected boolean |
MajorCompactionTTLRequest.shouldIncludeStore(HRegionFileSystem fileSystem,
String family,
Collection<StoreFileInfo> storeFiles,
long ts) |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.