| 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.mob.compactions | |
| org.apache.hadoop.hbase.regionserver | |
| org.apache.hadoop.hbase.regionserver.compactions | |
| 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. createDelFileWriter(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,
                   byte[] startKey,
                   CacheConfig cacheConfig,
                   Encryption.Context cryptoContext)Creates a writer for the del file in temp directory. | 
| static StoreFileWriter | MobUtils. createRefFileWriter(org.apache.hadoop.conf.Configuration conf,
                   org.apache.hadoop.fs.FileSystem fs,
                   ColumnFamilyDescriptor family,
                   org.apache.hadoop.fs.Path basePath,
                   long maxKeyCount,
                   CacheConfig cacheConfig,
                   Encryption.Context cryptoContext,
                   boolean isCompaction)Creates a writer for the ref 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. | 
| 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,
            String date,
            org.apache.hadoop.fs.Path basePath,
            long maxKeyCount,
            Compression.Algorithm compression,
            byte[] startKey,
            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,
            String date,
            org.apache.hadoop.fs.Path basePath,
            long maxKeyCount,
            Compression.Algorithm compression,
            String startKey,
            CacheConfig cacheConfig,
            Encryption.Context cryptoContext,
            boolean isCompaction)Creates a writer for the mob file in temp directory. | 
| Modifier and Type | Method and Description | 
|---|---|
| protected void | DefaultMobStoreFlusher. performMobFlush(MemStoreSnapshot snapshot,
               long cacheFlushId,
               InternalScanner scanner,
               StoreFileWriter writer,
               MonitoredTask status,
               ThroughputController throughputController)Flushes the cells in the mob store. | 
| Modifier and Type | Method and Description | 
|---|---|
| private void | PartitionedMobCompactor. closeMobFileWriter(StoreFileWriter writer,
                  long maxSeqId,
                  long mobCellsCount)Closes the mob file writer. | 
| private void | PartitionedMobCompactor. closeRefFileWriter(StoreFileWriter writer,
                  long maxSeqId,
                  long bulkloadTime)Closes the ref file writer. | 
| 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 | HMobStore. createDelFileWriterInTmp(Date date,
                        long maxKeyCount,
                        Compression.Algorithm compression,
                        byte[] startKey)Creates the writer for the del file in temp directory. | 
| StoreFileWriter | AbstractMultiFileWriter.WriterFactory. createWriter() | 
| 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 | HStore. createWriterInTmp(long maxKeyCount,
                 Compression.Algorithm compression,
                 boolean isCompaction,
                 boolean includeMVCCReadpoint,
                 boolean includesTag,
                 boolean shouldDropBehind) | 
| StoreFileWriter | HStore. createWriterInTmp(long maxKeyCount,
                 Compression.Algorithm compression,
                 boolean isCompaction,
                 boolean includeMVCCReadpoint,
                 boolean includesTag,
                 boolean shouldDropBehind,
                 long totalCompactedFilesSize,
                 String fileStoragePolicy) | 
| StoreFileWriter | HMobStore. createWriterInTmp(MobFileName mobFileName,
                 org.apache.hadoop.fs.Path basePath,
                 long maxKeyCount,
                 Compression.Algorithm compression,
                 boolean isCompaction)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)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. createTmpWriter(Compactor.FileDetails fd,
               boolean shouldDropBehind)Creates a writer for a new file in a temporary directory. | 
| protected StoreFileWriter | Compactor. createTmpWriter(Compactor.FileDetails fd,
               boolean shouldDropBehind,
               String fileStoragePolicy) | 
| 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 | 
|---|---|
| private StoreFileWriter | BoundedRecoveredHFilesOutputSink. createRecoveredHFileWriter(TableName tableName,
                          String regionName,
                          long seqId,
                          String familyName,
                          boolean isMetaTable) | 
Copyright © 2007–2021 The Apache Software Foundation. All rights reserved.