Uses of Class
org.apache.hadoop.hbase.regionserver.StoreFileWriter
Packages that use StoreFileWriter
Package
Description
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
-
Uses of StoreFileWriter in org.apache.hadoop.hbase.mapreduce
Fields in org.apache.hadoop.hbase.mapreduce declared as StoreFileWriterModifier and TypeFieldDescription(package private) StoreFileWriter
HFileOutputFormat2.WriterLength.writer
-
Uses of StoreFileWriter in org.apache.hadoop.hbase.mob
Fields in org.apache.hadoop.hbase.mob with type parameters of type StoreFileWriterModifier and TypeFieldDescriptionprivate final Compactor.CellSinkFactory<StoreFileWriter>
DefaultMobStoreCompactor.writerFactory
Methods in org.apache.hadoop.hbase.mob that return StoreFileWriterModifier and TypeMethodDescriptionstatic 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.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, 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.private StoreFileWriter
DefaultMobStoreCompactor.newMobWriter
(Compactor.FileDetails fd, boolean major, Consumer<org.apache.hadoop.fs.Path> writerCreationTracker) private StoreFileWriter
DefaultMobStoreCompactor.switchToNewMobWriter
(StoreFileWriter mobFileWriter, Compactor.FileDetails fd, long mobCells, boolean major, CompactionRequestImpl request, List<String> committedMobWriterFileNames) Methods in org.apache.hadoop.hbase.mob with parameters of type StoreFileWriterModifier and TypeMethodDescriptionprivate 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.private StoreFileWriter
DefaultMobStoreCompactor.switchToNewMobWriter
(StoreFileWriter mobFileWriter, Compactor.FileDetails fd, long mobCells, boolean major, CompactionRequestImpl request, List<String> committedMobWriterFileNames) -
Uses of StoreFileWriter in org.apache.hadoop.hbase.regionserver
Fields in org.apache.hadoop.hbase.regionserver declared as StoreFileWriterModifier and TypeFieldDescriptionprivate StoreFileWriter
StripeMultiFileWriter.BoundaryMultiWriter.currentWriter
private StoreFileWriter
StripeMultiFileWriter.SizeMultiWriter.currentWriter
Fields in org.apache.hadoop.hbase.regionserver with type parameters of type StoreFileWriterModifier and TypeFieldDescriptionprotected List<StoreFileWriter>
StripeMultiFileWriter.existingWriters
private final NavigableMap<Long,
StoreFileWriter> DateTieredMultiFileWriter.lowerBoundary2Writer
Methods in org.apache.hadoop.hbase.regionserver that return StoreFileWriterModifier and TypeMethodDescriptionStoreFileWriter.Builder.build()
Create a store file writer.AbstractMultiFileWriter.WriterFactory.createWriter()
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.StoreEngine.createWriter
(CreateStoreFileWriterParams params) Create a writer for writing new store files.protected final StoreFileWriter
StoreFlusher.createWriter
(MemStoreSnapshot snapshot, boolean alwaysIncludesTag, Consumer<org.apache.hadoop.fs.Path> writerCreationTracker) 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.HMobStore.createWriterInTmp
(Date date, long maxKeyCount, Compression.Algorithm compression, byte[] startKey, boolean isCompaction) Creates the writer for the mob file in temp directory.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.default StoreFileWriter
AbstractMultiFileWriter.WriterFactory.createWriterWithStoragePolicy
(String fileStoragePolicy) Methods in org.apache.hadoop.hbase.regionserver that return types with arguments of type StoreFileWriterModifier and TypeMethodDescriptionprotected abstract Collection<StoreFileWriter>
AbstractMultiFileWriter.writers()
protected Collection<StoreFileWriter>
DateTieredMultiFileWriter.writers()
protected Collection<StoreFileWriter>
StripeMultiFileWriter.writers()
Methods in org.apache.hadoop.hbase.regionserver with parameters of type StoreFileWriterModifier and TypeMethodDescriptionprotected 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) -
Uses of StoreFileWriter in org.apache.hadoop.hbase.regionserver.compactions
Fields in org.apache.hadoop.hbase.regionserver.compactions with type parameters of type StoreFileWriterModifier and TypeFieldDescriptionprivate final Compactor.CellSinkFactory<StoreFileWriter>
DefaultCompactor.writerFactory
Methods in org.apache.hadoop.hbase.regionserver.compactions that return StoreFileWriterModifier and TypeMethodDescriptionprotected final 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 final StoreFileWriter
Compactor.createWriter
(Compactor.FileDetails fd, boolean shouldDropBehind, String fileStoragePolicy, boolean major, Consumer<org.apache.hadoop.fs.Path> writerCreationTracker) Methods in org.apache.hadoop.hbase.regionserver.compactions with parameters of type StoreFileWriterModifier and TypeMethodDescriptionprotected final void
DefaultCompactor.abortWriter
(StoreFileWriter writer) protected List<org.apache.hadoop.fs.Path>
DefaultCompactor.commitWriter
(StoreFileWriter writer, Compactor.FileDetails fd, CompactionRequestImpl request) -
Uses of StoreFileWriter in org.apache.hadoop.hbase.regionserver.storefiletracker
Methods in org.apache.hadoop.hbase.regionserver.storefiletracker that return StoreFileWriterModifier and TypeMethodDescriptionStoreFileTracker.createWriter
(CreateStoreFileWriterParams params) Create a writer for writing new store files.final StoreFileWriter
StoreFileTrackerBase.createWriter
(CreateStoreFileWriterParams params) -
Uses of StoreFileWriter in org.apache.hadoop.hbase.tool
Methods in org.apache.hadoop.hbase.tool that return StoreFileWriterModifier and TypeMethodDescriptionprivate static StoreFileWriter
BulkLoadHFilesTool.initStoreFileWriter
(org.apache.hadoop.conf.Configuration conf, Cell cell, HFileContext hFileContext, CacheConfig cacheConf, BloomType bloomFilterType, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path outFile, AsyncTableRegionLocator loc) -
Uses of StoreFileWriter in org.apache.hadoop.hbase.wal
Methods in org.apache.hadoop.hbase.wal that return StoreFileWriterModifier and TypeMethodDescriptionprivate StoreFileWriter
BoundedRecoveredHFilesOutputSink.createRecoveredHFileWriter
(TableName tableName, String regionName, long seqId, String familyName, boolean isMetaTable)