Uses of Class
org.apache.hadoop.hbase.ipc.RpcControllerFactory
Packages that use RpcControllerFactory
Package
Description
Provides HBase Client
Tools to help define network clients and servers.
-
Uses of RpcControllerFactory in org.apache.hadoop.hbase.client
Fields in org.apache.hadoop.hbase.client declared as RpcControllerFactoryModifier and TypeFieldDescriptionprivate final RpcControllerFactory
AbstractRpcBasedConnectionRegistry.rpcControllerFactory
(package private) final RpcControllerFactory
AsyncConnectionImpl.rpcControllerFactory
protected RpcControllerFactory
ClientScanner.rpcControllerFactory
private final RpcControllerFactory
ClusterIdFetcher.rpcControllerFactory
private final RpcControllerFactory
ConnectionImplementation.rpcControllerFactory
private final RpcControllerFactory
ConnectionRegistryRpcStubHolder.rpcControllerFactory
private RpcControllerFactory
HBaseAdmin.rpcControllerFactory
private RpcControllerFactory
HBaseHbck.rpcControllerFactory
private final RpcControllerFactory
HTable.rpcControllerFactory
protected final RpcControllerFactory
RegionAdminServiceCallable.rpcControllerFactory
private final RpcControllerFactory
RpcRetryingCallerWithReadReplicas.rpcControllerFactory
protected final RpcControllerFactory
ScannerCallable.rpcControllerFactory
private final RpcControllerFactory
SecureBulkLoadClient.rpcControllerFactory
(package private) final RpcControllerFactory
AsyncProcess.rpcFactory
Methods in org.apache.hadoop.hbase.client that return RpcControllerFactoryModifier and TypeMethodDescriptionClusterConnection.getRpcControllerFactory()
Returns Connection's RpcControllerFactory instanceConnectionImplementation.getRpcControllerFactory()
private RpcControllerFactory
HBaseAdmin.getRpcControllerFactory()
Methods in org.apache.hadoop.hbase.client with parameters of type RpcControllerFactoryModifier and TypeMethodDescription(package private) static HTableDescriptor
HBaseAdmin.getHTableDescriptor
(TableName tableName, Connection connection, RpcRetryingCallerFactory rpcCallerFactory, RpcControllerFactory rpcControllerFactory, int operationTimeout, int rpcTimeout) Deprecated.since 2.0 version and will be removed in 3.0 version.(package private) static TableDescriptor
HBaseAdmin.getTableDescriptor
(TableName tableName, Connection connection, RpcRetryingCallerFactory rpcCallerFactory, RpcControllerFactory rpcControllerFactory, int operationTimeout, int rpcTimeout) Constructors in org.apache.hadoop.hbase.client with parameters of type RpcControllerFactoryModifierConstructorDescription(package private)
AsyncProcess
(ClusterConnection hc, org.apache.hadoop.conf.Configuration conf, RpcRetryingCallerFactory rpcCaller, RpcControllerFactory rpcFactory) (package private)
AsyncProcess
(ClusterConnection hc, org.apache.hadoop.conf.Configuration conf, RpcRetryingCallerFactory rpcCaller, RpcControllerFactory rpcFactory, int retriesNumber) (package private)
BufferedMutatorImpl
(ClusterConnection conn, RpcRetryingCallerFactory rpcCallerFactory, RpcControllerFactory rpcFactory, BufferedMutatorParams params) ClientAsyncPrefetchScanner
(org.apache.hadoop.conf.Configuration configuration, Scan scan, Scan scanForMetrics, TableName name, ClusterConnection connection, RpcRetryingCallerFactory rpcCallerFactory, RpcControllerFactory rpcControllerFactory, ExecutorService pool, int scanReadRpcTimeout, int scannerTimeout, int replicaCallTimeoutMicroSecondScan, ConnectionConfiguration connectionConfiguration, Map<String, byte[]> requestAttributes) ClientScanner
(org.apache.hadoop.conf.Configuration conf, Scan scan, Scan scanForMetrics, TableName tableName, ClusterConnection connection, RpcRetryingCallerFactory rpcFactory, RpcControllerFactory controllerFactory, ExecutorService pool, int scanReadRpcTimeout, int scannerTimeout, int primaryOperationTimeout, ConnectionConfiguration connectionConfiguration, Map<String, byte[]> requestAttributes) Create a new ClientScanner for the specified table Note that the passedScan
's start row maybe changed changed.ClientSimpleScanner
(org.apache.hadoop.conf.Configuration configuration, Scan scan, Scan scanForMetrics, TableName name, ClusterConnection connection, RpcRetryingCallerFactory rpcCallerFactory, RpcControllerFactory rpcControllerFactory, ExecutorService pool, int scanReadRpcTimeout, int scannerTimeout, int replicaCallTimeoutMicroSecondScan, ConnectionConfiguration connectionConfiguration, Map<String, byte[]> requestAttributes) (package private)
ClusterIdFetcher
(org.apache.hadoop.conf.Configuration conf, User user, RpcControllerFactory rpcControllerFactory, Set<ServerName> bootstrapServers) (package private)
ConnectionRegistryRpcStubHolder
(org.apache.hadoop.conf.Configuration conf, User user, RpcControllerFactory rpcControllerFactory, Set<ServerName> bootstrapNodes) FlushRegionCallable
(ClusterConnection connection, RpcControllerFactory rpcControllerFactory, RegionInfo regionInfo, boolean writeFlushWalMarker) FlushRegionCallable
(ClusterConnection connection, RpcControllerFactory rpcControllerFactory, TableName tableName, byte[] regionName, byte[] regionStartKey, boolean writeFlushWalMarker) (package private)
HBaseHbck
(org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.HbckService.BlockingInterface hbck, RpcControllerFactory rpcControllerFactory) protected
HTable
(ConnectionImplementation connection, TableBuilderBase builder, RpcRetryingCallerFactory rpcCallerFactory, RpcControllerFactory rpcControllerFactory, ExecutorService pool, Map<String, byte[]> requestAttributes) Creates an object to access a HBase table.(package private)
MasterCallable
(Connection connection, RpcControllerFactory rpcConnectionFactory) RegionAdminServiceCallable
(ClusterConnection connection, RpcControllerFactory rpcControllerFactory, HRegionLocation location, TableName tableName, byte[] row) RegionAdminServiceCallable
(ClusterConnection connection, RpcControllerFactory rpcControllerFactory, HRegionLocation location, TableName tableName, byte[] row, int replicaId) RegionAdminServiceCallable
(ClusterConnection connection, RpcControllerFactory rpcControllerFactory, TableName tableName, byte[] row) ReversedClientScanner
(org.apache.hadoop.conf.Configuration conf, Scan scan, Scan scanForMetrics, TableName tableName, ClusterConnection connection, RpcRetryingCallerFactory rpcFactory, RpcControllerFactory controllerFactory, ExecutorService pool, int scanReadRpcTimeout, int scannerTimeout, int primaryOperationTimeout, ConnectionConfiguration connectionConfiguration, Map<String, byte[]> requestAttributes) Create a new ReversibleClientScanner for the specified table Note that the passedScan
's start row maybe changed.ReversedScannerCallable
(ClusterConnection connection, TableName tableName, Scan scan, ScanMetrics scanMetrics, RpcControllerFactory rpcFactory, int replicaId, Map<String, byte[]> requestAttributes) RpcRetryingCallerWithReadReplicas
(RpcControllerFactory rpcControllerFactory, TableName tableName, ClusterConnection cConnection, Get get, ExecutorService pool, int retries, int operationTimeout, int rpcTimeout, int timeBeforeReplicas, Map<String, byte[]> requestAttributes) ScannerCallable
(ClusterConnection connection, TableName tableName, Scan scan, ScanMetrics scanMetrics, RpcControllerFactory rpcControllerFactory, int id, Map<String, byte[]> requestAttributes) -
Uses of RpcControllerFactory in org.apache.hadoop.hbase.ipc
Methods in org.apache.hadoop.hbase.ipc that return RpcControllerFactoryModifier and TypeMethodDescriptionstatic RpcControllerFactory
RpcControllerFactory.instantiate
(org.apache.hadoop.conf.Configuration configuration) -
Uses of RpcControllerFactory in org.apache.hadoop.hbase.master
Fields in org.apache.hadoop.hbase.master declared as RpcControllerFactoryModifier and TypeFieldDescriptionprivate final RpcControllerFactory
ServerManager.rpcControllerFactory
-
Uses of RpcControllerFactory in org.apache.hadoop.hbase.regionserver
Fields in org.apache.hadoop.hbase.regionserver declared as RpcControllerFactory -
Uses of RpcControllerFactory in org.apache.hadoop.hbase.regionserver.handler
Fields in org.apache.hadoop.hbase.regionserver.handler declared as RpcControllerFactoryModifier and TypeFieldDescriptionprivate final RpcControllerFactory
RegionReplicaFlushHandler.rpcControllerFactory
Constructors in org.apache.hadoop.hbase.regionserver.handler with parameters of type RpcControllerFactoryModifierConstructorDescriptionRegionReplicaFlushHandler
(Server server, ClusterConnection connection, RpcRetryingCallerFactory rpcRetryingCallerFactory, RpcControllerFactory rpcControllerFactory, int operationTimeout, HRegion region) -
Uses of RpcControllerFactory in org.apache.hadoop.hbase.replication.regionserver
Fields in org.apache.hadoop.hbase.replication.regionserver declared as RpcControllerFactoryModifier and TypeFieldDescription(package private) RpcControllerFactory
RegionReplicaReplicationEndpoint.RegionReplicaSinkWriter.rpcControllerFactory
Constructors in org.apache.hadoop.hbase.replication.regionserver with parameters of type RpcControllerFactoryModifierConstructorDescriptionRegionReplicaReplayCallable
(ClusterConnection connection, RpcControllerFactory rpcControllerFactory, TableName tableName, HRegionLocation location, RegionInfo regionInfo, byte[] row, List<WAL.Entry> entries, AtomicLong skippedEntries) -
Uses of RpcControllerFactory in org.apache.hadoop.hbase.tool
Fields in org.apache.hadoop.hbase.tool declared as RpcControllerFactoryModifier and TypeFieldDescriptionprivate RpcControllerFactory
LoadIncrementalHFiles.rpcControllerFactory
Deprecated.