程序包 | 说明 |
---|---|
org.apache.hadoop.hbase.client |
Provides HBase Client
Table of Contents
Overview
Example API Usage
Overview
To administer HBase, create and drop tables, list and alter tables,
use
Admin . |
org.apache.hadoop.hbase.client.replication | |
org.apache.hadoop.hbase.replication | |
org.apache.hadoop.hbase.shaded.protobuf |
限定符和类型 | 方法和说明 |
---|---|
ReplicationPeerConfig |
Admin.getReplicationPeerConfig(String peerId)
Returns the configured ReplicationPeerConfig for the specified peer.
|
ReplicationPeerConfig |
HBaseAdmin.getReplicationPeerConfig(String peerId) |
限定符和类型 | 方法和说明 |
---|---|
CompletableFuture<ReplicationPeerConfig> |
AsyncAdmin.getReplicationPeerConfig(String peerId)
Returns the configured ReplicationPeerConfig for the specified peer
|
限定符和类型 | 方法和说明 |
---|---|
default CompletableFuture<Void> |
AsyncAdmin.addReplicationPeer(String peerId,
ReplicationPeerConfig peerConfig)
Add a new replication peer for replicating data to slave cluster
|
default void |
Admin.addReplicationPeer(String peerId,
ReplicationPeerConfig peerConfig)
Add a new replication peer for replicating data to slave cluster.
|
CompletableFuture<Void> |
AsyncAdmin.addReplicationPeer(String peerId,
ReplicationPeerConfig peerConfig,
boolean enabled)
Add a new replication peer for replicating data to slave cluster
|
void |
Admin.addReplicationPeer(String peerId,
ReplicationPeerConfig peerConfig,
boolean enabled)
Add a new replication peer for replicating data to slave cluster.
|
void |
HBaseAdmin.addReplicationPeer(String peerId,
ReplicationPeerConfig peerConfig,
boolean enabled) |
default Future<Void> |
Admin.addReplicationPeerAsync(String peerId,
ReplicationPeerConfig peerConfig)
Add a new replication peer but does not block and wait for it.
|
Future<Void> |
Admin.addReplicationPeerAsync(String peerId,
ReplicationPeerConfig peerConfig,
boolean enabled)
Add a new replication peer but does not block and wait for it.
|
Future<Void> |
HBaseAdmin.addReplicationPeerAsync(String peerId,
ReplicationPeerConfig peerConfig,
boolean enabled) |
CompletableFuture<Void> |
AsyncAdmin.updateReplicationPeerConfig(String peerId,
ReplicationPeerConfig peerConfig)
Update the peerConfig for the specified peer
|
void |
Admin.updateReplicationPeerConfig(String peerId,
ReplicationPeerConfig peerConfig)
Update the peerConfig for the specified peer.
|
void |
HBaseAdmin.updateReplicationPeerConfig(String peerId,
ReplicationPeerConfig peerConfig) |
Future<Void> |
Admin.updateReplicationPeerConfigAsync(String peerId,
ReplicationPeerConfig peerConfig)
Update the peerConfig for the specified peer but does not block and wait for it.
|
Future<Void> |
HBaseAdmin.updateReplicationPeerConfigAsync(String peerId,
ReplicationPeerConfig peerConfig) |
限定符和类型 | 方法和说明 |
---|---|
Map<String,ReplicationPeerConfig> |
ReplicationAdmin.listPeerConfigs()
已过时。
use
Admin.listReplicationPeers() instead |
限定符和类型 | 方法和说明 |
---|---|
ReplicationPeerConfig |
ReplicationPeerConfigBuilder.build()
Builds the configuration object from the current state of
this . |
ReplicationPeerConfig |
ReplicationPeerDescription.getPeerConfig() |
ReplicationPeerConfig |
ReplicationPeerConfig.setBandwidth(long bandwidth)
已过时。
as release of 2.0.0, and it will be removed in 3.0.0. Use
ReplicationPeerConfigBuilder.setBandwidth(long) instead. |
ReplicationPeerConfig |
ReplicationPeerConfig.setClusterKey(String clusterKey)
已过时。
as release of 2.0.0, and it will be removed in 3.0.0. Use
ReplicationPeerConfigBuilder.setClusterKey(String) instead. |
ReplicationPeerConfig |
ReplicationPeerConfig.setExcludeNamespaces(Set<String> namespaces)
已过时。
as release of 2.0.0, and it will be removed in 3.0.0. Use
ReplicationPeerConfigBuilder.setExcludeNamespaces(Set) instead. |
ReplicationPeerConfig |
ReplicationPeerConfig.setExcludeTableCFsMap(Map<TableName,? extends Collection<String>> tableCFsMap)
已过时。
as release of 2.0.0, and it will be removed in 3.0.0. Use
ReplicationPeerConfigBuilder.setExcludeTableCFsMap(Map) instead. |
ReplicationPeerConfig |
ReplicationPeerConfig.setNamespaces(Set<String> namespaces)
已过时。
as release of 2.0.0, and it will be removed in 3.0.0. Use
ReplicationPeerConfigBuilder.setNamespaces(Set) instead. |
ReplicationPeerConfig |
ReplicationPeerConfig.setReplicateAllUserTables(boolean replicateAllUserTables)
已过时。
as release of 2.0.0, and it will be removed in 3.0.0. Use
ReplicationPeerConfigBuilder.setReplicateAllUserTables(boolean) instead. |
ReplicationPeerConfig |
ReplicationPeerConfig.setReplicationEndpointImpl(String replicationEndpointImpl)
已过时。
as release of 2.0.0, and it will be removed in 3.0.0. Use
ReplicationPeerConfigBuilder.setReplicationEndpointImpl(String) instead. |
ReplicationPeerConfig |
ReplicationPeerConfig.setTableCFsMap(Map<TableName,? extends Collection<String>> tableCFsMap)
已过时。
as release of 2.0.0, and it will be removed in 3.0.0. Use
ReplicationPeerConfigBuilder.setTableCFsMap(Map) instead. |
限定符和类型 | 方法和说明 |
---|---|
static ReplicationPeerConfigBuilder |
ReplicationPeerConfig.newBuilder(ReplicationPeerConfig peerConfig) |
构造器和说明 |
---|
ReplicationPeerDescription(String id,
boolean enabled,
ReplicationPeerConfig config) |
限定符和类型 | 方法和说明 |
---|---|
static org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.AddReplicationPeerRequest |
RequestConverter.buildAddReplicationPeerRequest(String peerId,
ReplicationPeerConfig peerConfig,
boolean enabled) |
static org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.UpdateReplicationPeerConfigRequest |
RequestConverter.buildUpdateReplicationPeerConfigRequest(String peerId,
ReplicationPeerConfig peerConfig) |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.