Package | Description |
---|---|
org.apache.hadoop.hbase.master | |
org.apache.hadoop.hbase.master.migrate | |
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.replication |
Multi Cluster Replication
|
org.apache.hadoop.hbase.replication.regionserver | |
org.apache.hadoop.hbase.util |
Modifier and Type | Method and Description |
---|---|
TableDescriptors |
MasterServices.getTableDescriptors()
Returns Return table descriptors implementation.
|
Modifier and Type | Method and Description |
---|---|
private void |
TableStateManager.fixTableStates(TableDescriptors tableDescriptors,
Connection connection) |
Modifier and Type | Field and Description |
---|---|
private TableDescriptors |
RollingUpgradeChore.tableDescriptors |
Constructor and Description |
---|
RollingUpgradeChore(org.apache.hadoop.conf.Configuration conf,
ProcedureExecutor<MasterProcedureEnv> procedureExecutor,
TableDescriptors tableDescriptors,
Stoppable stopper) |
Modifier and Type | Field and Description |
---|---|
protected TableDescriptors |
HRegionServer.tableDescriptors
Go here to get table descriptors.
|
Modifier and Type | Method and Description |
---|---|
TableDescriptors |
RegionServerServices.getTableDescriptors()
Returns Return table descriptors implementation.
|
TableDescriptors |
HRegionServer.getTableDescriptors()
Returns Return table descriptors implementation.
|
Modifier and Type | Field and Description |
---|---|
private TableDescriptors |
ReplicationEndpoint.Context.tableDescriptors |
Modifier and Type | Method and Description |
---|---|
TableDescriptors |
ReplicationEndpoint.Context.getTableDescriptors() |
Constructor and Description |
---|
Context(org.apache.hadoop.conf.Configuration localConf,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
String peerId,
UUID clusterId,
ReplicationPeer replicationPeer,
MetricsSource metrics,
TableDescriptors tableDescriptors,
Abortable abortable) |
Modifier and Type | Field and Description |
---|---|
private TableDescriptors |
RegionReplicaReplicationEndpoint.tableDescriptors |
private TableDescriptors |
RegionReplicaReplicationEndpoint.RegionReplicaOutputSink.tableDescriptors |
(package private) TableDescriptors |
RegionReplicaReplicationEndpoint.RegionReplicaSinkWriter.tableDescriptors |
Constructor and Description |
---|
RegionReplicaOutputSink(WALSplitter.PipelineController controller,
TableDescriptors tableDescriptors,
EntryBuffers entryBuffers,
ClusterConnection connection,
ExecutorService pool,
int numWriters,
int operationTimeout) |
RegionReplicaSinkWriter(RegionReplicaReplicationEndpoint.RegionReplicaOutputSink sink,
ClusterConnection connection,
ExecutorService pool,
int operationTimeout,
TableDescriptors tableDescriptors) |
Modifier and Type | Class and Description |
---|---|
class |
FSTableDescriptors
Implementation of
TableDescriptors that reads descriptors from the passed filesystem. |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.