Package | Description |
---|---|
org.apache.hadoop.hbase.mapreduce |
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
|
org.apache.hadoop.hbase.mob | |
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.regionserver.compactions | |
org.apache.hadoop.hbase.regionserver.storefiletracker | |
org.apache.hadoop.hbase.wal |
Modifier and Type | Field and Description |
---|---|
(package private) StoreFileWriter |
HFileOutputFormat2.WriterLength.writer |
Modifier and Type | Field and Description |
---|---|
private Compactor.CellSinkFactory<StoreFileWriter> |
DefaultMobStoreCompactor.writerFactory |
Modifier and Type | Method and Description |
---|---|
static StoreFileWriter |
MobUtils.createWriter(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
ColumnFamilyDescriptor family,
MobFileName mobFileName,
org.apache.hadoop.fs.Path basePath,
long maxKeyCount,
Compression.Algorithm compression,
CacheConfig cacheConfig,
Encryption.Context cryptoContext,
boolean isCompaction)
Creates a writer for the mob file in temp directory.
|
static StoreFileWriter |
MobUtils.createWriter(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
ColumnFamilyDescriptor family,
org.apache.hadoop.fs.Path path,
long maxKeyCount,
Compression.Algorithm compression,
CacheConfig cacheConfig,
Encryption.Context cryptoContext,
ChecksumType checksumType,
int bytesPerChecksum,
int blocksize,
BloomType bloomType,
boolean isCompaction)
Creates a writer for the mob file in temp directory.
|
static StoreFileWriter |
MobUtils.createWriter(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
ColumnFamilyDescriptor family,
org.apache.hadoop.fs.Path path,
long maxKeyCount,
Compression.Algorithm compression,
CacheConfig cacheConfig,
Encryption.Context cryptoContext,
ChecksumType checksumType,
int bytesPerChecksum,
int blocksize,
BloomType bloomType,
boolean isCompaction,
Consumer<org.apache.hadoop.fs.Path> writerCreationTracker)
Creates a writer for the mob file in temp directory.
|
static StoreFileWriter |
MobUtils.createWriter(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
ColumnFamilyDescriptor family,
String date,
org.apache.hadoop.fs.Path basePath,
long maxKeyCount,
Compression.Algorithm compression,
String startKey,
CacheConfig cacheConfig,
Encryption.Context cryptoContext,
boolean isCompaction,
String regionName)
Creates a writer for the mob file in temp directory.
|
private StoreFileWriter |
DefaultMobStoreCompactor.newMobWriter(Compactor.FileDetails fd,
boolean major,
Consumer<org.apache.hadoop.fs.Path> writerCreationTracker) |
Modifier and Type | Method and Description |
---|---|
private void |
DefaultMobStoreCompactor.commitOrAbortMobWriter(StoreFileWriter mobFileWriter,
long maxSeqId,
long mobCells,
boolean major) |
protected List<org.apache.hadoop.fs.Path> |
DefaultMobStoreCompactor.commitWriter(StoreFileWriter writer,
Compactor.FileDetails fd,
CompactionRequestImpl request) |
protected void |
DefaultMobStoreFlusher.finalizeWriter(StoreFileWriter writer,
long cacheFlushSeqNum,
MonitoredTask status) |
protected void |
DefaultMobStoreFlusher.performMobFlush(MemStoreSnapshot snapshot,
long cacheFlushId,
InternalScanner scanner,
StoreFileWriter writer,
MonitoredTask status,
ThroughputController throughputController,
Consumer<org.apache.hadoop.fs.Path> writerCreationTracker)
Flushes the cells in the mob store.
|
Modifier and Type | Field and Description |
---|---|
private StoreFileWriter |
StripeMultiFileWriter.BoundaryMultiWriter.currentWriter |
private StoreFileWriter |
StripeMultiFileWriter.SizeMultiWriter.currentWriter |
Modifier and Type | Field and Description |
---|---|
protected List<StoreFileWriter> |
StripeMultiFileWriter.existingWriters |
private NavigableMap<Long,StoreFileWriter> |
DateTieredMultiFileWriter.lowerBoundary2Writer |
Modifier and Type | Method and Description |
---|---|
StoreFileWriter |
StoreFileWriter.Builder.build()
Create a store file writer.
|
StoreFileWriter |
AbstractMultiFileWriter.WriterFactory.createWriter() |
StoreFileWriter |
StoreEngine.createWriter(CreateStoreFileWriterParams params)
Create a writer for writing new store files.
|
StoreFileWriter |
HMobStore.createWriter(Date date,
long maxKeyCount,
Compression.Algorithm compression,
byte[] startKey,
boolean isCompaction,
Consumer<org.apache.hadoop.fs.Path> writerCreationTracker)
Creates the writer for the mob file in the mob family directory.
|
protected StoreFileWriter |
StoreFlusher.createWriter(MemStoreSnapshot snapshot,
boolean alwaysIncludesTag,
Consumer<org.apache.hadoop.fs.Path> writerCreationTracker) |
StoreFileWriter |
HMobStore.createWriterInTmp(Date date,
long maxKeyCount,
Compression.Algorithm compression,
byte[] startKey,
boolean isCompaction)
Creates the writer for the mob file in temp directory.
|
StoreFileWriter |
HMobStore.createWriterInTmp(MobFileName mobFileName,
org.apache.hadoop.fs.Path basePath,
long maxKeyCount,
Compression.Algorithm compression,
boolean isCompaction,
Consumer<org.apache.hadoop.fs.Path> writerCreationTracker)
Creates the writer for the mob file in temp directory.
|
StoreFileWriter |
HMobStore.createWriterInTmp(String date,
org.apache.hadoop.fs.Path basePath,
long maxKeyCount,
Compression.Algorithm compression,
byte[] startKey,
boolean isCompaction,
Consumer<org.apache.hadoop.fs.Path> writerCreationTracker)
Creates the writer for the mob file in temp directory.
|
default StoreFileWriter |
AbstractMultiFileWriter.WriterFactory.createWriterWithStoragePolicy(String fileStoragePolicy) |
Modifier and Type | Method and Description |
---|---|
protected abstract Collection<StoreFileWriter> |
AbstractMultiFileWriter.writers() |
protected Collection<StoreFileWriter> |
StripeMultiFileWriter.writers() |
protected Collection<StoreFileWriter> |
DateTieredMultiFileWriter.writers() |
Modifier and Type | Method and Description |
---|---|
protected void |
StoreFlusher.finalizeWriter(StoreFileWriter writer,
long cacheFlushSeqNum,
MonitoredTask status) |
protected void |
AbstractMultiFileWriter.preCloseWriter(StoreFileWriter writer)
Subclasses override this method to be called before we close the give writer.
|
protected void |
StripeMultiFileWriter.preCloseWriter(StoreFileWriter writer) |
Modifier and Type | Field and Description |
---|---|
private Compactor.CellSinkFactory<StoreFileWriter> |
DefaultCompactor.writerFactory |
Modifier and Type | Method and Description |
---|---|
protected StoreFileWriter |
Compactor.createWriter(Compactor.FileDetails fd,
boolean shouldDropBehind,
boolean major,
Consumer<org.apache.hadoop.fs.Path> writerCreationTracker)
Creates a writer for a new file.
|
protected StoreFileWriter |
Compactor.createWriter(Compactor.FileDetails fd,
boolean shouldDropBehind,
String fileStoragePolicy,
boolean major,
Consumer<org.apache.hadoop.fs.Path> writerCreationTracker) |
Modifier and Type | Method and Description |
---|---|
protected void |
DefaultCompactor.abortWriter(StoreFileWriter writer) |
protected List<org.apache.hadoop.fs.Path> |
DefaultCompactor.commitWriter(StoreFileWriter writer,
Compactor.FileDetails fd,
CompactionRequestImpl request) |
Modifier and Type | Method and Description |
---|---|
StoreFileWriter |
StoreFileTrackerBase.createWriter(CreateStoreFileWriterParams params) |
StoreFileWriter |
StoreFileTracker.createWriter(CreateStoreFileWriterParams params)
Create a writer for writing new store files.
|
Modifier and Type | Method and Description |
---|---|
private StoreFileWriter |
BoundedRecoveredHFilesOutputSink.createRecoveredHFileWriter(TableName tableName,
String regionName,
long seqId,
String familyName,
boolean isMetaTable) |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.