Package | Description |
---|---|
org.apache.hadoop.hbase.coprocessor |
Table of Contents
|
org.apache.hadoop.hbase.io | |
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.tool |
Modifier and Type | Method and Description |
---|---|
default StoreFileReader |
RegionObserver.postStoreFileReaderOpen(ObserverContext<RegionCoprocessorEnvironment> ctx,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path p,
FSDataInputStreamWrapper in,
long size,
CacheConfig cacheConf,
Reference r,
StoreFileReader reader)
Deprecated.
For Phoenix only, StoreFileReader is not a stable interface.
|
default StoreFileReader |
RegionObserver.preStoreFileReaderOpen(ObserverContext<RegionCoprocessorEnvironment> ctx,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path p,
FSDataInputStreamWrapper in,
long size,
CacheConfig cacheConf,
Reference r,
StoreFileReader reader)
Deprecated.
For Phoenix only, StoreFileReader is not a stable interface.
|
Modifier and Type | Method and Description |
---|---|
static Reference |
Reference.convert(org.apache.hadoop.hbase.shaded.protobuf.generated.FSProtos.Reference r) |
static Reference |
Reference.createBottomReference(byte[] splitRow) |
static Reference |
Reference.createTopReference(byte[] splitRow) |
static Reference |
Reference.read(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path p)
Read a Reference from FileSystem.
|
Constructor and Description |
---|
HalfStoreFileReader(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path p,
CacheConfig cacheConf,
Reference r,
boolean isPrimaryReplicaStoreFile,
AtomicInteger refCount,
boolean shared,
org.apache.hadoop.conf.Configuration conf)
Creates a half file reader for a normal hfile.
|
HalfStoreFileReader(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path p,
FSDataInputStreamWrapper in,
long size,
CacheConfig cacheConf,
Reference r,
boolean isPrimaryReplicaStoreFile,
AtomicInteger refCount,
boolean shared,
org.apache.hadoop.conf.Configuration conf)
Creates a half file reader for a hfile referred to by an hfilelink.
|
Modifier and Type | Field and Description |
---|---|
private Reference |
StoreFileInfo.reference |
Modifier and Type | Method and Description |
---|---|
Reference |
StoreFileInfo.getReference() |
Modifier and Type | Method and Description |
---|---|
private static HDFSBlocksDistribution |
StoreFileInfo.computeRefFileHDFSBlockDistribution(org.apache.hadoop.fs.FileSystem fs,
Reference reference,
org.apache.hadoop.fs.FileStatus status)
helper function to compute HDFS blocks distribution of a given reference
file.For reference file, we don't compute the exact value.
|
StoreFileReader |
RegionCoprocessorHost.postStoreFileReaderOpen(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path p,
FSDataInputStreamWrapper in,
long size,
CacheConfig cacheConf,
Reference r,
StoreFileReader reader) |
StoreFileReader |
RegionCoprocessorHost.preStoreFileReaderOpen(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path p,
FSDataInputStreamWrapper in,
long size,
CacheConfig cacheConf,
Reference r) |
Constructor and Description |
---|
StoreFileInfo(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.FileStatus fileStatus,
Reference reference)
Create a Store File Info from an HFileLink
|
StoreFileInfo(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.FileStatus fileStatus,
Reference reference,
HFileLink link)
Create a Store File Info from an HFileLink and a Reference
|
Modifier and Type | Method and Description |
---|---|
private static void |
LoadIncrementalHFiles.copyHFileHalf(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.Path inFile,
org.apache.hadoop.fs.Path outFile,
Reference reference,
ColumnFamilyDescriptor familyDescriptor)
Deprecated.
Copy half of an HFile into a new HFile.
|
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.