A B C D E F G H I J K L M N O P Q R S T U V W Y Z 

A

A - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'A'
abort(String, Throwable) - 接口 中的方法org.apache.hadoop.hbase.Abortable
Abort the server or client.
abort(String, Throwable) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
 
abort(String, Throwable) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
abort(String, Throwable) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
 
abort(String, Throwable) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
Abortable - org.apache.hadoop.hbase中的接口
Interface to support the aborting of a given server or client.
abortable - 类 中的变量org.apache.hadoop.hbase.replication.ReplicationStateZKBase
 
abortable - 类 中的变量org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
Used to abort if a fatal error occurs
abortable - 类 中的变量org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
abortProcedure(long, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
abort a procedure
abortProcedure(long, boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Abort a procedure
abortProcedureAsync(long, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Abort a procedure but does not block and wait for it be completely removed.
abortProcedureAsync(long, boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Abort a procedure but does not block and wait for it be completely removed.
abortProcedureResult(MasterProtos.AbortProcedureRequest) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
AbstractClientScanner - org.apache.hadoop.hbase.client中的类
Helper class for custom client scanners.
AbstractClientScanner() - 类 的构造器org.apache.hadoop.hbase.client.AbstractClientScanner
 
AbstractHBaseSaslRpcClient - org.apache.hadoop.hbase.security中的类
A utility class that encapsulates SASL logic for RPC client.
AbstractHBaseSaslRpcClient(AuthMethod, Token<? extends TokenIdentifier>, String, boolean) - 类 的构造器org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
Create a HBaseSaslRpcClient for an authentication method
AbstractHBaseSaslRpcClient(AuthMethod, Token<? extends TokenIdentifier>, String, boolean, String) - 类 的构造器org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
Create a HBaseSaslRpcClient for an authentication method
AbstractRpcClient<T extends org.apache.hadoop.hbase.ipc.RpcConnection> - org.apache.hadoop.hbase.ipc中的类
Provides the basics for a RpcClient implementation like configuration and Logging.
AbstractRpcClient(Configuration, String, SocketAddress, MetricsConnection) - 类 的构造器org.apache.hadoop.hbase.ipc.AbstractRpcClient
Construct an IPC client for the cluster clusterId
AbstractRpcClient.BlockingRpcChannelImplementation - org.apache.hadoop.hbase.ipc中的类
Blocking rpc channel that goes via hbase rpc.
AbstractRpcClient.BlockingRpcChannelImplementation(AbstractRpcClient<?>, InetSocketAddress, User, int) - 类 的构造器org.apache.hadoop.hbase.ipc.AbstractRpcClient.BlockingRpcChannelImplementation
 
AbstractRpcClient.RpcChannelImplementation - org.apache.hadoop.hbase.ipc中的类
Async rpc channel that goes via hbase rpc.
AbstractRpcClient.RpcChannelImplementation(AbstractRpcClient<?>, InetSocketAddress, User, int) - 类 的构造器org.apache.hadoop.hbase.ipc.AbstractRpcClient.RpcChannelImplementation
 
AccessControlClient - org.apache.hadoop.hbase.security.access中的类
Utility client for doing access control admin operations.
AccessControlClient() - 类 的构造器org.apache.hadoop.hbase.security.access.AccessControlClient
 
AccessControlConstants - org.apache.hadoop.hbase.security.access中的接口
 
AccessDeniedException - org.apache.hadoop.hbase.security中的异常错误
Exception thrown by access-related methods.
AccessDeniedException() - 异常错误 的构造器org.apache.hadoop.hbase.security.AccessDeniedException
 
AccessDeniedException(Class<?>, String) - 异常错误 的构造器org.apache.hadoop.hbase.security.AccessDeniedException
 
AccessDeniedException(String) - 异常错误 的构造器org.apache.hadoop.hbase.security.AccessDeniedException
 
AccessDeniedException(Throwable) - 异常错误 的构造器org.apache.hadoop.hbase.security.AccessDeniedException
 
ACL_TABLE_NAME - 类 中的静态变量org.apache.hadoop.hbase.security.access.AccessControlClient
 
Action<R> - org.apache.hadoop.hbase.client中的类
A Get, Put, Increment, Append, or Delete associated with it's region.
Action(Row, int) - 类 的构造器org.apache.hadoop.hbase.client.Action
 
Action(Row, int, int) - 类 的构造器org.apache.hadoop.hbase.client.Action
 
Action(Action<R>, int) - 类 的构造器org.apache.hadoop.hbase.client.Action
Creates an action for a particular replica from original action.
ACTION_BY_CODE - 类 中的静态变量org.apache.hadoop.hbase.security.access.Permission
 
actions - 类 中的变量org.apache.hadoop.hbase.client.MultiAction
 
actions - 类 中的变量org.apache.hadoop.hbase.security.access.Permission
 
add(byte[], byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Append
Add the specified column and value to this Append operation.
add(Cell) - 类 中的方法org.apache.hadoop.hbase.client.Append
Add column and value to this Append operation.
add(BigDecimal, BigDecimal) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
add(Double, Double) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
add(Long, Long) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
add(Map.Entry<byte[], List<Action<T>>>) - 类 中的方法org.apache.hadoop.hbase.client.DelayingRunner
 
add(Cell) - 类 中的方法org.apache.hadoop.hbase.client.Increment
Add the specified KeyValue to this operation.
add(byte[], Action<R>) - 类 中的方法org.apache.hadoop.hbase.client.MultiAction
Add an Action to this container based on it's regionName.
add(byte[], List<Action<R>>) - 类 中的方法org.apache.hadoop.hbase.client.MultiAction
Add an Action to this container based on it's regionName.
add(byte[], int, Object) - 类 中的方法org.apache.hadoop.hbase.client.MultiResponse
Add the pair to the container, grouped by the regionName
add(byte[], byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Put
已过时。
add(byte[], byte[], long, byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Put
已过时。
add(byte[], ByteBuffer, long, ByteBuffer) - 类 中的方法org.apache.hadoop.hbase.client.Put
add(Cell) - 类 中的方法org.apache.hadoop.hbase.client.Put
Add the specified KeyValue to this Put operation.
add(Put) - 类 中的方法org.apache.hadoop.hbase.client.RowMutations
Add a Put operation to the list of mutations
add(Delete) - 类 中的方法org.apache.hadoop.hbase.client.RowMutations
Add a Delete operation to the list of mutations
add(S, S) - 类 中的方法org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
 
addColumn(TableName, HColumnDescriptor) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Add a column to an existing table.
addColumn(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Delete
Delete the latest version of the specified column.
addColumn(byte[], byte[], long) - 类 中的方法org.apache.hadoop.hbase.client.Delete
Delete the specified version of the specified column.
addColumn(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Get
Get the column from the specific family with the specified qualifier.
addColumn(byte[], HColumnDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Add a column to an existing table.
addColumn(String, HColumnDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Add a column to an existing table.
addColumn(TableName, HColumnDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Add a column to an existing table.
addColumn(byte[], byte[], long) - 类 中的方法org.apache.hadoop.hbase.client.Increment
Increment the column from the specific family with the specified qualifier by the specified amount.
addColumn(byte[], byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Put
Add the specified column and value to this Put operation.
addColumn(byte[], byte[], long, byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Put
Add the specified column and value, with the specified timestamp as its version to this Put operation.
addColumn(byte[], ByteBuffer, long, ByteBuffer) - 类 中的方法org.apache.hadoop.hbase.client.Put
Add the specified column and value, with the specified timestamp as its version to this Put operation.
addColumn(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Scan
Get the column from the specified family with the specified qualifier.
addColumns(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Delete
Delete all versions of the specified column.
addColumns(byte[], byte[], long) - 类 中的方法org.apache.hadoop.hbase.client.Delete
Delete all versions of the specified column with a timestamp less than or equal to the specified timestamp.
addCoprocessor(String) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Add a table coprocessor to this table.
addCoprocessor(String, Path, int, Map<String, String>) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Add a table coprocessor to this table.
addCoprocessorWithSpec(String) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Add a table coprocessor to this table.
addDaughter(Connection, HRegionInfo, ServerName, long) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Adds a daughter region entry to meta.
addDaughtersToPut(Put, HRegionInfo, HRegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Adds split daughters to the Put
addDeleteMarker(Cell) - 类 中的方法org.apache.hadoop.hbase.client.Delete
Advanced use only.
addEmptyLocation(Put, int) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
 
addException(byte[], Throwable) - 类 中的方法org.apache.hadoop.hbase.client.MultiResponse
 
addFamily(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Delete
Delete all versions of all columns of the specified family.
addFamily(byte[], long) - 类 中的方法org.apache.hadoop.hbase.client.Delete
Delete all columns of the specified family with a timestamp less than or equal to the specified timestamp.
addFamily(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Get
Get all columns from the specified family.
addFamily(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Scan
Get all columns from the specified family.
addFamily(HColumnDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
Does NOT add a column family.
addFamily(HColumnDescriptor) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Adds a column family.
addFamilyVersion(byte[], long) - 类 中的方法org.apache.hadoop.hbase.client.Delete
Delete all columns of the specified family with a timestamp equal to the specified timestamp.
addFilter(List<Filter>) - 类 中的方法org.apache.hadoop.hbase.filter.FilterList
 
addFilter(Filter) - 类 中的方法org.apache.hadoop.hbase.filter.FilterList
Add a filter.
addFilterLists(List<Filter>) - 类 中的方法org.apache.hadoop.hbase.filter.FilterListBase
 
addFilterLists(List<Filter>) - 类 中的方法org.apache.hadoop.hbase.filter.FilterListWithAND
 
addFilterLists(List<Filter>) - 类 中的方法org.apache.hadoop.hbase.filter.FilterListWithOR
 
addHFileRefs(String, List<Pair<Path, Path>>) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationQueues
Add new hfile references to the queue.
addHFileRefs(String, List<Pair<Path, Path>>) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
addImmutable(byte[], byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Put
addImmutable(byte[], byte[], byte[], Tag[]) - 类 中的方法org.apache.hadoop.hbase.client.Put
This expects that the underlying arrays won't change.
addImmutable(byte[], byte[], long, byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Put
addImmutable(byte[], byte[], long, byte[], Tag[]) - 类 中的方法org.apache.hadoop.hbase.client.Put
This expects that the underlying arrays won't change.
addImmutable(byte[], ByteBuffer, long, ByteBuffer, Tag[]) - 类 中的方法org.apache.hadoop.hbase.client.Put
This expects that the underlying arrays won't change.
addImmutable(byte[], ByteBuffer, long, ByteBuffer) - 类 中的方法org.apache.hadoop.hbase.client.Put
addInfo(String, SecurityInfo) - 类 中的静态方法org.apache.hadoop.hbase.security.SecurityInfo
Adds a security configuration for a new service name.
addLabel(Configuration, String) - 类 中的静态方法org.apache.hadoop.hbase.security.visibility.VisibilityClient
addLabel(Connection, String) - 类 中的静态方法org.apache.hadoop.hbase.security.visibility.VisibilityClient
Utility method for adding label to the system.
addLabels(Configuration, String[]) - 类 中的静态方法org.apache.hadoop.hbase.security.visibility.VisibilityClient
addLabels(Connection, String[]) - 类 中的静态方法org.apache.hadoop.hbase.security.visibility.VisibilityClient
Utility method for adding labels to the system.
addListener(ReplicationPeerConfigListener) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl.PeerConfigTracker
 
addLocation(Put, ServerName, long, long, int) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
 
addLog(String, String) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationQueues
Add a new WAL file to the given queue.
addLog(String, String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
addPeer(String, String) - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
已过时。
Use addPeer(String, ReplicationPeerConfig, Map) instead.
addPeer(String, String, String) - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
已过时。
addPeer(String, ReplicationPeerConfig, Map<TableName, ? extends Collection<String>>) - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Add a new remote slave cluster for replication.
addPeer(String, ReplicationPeerConfig) - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Add a new remote slave cluster for replication.
addPeer(String, ReplicationPeerConfig) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeers
Add a new remote slave cluster for replication.
addPeer(String, ReplicationPeerConfig) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
addPeerToHFileRefs(String) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationQueues
Add a peer to hfile reference queue if peer does not exist.
addPeerToHFileRefs(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
addRegionsToMeta(Connection, List<HRegionInfo>, int) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Adds a hbase:meta row for each of the specified new regions.
addRegionsToMeta(Connection, List<HRegionInfo>, int, long) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Adds a hbase:meta row for each of the specified new regions.
addRegionToMeta(Connection, HRegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Adds a hbase:meta row for the specified new region.
addRegionToMeta(Table, HRegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Adds a hbase:meta row for the specified new region to the given catalog table.
addRegionToMeta(Table, HRegionInfo, HRegionInfo, HRegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Adds a (single) hbase:meta row for the specified new region and its daughters.
addRegionToMeta(Connection, HRegionInfo, HRegionInfo, HRegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Adds a (single) hbase:meta row for the specified new region and its daughters.
addResults(ClientProtos.RegionLoadStats) - 类 中的方法org.apache.hadoop.hbase.client.Result
addSequenceNum(Put, long, long, int) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
 
addStatistic(byte[], ClientProtos.RegionLoadStats) - 类 中的方法org.apache.hadoop.hbase.client.MultiResponse
 
addToCounter(String, long) - 类 中的方法org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
 
addToFailedServers(InetSocketAddress, Throwable) - 类 中的方法org.apache.hadoop.hbase.ipc.FailedServers
Add an address to the list of the failed servers list.
addTokenForJob(Connection, JobConf, User) - 类 中的静态方法org.apache.hadoop.hbase.security.token.TokenUtil
Checks for an authentication token for the given user, obtaining a new token if necessary, and adds it to the credentials for the given map reduce job.
addTokenForJob(Connection, User, Job) - 类 中的静态方法org.apache.hadoop.hbase.security.token.TokenUtil
Checks for an authentication token for the given user, obtaining a new token if necessary, and adds it to the credentials for the given map reduce job.
addTokenIfMissing(Connection, User) - 类 中的静态方法org.apache.hadoop.hbase.security.token.TokenUtil
Checks if an authentication tokens exists for the connected cluster, obtaining one if needed and adding it to the user's credentials.
addTypeFilter(QuotaType) - 类 中的方法org.apache.hadoop.hbase.quotas.QuotaFilter
Add a type to the filter list
Admin - org.apache.hadoop.hbase.client中的接口
The administrative API for HBase.
Admin.MasterSwitchType - org.apache.hadoop.hbase.client中的枚举
已过时。
advance() - 类 中的方法org.apache.hadoop.hbase.client.Result
 
AggregationClient - org.apache.hadoop.hbase.client.coprocessor中的类
This client class is for invoking the aggregate functions deployed on the Region Server side via the AggregateService.
AggregationClient(Configuration) - 类 的构造器org.apache.hadoop.hbase.client.coprocessor.AggregationClient
Constructor with Conf object
allTableRegions(Configuration, Connection, TableName, boolean) - 类 中的静态方法org.apache.hadoop.hbase.client.MetaScanner
allTableRegions(Connection, TableName) - 类 中的静态方法org.apache.hadoop.hbase.client.MetaScanner
Lists all of the table regions currently in META.
AND - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
AND Byte Array
AND_ARRAY - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
AND Array
AND_BUFFER - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
 
AND_OPERATOR - 类 中的静态变量org.apache.hadoop.hbase.security.visibility.VisibilityConstants
 
ap - 类 中的变量org.apache.hadoop.hbase.client.BufferedMutatorImpl
 
Append - org.apache.hadoop.hbase.client中的类
Performs Append operations on a single row.
Append(byte[]) - 类 的构造器org.apache.hadoop.hbase.client.Append
Create a Append operation for the specified row.
Append(Append) - 类 的构造器org.apache.hadoop.hbase.client.Append
Copy constructor
Append(byte[], int, int) - 类 的构造器org.apache.hadoop.hbase.client.Append
Create a Append operation for the specified row.
append(Append) - 类 中的方法org.apache.hadoop.hbase.client.HTable
Appends values to one or more columns within a single row.
append(Append) - 接口 中的方法org.apache.hadoop.hbase.client.Table
Appends values to one or more columns within a single row.
appendPeerTableCFs(String, String) - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Append the replicable table-cf config of the specified peer
appendPeerTableCFs(String, Map<TableName, ? extends Collection<String>>) - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Append the replicable table-cf config of the specified peer
appendTracker - 类 中的变量org.apache.hadoop.hbase.client.MetricsConnection
 
areAdjacent(HRegionInfo, HRegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
Check whether two regions are adjacent
areScanStartRowAndStopRowEqual(byte[], byte[]) - 类 中的静态方法org.apache.hadoop.hbase.client.ClientUtil
 
assertSnapshotRequestIsValid(HBaseProtos.SnapshotDescription) - 类 中的静态方法org.apache.hadoop.hbase.snapshot.ClientSnapshotDescriptionUtils
Check to make sure that the description of the snapshot requested is valid
assign(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
 
assign(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
assignmentZNode - 类 中的变量org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
asyncCreate(ZooKeeperWatcher, String, byte[], AsyncCallback.StringCallback, Object) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Async creates the specified node with the specified data.
asyncCreateNodeOffline(ZooKeeperWatcher, HRegionInfo, ServerName, AsyncCallback.StringCallback, Object) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKAssign
Creates an unassigned node in the OFFLINE state for the specified region.
Attributes - org.apache.hadoop.hbase.client中的接口
 
AUTH_TOKEN_TYPE - 类 中的静态变量org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
authenticationMethod - 枚举 中的变量org.apache.hadoop.hbase.security.AuthMethod
 
AuthenticationTokenIdentifier - org.apache.hadoop.hbase.security.token中的类
Represents the identity information stored in an HBase authentication token.
AuthenticationTokenIdentifier() - 类 的构造器org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
AuthenticationTokenIdentifier(String) - 类 的构造器org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
AuthenticationTokenIdentifier(String, int, long, long) - 类 的构造器org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
AuthenticationTokenSelector - org.apache.hadoop.hbase.security.token中的类
 
AuthenticationTokenSelector() - 类 的构造器org.apache.hadoop.hbase.security.token.AuthenticationTokenSelector
 
AuthMethod - org.apache.hadoop.hbase.security中的枚举
Authentication method
Authorizations - org.apache.hadoop.hbase.security.visibility中的类
This class contains visibility labels associated with a Scan/Get deciding which all labeled data current scan/get can access.
Authorizations(String...) - 类 的构造器org.apache.hadoop.hbase.security.visibility.Authorizations
 
Authorizations(List<String>) - 类 的构造器org.apache.hadoop.hbase.security.visibility.Authorizations
 
avg(TableName, ColumnInterpreter<R, S, P, Q, T>, Scan) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.AggregationClient
This is the client side interface/handle for calling the average method for a given cf-cq combination.
avg(Table, ColumnInterpreter<R, S, P, Q, T>, Scan) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.AggregationClient
This is the client side interface/handle for calling the average method for a given cf-cq combination.

B

BACKOFF_POLICY_CLASS - 接口 中的静态变量org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicy
 
BACKSLASH - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for Backslash
backupMasterAddressesZNode - 类 中的变量org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
BadAuthException - org.apache.hadoop.hbase.ipc中的异常错误
 
BadAuthException() - 异常错误 的构造器org.apache.hadoop.hbase.ipc.BadAuthException
 
BadAuthException(String) - 异常错误 的构造器org.apache.hadoop.hbase.ipc.BadAuthException
 
BadAuthException(String, Throwable) - 异常错误 的构造器org.apache.hadoop.hbase.ipc.BadAuthException
 
balancer() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Invoke the balancer.
balancer(boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Invoke the balancer.
balancer() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Invoke the balancer.
balancer(boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
balancerZNode - 类 中的变量org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
baseZNode - 类 中的变量org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
Batch - org.apache.hadoop.hbase.client.coprocessor中的类
A collection of interfaces and utilities used for interacting with custom RPC interfaces exposed by Coprocessors.
Batch() - 类 的构造器org.apache.hadoop.hbase.client.coprocessor.Batch
 
batch(List<? extends Row>, Object[], int) - 类 中的方法org.apache.hadoop.hbase.client.HTable
 
batch(List<? extends Row>, Object[]) - 类 中的方法org.apache.hadoop.hbase.client.HTable
Method that does a batch call on Deletes, Gets, Puts, Increments, Appends, RowMutations The ordering of execution of the actions is not defined.
batch(List<? extends Row>) - 类 中的方法org.apache.hadoop.hbase.client.HTable
已过时。
If any exception is thrown by one of the actions, there is no way to retrieve the partially executed results. Use HTable.batch(List, Object[]) instead.
batch(List<? extends Row>, Object[]) - 接口 中的方法org.apache.hadoop.hbase.client.Table
Method that does a batch call on Deletes, Gets, Puts, Increments, Appends, RowMutations The ordering of execution of the actions is not defined.
batch(List<? extends Row>) - 接口 中的方法org.apache.hadoop.hbase.client.Table
已过时。
If any exception is thrown by one of the actions, there is no way to retrieve the partially executed results. Use Table.batch(List, Object[]) instead.
Batch.Call<T,R> - org.apache.hadoop.hbase.client.coprocessor中的接口
Defines a unit of work to be executed.
Batch.Callback<R> - org.apache.hadoop.hbase.client.coprocessor中的接口
Defines a generic callback to be triggered for each Batch.Call.call(Object) result.
batchCallback(List<? extends Row>, Object[], Batch.Callback<R>) - 类 中的方法org.apache.hadoop.hbase.client.HTable
Same as Table.batch(List, Object[]), but with a callback.
batchCallback(List<? extends Row>, Batch.Callback<R>) - 类 中的方法org.apache.hadoop.hbase.client.HTable
已过时。
If any exception is thrown by one of the actions, there is no way to retrieve the partially executed results. Use HTable.batchCallback(List, Object[], org.apache.hadoop.hbase.client.coprocessor.Batch.Callback) instead.
batchCallback(List<? extends Row>, Object[], Batch.Callback<R>) - 接口 中的方法org.apache.hadoop.hbase.client.Table
Same as Table.batch(List, Object[]), but with a callback.
batchCallback(List<? extends Row>, Batch.Callback<R>) - 接口 中的方法org.apache.hadoop.hbase.client.Table
已过时。
If any exception is thrown by one of the actions, there is no way to retrieve the partially executed results. Use Table.batchCallback(List, Object[], org.apache.hadoop.hbase.client.coprocessor.Batch.Callback) instead.
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R) - 类 中的方法org.apache.hadoop.hbase.client.HTable
Creates an instance of the given Service subclass for each table region spanning the range from the startKey row to endKey row (inclusive), all the invocations to the same region server will be batched into one call.
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R, Batch.Callback<R>) - 类 中的方法org.apache.hadoop.hbase.client.HTable
Creates an instance of the given Service subclass for each table region spanning the range from the startKey row to endKey row (inclusive), all the invocations to the same region server will be batched into one call.
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R) - 接口 中的方法org.apache.hadoop.hbase.client.Table
Creates an instance of the given Service subclass for each table region spanning the range from the startKey row to endKey row (inclusive), all the invocations to the same region server will be batched into one call.
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R, Batch.Callback<R>) - 接口 中的方法org.apache.hadoop.hbase.client.Table
Creates an instance of the given Service subclass for each table region spanning the range from the startKey row to endKey row (inclusive), all the invocations to the same region server will be batched into one call.
BatchScanResultCache - org.apache.hadoop.hbase.client中的类
A scan result cache for batched scan, i.e, {@code scan.getBatch() > 0 && !
BatchScanResultCache(List<Result>, int) - 类 的构造器org.apache.hadoop.hbase.client.BatchScanResultCache
 
BigDecimalColumnInterpreter - org.apache.hadoop.hbase.client.coprocessor中的类
ColumnInterpreter for doing Aggregation's with BigDecimal columns.
BigDecimalColumnInterpreter() - 类 的构造器org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
BinaryComparator - org.apache.hadoop.hbase.filter中的类
A binary comparator which lexicographically compares against the specified byte array using Bytes.compareTo(byte[], byte[]).
BinaryComparator(byte[]) - 类 的构造器org.apache.hadoop.hbase.filter.BinaryComparator
Constructor
BinaryPrefixComparator - org.apache.hadoop.hbase.filter中的类
A comparator which compares against a specified byte array, but only compares up to the length of this byte array.
BinaryPrefixComparator(byte[]) - 类 的构造器org.apache.hadoop.hbase.filter.BinaryPrefixComparator
Constructor
binaryPrefixType - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
BinaryPrefixType byte array
binarySearch(Cell[], byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Result
 
binarySearch(Cell[], byte[], int, int, byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.client.Result
Searches for the latest value for the specified column.
binaryType - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
BinaryType byte array
BitComparator - org.apache.hadoop.hbase.filter中的类
A bit comparator which performs the specified bitwise operation on each of the bytes with the specified byte array.
BitComparator(byte[], BitComparator.BitwiseOp) - 类 的构造器org.apache.hadoop.hbase.filter.BitComparator
Constructor
BitComparator.BitwiseOp - org.apache.hadoop.hbase.filter中的枚举
Bit operators.
bitOperator - 类 中的变量org.apache.hadoop.hbase.filter.BitComparator
 
BLOCKCACHE - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
Key for the BLOCKCACHE attribute.
BlockingRpcCallback<R> - org.apache.hadoop.hbase.ipc中的类
Simple RpcCallback implementation providing a Future-like BlockingRpcCallback.get() method, which will block util the instance's BlockingRpcCallback.run(Object) method has been called.
BlockingRpcCallback() - 类 的构造器org.apache.hadoop.hbase.ipc.BlockingRpcCallback
 
BlockingRpcClient - org.apache.hadoop.hbase.ipc中的类
Does RPC against a cluster.
BlockingRpcClient(Configuration, String, SocketAddress, MetricsConnection) - 类 的构造器org.apache.hadoop.hbase.ipc.BlockingRpcClient
Construct an IPC client for the cluster clusterId with the default SocketFactory This method is called with reflection by the RpcClientFactory to create an instance
BLOCKSIZE - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
Size of storefile/hfile 'blocks'.
blockUntilAvailable(ZooKeeperWatcher, long, Configuration) - 类 中的方法org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Wait until the primary meta region is available.
blockUntilAvailable(ZooKeeperWatcher, long) - 类 中的方法org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Wait until the meta region is available and is not in transition.
blockUntilAvailable(ZooKeeperWatcher, int, long) - 类 中的方法org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Wait until the meta region is available and is not in transition.
blockUntilAvailable(ZooKeeperWatcher, String, long) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
 
blockUntilAvailable() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
Gets the data of the node, blocking until the node is available.
blockUntilAvailable(long, boolean) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
Gets the data of the node, blocking until the node is available or the specified timeout has elapsed.
blockUntilNoRIT(ZooKeeperWatcher) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKAssign
Blocks until there are no node in regions in transition.
blockUntilRIT(ZooKeeperWatcher) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKAssign
Blocks until there is at least one node in regions in transition.
BLOOMFILTER - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
 
BloomType - org.apache.hadoop.hbase.regionserver中的枚举
 
bucketRsBatch(HTable, List<Row>) - 类 中的静态方法org.apache.hadoop.hbase.client.HTableUtil
已过时。
Processes a List of Rows (Put, Delete) and writes them to an HTable instance in RegionServer buckets via the htable.batch method.
bucketRsPut(HTable, List<Put>) - 类 中的静态方法org.apache.hadoop.hbase.client.HTableUtil
已过时。
Processes a List of Puts and writes them to an HTable instance in RegionServer buckets via the htable.put method.
BufferedMutator - org.apache.hadoop.hbase.client中的接口
Used to communicate with a single HBase table similar to Table but meant for batched, asynchronous puts.
BufferedMutator.ExceptionListener - org.apache.hadoop.hbase.client中的接口
Listens for asynchronous exceptions on a BufferedMutator.
BufferedMutatorImpl - org.apache.hadoop.hbase.client中的类
Used to communicate with a single HBase table similar to HTable but meant for batched, potentially asynchronous puts.
BufferedMutatorParams - org.apache.hadoop.hbase.client中的类
Parameters for instantiating a BufferedMutator.
BufferedMutatorParams(TableName) - 类 的构造器org.apache.hadoop.hbase.client.BufferedMutatorParams
 
buildActionResult(Throwable) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ResponseConverter
Wrap a throwable to an action result.
buildActionResult(ClientProtos.Result) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ResponseConverter
Wrap a throwable to an action result.
buildAddColumnRequest(TableName, HColumnDescriptor, long, long) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer AddColumnRequest
buildAssignRegionRequest(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer AssignRegionRequest
buildBalanceRequest(boolean) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer BalanceRequest
buildBulkLoadHFileRequest(List<Pair<byte[], String>>, byte[], boolean) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
已过时。
use buildBulkLoadHFileRequest(final List> familyPaths, final byte[] regionName, boolean assignSeqNum, List clusterIds)
buildBulkLoadHFileRequest(List<Pair<byte[], String>>, byte[], boolean, List<String>) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer bulk load request
buildCatalogScanRequest() - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a request for running a catalog scan
buildCleanerChoreRequest() - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a request for running cleaner chore
buildClearDeadServersRequest(List<ServerName>) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
 
buildCloseRegionRequest(ServerName, byte[], boolean) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a CloseRegionRequest for a given region name
buildCloseRegionRequest(ServerName, byte[], int, ServerName, boolean) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
 
buildCloseRegionRequest(ServerName, String, boolean) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a CloseRegionRequest for a given encoded region name
buildCompactRegionRequest(byte[], boolean, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a CompactRegionRequest for a given region name
buildCondition(byte[], byte[], byte[], ByteArrayComparable, HBaseProtos.CompareType) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer Condition
buildCreateTableRequest(HTableDescriptor, byte[][], long, long) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer CreateTableRequest
buildDeleteColumnRequest(TableName, byte[], long, long) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer DeleteColumnRequest
buildDeleteTableRequest(TableName, long, long) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer DeleteTableRequest
buildDisableTableRequest(TableName, long, long) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer DisableTableRequest
buildDispatchMergingRegionsRequest(byte[], byte[], boolean) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
 
buildEnableCatalogJanitorRequest(boolean) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a request for enabling/disabling the catalog janitor
buildEnableCatalogJanitorResponse(boolean) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ResponseConverter
Creates a response for the catalog scan request
buildEnableTableRequest(TableName, long, long) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer EnableTableRequest
buildException(Throwable) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ResponseConverter
 
buildFlushRegionRequest(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer FlushRegionRequest for a given region name
buildFlushRegionRequest(byte[], boolean) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer FlushRegionRequest for a given region name
buildGetClusterStatusRequest() - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer GetClusterStatusRequest
buildGetLastFlushedSequenceIdRequest(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a request for querying the master the last flushed sequence Id for a region
buildGetLastFlushedSequenceIdResponse(ClusterStatusProtos.RegionStoreSequenceIds) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ResponseConverter
Creates a response for the last flushed sequence Id request
buildGetOnlineRegionRequest() - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer GetOnlineRegionRequest
buildGetOnlineRegionResponse(List<HRegionInfo>) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ResponseConverter
A utility to build a GetOnlineRegionResponse.
buildGetRegionInfoRequest(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer GetRegionInfoRequest for a given region name
buildGetRegionInfoRequest(byte[], boolean) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer GetRegionInfoRequest for a given region name
buildGetRequest(byte[], Get) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer GetRequest for a client Get
buildGetRowOrBeforeRequest(byte[], byte[], byte[]) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a new protocol buffer GetRequest to get a row, all columns in a family.
buildGetSchemaAlterStatusRequest(TableName) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer GetSchemaAlterStatusRequest
buildGetServerInfoRequest() - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a new GetServerInfoRequest
buildGetServerInfoResponse(ServerName, int) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ResponseConverter
A utility to build a GetServerInfoResponse.
buildGetStoreFileRequest(byte[], byte[]) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer GetStoreFileRequest for a given region name
buildGetTableDescriptorsRequest(List<TableName>) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer GetTableDescriptorsRequest
buildGetTableDescriptorsRequest(Pattern, boolean) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer GetTableDescriptorsRequest
buildGetTableDescriptorsRequest(TableName) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer GetTableDescriptorsRequest for a single table
buildGetTableNamesRequest(Pattern, boolean) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer GetTableNamesRequest
buildGetUserPermissionsResponse(List<UserPermission>) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ResponseConverter
Converts the permissions list into a protocol buffer GetUserPermissionsResponse
buildGrantRequest(String, boolean, AccessControlProtos.Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a request to grant user permissions.
buildGrantRequest(String, TableName, byte[], byte[], boolean, AccessControlProtos.Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a request to grant user permissions.
buildGrantRequest(String, String, boolean, AccessControlProtos.Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a request to grant user permissions.
buildIncrementRequest(byte[], byte[], byte[], byte[], long, Durability, long, long) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a client increment
buildIsBalancerEnabledRequest() - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer IsBalancerEnabledRequest
buildIsCatalogJanitorEnabledRequest() - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a request for querying the master whether the catalog janitor is enabled
buildIsCleanerChoreEnabledRequest() - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a request for querying the master whether the cleaner chore is enabled
buildIsMasterRunningRequest() - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer IsMasterRunningRequest
buildIsNormalizerEnabledRequest() - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer IsNormalizerEnabledRequest
buildIsSplitOrMergeEnabledRequest(Admin.MasterSwitchType) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer IsSplitOrMergeEnabledRequest
buildMergeRegionsRequest(byte[], byte[], boolean) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a MergeRegionsRequest for the given regions
buildModifyColumnRequest(TableName, HColumnDescriptor, long, long) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer ModifyColumnRequest
buildModifyTableRequest(TableName, HTableDescriptor, long, long) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer ModifyTableRequest
buildMoveRegionRequest(byte[], byte[]) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MoveRegionRequest
buildMutateRequest(byte[], byte[], byte[], byte[], ByteArrayComparable, HBaseProtos.CompareType, Put) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a conditioned put
buildMutateRequest(byte[], byte[], byte[], byte[], ByteArrayComparable, HBaseProtos.CompareType, Delete) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a conditioned delete
buildMutateRequest(byte[], byte[], byte[], byte[], ByteArrayComparable, HBaseProtos.CompareType, RowMutations) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MutateRequest for conditioned row mutations
buildMutateRequest(byte[], Put) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a put
buildMutateRequest(byte[], Append, long, long) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MutateRequest for an append
buildMutateRequest(byte[], Increment, long, long) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a client increment
buildMutateRequest(byte[], Delete) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a delete
buildNoDataRegionAction(byte[], RowMutations, List<CellScannable>, ClientProtos.RegionAction.Builder, ClientProtos.Action.Builder, ClientProtos.MutationProto.Builder) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MultiRequest for row mutations that does not hold data.
buildNoDataRegionAction(byte[], List<Action<R>>, List<CellScannable>, ClientProtos.RegionAction.Builder, ClientProtos.Action.Builder, ClientProtos.MutationProto.Builder) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer multirequest with NO data for a list of actions (data is carried otherwise than via protobuf).
buildNormalizeRequest() - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer NormalizeRequest
buildOfflineRegionRequest(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer OfflineRegionRequest
buildOpenRegionRequest(ServerName, List<Triple<HRegionInfo, Integer, List<ServerName>>>, Boolean) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer OpenRegionRequest to open a list of regions
buildOpenRegionRequest(ServerName, HRegionInfo, int, List<ServerName>, Boolean) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer OpenRegionRequest for a given region
buildRegionAction(byte[], RowMutations) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MultiRequest for row mutations.
buildRegionAction(byte[], List<Action<R>>, ClientProtos.RegionAction.Builder, ClientProtos.Action.Builder, ClientProtos.MutationProto.Builder) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer multi request for a list of actions.
buildRegionSpecifier(HBaseProtos.RegionSpecifier.RegionSpecifierType, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Convert a byte array to a protocol buffer RegionSpecifier
buildRevokeRequest(String, AccessControlProtos.Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a request to revoke user permissions.
buildRevokeRequest(String, TableName, byte[], byte[], AccessControlProtos.Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a request to revoke user permissions.
buildRevokeRequest(String, String, AccessControlProtos.Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a request to revoke user permissions.
buildRollWALWriterRequest() - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a new RollWALWriterRequest
buildRunCatalogScanResponse(int) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ResponseConverter
Creates a response for the catalog scan request
buildRunCleanerChoreResponse(boolean) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ResponseConverter
Creates a response for the cleaner chore request
buildScanRequest(byte[], Scan, int, boolean) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer ScanRequest for a client Scan
buildScanRequest(long, int, boolean, boolean) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer ScanRequest for a scanner id
buildScanRequest(long, int, boolean, long, boolean, boolean, int) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer ScanRequest for a scanner id
buildServiceCall(byte[], Descriptors.MethodDescriptor, Message) - 类 中的静态方法org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
Returns a service call instance for the given coprocessor request.
buildSetBalancerRunningRequest(boolean, boolean) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer SetBalancerRunningRequest
buildSetCleanerChoreRunningRequest(boolean) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a request for enabling/disabling the cleaner chore
buildSetNormalizerRunningRequest(boolean) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer SetNormalizerRunningRequest
buildSetQuotaRequestProto(QuotaSettings) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaSettings
已过时。
Removed in HBase 2.0+ as a part of removing protobuf from our API
buildSetSplitOrMergeEnabledRequest(boolean, boolean, Admin.MasterSwitchType...) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer SetSplitOrMergeEnabledRequest
buildSplitRegionRequest(byte[], byte[]) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a SplitRegionRequest for a given region name
buildStopServerRequest(String) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a new StopServerRequest
buildTruncateTableRequest(TableName, boolean, long, long) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer TruncateTableRequest
buildUnassignRegionRequest(byte[], boolean) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer UnassignRegionRequest
buildUpdateFavoredNodesRequest(List<Pair<HRegionInfo, List<ServerName>>>) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer UpdateFavoredNodesRequest to update a list of favorednode mappings
buildWarmupRegionRequest(HRegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
Create a WarmupRegionRequest for a given region name
bulkLoadHFile(ClientProtos.ClientService.BlockingInterface, List<Pair<byte[], String>>, byte[], boolean) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
已过时。
use bulkLoadHFile(final ClientService.BlockingInterface client, final List> familyPaths, final byte[] regionName, boolean assignSeqNum, List clusterIds) instead.
bulkLoadHFile(ClientProtos.ClientService.BlockingInterface, List<Pair<byte[], String>>, byte[], boolean, List<String>) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to bulk load a list of HFiles using client protocol.
bulkLoadHFiles(List<Pair<byte[], String>>, Token<?>, String, byte[]) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.SecureBulkLoadClient
已过时。 
bulkLoadHFiles(List<Pair<byte[], String>>, Token<?>, String, byte[], List<String>) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.SecureBulkLoadClient
 
bypassGlobals(String, boolean) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Set the "bypass global settings" for the specified user
ByteArrayComparable - org.apache.hadoop.hbase.filter中的类
Base class for byte array comparators
ByteArrayComparable(byte[]) - 类 的构造器org.apache.hadoop.hbase.filter.ByteArrayComparable
Constructor.
BYTES_IN_REMOTE_RESULTS_METRIC_NAME - 类 中的静态变量org.apache.hadoop.hbase.client.metrics.ScanMetrics
 
BYTES_IN_RESULTS_METRIC_NAME - 类 中的静态变量org.apache.hadoop.hbase.client.metrics.ScanMetrics
 

C

cache - 类 中的变量org.apache.hadoop.hbase.client.ClientScanner
 
CACHE_BLOOMS_ON_WRITE - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
 
CACHE_DATA_IN_L1 - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
Key for cache data into L1 if cache is set up with more than one tier.
CACHE_DATA_ON_WRITE - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
 
CACHE_INDEX_ON_WRITE - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
 
cacheLocation(TableName, RegionLocations) - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
 
cacheLocation(TableName, ServerName, HRegionLocation) - 类 中的方法org.apache.hadoop.hbase.client.MetaCache
Put a newly discovered HRegionLocation into the cache.
cacheLocation(TableName, RegionLocations) - 类 中的方法org.apache.hadoop.hbase.client.MetaCache
Put a newly discovered HRegionLocation into the cache.
caching - 类 中的变量org.apache.hadoop.hbase.client.ClientScanner
 
calculateTheClosestNextRowKeyForPrefix(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.client.ClientUtil
When scanning for a prefix the scan should stop immediately after the the last row that has the specified prefix.
call(T) - 接口 中的方法org.apache.hadoop.hbase.client.coprocessor.Batch.Call
 
call(int) - 类 中的方法org.apache.hadoop.hbase.client.DelegatingRetryingCallable
 
call(int) - 类 中的方法org.apache.hadoop.hbase.client.FlushRegionCallable
 
call(int) - 接口 中的方法org.apache.hadoop.hbase.client.RetryingCallable
Computes a result, or throws an exception if unable to do so.
call(int) - 类 中的方法org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
Algo: - we put the query into the execution pool
call(int) - 类 中的方法org.apache.hadoop.hbase.client.ScannerCallable
 
callable - 类 中的变量org.apache.hadoop.hbase.client.ClientScanner
 
callBlockingMethod(Descriptors.MethodDescriptor, RpcController, Message, Message) - 类 中的方法org.apache.hadoop.hbase.ipc.AbstractRpcClient.BlockingRpcChannelImplementation
 
callBlockingMethod(Descriptors.MethodDescriptor, RpcController, Message, Message) - 类 中的方法org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
 
CallCancelledException - org.apache.hadoop.hbase.ipc中的异常错误
Client side call cancelled.
CallCancelledException(String) - 异常错误 的构造器org.apache.hadoop.hbase.ipc.CallCancelledException
 
CallDroppedException - org.apache.hadoop.hbase中的异常错误
Returned to the clients when their request was discarded due to server being overloaded.
CallDroppedException() - 异常错误 的构造器org.apache.hadoop.hbase.CallDroppedException
 
CallDroppedException(String) - 异常错误 的构造器org.apache.hadoop.hbase.CallDroppedException
 
caller - 类 中的变量org.apache.hadoop.hbase.client.ClientScanner
 
CallerDisconnectedException - org.apache.hadoop.hbase.ipc中的异常错误
Exception indicating that the remote host making this IPC lost its IPC connection.
CallerDisconnectedException(String) - 异常错误 的构造器org.apache.hadoop.hbase.ipc.CallerDisconnectedException
 
callExecService(RpcController, Descriptors.MethodDescriptor, Message, Message) - 类 中的方法org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
 
callExecService(RpcController, Descriptors.MethodDescriptor, Message, Message) - 类 中的方法org.apache.hadoop.hbase.ipc.MasterCoprocessorRpcChannel
 
callExecService(RpcController, Descriptors.MethodDescriptor, Message, Message) - 类 中的方法org.apache.hadoop.hbase.ipc.RegionCoprocessorRpcChannel
 
callExecService(RpcController, Descriptors.MethodDescriptor, Message, Message) - 类 中的方法org.apache.hadoop.hbase.ipc.RegionServerCoprocessorRpcChannel
 
callMethod(Descriptors.MethodDescriptor, RpcController, Message, Message, RpcCallback<Message>) - 类 中的方法org.apache.hadoop.hbase.ipc.AbstractRpcClient.RpcChannelImplementation
 
callMethod(Descriptors.MethodDescriptor, RpcController, Message, Message, RpcCallback<Message>) - 类 中的方法org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
 
CallQueueTooBigException - org.apache.hadoop.hbase中的异常错误
 
CallQueueTooBigException() - 异常错误 的构造器org.apache.hadoop.hbase.CallQueueTooBigException
 
CallQueueTooBigException(String) - 异常错误 的构造器org.apache.hadoop.hbase.CallQueueTooBigException
 
CallTimeoutException - org.apache.hadoop.hbase.ipc中的异常错误
Client-side call timeout
CallTimeoutException(String) - 异常错误 的构造器org.apache.hadoop.hbase.ipc.CallTimeoutException
 
callWithoutRetries(RetryingCallable<T>, int) - 类 中的方法org.apache.hadoop.hbase.client.RpcRetryingCaller
Call the server once only.
callWithRetries(RetryingCallable<T>, int) - 类 中的方法org.apache.hadoop.hbase.client.RpcRetryingCaller
Retries if invocation fails.
cancel(boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
cancel() - 类 中的方法org.apache.hadoop.hbase.client.PayloadCarryingServerCallable
 
cancel() - 类 中的方法org.apache.hadoop.hbase.client.RpcRetryingCaller
 
cancelAll() - 类 中的方法org.apache.hadoop.hbase.client.ResultBoundedCompletionService
 
cancelConnections(ServerName) - 类 中的方法org.apache.hadoop.hbase.ipc.AbstractRpcClient
Interrupt the connections to the given ip:port server.
cancelConnections(ServerName) - 接口 中的方法org.apache.hadoop.hbase.ipc.RpcClient
Interrupt the connections to the given server.
castToCellType(BigDecimal) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
castToCellType(Double) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
castToCellType(Long) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
castToCellType(S) - 类 中的方法org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
The response message comes as type S.
castToReturnType(BigDecimal) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
castToReturnType(Double) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
castToReturnType(Long) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
castToReturnType(T) - 类 中的方法org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
provides casting opportunity between the data types.
cConnection - 类 中的变量org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
 
cConnection - 类 中的变量org.apache.hadoop.hbase.client.ScannerCallable
 
cellBlockBuilder - 类 中的变量org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
cellScanner() - 类 中的方法org.apache.hadoop.hbase.client.Mutation
 
cellScanner() - 类 中的方法org.apache.hadoop.hbase.client.Result
 
cellScanner() - 类 中的方法org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
cellScanner() - 类 中的方法org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
CellScannerButNoCodecException - org.apache.hadoop.hbase.ipc中的异常错误
Thrown if a cellscanner but no codec to encode it with.
CellScannerButNoCodecException() - 异常错误 的构造器org.apache.hadoop.hbase.ipc.CellScannerButNoCodecException
 
CellVisibility - org.apache.hadoop.hbase.security.visibility中的类
This contains a visibility expression which can be associated with a cell.
CellVisibility(String) - 类 的构造器org.apache.hadoop.hbase.security.visibility.CellVisibility
 
CF_ATTRIBUTE_EARLY_OUT - 接口 中的静态变量org.apache.hadoop.hbase.security.access.AccessControlConstants
Configuration or CF schema option for early termination of access checks if table or CF permissions grant access.
CFNAME - 类 中的静态变量org.apache.hadoop.hbase.client.replication.ReplicationAdmin
 
chance - 类 中的变量org.apache.hadoop.hbase.filter.RandomRowFilter
 
channelInactive(ChannelHandlerContext) - 类 中的方法org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClientHandler
 
channelInactive(ChannelHandlerContext) - 类 中的方法org.apache.hadoop.hbase.security.SaslUnwrapHandler
 
channelRead0(ChannelHandlerContext, ByteBuf) - 类 中的方法org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClientHandler
 
channelRead0(ChannelHandlerContext, ByteBuf) - 类 中的方法org.apache.hadoop.hbase.security.SaslUnwrapHandler
 
CHECK_AUTHS_FOR_MUTATION - 类 中的静态变量org.apache.hadoop.hbase.security.visibility.VisibilityConstants
 
checkAndDelete(byte[], byte[], byte[], byte[], Delete) - 类 中的方法org.apache.hadoop.hbase.client.HTable
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndDelete(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Delete) - 类 中的方法org.apache.hadoop.hbase.client.HTable
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndDelete(byte[], byte[], byte[], byte[], Delete) - 接口 中的方法org.apache.hadoop.hbase.client.Table
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndDelete(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Delete) - 接口 中的方法org.apache.hadoop.hbase.client.Table
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndGetReversed(List<Filter>, boolean) - 类 中的静态方法org.apache.hadoop.hbase.filter.FilterListBase
 
checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], RowMutations) - 类 中的方法org.apache.hadoop.hbase.client.HTable
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], RowMutations) - 接口 中的方法org.apache.hadoop.hbase.client.Table
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndPut(byte[], byte[], byte[], byte[], Put) - 类 中的方法org.apache.hadoop.hbase.client.HTable
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndPut(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Put) - 类 中的方法org.apache.hadoop.hbase.client.HTable
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndPut(byte[], byte[], byte[], byte[], Put) - 接口 中的方法org.apache.hadoop.hbase.client.Table
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndPut(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Put) - 接口 中的方法org.apache.hadoop.hbase.client.Table
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndSetZNodeAcls() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
On master start, we check the znode ACLs under the root directory and set the ACLs properly if needed.
checkClosingState(ZooKeeperWatcher, HRegionInfo, int) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKAssign
 
checkExists(ZooKeeperWatcher, String) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Check if the specified node exists.
checkFailed() - 类 中的方法org.apache.hadoop.hbase.ipc.ServerRpcController
Throws an IOException back out if one is currently stored.
checkForAnd(byte[], int) - 类 中的静态方法org.apache.hadoop.hbase.filter.ParseFilter
Checks if the current index of filter string we are on is the beginning of the keyword 'AND'
checkForOr(byte[], int) - 类 中的静态方法org.apache.hadoop.hbase.filter.ParseFilter
Checks if the current index of filter string we are on is the beginning of the keyword 'OR'
checkForSkip(byte[], int) - 类 中的静态方法org.apache.hadoop.hbase.filter.ParseFilter
Checks if the current index of filter string we are on is the beginning of the keyword 'SKIP'
checkForWhile(byte[], int) - 类 中的静态方法org.apache.hadoop.hbase.filter.ParseFilter
Checks if the current index of filter string we are on is the beginning of the keyword 'WHILE'
checkHBaseAvailable(Configuration) - 类 中的静态方法org.apache.hadoop.hbase.client.HBaseAdmin
Check to see if HBase is running.
checkIfBaseNodeAvailable() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
Checks if the baseznode set as per the property 'zookeeper.znode.parent' exists.
checkIfRegionServerIsRemote() - 类 中的方法org.apache.hadoop.hbase.client.ScannerCallable
compare the local machine hostname with region server's hostname to decide if hbase client connects to a remote region server
checkIOException(IOException) - 类 中的静态方法org.apache.hadoop.hbase.RemoteExceptionHandler
Examine passed IOException.
checkLockExists(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
checkState(int) - 接口 中的方法org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture.WaitForStateCallable
 
checkThrowable(Throwable) - 类 中的静态方法org.apache.hadoop.hbase.RemoteExceptionHandler
Examine passed Throwable.
checkUpdateNumberOfCompleteRowsAndCache(Result) - 类 中的方法org.apache.hadoop.hbase.client.BatchScanResultCache
 
checkZk() - 类 中的方法org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
Try to create a Zookeeper connection.
claimQueue(String, String) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationQueues
Take ownership for the queue identified by queueId and belongs to a dead region server.
claimQueue(String, String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
classifyExs(List<Throwable>) - 异常错误 中的静态方法org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
cleanupBulkLoad(String) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.SecureBulkLoadClient
 
clear() - 类 中的方法org.apache.hadoop.hbase.client.BatchScanResultCache
 
clear() - 类 中的方法org.apache.hadoop.hbase.util.PoolMap
 
clear() - 接口 中的方法org.apache.hadoop.hbase.util.PoolMap.Pool
 
clearAuths(Configuration, String[], String) - 类 中的静态方法org.apache.hadoop.hbase.security.visibility.VisibilityClient
clearAuths(Connection, String[], String) - 类 中的静态方法org.apache.hadoop.hbase.security.visibility.VisibilityClient
Removes given labels from user's globally authorized list of labels.
clearCache() - 类 中的方法org.apache.hadoop.hbase.client.MetaCache
Delete all cached entries.
clearCache(ServerName) - 类 中的方法org.apache.hadoop.hbase.client.MetaCache
Delete all cached entries of a server.
clearCache(TableName) - 类 中的方法org.apache.hadoop.hbase.client.MetaCache
Delete all cached entries of a table.
clearCache(TableName, byte[]) - 类 中的方法org.apache.hadoop.hbase.client.MetaCache
Delete a cached location, no matter what it is.
clearCache(TableName, byte[], int) - 类 中的方法org.apache.hadoop.hbase.client.MetaCache
Delete a cached location with specific replicaId.
clearCache(TableName, byte[], ServerName) - 类 中的方法org.apache.hadoop.hbase.client.MetaCache
Delete a cached location for a table, row and server
clearCache(HRegionInfo) - 类 中的方法org.apache.hadoop.hbase.client.MetaCache
Deletes the cached location of the region if necessary, based on some error from source.
clearCache(HRegionLocation) - 类 中的方法org.apache.hadoop.hbase.client.MetaCache
 
clearCaches(ServerName) - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
Clear any caches that pertain to server name sn.
clearCaches(ServerName) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
internal method, do not use thru HConnection
clearDeadServers(List<ServerName>) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Clear dead region servers from master.
clearDeadServers(List<ServerName>) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
clearRegionCache() - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
Allows flushing the region cache.
clearRegionCache(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
Allows flushing the region cache of all locations that pertain to tableName
clearRegionCache() - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
internal method, do not use thru HConnection
clearRegionCache(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
internal method, do not use thru HConnection
clearRegionCache(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
clearRegionCache() - 类 中的方法org.apache.hadoop.hbase.client.HTable
Explicitly clears the region cache to fetch the latest value from META.
CLIENT_SIDE_METRICS_ENABLED_KEY - 类 中的静态变量org.apache.hadoop.hbase.client.MetricsConnection
Set this key to true to enable metrics collection of client requests.
ClientBackoffPolicy - org.apache.hadoop.hbase.client.backoff中的接口
Configurable policy for the amount of time a client should wait for a new request to the server when given the server load statistics.
ClientBackoffPolicyFactory - org.apache.hadoop.hbase.client.backoff中的类
 
ClientBackoffPolicyFactory.NoBackoffPolicy - org.apache.hadoop.hbase.client.backoff中的类
Default backoff policy that doesn't create any backoff for the client, regardless of load
ClientBackoffPolicyFactory.NoBackoffPolicy(Configuration) - 类 的构造器org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicyFactory.NoBackoffPolicy
 
ClientExceptionsUtil - org.apache.hadoop.hbase.exceptions中的类
 
ClientScanner - org.apache.hadoop.hbase.client中的类
Implements the scanner interface for the HBase client.
ClientScanner(Configuration, Scan, TableName, ClusterConnection, RpcRetryingCallerFactory, RpcControllerFactory, ExecutorService, int) - 类 的构造器org.apache.hadoop.hbase.client.ClientScanner
Create a new ClientScanner for the specified table Note that the passed Scan's start row maybe changed changed.
ClientSimpleScanner - org.apache.hadoop.hbase.client中的类
ClientSimpleScanner implements a sync scanner behaviour.
ClientSimpleScanner(Configuration, Scan, TableName, ClusterConnection, RpcRetryingCallerFactory, RpcControllerFactory, ExecutorService, int) - 类 的构造器org.apache.hadoop.hbase.client.ClientSimpleScanner
 
ClientSnapshotDescriptionUtils - org.apache.hadoop.hbase.snapshot中的类
Class to help with dealing with a snapshot description on the client side.
ClientUtil - org.apache.hadoop.hbase.client中的类
 
ClientUtil() - 类 的构造器org.apache.hadoop.hbase.client.ClientUtil
 
ClockOutOfSyncException - org.apache.hadoop.hbase中的异常错误
This exception is thrown by the master when a region server clock skew is too high.
ClockOutOfSyncException(String) - 异常错误 的构造器org.apache.hadoop.hbase.ClockOutOfSyncException
 
cloneSnapshot(byte[], TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Create a new table by cloning the snapshot content.
cloneSnapshot(String, TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Create a new table by cloning the snapshot content.
cloneSnapshot(String, TableName, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Create a new table by cloning the snapshot content.
cloneSnapshot(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Create a new table by cloning the snapshot content.
cloneSnapshot(byte[], TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Create a new table by cloning the snapshot content.
cloneSnapshot(String, String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Create a new table by cloning the snapshot content.
cloneSnapshot(String, TableName, boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Create a new table by cloning the snapshot content.
cloneSnapshot(String, TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
close() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
 
close() - 接口 中的方法org.apache.hadoop.hbase.client.BufferedMutator
Performs a BufferedMutator.flush() and releases any resources held.
close() - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorImpl
 
close() - 类 中的方法org.apache.hadoop.hbase.client.ClientScanner
 
close() - 接口 中的方法org.apache.hadoop.hbase.client.Connection
 
close() - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.AggregationClient
 
close() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
close() - 类 中的方法org.apache.hadoop.hbase.client.HRegionLocator
close() - 类 中的方法org.apache.hadoop.hbase.client.HTable
 
close() - 类 中的方法org.apache.hadoop.hbase.client.HTableMultiplexer
Closes the internal Connection.
close() - 类 中的方法org.apache.hadoop.hbase.client.HTablePool
已过时。
Closes all the HTable instances , belonging to all tables in the table pool.
close() - 类 中的方法org.apache.hadoop.hbase.client.MetaScanner.MetaScannerVisitorBase
 
close() - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
 
close() - 接口 中的方法org.apache.hadoop.hbase.client.ResultScanner
Closes the scanner and releases any resources it has allocated
close() - 接口 中的方法org.apache.hadoop.hbase.client.Table
Releases any resources held or pending changes in internal buffers.
close() - 类 中的方法org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
close() - 接口 中的方法org.apache.hadoop.hbase.ipc.RpcClient
Stop all threads related to this client.
close() - 类 中的方法org.apache.hadoop.hbase.quotas.QuotaRetriever
 
close() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
 
close(ChannelHandlerContext, ChannelPromise) - 类 中的方法org.apache.hadoop.hbase.security.SaslWrapHandler
 
close() - 类 中的方法org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
close() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Close the connection to ZooKeeper.
closed - 类 中的变量org.apache.hadoop.hbase.client.ClientScanner
 
closed - 类 中的变量org.apache.hadoop.hbase.client.ScannerCallable
 
CLOSED_PARAN - 类 中的静态变量org.apache.hadoop.hbase.security.visibility.VisibilityConstants
 
closeInternal() - 类 中的方法org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
closeInternal() - 类 中的方法org.apache.hadoop.hbase.ipc.BlockingRpcClient
 
closeInternal() - 类 中的方法org.apache.hadoop.hbase.ipc.NettyRpcClient
 
closeRegion(String, String) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Close a region.
closeRegion(byte[], String) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Close a region.
closeRegion(ServerName, HRegionInfo) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Close a region.
closeRegion(String, String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Close a region.
closeRegion(byte[], String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Close a region.
closeRegion(ServerName, HRegionInfo) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Close a region.
closeRegion(RpcController, AdminProtos.AdminService.BlockingInterface, ServerName, byte[], boolean) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to close a region given a region name using admin protocol.
closeRegion(RpcController, AdminProtos.AdminService.BlockingInterface, ServerName, byte[], int, ServerName, boolean) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to close a region given a region name using admin protocol.
closeRegionWithEncodedRegionName(String, String) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
For expert-admins.
closeRegionWithEncodedRegionName(String, String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
For expert-admins.
closeTablePool(String) - 类 中的方法org.apache.hadoop.hbase.client.HTablePool
已过时。
Closes all the HTable instances , belonging to the given table, in the table pool.
closeTablePool(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HTablePool
已过时。
ClusterConnection - org.apache.hadoop.hbase.client中的接口
Internal methods on Connection that should not be used by user code.
ClusterId - org.apache.hadoop.hbase中的类
The identifier for this cluster.
ClusterId() - 类 的构造器org.apache.hadoop.hbase.ClusterId
New ClusterID.
ClusterId(String) - 类 的构造器org.apache.hadoop.hbase.ClusterId
 
clusterId - 类 中的变量org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
clusterIdZNode - 类 中的变量org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
clusterStateZNode - 类 中的变量org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
ClusterStatus - org.apache.hadoop.hbase中的类
Status information on the HBase cluster.
ClusterStatus() - 类 的构造器org.apache.hadoop.hbase.ClusterStatus
已过时。
As of release 0.96 (HBASE-6038). This will be removed in HBase 2.0.0. Used by Writables and Writables are going away.
ClusterStatus(String, String, List<ServerName>, ServerName) - 类 的构造器org.apache.hadoop.hbase.ClusterStatus
已过时。
ClusterStatus(String, String, Map<ServerName, ServerLoad>, Collection<ServerName>, ServerName, Collection<ServerName>, Map<String, RegionState>, String[], Boolean) - 类 的构造器org.apache.hadoop.hbase.ClusterStatus
已过时。
ClusterStatus(String, String, Map<ServerName, ServerLoad>, Collection<ServerName>, ServerName, Collection<ServerName>, Set<RegionState>, String[], Boolean) - 类 的构造器org.apache.hadoop.hbase.ClusterStatus
 
code() - 枚举 中的方法org.apache.hadoop.hbase.security.access.Permission.Action
 
code - 枚举 中的变量org.apache.hadoop.hbase.security.AuthMethod
The code for this method.
codec - 类 中的变量org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
colFamTimeRangeMap - 类 中的变量org.apache.hadoop.hbase.client.Query
 
COLON - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for colon (:)
ColumnCountGetFilter - org.apache.hadoop.hbase.filter中的类
Simple filter that returns first N columns on row only.
ColumnCountGetFilter(int) - 类 的构造器org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
columnFamily - 类 中的变量org.apache.hadoop.hbase.filter.DependentColumnFilter
 
columnFamily - 类 中的变量org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
ColumnInterpreter<T,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,R extends com.google.protobuf.Message> - org.apache.hadoop.hbase.coprocessor中的类
Defines how value for specific column is interpreted and provides utility methods like compare, add, multiply etc for them.
ColumnInterpreter() - 类 的构造器org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
 
ColumnPaginationFilter - org.apache.hadoop.hbase.filter中的类
A filter, based on the ColumnCountGetFilter, takes two arguments: limit and offset.
ColumnPaginationFilter(int, int) - 类 的构造器org.apache.hadoop.hbase.filter.ColumnPaginationFilter
Initializes filter with an integer offset and limit.
ColumnPaginationFilter(int, byte[]) - 类 的构造器org.apache.hadoop.hbase.filter.ColumnPaginationFilter
Initializes filter with a string/bookmark based offset and limit.
ColumnPrefixFilter - org.apache.hadoop.hbase.filter中的类
This filter is used for selecting only those keys with columns that matches a particular prefix.
ColumnPrefixFilter(byte[]) - 类 的构造器org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
columnQualifier - 类 中的变量org.apache.hadoop.hbase.filter.DependentColumnFilter
 
columnQualifier - 类 中的变量org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
ColumnRangeFilter - org.apache.hadoop.hbase.filter中的类
This filter is used for selecting only those keys with columns that are between minColumn to maxColumn.
ColumnRangeFilter(byte[], boolean, byte[], boolean) - 类 的构造器org.apache.hadoop.hbase.filter.ColumnRangeFilter
Create a filter to select those keys with columns that are between minColumn and maxColumn.
COMMA - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for a comma
compact(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Compact a table.
compact(TableName, byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Compact a column family within a table.
compact(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Compact a table.
compact(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
compact(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
compact(TableName, byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Compact a column family within a table.
compact(String, String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
compact(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
COMPACTION_ENABLED - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Used by HBase Shell interface to access this metadata attribute which denotes if the table is compaction enabled
compactRegion(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Compact an individual region.
compactRegion(byte[], byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Compact a column family within a region.
compactRegion(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Compact an individual region.
compactRegion(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Compact a column family within a region.
compactRegionServer(ServerName, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Compact all regions on the region server
compactRegionServer(ServerName, boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Compact all regions on the region server
comparator - 类 中的变量org.apache.hadoop.hbase.filter.CompareFilter
 
comparator - 类 中的变量org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
compare(BigDecimal, BigDecimal) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
compare(Double, Double) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
compare(Long, Long) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
compare(T, T) - 类 中的方法org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
This takes care if either of arguments are null. returns 0 if they are equal or both are null; > 0 if l1 > l2 or l1 is not null and l2 is null.
compareCell(Cell, Cell) - 类 中的方法org.apache.hadoop.hbase.filter.FilterListBase
 
CompareFilter - org.apache.hadoop.hbase.filter中的类
This is a generic filter to be used to filter by comparison.
CompareFilter(CompareFilter.CompareOp, ByteArrayComparable) - 类 的构造器org.apache.hadoop.hbase.filter.CompareFilter
Constructor.
CompareFilter.CompareOp - org.apache.hadoop.hbase.filter中的枚举
Comparison operators.
compareOp - 类 中的变量org.apache.hadoop.hbase.filter.CompareFilter
 
compareOp - 类 中的变量org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
compareResults(Result, Result) - 类 中的静态方法org.apache.hadoop.hbase.client.Result
Does a deep comparison of two Results, down to the byte arrays.
compareTo(Object) - 类 中的方法org.apache.hadoop.hbase.client.Action
 
compareTo(Row) - 类 中的方法org.apache.hadoop.hbase.client.Get
 
compareTo(Row) - 类 中的方法org.apache.hadoop.hbase.client.Increment
 
compareTo(Row) - 类 中的方法org.apache.hadoop.hbase.client.Mutation
 
compareTo(Row) - 类 中的方法org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
 
compareTo(Row) - 类 中的方法org.apache.hadoop.hbase.client.RowMutations
 
compareTo(byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.filter.BinaryComparator
 
compareTo(byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.filter.BinaryPrefixComparator
 
compareTo(byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.filter.BitComparator
 
compareTo(byte[]) - 类 中的方法org.apache.hadoop.hbase.filter.ByteArrayComparable
 
compareTo(byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.filter.ByteArrayComparable
Special compareTo method for subclasses, to avoid copying byte[] unnecessarily.
compareTo(byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.filter.LongComparator
 
compareTo(MultiRowRangeFilter.RowRange) - 类 中的方法org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
 
compareTo(byte[]) - 类 中的方法org.apache.hadoop.hbase.filter.NullComparator
 
compareTo(byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.filter.NullComparator
 
compareTo(byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.filter.RegexStringComparator
 
compareTo(byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.filter.SubstringComparator
 
compareTo(HColumnDescriptor) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
compareTo(HRegionInfo) - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
 
compareTo(HRegionLocation) - 类 中的方法org.apache.hadoop.hbase.HRegionLocation
 
compareTo(HTableDescriptor) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Compares the descriptor with another descriptor which is passed as a parameter.
compareTo(ServerName) - 类 中的方法org.apache.hadoop.hbase.ServerName
 
COMPRESS_TAGS - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
 
COMPRESSION - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
 
COMPRESSION_COMPACT - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
 
compressor - 类 中的变量org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
concurrentCallsPerServerHist - 类 中的变量org.apache.hadoop.hbase.client.MetricsConnection
 
conf - 类 中的变量org.apache.hadoop.hbase.client.ClientScanner
 
conf - 类 中的变量org.apache.hadoop.hbase.client.HConnectable
 
conf - 类 中的变量org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
 
conf - 类 中的变量org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
 
conf - 类 中的变量org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
conf - 类 中的变量org.apache.hadoop.hbase.ipc.RpcControllerFactory
 
conf - 类 中的变量org.apache.hadoop.hbase.replication.ReplicationStateZKBase
 
confirmNodeOpening(ZooKeeperWatcher, HRegionInfo, ServerName, int) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKAssign
Confirm an existing unassigned node for the specified region which is currently in the OPENING state to be still in the OPENING state on the specified server.
connect(HConnection) - 类 中的方法org.apache.hadoop.hbase.client.HConnectable
 
connect(Configuration, Watcher) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Creates a new connection to ZooKeeper, pulling settings and ensemble config from the specified configuration object using methods from ZKConfig.
connect(Configuration, String, Watcher) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
 
connect(Configuration, String, Watcher, String) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
 
connection - 类 中的变量org.apache.hadoop.hbase.client.BufferedMutatorImpl
 
Connection - org.apache.hadoop.hbase.client中的接口
A cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.
connection - 类 中的变量org.apache.hadoop.hbase.client.HTable
 
connection - 类 中的变量org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
connection - 类 中的变量org.apache.hadoop.hbase.client.RegionServerCallable
 
ConnectionClosingException - org.apache.hadoop.hbase.exceptions中的异常错误
Thrown when the client believes that we are trying to communicate to has been repeatedly unresponsive for a while.
ConnectionClosingException(String) - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.ConnectionClosingException
 
ConnectionConfiguration - org.apache.hadoop.hbase.client中的类
Configuration parameters for the connection.
ConnectionConfiguration() - 类 的构造器org.apache.hadoop.hbase.client.ConnectionConfiguration
Constructor This is for internal testing purpose (using the default value).
ConnectionFactory - org.apache.hadoop.hbase.client中的类
A non-instantiable class that manages creation of Connections.
ConnectionFactory() - 类 的构造器org.apache.hadoop.hbase.client.ConnectionFactory
No public c.tors
ConnectionId - org.apache.hadoop.hbase.ipc中的类
This class holds the address and the user ticket, etc.
ConnectionId(User, String, InetSocketAddress) - 类 的构造器org.apache.hadoop.hbase.ipc.ConnectionId
 
connections - 类 中的变量org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
ConnectionUtils - org.apache.hadoop.hbase.client中的类
Utility used by client connections.
ConnectionUtils() - 类 的构造器org.apache.hadoop.hbase.client.ConnectionUtils
 
connectTO - 类 中的变量org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
Consistency - org.apache.hadoop.hbase.client中的枚举
Consistency defines the expected consistency level for an operation.
consistency - 类 中的变量org.apache.hadoop.hbase.client.Query
 
containsColumn(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Result
Checks for existence of a value for the specified column (empty or not).
containsColumn(byte[], int, int, byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.client.Result
Checks for existence of a value for the specified column (empty or not).
containsEmptyColumn(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Result
Checks if the specified column contains an empty value (a zero-length byte array).
containsEmptyColumn(byte[], int, int, byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.client.Result
Checks if the specified column contains an empty value (a zero-length byte array).
containsKey(Object) - 类 中的方法org.apache.hadoop.hbase.util.PoolMap
 
containsNonEmptyColumn(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Result
Checks if the specified column contains a non-empty value (not a zero-length byte array).
containsNonEmptyColumn(byte[], int, int, byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.client.Result
Checks if the specified column contains a non-empty value (not a zero-length byte array).
containsRange(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
Returns true if the given inclusive range of rows is fully contained by this region.
containsRow(byte[]) - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
Return true if the given row falls in this region.
containsValue(Object) - 类 中的方法org.apache.hadoop.hbase.util.PoolMap
 
controller - 类 中的变量org.apache.hadoop.hbase.client.PayloadCarryingServerCallable
 
controller - 类 中的变量org.apache.hadoop.hbase.client.ScannerCallable
 
controllerFactory - 类 中的变量org.apache.hadoop.hbase.client.ScannerCallable
 
convert() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
已过时。
convert(ClusterStatusProtos.ClusterStatus) - 类 中的静态方法org.apache.hadoop.hbase.ClusterStatus
已过时。
convert(HBaseProtos.ColumnFamilySchema) - 类 中的静态方法org.apache.hadoop.hbase.HColumnDescriptor
已过时。
convert() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
已过时。
convert(HRegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
Convert a HRegionInfo to a RegionInfo
convert(HBaseProtos.RegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
Convert a RegionInfo to a HRegionInfo
convert() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
已过时。
convert(HBaseProtos.TableSchema) - 类 中的静态方法org.apache.hadoop.hbase.HTableDescriptor
已过时。
convert() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
Convert a RegionState to an HBaseProtos.RegionState
convert(ClusterStatusProtos.RegionState) - 类 中的静态方法org.apache.hadoop.hbase.master.RegionState
Convert a protobuf HBaseProtos.RegionState to a RegionState
convert() - 枚举 中的方法org.apache.hadoop.hbase.master.RegionState.State
Convert to protobuf ClusterStatusProtos.RegionState.State
convert(ClusterStatusProtos.RegionState.State) - 枚举 中的静态方法org.apache.hadoop.hbase.master.RegionState.State
Convert a protobuf HBaseProtos.RegionState.State to a RegionState.State
convert(Map<TableName, ? extends Collection<String>>) - 类 中的静态方法org.apache.hadoop.hbase.replication.ReplicationSerDeHelper
convert map to TableCFs Object
convert(String) - 类 中的静态方法org.apache.hadoop.hbase.replication.ReplicationSerDeHelper
Convert string to TableCFs Object.
convert(ZooKeeperProtos.TableCF[]) - 类 中的静态方法org.apache.hadoop.hbase.replication.ReplicationSerDeHelper
Convert TableCFs Object to String.
convert(DeserializationException) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Convert a DeserializationException to a more palatable KeeperException.
convert2Map(ZooKeeperProtos.TableCF[]) - 类 中的静态方法org.apache.hadoop.hbase.replication.ReplicationSerDeHelper
Convert tableCFs Object to Map.
convertByteArrayToBoolean(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.ParseFilter
Converts a boolean expressed in a byte array to an actual boolean This doesn't used Bytes.toBoolean because Bytes.toBoolean(byte []) assumes that 1 stands for true and 0 for false.
convertByteArrayToInt(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.ParseFilter
Converts an int expressed in a byte array to an actual int This doesn't use Bytes.toInt because that assumes that there will be Bytes.SIZEOF_INT bytes available.
convertByteArrayToLong(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.ParseFilter
Converts a long expressed in a byte array to an actual long This doesn't use Bytes.toLong because that assumes that there will be Bytes.SIZEOF_INT bytes available.
convertResult(MasterProtos.GetProcedureResultResponse) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
Convert the procedure result response to a specified type.
convertToString(Map<TableName, ? extends Collection<String>>) - 类 中的静态方法org.apache.hadoop.hbase.replication.ReplicationSerDeHelper
 
CoordinatedStateException - org.apache.hadoop.hbase中的异常错误
Thrown by operations requiring coordination state access or manipulation when internal error within coordination engine (or other internal implementation) occurs.
CoordinatedStateException() - 异常错误 的构造器org.apache.hadoop.hbase.CoordinatedStateException
 
CoordinatedStateException(String) - 异常错误 的构造器org.apache.hadoop.hbase.CoordinatedStateException
 
CoordinatedStateException(String, Throwable) - 异常错误 的构造器org.apache.hadoop.hbase.CoordinatedStateException
 
CoordinatedStateException(Throwable) - 异常错误 的构造器org.apache.hadoop.hbase.CoordinatedStateException
 
Coprocessor - org.apache.hadoop.hbase中的接口
Coprocessor interface.
Coprocessor.State - org.apache.hadoop.hbase中的枚举
Lifecycle state of a given coprocessor instance.
CoprocessorEnvironment - org.apache.hadoop.hbase中的接口
Coprocessor environment state.
CoprocessorException - org.apache.hadoop.hbase.coprocessor中的异常错误
Thrown if a coprocessor encounters any exception.
CoprocessorException() - 异常错误 的构造器org.apache.hadoop.hbase.coprocessor.CoprocessorException
Default Constructor
CoprocessorException(Class<?>, String) - 异常错误 的构造器org.apache.hadoop.hbase.coprocessor.CoprocessorException
Constructor with a Class object and exception message.
CoprocessorException(String) - 异常错误 的构造器org.apache.hadoop.hbase.coprocessor.CoprocessorException
Constructs the exception and supplies a string as the message
CoprocessorRpcChannel - org.apache.hadoop.hbase.ipc中的类
Base class which provides clients with an RPC connection to call coprocessor endpoint Services.
CoprocessorRpcChannel() - 类 的构造器org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
 
CoprocessorRpcUtils - org.apache.hadoop.hbase.ipc中的类
Utilities for handling coprocessor service calls.
coprocessorService() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Creates and returns a RpcChannel instance connected to the active master.
coprocessorService(ServerName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Creates and returns a RpcChannel instance connected to the passed region server.
coprocessorService() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Creates and returns a RpcChannel instance connected to the active master.
coprocessorService(ServerName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Creates and returns a RpcChannel instance connected to the passed region server.
coprocessorService(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HTable
Creates and returns a RpcChannel instance connected to the table region containing the specified row.
coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>) - 类 中的方法org.apache.hadoop.hbase.client.HTable
Creates an instance of the given Service subclass for each table region spanning the range from the startKey row to endKey row (inclusive), and invokes the passed Batch.Call.call(T) method with each Service instance.
coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>, Batch.Callback<R>) - 类 中的方法org.apache.hadoop.hbase.client.HTable
Creates an instance of the given Service subclass for each table region spanning the range from the startKey row to endKey row (inclusive), and invokes the passed Batch.Call.call(T) method with each Service instance.
coprocessorService(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Table
Creates and returns a RpcChannel instance connected to the table region containing the specified row.
coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>) - 接口 中的方法org.apache.hadoop.hbase.client.Table
Creates an instance of the given Service subclass for each table region spanning the range from the startKey row to endKey row (inclusive), and invokes the passed Batch.Call.call(T) method with each Service instance.
coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>, Batch.Callback<R>) - 接口 中的方法org.apache.hadoop.hbase.client.Table
Creates an instance of the given Service subclass for each table region spanning the range from the startKey row to endKey row (inclusive), and invokes the passed Batch.Call.call(T) method with each Service instance.
copyFrom(Result) - 类 中的方法org.apache.hadoop.hbase.client.Result
Copy another Result into this one.
copyWritable(Writable, Writable) - 类 中的静态方法org.apache.hadoop.hbase.util.Writables
Copy one Writable to another.
copyWritable(byte[], Writable) - 类 中的静态方法org.apache.hadoop.hbase.util.Writables
Copy one Writable to another.
CorruptedSnapshotException - org.apache.hadoop.hbase.snapshot中的异常错误
Exception thrown when the found snapshot info from the filesystem is not valid.
CorruptedSnapshotException(String, Exception) - 异常错误 的构造器org.apache.hadoop.hbase.snapshot.CorruptedSnapshotException
Snapshot was corrupt for some reason.
CorruptedSnapshotException(String, HBaseProtos.SnapshotDescription) - 异常错误 的构造器org.apache.hadoop.hbase.snapshot.CorruptedSnapshotException
已过时。
since 1.3.0, will be removed in 3.0.0
CorruptedSnapshotException(String) - 异常错误 的构造器org.apache.hadoop.hbase.snapshot.CorruptedSnapshotException
Snapshot was corrupt for some reason.
COUNT_OF_ROWS_FILTERED_KEY - 类 中的静态变量org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
COUNT_OF_ROWS_FILTERED_KEY_METRIC_NAME - 类 中的静态变量org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
 
COUNT_OF_ROWS_SCANNED_KEY - 类 中的静态变量org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
COUNT_OF_ROWS_SCANNED_KEY_METRIC_NAME - 类 中的静态变量org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
 
countOfBytesInRemoteResults - 类 中的变量org.apache.hadoop.hbase.client.metrics.ScanMetrics
number of bytes in Result objects from remote region servers
countOfBytesInResults - 类 中的变量org.apache.hadoop.hbase.client.metrics.ScanMetrics
number of bytes in Result objects from region servers
countOfNSRE - 类 中的变量org.apache.hadoop.hbase.client.metrics.ScanMetrics
number of NotServingRegionException caught
countOfRegions - 类 中的变量org.apache.hadoop.hbase.client.metrics.ScanMetrics
number of regions
countOfRemoteRPCcalls - 类 中的变量org.apache.hadoop.hbase.client.metrics.ScanMetrics
number of remote RPC calls
countOfRemoteRPCRetries - 类 中的变量org.apache.hadoop.hbase.client.metrics.ScanMetrics
number of remote RPC retries
countOfRowsFiltered - 类 中的变量org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
number of rows filtered during scan RPC
countOfRowsScanned - 类 中的变量org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
number of rows scanned during scan RPC.
countOfRPCcalls - 类 中的变量org.apache.hadoop.hbase.client.metrics.ScanMetrics
number of RPC calls
countOfRPCRetries - 类 中的变量org.apache.hadoop.hbase.client.metrics.ScanMetrics
number of RPC retries
create(Configuration) - 类 中的静态方法org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicyFactory
 
create(List<Cell>) - 类 中的静态方法org.apache.hadoop.hbase.client.Result
Instantiate a Result with the specified List of KeyValues.
create(List<Cell>, Boolean) - 类 中的静态方法org.apache.hadoop.hbase.client.Result
 
create(List<Cell>, Boolean, boolean) - 类 中的静态方法org.apache.hadoop.hbase.client.Result
 
create(List<Cell>, Boolean, boolean, boolean) - 类 中的静态方法org.apache.hadoop.hbase.client.Result
 
create(Cell[]) - 类 中的静态方法org.apache.hadoop.hbase.client.Result
Instantiate a Result with the specified array of KeyValues.
create(Cell[], Boolean, boolean) - 类 中的静态方法org.apache.hadoop.hbase.client.Result
 
create(Cell[], Boolean, boolean, boolean) - 类 中的静态方法org.apache.hadoop.hbase.client.Result
 
create(Configuration) - 类 中的静态方法org.apache.hadoop.hbase.client.ServerStatisticTracker
 
create(String, byte[], List<ACL>, CreateMode) - 类 中的方法org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
NONSEQUENTIAL create is idempotent operation.
createACL(ZooKeeperWatcher, String, boolean) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
 
createAndAddPeer(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
Attempt to connect to a new remote slave cluster.
createAndFailSilent(ZooKeeperWatcher, String) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Creates the specified node, iff the node does not exist.
createAndFailSilent(ZooKeeperWatcher, String, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Creates the specified node containing specified data, iff the node does not exist.
createAndFailSilent(String, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
 
createAndWatch(ZooKeeperWatcher, String, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Creates the specified node with the specified data and watches it.
createBlockingRpcChannel(ServerName, User, int) - 类 中的方法org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
createBlockingRpcChannel(ServerName, User, int) - 接口 中的方法org.apache.hadoop.hbase.ipc.RpcClient
Creates a "channel" that can be used by a blocking protobuf service.
createClient(Configuration, String) - 类 中的静态方法org.apache.hadoop.hbase.ipc.RpcClientFactory
Helper method for tests only.
createClient(Configuration, String, MetricsConnection) - 类 中的静态方法org.apache.hadoop.hbase.ipc.RpcClientFactory
Creates a new RpcClient by the class defined in the configuration or falls back to RpcClientImpl
createClient(Configuration, String, SocketAddress, MetricsConnection) - 类 中的静态方法org.apache.hadoop.hbase.ipc.RpcClientFactory
Creates a new RpcClient by the class defined in the configuration or falls back to RpcClientImpl
createComparator(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.ParseFilter
Parses a comparator of the form comparatorType:comparatorValue form and returns a comparator
createCompareOp(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.ParseFilter
Takes a compareOperator symbol as a byte array and returns the corresponding CompareOperator
createCompleteResult(List<Result>) - 类 中的静态方法org.apache.hadoop.hbase.client.Result
已过时。 
createCompleteResult(Iterable<Result>) - 类 中的静态方法org.apache.hadoop.hbase.client.Result
Forms a single result from the partial results in the partialResults list.
createConnection() - 类 中的静态方法org.apache.hadoop.hbase.client.ConnectionFactory
Create a new Connection instance using default HBaseConfiguration.
createConnection(Configuration) - 类 中的静态方法org.apache.hadoop.hbase.client.ConnectionFactory
Create a new Connection instance using the passed conf instance.
createConnection(Configuration, ExecutorService) - 类 中的静态方法org.apache.hadoop.hbase.client.ConnectionFactory
Create a new Connection instance using the passed conf instance.
createConnection(Configuration, User) - 类 中的静态方法org.apache.hadoop.hbase.client.ConnectionFactory
Create a new Connection instance using the passed conf instance.
createConnection(Configuration, ExecutorService, User) - 类 中的静态方法org.apache.hadoop.hbase.client.ConnectionFactory
Create a new Connection instance using the passed conf instance.
createConnection(Configuration) - 类 中的静态方法org.apache.hadoop.hbase.client.HConnectionManager
已过时。
createConnection(Configuration, ExecutorService) - 类 中的静态方法org.apache.hadoop.hbase.client.HConnectionManager
已过时。
createConnection(Configuration, User) - 类 中的静态方法org.apache.hadoop.hbase.client.HConnectionManager
已过时。
createConnection(Configuration, ExecutorService, User) - 类 中的静态方法org.apache.hadoop.hbase.client.HConnectionManager
已过时。
createConnection(ConnectionId) - 类 中的方法org.apache.hadoop.hbase.ipc.AbstractRpcClient
Not connected.
createConnection(ConnectionId) - 类 中的方法org.apache.hadoop.hbase.ipc.BlockingRpcClient
Creates a connection.
createConnection(ConnectionId) - 类 中的方法org.apache.hadoop.hbase.ipc.NettyRpcClient
 
createCounter(String) - 类 中的方法org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
Create a new counter with the specified name
createCursor(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.client.ClientUtil
 
createCursorResult(Cursor) - 类 中的静态方法org.apache.hadoop.hbase.client.Result
 
createDigestSaslClient(String[], String, CallbackHandler) - 类 中的方法org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
 
createEphemeralNodeAndWatch(ZooKeeperWatcher, String, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Set the specified znode to be an ephemeral node carrying the specified data.
createEventLoopPerClient(Configuration) - 类 中的静态方法org.apache.hadoop.hbase.ipc.NettyRpcClientConfigHelper
The AsyncRpcClient will create its own NioEventLoopGroup.
createFilterFromArguments(ArrayList<byte[]>) - 类 中的静态方法org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
createFilterFromArguments(ArrayList<byte[]>) - 类 中的静态方法org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
createFilterFromArguments(ArrayList<byte[]>) - 类 中的静态方法org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
createFilterFromArguments(ArrayList<byte[]>) - 类 中的静态方法org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
createFilterFromArguments(ArrayList<byte[]>) - 类 中的静态方法org.apache.hadoop.hbase.filter.DependentColumnFilter
 
createFilterFromArguments(ArrayList<byte[]>) - 类 中的静态方法org.apache.hadoop.hbase.filter.FamilyFilter
 
createFilterFromArguments(ArrayList<byte[]>) - 类 中的静态方法org.apache.hadoop.hbase.filter.FilterBase
Given the filter's arguments it constructs the filter
createFilterFromArguments(ArrayList<byte[]>) - 类 中的静态方法org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
createFilterFromArguments(ArrayList<byte[]>) - 类 中的静态方法org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
createFilterFromArguments(ArrayList<byte[]>) - 类 中的静态方法org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
createFilterFromArguments(ArrayList<byte[]>) - 类 中的静态方法org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
createFilterFromArguments(ArrayList<byte[]>) - 类 中的静态方法org.apache.hadoop.hbase.filter.PageFilter
 
createFilterFromArguments(ArrayList<byte[]>) - 类 中的静态方法org.apache.hadoop.hbase.filter.PrefixFilter
 
createFilterFromArguments(ArrayList<byte[]>) - 类 中的静态方法org.apache.hadoop.hbase.filter.QualifierFilter
 
createFilterFromArguments(ArrayList<byte[]>) - 类 中的静态方法org.apache.hadoop.hbase.filter.RowFilter
 
createFilterFromArguments(ArrayList<byte[]>) - 类 中的静态方法org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
 
createFilterFromArguments(ArrayList<byte[]>) - 类 中的静态方法org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
createFilterFromArguments(ArrayList<byte[]>) - 类 中的静态方法org.apache.hadoop.hbase.filter.TimestampsFilter
 
createFilterFromArguments(ArrayList<byte[]>) - 类 中的静态方法org.apache.hadoop.hbase.filter.ValueFilter
 
createHTable(String) - 类 中的方法org.apache.hadoop.hbase.client.HTablePool
已过时。
 
createHTableInterface(Configuration, byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HTableFactory
已过时。
 
createHTableInterface(Configuration, byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.HTableInterfaceFactory
已过时。
Creates a new HTableInterface.
createKerberosSaslClient(String[], String, String) - 类 中的方法org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
 
createNamespace(NamespaceDescriptor) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Create a new namespace
createNamespace(NamespaceDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Create a new namespace
createNodeClosing(ZooKeeperWatcher, HRegionInfo, ServerName) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKAssign
Creates a new unassigned node in the CLOSING state for the specified region.
createNodeIfNotExistsAndWatch(ZooKeeperWatcher, String, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Creates the specified znode to be a persistent node carrying the specified data.
createNodeIfNotExistsNoWatch(ZooKeeperWatcher, String, byte[], CreateMode) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Creates the specified znode with the specified data but does not watch it.
createNodeOffline(ZooKeeperWatcher, HRegionInfo, ServerName) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKAssign
Creates a new unassigned node in the OFFLINE state for the specified region.
createNodeOffline(ZooKeeperWatcher, HRegionInfo, ServerName, EventType) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKAssign
 
createOrForceNodeOffline(ZooKeeperWatcher, HRegionInfo, ServerName) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKAssign
Creates or force updates an unassigned node to the OFFLINE state for the specified region.
createPool() - 类 中的方法org.apache.hadoop.hbase.util.PoolMap
 
createRegionName(TableName, byte[], long, boolean) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
Make a region name of passed parameters.
createRegionName(TableName, byte[], String, boolean) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
Make a region name of passed parameters.
createRegionName(TableName, byte[], long, int, boolean) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
Make a region name of passed parameters.
createRegionName(TableName, byte[], byte[], boolean) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
Make a region name of passed parameters.
createRegionName(TableName, byte[], byte[], int, boolean) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
Make a region name of passed parameters.
createRegionTransition(EventType, byte[], ServerName) - 类 中的静态方法org.apache.hadoop.hbase.RegionTransition
 
createRegionTransition(EventType, byte[], ServerName, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.RegionTransition
 
createRpcChannel(ServerName, User, int) - 类 中的方法org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
createRpcChannel(ServerName, User, int) - 接口 中的方法org.apache.hadoop.hbase.ipc.RpcClient
Creates a "channel" that can be used by a protobuf service.
createScanFromCursor(Cursor) - 类 中的静态方法org.apache.hadoop.hbase.client.Scan
Create a new Scan with a cursor.
createScannerCallable() - 类 中的方法org.apache.hadoop.hbase.client.ClientScanner
Will be called in moveToNextRegion to create ScannerCallable.
createScannerCallable() - 类 中的方法org.apache.hadoop.hbase.client.ClientSimpleScanner
 
createScannerCallable() - 类 中的方法org.apache.hadoop.hbase.client.ReversedClientScanner
 
createScanResultCache(Scan, List<Result>) - 类 中的静态方法org.apache.hadoop.hbase.client.ConnectionUtils
 
createSetData(ZooKeeperWatcher, String, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Set data into node creating node if it doesn't yet exist.
createShortCircuitConnection(Configuration, ExecutorService, User, ServerName, AdminProtos.AdminService.BlockingInterface, ClientProtos.ClientService.BlockingInterface) - 类 中的静态方法org.apache.hadoop.hbase.client.ConnectionUtils
Creates a short-circuit connection that can bypass the RPC layer (serialization, deserialization, networking, etc..) when talking to a local server.
createShortCircuitHConnection(Connection, ServerName, AdminProtos.AdminService.BlockingInterface, ClientProtos.ClientService.BlockingInterface) - 类 中的静态方法org.apache.hadoop.hbase.client.ConnectionUtils
已过时。
createTable(HTableDescriptor) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Creates a new table.
createTable(HTableDescriptor, byte[], byte[], int) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Creates a new table with the specified number of regions.
createTable(HTableDescriptor, byte[][]) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Creates a new table with an initial set of empty regions defined by the specified split keys.
createTable(HTableDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Creates a new table.
createTable(HTableDescriptor, byte[], byte[], int) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Creates a new table with the specified number of regions.
createTable(HTableDescriptor, byte[][]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Creates a new table with an initial set of empty regions defined by the specified split keys.
createTableAsync(HTableDescriptor, byte[][]) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Creates a new table but does not block and wait for it to come online.
createTableAsync(HTableDescriptor, byte[][]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Creates a new table but does not block and wait for it to come online.
createTreeSet() - 类 中的方法org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
createUnescapdArgument(byte[], int, int) - 类 中的静态方法org.apache.hadoop.hbase.filter.ParseFilter
Removes the single quote escaping a single quote - thus it returns an unescaped argument
createWithParents(ZooKeeperWatcher, String) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Creates the specified node and all parent nodes required for it to exist.
createWithParents(ZooKeeperWatcher, String, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Creates the specified node and all parent nodes required for it to exist.
CREATOR_ALL_AND_WORLD_READABLE - 类 中的静态变量org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
current() - 类 中的方法org.apache.hadoop.hbase.client.Result
 
currentRegion - 类 中的变量org.apache.hadoop.hbase.client.ClientScanner
 
Cursor - org.apache.hadoop.hbase.client中的类
Scan cursor to tell client where server is scanning Scan.setNeedCursorResult(boolean) Result.isCursor() Result.getCursor()
cursor - 类 中的变量org.apache.hadoop.hbase.client.ScannerCallable
 
CUSTOM_CALLER_CONF_KEY - 类 中的静态变量org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
Configuration key for a custom RpcRetryingCaller
CUSTOM_CONTROLLER_CONF_KEY - 类 中的静态变量org.apache.hadoop.hbase.ipc.RpcControllerFactory
Custom RPC Controller factory allows frameworks to change the RPC controller.
CUSTOM_RPC_CLIENT_IMPL_CONF_KEY - 类 中的静态变量org.apache.hadoop.hbase.ipc.RpcClientFactory
 

D

D - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'D'
DATA_BLOCK_ENCODING - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - 类 中的方法org.apache.hadoop.hbase.security.SaslChallengeDecoder
 
decodeRemoteException(RemoteException) - 类 中的静态方法org.apache.hadoop.hbase.RemoteExceptionHandler
已过时。
Use RemoteException.unwrapRemoteException() instead. In fact we should look into deprecating this whole class - St.Ack 2010929
DEFAULT_ATTRIBUTE_EARLY_OUT - 接口 中的静态变量org.apache.hadoop.hbase.security.access.AccessControlConstants
Default setting for hbase.security.access.early_out
DEFAULT_BLOCKCACHE - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
Default setting for whether to use a block cache or not.
DEFAULT_BLOCKSIZE - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
Default size of blocks in files stored to the filesytem (hfiles).
DEFAULT_BLOOMFILTER - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
Default setting for whether or not to use bloomfilters.
DEFAULT_CACHE_BLOOMS_ON_WRITE - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
Default setting for whether to cache bloom filter blocks on write if block caching is enabled.
DEFAULT_CACHE_DATA_IN_L1 - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
Default setting for whether to cache data blocks in L1 tier.
DEFAULT_CACHE_DATA_ON_WRITE - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
Default setting for whether to cache data blocks on write if block caching is enabled.
DEFAULT_CACHE_INDEX_ON_WRITE - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
Default setting for whether to cache index blocks on write if block caching is enabled.
DEFAULT_CODEC_CLASS - 接口 中的静态变量org.apache.hadoop.hbase.ipc.RpcClient
 
DEFAULT_COMPACTION_ENABLED - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
Constant that denotes whether the table is compaction enabled by default
DEFAULT_COMPRESS_TAGS - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
Default compress tags along with any type of DataBlockEncoding.
DEFAULT_COMPRESSION - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
Default compression type.
DEFAULT_DATA_BLOCK_ENCODING - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
Default data block encoding algorithm.
DEFAULT_DFS_REPLICATION - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
 
DEFAULT_ENCODE_ON_DISK - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
Default value of the flag that enables data block encoding on disk, as opposed to encoding in cache only.
DEFAULT_EVICT_BLOCKS_ON_CLOSE - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
Default setting for whether to evict cached blocks from the blockcache on close.
DEFAULT_EXEC_PERMISSION_CHECKS - 接口 中的静态变量org.apache.hadoop.hbase.security.access.AccessControlConstants
Default setting for hbase.security.exec.permission.checks; false
DEFAULT_IN_MEMORY - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
Default setting for whether to try and serve this column family from memory or not.
DEFAULT_KEEP_DELETED - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
Default setting for preventing deleted from being collected immediately.
DEFAULT_MAX_BACKOFF - 类 中的静态变量org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
 
DEFAULT_MEMSTORE_FLUSH_SIZE - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
Constant that denotes the maximum default size of the memstore after which the contents are flushed to the store files
DEFAULT_MIN_VERSIONS - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
Default is not to keep a minimum of versions.
DEFAULT_NORMALIZATION_ENABLED - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
Constant that denotes whether the table is normalized by default.
DEFAULT_PREFETCH_BLOCKS_ON_OPEN - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
 
DEFAULT_READONLY - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
Constant that denotes whether the table is READONLY by default and is false
DEFAULT_REGION_MEMSTORE_REPLICATION - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
 
DEFAULT_REGION_REPLICA_WAIT_FOR_PRIMARY_FLUSH - 类 中的静态变量org.apache.hadoop.hbase.client.RegionReplicaUtil
 
DEFAULT_REGION_REPLICATION - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
 
DEFAULT_REPLICA_ID - 类 中的静态变量org.apache.hadoop.hbase.HRegionInfo
 
DEFAULT_REPLICATION_SCOPE - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
Default scope.
DEFAULT_SOCKET_TIMEOUT_CONNECT - 接口 中的静态变量org.apache.hadoop.hbase.ipc.RpcClient
 
DEFAULT_SOCKET_TIMEOUT_READ - 接口 中的静态变量org.apache.hadoop.hbase.ipc.RpcClient
 
DEFAULT_SOCKET_TIMEOUT_WRITE - 接口 中的静态变量org.apache.hadoop.hbase.ipc.RpcClient
 
DEFAULT_TTL - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
Default time to live of cell contents.
DEFAULT_VERSIONS - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
Default number of versions of a record to keep.
DEFERRED_LOG_FLUSH - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
已过时。
DelayingRunner<T> - org.apache.hadoop.hbase.client中的类
A wrapper for a runnable for a group of actions for a single regionserver.
DelayingRunner(long, Map.Entry<byte[], List<Action<T>>>) - 类 的构造器org.apache.hadoop.hbase.client.DelayingRunner
 
delegate - 类 中的变量org.apache.hadoop.hbase.client.DelegatingRetryingCallable
 
DelegatingHBaseRpcController - org.apache.hadoop.hbase.ipc中的类
Simple delegating controller for use with the RpcControllerFactory to help override standard behavior of a HBaseRpcController.
DelegatingHBaseRpcController(HBaseRpcController) - 类 的构造器org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
DelegatingRetryingCallable<T,D extends RetryingCallable<T>> - org.apache.hadoop.hbase.client中的类
Helper callable for internal use when you just want to override a single method of a RetryingCallable.
DelegatingRetryingCallable(D) - 类 的构造器org.apache.hadoop.hbase.client.DelegatingRetryingCallable
 
Delete - org.apache.hadoop.hbase.client中的类
Used to perform Delete operations on a single row.
Delete(byte[]) - 类 的构造器org.apache.hadoop.hbase.client.Delete
Create a Delete operation for the specified row.
Delete(byte[], long) - 类 的构造器org.apache.hadoop.hbase.client.Delete
Create a Delete operation for the specified row and timestamp.
Delete(byte[], int, int) - 类 的构造器org.apache.hadoop.hbase.client.Delete
Create a Delete operation for the specified row and timestamp.
Delete(byte[], int, int, long) - 类 的构造器org.apache.hadoop.hbase.client.Delete
Create a Delete operation for the specified row and timestamp.
Delete(Delete) - 类 的构造器org.apache.hadoop.hbase.client.Delete
 
delete(Delete) - 类 中的方法org.apache.hadoop.hbase.client.HTable
Deletes the specified cells/row.
delete(List<Delete>) - 类 中的方法org.apache.hadoop.hbase.client.HTable
Deletes the specified cells/rows in bulk.
delete(Delete) - 接口 中的方法org.apache.hadoop.hbase.client.Table
Deletes the specified cells/row.
delete(List<Delete>) - 接口 中的方法org.apache.hadoop.hbase.client.Table
Deletes the specified cells/rows in bulk.
delete(String, int) - 类 中的方法org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
delete is an idempotent operation.
deleteAllConnections(boolean) - 类 中的静态方法org.apache.hadoop.hbase.client.HConnectionManager
已过时。 
deleteAllConnections() - 类 中的静态方法org.apache.hadoop.hbase.client.HConnectionManager
已过时。
kept for backward compatibility, but the behavior is broken. HBASE-8983
deleteAllNodes(ZooKeeperWatcher) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKAssign
Deletes all unassigned nodes regardless of their state.
deleteCachedRegionLocation(HRegionLocation) - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
Deletes cached locations for the specific region.
deleteCachedRegionLocation(HRegionLocation) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
internal method, do not use thru HConnection
deleteChildrenRecursively(ZooKeeperWatcher, String) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Delete all the children of the specified node but not the node itself.
deleteChildrenRecursivelyMultiOrSequential(ZooKeeperWatcher, boolean, String...) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Delete all the children of the specified node but not the node itself.
deleteClosedNode(ZooKeeperWatcher, String, ServerName) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKAssign
Deletes an existing unassigned node that is in the CLOSED state for the specified region.
deleteClosingNode(ZooKeeperWatcher, HRegionInfo, ServerName) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKAssign
Deletes an existing unassigned node that is in the CLOSING state for the specified region.
deleteColumn(TableName, byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Delete a column from a table.
deleteColumn(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Delete
已过时。
Since hbase-1.0.0. Use Delete.addColumn(byte[], byte[])
deleteColumn(byte[], byte[], long) - 类 中的方法org.apache.hadoop.hbase.client.Delete
已过时。
deleteColumn(byte[], String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Delete a column from a table.
deleteColumn(String, String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Delete a column from a table.
deleteColumn(TableName, byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Delete a column from a table.
deleteColumns(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Delete
已过时。
Since hbase-1.0.0. Use Delete.addColumns(byte[], byte[])
deleteColumns(byte[], byte[], long) - 类 中的方法org.apache.hadoop.hbase.client.Delete
已过时。
deleteConnection(Configuration) - 类 中的静态方法org.apache.hadoop.hbase.client.HConnectionManager
已过时。 
deleteFamily(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Delete
已过时。
Since 1.0.0. Use Delete.addFamily(byte[])
deleteFamily(byte[], long) - 类 中的方法org.apache.hadoop.hbase.client.Delete
已过时。
deleteFamilyVersion(byte[], long) - 类 中的方法org.apache.hadoop.hbase.client.Delete
已过时。
deleteFromMetaTable(Connection, List<Delete>) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Delete the passed deletes from the hbase:meta table.
deleteIfEquals(ZooKeeperWatcher, String) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
delete the master znode if its content is same as the parameter
deleteMergeQualifiers(Connection, HRegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Deletes merge qualifiers for the specified merged region.
deleteMetaLocation(ZooKeeperWatcher) - 类 中的方法org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Deletes the location of hbase:meta in ZooKeeper.
deleteMetaLocation(ZooKeeperWatcher, int) - 类 中的方法org.apache.hadoop.hbase.zookeeper.MetaTableLocator
 
deleteNamespace(String) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Delete an existing namespace.
deleteNamespace(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Delete an existing namespace.
deleteNode(ZooKeeperWatcher, String, EventType, ServerName) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKAssign
Deletes an existing unassigned node that is in the specified state for the specified region.
deleteNode(ZooKeeperWatcher, String, EventType, int) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKAssign
Deletes an existing unassigned node that is in the specified state for the specified region.
deleteNode(ZooKeeperWatcher, String, EventType, ServerName, int) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKAssign
Deletes an existing unassigned node that is in the specified state for the specified region.
deleteNode(ZooKeeperWatcher, String) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Delete the specified node.
deleteNode(ZooKeeperWatcher, String, int) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Delete the specified node with the specified version.
deleteNodeFailSilent(ZooKeeperWatcher, HRegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKAssign
Delete the assignment node regardless of its current state.
deleteNodeFailSilent(ZooKeeperWatcher, String) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Deletes the specified node.
deleteNodeFailSilent(String) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
 
deleteNodeRecursively(ZooKeeperWatcher, String) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Delete the specified node and all of it's children.
deleteNodeRecursivelyMultiOrSequential(ZooKeeperWatcher, boolean, String...) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Delete the specified node and its children.
deleteOfflineNode(ZooKeeperWatcher, String, ServerName) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKAssign
Deletes an existing unassigned node that is in the OFFLINE state for the specified region.
deleteOpenedNode(ZooKeeperWatcher, String, ServerName) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKAssign
Deletes an existing unassigned node that is in the OPENED state for the specified region.
deleteRegion(Connection, HRegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Deletes the specified region from META.
deleteRegions(Connection, List<HRegionInfo>, long) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Deletes the specified regions from META.
deleteRegions(Connection, List<HRegionInfo>) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Deletes the specified regions from META.
deleteSnapshot(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Delete an existing snapshot.
deleteSnapshot(String) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Delete an existing snapshot.
deleteSnapshot(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Delete an existing snapshot.
deleteSnapshot(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Delete an existing snapshot.
deleteSnapshots(String) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Delete existing snapshots whose names match the pattern passed.
deleteSnapshots(Pattern) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Delete existing snapshots whose names match the pattern passed.
deleteSnapshots(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Delete existing snapshots whose names match the pattern passed.
deleteSnapshots(Pattern) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Delete existing snapshots whose names match the pattern passed.
deleteStaleConnection(HConnection) - 类 中的静态方法org.apache.hadoop.hbase.client.HConnectionManager
已过时。 
deleteTable(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Deletes a table.
deleteTable(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
deleteTable(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
deleteTable(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Deletes a table.
deleteTables(String) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Deletes tables matching the passed in pattern and wait on completion.
deleteTables(Pattern) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Delete tables matching the passed in pattern and wait on completion.
deleteTables(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Deletes tables matching the passed in pattern and wait on completion.
deleteTables(Pattern) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Delete tables matching the passed in pattern and wait on completion.
deleteTableSnapshots(String, String) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Delete all existing snapshots matching the given table name regular expression and snapshot name regular expression.
deleteTableSnapshots(Pattern, Pattern) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Delete all existing snapshots matching the given table name regular expression and snapshot name regular expression.
deleteTableSnapshots(String, String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Delete all existing snapshots matching the given table name regular expression and snapshot name regular expression.
deleteTableSnapshots(Pattern, Pattern) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Delete all existing snapshots matching the given table name regular expression and snapshot name regular expression.
deleteTracker - 类 中的变量org.apache.hadoop.hbase.client.MetricsConnection
 
DependentColumnFilter - org.apache.hadoop.hbase.filter中的类
A filter for adding inter-column timestamp matching Only cells with a correspondingly timestamped entry in the target column will be retained Not compatible with Scan.setBatch as operations need full rows for correct filtering
DependentColumnFilter(byte[], byte[], boolean, CompareFilter.CompareOp, ByteArrayComparable) - 类 的构造器org.apache.hadoop.hbase.filter.DependentColumnFilter
Build a dependent column filter with value checking dependent column varies will be compared using the supplied compareOp and comparator, for usage of which refer to CompareFilter
DependentColumnFilter(byte[], byte[]) - 类 的构造器org.apache.hadoop.hbase.filter.DependentColumnFilter
Constructor for DependentColumn filter.
DependentColumnFilter(byte[], byte[], boolean) - 类 的构造器org.apache.hadoop.hbase.filter.DependentColumnFilter
Constructor for DependentColumn filter.
DeserializationException - org.apache.hadoop.hbase.exceptions中的异常错误
Failed deserialization.
DeserializationException() - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.DeserializationException
 
DeserializationException(String) - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.DeserializationException
 
DeserializationException(String, Throwable) - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.DeserializationException
 
DeserializationException(Throwable) - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.DeserializationException
 
DFS_REPLICATION - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
 
DISABLED_ZNODE_BYTES - 类 中的静态变量org.apache.hadoop.hbase.replication.ReplicationStateZKBase
 
disablePeer(String) - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Stop the replication stream to the specified peer.
disablePeer(String) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeers
Stop the replication to the specified remote slave cluster.
disablePeer(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
disableTable(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Disable table and wait on completion.
disableTable(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Disable table and wait on completion.
disableTable(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
disableTable(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
disableTableAsync(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Starts the disable of a table.
disableTableAsync(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Starts the disable of a table.
disableTableAsync(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
disableTableAsync(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
disableTableRep(TableName) - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Disable a table's replication switch.
disableTables(String) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Disable tables matching the passed in pattern and wait on completion.
disableTables(Pattern) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Disable tables matching the passed in pattern and wait on completion.
disableTables(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Disable tables matching the passed in pattern and wait on completion.
disableTables(Pattern) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Disable tables matching the passed in pattern and wait on completion.
dispose() - 类 中的方法org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
Release resources used by wrapped saslClient
divideForAvg(BigDecimal, Long) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
divideForAvg(Double, Long) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
divideForAvg(Long, Long) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
divideForAvg(S, Long) - 类 中的方法org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
used for computing average of <S> data values.
doCompare(CompareFilter.CompareOp, ByteArrayComparable, byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.filter.CompareFilter
 
doGet(Connection, Get) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
doGet(Connection, List<Get>) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
doLoadColumnFamiliesOnDemand() - 类 中的方法org.apache.hadoop.hbase.client.Query
Get the logical value indicating whether on-demand CF loading should be allowed.
DoNotRetryIOException - org.apache.hadoop.hbase中的异常错误
Subclass if exception is not meant to be retried: e.g.
DoNotRetryIOException() - 异常错误 的构造器org.apache.hadoop.hbase.DoNotRetryIOException
 
DoNotRetryIOException(String) - 异常错误 的构造器org.apache.hadoop.hbase.DoNotRetryIOException
 
DoNotRetryIOException(String, Throwable) - 异常错误 的构造器org.apache.hadoop.hbase.DoNotRetryIOException
 
DoNotRetryIOException(Throwable) - 异常错误 的构造器org.apache.hadoop.hbase.DoNotRetryIOException
 
DoNotRetryRegionException - org.apache.hadoop.hbase.client中的异常错误
Similar to RegionException, but disables retries.
DoNotRetryRegionException() - 异常错误 的构造器org.apache.hadoop.hbase.client.DoNotRetryRegionException
 
DoNotRetryRegionException(String) - 异常错误 的构造器org.apache.hadoop.hbase.client.DoNotRetryRegionException
 
DoubleColumnInterpreter - org.apache.hadoop.hbase.client.coprocessor中的类
a concrete column interpreter implementation.
DoubleColumnInterpreter() - 类 的构造器org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
drainingZNode - 类 中的变量org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
dropDependentColumn - 类 中的变量org.apache.hadoop.hbase.filter.DependentColumnFilter
 
dropDependentColumn() - 类 中的方法org.apache.hadoop.hbase.filter.DependentColumnFilter
 
DroppedSnapshotException - org.apache.hadoop.hbase中的异常错误
Thrown during flush if the possibility snapshot content was not properly persisted into store files.
DroppedSnapshotException() - 异常错误 的构造器org.apache.hadoop.hbase.DroppedSnapshotException
 
DroppedSnapshotException(String) - 异常错误 的构造器org.apache.hadoop.hbase.DroppedSnapshotException
 
dump(ZooKeeperWatcher) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
 
Durability - org.apache.hadoop.hbase.client中的枚举
Enum describing the durability guarantees for tables and Mutations Note that the items must be sorted in order of increasing durability
durability - 类 中的变量org.apache.hadoop.hbase.client.Mutation
 
DURABILITY - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Durability setting for the table.

E

E - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'E'
EMPTY_RESULT - 类 中的静态变量org.apache.hadoop.hbase.client.Result
 
EMPTY_SERVER_LIST - 类 中的静态变量org.apache.hadoop.hbase.ServerName
 
EMPTY_SERVERLOAD - 类 中的静态变量org.apache.hadoop.hbase.ServerLoad
 
EmptyWatcher - org.apache.hadoop.hbase.zookeeper中的类
An empty ZooKeeper watcher
enableCatalogJanitor(boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Enable/Disable the catalog janitor
enableCatalogJanitor(boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Enable/Disable the catalog janitor
ENABLED_ZNODE_BYTES - 类 中的静态变量org.apache.hadoop.hbase.replication.ReplicationStateZKBase
 
enablePeer(String) - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Restart the replication stream to the specified peer.
enablePeer(String) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeers
Restart the replication to the specified remote slave cluster.
enablePeer(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
enableTable(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Enable a table.
enableTable(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Enable a table.
enableTable(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
enableTable(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
enableTableAsync(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Brings a table on-line (enables it).
enableTableAsync(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Brings a table on-line (enables it).
enableTableAsync(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
enableTableAsync(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
enableTableRep(TableName) - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Enable a table's replication switch.
enableTables(String) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Enable tables matching the passed in pattern and wait on completion.
enableTables(Pattern) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Enable tables matching the passed in pattern and wait on completion.
enableTables(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Enable tables matching the passed in pattern and wait on completion.
enableTables(Pattern) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Enable tables matching the passed in pattern and wait on completion.
ENCODE_ON_DISK - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
 
ENCODED_REGION_NAME_REGEX - 类 中的静态变量org.apache.hadoop.hbase.HRegionInfo
A non-capture group so that this can be embedded.
encodeRegionName(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
 
ENCRYPTION - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
 
ENCRYPTION_KEY - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
 
EncryptionUtil - org.apache.hadoop.hbase.security中的类
Some static utility methods for encryption uses in hbase-client.
EncryptionUtil() - 类 的构造器org.apache.hadoop.hbase.security.EncryptionUtil
 
entrySet() - 类 中的方法org.apache.hadoop.hbase.util.PoolMap
 
EQUAL_TO - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for equal to (=)
EQUAL_TO_ARRAY - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
EQUAL_TO Array
EQUAL_TO_BUFFER - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.client.Action
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.client.Get
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.client.Increment
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.client.RowMutations
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.filter.CompareFilter
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.filter.DependentColumnFilter
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.filter.FamilyFilter
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.filter.FilterList
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.filter.FilterListWithAND
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.filter.FilterListWithOR
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.filter.FuzzyRowFilter
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.filter.NullComparator
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.filter.PageFilter
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.filter.PrefixFilter
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.filter.QualifierFilter
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.filter.RandomRowFilter
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.filter.RowFilter
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.filter.SkipFilter
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.filter.TimestampsFilter
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.filter.ValueFilter
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.filter.WhileMatchFilter
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.HRegionLocation
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Compare the contents of the descriptor with another one passed as a parameter.
equals(Object) - 类 中的方法org.apache.hadoop.hbase.ipc.ConnectionId
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.master.RegionState
Check if two states are the same, except timestamp
equals(Object) - 类 中的方法org.apache.hadoop.hbase.security.access.Permission
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.security.access.TablePermission
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.security.access.UserPermission
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.ServerLoad
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.ServerName
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.CreateAndFailSilent
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.DeleteNodeFailSilent
 
equals(Object) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.SetData
 
errorText() - 类 中的方法org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
errorText() - 类 中的方法org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
errorText() - 类 中的方法org.apache.hadoop.hbase.ipc.ServerRpcController
 
evaluateChallenge(byte[]) - 类 中的方法org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
 
EVENT_LOOP_CONFIG - 类 中的静态变量org.apache.hadoop.hbase.ipc.NettyRpcClientConfigHelper
 
EventType - org.apache.hadoop.hbase.executor中的枚举
List of all HBase event handler types.
EVICT_BLOCKS_ON_CLOSE - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
 
exceptionCaught(ChannelHandlerContext, Throwable) - 类 中的方法org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClientHandler
 
EXEC_PERMISSION_CHECKS_KEY - 接口 中的静态变量org.apache.hadoop.hbase.security.access.AccessControlConstants
Configuration option that toggles whether EXEC permission checking is performed during coprocessor endpoint invocations.
execProcedure(String, String, Map<String, String>) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Execute a distributed procedure on a cluster.
execProcedure(String, String, Map<String, String>) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Execute a distributed procedure on a cluster.
execProcedureWithRet(String, String, Map<String, String>) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Execute a distributed procedure on a cluster.
execProcedureWithRet(String, String, Map<String, String>) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Execute a distributed procedure on a cluster synchronously with return data
execRegionServerService(RpcController, ClientProtos.ClientService.BlockingInterface, ClientProtos.CoprocessorServiceCall) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Make a region server endpoint call
execService(RpcController, ClientProtos.ClientService.BlockingInterface, ClientProtos.CoprocessorServiceCall, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
execService(RpcController, MasterProtos.MasterService.BlockingInterface, ClientProtos.CoprocessorServiceCall) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
execute(HConnectable<T>) - 类 中的静态方法org.apache.hadoop.hbase.client.HConnectionManager
已过时。
Internal method, do not use thru HConnectionManager.
ExecutorType - org.apache.hadoop.hbase.executor中的枚举
The following is a list of all executor types, both those that run in the master and those that run in the regionserver.
exists(Get) - 类 中的方法org.apache.hadoop.hbase.client.HTable
Test for the existence of columns in the table, as specified by the Get.
exists(List<Get>) - 类 中的方法org.apache.hadoop.hbase.client.HTable
已过时。
exists(List<Get>) - 接口 中的方法org.apache.hadoop.hbase.client.HTableInterface
已过时。
exists(Get) - 接口 中的方法org.apache.hadoop.hbase.client.Table
Test for the existence of columns in the table, as specified by the Get.
exists(String, Watcher) - 类 中的方法org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
exists is an idempotent operation.
exists(String, boolean) - 类 中的方法org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
exists is an idempotent operation.
existsAll(List<Get>) - 类 中的方法org.apache.hadoop.hbase.client.HTable
Test for the existence of columns in the table, as specified by the Gets.
existsAll(List<Get>) - 接口 中的方法org.apache.hadoop.hbase.client.Table
Test for the existence of columns in the table, as specified by the Gets.
expectPBMagicPrefix(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
expirationDate - 类 中的变量org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
ExponentialClientBackoffPolicy - org.apache.hadoop.hbase.client.backoff中的类
Simple exponential backoff policy on for the client that uses a percent^4 times the max backoff to generate the backoff time.
ExponentialClientBackoffPolicy(Configuration) - 类 的构造器org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
 
ExportSnapshotException - org.apache.hadoop.hbase.snapshot中的异常错误
Thrown when a snapshot could not be exported due to an error during the operation.
ExportSnapshotException(String) - 异常错误 的构造器org.apache.hadoop.hbase.snapshot.ExportSnapshotException
 
ExportSnapshotException(String, Exception) - 异常错误 的构造器org.apache.hadoop.hbase.snapshot.ExportSnapshotException
 
extractArguments(ArrayList<byte[]>) - 类 中的静态方法org.apache.hadoop.hbase.filter.CompareFilter
 
extractFilterSimpleExpression(byte[], int) - 类 中的方法org.apache.hadoop.hbase.filter.ParseFilter
Extracts a simple filter expression from the filter string given by the user A simpleFilterExpression is of the form: FilterName('arg', 'arg', 'arg') The user given filter string can have many simpleFilterExpressions combined using operators.
extraHeapSize() - 类 中的方法org.apache.hadoop.hbase.client.Increment
 
extraHeapSize() - 类 中的方法org.apache.hadoop.hbase.client.Mutation
Subclasses should override this method to add the heap size of their own fields.

F

failed() - 类 中的方法org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
failed() - 类 中的方法org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
failed() - 类 中的方法org.apache.hadoop.hbase.ipc.ServerRpcController
 
FAILED_SERVER_EXPIRY_DEFAULT - 接口 中的静态变量org.apache.hadoop.hbase.ipc.RpcClient
 
FAILED_SERVER_EXPIRY_KEY - 接口 中的静态变量org.apache.hadoop.hbase.ipc.RpcClient
 
FailedLogCloseException - org.apache.hadoop.hbase.regionserver.wal中的异常错误
Thrown when we fail close of the write-ahead-log file.
FailedLogCloseException() - 异常错误 的构造器org.apache.hadoop.hbase.regionserver.wal.FailedLogCloseException
 
FailedLogCloseException(String) - 异常错误 的构造器org.apache.hadoop.hbase.regionserver.wal.FailedLogCloseException
 
FailedLogCloseException(String, Throwable) - 异常错误 的构造器org.apache.hadoop.hbase.regionserver.wal.FailedLogCloseException
 
FailedLogCloseException(Throwable) - 异常错误 的构造器org.apache.hadoop.hbase.regionserver.wal.FailedLogCloseException
 
failedOnException() - 类 中的方法org.apache.hadoop.hbase.ipc.ServerRpcController
Returns whether or not a server exception was generated in the prior RPC invocation.
FailedSanityCheckException - org.apache.hadoop.hbase.exceptions中的异常错误
Exception thrown if a mutation fails sanity checks.
FailedSanityCheckException() - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.FailedSanityCheckException
default constructor
FailedSanityCheckException(String) - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.FailedSanityCheckException
 
FailedSanityCheckException(String, Throwable) - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.FailedSanityCheckException
 
FailedServerException - org.apache.hadoop.hbase.ipc中的异常错误
Indicates that we're trying to connect to a already known as dead server.
FailedServerException(String) - 异常错误 的构造器org.apache.hadoop.hbase.ipc.FailedServerException
 
failedServers - 类 中的变量org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
FailedServers - org.apache.hadoop.hbase.ipc中的类
A class to manage a list of servers that failed recently.
FailedServers(Configuration) - 类 的构造器org.apache.hadoop.hbase.ipc.FailedServers
 
FailedSyncBeforeLogCloseException - org.apache.hadoop.hbase.regionserver.wal中的异常错误
Thrown when we fail close of the write-ahead-log file.
FailedSyncBeforeLogCloseException() - 异常错误 的构造器org.apache.hadoop.hbase.regionserver.wal.FailedSyncBeforeLogCloseException
 
FailedSyncBeforeLogCloseException(String) - 异常错误 的构造器org.apache.hadoop.hbase.regionserver.wal.FailedSyncBeforeLogCloseException
 
FailedSyncBeforeLogCloseException(String, Throwable) - 异常错误 的构造器org.apache.hadoop.hbase.regionserver.wal.FailedSyncBeforeLogCloseException
 
FailedSyncBeforeLogCloseException(Throwable) - 异常错误 的构造器org.apache.hadoop.hbase.regionserver.wal.FailedSyncBeforeLogCloseException
 
failureSleep - 类 中的变量org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
fallbackAllowed - 类 中的变量org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
fallbackAllowed - 类 中的变量org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
 
FallbackDisallowedException - org.apache.hadoop.hbase.ipc中的异常错误
Indicate that the rpc server tells client to fallback to simple auth but client is disabled to do so.
FallbackDisallowedException() - 异常错误 的构造器org.apache.hadoop.hbase.ipc.FallbackDisallowedException
 
FamilyFilter - org.apache.hadoop.hbase.filter中的类
This filter is used to filter based on the column family.
FamilyFilter(CompareFilter.CompareOp, ByteArrayComparable) - 类 的构造器org.apache.hadoop.hbase.filter.FamilyFilter
Constructor.
familyMap - 类 中的变量org.apache.hadoop.hbase.client.Mutation
 
familySet() - 类 中的方法org.apache.hadoop.hbase.client.Get
Method for retrieving the keys in the familyMap
FatalConnectionException - org.apache.hadoop.hbase.ipc中的异常错误
Thrown when server finds fatal issue w/ connection setup: e.g. bad rpc version or unsupported auth method.
FatalConnectionException() - 异常错误 的构造器org.apache.hadoop.hbase.ipc.FatalConnectionException
 
FatalConnectionException(String) - 异常错误 的构造器org.apache.hadoop.hbase.ipc.FatalConnectionException
 
FatalConnectionException(String, Throwable) - 异常错误 的构造器org.apache.hadoop.hbase.ipc.FatalConnectionException
 
FileSystemVersionException - org.apache.hadoop.hbase.util中的异常错误
Thrown when the file system needs to be upgraded
FileSystemVersionException() - 异常错误 的构造器org.apache.hadoop.hbase.util.FileSystemVersionException
default constructor
FileSystemVersionException(String) - 异常错误 的构造器org.apache.hadoop.hbase.util.FileSystemVersionException
 
filter - 类 中的变量org.apache.hadoop.hbase.client.Query
 
Filter - org.apache.hadoop.hbase.filter中的类
Interface for row and column filters directly applied within the regionserver.
Filter() - 类 的构造器org.apache.hadoop.hbase.filter.Filter
 
Filter.ReturnCode - org.apache.hadoop.hbase.filter中的枚举
Return codes for filterValue().
FILTER_PACKAGE - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
Package containing filters
filterAllRemaining() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
filterAllRemaining() - 类 中的方法org.apache.hadoop.hbase.filter.DependentColumnFilter
 
filterAllRemaining() - 类 中的方法org.apache.hadoop.hbase.filter.Filter
If this returns true, the scan will terminate.
filterAllRemaining() - 类 中的方法org.apache.hadoop.hbase.filter.FilterBase
Filters that never filter all remaining can inherit this implementation that never stops the filter early.
filterAllRemaining() - 类 中的方法org.apache.hadoop.hbase.filter.FilterList
 
filterAllRemaining() - 类 中的方法org.apache.hadoop.hbase.filter.FilterListWithAND
 
filterAllRemaining() - 类 中的方法org.apache.hadoop.hbase.filter.FilterListWithOR
 
filterAllRemaining() - 类 中的方法org.apache.hadoop.hbase.filter.FilterWrapper
 
filterAllRemaining() - 类 中的方法org.apache.hadoop.hbase.filter.FuzzyRowFilter
 
filterAllRemaining() - 类 中的方法org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
filterAllRemaining() - 类 中的方法org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
filterAllRemaining() - 类 中的方法org.apache.hadoop.hbase.filter.PageFilter
 
filterAllRemaining() - 类 中的方法org.apache.hadoop.hbase.filter.PrefixFilter
 
filterAllRemaining() - 类 中的方法org.apache.hadoop.hbase.filter.RandomRowFilter
 
filterAllRemaining() - 类 中的方法org.apache.hadoop.hbase.filter.WhileMatchFilter
 
FilterBase - org.apache.hadoop.hbase.filter中的类
Abstract base class to help you implement new Filters.
FilterBase() - 类 的构造器org.apache.hadoop.hbase.filter.FilterBase
 
filterColumn(byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
filterColumn(byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
filterIfMissing - 类 中的变量org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
filterKeyValue(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
filterKeyValue(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
filterKeyValue(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
filterKeyValue(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
filterKeyValue(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.DependentColumnFilter
 
filterKeyValue(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.FamilyFilter
 
filterKeyValue(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.Filter
A way to filter based on the column family, column qualifier and/or the column value.
filterKeyValue(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.FilterList
 
filterKeyValue(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.FilterListWithAND
 
filterKeyValue(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.FilterListWithOR
 
filterKeyValue(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.FilterWrapper
 
filterKeyValue(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
filterKeyValue(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
 
filterKeyValue(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.FuzzyRowFilter
 
filterKeyValue(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
filterKeyValue(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
filterKeyValue(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
filterKeyValue(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
filterKeyValue(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.PageFilter
 
filterKeyValue(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.PrefixFilter
 
filterKeyValue(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.QualifierFilter
 
filterKeyValue(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.RandomRowFilter
 
filterKeyValue(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.RowFilter
 
filterKeyValue(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
filterKeyValue(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.SkipFilter
 
filterKeyValue(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.TimestampsFilter
 
filterKeyValue(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.ValueFilter
 
filterKeyValue(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.WhileMatchFilter
 
FilterList - org.apache.hadoop.hbase.filter中的类
Implementation of Filter that represents an ordered List of Filters which will be evaluated with a specified boolean operator FilterList.Operator.MUST_PASS_ALL (AND) or FilterList.Operator.MUST_PASS_ONE (OR).
FilterList(FilterList.Operator, List<Filter>) - 类 的构造器org.apache.hadoop.hbase.filter.FilterList
Constructor that takes a set of Filters and an operator.
FilterList(List<Filter>) - 类 的构造器org.apache.hadoop.hbase.filter.FilterList
Constructor that takes a set of Filters.
FilterList(Filter...) - 类 的构造器org.apache.hadoop.hbase.filter.FilterList
Constructor that takes a var arg number of Filters.
FilterList(FilterList.Operator) - 类 的构造器org.apache.hadoop.hbase.filter.FilterList
Constructor that takes an operator.
FilterList(FilterList.Operator, Filter...) - 类 的构造器org.apache.hadoop.hbase.filter.FilterList
Constructor that takes a var arg number of Filters and an operator.
FilterList.Operator - org.apache.hadoop.hbase.filter中的枚举
set operator
FilterListBase - org.apache.hadoop.hbase.filter中的类
Base class for FilterList.
FilterListBase(List<Filter>) - 类 的构造器org.apache.hadoop.hbase.filter.FilterListBase
 
FilterListWithAND - org.apache.hadoop.hbase.filter中的类
FilterListWithAND represents an ordered list of filters which will be evaluated with an AND operator.
FilterListWithAND(List<Filter>) - 类 的构造器org.apache.hadoop.hbase.filter.FilterListWithAND
 
FilterListWithOR - org.apache.hadoop.hbase.filter中的类
FilterListWithOR represents an ordered list of filters which will be evaluated with an OR operator.
FilterListWithOR(List<Filter>) - 类 的构造器org.apache.hadoop.hbase.filter.FilterListWithOR
 
filterOutRow - 类 中的变量org.apache.hadoop.hbase.filter.RandomRowFilter
 
filterRow() - 类 中的方法org.apache.hadoop.hbase.filter.DependentColumnFilter
 
filterRow() - 类 中的方法org.apache.hadoop.hbase.filter.Filter
Last chance to veto row based on previous Filter.filterKeyValue(Cell) calls.
filterRow() - 类 中的方法org.apache.hadoop.hbase.filter.FilterBase
Filters that never filter by rows based on previously gathered state from Filter.filterKeyValue(Cell) can inherit this implementation that never filters a row.
filterRow() - 类 中的方法org.apache.hadoop.hbase.filter.FilterList
 
filterRow() - 类 中的方法org.apache.hadoop.hbase.filter.FilterListWithAND
 
filterRow() - 类 中的方法org.apache.hadoop.hbase.filter.FilterListWithOR
 
filterRow() - 类 中的方法org.apache.hadoop.hbase.filter.FilterWrapper
 
filterRow() - 类 中的方法org.apache.hadoop.hbase.filter.PageFilter
 
filterRow - 类 中的变量org.apache.hadoop.hbase.filter.PrefixFilter
 
filterRow() - 类 中的方法org.apache.hadoop.hbase.filter.PrefixFilter
 
filterRow() - 类 中的方法org.apache.hadoop.hbase.filter.RandomRowFilter
 
filterRow() - 类 中的方法org.apache.hadoop.hbase.filter.RowFilter
 
filterRow() - 类 中的方法org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
filterRow() - 类 中的方法org.apache.hadoop.hbase.filter.SkipFilter
 
filterRow() - 类 中的方法org.apache.hadoop.hbase.filter.WhileMatchFilter
 
filterRowCells(List<Cell>) - 类 中的方法org.apache.hadoop.hbase.filter.DependentColumnFilter
 
filterRowCells(List<Cell>) - 类 中的方法org.apache.hadoop.hbase.filter.Filter
Chance to alter the list of Cells to be submitted.
filterRowCells(List<Cell>) - 类 中的方法org.apache.hadoop.hbase.filter.FilterBase
Filters that never filter by modifying the returned List of Cells can inherit this implementation that does nothing.
filterRowCells(List<Cell>) - 类 中的方法org.apache.hadoop.hbase.filter.FilterList
Filters that never filter by modifying the returned List of Cells can inherit this implementation that does nothing.
filterRowCells(List<Cell>) - 类 中的方法org.apache.hadoop.hbase.filter.FilterListBase
Filters that never filter by modifying the returned List of Cells can inherit this implementation that does nothing.
filterRowCells(List<Cell>) - 类 中的方法org.apache.hadoop.hbase.filter.FilterWrapper
 
filterRowCells(List<Cell>) - 类 中的方法org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
 
filterRowCellsWithRet(List<Cell>) - 类 中的方法org.apache.hadoop.hbase.filter.FilterWrapper
 
filterRowKey(byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.filter.DependentColumnFilter
 
filterRowKey(byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.filter.Filter
Filters a row based on the row key.
filterRowKey(byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.filter.FilterBase
Filters that do not filter by row key can inherit this implementation that never filters anything.
filterRowKey(byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.filter.FilterList
 
filterRowKey(byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.filter.FilterListWithAND
 
filterRowKey(byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.filter.FilterListWithOR
 
filterRowKey(byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.filter.FilterWrapper
 
filterRowKey(byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
filterRowKey(byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
filterRowKey(byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.filter.PrefixFilter
 
filterRowKey(byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.filter.RandomRowFilter
 
filterRowKey(byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.filter.RowFilter
 
filterRowKey(byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.filter.WhileMatchFilter
 
filters - 类 中的变量org.apache.hadoop.hbase.filter.FilterListBase
 
FilterWrapper - org.apache.hadoop.hbase.filter中的类
This is a Filter wrapper class which is used in the server side.
FilterWrapper(Filter) - 类 的构造器org.apache.hadoop.hbase.filter.FilterWrapper
 
FilterWrapper.FilterRowRetCode - org.apache.hadoop.hbase.filter中的枚举
 
findException(Object) - 类 中的静态方法org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
Look for an exception we know in the remote exception: - hadoop.ipc wrapped exceptions - nested exceptions Looks for: RegionMovedException / RegionOpeningException / RegionTooBusyException / ThrottlingException
FIRST_META_REGIONINFO - 类 中的静态变量org.apache.hadoop.hbase.HRegionInfo
HRegionInfo for first meta region
FirstKeyOnlyFilter - org.apache.hadoop.hbase.filter中的类
A filter that will only return the first KV from each row.
FirstKeyOnlyFilter() - 类 的构造器org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
FirstKeyValueMatchingQualifiersFilter - org.apache.hadoop.hbase.filter中的类
The filter looks for the given columns in KeyValue.
FirstKeyValueMatchingQualifiersFilter(Set<byte[]>) - 类 的构造器org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
Constructor which takes a set of columns.
flush(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Flush a table.
flush() - 接口 中的方法org.apache.hadoop.hbase.client.BufferedMutator
Executes all the buffered, asynchronous Mutation operations and waits until they are done.
flush() - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorImpl
 
flush(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Flush a table.
flush(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
flush(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
flush(ChannelHandlerContext) - 类 中的方法org.apache.hadoop.hbase.security.SaslWrapHandler
 
FLUSH_POLICY - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
 
flushCommits() - 类 中的方法org.apache.hadoop.hbase.client.HTable
Executes all the buffered Put operations.
flushCommits() - 接口 中的方法org.apache.hadoop.hbase.client.HTableInterface
已过时。
as of 1.0.0. Replaced by BufferedMutator.flush()
flushRegion(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Flush an individual region.
flushRegion(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Flush an individual region.
FlushRegionCallable - org.apache.hadoop.hbase.client中的类
A Callable for flushRegion() RPC.
FlushRegionCallable(ClusterConnection, RpcControllerFactory, TableName, byte[], byte[], boolean) - 类 的构造器org.apache.hadoop.hbase.client.FlushRegionCallable
 
FlushRegionCallable(ClusterConnection, RpcControllerFactory, HRegionInfo, boolean) - 类 的构造器org.apache.hadoop.hbase.client.FlushRegionCallable
 
FOREVER - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
 
formatLogFilters(List<Filter>) - 类 中的方法org.apache.hadoop.hbase.filter.FilterListBase
 
formatLogFilters(List<Filter>) - 类 中的方法org.apache.hadoop.hbase.filter.FilterListWithAND
 
formatLogFilters(List<Filter>) - 类 中的方法org.apache.hadoop.hbase.filter.FilterListWithOR
 
formatTime(long) - 异常错误 中的静态方法org.apache.hadoop.hbase.quotas.ThrottlingException
 
foundColumn - 类 中的变量org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
fromByte(byte) - 枚举 中的静态方法org.apache.hadoop.hbase.client.IsolationLevel
 
fromBytes(byte[]) - 枚举 中的静态方法org.apache.hadoop.hbase.client.IsolationLevel
 
fromDeleteType(ClientProtos.MutationProto.DeleteType) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer DeleteType to delete KeyValue type.
fullScan(Connection, MetaTableAccessor.Visitor) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Performs a full scan of hbase:meta.
fullScan(Connection) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Performs a full scan of hbase:meta.
fullScan(Connection, MetaTableAccessor.Visitor, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Performs a full scan of a catalog table.
fullScanMetaAndPrint(Connection) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
 
fullScanOfMeta(Connection) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Performs a full scan of a hbase:meta table.
fuzzyMatch(String) - 枚举 中的静态方法org.apache.hadoop.hbase.util.PoolMap.PoolType
 
fuzzyNormalize(String) - 枚举 中的静态方法org.apache.hadoop.hbase.util.PoolMap.PoolType
 
FuzzyRowFilter - org.apache.hadoop.hbase.filter中的类
This is optimized version of a standard FuzzyRowFilter Filters data based on fuzzy row key.
FuzzyRowFilter(List<Pair<byte[], byte[]>>) - 类 的构造器org.apache.hadoop.hbase.filter.FuzzyRowFilter
 

G

Get - org.apache.hadoop.hbase.client中的类
Used to perform Get operations on a single row.
Get(byte[]) - 类 的构造器org.apache.hadoop.hbase.client.Get
Create a Get operation for the specified row.
Get(Get) - 类 的构造器org.apache.hadoop.hbase.client.Get
Copy-constructor
get() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
get(long, TimeUnit) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
get(Get) - 类 中的方法org.apache.hadoop.hbase.client.HTable
Extracts certain cells from a given row.
get(List<Get>) - 类 中的方法org.apache.hadoop.hbase.client.HTable
Extracts certain cells from the given rows, in batch.
get(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Put
Returns a list of all KeyValue objects with matching column family and qualifier.
get - 类 中的变量org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
 
get(Get) - 接口 中的方法org.apache.hadoop.hbase.client.Table
Extracts certain cells from a given row.
get(List<Get>) - 接口 中的方法org.apache.hadoop.hbase.client.Table
Extracts certain cells from the given rows, in batch.
get(int) - 枚举 中的静态方法org.apache.hadoop.hbase.executor.EventType
 
get() - 类 中的方法org.apache.hadoop.hbase.ipc.BlockingRpcCallback
Returns the parameter passed to BlockingRpcCallback.run(Object) or null if a null value was passed.
get(Object) - 类 中的方法org.apache.hadoop.hbase.util.PoolMap
 
get() - 接口 中的方法org.apache.hadoop.hbase.util.PoolMap.Pool
 
get() - 类 中的方法org.apache.hadoop.hbase.util.PoolMap.ReusablePool
 
getACL() - 类 中的方法org.apache.hadoop.hbase.client.Mutation
 
getACL() - 类 中的方法org.apache.hadoop.hbase.client.Query
 
getAcl(String, Stat) - 类 中的方法org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
getAcl is an idempotent operation.
getAction() - 类 中的方法org.apache.hadoop.hbase.client.Action
 
getActions() - 类 中的方法org.apache.hadoop.hbase.client.DelayingRunner
 
getActions() - 类 中的方法org.apache.hadoop.hbase.security.access.Permission
 
getAddress() - 类 中的方法org.apache.hadoop.hbase.ipc.ConnectionId
 
getAddress() - 类 中的方法org.apache.hadoop.hbase.ServerName
 
getAdmin(ServerName) - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
Establishes a connection to the region server at the specified address.
getAdmin() - 接口 中的方法org.apache.hadoop.hbase.client.Connection
Retrieve an Admin implementation to administer an HBase cluster.
getAdmin() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
getAdmin() - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
Retrieve an Admin implementation to administer an HBase cluster.
getAdmin(ServerName) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
internal method, do not use thru HConnection
getAdmin(ServerName, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
You can pass master flag but nothing special is done.
getAgeOfLastAppliedOp() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationLoadSink
 
getAgeOfLastShippedOp() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationLoadSource
 
getAllFilters() - 类 中的静态方法org.apache.hadoop.hbase.filter.ParseFilter
Returns all known filters
getAllowPartialResults() - 类 中的方法org.apache.hadoop.hbase.client.Scan
 
getAllPeerConfigs() - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeers
List the cluster replication configs of all remote slave clusters (whether they are enabled/disabled or connected/disconnected).
getAllPeerConfigs() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
getAllPeerIds() - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeers
List the peer ids of all remote slave clusters (whether they are enabled/disabled or connected/disconnected).
getAllPeerIds() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
List all registered peer clusters and set a watch on their znodes.
getAllPeersFromHFileRefsQueue() - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesClient
Get list of all peers from hfile reference queue.
getAllPeersFromHFileRefsQueue() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesClientZKImpl
 
getAllQueues() - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationQueues
Get a list of all queues for this region server.
getAllQueues(String) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesClient
Get a list of all queues for the specified region server.
getAllQueues(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesClientZKImpl
 
getAllQueues() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
getAllRegionLocations() - 类 中的方法org.apache.hadoop.hbase.client.HRegionLocator
 
getAllRegionLocations() - 类 中的方法org.apache.hadoop.hbase.client.HTable
已过时。
getAllRegionLocations() - 接口 中的方法org.apache.hadoop.hbase.client.RegionLocator
Retrieves all of the regions associated with this table.
getAlterStatus(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Get the status of alter command - indicates how many regions have received the updated schema Asynchronous operation.
getAlterStatus(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Get the status of alter command - indicates how many regions have received the updated schema Asynchronous operation.
getAlterStatus(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Get the status of alter command - indicates how many regions have received the updated schema Asynchronous operation.
getAlterStatus(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Get the status of alter command - indicates how many regions have received the updated schema Asynchronous operation.
getAsyncProcess() - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
 
getAttribute(String) - 接口 中的方法org.apache.hadoop.hbase.client.Attributes
Gets an attribute
getAttribute(String) - 类 中的方法org.apache.hadoop.hbase.client.OperationWithAttributes
 
getAttributeSize() - 类 中的方法org.apache.hadoop.hbase.client.OperationWithAttributes
 
getAttributesMap() - 接口 中的方法org.apache.hadoop.hbase.client.Attributes
Gets all attributes
getAttributesMap() - 类 中的方法org.apache.hadoop.hbase.client.OperationWithAttributes
 
getAuthorizations() - 类 中的方法org.apache.hadoop.hbase.client.Query
 
getAuths(Configuration, String) - 类 中的静态方法org.apache.hadoop.hbase.security.visibility.VisibilityClient
getAuths(Connection, String) - 类 中的静态方法org.apache.hadoop.hbase.security.visibility.VisibilityClient
 
getAverageLatencyForEachRegionServer() - 类 中的方法org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
getAverageLoad() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
 
getBackoffPolicy() - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
 
getBackoffTime(ServerName, byte[], ServerStatistics) - 接口 中的方法org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicy
 
getBackoffTime(ServerName, byte[], ServerStatistics) - 类 中的方法org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicyFactory.NoBackoffPolicy
 
getBackoffTime(ServerName, byte[], ServerStatistics) - 类 中的方法org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
 
getBackupMasterInfoPort(ServerName) - 类 中的方法org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
Get the info port of the backup master if it is available.
getBackupMasters() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
 
getBackupMastersSize() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
 
getBalancerOn() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
 
getBandwidth() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
getBaseStagingDir(Configuration) - 类 中的静态方法org.apache.hadoop.hbase.security.SecureBulkLoadUtil
 
getBaseZNode() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
getBatch() - 类 中的方法org.apache.hadoop.hbase.client.Scan
 
getBlocksize() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
getBloomFilterType() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
getBufferedCounterForEachRegionServer() - 类 中的方法org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
getBufferedMutator(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Connection
Retrieve a BufferedMutator for performing client-side buffering of writes.
getBufferedMutator(BufferedMutatorParams) - 接口 中的方法org.apache.hadoop.hbase.client.Connection
Retrieve a BufferedMutator for performing client-side buffering of writes.
getBytes(Writable) - 类 中的静态方法org.apache.hadoop.hbase.util.Writables
 
getBytes(Writable...) - 类 中的静态方法org.apache.hadoop.hbase.util.Writables
Put a bunch of Writables as bytes all into the one byte array.
getCacheBlocks() - 类 中的方法org.apache.hadoop.hbase.client.Get
Get whether blocks should be cached for this Get.
getCacheBlocks() - 类 中的方法org.apache.hadoop.hbase.client.Scan
Get whether blocks should be cached for this Scan.
getCachedLocation(TableName, byte[]) - 类 中的方法org.apache.hadoop.hbase.client.MetaCache
Search the cache for a location that fits our table and row key.
getCacheSize() - 类 中的方法org.apache.hadoop.hbase.client.ClientScanner
 
getCaching() - 类 中的方法org.apache.hadoop.hbase.client.ClientScanner
 
getCaching() - 类 中的方法org.apache.hadoop.hbase.client.Scan
 
getCaching() - 类 中的方法org.apache.hadoop.hbase.client.ScannerCallable
Get the number of rows that will be fetched on next
getCallTimeMs() - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
getCallTimeout() - 类 中的方法org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
getCallTimeout() - 接口 中的方法org.apache.hadoop.hbase.ipc.HBaseRpcController
 
getCallTimeout() - 类 中的方法org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
getCause(int) - 异常错误 中的方法org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
getCauses() - 异常错误 中的方法org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
getCellValueFromProto(HBaseProtos.BigDecimalMsg) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
getCellValueFromProto(HBaseProtos.DoubleMsg) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
getCellValueFromProto(HBaseProtos.LongMsg) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
getCellValueFromProto(Q) - 类 中的方法org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
This method gets the PB message corresponding to the cell type
getCellVisibility() - 类 中的方法org.apache.hadoop.hbase.client.Mutation
 
getChance() - 类 中的方法org.apache.hadoop.hbase.filter.RandomRowFilter
 
getChildDataAndWatchForNewChildren(ZooKeeperWatcher, String) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
已过时。
Unused
getChildren(String, Watcher) - 类 中的方法org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
getChildren is an idempotent operation.
getChildren(String, boolean) - 类 中的方法org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
getChildren is an idempotent operation.
getClassLoader() - 接口 中的方法org.apache.hadoop.hbase.CoprocessorEnvironment
 
getClient(ServerName) - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
Establishes a connection to the region server at the specified address, and returns a region client protocol.
getClient(ServerName) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
internal method, do not use thru HConnection
getClusterId() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
 
getClusterIds() - 类 中的方法org.apache.hadoop.hbase.client.Mutation
 
getClusterKey() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
getClusterStatus() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
 
getClusterStatus() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
getCode() - 枚举 中的方法org.apache.hadoop.hbase.executor.EventType
 
getColumn(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Result
已过时。
getColumnCells(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Result
Return the Cells for the specific column.
getColumnFamilies() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Returns an array all the HColumnDescriptor of the column families of the table.
getColumnFamilyTimeRange() - 类 中的方法org.apache.hadoop.hbase.client.Query
 
getColumnLatest(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Result
getColumnLatest(byte[], int, int, byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.client.Result
getColumnLatestCell(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Result
The Cell for the most recent timestamp for a given column.
getColumnLatestCell(byte[], int, int, byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.client.Result
The Cell for the most recent timestamp for a given column.
getColumnOffset() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
getCompactionCompression() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
getCompactionCompressionType() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
getCompactionPressure() - 类 中的方法org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
 
getCompactionState(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Get the current compaction state of a table.
getCompactionState(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Get the current compaction state of a table.
getCompactionState(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
getCompactionState(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
getCompactionStateForRegion(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
已过时。
getCompactionStateForRegion(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Get the current compaction state of region.
getComparator() - 类 中的方法org.apache.hadoop.hbase.filter.CompareFilter
 
getComparator() - 类 中的方法org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
getComparator() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
 
getComparisonData() - 类 中的方法org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
 
getCompleteSequenceId() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
This does not really belong inside RegionLoad but its being done in the name of expediency.
getCompression() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
getCompressionType() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
getConcurrentCallsPerServer() - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
getConf() - 类 中的方法org.apache.hadoop.hbase.client.ClientScanner
 
getConfiguration() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
 
getConfiguration() - 接口 中的方法org.apache.hadoop.hbase.client.BufferedMutator
Returns the Configuration object used by this instance.
getConfiguration() - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorImpl
 
getConfiguration() - 接口 中的方法org.apache.hadoop.hbase.client.Connection
 
getConfiguration() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
getConfiguration() - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
 
getConfiguration() - 类 中的方法org.apache.hadoop.hbase.client.HRegionLocator
 
getConfiguration() - 类 中的方法org.apache.hadoop.hbase.client.HTable
Returns the Configuration object used by this instance.
getConfiguration() - 接口 中的方法org.apache.hadoop.hbase.client.Table
Returns the Configuration object used by this instance.
getConfiguration() - 接口 中的方法org.apache.hadoop.hbase.CoprocessorEnvironment
 
getConfiguration() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
Getter for fetching an unmodifiable HColumnDescriptor.configuration map.
getConfiguration() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Getter for fetching an unmodifiable HTableDescriptor.configuration map.
getConfiguration() - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeer
Get the configuration object required to communicate with this peer
getConfiguration() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
getConfiguration() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
Get the configuration object required to communicate with this peer
getConfiguration() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
getConfigurationValue(String) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
Getter for accessing the configuration value by key.
getConfigurationValue(String) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Getter for accessing the configuration value by key
getConnection() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
 
getConnection() - 类 中的方法org.apache.hadoop.hbase.client.ClientScanner
 
getConnection() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
getConnection(Configuration) - 类 中的静态方法org.apache.hadoop.hbase.client.HConnectionManager
已过时。
getConnection() - 类 中的方法org.apache.hadoop.hbase.client.HTable
已过时。
This method will be changed from public to package protected.
getConnection() - 类 中的方法org.apache.hadoop.hbase.client.ScannerCallable
 
getConnectionConfiguration() - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
 
getConnectionMetrics() - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
 
getConsistency() - 类 中的方法org.apache.hadoop.hbase.client.Query
Returns the consistency level for this operation
getControllerException(RpcController) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ResponseConverter
Retreivies exception stored during RPC invocation.
getCoprocessors() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Return the list of attached co-processor represented by their name className
getCounter(String) - 类 中的方法org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
 
getCreateTime() - 类 中的方法org.apache.hadoop.hbase.RegionTransition
 
getCurrentCompactedKVs() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
 
getCurrentCompactedKVs() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
 
getCurrentNrHRS() - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
This method will be changed from public to package protected.
getCurrentPoolSize(String) - 类 中的方法org.apache.hadoop.hbase.client.HTablePool
已过时。
 
getCursor() - 类 中的方法org.apache.hadoop.hbase.client.Result
Return the cursor if this Result is a cursor result.
getCursor() - 类 中的方法org.apache.hadoop.hbase.client.ScannerCallable
 
getData(String, Watcher, Stat) - 类 中的方法org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
getData is an idempotent operation.
getData(String, boolean, Stat) - 类 中的方法org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
getData is an idemnpotent operation.
getData(ZooKeeperWatcher, String) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKAssign
Gets the current data in the unassigned node for the specified region name or fully-qualified path.
getData(ZooKeeperWatcher, String) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Get znode data.
getData() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData
已过时。
 
getData() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.CreateAndFailSilent
 
getData() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.SetData
 
getData(boolean) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
Gets the data of the node.
getDataAndWatch(ZooKeeperWatcher, String, Stat) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKAssign
Gets the current data in the unassigned node for the specified region name or fully-qualified path.
getDataAndWatch(ZooKeeperWatcher, String) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Get the data at the specified znode and set a watch.
getDataAndWatch(ZooKeeperWatcher, String, Stat) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Get the data at the specified znode and set a watch.
getDataBlockEncoding() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
getDataBlockEncodingOnDisk() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
已过时。
As of release 0.98 (HBASE-9870). This will be removed in HBase 2.0.0. See HColumnDescriptor.getDataBlockEncoding()}
getDataLocality() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
 
getDataNoWatch(ZooKeeperWatcher, String, Stat) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKAssign
Gets the current data in the unassigned node for the specified region name or fully-qualified path.
getDataNoWatch(ZooKeeperWatcher, String, Stat) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Get the data at the specified znode without setting a watch.
getDaughterRegions(Result) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
已过时。
use MetaTableAccessor methods for interacting with meta layouts
getDaughterRegions(Result) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Returns the daughter regions by reading the corresponding columns of the catalog table Result.
getDeadRegionServers() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationQueueInfo
 
getDeadServerNames() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
 
getDeadServers() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
 
getDefaultCodec(Configuration) - 类 中的静态方法org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
getDefaultExecutor(Configuration) - 类 中的静态方法org.apache.hadoop.hbase.client.HTable
 
getDefaultRegionLocation() - 类 中的方法org.apache.hadoop.hbase.RegionLocations
 
getDefaultValues() - 类 中的静态方法org.apache.hadoop.hbase.HColumnDescriptor
 
getDesc(List<Throwable>, List<? extends Row>, List<String>) - 异常错误 中的静态方法org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
getDesc(Map<String, Integer>) - 异常错误 中的静态方法org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
getDFSReplication() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
getDisabledOrDisablingTables(ZooKeeperWatcher) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKTableStateClientSideReader
Gets a list of all the tables set as disabled in zookeeper.
getDisabledTables(ZooKeeperWatcher) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKTableStateClientSideReader
Gets a list of all the tables set as disabled in zookeeper.
getDropDependentColumn() - 类 中的方法org.apache.hadoop.hbase.filter.DependentColumnFilter
 
getDurability() - 类 中的方法org.apache.hadoop.hbase.client.Mutation
Get the current durability
getDurability() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Returns the durability setting for the table.
getEnablingTables(ZooKeeperWatcher) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKTableStateClientSideReader
Gets a list of all the tables set as enabling in zookeeper.
getEncodedName() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
 
getEncodedNameAsBytes() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
 
getEncryptionKey() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
Return the raw crypto key attribute for the family, or null if not set
getEncryptionType() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
Return the encryption algorithm in use by this family
getEndKey() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
 
getEndKeys() - 类 中的方法org.apache.hadoop.hbase.client.HRegionLocator
Gets the ending row key for every region in the currently open table.
getEndKeys() - 类 中的方法org.apache.hadoop.hbase.client.HTable
已过时。
Since 1.1.0. Use RegionLocator.getEndKeys() instead;
getEndKeys() - 接口 中的方法org.apache.hadoop.hbase.client.RegionLocator
Gets the ending row key for every region in the currently open table.
getEventType() - 类 中的方法org.apache.hadoop.hbase.RegionTransition
 
getException(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.MultiResponse
 
getExceptionMessage() - 类 中的方法org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
getExceptionMessageAdditionalDetail() - 类 中的方法org.apache.hadoop.hbase.client.DelegatingRetryingCallable
 
getExceptionMessageAdditionalDetail() - 类 中的方法org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
getExceptionMessageAdditionalDetail() - 类 中的方法org.apache.hadoop.hbase.client.RegionServerCallable
 
getExceptionMessageAdditionalDetail() - 接口 中的方法org.apache.hadoop.hbase.client.RetryingCallable
 
getExceptions() - 类 中的方法org.apache.hadoop.hbase.client.MultiResponse
 
getExhaustiveDescription() - 异常错误 中的方法org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
getExists() - 类 中的方法org.apache.hadoop.hbase.client.Result
 
getExpirationDate() - 类 中的方法org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
getExpression() - 类 中的方法org.apache.hadoop.hbase.security.visibility.CellVisibility
 
getFailed() - 类 中的方法org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
getFailed() - 接口 中的方法org.apache.hadoop.hbase.ipc.HBaseRpcController
Return the failed exception, null if not failed.
getFailed() - 类 中的方法org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
getFailedCounterForEachRegionServer() - 类 中的方法org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
getFailedOn() - 类 中的方法org.apache.hadoop.hbase.ipc.ServerRpcController
Returns any exception thrown during service method invocation, or null if no exception was thrown.
getFailureCount() - 异常错误 中的方法org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
 
getFamilies() - 类 中的方法org.apache.hadoop.hbase.client.Scan
 
getFamilies() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Returns an unmodifiable collection of all the HColumnDescriptor of all the column families of the table.
getFamiliesKeys() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Returns all the column family names of the current table.
getFamily() - 类 中的方法org.apache.hadoop.hbase.filter.DependentColumnFilter
 
getFamily() - 类 中的方法org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
getFamily(byte[]) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Returns the HColumnDescriptor for a specific column family with name as specified by the parameter column.
getFamily() - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Returns the column family used for meta columns.
getFamily() - 类 中的方法org.apache.hadoop.hbase.security.access.TablePermission
 
getFamilyCellMap() - 类 中的方法org.apache.hadoop.hbase.client.Mutation
Method for retrieving the put's familyMap
getFamilyMap() - 类 中的方法org.apache.hadoop.hbase.client.Get
Method for retrieving the get's familyMap
getFamilyMap() - 类 中的方法org.apache.hadoop.hbase.client.Mutation
已过时。
getFamilyMap(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Result
Map of qualifiers to values.
getFamilyMap() - 类 中的方法org.apache.hadoop.hbase.client.Scan
Getting the familyMap
getFamilyMapOfLongs() - 类 中的方法org.apache.hadoop.hbase.client.Increment
Before 0.95, when you called Increment#getFamilyMap(), you got back a map of families to a list of Longs.
getFilter() - 类 中的方法org.apache.hadoop.hbase.client.Query
 
getFilter() - 类 中的方法org.apache.hadoop.hbase.client.Scan
 
getFilter() - 类 中的方法org.apache.hadoop.hbase.filter.SkipFilter
 
getFilter() - 类 中的方法org.apache.hadoop.hbase.filter.WhileMatchFilter
 
getFilterArguments(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.ParseFilter
Returns the arguments of the filter from the filter string
getFilterIfMissing() - 类 中的方法org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Get whether entire row should be filtered if column is not found.
getFilterName(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.ParseFilter
Returns the filter name given a simple filter expression
getFilters() - 类 中的方法org.apache.hadoop.hbase.filter.FilterList
Get the filters.
getFilters() - 类 中的方法org.apache.hadoop.hbase.filter.FilterListBase
 
getFingerprint() - 类 中的方法org.apache.hadoop.hbase.client.Get
Compile the table and column family (i.e. schema) information into a String.
getFingerprint() - 类 中的方法org.apache.hadoop.hbase.client.Mutation
Compile the column family (i.e. schema) information into a Map.
getFingerprint() - 类 中的方法org.apache.hadoop.hbase.client.Operation
Produces a Map containing a fingerprint which identifies the type and the static schema components of a query (i.e. column families)
getFingerprint() - 类 中的方法org.apache.hadoop.hbase.client.Scan
Compile the table and column family (i.e. schema) information into a String.
getFirstFailureAt() - 异常错误 中的方法org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
 
getFlushPolicyClassName() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
This gets the class associated with the flush policy which determines the stores need to be flushed when flushing a region.
getHBaseVersion() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
 
getHBaseVersion() - 接口 中的方法org.apache.hadoop.hbase.CoprocessorEnvironment
 
getHeapOccupancyPercent() - 类 中的方法org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
 
getHFileRefsNodeChangeVersion() - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesClient
Get the change version number of replication hfile references node.
getHFileRefsNodeChangeVersion() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesClientZKImpl
 
getHostAndPort() - 类 中的方法org.apache.hadoop.hbase.ServerName
 
getHostname() - 异常错误 中的方法org.apache.hadoop.hbase.exceptions.RegionMovedException
 
getHostname() - 类 中的方法org.apache.hadoop.hbase.HRegionLocation
 
getHostname() - 异常错误 中的方法org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
 
getHostname() - 类 中的方法org.apache.hadoop.hbase.ServerName
 
getHostnamePort(int) - 异常错误 中的方法org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
getHostnamePort() - 类 中的方法org.apache.hadoop.hbase.HRegionLocation
 
getHRegionInfo(Result) - 类 中的静态方法org.apache.hadoop.hbase.client.MetaScanner
getHRegionInfo() - 类 中的方法org.apache.hadoop.hbase.client.RegionServerCallable
 
getHRegionInfo() - 类 中的方法org.apache.hadoop.hbase.client.ScannerCallable
 
getHRegionInfo(Result) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
已过时。
use MetaTableAccessor methods for interacting with meta layouts
getHRegionInfo(Result, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
已过时。
use MetaTableAccessor methods for interacting with meta layouts
getHRegionInfo(Result) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Returns HRegionInfo object from the column HConstants.CATALOG_FAMILY:HConstants.REGIONINFO_QUALIFIER of the catalog table Result.
getHRegionInfoAndServerName(Result) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
已过时。
use MetaTableAccessor methods for interacting with meta layouts
getHTableDescriptor(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
getHTableDescriptor(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
getHTableDescriptorArray(MasterProtos.GetTableDescriptorsResponse) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Get HTableDescriptor[] from GetTableDescriptorsResponse protobuf
getHTableDescriptors(List<String>) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
getHTableDescriptorsByTableName(List<TableName>) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
getHTableMultiplexerStatus() - 类 中的方法org.apache.hadoop.hbase.client.HTableMultiplexer
 
getId() - 类 中的方法org.apache.hadoop.hbase.client.OperationWithAttributes
This method allows you to retrieve the identifier for the operation if one was set.
getId() - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeer
Get the identifier of this peer
getId() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
Get the identifier of this peer
getId() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZKClusterId
 
getIdentifier() - 类 中的方法org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
getInfo(String) - 类 中的静态方法org.apache.hadoop.hbase.security.SecurityInfo
Returns the security configuration associated with the given service name.
getInfoServerPort() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
 
getInitialResponse() - 类 中的方法org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
 
getInputStream(InputStream) - 类 中的方法org.apache.hadoop.hbase.security.HBaseSaslRpcClient
Get a SASL wrapped InputStream.
getInstance() - 接口 中的方法org.apache.hadoop.hbase.CoprocessorEnvironment
 
getIsolationLevel() - 类 中的方法org.apache.hadoop.hbase.client.Query
 
getIssueDate() - 类 中的方法org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
getKeepAliveMasterService() - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
已过时。
getKeepAliveMasterService() - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
Since 0.96.0
getKeepDeletedCells() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
getKeyId() - 类 中的方法org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
getKind() - 类 中的方法org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
getLabels() - 类 中的方法org.apache.hadoop.hbase.security.visibility.Authorizations
 
getLastAttemptAt() - 异常错误 中的方法org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
 
getLastMajorCompactionTimestamp(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Get the timestamp of the last major compaction for the passed table The timestamp of the oldest HFile resulting from a major compaction of that table, or 0 if no such HFile could be found.
getLastMajorCompactionTimestamp(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
getLastMajorCompactionTimestampForRegion(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Get the timestamp of the last major compaction for the passed region.
getLastMajorCompactionTimestampForRegion(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
getLastMajorCompactionTs() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
 
getLastMajorCompactionTsForRegion(byte[]) - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
 
getLastMajorCompactionTsForTable(TableName) - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
 
getLastRegion() - 类 中的方法org.apache.hadoop.hbase.ipc.RegionCoprocessorRpcChannel
 
getLatestVersionOnly() - 类 中的方法org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Get whether only the latest version of the column value should be compared.
getLimit() - 类 中的方法org.apache.hadoop.hbase.client.Scan
 
getLimit() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
getLimit() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
getListener() - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorParams
 
getListeners() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Get a copy of current registered listeners
getListOfRegionServers() - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationTracker
Returns a list of other live region servers in the cluster.
getListOfRegionServers() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl
Return a snapshot of the current region servers.
getListOfReplicators() - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationQueues
Get a list of all region servers that have outstanding replication queues.
getListOfReplicators() - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesClient
Get a list of all region servers that have outstanding replication queues.
getListOfReplicators() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesClientZKImpl
 
getListOfReplicators() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
getListOfReplicatorsZK() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationStateZKBase
Subclasses that use ZK explicitly can just call this directly while classes that are trying to hide internal details of storage can wrap the KeeperException into a ReplicationException or something else.
getLoad(ServerName) - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
 
getLoad() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
Originally, this method factored in the effect of requests going to the server as well.
getLoadColumnFamiliesOnDemandValue() - 类 中的方法org.apache.hadoop.hbase.client.Query
Get the raw loadColumnFamiliesOnDemand setting; if it's not set, can be null.
getLoadSequence() - 接口 中的方法org.apache.hadoop.hbase.CoprocessorEnvironment
 
getLocation(boolean) - 类 中的方法org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
getLocation() - 类 中的方法org.apache.hadoop.hbase.client.RegionServerCallable
 
getLocationSeqNum() - 异常错误 中的方法org.apache.hadoop.hbase.exceptions.RegionMovedException
 
getLockZNode(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
getLogPosition(String, String) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationQueues
Get the current position for a specific WAL in a given queue.
getLogPosition(String, String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
getLogsInQueue(String) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationQueues
Get a list of all WALs in the given queue.
getLogsInQueue(String, String) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesClient
Get a list of all WALs in the given queue on the given region server.
getLogsInQueue(String, String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesClientZKImpl
 
getLogsInQueue(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
getMap() - 类 中的方法org.apache.hadoop.hbase.client.Result
Map of families to all versions of its qualifiers and values.
getMaster() - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
Returns a MasterKeepAliveConnection to the active master
getMaster() - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
internal method, do not use thru HConnection
getMaster() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
Returns detailed information about the current master ServerName.
getMasterAddress() - 类 中的方法org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
Get the address of the current master if one is available.
getMasterAddress(boolean) - 类 中的方法org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
Get the address of the current master if one is available.
getMasterAddress(ZooKeeperWatcher) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
Get master address.
getMasterAddressZNode() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
getMasterCoprocessors() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Helper delegage to getClusterStatus().getMasterCoprocessors().
getMasterCoprocessors() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
getMasterCoprocessors() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
 
getMasterInfoPort() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Get the info port of the current master if one is available.
getMasterInfoPort() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
getMasterInfoPort() - 类 中的方法org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
Get the info port of the current master of one is available.
getMasterInfoPort(ZooKeeperWatcher) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
Get master info port.
getMaxColumn() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
getMaxColumnInclusive() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
getMaxFileSize() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Returns the maximum size upto which a region can grow to after which a region split is triggered.
getMaxHeapMB() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
 
getMaxKeyValueSize() - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorParams
 
getMaxKeyValueSize() - 类 中的方法org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getMaxKeyValueSize(Configuration) - 类 中的静态方法org.apache.hadoop.hbase.client.HTable
 
getMaxLatency() - 类 中的方法org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
getMaxLatencyForEachRegionServer() - 类 中的方法org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
getMaxPriority() - 类 中的方法org.apache.hadoop.hbase.client.RowMutations
 
getMaxResultSize() - 类 中的方法org.apache.hadoop.hbase.client.ClientScanner
 
getMaxResultSize() - 类 中的方法org.apache.hadoop.hbase.client.Scan
 
getMaxResultsPerColumnFamily() - 类 中的方法org.apache.hadoop.hbase.client.Get
Method for retrieving the get's maximum number of values to return per Column Family
getMaxResultsPerColumnFamily() - 类 中的方法org.apache.hadoop.hbase.client.Scan
 
getMaxValue() - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
getMaxValue() - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
getMaxValue() - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
getMaxValue() - 类 中的方法org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
returns the maximum value for this type T
getMaxVersions() - 类 中的方法org.apache.hadoop.hbase.client.Get
Method for retrieving the get's maximum number of version
getMaxVersions() - 类 中的方法org.apache.hadoop.hbase.client.Scan
 
getMaxVersions() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
getMechanismName() - 枚举 中的方法org.apache.hadoop.hbase.security.AuthMethod
Return the SASL mechanism name
getMemStoreFlushSize() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Returns the size of the memstore after which a flush to filesystem is triggered.
getMemstoreLoadPercent() - 类 中的方法org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
 
getMemstoreSizeInMB() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
 
getMemStoreSizeMB() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
 
getMergeRegions(Result) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
已过时。
use MetaTableAccessor methods for interacting with meta layouts
getMergeRegions(Result) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Returns the merge regions by reading the corresponding columns of the catalog table Result.
getMessage() - 异常错误 中的方法org.apache.hadoop.hbase.exceptions.RegionMovedException
 
getMetaKeyForRegion(HRegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Returns the row key to use for this regionInfo
getMetaOperationTimeout() - 类 中的方法org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getMetaRegionLocation(ZooKeeperWatcher) - 类 中的方法org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Gets the meta region location, if available.
getMetaRegionLocation(ZooKeeperWatcher, int) - 类 中的方法org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Gets the meta region location, if available.
getMetaRegions(ZooKeeperWatcher) - 类 中的方法org.apache.hadoop.hbase.zookeeper.MetaTableLocator
 
getMetaRegions(ZooKeeperWatcher, int) - 类 中的方法org.apache.hadoop.hbase.zookeeper.MetaTableLocator
 
getMetaRegionsAndLocations(ZooKeeperWatcher) - 类 中的方法org.apache.hadoop.hbase.zookeeper.MetaTableLocator
 
getMetaRegionsAndLocations(ZooKeeperWatcher, int) - 类 中的方法org.apache.hadoop.hbase.zookeeper.MetaTableLocator
 
getMetaRegionState(ZooKeeperWatcher) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Load the meta region state from the meta server ZNode.
getMetaRegionState(ZooKeeperWatcher, int) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Load the meta region state from the meta server ZNode.
getMetaReplicaCallTimeoutMicroSecondScan() - 类 中的方法org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getMetaReplicaIdFromZnode(String) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Parse the meta replicaId from the passed znode
getMetaReplicaNodes() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Get the znodes corresponding to the meta replicas from ZK
getMethod() - 类 中的方法org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
 
getMetricsMap() - 类 中的方法org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
Get all of the values since the last time this function was called.
getMetricsMap(boolean) - 类 中的方法org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
Get all of the values.
getMin() - 类 中的方法org.apache.hadoop.hbase.filter.TimestampsFilter
Gets the minimum timestamp requested by filter.
getMinColumn() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
getMinColumnInclusive() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
getMinValue() - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
getMinValue() - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
getMinValue() - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
getMinValue() - 类 中的方法org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
 
getMinVersions() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
getMutations() - 类 中的方法org.apache.hadoop.hbase.client.RowMutations
 
getMvccReadPoint(Scan) - 类 中的静态方法org.apache.hadoop.hbase.client.PackagePrivateFieldAccessor
 
getName() - 接口 中的方法org.apache.hadoop.hbase.client.BufferedMutator
Gets the fully qualified table name instance of the table that this BufferedMutator writes to.
getName() - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorImpl
 
getName() - 类 中的方法org.apache.hadoop.hbase.client.HRegionLocator
 
getName() - 类 中的方法org.apache.hadoop.hbase.client.HTable
 
getName() - 接口 中的方法org.apache.hadoop.hbase.client.RegionLocator
Gets the fully qualified table name instance of this table.
getName() - 枚举 中的方法org.apache.hadoop.hbase.client.security.SecurityCapability
 
getName() - 接口 中的方法org.apache.hadoop.hbase.client.Table
Gets the fully qualified table name instance of this table.
getName() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
getName() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
已过时。
getName() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
 
getNameAsString() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
getNameAsString() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Get the name of the table as a String
getNameAsString() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
 
getNamespace() - 类 中的方法org.apache.hadoop.hbase.quotas.QuotaSettings
 
getNamespace() - 类 中的方法org.apache.hadoop.hbase.security.access.TablePermission
 
getNamespaceDescriptor(String) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Get a namespace descriptor by name
getNamespaceDescriptor(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Get a namespace descriptor by name
getNamespaceFilter() - 类 中的方法org.apache.hadoop.hbase.quotas.QuotaFilter
 
getNamespaceFromRowKey(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getNamespaceQuota(Connection, String) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getNamespaceRowKey(String) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getNamespaceRowKeyRegex(String) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getNewRpcRetryingCallerFactory(Configuration) - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
Returns a new RpcRetryingCallerFactory from the given Configuration.
getNextCellHint(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
getNextCellHint(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
getNextCellHint(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
getNextCellHint(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.Filter
If the filter returns the match code SEEK_NEXT_USING_HINT, then it should also tell which is the next key it must seek to.
getNextCellHint(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.FilterBase
Filters that are not sure which key must be next seeked to, can inherit this implementation that, by default, returns a null Cell.
getNextCellHint(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.FilterList
 
getNextCellHint(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.FilterListWithAND
 
getNextCellHint(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.FilterListWithOR
 
getNextCellHint(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.FilterWrapper
 
getNextCellHint(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.FuzzyRowFilter
 
getNextCellHint(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
getNextCellHint(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
getNextCellHint(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.TimestampsFilter
Pick the next cell that the scanner should seek to.
getNextKeyHint(KeyValue) - 类 中的方法org.apache.hadoop.hbase.filter.Filter
已过时。
getNextKeyHint(KeyValue) - 类 中的方法org.apache.hadoop.hbase.filter.FilterBase
已过时。
getNextKeyHint(KeyValue) - 类 中的方法org.apache.hadoop.hbase.filter.FilterList
已过时。
getNextKeyHint(KeyValue) - 类 中的方法org.apache.hadoop.hbase.filter.FilterWrapper
已过时。
getNode() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData
已过时。
 
getNode() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
 
getNodeName(ZooKeeperWatcher, String) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKAssign
Gets the full path node name for the unassigned node for the specified region.
getNodeName(String) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Get the name of the current node from the specified fully-qualified path.
getNonce() - 类 中的方法org.apache.hadoop.hbase.client.Action
 
getNonceGenerator() - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
 
getNonceGenerator() - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
internal method, do not use thru HConnection
getNonceGroup() - 类 中的方法org.apache.hadoop.hbase.client.MultiAction
 
getNonceGroup() - 接口 中的方法org.apache.hadoop.hbase.client.NonceGenerator
 
getNonceGroup() - 类 中的方法org.apache.hadoop.hbase.client.PerClientRandomNonceGenerator
 
getNoVersionMap() - 类 中的方法org.apache.hadoop.hbase.client.Result
Map of families to their most recent qualifiers and values.
getNumberOfCachedRegionLocations(TableName) - 类 中的方法org.apache.hadoop.hbase.client.MetaCache
Return the number of cached region for a table.
getNumberOfChildren(ZooKeeperWatcher, String) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Get the number of children of the specified node.
getNumberOfListeners() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
getNumberOfRegions() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
 
getNumberOfRequests() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
 
getNumExceptions() - 异常错误 中的方法org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
getOffset() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
getOnlineRegions(ServerName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Get all the online regions on a region server.
getOnlineRegions(ServerName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Get all the online regions on a region server.
getOnlineRegions(AdminProtos.AdminService.BlockingInterface) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to get the all the online regions on a region server using admin protocol.
getOnlineRegions(RpcController, AdminProtos.AdminService.BlockingInterface) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to get the all the online regions on a region server using admin protocol.
getOperationTimeout() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
 
getOperationTimeout() - 类 中的方法org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getOperationTimeout() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
getOperationTimeout() - 类 中的方法org.apache.hadoop.hbase.client.HTable
 
getOperationTimeout() - 接口 中的方法org.apache.hadoop.hbase.client.Table
Get timeout (millisecond) of each operation for in Table instance.
getOperator() - 类 中的方法org.apache.hadoop.hbase.filter.BitComparator
 
getOperator() - 类 中的方法org.apache.hadoop.hbase.filter.CompareFilter
 
getOperator() - 类 中的方法org.apache.hadoop.hbase.filter.FilterList
Get the operator.
getOperator() - 类 中的方法org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
getOriginalIndex() - 类 中的方法org.apache.hadoop.hbase.client.Action
 
getOutputStream(OutputStream) - 类 中的方法org.apache.hadoop.hbase.security.HBaseSaslRpcClient
Get a SASL wrapped OutputStream.
getOverallAverageLatency() - 类 中的方法org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
getOwnerString() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
已过时。
since 0.94.1
getPageSize() - 类 中的方法org.apache.hadoop.hbase.filter.PageFilter
 
getParent(String) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Returns the full path of the immediate parent of the specified node.
getParsedGenericInstance(Class<?>, int, ByteString) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Get an instance of the argument type declared in a class's signature.
getPath(ZooKeeperWatcher, String) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKAssign
 
getPath() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
 
getPause() - 类 中的方法org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getPauseForCQTBE() - 类 中的方法org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getPauseTime(long, int) - 类 中的静态方法org.apache.hadoop.hbase.client.ConnectionUtils
Calculate pause time.
getPayload() - 类 中的方法org.apache.hadoop.hbase.RegionTransition
 
getPeer(String) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeers
Returns the ReplicationPeer
getPeer(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
getPeerBandwidth() - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeer
Get the per node bandwidth upper limit for this peer
getPeerBandwidth() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
 
getPeerClusterZnode() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationQueueInfo
 
getPeerConf(String) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeers
Returns the configuration needed to talk to the remote slave cluster.
getPeerConf(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
getPeerConfig(String) - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
 
getPeerConfig() - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeer
Get the peer config object
getPeerConfig() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
Get the peer config object
getPeerData() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
getPeerID() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationLoadSource
 
getPeerId() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationQueueInfo
 
getPeerIds() - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeers
Returns the set of peerIds defined
getPeerIds() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
getPeerNode(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationStateZKBase
 
getPeersCount() - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Get the number of slave clusters the local cluster has.
getPeerState(String) - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Get the state of the specified peer cluster
getPeerState() - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeer
Returns the state of the peer
getPeerState() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
 
getPeerStateNode(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationStateZKBase
 
getPeerTableCFs(String) - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Get the replicable table-cf config of the specified peer.
getPeerTableCFsConfig(String) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeers
Get the table and column-family list of the peer from ZK.
getPeerTableCFsConfig(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
getPool() - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorParams
 
getPool() - 类 中的方法org.apache.hadoop.hbase.client.ClientScanner
 
getPort() - 异常错误 中的方法org.apache.hadoop.hbase.exceptions.RegionMovedException
 
getPort() - 类 中的方法org.apache.hadoop.hbase.HRegionLocation
 
getPort() - 异常错误 中的方法org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
 
getPort() - 类 中的方法org.apache.hadoop.hbase.ServerName
 
getPrefix() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
getPrefix() - 类 中的方法org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
getPrefix() - 类 中的方法org.apache.hadoop.hbase.filter.PrefixFilter
 
getPrimaryCallTimeoutMicroSecond() - 类 中的方法org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getPrimaryOperationTimeout() - 类 中的方法org.apache.hadoop.hbase.client.ClientScanner
 
getPriority() - 类 中的方法org.apache.hadoop.hbase.client.Action
 
getPriority() - 类 中的方法org.apache.hadoop.hbase.client.MultiAction
 
getPriority() - 类 中的方法org.apache.hadoop.hbase.client.OperationWithAttributes
 
getPriority() - 类 中的方法org.apache.hadoop.hbase.client.RegionServerCallable
 
getPriority() - 接口 中的方法org.apache.hadoop.hbase.CoprocessorEnvironment
 
getPriority() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
 
getPriority() - 类 中的方法org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
getPriority() - 接口 中的方法org.apache.hadoop.hbase.ipc.HBaseRpcController
 
getPriority() - 类 中的方法org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
getProcedureResult(MasterProtos.GetProcedureResultRequest) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
getPromotedValueFromProto(HBaseProtos.BigDecimalMsg) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
getPromotedValueFromProto(HBaseProtos.DoubleMsg) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
getPromotedValueFromProto(HBaseProtos.LongMsg) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
getPromotedValueFromProto(R) - 类 中的方法org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
This method gets the promoted type from the proto message
getProtocol() - 异常错误 中的方法org.apache.hadoop.hbase.exceptions.UnknownProtocolException
 
getProtoForCellType(BigDecimal) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
getProtoForCellType(Double) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
getProtoForCellType(Long) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
getProtoForCellType(T) - 类 中的方法org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
This method gets the PB message corresponding to the cell type
getProtoForPromotedType(BigDecimal) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
getProtoForPromotedType(Double) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
getProtoForPromotedType(Long) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
getProtoForPromotedType(S) - 类 中的方法org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
This method gets the PB message corresponding to the promoted type
getQop(String) - 类 中的静态方法org.apache.hadoop.hbase.security.SaslUtil
Returns SaslUtil.QualityOfProtection corresponding to the given stringQop value.
getQualifier() - 类 中的方法org.apache.hadoop.hbase.filter.DependentColumnFilter
 
getQualifier() - 类 中的方法org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
getQualifier() - 类 中的方法org.apache.hadoop.hbase.security.access.TablePermission
 
getQueuesZNodeCversion() - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesClient
Get the cversion of replication rs node.
getQueuesZNodeCversion() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesClientZKImpl
 
getQuorum() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Get the quorum address of this instance.
getQuotaRetriever(QuotaFilter) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Return a QuotaRetriever to list the quotas based on the filter.
getQuotaRetriever(QuotaFilter) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Return a Quota Scanner to list the quotas based on the filter.
getQuotaType() - 类 中的方法org.apache.hadoop.hbase.quotas.QuotaSettings
 
getReadRequestsCount() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
 
getReadRequestsCount() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
 
getReadRpcTimeout() - 类 中的方法org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getReadRpcTimeout() - 类 中的方法org.apache.hadoop.hbase.client.HTable
 
getReadRpcTimeout() - 接口 中的方法org.apache.hadoop.hbase.client.Table
Get timeout (millisecond) of each rpc read request in this Table instance.
getReadType() - 类 中的方法org.apache.hadoop.hbase.client.Scan
 
getRecoverableZooKeeper() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Get the connection to ZooKeeper.
getRegion() - 类 中的方法org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
 
getRegion() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
 
getRegion(Connection, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
getRegionActionBuilderWithRegion(ClientProtos.RegionAction.Builder, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.RequestConverter
 
getRegionCachePrefetch(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
always return false since 0.99
getRegionCachePrefetch(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
always return false since 0.99
getRegionCachePrefetch(Configuration, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.client.HTable
已过时。
always return false since 0.99
getRegionCachePrefetch(Configuration, TableName) - 类 中的静态方法org.apache.hadoop.hbase.client.HTable
已过时。
always return false since 0.99
getRegionCachePrefetch(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.client.HTable
已过时。
always return false since 0.99
getRegionCachePrefetch(TableName) - 类 中的静态方法org.apache.hadoop.hbase.client.HTable
已过时。
always return false since 0.99
getRegionCount(Configuration, String) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
已过时。
getRegionCount(Configuration, TableName) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Count regions in hbase:meta for passed table.
getRegionCount(Connection, TableName) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Count regions in hbase:meta for passed table.
getRegionEncodedName(HBaseProtos.RegionSpecifier) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Find the HRegion encoded name based on a region specifier
getRegionId() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
 
getRegionInfo() - 类 中的方法org.apache.hadoop.hbase.HRegionLocation
 
getRegionInfo(RpcController, AdminProtos.AdminService.BlockingInterface, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to retrieve region info given a region name using admin protocol.
getRegionInfoColumn() - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Returns the column qualifier for serialized region info
getRegionInfoForDefaultReplica(HRegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.client.RegionReplicaUtil
Returns the HRegionInfo for the default replicaId (0).
getRegionInfoForReplica(HRegionInfo, int) - 类 中的静态方法org.apache.hadoop.hbase.client.RegionReplicaUtil
Returns the HRegionInfo for the given replicaId.
getRegionInfos(AdminProtos.GetOnlineRegionResponse) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ResponseConverter
Get the list of region info from a GetOnlineRegionResponse
getRegionLocation(TableName, byte[], boolean) - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
Find region location hosting passed row
getRegionLocation(TableName, byte[], boolean) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
internal method, do not use thru HConnection
getRegionLocation(byte[], byte[], boolean) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
getRegionLocation(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HRegionLocator
Finds the region on which the given row is being served.
getRegionLocation(byte[], boolean) - 类 中的方法org.apache.hadoop.hbase.client.HRegionLocator
Finds the region on which the given row is being served.
getRegionLocation(String) - 类 中的方法org.apache.hadoop.hbase.client.HTable
getRegionLocation(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HTable
已过时。
getRegionLocation(byte[], boolean) - 类 中的方法org.apache.hadoop.hbase.client.HTable
getRegionLocation(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.RegionLocator
Finds the region on which the given row is being served.
getRegionLocation(byte[], boolean) - 接口 中的方法org.apache.hadoop.hbase.client.RegionLocator
Finds the region on which the given row is being served.
getRegionLocation(Connection, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Returns the HRegionLocation from meta for the given region
getRegionLocation(Connection, HRegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Returns the HRegionLocation from meta for the given region
getRegionLocation(int) - 类 中的方法org.apache.hadoop.hbase.RegionLocations
 
getRegionLocation() - 类 中的方法org.apache.hadoop.hbase.RegionLocations
Returns the first not-null region location in the list
getRegionLocationByRegionName(byte[]) - 类 中的方法org.apache.hadoop.hbase.RegionLocations
Returns the region location from the list for matching regionName, which can be regionName or encodedRegionName
getRegionLocations() - 类 中的方法org.apache.hadoop.hbase.client.HTable
已过时。
This is no longer a public API. Use HTable.getAllRegionLocations() instead.
getRegionLocations(ClusterConnection, TableName, byte[], boolean, int) - 类 中的静态方法org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
getRegionLocations(Result) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Returns an HRegionLocationList extracted from the result.
getRegionLocations() - 类 中的方法org.apache.hadoop.hbase.RegionLocations
 
getRegionLocator(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Connection
Retrieve a RegionLocator implementation to inspect region information on a table.
getRegionLocator(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
Retrieve a RegionLocator implementation to inspect region information on a table.
getRegionLocator() - 类 中的方法org.apache.hadoop.hbase.client.HTable
 
getRegionName() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
 
getRegionName() - 类 中的方法org.apache.hadoop.hbase.RegionTransition
 
getRegionName(ZooKeeperWatcher, String) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKAssign
Gets the region name from the full path node name of an unassigned node.
getRegionNameAsString(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
 
getRegionNameAsString(HRegionInfo, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
 
getRegionNameAsString() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
 
getRegionNormalizerZNode() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
getRegionOpeningState(AdminProtos.OpenRegionResponse) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ResponseConverter
Get the region opening state from a OpenRegionResponse
getRegionOpeningStateList(AdminProtos.OpenRegionResponse) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ResponseConverter
Get a list of region opening state from a OpenRegionResponse
getRegionReplication() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Returns the configured replicas per region
getRegionResult(Connection, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Gets the result in hbase:meta for the specified region.
getRegions() - 类 中的方法org.apache.hadoop.hbase.client.MultiAction
 
getRegionsCount() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
 
getRegionServerCoprocessors() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
Return the RegionServer-level coprocessors
getRegionsFromMergeQualifier(Connection, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Get regions from the merge qualifier of the specified merged region
getRegionsInRange(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HTable
已过时。
This is no longer a public API
getRegionsInRange(byte[], byte[], boolean) - 类 中的方法org.apache.hadoop.hbase.client.HTable
已过时。
This is no longer a public API
getRegionsInTransition() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
 
getRegionsLoad() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
 
getRegionSplitPolicyClassName() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
This gets the class associated with the region split policy which determines when a region split should occur.
getRemoteException(ServiceException) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Return the IOException thrown by the remote server wrapped in ServiceException as cause.
getReplicableHFiles(String) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesClient
Get a list of all hfile references in the given peer.
getReplicableHFiles(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesClientZKImpl
 
getReplicaCallTimeoutMicroSecondScan() - 类 中的方法org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getReplicaId() - 类 中的方法org.apache.hadoop.hbase.client.Action
 
getReplicaId() - 类 中的方法org.apache.hadoop.hbase.client.Query
Returns region replica id where Query will fetch data from.
getReplicaId() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
Returns the region replica id
getReplicationEndpointImpl() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
getReplicationLag() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationLoadSource
 
getReplicationLoadSink() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
Call directly from client such as hbase shell
getReplicationLoadSourceList() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
Call directly from client such as hbase shell
getReplicationPeerConfig(String) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeers
Returns the configured ReplicationPeerConfig for this peerId
getReplicationPeerConfig(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
Returns a ReplicationPeerConfig from the znode or null for the given peerId.
getReplicationPeers(ZooKeeperWatcher, Configuration, Abortable) - 类 中的静态方法org.apache.hadoop.hbase.replication.ReplicationFactory
 
getReplicationPeers(ZooKeeperWatcher, Configuration, ReplicationQueuesClient, Abortable) - 类 中的静态方法org.apache.hadoop.hbase.replication.ReplicationFactory
 
getReplicationQueues(ZooKeeperWatcher, Configuration, Abortable) - 类 中的静态方法org.apache.hadoop.hbase.replication.ReplicationFactory
 
getReplicationQueuesClient(ZooKeeperWatcher, Configuration, Abortable) - 类 中的静态方法org.apache.hadoop.hbase.replication.ReplicationFactory
 
getReplicationTracker(ZooKeeperWatcher, ReplicationPeers, Configuration, Abortable, Stoppable) - 类 中的静态方法org.apache.hadoop.hbase.replication.ReplicationFactory
 
getReplicationZnodesDump(ZooKeeperWatcher) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Returns a string with replication znodes and position of the replication log
getReportTime() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
 
getRequest() - 类 中的方法org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
 
getRequestData() - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
getRequestData() - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
getRequestData() - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
getRequestData() - 类 中的方法org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
This method should return any additional data that is needed on the server side to construct the ColumnInterpreter.
getRequestsCount() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
 
getRequestsCount() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
 
getRequestSizeBytes() - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
getRequestsPerSecond() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
 
getResponseSizeBytes() - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
getResults() - 类 中的方法org.apache.hadoop.hbase.client.MultiResponse
 
getResults(ClientProtos.MultiRequest, ClientProtos.MultiResponse, CellScanner) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ResponseConverter
Get the results from a protocol buffer MultiResponse
getResults(ClientProtos.MultiRequest, Map<Integer, Integer>, ClientProtos.MultiResponse, CellScanner) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ResponseConverter
Get the results from a protocol buffer MultiResponse
getResults(CellScanner, ClientProtos.ScanResponse) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ResponseConverter
Create Results from the cells using the cells meta data.
getRetries() - 类 中的方法org.apache.hadoop.hbase.client.ClientScanner
 
getRetriesNumber() - 类 中的方法org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getRitDuration() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
 
getRootIndexSizeKB() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
 
getRootIndexSizeKB() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
 
getRow() - 类 中的方法org.apache.hadoop.hbase.client.Cursor
 
getRow() - 类 中的方法org.apache.hadoop.hbase.client.Get
Method for retrieving the get's row
getRow() - 类 中的方法org.apache.hadoop.hbase.client.Mutation
Method for retrieving the delete's row
getRow() - 类 中的方法org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
 
getRow() - 类 中的方法org.apache.hadoop.hbase.client.RegionServerCallable
 
getRow() - 类 中的方法org.apache.hadoop.hbase.client.Result
Method for retrieving the row key that corresponds to the row from which this Result was created.
getRow(int) - 异常错误 中的方法org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
getRow() - 接口 中的方法org.apache.hadoop.hbase.client.Row
 
getRow() - 类 中的方法org.apache.hadoop.hbase.client.RowMutations
 
getRowOffsetPerColumnFamily() - 类 中的方法org.apache.hadoop.hbase.client.Get
Method for retrieving the get's offset per row per column family (#kvs to be skipped)
getRowOffsetPerColumnFamily() - 类 中的方法org.apache.hadoop.hbase.client.Scan
Method for retrieving the scan's offset per row per column family (#kvs to be skipped)
getRowOrBefore(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HTable
已过时。
Use reversed scan instead.
getRowOrBefore(byte[], byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.HTableInterface
已过时。
As of version 0.92 this method is deprecated without replacement. Since version 0.96+, you can use reversed scan. getRowOrBefore is used internally to find entries in hbase:meta and makes various assumptions about the table (which are true for hbase:meta but not in general) to be efficient.
getRowOrBefore(ClientProtos.ClientService.BlockingInterface, byte[], byte[], byte[]) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
已过时。
since 0.99 - use reversed scanner instead.
getRowRanges() - 类 中的方法org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
getRpcControllerFactory() - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
 
getRpcRetryingCallerFactory() - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
 
getRpcTimeout() - 类 中的方法org.apache.hadoop.hbase.client.HTable
已过时。
getRpcTimeout() - 接口 中的方法org.apache.hadoop.hbase.client.Table
已过时。
Use getReadRpcTimeout or getWriteRpcTimeout instead
getRsCoprocessors() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
Return the RegionServer-level and Region-level coprocessors
getSaslQop() - 枚举 中的方法org.apache.hadoop.hbase.security.SaslUtil.QualityOfProtection
 
getScan() - 类 中的方法org.apache.hadoop.hbase.client.ClientScanner
 
getScan() - 类 中的方法org.apache.hadoop.hbase.client.ScannerCallable
 
getScanForTableName(TableName) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
This method creates a Scan object that will only scan catalog rows that belong to the specified table.
getScanMetrics() - 类 中的方法org.apache.hadoop.hbase.client.AbstractClientScanner
Used internally accumulating metrics on scan.
getScanMetrics() - 接口 中的方法org.apache.hadoop.hbase.client.ResultScanner
 
getScanMetrics() - 类 中的方法org.apache.hadoop.hbase.client.Scan
已过时。
Use ResultScanner.getScanMetrics() instead. And notice that, please do not use this method and ResultScanner.getScanMetrics() together, the metrics will be messed up.
getScanMetrics(ClientProtos.ScanResponse) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ResponseConverter
 
getScanner(Scan) - 类 中的方法org.apache.hadoop.hbase.client.HTable
The underlying HTable must not be closed.
getScanner(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HTable
The underlying HTable must not be closed.
getScanner(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HTable
The underlying HTable must not be closed.
getScanner(Scan) - 接口 中的方法org.apache.hadoop.hbase.client.Table
Returns a scanner on the current table as specified by the Scan object.
getScanner(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Table
Gets a scanner on the current table for the given family.
getScanner(byte[], byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Table
Gets a scanner on the current table for the given family and qualifier.
getScannerCaching() - 类 中的方法org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getScannerCaching() - 类 中的方法org.apache.hadoop.hbase.client.HTable
getScannerCallableForReplica(int) - 类 中的方法org.apache.hadoop.hbase.client.ReversedScannerCallable
 
getScannerCallableForReplica(int) - 类 中的方法org.apache.hadoop.hbase.client.ScannerCallable
 
getScannerMaxResultSize() - 类 中的方法org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getScannerTimeout() - 类 中的方法org.apache.hadoop.hbase.client.ClientScanner
 
getScope() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
getSecurityCapabilities() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Return the set of supported security capabilities.
getSecurityCapabilities() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
getSeqNum() - 类 中的方法org.apache.hadoop.hbase.HRegionLocation
 
getSeqNumColumn(int) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Returns the column qualifier for seqNum column for replicaId
getSeqNumDuringOpen(Result) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
已过时。
use MetaTableAccessor methods for interacting with meta layouts
getSequenceNumber() - 类 中的方法org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
getServerColumn(int) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Returns the column qualifier for server column for replicaId
getServerInfo() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
已过时。
As of release 0.92 (HBASE-1502). This will be removed in HBase 2.0.0. Use ClusterStatus.getServers().
getServerInfo(RpcController, AdminProtos.AdminService.BlockingInterface) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to get the info of a region server using admin protocol.
getServerName() - 异常错误 中的方法org.apache.hadoop.hbase.exceptions.RegionMovedException
 
getServerName(Result) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
已过时。
use MetaTableAccessor methods for interacting with meta layouts
getServerName() - 类 中的方法org.apache.hadoop.hbase.HRegionLocation
 
getServerName() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
 
getServerName() - 类 中的方法org.apache.hadoop.hbase.RegionTransition
 
getServerName() - 类 中的方法org.apache.hadoop.hbase.ServerName
 
getServerName(String, long) - 类 中的静态方法org.apache.hadoop.hbase.ServerName
 
getServerNameLessStartCode(String) - 类 中的静态方法org.apache.hadoop.hbase.ServerName
Utility method to excise the start code from a server name
getServerPrincipal() - 类 中的方法org.apache.hadoop.hbase.security.SecurityInfo
 
getServers() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
 
getServersSize() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
 
getServerStartcodeFromServerName(String) - 类 中的静态方法org.apache.hadoop.hbase.ServerName
 
getServerStats(String, int) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Gets the statistics from the given server.
getServerUserRegions(Connection, ServerName) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
 
getServiceException(ServiceException) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Return the Exception thrown by the remote server wrapped in ServiceException as cause.
getServiceName() - 类 中的方法org.apache.hadoop.hbase.ipc.ConnectionId
 
getServiceName(Descriptors.ServiceDescriptor) - 类 中的静态方法org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
Returns the name to use for coprocessor service calls.
getSessionId() - 类 中的方法org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
getSessionPasswd() - 类 中的方法org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
getSettingsQualifierForUserNamespace(String) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getSettingsQualifierForUserTable(TableName) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getSettingsQualifierRegexForUserNamespace(String) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getSettingsQualifierRegexForUserTable(String) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getShortNameToLog() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
 
getShortTextFormat(Message) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Return short version of Message toString'd, shorter than TextFormat#shortDebugString.
getSizeOfLogQueue() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationLoadSource
 
getSleepTime() - 类 中的方法org.apache.hadoop.hbase.client.DelayingRunner
 
getSnapshotDescription() - 异常错误 中的方法org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
已过时。
since 1.3.0, will be removed in 3.0.0
getSplitKeysArray(MasterProtos.CreateTableRequest) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
get the split keys in form "byte [][]" from a CreateTableRequest proto
getStagingPath(String, byte[]) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.SecureBulkLoadClient
 
getStagingPath(Configuration, String, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.security.SecureBulkLoadUtil
This returns the staging path for a given column family.
getStamp() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
 
getStartcode() - 类 中的方法org.apache.hadoop.hbase.ServerName
 
getStartCodeColumn(int) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Returns the column qualifier for server start code column for replicaId
getStartEndKeys() - 类 中的方法org.apache.hadoop.hbase.client.HRegionLocator
Gets the starting and ending row keys for every region in the currently open table.
getStartEndKeys() - 类 中的方法org.apache.hadoop.hbase.client.HTable
已过时。
Since 1.1.0. Use RegionLocator.getStartEndKeys() instead;
getStartEndKeys() - 接口 中的方法org.apache.hadoop.hbase.client.RegionLocator
Gets the starting and ending row keys for every region in the currently open table.
getStartKey(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
Gets the start key from the specified region name.
getStartKey() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
 
getStartKeys() - 类 中的方法org.apache.hadoop.hbase.client.HRegionLocator
Gets the starting row key for every region in the currently open table.
getStartKeys() - 类 中的方法org.apache.hadoop.hbase.client.HTable
已过时。
Since 1.1.0. Use RegionLocator.getStartEndKeys() instead
getStartKeys() - 接口 中的方法org.apache.hadoop.hbase.client.RegionLocator
Gets the starting row key for every region in the currently open table.
getStartRow() - 类 中的方法org.apache.hadoop.hbase.client.Scan
 
getStartTime() - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
getState() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
 
getState() - 类 中的方法org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
getStatisticsTracker() - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
 
getStats() - 类 中的方法org.apache.hadoop.hbase.client.Result
已过时。
getStats(ServerName) - 类 中的方法org.apache.hadoop.hbase.client.ServerStatisticTracker
 
getStatsForRegion(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.backoff.ServerStatistics
 
getStatusOfPeer(String) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeers
Get the replication status for the specified connected remote slave cluster.
getStatusOfPeer(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
getStatusOfPeerFromBackingStore(String) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeers
Get the replication status for the specified remote slave cluster, which doesn't have to be connected.
getStatusOfPeerFromBackingStore(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
getStopRow() - 类 中的方法org.apache.hadoop.hbase.client.Scan
 
getStopRowKey() - 类 中的方法org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
getStoreCompleteSequenceId() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
 
getStorefileIndexSizeInMB() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
 
getStorefileIndexSizeMB() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
 
getStoreFiles(AdminProtos.AdminService.BlockingInterface, byte[], byte[]) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to get the list of files of a column family on a given region using admin protocol.
getStoreFiles(RpcController, AdminProtos.AdminService.BlockingInterface, byte[], byte[]) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to get the list of files of a column family on a given region using admin protocol.
getStorefiles() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
 
getStorefiles() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
 
getStorefileSizeInMB() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
 
getStorefileSizeMB() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
 
getStores() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
 
getStores() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
 
getStoreUncompressedSizeMB() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
 
getStoreUncompressedSizeMB() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
 
getStub() - 类 中的方法org.apache.hadoop.hbase.client.RegionServerCallable
 
getSupportedFilters() - 类 中的方法org.apache.hadoop.hbase.filter.ParseFilter
Return a Set of filters supported by the Filter Language
getSwitchZNode() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
getTable() - 类 中的方法org.apache.hadoop.hbase.client.ClientScanner
 
getTable(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Connection
Retrieve a Table implementation for accessing a table.
getTable(TableName, ExecutorService) - 接口 中的方法org.apache.hadoop.hbase.client.Connection
Retrieve a Table implementation for accessing a table.
getTable(String) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
Retrieve an HTableInterface implementation for access to a table.
getTable(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
Retrieve an HTableInterface implementation for access to a table.
getTable(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
Retrieve an HTableInterface implementation for access to a table.
getTable(String, ExecutorService) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
Retrieve an HTableInterface implementation for access to a table.
getTable(byte[], ExecutorService) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
Retrieve an HTableInterface implementation for access to a table.
getTable(TableName, ExecutorService) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
Retrieve an HTableInterface implementation for access to a table.
getTable(String) - 类 中的方法org.apache.hadoop.hbase.client.HTablePool
已过时。
Get a reference to the specified table from the pool.
getTable(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HTablePool
已过时。
Get a reference to the specified table from the pool.
getTable(TableName) - 接口 中的方法org.apache.hadoop.hbase.CoprocessorEnvironment
 
getTable(TableName, ExecutorService) - 接口 中的方法org.apache.hadoop.hbase.CoprocessorEnvironment
 
getTable(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
Gets the table name from the specified region name.
getTable() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
Get current table name of the region
getTableCF(ZooKeeperProtos.TableCF[], String) - 类 中的静态方法org.apache.hadoop.hbase.replication.ReplicationSerDeHelper
Get TableCF in TableCFs, if not exist, return null.
getTableCFs() - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeer
Get replicable (table, cf-list) map of this peer
getTableCFs(String) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeers
Get the table and column-family-list map of the peer.
getTableCFs(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
getTableCFs() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
Get replicable (table, cf-list) map of this peer
getTableCFsMap() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
getTableCFsNode(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationStateZKBase
 
getTableDescriptor(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Method for getting the tableDescriptor
getTableDescriptor(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Method for getting the tableDescriptor
getTableDescriptor(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
getTableDescriptor() - 类 中的方法org.apache.hadoop.hbase.client.HTable
Gets the table descriptor for this table.
getTableDescriptor() - 接口 中的方法org.apache.hadoop.hbase.client.Table
Gets the table descriptor for this table.
getTableDescriptors(List<String>) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Get tableDescriptors
getTableDescriptors(List<String>) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Get tableDescriptors
getTableDescriptorsByTableName(List<TableName>) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Get tableDescriptors
getTableDescriptorsByTableName(List<TableName>) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Get tableDescriptors
getTableDir(Path, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.HTableDescriptor
已过时。
getTableFilter() - 类 中的方法org.apache.hadoop.hbase.quotas.QuotaFilter
 
getTableFromRowKey(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getTableName() - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorParams
 
getTableName() - 类 中的方法org.apache.hadoop.hbase.client.ClientScanner
已过时。
As of release 0.96 (HBASE-9508). This will be removed in HBase 2.0.0. Use ClientScanner.getTable().
getTableName() - 类 中的方法org.apache.hadoop.hbase.client.HTable
Gets the name of this table.
getTableName() - 接口 中的方法org.apache.hadoop.hbase.client.HTableInterface
已过时。
Use Table.getName() instead
getTableName() - 类 中的方法org.apache.hadoop.hbase.client.RegionServerCallable
 
getTableName(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
已过时。
As of release 0.96 (HBASE-9508). This will be removed in HBase 2.0.0. Use HRegionInfo.getTable(byte[]).
getTableName() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
已过时。
As of release 0.96 (HBASE-9508). This will be removed in HBase 2.0.0. Use HRegionInfo.getTable().
getTableName() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Get the name of the table
getTableName() - 类 中的方法org.apache.hadoop.hbase.quotas.QuotaSettings
 
getTableName() - 类 中的方法org.apache.hadoop.hbase.security.access.TablePermission
 
getTableNameArray(List<TableProtos.TableName>) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
getTableNames() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
已过时。
getTableNames(Pattern) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
已过时。
getTableNames(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
已过时。
getTableNames() - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
getTableQuota(Connection, TableName) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getTableRegions(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Get the regions of a given table.
getTableRegions(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
get the regions of a given table.
getTableRegions(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
getTableRegions(ZooKeeperWatcher, Connection, TableName) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Gets all of the regions of the specified table.
getTableRegions(ZooKeeperWatcher, Connection, TableName, boolean) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Gets all of the regions of the specified table.
getTableRegions(ZooKeeperWatcher, Connection, TableName, boolean, boolean) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Gets all of the regions of the specified table.
getTableRegionsAndLocations(ZooKeeperWatcher, Connection, TableName) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
 
getTableRegionsAndLocations(ZooKeeperWatcher, Connection, TableName, boolean) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
 
getTableRegionsAndLocations(ZooKeeperWatcher, Connection, TableName, boolean, boolean) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
 
getTableRowKey(TableName) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getTableRowKeyRegex(String) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getTicket() - 类 中的方法org.apache.hadoop.hbase.ipc.ConnectionId
 
getTimeRange() - 类 中的方法org.apache.hadoop.hbase.client.Get
Method for retrieving the get's TimeRange
getTimeRange() - 类 中的方法org.apache.hadoop.hbase.client.Increment
Gets the TimeRange used for this increment.
getTimeRange() - 类 中的方法org.apache.hadoop.hbase.client.Scan
 
getTimestamp() - 类 中的方法org.apache.hadoop.hbase.client.ClientScanner
 
getTimeStamp() - 类 中的方法org.apache.hadoop.hbase.client.Mutation
Method for retrieving the timestamp
getTimeStampOfLastShippedOp() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationLoadSource
 
getTimestamps() - 类 中的方法org.apache.hadoop.hbase.filter.TimestampsFilter
 
getTimeStampsOfLastAppliedOp() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationLoadSink
 
getTimeToLive() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
getTokenKind() - 类 中的方法org.apache.hadoop.hbase.security.SecurityInfo
 
getTotalBufferedCounter() - 类 中的方法org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
getTotalCompactingKVs() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
 
getTotalCompactingKVs() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
 
getTotalFailedCounter() - 类 中的方法org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
getTotalNumberOfRequests() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
 
getTotalRequestsCount(ClusterStatusProtos.RegionLoad) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
getTotalSizeOfCells(Result) - 类 中的静态方法org.apache.hadoop.hbase.client.Result
Get total size of raw cells
getTotalStaticBloomSizeKB() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
 
getTotalStaticBloomSizeKB() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
 
getTotalStaticIndexSizeKB() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
 
getTotalStaticIndexSizeKB() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
 
getTracker - 类 中的变量org.apache.hadoop.hbase.client.MetricsConnection
 
getTTL() - 类 中的方法org.apache.hadoop.hbase.client.Mutation
Return the TTL requested for the result of the mutation, in milliseconds.
getType() - 异常错误 中的方法org.apache.hadoop.hbase.quotas.ThrottlingException
 
getTypeFilters() - 类 中的方法org.apache.hadoop.hbase.quotas.QuotaFilter
 
getUnClaimedQueueIds(String) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationQueues
Get queueIds from a dead region server, whose queues has not been claimed by other region servers.
getUnClaimedQueueIds(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
getUnit(String) - 类 中的静态方法org.apache.hadoop.hbase.HColumnDescriptor
 
getUsedHeapMB() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
 
getUser() - 类 中的方法org.apache.hadoop.hbase.security.access.UserPermission
 
getUser() - 类 中的方法org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
getUserFilter() - 类 中的方法org.apache.hadoop.hbase.quotas.QuotaFilter
 
getUserFromRowKey(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getUserName() - 类 中的方法org.apache.hadoop.hbase.quotas.QuotaSettings
 
getUsername() - 类 中的方法org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
getUserPermissions(RpcController, AccessControlProtos.AccessControlService.BlockingInterface) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
A utility used to get user's global permissions.
getUserPermissions(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, TableName) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
A utility used to get user table permissions.
getUserPermissions(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
A utility used to get permissions for selected namespace.
getUserPermissions(Connection, String) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlClient
List all the userPermissions matching the given pattern.
getUserPermissions(Configuration, String) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlClient
getUserQuota(Connection, String) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getUserQuota(Connection, String, TableName) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getUserQuota(Connection, String, String) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getUserRowKey(String) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getUserRowKeyRegex(String) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getUUIDForCluster(ZooKeeperWatcher) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKClusterId
Get the UUID for the provided ZK watcher.
getValue(byte[], byte[], Cell) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
getValue(byte[], byte[], Cell) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
getValue(byte[], byte[], Cell) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
getValue(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Result
Get the latest version of the specified column.
getValue() - 枚举 中的方法org.apache.hadoop.hbase.client.security.SecurityCapability
 
getValue(byte[], byte[], Cell) - 类 中的方法org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
 
getValue() - 类 中的方法org.apache.hadoop.hbase.filter.ByteArrayComparable
 
getValue() - 类 中的方法org.apache.hadoop.hbase.filter.SubstringComparator
 
getValue(byte[]) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
getValue(String) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
getValue(byte[]) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Getter for accessing the metadata associated with the key
getValue(String) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Getter for accessing the metadata associated with the key
getValueAsByteBuffer(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Result
Returns the value wrapped in a new ByteBuffer.
getValueAsByteBuffer(byte[], int, int, byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.client.Result
Returns the value wrapped in a new ByteBuffer.
getValues() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
getValues() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Getter for fetching an unmodifiable HTableDescriptor.values map.
getVersion() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
 
getVersion() - 接口 中的方法org.apache.hadoop.hbase.CoprocessorEnvironment
 
getVersion() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
已过时。
HRI is no longer a VersionedWritable
getVersion() - 类 中的方法org.apache.hadoop.hbase.security.access.Permission
 
getVersion(ZooKeeperWatcher, HRegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKAssign
Get the version of the specified znode
getVersionedBytes() - 类 中的方法org.apache.hadoop.hbase.ServerName
 
getVersionInfo() - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Get a protocol buffer VersionInfo
getWaitInterval() - 异常错误 中的方法org.apache.hadoop.hbase.quotas.ThrottlingException
 
getWatcher() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperListener
 
getWritable(byte[], Writable) - 类 中的静态方法org.apache.hadoop.hbase.util.Writables
Set bytes into the passed Writable by calling its Writable.readFields(java.io.DataInput).
getWritable(byte[], int, int, Writable) - 类 中的静态方法org.apache.hadoop.hbase.util.Writables
Set bytes into the passed Writable by calling its Writable.readFields(java.io.DataInput).
getWriteBuffer() - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorImpl
已过时。
Going away when we drop public support for HTableInterface. Ó
getWriteBuffer() - 类 中的方法org.apache.hadoop.hbase.client.HTable
已过时。
since 0.96. This is an internal buffer that should not be read nor write.
getWriteBufferSize() - 接口 中的方法org.apache.hadoop.hbase.client.BufferedMutator
Returns the maximum size in bytes of the write buffer for this HTable.
getWriteBufferSize() - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorImpl
Returns the maximum size in bytes of the write buffer for this HTable.
getWriteBufferSize() - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorParams
 
getWriteBufferSize() - 类 中的方法org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getWriteBufferSize() - 类 中的方法org.apache.hadoop.hbase.client.HTable
Returns the maximum size in bytes of the write buffer for this HTable.
getWriteBufferSize() - 接口 中的方法org.apache.hadoop.hbase.client.HTableInterface
已过时。
as of 1.0.0. Replaced by BufferedMutator.getWriteBufferSize()
getWriteBufferSize() - 接口 中的方法org.apache.hadoop.hbase.client.Table
已过时。
as of 1.0.1 (should not have been in 1.0.0). Replaced by BufferedMutator.getWriteBufferSize()
getWriteRequestsCount() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
 
getWriteRequestsCount() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
 
getWriteRpcTimeout() - 类 中的方法org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getWriteRpcTimeout() - 类 中的方法org.apache.hadoop.hbase.client.HTable
 
getWriteRpcTimeout() - 接口 中的方法org.apache.hadoop.hbase.client.Table
Get timeout (millisecond) of each rpc write request in this Table instance.
getWriteToWAL() - 类 中的方法org.apache.hadoop.hbase.client.Mutation
已过时。
getZNodeForReplica(int) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Get the znode string corresponding to a replicaId
getZooKeeper() - 类 中的方法org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
grant(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, boolean, Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
A utility used to grant a user global permissions.
grant(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, TableName, byte[], byte[], boolean, Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
A utility used to grant a user table permissions.
grant(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, String, boolean, Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
A utility used to grant a user namespace permissions.
grant(Connection, TableName, String, byte[], byte[], boolean, Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlClient
Grants permission on the specified table for the specified user
grant(Connection, TableName, String, byte[], byte[], Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlClient
Grants permission on the specified table for the specified user.
grant(Connection, String, String, boolean, Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlClient
Grants permission on the specified namespace for the specified user.
grant(Connection, String, String, Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlClient
Grants permission on the specified namespace for the specified user.
grant(Connection, String, boolean, Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlClient
Grant global permissions for the specified user.
grant(Connection, String, Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlClient
Grant global permissions for the specified user.
grant(Configuration, TableName, String, byte[], byte[], Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlClient
grant(Configuration, String, String, Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlClient
grant(Configuration, String, Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlClient
GREATER_THAN_ARRAY - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
GREATER_THAN Array
GREATER_THAN_BUFFER - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
 
GREATER_THAN_OR_EQUAL_TO_ARRAY - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
GREATER_THAN_OR_EQUAL_TO Array
GREATER_THAN_OR_EQUAL_TO_BUFFER - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
 

H

H - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'H'
handlerAdded(ChannelHandlerContext) - 类 中的方法org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClientHandler
 
handlerAdded(ChannelHandlerContext) - 类 中的方法org.apache.hadoop.hbase.security.SaslWrapHandler
 
handleRemoteException(Exception) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Like ProtobufUtil.getRemoteException(ServiceException) but more generic, able to handle more than just ServiceException.
has(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Put
A convenience method to determine if this object's familyMap contains a value assigned to the given family & qualifier.
has(byte[], byte[], long) - 类 中的方法org.apache.hadoop.hbase.client.Put
A convenience method to determine if this object's familyMap contains a value assigned to the given family, qualifier and timestamp.
has(byte[], byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Put
A convenience method to determine if this object's familyMap contains a value assigned to the given family, qualifier and timestamp.
has(byte[], byte[], long, byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Put
A convenience method to determine if this object's familyMap contains the given value assigned to the given family, qualifier and timestamp.
hasCallTimeout() - 类 中的方法org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
hasCallTimeout() - 接口 中的方法org.apache.hadoop.hbase.ipc.HBaseRpcController
 
hasCallTimeout() - 类 中的方法org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
hasCellBlockSupport() - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
 
hasCellBlockSupport() - 类 中的方法org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
hasCellBlockSupport() - 接口 中的方法org.apache.hadoop.hbase.ipc.RpcClient
 
hasCoprocessor(String) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Check if the table has an attached co-processor represented by the name className
hasCounter(String) - 类 中的方法org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
 
hasFamilies() - 类 中的方法org.apache.hadoop.hbase.client.Get
Method for checking if any families have been inserted into this Get
hasFamilies() - 类 中的方法org.apache.hadoop.hbase.client.Increment
Method for checking if any families have been inserted into this Increment
hasFamilies() - 类 中的方法org.apache.hadoop.hbase.client.Scan
 
hasFamily(byte[]) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Checks to see if this table contains the given column family
hasFamily() - 类 中的方法org.apache.hadoop.hbase.security.access.TablePermission
 
hasFilter() - 类 中的方法org.apache.hadoop.hbase.client.Scan
 
hasFilterRow() - 类 中的方法org.apache.hadoop.hbase.filter.DependentColumnFilter
 
hasFilterRow() - 类 中的方法org.apache.hadoop.hbase.filter.Filter
Primarily used to check for conflicts with scans(such as scans that do not read a full row at a time).
hasFilterRow() - 类 中的方法org.apache.hadoop.hbase.filter.FilterBase
Fitlers that never filter by modifying the returned List of Cells can inherit this implementation that does nothing.
hasFilterRow() - 类 中的方法org.apache.hadoop.hbase.filter.FilterList
 
hasFilterRow() - 类 中的方法org.apache.hadoop.hbase.filter.FilterListBase
 
hasFilterRow() - 类 中的方法org.apache.hadoop.hbase.filter.FilterWrapper
 
hasFilterRow() - 类 中的方法org.apache.hadoop.hbase.filter.PageFilter
 
hasFilterRow() - 类 中的方法org.apache.hadoop.hbase.filter.RandomRowFilter
 
hasFilterRow() - 类 中的方法org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
 
hasFilterRow() - 类 中的方法org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
hasFilterRow() - 类 中的方法org.apache.hadoop.hbase.filter.SkipFilter
 
hasFilterRow() - 类 中的方法org.apache.hadoop.hbase.filter.WhileMatchFilter
 
hasFoundKV() - 类 中的方法org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.client.Action
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.client.Get
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.client.Increment
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.client.RowMutations
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.filter.CompareFilter
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.filter.DependentColumnFilter
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.filter.FamilyFilter
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.filter.FilterList
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.filter.FilterListWithAND
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.filter.FilterListWithOR
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.filter.FuzzyRowFilter
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.filter.NullComparator
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.filter.PageFilter
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.filter.PrefixFilter
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.filter.QualifierFilter
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.filter.RandomRowFilter
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.filter.RowFilter
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.filter.SkipFilter
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.filter.TimestampsFilter
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.filter.ValueFilter
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.filter.WhileMatchFilter
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.HRegionLocation
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.ipc.ConnectionId
 
hashCode(User, String, InetSocketAddress) - 类 中的静态方法org.apache.hadoop.hbase.ipc.ConnectionId
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
Don't count timestamp in hash code calculation
hashCode() - 类 中的方法org.apache.hadoop.hbase.security.access.Permission
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.security.access.TablePermission
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.security.access.UserPermission
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.ServerName
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.CreateAndFailSilent
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.DeleteNodeFailSilent
 
hashCode() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.SetData
 
hasHigherPriority(ByteBuffer, ByteBuffer) - 类 中的方法org.apache.hadoop.hbase.filter.ParseFilter
Returns which operator has higher precedence If a has higher precedence than b, it returns true If they have the same precedence, it returns false
hasId() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZKClusterId
 
hasLeader() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
已过时。
 
hasMaster() - 类 中的方法org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
Check if there is a master available.
hasMaxHeapMB() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
 
hasNamespace() - 类 中的方法org.apache.hadoop.hbase.security.access.TablePermission
 
hasNonce() - 类 中的方法org.apache.hadoop.hbase.client.Action
 
hasNonceGroup() - 类 中的方法org.apache.hadoop.hbase.client.MultiAction
 
hasNumberOfRequests() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
 
hasQualifier() - 类 中的方法org.apache.hadoop.hbase.security.access.TablePermission
 
hasRegionMemstoreReplication() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
 
hasTable() - 类 中的方法org.apache.hadoop.hbase.security.access.TablePermission
 
hasTotalNumberOfRequests() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
 
hasUsedHeapMB() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
 
HBASE_CLIENT_CONNECTION_IMPL - 接口 中的静态变量org.apache.hadoop.hbase.client.HConnection
已过时。
Key for configuration in Configuration whose value is the class we implement making a new HConnection instance.
HBaseAdmin - org.apache.hadoop.hbase.client中的类
HBaseAdmin is no longer a client API.
HBaseAdmin(Configuration) - 类 的构造器org.apache.hadoop.hbase.client.HBaseAdmin
已过时。
Constructing HBaseAdmin objects manually has been deprecated. Use Connection.getAdmin() to obtain an instance of Admin instead.
HBaseAdmin(Connection) - 类 的构造器org.apache.hadoop.hbase.client.HBaseAdmin
已过时。
Constructing HBaseAdmin objects manually has been deprecated. Use Connection.getAdmin() to obtain an instance of Admin instead.
HBaseAdmin.ProcedureFuture<V> - org.apache.hadoop.hbase.client中的类
Future that waits on a procedure result.
HBaseAdmin.ProcedureFuture(HBaseAdmin, Long) - 类 的构造器org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
HBaseAdmin.ProcedureFuture(HBaseAdmin, Long, boolean) - 类 的构造器org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
HBaseAdmin.ProcedureFuture.WaitForStateCallable - org.apache.hadoop.hbase.client中的接口
 
HBaseException - org.apache.hadoop.hbase.exceptions中的异常错误
Base checked exception in HBase.
HBaseException() - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.HBaseException
 
HBaseException(String) - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.HBaseException
 
HBaseException(String, Throwable) - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.HBaseException
 
HBaseException(Throwable) - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.HBaseException
 
HBaseRpcController - org.apache.hadoop.hbase.ipc中的接口
Optionally carries Cells across the proxy/service interface down into ipc.
HBaseRpcController.CancellationCallback - org.apache.hadoop.hbase.ipc中的接口
 
HBaseRpcControllerImpl - org.apache.hadoop.hbase.ipc中的类
Optionally carries Cells across the proxy/service interface down into ipc.
HBaseRpcControllerImpl() - 类 的构造器org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
HBaseRpcControllerImpl(CellScanner) - 类 的构造器org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
HBaseRpcControllerImpl(List<CellScannable>) - 类 的构造器org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
HBaseSaslRpcClient - org.apache.hadoop.hbase.security中的类
A utility class that encapsulates SASL logic for RPC client.
HBaseSaslRpcClient(AuthMethod, Token<? extends TokenIdentifier>, String, boolean) - 类 的构造器org.apache.hadoop.hbase.security.HBaseSaslRpcClient
 
HBaseSaslRpcClient(AuthMethod, Token<? extends TokenIdentifier>, String, boolean, String) - 类 的构造器org.apache.hadoop.hbase.security.HBaseSaslRpcClient
 
HBaseSnapshotException - org.apache.hadoop.hbase.snapshot中的异常错误
General exception base class for when a snapshot fails.
HBaseSnapshotException(String) - 异常错误 的构造器org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
Some exception happened for a snapshot and don't even know the snapshot that it was about.
HBaseSnapshotException(String, HBaseProtos.SnapshotDescription) - 异常错误 的构造器org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
已过时。
since 1.3.0, will be removed in 3.0.0
HBaseSnapshotException(String, Throwable, HBaseProtos.SnapshotDescription) - 异常错误 的构造器org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
已过时。
since 1.3.0, will be removed in 3.0.0
HBaseSnapshotException(String, Exception) - 异常错误 的构造器org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
Exception when the description of the snapshot cannot be determined, due to some root other root cause.
HColumnDescriptor - org.apache.hadoop.hbase中的类
An HColumnDescriptor contains information about a column family such as the number of versions, compression settings, etc.
HColumnDescriptor() - 类 的构造器org.apache.hadoop.hbase.HColumnDescriptor
已过时。
As of release 0.96 (HBASE-5453). This will be made private in HBase 2.0.0. Used by Writables and Writables are going away.
HColumnDescriptor(String) - 类 的构造器org.apache.hadoop.hbase.HColumnDescriptor
Construct a column descriptor specifying only the family name The other attributes are defaulted.
HColumnDescriptor(byte[]) - 类 的构造器org.apache.hadoop.hbase.HColumnDescriptor
Construct a column descriptor specifying only the family name The other attributes are defaulted.
HColumnDescriptor(HColumnDescriptor) - 类 的构造器org.apache.hadoop.hbase.HColumnDescriptor
Constructor.
HColumnDescriptor(byte[], int, String, boolean, boolean, int, String) - 类 的构造器org.apache.hadoop.hbase.HColumnDescriptor
已过时。
As of release 0.96 (HBASE-). This will be removed in HBase 2.0.0. Use HColumnDescriptor.HColumnDescriptor(String) and setters.
HColumnDescriptor(byte[], int, String, boolean, boolean, int, int, String, int) - 类 的构造器org.apache.hadoop.hbase.HColumnDescriptor
已过时。
As of release 0.96 (HBASE-). This will be removed in HBase 2.0.0. Use HColumnDescriptor.HColumnDescriptor(String) and setters.
HColumnDescriptor(byte[], int, int, KeepDeletedCells, String, boolean, String, boolean, boolean, int, int, String, int) - 类 的构造器org.apache.hadoop.hbase.HColumnDescriptor
已过时。
As of release 0.96 (HBASE-). This will be removed in HBase 2.0.0. Use HColumnDescriptor.HColumnDescriptor(String) and setters.
HConnectable<T> - org.apache.hadoop.hbase.client中的类
This class makes it convenient for one to execute a command in the context of a HConnection instance based on the given Configuration.
HConnectable(Configuration) - 类 的构造器org.apache.hadoop.hbase.client.HConnectable
 
HConnection - org.apache.hadoop.hbase.client中的接口
已过时。
HConnectionManager - org.apache.hadoop.hbase.client中的类
已过时。
Please use ConnectionFactory instead
heapSize() - 类 中的方法org.apache.hadoop.hbase.client.Mutation
 
heartbeatMessage - 类 中的变量org.apache.hadoop.hbase.client.ScannerCallable
Saves whether or not the most recent response from the server was a heartbeat message.
hedgedReadOps - 类 中的变量org.apache.hadoop.hbase.client.MetricsConnection
 
hedgedReadWin - 类 中的变量org.apache.hadoop.hbase.client.MetricsConnection
 
hfileRefsZNode - 类 中的变量org.apache.hadoop.hbase.replication.ReplicationStateZKBase
The name of the znode that contains queues of hfile references to be replicated
hint - 类 中的变量org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
HINT_LOOKAHEAD - 类 中的静态变量org.apache.hadoop.hbase.client.Scan
已过时。
without replacement This is now a no-op, SEEKs and SKIPs are optimizated automatically. Will be removed in 2.0+
HQuorumPeer - org.apache.hadoop.hbase.zookeeper中的类
HBase's version of ZooKeeper's QuorumPeer.
HQuorumPeer() - 类 的构造器org.apache.hadoop.hbase.zookeeper.HQuorumPeer
 
HRegionInfo - org.apache.hadoop.hbase中的类
Information about a region.
HRegionInfo(long, TableName, int) - 类 的构造器org.apache.hadoop.hbase.HRegionInfo
 
HRegionInfo() - 类 的构造器org.apache.hadoop.hbase.HRegionInfo
已过时。
As of release 0.96 (HBASE-5453). This will be removed in HBase 2.0.0. Used by Writables and Writables are going away.
HRegionInfo(TableName) - 类 的构造器org.apache.hadoop.hbase.HRegionInfo
 
HRegionInfo(TableName, byte[], byte[]) - 类 的构造器org.apache.hadoop.hbase.HRegionInfo
Construct HRegionInfo with explicit parameters
HRegionInfo(TableName, byte[], byte[], boolean) - 类 的构造器org.apache.hadoop.hbase.HRegionInfo
Construct HRegionInfo with explicit parameters
HRegionInfo(TableName, byte[], byte[], boolean, long) - 类 的构造器org.apache.hadoop.hbase.HRegionInfo
Construct HRegionInfo with explicit parameters
HRegionInfo(TableName, byte[], byte[], boolean, long, int) - 类 的构造器org.apache.hadoop.hbase.HRegionInfo
Construct HRegionInfo with explicit parameters
HRegionInfo(HRegionInfo) - 类 的构造器org.apache.hadoop.hbase.HRegionInfo
Costruct a copy of another HRegionInfo
HRegionInfo(HRegionInfo, int) - 类 的构造器org.apache.hadoop.hbase.HRegionInfo
 
HRegionLocation - org.apache.hadoop.hbase中的类
Data structure to hold HRegionInfo and the address for the hosting HRegionServer.
HRegionLocation(HRegionInfo, ServerName) - 类 的构造器org.apache.hadoop.hbase.HRegionLocation
 
HRegionLocation(HRegionInfo, ServerName, long) - 类 的构造器org.apache.hadoop.hbase.HRegionLocation
 
HRegionLocator - org.apache.hadoop.hbase.client中的类
An implementation of RegionLocator.
HRegionLocator(TableName, ClusterConnection) - 类 的构造器org.apache.hadoop.hbase.client.HRegionLocator
 
HTable - org.apache.hadoop.hbase.client中的类
An implementation of Table.
HTable(Configuration, String) - 类 的构造器org.apache.hadoop.hbase.client.HTable
已过时。
Constructing HTable objects manually has been deprecated. Please use Connection to instantiate a Table instead.
HTable(Configuration, byte[]) - 类 的构造器org.apache.hadoop.hbase.client.HTable
已过时。
Constructing HTable objects manually has been deprecated. Please use Connection to instantiate a Table instead.
HTable(Configuration, TableName) - 类 的构造器org.apache.hadoop.hbase.client.HTable
已过时。
Constructing HTable objects manually has been deprecated. Please use Connection to instantiate a Table instead.
HTable(TableName, Connection) - 类 的构造器org.apache.hadoop.hbase.client.HTable
已过时。
Do not use.
HTable(Configuration, byte[], ExecutorService) - 类 的构造器org.apache.hadoop.hbase.client.HTable
已过时。
Constructing HTable objects manually has been deprecated. Please use Connection to instantiate a Table instead.
HTable(Configuration, TableName, ExecutorService) - 类 的构造器org.apache.hadoop.hbase.client.HTable
已过时。
Constructing HTable objects manually has been deprecated. Please use Connection to instantiate a Table instead.
HTable(byte[], Connection, ExecutorService) - 类 的构造器org.apache.hadoop.hbase.client.HTable
已过时。
Do not use, internal ctor.
HTable(TableName, Connection, ExecutorService) - 类 的构造器org.apache.hadoop.hbase.client.HTable
已过时。
Do not use, internal ctor.
HTable(TableName, ClusterConnection, ConnectionConfiguration, RpcRetryingCallerFactory, RpcControllerFactory, ExecutorService) - 类 的构造器org.apache.hadoop.hbase.client.HTable
Creates an object to access a HBase table.
HTable(ClusterConnection, BufferedMutatorParams) - 类 的构造器org.apache.hadoop.hbase.client.HTable
For internal testing.
HTableDescriptor - org.apache.hadoop.hbase中的类
HTableDescriptor contains the details about an HBase table such as the descriptors of all the column families, is the table a catalog table, -ROOT- or hbase:meta , if the table is read only, the maximum size of the memstore, when the region split should occur, coprocessors associated with it etc...
HTableDescriptor(TableName, HColumnDescriptor[]) - 类 的构造器org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Private constructor used internally creating table descriptors for catalog tables, hbase:meta and -ROOT-.
HTableDescriptor(TableName, HColumnDescriptor[], Map<ImmutableBytesWritable, ImmutableBytesWritable>) - 类 的构造器org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Private constructor used internally creating table descriptors for catalog tables, hbase:meta and -ROOT-.
HTableDescriptor() - 类 的构造器org.apache.hadoop.hbase.HTableDescriptor
已过时。
As of release 0.96 (HBASE-5453). This will be removed in HBase 2.0.0. Used by Writables and Writables are going away.
HTableDescriptor(TableName) - 类 的构造器org.apache.hadoop.hbase.HTableDescriptor
Construct a table descriptor specifying a TableName object
HTableDescriptor(byte[]) - 类 的构造器org.apache.hadoop.hbase.HTableDescriptor
已过时。
HTableDescriptor(String) - 类 的构造器org.apache.hadoop.hbase.HTableDescriptor
已过时。
HTableDescriptor(HTableDescriptor) - 类 的构造器org.apache.hadoop.hbase.HTableDescriptor
Construct a table descriptor by cloning the descriptor passed as a parameter.
HTableDescriptor(TableName, HTableDescriptor) - 类 的构造器org.apache.hadoop.hbase.HTableDescriptor
Construct a table descriptor by cloning the descriptor passed as a parameter but using a different table name.
HTableFactory - org.apache.hadoop.hbase.client中的类
HTableFactory() - 类 的构造器org.apache.hadoop.hbase.client.HTableFactory
已过时。
 
HTableInterface - org.apache.hadoop.hbase.client中的接口
已过时。
use Table instead
HTableInterfaceFactory - org.apache.hadoop.hbase.client中的接口
已过时。
in favor of ConnectionFactory and Connection.
HTableMultiplexer - org.apache.hadoop.hbase.client中的类
HTableMultiplexer provides a thread-safe non blocking PUT API across all the tables.
HTableMultiplexer(Configuration, int) - 类 的构造器org.apache.hadoop.hbase.client.HTableMultiplexer
 
HTableMultiplexer(Connection, Configuration, int) - 类 的构造器org.apache.hadoop.hbase.client.HTableMultiplexer
 
HTableMultiplexer.HTableMultiplexerStatus - org.apache.hadoop.hbase.client中的类
HTableMultiplexerStatus keeps track of the current status of the HTableMultiplexer.
HTableMultiplexer.HTableMultiplexerStatus(Map<HRegionLocation, HTableMultiplexer.FlushWorker>) - 类 的构造器org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
HTablePool - org.apache.hadoop.hbase.client中的类
已过时。
as of 0.98.1. See HConnection.getTable(String).
HTablePool() - 类 的构造器org.apache.hadoop.hbase.client.HTablePool
已过时。
Default Constructor.
HTablePool(Configuration, int) - 类 的构造器org.apache.hadoop.hbase.client.HTablePool
已过时。
Constructor to set maximum versions and use the specified configuration.
HTablePool(Configuration, int, HTableInterfaceFactory) - 类 的构造器org.apache.hadoop.hbase.client.HTablePool
已过时。
Constructor to set maximum versions and use the specified configuration and table factory.
HTablePool(Configuration, int, PoolMap.PoolType) - 类 的构造器org.apache.hadoop.hbase.client.HTablePool
已过时。
Constructor to set maximum versions and use the specified configuration and pool type.
HTablePool(Configuration, int, HTableInterfaceFactory, PoolMap.PoolType) - 类 的构造器org.apache.hadoop.hbase.client.HTablePool
已过时。
Constructor to set maximum versions and use the specified configuration, table factory and pool type.
HTableUtil - org.apache.hadoop.hbase.client中的类
已过时。
since 1.0
HTableUtil() - 类 的构造器org.apache.hadoop.hbase.client.HTableUtil
已过时。
 

I

I - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'I'
id - 类 中的变量org.apache.hadoop.hbase.client.ScannerCallable
 
ID_ATRIBUTE - 类 中的静态变量org.apache.hadoop.hbase.client.OperationWithAttributes
 
IDLE_TIME - 接口 中的静态变量org.apache.hadoop.hbase.ipc.RpcClient
 
implies(Permission.Action) - 类 中的方法org.apache.hadoop.hbase.security.access.Permission
 
implies(String, Permission.Action) - 类 中的方法org.apache.hadoop.hbase.security.access.TablePermission
Checks that a given table operation is authorized by this permission instance.
implies(TableName, byte[], byte[], Permission.Action) - 类 中的方法org.apache.hadoop.hbase.security.access.TablePermission
Checks that a given table operation is authorized by this permission instance.
implies(TableName, KeyValue, Permission.Action) - 类 中的方法org.apache.hadoop.hbase.security.access.TablePermission
Checks if this permission grants access to perform the given action on the given table and key value.
includeStartRow() - 类 中的方法org.apache.hadoop.hbase.client.Scan
 
includeStopRow() - 类 中的方法org.apache.hadoop.hbase.client.Scan
 
InclusiveStopFilter - org.apache.hadoop.hbase.filter中的类
A Filter that stops after the given row.
InclusiveStopFilter(byte[]) - 类 的构造器org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
IncompatibleFilterException - org.apache.hadoop.hbase.filter中的异常错误
Used to indicate a filter incompatibility
IncompatibleFilterException() - 异常错误 的构造器org.apache.hadoop.hbase.filter.IncompatibleFilterException
constructor
IncompatibleFilterException(String) - 异常错误 的构造器org.apache.hadoop.hbase.filter.IncompatibleFilterException
constructor
incrCacheDroppingExceptions(Object) - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection
 
incrDelayRunners() - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection
Increment the number of delay runner counts.
incrDelayRunners() - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection.RunnerStats
 
increment(BigDecimal) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
increment(Double) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
increment(Long) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
increment(Increment) - 类 中的方法org.apache.hadoop.hbase.client.HTable
Increments one or more columns within a single row.
Increment - org.apache.hadoop.hbase.client中的类
Used to perform Increment operations on a single row.
Increment(byte[]) - 类 的构造器org.apache.hadoop.hbase.client.Increment
Create a Increment operation for the specified row.
Increment(byte[], int, int) - 类 的构造器org.apache.hadoop.hbase.client.Increment
Create a Increment operation for the specified row.
Increment(Increment) - 类 的构造器org.apache.hadoop.hbase.client.Increment
Copy constructor
increment(Increment) - 接口 中的方法org.apache.hadoop.hbase.client.Table
Increments one or more columns within a single row.
increment(S) - 类 中的方法org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
 
incrementColumnValue(byte[], byte[], byte[], long) - 类 中的方法org.apache.hadoop.hbase.client.HTable
incrementColumnValue(byte[], byte[], byte[], long, boolean) - 类 中的方法org.apache.hadoop.hbase.client.HTable
已过时。
As of release 0.96 (HBASE-9508). This will be removed in HBase 2.0.0. Use HTable.incrementColumnValue(byte[], byte[], byte[], long, Durability).
incrementColumnValue(byte[], byte[], byte[], long, Durability) - 类 中的方法org.apache.hadoop.hbase.client.HTable
Atomically increments a column value.
incrementColumnValue(byte[], byte[], byte[], long, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.HTableInterface
已过时。
As of release 0.96 (HBASE-9508). This will be removed in HBase 2.0.0. Use Table.incrementColumnValue(byte[], byte[], byte[], long, Durability).
incrementColumnValue(byte[], byte[], byte[], long) - 接口 中的方法org.apache.hadoop.hbase.client.Table
incrementColumnValue(byte[], byte[], byte[], long, Durability) - 接口 中的方法org.apache.hadoop.hbase.client.Table
Atomically increments a column value.
incrementTracker - 类 中的变量org.apache.hadoop.hbase.client.MetricsConnection
 
incrHedgedReadOps() - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection
Increment the number of hedged read that have occurred.
incrHedgedReadWin() - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection
Increment the number of hedged read returned faster than the original read.
incrMetaCacheHit() - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection
Increment the number of meta cache hits.
incrMetaCacheMiss() - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection
Increment the number of meta cache misses.
incrMetaCacheNumClearRegion() - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection
Increment the number of meta cache drops requested for individual region.
incrMetaCacheNumClearServer() - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection
Increment the number of meta cache drops requested for entire RegionServer.
incrNormalRunners() - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection
Increment the number of normal runner counts.
incrNormalRunners() - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection.RunnerStats
 
infoServerExists(Connection) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Checks whether hbase:meta contains any info:server entry.
init() - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeers
Initialize the ReplicationPeers interface.
init() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
init(String) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationQueues
Initialize the region server replication queue interface.
init() - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesClient
Initialize the replication queue client interface.
init() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesClientZKImpl
 
init(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
initialize(HBaseProtos.EmptyMsg) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
initialize(HBaseProtos.EmptyMsg) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
initialize(HBaseProtos.EmptyMsg) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
initialize(P) - 类 中的方法org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
This method should initialize any field(s) of the ColumnInterpreter with a parsing of the passed message bytes (used on the server side).
initSaslProperties(String) - 类 中的静态方法org.apache.hadoop.hbase.security.SaslUtil
 
initScanMetrics(Scan) - 类 中的方法org.apache.hadoop.hbase.client.AbstractClientScanner
Check and initialize if application wants to collect scan metrics
injectNonceGeneratorForTesting(ClusterConnection, NonceGenerator) - 类 中的静态方法org.apache.hadoop.hbase.client.ConnectionUtils
 
instance - 类 中的静态变量org.apache.hadoop.hbase.zookeeper.EmptyWatcher
 
instantiate(Configuration) - 类 中的静态方法org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
 
instantiate(Configuration, ServerStatisticTracker) - 类 中的静态方法org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
 
instantiate(Configuration, RetryingCallerInterceptor, ServerStatisticTracker) - 类 中的静态方法org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
 
instantiate(Configuration) - 类 中的静态方法org.apache.hadoop.hbase.ipc.RpcControllerFactory
 
instantiated - 类 中的变量org.apache.hadoop.hbase.client.ScannerCallable
 
interruptedException(InterruptedException) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Handles InterruptedExceptions in client calls.
interruptedExceptionNoThrow(InterruptedException, boolean) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Log the InterruptedException and interrupt current thread
INVALID_REGION_NAME_FORMAT_MESSAGE - 类 中的静态变量org.apache.hadoop.hbase.HRegionInfo
 
InvalidFamilyOperationException - org.apache.hadoop.hbase中的异常错误
Thrown if a request is table schema modification is requested but made for an invalid family name.
InvalidFamilyOperationException() - 异常错误 的构造器org.apache.hadoop.hbase.InvalidFamilyOperationException
default constructor
InvalidFamilyOperationException(String) - 异常错误 的构造器org.apache.hadoop.hbase.InvalidFamilyOperationException
Constructor
InvalidFamilyOperationException(Exception) - 异常错误 的构造器org.apache.hadoop.hbase.InvalidFamilyOperationException
Constructor taking another exception.
InvalidLabelException - org.apache.hadoop.hbase.security.visibility中的异常错误
 
InvalidLabelException(String) - 异常错误 的构造器org.apache.hadoop.hbase.security.visibility.InvalidLabelException
 
InvalidQuotaSettingsException - org.apache.hadoop.hbase.quotas中的异常错误
Generic quota exceeded exception for invalid settings
InvalidQuotaSettingsException(String) - 异常错误 的构造器org.apache.hadoop.hbase.quotas.InvalidQuotaSettingsException
 
InvalidRowFilterException - org.apache.hadoop.hbase.filter中的异常错误
Used to indicate an invalid RowFilter.
InvalidRowFilterException() - 异常错误 的构造器org.apache.hadoop.hbase.filter.InvalidRowFilterException
constructor
InvalidRowFilterException(String) - 异常错误 的构造器org.apache.hadoop.hbase.filter.InvalidRowFilterException
constructor
IPC_CLIENT_FALLBACK_TO_SIMPLE_AUTH_ALLOWED_DEFAULT - 接口 中的静态变量org.apache.hadoop.hbase.ipc.RpcClient
 
IPC_CLIENT_FALLBACK_TO_SIMPLE_AUTH_ALLOWED_KEY - 接口 中的静态变量org.apache.hadoop.hbase.ipc.RpcClient
 
IS_META - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Used by rest interface to access this metadata attribute which denotes if it is a catalog table, either hbase:meta or -ROOT-
IS_ROOT - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Used by rest interface to access this metadata attribute which denotes if the table is a -ROOT- region or not
isAborted() - 接口 中的方法org.apache.hadoop.hbase.Abortable
Check if the server or client was aborted.
isAborted() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
 
isAborted() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
isAborted() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
 
isAborted() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
isAccessControllerRunning(Connection) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlClient
 
isAccessControllerRunning(Configuration) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlClient
isAnyMetaReplicaZnode(String) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Is the znode of any meta replica
isAscendingOrder() - 类 中的方法org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
 
isAuthorizationEnabled(Connection) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlClient
Return true if authorization is supported and enabled
isAutoFlush() - 类 中的方法org.apache.hadoop.hbase.client.HTable
Tells whether or not 'auto-flush' is turned on.
isAutoFlush() - 接口 中的方法org.apache.hadoop.hbase.client.HTableInterface
已过时。
as of 1.0.0. Replaced by BufferedMutator
isBalancerEnabled() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Query the current state of the balancer
isBalancerEnabled() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Query the state of the balancer from the Master.
isBalancerOn() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
 
isBlockCacheEnabled() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
isCacheBloomsOnWrite() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
isCacheDataInL1() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
isCacheDataOnWrite() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
isCacheIndexesOnWrite() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
isCallDroppedException(Throwable) - 类 中的静态方法org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
Checks if the exception is CallDroppedException (maybe wrapped into some RemoteException).
isCallQueueTooBigException(Throwable) - 类 中的静态方法org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
Checks if the exception is CallQueueTooBig exception (maybe wrapped into some RemoteException).
isCanceled() - 类 中的方法org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
isCanceled() - 类 中的方法org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
isCanceled() - 类 中的方法org.apache.hadoop.hbase.ipc.ServerRpcController
 
isCancelled() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
isCancelled() - 类 中的方法org.apache.hadoop.hbase.client.PayloadCarryingServerCallable
 
isCatalogJanitorEnabled() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Query on the catalog janitor state (Enabled/Disabled?)
isCatalogJanitorEnabled() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Query on the catalog janitor state (Enabled/Disabled?)
isCellAuthorizationEnabled(Connection) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlClient
Return true if cell authorization is supported and enabled
isCellVisibilityEnabled(Connection) - 类 中的静态方法org.apache.hadoop.hbase.security.visibility.VisibilityClient
Return true if cell visibility features are supported and enabled
isCheckExistenceOnly() - 类 中的方法org.apache.hadoop.hbase.client.Get
 
isCleanerChoreEnabled() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Query on the cleaner chore state (Enabled/Disabled?)
isCleanerChoreEnabled() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
isClientReadable(String) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Returns whether the znode is supposed to be readable by the client and DOES NOT contain sensitive information (world readable).
isClosed() - 接口 中的方法org.apache.hadoop.hbase.client.Connection
Returns whether the connection is closed or not.
isClosed() - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
 
isClosed() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
 
isClosed(AdminProtos.CloseRegionResponse) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ResponseConverter
Check if the region is closed from a CloseRegionResponse
isClosestRowBefore() - 类 中的方法org.apache.hadoop.hbase.client.Get
 
isClosing() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
 
isCompactionEnabled() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Check if the compaction enable flag of the table is true.
isComplete() - 类 中的方法org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
 
isCompressTags() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
isConnectionException(Throwable) - 类 中的静态方法org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
Check if the exception is something that indicates that we cannot contact/communicate with the server.
isCursor() - 类 中的方法org.apache.hadoop.hbase.client.Result
Return true if this Result is a cursor to tell users where the server has scanned.
isDeadServer(ServerName) - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
已过时。
internal method, do not use thru HConnection
isDeadServer(ServerName) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
internal method, do not use thru HConnection
isDefaultMetaReplicaZnode(String) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Is it the default meta replica's znode
isDefaultReplica(int) - 类 中的静态方法org.apache.hadoop.hbase.client.RegionReplicaUtil
 
isDefaultReplica(HRegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.client.RegionReplicaUtil
 
isDisabledTable(ZooKeeperWatcher, TableName) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKTableStateClientSideReader
Go to zookeeper and see if state of table is ZooKeeperProtos.Table.State#DISABLED.
isDisablingOrDisabledTable(ZooKeeperWatcher, TableName) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKTableStateClientSideReader
Go to zookeeper and see if state of table is ZooKeeperProtos.Table.State#DISABLING of ZooKeeperProtos.Table.State#DISABLED.
isDone() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
isDoNotRetry() - 异常错误 中的方法org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
 
isEmpty() - 类 中的方法org.apache.hadoop.hbase.client.Mutation
Method to check if the familyMap is empty
isEmpty() - 类 中的方法org.apache.hadoop.hbase.client.Result
Check if the underlying Cell [] is empty or not
isEmpty() - 类 中的方法org.apache.hadoop.hbase.filter.FilterListBase
 
isEmpty() - 类 中的方法org.apache.hadoop.hbase.RegionLocations
Returns whether there are non-null elements in the list
isEmpty() - 类 中的方法org.apache.hadoop.hbase.util.PoolMap
 
isEmpty() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData
已过时。
 
isEmptyQuota(QuotaProtos.Quotas) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
isEnabledTable(ZooKeeperWatcher, TableName) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKTableStateClientSideReader
Go to zookeeper and see if state of table is ZooKeeperProtos.Table.State#ENABLED.
isEvictBlocksOnClose() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
isFailedClose() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
 
isFailedOpen() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
 
isFailedServer(InetSocketAddress) - 类 中的方法org.apache.hadoop.hbase.ipc.FailedServers
Check if the server should be considered as bad.
isFamilyEssential(byte[]) - 类 中的方法org.apache.hadoop.hbase.filter.Filter
Check that given column family is essential for filter to check row.
isFamilyEssential(byte[]) - 类 中的方法org.apache.hadoop.hbase.filter.FilterBase
By default, we require all scan's column families to be present.
isFamilyEssential(byte[]) - 类 中的方法org.apache.hadoop.hbase.filter.FilterList
 
isFamilyEssential(byte[]) - 类 中的方法org.apache.hadoop.hbase.filter.FilterListBase
 
isFamilyEssential(byte[]) - 类 中的方法org.apache.hadoop.hbase.filter.FilterWrapper
 
isFamilyEssential(byte[]) - 类 中的方法org.apache.hadoop.hbase.filter.SingleColumnValueFilter
The only CF this filter needs is given column family.
isFamilyEssential(byte[]) - 类 中的方法org.apache.hadoop.hbase.filter.SkipFilter
 
isFamilyEssential(byte[]) - 类 中的方法org.apache.hadoop.hbase.filter.WhileMatchFilter
 
isFullServerName(String) - 类 中的静态方法org.apache.hadoop.hbase.ServerName
 
isGetScan() - 类 中的方法org.apache.hadoop.hbase.client.Scan
 
isGlobal() - 类 中的方法org.apache.hadoop.hbase.security.access.UserPermission
Returns true if this permission describes a global user permission.
isGuaranteedClientSideOnly() - 异常错误 中的方法org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
 
isInMemory() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
isInReturnCodes(Filter.ReturnCode, Filter.ReturnCode...) - 类 中的静态方法org.apache.hadoop.hbase.filter.FilterListBase
 
isLegalFamilyName(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.HColumnDescriptor
 
isLocationAvailable(ZooKeeperWatcher) - 类 中的方法org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Checks if the meta region location is available.
isManaged() - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
 
isMasterInMaintenanceMode() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Check whether Master is in maintenance mode
isMasterInMaintenanceMode() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
isMasterRunning() - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
已过时。
this has been deprecated without a replacement
isMasterRunning() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
已过时。
this has been deprecated without a replacement
isMasterRunning() - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
internal method, do not use thru HConnection
isMaxColumnInclusive() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
isMerged() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
 
isMerging() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
 
isMergingNew() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
 
isMetaClearingException(Throwable) - 类 中的静态方法org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
 
isMetaRegion() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
 
isMetaRegion() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Checks if this table is hbase:meta region.
isMetaTable() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
 
isMetaTable() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Checks if the table is a hbase:meta table
isMinColumnInclusive() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
isNamespaceRowKey(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
isNeedCursorResult() - 类 中的方法org.apache.hadoop.hbase.client.Scan
 
isNormalizationEnabled() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Check if normalization enable flag of the table is true.
isNormalizerEnabled() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Query the current state of the region normalizer
isNormalizerEnabled() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Query the current state of the region normalizer
isNull() - 类 中的方法org.apache.hadoop.hbase.quotas.QuotaFilter
 
isOffline() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
 
isOffline() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
 
IsolationLevel - org.apache.hadoop.hbase.client中的枚举
Specify Isolation levels in Scan operations.
isOnlineSchemaChangeSupported() - 枚举 中的方法org.apache.hadoop.hbase.executor.EventType
 
isOnServer(ServerName) - 类 中的方法org.apache.hadoop.hbase.master.RegionState
 
isOpened() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
 
isOpening() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
 
isOpenOrMergingNewOnServer(ServerName) - 类 中的方法org.apache.hadoop.hbase.master.RegionState
 
isOpenOrMergingOnServer(ServerName) - 类 中的方法org.apache.hadoop.hbase.master.RegionState
 
isOpenOrSplittingNewOnServer(ServerName) - 类 中的方法org.apache.hadoop.hbase.master.RegionState
 
isOpenOrSplittingOnServer(ServerName) - 类 中的方法org.apache.hadoop.hbase.master.RegionState
 
isPartial() - 类 中的方法org.apache.hadoop.hbase.client.Result
已过时。
the word 'partial' ambiguous, use Result.mayHaveMoreCellsInRow() instead. Deprecated since 1.4.0.
isPBMagicPrefix(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
isPBMagicPrefix(byte[], int, int) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
isPeerPath(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationStateZKBase
Determine if a ZK path points to a peer node.
isPendingClose() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
 
isPendingCloseOrClosing() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
 
isPendingCloseOrClosingOnServer(ServerName) - 类 中的方法org.apache.hadoop.hbase.master.RegionState
 
isPendingOpen() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
 
isPendingOpenOrOpening() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
 
isPendingOpenOrOpeningOnServer(ServerName) - 类 中的方法org.apache.hadoop.hbase.master.RegionState
 
isPrefetchBlocksOnOpen() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
isProcedureFinished(String, String, Map<String, String>) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Check the current state of the specified procedure.
isProcedureFinished(String, String, Map<String, String>) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Check the current state of the specified procedure.
isQueueRecovered() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationQueueInfo
 
isQuoteUnescaped(byte[], int) - 类 中的静态方法org.apache.hadoop.hbase.filter.ParseFilter
Returns a boolean indicating whether the quote was escaped or not
isRaw() - 类 中的方法org.apache.hadoop.hbase.client.Scan
 
isReadOnly() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Check if the readOnly flag of the table is set.
isReadyToOffline() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
Check if a region state can transition to offline
isReadyToOnline() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
Check if a region state can transition to online
isRegionCached(TableName, byte[]) - 类 中的方法org.apache.hadoop.hbase.client.MetaCache
Check the region cache to see whether a region is cached yet or not.
isRegionServerRemote - 类 中的变量org.apache.hadoop.hbase.client.ScannerCallable
 
isReplicasForSameRegion(HRegionInfo, HRegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.client.RegionReplicaUtil
 
isReturnResults() - 类 中的方法org.apache.hadoop.hbase.client.Append
 
isReturnResults() - 类 中的方法org.apache.hadoop.hbase.client.Increment
 
isReturnResults() - 类 中的方法org.apache.hadoop.hbase.client.Mutation
 
isReversed() - 类 中的方法org.apache.hadoop.hbase.client.Scan
Get whether this scan is a reversed one.
isReversed() - 类 中的方法org.apache.hadoop.hbase.filter.Filter
 
isReversed() - 类 中的方法org.apache.hadoop.hbase.filter.FilterList
 
isRootRegion() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Check if the descriptor represents a -ROOT- region.
isSameAddress(ServerName, ServerName) - 类 中的静态方法org.apache.hadoop.hbase.ServerName
 
isSameHostnameAndPort(ServerName, ServerName) - 类 中的静态方法org.apache.hadoop.hbase.ServerName
 
isScanMetricsEnabled() - 类 中的方法org.apache.hadoop.hbase.client.Scan
 
isSearchRowInclusive() - 类 中的方法org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
 
isSecureZooKeeper(Configuration) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Returns whether or not secure authentication is enabled (whether hbase.security.authentication is set to kerberos.
isSmall() - 类 中的方法org.apache.hadoop.hbase.client.Scan
Get whether this scan is a small scan
isSnapshotFinished(HBaseProtos.SnapshotDescription) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
已过时。
isSnapshotFinished(HBaseProtos.SnapshotDescription) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Check the current state of the passed snapshot.
isSpecialException(Throwable) - 类 中的静态方法org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
 
isSplit() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
 
isSplit() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
 
isSplitOrMergeEnabled(Admin.MasterSwitchType) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Query the current state of the switch
isSplitOrMergeEnabled(Admin.MasterSwitchType) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
isSplitParent() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
 
isSplitting() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
 
isSplittingNew() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
 
isStale() - 类 中的方法org.apache.hadoop.hbase.client.Result
Whether or not the results are coming from possibly stale data.
isStateEnabled(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
Parse the raw data from ZK to get a peer's state
issueDate - 类 中的变量org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
isSuperUserId(String[], Id) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
isSystemTable() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
 
isTableAvailable(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
 
isTableAvailable(TableName, byte[][]) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Use this api to check if the table has been created with the specified number of splitkeys which was used while creating the given table.
isTableAvailable(TableName, byte[][]) - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
Use this api to check if the table has been created with the specified number of splitkeys which was used while creating the given table.
isTableAvailable(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableAvailable(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableAvailable(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableAvailable(TableName, byte[][]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Use this api to check if the table has been created with the specified number of splitkeys which was used while creating the given table.
isTableAvailable(byte[], byte[][]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableAvailable(String, byte[][]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableAvailable(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
 
isTableAvailable(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
isTableAvailable(TableName, byte[][]) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
internal method, do not use thru HConnection
isTableAvailable(byte[], byte[][]) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
isTableDisabled(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
 
isTableDisabled(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableDisabled(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableDisabled(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableDisabled(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
 
isTableDisabled(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
isTableEnabled(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
 
isTableEnabled(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableEnabled(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableEnabled(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableEnabled(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
A table that isTableEnabled == false and isTableDisabled == false is possible.
isTableEnabled(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
isTableEnabled(String) - 类 中的静态方法org.apache.hadoop.hbase.client.HTable
isTableEnabled(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.client.HTable
isTableEnabled(TableName) - 类 中的静态方法org.apache.hadoop.hbase.client.HTable
isTableEnabled(Configuration, String) - 类 中的静态方法org.apache.hadoop.hbase.client.HTable
isTableEnabled(Configuration, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.client.HTable
isTableEnabled(Configuration, TableName) - 类 中的静态方法org.apache.hadoop.hbase.client.HTable
isTableRowKey(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
isThisOurRegionServer(String) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationQueues
Checks if the provided znode is the same as this region server's
isThisOurRegionServer(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
isThisOurZnode(String) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationQueues
Checks if the provided znode is the same as this region server's
isThisOurZnode(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
isUnassignable() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
Check if a region state is one of offline states that can't transition to pending_close/closing (unassign/offline)
isUnassignable(RegionState.State) - 类 中的静态方法org.apache.hadoop.hbase.master.RegionState
Check if a region state is one of offline states that can't transition to pending_close/closing (unassign/offline)
isUserRowKey(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
isValidLabel(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.security.visibility.VisibilityLabelsValidator
 
iterator() - 类 中的方法org.apache.hadoop.hbase.client.AbstractClientScanner
 
iterator() - 类 中的方法org.apache.hadoop.hbase.quotas.QuotaRetriever
 

J

joinZNode(String, String) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Join the prefix znode name with the suffix znode name to generate a proper full znode name.
JsonMapper - org.apache.hadoop.hbase.util中的类
Utility class for converting objects to JSON

K

K - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'K'
KEEP_DELETED_CELLS - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
 
KeepDeletedCells - org.apache.hadoop.hbase中的枚举
Ways to keep cells marked for delete around.
keeperException(KeeperException) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Handles KeeperExceptions in client calls.
keyId - 类 中的变量org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
KeyOnlyFilter - org.apache.hadoop.hbase.filter中的类
A filter that will only return the key component of each KV (the value will be rewritten as empty).
KeyOnlyFilter() - 类 的构造器org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
KeyOnlyFilter(boolean) - 类 的构造器org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
keySet() - 类 中的方法org.apache.hadoop.hbase.util.PoolMap
 

L

L - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'L'
LABEL_QUALIFIER - 类 中的静态变量org.apache.hadoop.hbase.security.visibility.VisibilityConstants
Qualifier for the internal storage table for visibility labels
LabelAlreadyExistsException - org.apache.hadoop.hbase.security.visibility中的异常错误
 
LabelAlreadyExistsException(String) - 异常错误 的构造器org.apache.hadoop.hbase.security.visibility.LabelAlreadyExistsException
 
LABELS_TABLE_FAMILY - 类 中的静态变量org.apache.hadoop.hbase.security.visibility.VisibilityConstants
Family for the internal storage table for visibility labels
LABELS_TABLE_NAME - 类 中的静态变量org.apache.hadoop.hbase.security.visibility.VisibilityConstants
Internal storage table for visibility labels
lastNext - 类 中的变量org.apache.hadoop.hbase.client.ClientScanner
 
lastResult - 类 中的变量org.apache.hadoop.hbase.client.ClientScanner
 
latestVersionOnly - 类 中的变量org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
LeaseException - org.apache.hadoop.hbase.regionserver中的异常错误
Reports a problem with a lease
LeaseException() - 异常错误 的构造器org.apache.hadoop.hbase.regionserver.LeaseException
default constructor
LeaseException(String) - 异常错误 的构造器org.apache.hadoop.hbase.regionserver.LeaseException
 
LENGTH - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
 
lengthOfPBMagic() - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
LESS_THAN_ARRAY - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
LESS_THAN Array
LESS_THAN_BUFFER - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
 
LESS_THAN_OR_EQUAL_TO_ARRAY - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
LESS_THAN_OR_EQUAL_TO Array
LESS_THAN_OR_EQUAL_TO_BUFFER - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
 
list() - 类 中的方法org.apache.hadoop.hbase.client.Result
已过时。
as of 0.96, use Result.listCells()
listAllRegions(Configuration, Connection, boolean) - 类 中的静态方法org.apache.hadoop.hbase.client.MetaScanner
Lists all of the regions currently in META.
listCells() - 类 中的方法org.apache.hadoop.hbase.client.Result
Create a sorted list of the Cell's in this result.
listChildrenAndWatchForNewChildren(ZooKeeperWatcher, String) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Lists the children znodes of the specified znode.
listChildrenAndWatchThem(ZooKeeperWatcher, String) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
List all the children of the specified znode, setting a watch for children changes and also setting a watch on every individual child in order to get the NodeCreated and NodeDeleted events.
listChildrenNoWatch(ZooKeeperWatcher, String) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Lists the children of the specified znode without setting any watches.
listDeadServers() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
List dead region servers.
listDeadServers() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
listener(BufferedMutator.ExceptionListener) - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorParams
Override the default error handler.
listLabels(Configuration, String) - 类 中的静态方法org.apache.hadoop.hbase.security.visibility.VisibilityClient
listLabels(Connection, String) - 类 中的静态方法org.apache.hadoop.hbase.security.visibility.VisibilityClient
Retrieve the list of visibility labels defined in the system.
listNamespaceDescriptors() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
List available namespace descriptors
listNamespaceDescriptors() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
List available namespace descriptors
listPeerConfigs() - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
 
listPeers() - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
listProcedures() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
List procedures
listProcedures() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
List procedures
listReplicated() - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Find all column families that are replicated from this cluster
listSnapshots() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
已过时。
listSnapshots(String) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
已过时。
listSnapshots(Pattern) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
已过时。
listSnapshots() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
List completed snapshots.
listSnapshots(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
List all the completed snapshots matching the given regular expression.
listSnapshots(Pattern) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
List all the completed snapshots matching the given pattern.
listTableDescriptorsByNamespace(String) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Get list of table descriptors by namespace
listTableDescriptorsByNamespace(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Get list of table descriptors by namespace
listTableNames() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
List all of the names of userspace tables.
listTableNames(Pattern) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
List all of the names of userspace tables.
listTableNames(String) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
List all of the names of userspace tables.
listTableNames(Pattern, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
List all of the names of userspace tables.
listTableNames(String, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
List all of the names of userspace tables.
listTableNames() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
listTableNames(Pattern) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
listTableNames(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
listTableNames(Pattern, boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
listTableNames(String, boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
listTableNames() - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
Use Admin.listTables() instead.
listTableNamesByNamespace(String) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Get list of table names by namespace
listTableNamesByNamespace(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Get list of table names by namespace
listTableRegionLocations(Configuration, Connection, TableName) - 类 中的静态方法org.apache.hadoop.hbase.client.MetaScanner
Lists table regions and locations grouped by region range from META.
listTables() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
List all the userspace tables.
listTables(Pattern) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
List all the userspace tables matching the given pattern.
listTables(String) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
List all the userspace tables matching the given regular expression.
listTables(Pattern, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
List all the tables matching the given pattern.
listTables(String, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
List all the tables matching the given pattern.
listTables() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
listTables(Pattern) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
listTables(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
listTables(Pattern, boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
listTables(String, boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
listTables() - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
Use Admin.listTables() instead.
listTableSnapshots(String, String) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
已过时。
listTableSnapshots(Pattern, Pattern) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
已过时。
listTableSnapshots(String, String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
List all the completed snapshots matching the given table name regular expression and snapshot name regular expression.
listTableSnapshots(Pattern, Pattern) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
List all the completed snapshots matching the given table name regular expression and snapshot name regular expression.
loadCache() - 类 中的方法org.apache.hadoop.hbase.client.ClientScanner
Contact the servers to load more Results in the cache.
loadColumnFamiliesOnDemand - 类 中的变量org.apache.hadoop.hbase.client.Query
 
loadResultsToCache(Result[], boolean) - 类 中的方法org.apache.hadoop.hbase.client.BatchScanResultCache
 
loadValue(byte[], byte[], ByteBuffer) - 类 中的方法org.apache.hadoop.hbase.client.Result
Loads the latest version of the specified column into the provided ByteBuffer.
loadValue(byte[], int, int, byte[], int, int, ByteBuffer) - 类 中的方法org.apache.hadoop.hbase.client.Result
Loads the latest version of the specified column into the provided ByteBuffer.
localAddr - 类 中的变量org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
locateRegion(TableName, byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
Find the location of the region of tableName that row lives in.
locateRegion(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
Gets the location of the region of regionName.
locateRegion(TableName, byte[], boolean, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
 
locateRegion(TableName, byte[], boolean, boolean, int) - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
 
locateRegion(TableName, byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
internal method, do not use thru HConnection
locateRegion(byte[], byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
locateRegion(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
internal method, do not use thru HConnection
locateRegions(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
Gets the locations of all regions in the specified table, tableName.
locateRegions(TableName, boolean, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
Gets the locations of all regions in the specified table, tableName.
locateRegions(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
internal method, do not use thru HConnection
locateRegions(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
locateRegions(TableName, boolean, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
internal method, do not use thru HConnection
locateRegions(byte[], boolean, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
location - 类 中的变量org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
location - 类 中的变量org.apache.hadoop.hbase.client.RegionServerCallable
 
lockOtherRS(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
Try to set a lock in another region server's znode.
LockTimeoutException - org.apache.hadoop.hbase.exceptions中的异常错误
Thrown when there is a timeout when trying to acquire a lock
LockTimeoutException() - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.LockTimeoutException
Default constructor
LockTimeoutException(String) - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.LockTimeoutException
 
LOG - 类 中的静态变量org.apache.hadoop.hbase.client.RpcRetryingCaller
 
LOG - 类 中的静态变量org.apache.hadoop.hbase.client.ScannerCallable
 
LOG - 类 中的静态变量org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
LOG - 类 中的静态变量org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
 
LOG_SCANNER_ACTIVITY - 类 中的静态变量org.apache.hadoop.hbase.client.ScannerCallable
 
LOG_SCANNER_LATENCY_CUTOFF - 类 中的静态变量org.apache.hadoop.hbase.client.ScannerCallable
 
loginClient(Configuration, String, String, String) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Log in the current zookeeper client using the given configuration keys for the credential file and login principal.
loginServer(Configuration, String, String, String) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Log in the current zookeeper server process using the given configuration keys for the credential file and login principal.
logZKTree(ZooKeeperWatcher, String) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Recursively print the current state of ZK (non-transactional)
logZKTree(ZooKeeperWatcher, String, String) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Helper method to print the current state of the ZK tree.
LongColumnInterpreter - org.apache.hadoop.hbase.client.coprocessor中的类
a concrete column interpreter implementation.
LongColumnInterpreter() - 类 的构造器org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
LongComparator - org.apache.hadoop.hbase.filter中的类
A long comparator which numerical compares against the specified byte array
LongComparator(long) - 类 的构造器org.apache.hadoop.hbase.filter.LongComparator
 
LPAREN - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for LPAREN
LPAREN_ARRAY - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
LPAREN Array
LPAREN_BUFFER - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
 

M

main(String[]) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.HQuorumPeer
Parse ZooKeeper configuration from HBase XML config and run a QuorumPeer.
main(String[]) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZkAclReset
 
MAJOR_VERSION - 异常错误 中的静态变量org.apache.hadoop.hbase.exceptions.RequestTooBigException
 
majorCompact(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Major compact a table.
majorCompact(TableName, byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Major compact a column family within a table.
majorCompact(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Major compact a table.
majorCompact(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
majorCompact(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
majorCompact(TableName, byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Major compact a column family within a table.
majorCompact(String, String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
majorCompact(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
majorCompactRegion(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Major compact a table or an individual region.
majorCompactRegion(byte[], byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Major compact a column family within region.
majorCompactRegion(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Major compact a table or an individual region.
majorCompactRegion(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Major compact a column family within region.
makeDeleteFromRegionInfo(HRegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Generates and returns a Delete containing the region info for the catalog table
makeDeleteFromRegionInfo(HRegionInfo, long) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Generates and returns a Delete containing the region info for the catalog table
makeFilter(QuotaFilter) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
converts quotafilter to serializeable filterlists.
makeGetForNamespaceQuotas(String) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
makeGetForTableQuotas(TableName) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
makeGetForUserQuotas(String, Iterable<TableName>, Iterable<String>) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
makePutFromRegionInfo(HRegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Generates and returns a Put containing the region into for the catalog table
makePutFromRegionInfo(HRegionInfo, long) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Generates and returns a Put containing the region into for the catalog table
makeScan(QuotaFilter) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
MasterAddressTracker - org.apache.hadoop.hbase.zookeeper中的类
Manages the location of the current active Master for the RegionServer.
MasterAddressTracker(ZooKeeperWatcher, Abortable) - 类 的构造器org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
Construct a master address listener with the specified zookeeper reference.
MasterCoprocessorRpcChannel - org.apache.hadoop.hbase.ipc中的类
Provides clients with an RPC connection to call coprocessor endpoint Services against the active master.
MasterCoprocessorRpcChannel(ClusterConnection) - 类 的构造器org.apache.hadoop.hbase.ipc.MasterCoprocessorRpcChannel
 
masterMaintZNode - 类 中的静态变量org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
MasterNotRunningException - org.apache.hadoop.hbase中的异常错误
Thrown if the master is not running
MasterNotRunningException() - 异常错误 的构造器org.apache.hadoop.hbase.MasterNotRunningException
default constructor
MasterNotRunningException(String) - 异常错误 的构造器org.apache.hadoop.hbase.MasterNotRunningException
Constructor
MasterNotRunningException(Exception) - 异常错误 的构造器org.apache.hadoop.hbase.MasterNotRunningException
Constructor taking another exception.
MasterNotRunningException(String, Exception) - 异常错误 的构造器org.apache.hadoop.hbase.MasterNotRunningException
 
matchedColumn - 类 中的变量org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
matches(String) - 枚举 中的方法org.apache.hadoop.hbase.security.SaslUtil.QualityOfProtection
 
matchesFamily(TableName, byte[], Permission.Action) - 类 中的方法org.apache.hadoop.hbase.security.access.TablePermission
Returns true if this permission matches the given column family at least.
matchesFamilyQualifier(TableName, byte[], byte[], Permission.Action) - 类 中的方法org.apache.hadoop.hbase.security.access.TablePermission
Returns if the given permission matches the given qualifier.
max(TableName, ColumnInterpreter<R, S, P, Q, T>, Scan) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.AggregationClient
It gives the maximum value of a column for a given column family for the given range.
max(Table, ColumnInterpreter<R, S, P, Q, T>, Scan) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.AggregationClient
It gives the maximum value of a column for a given column family for the given range.
MAX_BACKOFF_KEY - 类 中的静态变量org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
 
MAX_CACHED_CONNECTION_INSTANCES - 类 中的静态变量org.apache.hadoop.hbase.client.HConnectionManager
已过时。
MAX_FILESIZE - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Used by HBase Shell interface to access this metadata attribute which denotes the maximum size of the store file after which a region split occurs
MAX_KEYVALUE_SIZE_DEFAULT - 类 中的静态变量org.apache.hadoop.hbase.client.ConnectionConfiguration
 
MAX_KEYVALUE_SIZE_KEY - 类 中的静态变量org.apache.hadoop.hbase.client.ConnectionConfiguration
 
maxColumn - 类 中的变量org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
maxColumnInclusive - 类 中的变量org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
maxKeyValueSize(int) - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorParams
Override the maximum key-value size specified by the provided Connection's Configuration instance, via the configuration key hbase.client.keyvalue.maxsize.
maxRetries - 类 中的变量org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
maxScannerResultSize - 类 中的变量org.apache.hadoop.hbase.client.ClientScanner
 
mayHaveClusterIssues() - 异常错误 中的方法org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
mayHaveMoreCellsInRow() - 类 中的方法org.apache.hadoop.hbase.client.Result
For scanning large rows, the RS may choose to return the cells chunk by chunk to prevent OOM or timeout.
MD5_HEX_LENGTH - 类 中的静态变量org.apache.hadoop.hbase.HRegionInfo
 
mechanismName - 枚举 中的变量org.apache.hadoop.hbase.security.AuthMethod
 
median(TableName, ColumnInterpreter<R, S, P, Q, T>, Scan) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.AggregationClient
This is the client side interface/handler for calling the median method for a given cf-cq combination.
median(Table, ColumnInterpreter<R, S, P, Q, T>, Scan) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.AggregationClient
This is the client side interface/handler for calling the median method for a given cf-cq combination.
MEMSTORE_FLUSHSIZE - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Used by HBase Shell interface to access this metadata attribute which represents the maximum size of the memstore after which its contents are flushed onto the disk
mergeDelimitedFrom(Message.Builder, InputStream) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
This version of protobuf's mergeDelimitedFrom avoids the hard-coded 64MB limit for decoding buffers
mergeFrom(Message.Builder, InputStream, int) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
This version of protobuf's mergeFrom avoids the hard-coded 64MB limit for decoding buffers where the message size is known
mergeFrom(Message.Builder, InputStream) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
This version of protobuf's mergeFrom avoids the hard-coded 64MB limit for decoding buffers where the message size is not known
mergeFrom(Message.Builder, ByteString) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
This version of protobuf's mergeFrom avoids the hard-coded 64MB limit for decoding buffers when working with ByteStrings
mergeFrom(Message.Builder, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
This version of protobuf's mergeFrom avoids the hard-coded 64MB limit for decoding buffers when working with byte arrays
mergeFrom(Message.Builder, byte[], int, int) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
This version of protobuf's mergeFrom avoids the hard-coded 64MB limit for decoding buffers when working with byte arrays
mergeFrom(Message.Builder, CodedInputStream, int) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
mergeLocations(RegionLocations) - 类 中的方法org.apache.hadoop.hbase.RegionLocations
Merges this RegionLocations list with the given list assuming same range, and keeping the most up to date version of the HRegionLocation entries from either list according to seqNum.
MergeRegionException - org.apache.hadoop.hbase.exceptions中的异常错误
Thrown when something is wrong in trying to merge two regions.
MergeRegionException() - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.MergeRegionException
default constructor
MergeRegionException(String) - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.MergeRegionException
Constructor
mergeRegions(byte[], byte[], boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Merge two regions.
mergeRegions(byte[], byte[], boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Merge two regions.
mergeRegions(Connection, HRegionInfo, HRegionInfo, HRegionInfo, ServerName, int, long) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Merge the two regions into one in an atomic operation.
mergeRegions(RpcController, AdminProtos.AdminService.BlockingInterface, HRegionInfo, HRegionInfo, boolean, User) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to merge regions using admin protocol.
META_REPLICA_ID_DELIMITER - 类 中的静态变量org.apache.hadoop.hbase.MetaTableAccessor
The delimiter for meta columns for replicaIds > 0
META_TABLEDESC - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
已过时。
Use TableDescriptors#get(TableName.META_TABLE_NAME) or HBaseAdmin#getTableDescriptor(TableName.META_TABLE_NAME) instead.
META_ZNODE_PREFIX - 类 中的静态变量org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
MetaCache - org.apache.hadoop.hbase.client中的类
A cache implementation for region locations from meta.
MetaCache(MetricsConnection) - 类 的构造器org.apache.hadoop.hbase.client.MetaCache
 
metaCacheHits - 类 中的变量org.apache.hadoop.hbase.client.MetricsConnection
 
metaCacheMisses - 类 中的变量org.apache.hadoop.hbase.client.MetricsConnection
 
metaCacheNumClearRegion - 类 中的变量org.apache.hadoop.hbase.client.MetricsConnection
 
metaCacheNumClearServer - 类 中的变量org.apache.hadoop.hbase.client.MetricsConnection
 
metaScan(Connection, MetaScanner.MetaScannerVisitor) - 类 中的静态方法org.apache.hadoop.hbase.client.MetaScanner
Scans the meta table and calls a visitor on each RowResult and uses a empty start row value as table name.
metaScan(Connection, MetaScanner.MetaScannerVisitor, TableName) - 类 中的静态方法org.apache.hadoop.hbase.client.MetaScanner
Scans the meta table and calls a visitor on each RowResult.
metaScan(Connection, MetaScanner.MetaScannerVisitor, TableName, byte[], int) - 类 中的静态方法org.apache.hadoop.hbase.client.MetaScanner
Scans the meta table and calls a visitor on each RowResult.
MetaScanner - org.apache.hadoop.hbase.client中的类
Scanner class that contains the hbase:meta table scanning logic.
MetaScanner() - 类 的构造器org.apache.hadoop.hbase.client.MetaScanner
 
MetaScanner.DefaultMetaScannerVisitor - org.apache.hadoop.hbase.client中的类
A MetaScannerVisitor that skips offline regions and split parents
MetaScanner.DefaultMetaScannerVisitor() - 类 的构造器org.apache.hadoop.hbase.client.MetaScanner.DefaultMetaScannerVisitor
 
MetaScanner.MetaScannerVisitor - org.apache.hadoop.hbase.client中的接口
Visitor class called to process each row of the hbase:meta table
MetaScanner.MetaScannerVisitorBase - org.apache.hadoop.hbase.client中的类
 
MetaScanner.MetaScannerVisitorBase() - 类 的构造器org.apache.hadoop.hbase.client.MetaScanner.MetaScannerVisitorBase
 
MetaScanner.TableMetaScannerVisitor - org.apache.hadoop.hbase.client中的类
A MetaScannerVisitor for a table.
MetaScanner.TableMetaScannerVisitor(TableName) - 类 的构造器org.apache.hadoop.hbase.client.MetaScanner.TableMetaScannerVisitor
 
MetaTableAccessor - org.apache.hadoop.hbase中的类
Read/write operations on region and assignment information store in hbase:meta.
MetaTableAccessor() - 类 的构造器org.apache.hadoop.hbase.MetaTableAccessor
 
MetaTableAccessor.Visitor - org.apache.hadoop.hbase中的接口
Implementations 'visit' a catalog table row.
metaTableDescriptor(Configuration) - 类 中的静态方法org.apache.hadoop.hbase.HTableDescriptor
 
MetaTableLocator - org.apache.hadoop.hbase.zookeeper中的类
Utility class to perform operation (get/wait for/verify/set/delete) on znode in ZooKeeper which keeps hbase:meta region server location.
MetaTableLocator() - 类 的构造器org.apache.hadoop.hbase.zookeeper.MetaTableLocator
 
metrics - 类 中的变量org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
MetricsConnection - org.apache.hadoop.hbase.client中的类
This class is for maintaining the various connection statistics and publishing them through the metrics interfaces.
MetricsConnection(ConnectionManager.HConnectionImplementation) - 类 的构造器org.apache.hadoop.hbase.client.MetricsConnection
 
MetricsConnection.CallStats - org.apache.hadoop.hbase.client中的类
A container class for collecting details about the RPC call as it percolates.
MetricsConnection.CallStats() - 类 的构造器org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
MetricsConnection.CallTracker - org.apache.hadoop.hbase.client中的类
 
MetricsConnection.RegionStats - org.apache.hadoop.hbase.client中的类
 
MetricsConnection.RegionStats(MetricsRegistry, String) - 类 的构造器org.apache.hadoop.hbase.client.MetricsConnection.RegionStats
 
MetricsConnection.RunnerStats - org.apache.hadoop.hbase.client中的类
 
MetricsConnection.RunnerStats(MetricsRegistry) - 类 的构造器org.apache.hadoop.hbase.client.MetricsConnection.RunnerStats
 
MILLIS_BETWEEN_NEXTS_METRIC_NAME - 类 中的静态变量org.apache.hadoop.hbase.client.metrics.ScanMetrics
 
min(TableName, ColumnInterpreter<R, S, P, Q, T>, Scan) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.AggregationClient
It gives the minimum value of a column for a given column family for the given range.
min(Table, ColumnInterpreter<R, S, P, Q, T>, Scan) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.AggregationClient
It gives the minimum value of a column for a given column family for the given range.
MIN_VERSIONS - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
 
minColumn - 类 中的变量org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
minColumnInclusive - 类 中的变量org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
minIdleTimeBeforeClose - 类 中的变量org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
MINOR_VERSION - 异常错误 中的静态变量org.apache.hadoop.hbase.exceptions.RequestTooBigException
 
MINUS_SIGN - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
ASCII for Minus Sign
modifyColumn(TableName, HColumnDescriptor) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Modify an existing column family on a table.
modifyColumn(String, HColumnDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Modify an existing column family on a table.
modifyColumn(byte[], HColumnDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Modify an existing column family on a table.
modifyColumn(TableName, HColumnDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Modify an existing column family on a table.
modifyFamily(HColumnDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
 
modifyFamily(HColumnDescriptor) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Modifies the existing column family.
modifyNamespace(NamespaceDescriptor) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Modify an existing namespace
modifyNamespace(NamespaceDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Modify an existing namespace
modifyTable(TableName, HTableDescriptor) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Modify an existing table, more IRB friendly version.
modifyTable(TableName, HTableDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Modify an existing table, more IRB friendly version.
modifyTable(byte[], HTableDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
modifyTable(String, HTableDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
move(byte[], byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Move the region r to dest.
move(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Move the region r to dest.
moveToNextRegion() - 类 中的方法org.apache.hadoop.hbase.client.ClientScanner
Close the previous scanner and create a new ScannerCallable for the next scanner.
multi(Iterable<Op>) - 类 中的方法org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
Run multiple operations in a transactional manner.
MultiAction<R> - org.apache.hadoop.hbase.client中的类
Container for Actions (i.e.
MultiAction() - 类 的构造器org.apache.hadoop.hbase.client.MultiAction
 
MultiActionResultTooLarge - org.apache.hadoop.hbase中的异常错误
Exception thrown when the result needs to be chunked on the server side.
MultiActionResultTooLarge(String) - 异常错误 的构造器org.apache.hadoop.hbase.MultiActionResultTooLarge
 
multiAp - 类 中的变量org.apache.hadoop.hbase.client.HTable
The Async process for batch
multiOrSequential(ZooKeeperWatcher, List<ZKUtil.ZKUtilOp>, boolean) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
If hbase.zookeeper.useMulti is true, use ZooKeeper's multi-update functionality.
MultipleColumnPrefixFilter - org.apache.hadoop.hbase.filter中的类
This filter is used for selecting only those keys with columns that matches a particular prefix.
MultipleColumnPrefixFilter(byte[][]) - 类 的构造器org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
multiply(BigDecimal, BigDecimal) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
multiply(Double, Double) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
multiply(Long, Long) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
multiply(S, S) - 类 中的方法org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
 
MultiResponse - org.apache.hadoop.hbase.client中的类
A container for Result objects, grouped by regionName.
MultiResponse() - 类 的构造器org.apache.hadoop.hbase.client.MultiResponse
 
MultiRowRangeFilter - org.apache.hadoop.hbase.filter中的类
Filter to support scan multiple row key ranges.
MultiRowRangeFilter(List<MultiRowRangeFilter.RowRange>) - 类 的构造器org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
MultiRowRangeFilter(byte[][]) - 类 的构造器org.apache.hadoop.hbase.filter.MultiRowRangeFilter
Constructor for creating a MultiRowRangeFilter from multiple rowkey prefixes.
MultiRowRangeFilter.RowRange - org.apache.hadoop.hbase.filter中的类
 
MultiRowRangeFilter.RowRange() - 类 的构造器org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
 
MultiRowRangeFilter.RowRange(String, boolean, String, boolean) - 类 的构造器org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
If the startRow is empty or null, set it to HConstants.EMPTY_BYTE_ARRAY, means begin at the start row of the table.
MultiRowRangeFilter.RowRange(byte[], boolean, byte[], boolean) - 类 的构造器org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
 
multiTracker - 类 中的变量org.apache.hadoop.hbase.client.MetricsConnection
 
mutate(Mutation) - 接口 中的方法org.apache.hadoop.hbase.client.BufferedMutator
Sends a Mutation to the table.
mutate(List<? extends Mutation>) - 接口 中的方法org.apache.hadoop.hbase.client.BufferedMutator
Send some Mutations to the table.
mutate(Mutation) - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorImpl
 
mutate(List<? extends Mutation>) - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorImpl
 
mutateMetaTable(Connection, List<Mutation>) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Execute the passed mutations against hbase:meta table.
mutateRegions(Connection, List<HRegionInfo>, List<HRegionInfo>) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Adds and Removes the specified regions from hbase:meta
mutateRow(RowMutations) - 类 中的方法org.apache.hadoop.hbase.client.HTable
Performs multiple mutations atomically on a single row.
mutateRow(RowMutations) - 接口 中的方法org.apache.hadoop.hbase.client.Table
Performs multiple mutations atomically on a single row.
Mutation - org.apache.hadoop.hbase.client中的类
 
Mutation() - 类 的构造器org.apache.hadoop.hbase.client.Mutation
 
MUTATION_OVERHEAD - 类 中的静态变量org.apache.hadoop.hbase.client.Mutation
 
mutator - 类 中的变量org.apache.hadoop.hbase.client.HTable
 

N

N - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'N'
NAMESPACE_COL_DESC_BYTES - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
 
NAMESPACE_FAMILY_INFO - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
 
NAMESPACE_FAMILY_INFO_BYTES - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
 
NAMESPACE_TABLEDESC - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
Table descriptor for namespace table
NamespaceExistException - org.apache.hadoop.hbase中的异常错误
Thrown when a namespace exists but should not
NamespaceExistException() - 异常错误 的构造器org.apache.hadoop.hbase.NamespaceExistException
 
NamespaceExistException(String) - 异常错误 的构造器org.apache.hadoop.hbase.NamespaceExistException
 
NamespaceNotFoundException - org.apache.hadoop.hbase中的异常错误
Thrown when a namespace can not be located
NamespaceNotFoundException() - 异常错误 的构造器org.apache.hadoop.hbase.NamespaceNotFoundException
 
NamespaceNotFoundException(String) - 异常错误 的构造器org.apache.hadoop.hbase.NamespaceNotFoundException
 
namespaceZNode - 类 中的静态变量org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
NeedUnmanagedConnectionException - org.apache.hadoop.hbase.client中的异常错误
Used for internal signalling that a Connection implementation needs to be user-managed to be used for particular request types.
NeedUnmanagedConnectionException() - 异常错误 的构造器org.apache.hadoop.hbase.client.NeedUnmanagedConnectionException
 
NettyHBaseSaslRpcClient - org.apache.hadoop.hbase.security中的类
Implement SASL logic for netty rpc client.
NettyHBaseSaslRpcClient(AuthMethod, Token<? extends TokenIdentifier>, String, boolean, String) - 类 的构造器org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClient
 
NettyHBaseSaslRpcClientHandler - org.apache.hadoop.hbase.security中的类
Implement SASL logic for netty rpc client.
NettyHBaseSaslRpcClientHandler(Promise<Boolean>, UserGroupInformation, AuthMethod, Token<? extends TokenIdentifier>, String, boolean, String) - 类 的构造器org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClientHandler
 
NettyRpcClient - org.apache.hadoop.hbase.ipc中的类
Netty client for the requests and responses.
NettyRpcClient(Configuration, String, SocketAddress, MetricsConnection) - 类 的构造器org.apache.hadoop.hbase.ipc.NettyRpcClient
 
NettyRpcClientConfigHelper - org.apache.hadoop.hbase.ipc中的类
Helper class for passing config to NettyRpcClient.
NettyRpcClientConfigHelper() - 类 的构造器org.apache.hadoop.hbase.ipc.NettyRpcClientConfigHelper
 
newCaller(int) - 类 中的方法org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
Create a new RetryingCaller with specific rpc timeout.
newCaller() - 类 中的方法org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
Create a new RetryingCaller with configured rpc timeout.
newCallStats() - 类 中的静态方法org.apache.hadoop.hbase.client.MetricsConnection
Produce an instance of MetricsConnection.CallStats for clients to attach to RPCs.
newController() - 类 中的方法org.apache.hadoop.hbase.ipc.RpcControllerFactory
 
newController(CellScanner) - 类 中的方法org.apache.hadoop.hbase.ipc.RpcControllerFactory
 
newController(List<CellScannable>) - 类 中的方法org.apache.hadoop.hbase.ipc.RpcControllerFactory
 
newNonce() - 接口 中的方法org.apache.hadoop.hbase.client.NonceGenerator
 
newNonce() - 类 中的方法org.apache.hadoop.hbase.client.PerClientRandomNonceGenerator
 
newServiceStub(Class<T>, RpcChannel) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
next(int) - 类 中的方法org.apache.hadoop.hbase.client.AbstractClientScanner
Get nbRows rows.
next() - 类 中的方法org.apache.hadoop.hbase.client.ClientScanner
 
next() - 接口 中的方法org.apache.hadoop.hbase.client.ResultScanner
Grab the next row's worth of values.
next(int) - 接口 中的方法org.apache.hadoop.hbase.client.ResultScanner
 
next() - 类 中的方法org.apache.hadoop.hbase.quotas.QuotaRetriever
 
NINE - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
ASCII code foe Nine
NO_HASH - 类 中的静态变量org.apache.hadoop.hbase.HRegionInfo
 
node - 类 中的变量org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
Path of node being tracked
nodeChildrenChanged(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl.OtherRegionServerWatcher
Called when an existing node has a child node added or removed.
nodeChildrenChanged(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl.PeersWatcher
Called when an existing node has a child node added or removed.
nodeChildrenChanged(String) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperListener
Called when an existing node has a child node added or removed.
nodeCreated(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl.PeerConfigTracker
 
nodeCreated(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl.OtherRegionServerWatcher
Called when a new node has been created.
nodeCreated(String) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
已过时。
 
nodeCreated(String) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperListener
Called when a new node has been created.
nodeCreated(String) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
 
nodeDataChanged(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl.PeerConfigTracker
 
nodeDataChanged(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl.PeerStateTracker
 
nodeDataChanged(String) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperListener
Called when an existing node has changed data.
nodeDataChanged(String) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
 
nodeDeleted(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl.OtherRegionServerWatcher
Called when a node has been deleted
nodeDeleted(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl.PeersWatcher
Called when a node has been deleted
nodeDeleted(String) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
已过时。
 
nodeDeleted(String) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperListener
Called when a node has been deleted
nodeDeleted(String) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
 
nodeHasChildren(ZooKeeperWatcher, String) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Checks if the specified znode has any children.
NON_EXIST_LABEL_ORDINAL - 类 中的静态变量org.apache.hadoop.hbase.security.visibility.VisibilityConstants
Label ordinal value for invalid labels
NON_STARTCODE - 类 中的静态变量org.apache.hadoop.hbase.ServerName
What to use if no startcode supplied.
NonceGenerator - org.apache.hadoop.hbase.client中的接口
NonceGenerator interface.
NORMALIZATION_ENABLED - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Used by shell/rest interface to access this metadata attribute which denotes if the table should be treated by region normalizer.
normalize() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Invoke region normalizer.
normalize() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Invoke region normalizer.
NoServerForRegionException - org.apache.hadoop.hbase.client中的异常错误
Thrown when no region server can be found for a region
NoServerForRegionException() - 异常错误 的构造器org.apache.hadoop.hbase.client.NoServerForRegionException
default constructor
NoServerForRegionException(String) - 异常错误 的构造器org.apache.hadoop.hbase.client.NoServerForRegionException
Constructor
NoSuchColumnFamilyException - org.apache.hadoop.hbase.regionserver中的异常错误
Thrown if request for nonexistent column family.
NoSuchColumnFamilyException() - 异常错误 的构造器org.apache.hadoop.hbase.regionserver.NoSuchColumnFamilyException
default constructor
NoSuchColumnFamilyException(String) - 异常错误 的构造器org.apache.hadoop.hbase.regionserver.NoSuchColumnFamilyException
 
NOT_EQUAL_TO_ARRAY - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
NOT_EQUAL_TO Array
NOT_EQUAL_TO_BUFFER - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
 
NOT_OPERATOR - 类 中的静态变量org.apache.hadoop.hbase.security.visibility.VisibilityConstants
 
NOT_SERVING_REGION_EXCEPTION_METRIC_NAME - 类 中的静态变量org.apache.hadoop.hbase.client.metrics.ScanMetrics
 
NotAllMetaRegionsOnlineException - org.apache.hadoop.hbase中的异常错误
Thrown when an operation requires the root and all meta regions to be online
NotAllMetaRegionsOnlineException() - 异常错误 的构造器org.apache.hadoop.hbase.NotAllMetaRegionsOnlineException
default constructor
NotAllMetaRegionsOnlineException(String) - 异常错误 的构造器org.apache.hadoop.hbase.NotAllMetaRegionsOnlineException
 
notifyOnCancel(RpcCallback<Object>) - 类 中的方法org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
notifyOnCancel(RpcCallback<Object>, HBaseRpcController.CancellationCallback) - 类 中的方法org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
notifyOnCancel(RpcCallback<Object>) - 接口 中的方法org.apache.hadoop.hbase.ipc.HBaseRpcController
A little different from the basic RpcController: You can register multiple callbacks to an HBaseRpcController.
notifyOnCancel(RpcCallback<Object>, HBaseRpcController.CancellationCallback) - 接口 中的方法org.apache.hadoop.hbase.ipc.HBaseRpcController
If not cancelled, add the callback to cancellation callback list.
notifyOnCancel(RpcCallback<Object>) - 类 中的方法org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
notifyOnCancel(RpcCallback<Object>, HBaseRpcController.CancellationCallback) - 类 中的方法org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
notifyOnCancel(RpcCallback<Object>) - 类 中的方法org.apache.hadoop.hbase.ipc.ServerRpcController
 
NotServingRegionException - org.apache.hadoop.hbase中的异常错误
Thrown by a region server if it is sent a request for a region it is not serving.
NotServingRegionException() - 异常错误 的构造器org.apache.hadoop.hbase.NotServingRegionException
 
NotServingRegionException(String) - 异常错误 的构造器org.apache.hadoop.hbase.NotServingRegionException
 
NotServingRegionException(byte[]) - 异常错误 的构造器org.apache.hadoop.hbase.NotServingRegionException
 
NullComparator - org.apache.hadoop.hbase.filter中的类
A binary comparator which lexicographically compares against the specified byte array using Bytes.compareTo(byte[], byte[]).
NullComparator() - 类 的构造器org.apache.hadoop.hbase.filter.NullComparator
 
numFamilies() - 类 中的方法org.apache.hadoop.hbase.client.Get
Method for retrieving the number of families to get from
numFamilies() - 类 中的方法org.apache.hadoop.hbase.client.Increment
Method for retrieving the number of families to increment from
numFamilies() - 类 中的方法org.apache.hadoop.hbase.client.Mutation
 
numFamilies() - 类 中的方法org.apache.hadoop.hbase.client.Scan
 
numNonNullElements() - 类 中的方法org.apache.hadoop.hbase.RegionLocations
Returns the size of not-null locations

O

O - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'O'
obtainAndCacheToken(Configuration, UserGroupInformation) - 类 中的静态方法org.apache.hadoop.hbase.security.token.TokenUtil
obtainAndCacheToken(Connection, User) - 类 中的静态方法org.apache.hadoop.hbase.security.token.TokenUtil
Obtain an authentication token for the given user and add it to the user's credentials.
obtainServerLoadPB() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
 
obtainToken(Configuration) - 类 中的静态方法org.apache.hadoop.hbase.security.token.TokenUtil
已过时。
obtainToken(Connection) - 类 中的静态方法org.apache.hadoop.hbase.security.token.TokenUtil
Obtain and return an authentication token for the current user.
obtainToken(Connection, User) - 类 中的静态方法org.apache.hadoop.hbase.security.token.TokenUtil
Obtain and return an authentication token for the current user.
obtainTokenForJob(Configuration, UserGroupInformation, Job) - 类 中的静态方法org.apache.hadoop.hbase.security.token.TokenUtil
obtainTokenForJob(Connection, User, Job) - 类 中的静态方法org.apache.hadoop.hbase.security.token.TokenUtil
Obtain an authentication token on behalf of the given user and add it to the credentials for the given map reduce job.
obtainTokenForJob(JobConf, UserGroupInformation) - 类 中的静态方法org.apache.hadoop.hbase.security.token.TokenUtil
obtainTokenForJob(Connection, JobConf, User) - 类 中的静态方法org.apache.hadoop.hbase.security.token.TokenUtil
Obtain an authentication token on behalf of the given user and add it to the credentials for the given map reduce job.
offline(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Offline specified region from master's in-memory state.
offline(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Offline specified region from master's in-memory state.
onException(RetriesExhaustedWithDetailsException, BufferedMutator) - 接口 中的方法org.apache.hadoop.hbase.client.BufferedMutator.ExceptionListener
 
OP_ATTRIBUTE_ACL - 接口 中的静态变量org.apache.hadoop.hbase.security.access.AccessControlConstants
Cell level ACL
OP_ATTRIBUTE_ACL_STRATEGY - 接口 中的静态变量org.apache.hadoop.hbase.security.access.AccessControlConstants
已过时。
OP_ATTRIBUTE_ACL_STRATEGY_CELL_FIRST - 接口 中的静态变量org.apache.hadoop.hbase.security.access.AccessControlConstants
已过时。
OP_ATTRIBUTE_ACL_STRATEGY_DEFAULT - 接口 中的静态变量org.apache.hadoop.hbase.security.access.AccessControlConstants
已过时。
open(Configuration) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaRetriever
Open a QuotaRetriever with no filter, all the quota settings will be returned.
open(Configuration, QuotaFilter) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaRetriever
Open a QuotaRetriever with the specified filter.
OPEN_PARAN - 类 中的静态变量org.apache.hadoop.hbase.security.visibility.VisibilityConstants
 
openRegion(RpcController, AdminProtos.AdminService.BlockingInterface, ServerName, HRegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to open a region using admin protocol.
Operation - org.apache.hadoop.hbase.client中的类
Superclass for any type that maps to a potentially application-level query.
Operation() - 类 的构造器org.apache.hadoop.hbase.client.Operation
 
OperationConflictException - org.apache.hadoop.hbase.exceptions中的异常错误
The exception that is thrown if there's duplicate execution of non-idempotent operation.
OperationConflictException() - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.OperationConflictException
 
OperationConflictException(String) - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.OperationConflictException
 
OperationConflictException(Throwable) - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.OperationConflictException
 
OperationConflictException(String, Throwable) - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.OperationConflictException
 
OperationWithAttributes - org.apache.hadoop.hbase.client中的类
 
OperationWithAttributes() - 类 的构造器org.apache.hadoop.hbase.client.OperationWithAttributes
 
OR - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
OR Byte Array
OR_ARRAY - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
OR Array
OR_BUFFER - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
 
OR_OPERATOR - 类 中的静态变量org.apache.hadoop.hbase.security.visibility.VisibilityConstants
 
org.apache.hadoop.hbase - 程序包 org.apache.hadoop.hbase
 
org.apache.hadoop.hbase.client - 程序包 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.backoff - 程序包 org.apache.hadoop.hbase.client.backoff
 
org.apache.hadoop.hbase.client.coprocessor - 程序包 org.apache.hadoop.hbase.client.coprocessor
Provides client classes for invoking Coprocessor RPC protocols Overview Example Usage Overview The coprocessor framework provides a way for custom code to run in place on the HBase region servers with each of a table's regions.
org.apache.hadoop.hbase.client.metrics - 程序包 org.apache.hadoop.hbase.client.metrics
 
org.apache.hadoop.hbase.client.replication - 程序包 org.apache.hadoop.hbase.client.replication
 
org.apache.hadoop.hbase.client.security - 程序包 org.apache.hadoop.hbase.client.security
 
org.apache.hadoop.hbase.coprocessor - 程序包 org.apache.hadoop.hbase.coprocessor
 
org.apache.hadoop.hbase.exceptions - 程序包 org.apache.hadoop.hbase.exceptions
 
org.apache.hadoop.hbase.executor - 程序包 org.apache.hadoop.hbase.executor
 
org.apache.hadoop.hbase.filter - 程序包 org.apache.hadoop.hbase.filter
Provides row-level filters applied to HRegion scan results during calls to ResultScanner.next().
org.apache.hadoop.hbase.ipc - 程序包 org.apache.hadoop.hbase.ipc
 
org.apache.hadoop.hbase.master - 程序包 org.apache.hadoop.hbase.master
 
org.apache.hadoop.hbase.protobuf - 程序包 org.apache.hadoop.hbase.protobuf
Holds classes generated from protobuf src/main/protobuf definition files.
org.apache.hadoop.hbase.quotas - 程序包 org.apache.hadoop.hbase.quotas
 
org.apache.hadoop.hbase.regionserver - 程序包 org.apache.hadoop.hbase.regionserver
 
org.apache.hadoop.hbase.regionserver.wal - 程序包 org.apache.hadoop.hbase.regionserver.wal
 
org.apache.hadoop.hbase.replication - 程序包 org.apache.hadoop.hbase.replication
 
org.apache.hadoop.hbase.security - 程序包 org.apache.hadoop.hbase.security
 
org.apache.hadoop.hbase.security.access - 程序包 org.apache.hadoop.hbase.security.access
 
org.apache.hadoop.hbase.security.token - 程序包 org.apache.hadoop.hbase.security.token
 
org.apache.hadoop.hbase.security.visibility - 程序包 org.apache.hadoop.hbase.security.visibility
 
org.apache.hadoop.hbase.snapshot - 程序包 org.apache.hadoop.hbase.snapshot
 
org.apache.hadoop.hbase.util - 程序包 org.apache.hadoop.hbase.util
 
org.apache.hadoop.hbase.zookeeper - 程序包 org.apache.hadoop.hbase.zookeeper
 
ourClusterKey - 类 中的变量org.apache.hadoop.hbase.replication.ReplicationStateZKBase
The cluster key of the local cluster
OutOfOrderScannerNextException - org.apache.hadoop.hbase.exceptions中的异常错误
Thrown by a RegionServer while doing next() calls on a ResultScanner.
OutOfOrderScannerNextException() - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.OutOfOrderScannerNextException
 
OutOfOrderScannerNextException(String) - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.OutOfOrderScannerNextException
 
overwriteRegions(Connection, List<HRegionInfo>, int) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Overwrites the specified regions from hbase:meta
OWNER - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
 
OWNER_KEY - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
 
ownerToString() - 类 中的方法org.apache.hadoop.hbase.quotas.QuotaSettings
 

P

P - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'P'
PackagePrivateFieldAccessor - org.apache.hadoop.hbase.client中的类
A helper class used to access the package private field in o.a.h.h.client package.
PackagePrivateFieldAccessor() - 类 的构造器org.apache.hadoop.hbase.client.PackagePrivateFieldAccessor
 
PageFilter - org.apache.hadoop.hbase.filter中的类
Implementation of Filter interface that limits results to a specific page size.
PageFilter(long) - 类 的构造器org.apache.hadoop.hbase.filter.PageFilter
Constructor that takes a maximum page size.
parse(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
 
parseComparator(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.ParseFilter
Splits a column in comparatorType:comparatorValue form into separate byte arrays
ParseConstants - org.apache.hadoop.hbase.filter中的类
ParseConstants holds a bunch of constants related to parsing Filter Strings Used by ParseFilter
ParseConstants() - 类 的构造器org.apache.hadoop.hbase.filter.ParseConstants
 
parseDelimitedFrom(byte[], int, int) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
Parses all the HRegionInfo instances from the passed in stream until EOF.
ParseFilter - org.apache.hadoop.hbase.filter中的类
This class allows a user to specify a filter via a string The string is parsed using the methods of this class and a filter object is constructed.
ParseFilter() - 类 的构造器org.apache.hadoop.hbase.filter.ParseFilter
 
parseFilterString(String) - 类 中的方法org.apache.hadoop.hbase.filter.ParseFilter
Parses the filterString and constructs a filter using it
parseFilterString(byte[]) - 类 中的方法org.apache.hadoop.hbase.filter.ParseFilter
Parses the filterString and constructs a filter using it
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.ClusterId
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.BinaryComparator
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.BinaryPrefixComparator
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.BitComparator
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.ByteArrayComparable
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.DependentColumnFilter
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.FamilyFilter
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.Filter
Concrete implementers can signal a failure condition in their code by throwing an IOException.
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.FilterList
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.FilterWrapper
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.FuzzyRowFilter
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.LongComparator
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.NullComparator
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.PageFilter
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.PrefixFilter
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.QualifierFilter
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.RandomRowFilter
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.RegexStringComparator
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.RowFilter
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.SkipFilter
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.SubstringComparator
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.TimestampsFilter
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.ValueFilter
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.WhileMatchFilter
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.HColumnDescriptor
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
 
parseFrom(byte[], int, int) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
 
parseFrom(DataInputStream) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
Parses an HRegionInfo instance from the passed in stream.
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.HTableDescriptor
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.RegionTransition
 
parseFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.ServerName
Get a ServerName from the passed in data bytes.
parseFromOrNull(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
 
parseFromOrNull(byte[], int, int) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
 
parseHostname(String) - 类 中的静态方法org.apache.hadoop.hbase.ServerName
 
parseNamespaceResult(Result, QuotaTableUtil.NamespaceQuotasVisitor) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
parseNamespaceResult(String, Result, QuotaTableUtil.NamespaceQuotasVisitor) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
parsePeerFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.replication.ReplicationSerDeHelper
 
parsePort(String) - 类 中的静态方法org.apache.hadoop.hbase.ServerName
 
parseRegionInfoFromRegionName(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Returns an HRI parsed from this regionName.
parseRegionName(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
Separate elements of a regionName.
parseRegionStoreSequenceIds(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
 
parseResult(Result, QuotaTableUtil.QuotasVisitor) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
parseServerName(String) - 类 中的静态方法org.apache.hadoop.hbase.ServerName
 
parseSimpleFilterExpression(byte[]) - 类 中的方法org.apache.hadoop.hbase.filter.ParseFilter
Constructs a filter object given a simple filter expression
parseStartcode(String) - 类 中的静态方法org.apache.hadoop.hbase.ServerName
 
parseTableCFs(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.replication.ReplicationSerDeHelper
Parse bytes into TableCFs.
parseTableCFsFromConfig(String) - 类 中的静态方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
 
parseTableCFsFromConfig(String) - 类 中的静态方法org.apache.hadoop.hbase.replication.ReplicationSerDeHelper
Convert tableCFs string into Map.
parseTableResult(Result, QuotaTableUtil.TableQuotasVisitor) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
parseTableResult(TableName, Result, QuotaTableUtil.TableQuotasVisitor) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
parseUserResult(Result, QuotaTableUtil.UserQuotasVisitor) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
parseUserResult(String, Result, QuotaTableUtil.UserQuotasVisitor) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
parseVersionedServerName(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.ServerName
Use this method instantiating a ServerName from bytes gotten from a call to ServerName.getVersionedBytes().
parseWALPositionFrom(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
 
passedPrefix - 类 中的变量org.apache.hadoop.hbase.filter.PrefixFilter
 
pattern - 类 中的静态变量org.apache.hadoop.hbase.security.visibility.VisibilityLabelsValidator
 
PayloadCarryingServerCallable<T> - org.apache.hadoop.hbase.client中的类
This class is used to unify HTable calls with AsyncProcess Framework.
PayloadCarryingServerCallable(Connection, TableName, byte[], RpcControllerFactory) - 类 的构造器org.apache.hadoop.hbase.client.PayloadCarryingServerCallable
 
PayloadCarryingServerCallable(Connection, TableName, byte[], RpcControllerFactory, int) - 类 的构造器org.apache.hadoop.hbase.client.PayloadCarryingServerCallable
 
PB_MAGIC - 类 中的静态变量org.apache.hadoop.hbase.protobuf.ProtobufUtil
Magic we put ahead of a serialized protobuf message.
peerAdded(String) - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
 
peerAdded(String) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeers
 
peerAdded(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
peerConfigUpdated(ReplicationPeerConfig) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfigListener
Callback method for when users update the ReplicationPeerConfig for this peer
peerExists(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationStateZKBase
 
peerListChanged(List<String>) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationListener
The list of registered peer clusters has changed.
peerRemoved(String) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationListener
A peer cluster has been removed (i.e. unregistered) from replication.
peerRemoved(String) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeers
 
peerRemoved(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
peerStateNodeName - 类 中的变量org.apache.hadoop.hbase.replication.ReplicationStateZKBase
The name of the znode that contains the replication status of a remote slave (i.e. peer) cluster.
peersZNode - 类 中的变量org.apache.hadoop.hbase.replication.ReplicationStateZKBase
The name of the znode that contains a list of all remote slave (i.e. peer) clusters.
PerClientRandomNonceGenerator - org.apache.hadoop.hbase.client中的类
NonceGenerator implementation that uses client ID hash + random int as nonce group, and random numbers as nonces.
PerClientRandomNonceGenerator() - 类 的构造器org.apache.hadoop.hbase.client.PerClientRandomNonceGenerator
 
Permission - org.apache.hadoop.hbase.security.access中的类
Base permissions instance representing the ability to perform a given set of actions.
Permission() - 类 的构造器org.apache.hadoop.hbase.security.access.Permission
Empty constructor for Writable implementation.
Permission(Permission.Action...) - 类 的构造器org.apache.hadoop.hbase.security.access.Permission
 
Permission(byte[]) - 类 的构造器org.apache.hadoop.hbase.security.access.Permission
 
Permission.Action - org.apache.hadoop.hbase.security.access中的枚举
 
PING_CALL_ID - 接口 中的静态变量org.apache.hadoop.hbase.ipc.RpcClient
 
PleaseHoldException - org.apache.hadoop.hbase中的异常错误
This exception is thrown by the master when a region server was shut down and restarted so fast that the master still hasn't processed the server shutdown of the first instance, or when master is initializing and client call admin operations, or when an operation is performed on a region server that is still starting.
PleaseHoldException(String) - 异常错误 的构造器org.apache.hadoop.hbase.PleaseHoldException
 
PleaseHoldException(String, Throwable) - 异常错误 的构造器org.apache.hadoop.hbase.PleaseHoldException
 
PleaseHoldException(Throwable) - 异常错误 的构造器org.apache.hadoop.hbase.PleaseHoldException
 
pluralize(Collection<?>) - 异常错误 中的静态方法org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
pluralize(int) - 异常错误 中的静态方法org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
poll(long, TimeUnit) - 类 中的方法org.apache.hadoop.hbase.client.ResultBoundedCompletionService
Poll for the first completed task whether it is a success or execution exception.
pollForFirstSuccessfullyCompletedTask(long, TimeUnit, int, int) - 类 中的方法org.apache.hadoop.hbase.client.ResultBoundedCompletionService
Poll for the first successfully completed task whose completed order is in startIndex, endIndex(exclusive) range
pool(ExecutorService) - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorParams
Override the default executor pool defined by the hbase.htable.threads.* configuration values.
pool - 类 中的变量org.apache.hadoop.hbase.client.ClientScanner
 
pool - 类 中的变量org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
 
PoolMap<K,V> - org.apache.hadoop.hbase.util中的类
The PoolMap maps a key to a collection of values, the elements of which are managed by a pool.
PoolMap(PoolMap.PoolType) - 类 的构造器org.apache.hadoop.hbase.util.PoolMap
 
PoolMap(PoolMap.PoolType, int) - 类 的构造器org.apache.hadoop.hbase.util.PoolMap
 
PoolMap.Pool<R> - org.apache.hadoop.hbase.util中的接口
 
PoolMap.PoolType - org.apache.hadoop.hbase.util中的枚举
 
PoolMap.ReusablePool<R> - org.apache.hadoop.hbase.util中的类
The ReusablePool represents a PoolMap.Pool that builds on the LinkedList class.
PoolMap.ReusablePool(int) - 类 的构造器org.apache.hadoop.hbase.util.PoolMap.ReusablePool
 
popArguments(Stack<ByteBuffer>, Stack<Filter>) - 类 中的静态方法org.apache.hadoop.hbase.filter.ParseFilter
Pops an argument from the operator stack and the number of arguments required by the operator from the filterStack and evaluates them
positionToByteArray(long) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
 
postOpeartionFailure(IOException, long) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
Called after the operation is terminated with a failure.
postOperationResult(V, long) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
Called after the operation is completed and the result fetched.
PreemptiveFastFailException - org.apache.hadoop.hbase.exceptions中的异常错误
Thrown when the client believes that we are trying to communicate to has been repeatedly unresponsive for a while.
PreemptiveFastFailException(long, long, long, ServerName) - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
 
PreemptiveFastFailException(long, long, long, ServerName, boolean) - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
 
PREFETCH_BLOCKS_ON_OPEN - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
Key for the PREFETCH_BLOCKS_ON_OPEN attribute.
prefix - 类 中的变量org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
prefix - 类 中的变量org.apache.hadoop.hbase.filter.PrefixFilter
 
prefix(String) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Adds this instance's identifier as a prefix to the passed str
PrefixFilter - org.apache.hadoop.hbase.filter中的类
Pass results that have same row prefix.
PrefixFilter(byte[]) - 类 的构造器org.apache.hadoop.hbase.filter.PrefixFilter
 
prepare(boolean) - 类 中的方法org.apache.hadoop.hbase.client.DelegatingRetryingCallable
 
prepare(boolean) - 类 中的方法org.apache.hadoop.hbase.client.FlushRegionCallable
 
prepare(boolean) - 类 中的方法org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
prepare(boolean) - 类 中的方法org.apache.hadoop.hbase.client.RegionServerCallable
Prepare for connection to the server hosting region with row from tablename.
prepare(boolean) - 接口 中的方法org.apache.hadoop.hbase.client.RetryingCallable
Prepare by setting up any connections to servers, etc., ahead of RetryingCallable.call(int) invocation.
prepare(boolean) - 类 中的方法org.apache.hadoop.hbase.client.ReversedScannerCallable
 
prepare(boolean) - 类 中的方法org.apache.hadoop.hbase.client.ScannerCallable
 
prepareBulkLoad(TableName) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.SecureBulkLoadClient
 
prependPBMagic(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Prepend the passed bytes with four bytes of magic, ProtobufUtil.PB_MAGIC, to flag what follows as a protobuf in hbase.
prettyPrint(String) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
Use logging.
primaryOperationTimeout - 类 中的变量org.apache.hadoop.hbase.client.ClientScanner
 
priority - 类 中的变量org.apache.hadoop.hbase.client.RegionServerCallable
 
PRIORITY - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
 
PRIORITY_HIGHEST - 接口 中的静态变量org.apache.hadoop.hbase.Coprocessor
Highest installation priority
PRIORITY_LOWEST - 接口 中的静态变量org.apache.hadoop.hbase.Coprocessor
Lowest installation priority
PRIORITY_SYSTEM - 接口 中的静态变量org.apache.hadoop.hbase.Coprocessor
High (system) installation priority
PRIORITY_USER - 接口 中的静态变量org.apache.hadoop.hbase.Coprocessor
Default installation priority for user coprocessors
process(WatchedEvent) - 类 中的方法org.apache.hadoop.hbase.zookeeper.EmptyWatcher
 
process(WatchedEvent) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Method called from ZooKeeper for events and connection status.
processBatch(List<? extends Row>, TableName, ExecutorService, Object[]) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
processBatch(List<? extends Row>, byte[], ExecutorService, Object[]) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
processBatchCallback(List<? extends Row>, TableName, ExecutorService, Object[], Batch.Callback<R>) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
processBatchCallback(List<? extends Row>, byte[], ExecutorService, Object[], Batch.Callback<R>) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
processBatchCallback(List<? extends Row>, Object[], Batch.Callback<R>) - 类 中的方法org.apache.hadoop.hbase.client.HTable
Process a mixed batch of Get, Put and Delete actions.
processRow(Result) - 类 中的方法org.apache.hadoop.hbase.client.MetaScanner.DefaultMetaScannerVisitor
 
processRow(Result) - 接口 中的方法org.apache.hadoop.hbase.client.MetaScanner.MetaScannerVisitor
Visitor method that accepts a RowResult and the meta region location.
processRow(Result) - 类 中的方法org.apache.hadoop.hbase.client.MetaScanner.TableMetaScannerVisitor
 
processRowInternal(Result) - 类 中的方法org.apache.hadoop.hbase.client.MetaScanner.DefaultMetaScannerVisitor
 
ProtobufUtil - org.apache.hadoop.hbase.protobuf中的类
Protobufs utility.
put(Put) - 类 中的方法org.apache.hadoop.hbase.client.HTable
Puts some data in the table.
put(List<Put>) - 类 中的方法org.apache.hadoop.hbase.client.HTable
Puts some data in the table, in batch.
put(TableName, Put) - 类 中的方法org.apache.hadoop.hbase.client.HTableMultiplexer
The put request will be buffered by its corresponding buffer queue.
put(TableName, List<Put>) - 类 中的方法org.apache.hadoop.hbase.client.HTableMultiplexer
The puts request will be buffered by their corresponding buffer queue.
put(byte[], List<Put>) - 类 中的方法org.apache.hadoop.hbase.client.HTableMultiplexer
已过时。
put(TableName, Put, int) - 类 中的方法org.apache.hadoop.hbase.client.HTableMultiplexer
The put request will be buffered by its corresponding buffer queue.
put(byte[], Put, int) - 类 中的方法org.apache.hadoop.hbase.client.HTableMultiplexer
已过时。
put(byte[], Put) - 类 中的方法org.apache.hadoop.hbase.client.HTableMultiplexer
已过时。
Put - org.apache.hadoop.hbase.client中的类
Used to perform Put operations for a single row.
Put(byte[]) - 类 的构造器org.apache.hadoop.hbase.client.Put
Create a Put operation for the specified row.
Put(byte[], long) - 类 的构造器org.apache.hadoop.hbase.client.Put
Create a Put operation for the specified row, using a given timestamp.
Put(byte[], int, int) - 类 的构造器org.apache.hadoop.hbase.client.Put
We make a copy of the passed in row key to keep local.
Put(ByteBuffer, long) - 类 的构造器org.apache.hadoop.hbase.client.Put
 
Put(ByteBuffer) - 类 的构造器org.apache.hadoop.hbase.client.Put
 
Put(byte[], int, int, long) - 类 的构造器org.apache.hadoop.hbase.client.Put
We make a copy of the passed in row key to keep local.
Put(Put) - 类 的构造器org.apache.hadoop.hbase.client.Put
Copy constructor.
put(Put) - 接口 中的方法org.apache.hadoop.hbase.client.Table
Puts some data in the table.
put(List<Put>) - 接口 中的方法org.apache.hadoop.hbase.client.Table
Puts some data in the table, in batch.
put(R) - 接口 中的方法org.apache.hadoop.hbase.util.PoolMap.Pool
 
put(K, V) - 类 中的方法org.apache.hadoop.hbase.util.PoolMap
 
put(R) - 类 中的方法org.apache.hadoop.hbase.util.PoolMap.ReusablePool
 
putAll(Map<? extends K, ? extends V>) - 类 中的方法org.apache.hadoop.hbase.util.PoolMap
 
putsToMetaTable(Connection, List<Put>) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Put the passed ps to the hbase:meta table.
putTable(HTableInterface) - 类 中的方法org.apache.hadoop.hbase.client.HTablePool
已过时。 
putTracker - 类 中的变量org.apache.hadoop.hbase.client.MetricsConnection
 

Q

QualifierFilter - org.apache.hadoop.hbase.filter中的类
This filter is used to filter based on the column qualifier.
QualifierFilter(CompareFilter.CompareOp, ByteArrayComparable) - 类 的构造器org.apache.hadoop.hbase.filter.QualifierFilter
Constructor.
Query - org.apache.hadoop.hbase.client中的类
 
Query() - 类 的构造器org.apache.hadoop.hbase.client.Query
 
queuesZNode - 类 中的变量org.apache.hadoop.hbase.replication.ReplicationStateZKBase
The name of the znode that contains all replication queues
QUOTA_FAMILY_INFO - 类 中的静态变量org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
QUOTA_FAMILY_USAGE - 类 中的静态变量org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
QUOTA_NAMESPACE_ROW_KEY_PREFIX - 类 中的静态变量org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
QUOTA_QUALIFIER_SETTINGS - 类 中的静态变量org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
QUOTA_QUALIFIER_SETTINGS_PREFIX - 类 中的静态变量org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
QUOTA_TABLE_NAME - 类 中的静态变量org.apache.hadoop.hbase.quotas.QuotaTableUtil
System table for quotas
QUOTA_TABLE_ROW_KEY_PREFIX - 类 中的静态变量org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
QUOTA_USER_ROW_KEY_PREFIX - 类 中的静态变量org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
QuotaExceededException - org.apache.hadoop.hbase.quotas中的异常错误
Generic quota exceeded exception
QuotaExceededException(String) - 异常错误 的构造器org.apache.hadoop.hbase.quotas.QuotaExceededException
 
QuotaFilter - org.apache.hadoop.hbase.quotas中的类
Filter to use to filter the QuotaRetriever results.
QuotaFilter() - 类 的构造器org.apache.hadoop.hbase.quotas.QuotaFilter
 
QuotaRetriever - org.apache.hadoop.hbase.quotas中的类
Scanner to iterate over the quota settings.
QuotaScope - org.apache.hadoop.hbase.quotas中的枚举
Describe the Scope of the quota rules.
QuotaSettings - org.apache.hadoop.hbase.quotas中的类
 
QuotaSettings(String, TableName, String) - 类 的构造器org.apache.hadoop.hbase.quotas.QuotaSettings
 
QuotaSettingsFactory - org.apache.hadoop.hbase.quotas中的类
 
quotasFromData(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
quotasToData(QuotaProtos.Quotas) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
QuotaTableUtil - org.apache.hadoop.hbase.quotas中的类
Helper class to interact with the quota table.
QuotaTableUtil() - 类 的构造器org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
QuotaTableUtil.NamespaceQuotasVisitor - org.apache.hadoop.hbase.quotas中的接口
 
QuotaTableUtil.QuotasVisitor - org.apache.hadoop.hbase.quotas中的接口
 
QuotaTableUtil.TableQuotasVisitor - org.apache.hadoop.hbase.quotas中的接口
 
QuotaTableUtil.UserQuotasVisitor - org.apache.hadoop.hbase.quotas中的接口
 
QuotaType - org.apache.hadoop.hbase.quotas中的枚举
Describe the Quota Type.
quote(String) - 类 中的静态方法org.apache.hadoop.hbase.security.visibility.CellVisibility
Helps in quoting authentication Strings.
quote(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.security.visibility.CellVisibility
Helps in quoting authentication Strings.

R

R - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'R'
random - 类 中的静态变量org.apache.hadoop.hbase.filter.RandomRowFilter
 
RandomRowFilter - org.apache.hadoop.hbase.filter中的类
A filter that includes rows based on a chance.
RandomRowFilter(float) - 类 的构造器org.apache.hadoop.hbase.filter.RandomRowFilter
Create a new filter with a specified chance for a row to be included.
raw() - 类 中的方法org.apache.hadoop.hbase.client.Result
已过时。
as of 0.96, use Result.rawCells()
rawCells() - 类 中的方法org.apache.hadoop.hbase.client.Result
Return the array of Cells backing this Result instance.
read(DataInput) - 枚举 中的静态方法org.apache.hadoop.hbase.security.AuthMethod
Read from in
readClusterIdZNode(ZooKeeperWatcher) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKClusterId
 
readFields(DataInput) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
已过时。
Writables are going away. Use pb HColumnDescriptor.parseFrom(byte[]) instead.
readFields(DataInput) - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
已过时。
Use protobuf deserialization instead.
readFields(DataInput) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
已过时。
Writables are going away. Use pb HTableDescriptor.parseFrom(byte[]) instead.
readFields(DataInput) - 类 中的方法org.apache.hadoop.hbase.security.access.Permission
 
readFields(DataInput) - 类 中的方法org.apache.hadoop.hbase.security.access.TablePermission
 
readFields(DataInput) - 类 中的方法org.apache.hadoop.hbase.security.access.UserPermission
 
readFields(DataInput) - 类 中的方法org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
READONLY - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Used by rest interface to access this metadata attribute which denotes if the table is Read Only
readTO - 类 中的变量org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
reconnectAfterExpiration() - 类 中的方法org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
reconnectAfterExpiration() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
RecoverableZooKeeper - org.apache.hadoop.hbase.zookeeper中的类
A zookeeper that can handle 'recoverable' errors.
RecoverableZooKeeper(String, int, Watcher, int, int, int) - 类 的构造器org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
RecoverableZooKeeper(String, int, Watcher, int, int, int, String) - 类 的构造器org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
recoveringRegionsZNode - 类 中的变量org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
reduce(Stack<ByteBuffer>, Stack<Filter>, ByteBuffer) - 类 中的方法org.apache.hadoop.hbase.filter.ParseFilter
This function is called while parsing the filterString and an operator is parsed
regex - 类 中的静态变量org.apache.hadoop.hbase.security.visibility.VisibilityLabelsValidator
 
RegexStringComparator - org.apache.hadoop.hbase.filter中的类
This comparator is for use with CompareFilter implementations, such as RowFilter, QualifierFilter, and ValueFilter, for filtering based on the value of a given column.
RegexStringComparator(String) - 类 的构造器org.apache.hadoop.hbase.filter.RegexStringComparator
Constructor Adds Pattern.DOTALL to the underlying Pattern
RegexStringComparator(String, RegexStringComparator.EngineType) - 类 的构造器org.apache.hadoop.hbase.filter.RegexStringComparator
Constructor Adds Pattern.DOTALL to the underlying Pattern
RegexStringComparator(String, int) - 类 的构造器org.apache.hadoop.hbase.filter.RegexStringComparator
Constructor
RegexStringComparator(String, int, RegexStringComparator.EngineType) - 类 的构造器org.apache.hadoop.hbase.filter.RegexStringComparator
Constructor
RegexStringComparator.EngineType - org.apache.hadoop.hbase.filter中的枚举
Engine implementation type (default=JAVA)
regexStringType - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
RegexStringType byte array
REGION_MEMSTORE_REPLICATION - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
INTERNAL flag to indicate whether or not the memstore should be replicated for read-replicas (CONSISTENCY => TIMELINE).
REGION_REPLICA_WAIT_FOR_PRIMARY_FLUSH_CONF_KEY - 类 中的静态变量org.apache.hadoop.hbase.client.RegionReplicaUtil
Whether or not the secondary region will wait for observing a flush / region open event from the primary region via async wal replication before enabling read requests.
REGION_REPLICATION - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
INTERNAL number of region replicas for the table.
RegionAdminServiceCallable<T> - org.apache.hadoop.hbase.client中的类
Similar to RegionServerCallable but for the AdminService interface.
RegionAdminServiceCallable(ClusterConnection, RpcControllerFactory, TableName, byte[]) - 类 的构造器org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
RegionAdminServiceCallable(ClusterConnection, RpcControllerFactory, HRegionLocation, TableName, byte[]) - 类 的构造器org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
RegionAdminServiceCallable(ClusterConnection, RpcControllerFactory, HRegionLocation, TableName, byte[], int) - 类 的构造器org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
RegionAlreadyInTransitionException - org.apache.hadoop.hbase.regionserver中的异常错误
This exception is thrown when a region server is asked to open or close a region but it's already processing it
RegionAlreadyInTransitionException(String) - 异常错误 的构造器org.apache.hadoop.hbase.regionserver.RegionAlreadyInTransitionException
 
RegionCoprocessorRpcChannel - org.apache.hadoop.hbase.ipc中的类
Provides clients with an RPC connection to call coprocessor endpoint Services against a given table region.
RegionCoprocessorRpcChannel(ClusterConnection, TableName, byte[]) - 类 的构造器org.apache.hadoop.hbase.ipc.RegionCoprocessorRpcChannel
 
RegionCoprocessorServiceExec - org.apache.hadoop.hbase.client中的类
Represents a coprocessor service method execution against a single region.
RegionCoprocessorServiceExec(byte[], byte[], Descriptors.MethodDescriptor, Message) - 类 的构造器org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
 
RegionException - org.apache.hadoop.hbase中的异常错误
Thrown when something happens related to region handling.
RegionException() - 异常错误 的构造器org.apache.hadoop.hbase.RegionException
default constructor
RegionException(String) - 异常错误 的构造器org.apache.hadoop.hbase.RegionException
Constructor
RegionInRecoveryException - org.apache.hadoop.hbase.exceptions中的异常错误
Thrown when a read request issued against a region which is in recovering state.
RegionInRecoveryException() - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.RegionInRecoveryException
default constructor
RegionInRecoveryException(String) - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.RegionInRecoveryException
Constructor
RegionLoad - org.apache.hadoop.hbase中的类
Encapsulates per-region load metrics.
RegionLoad(ClusterStatusProtos.RegionLoad) - 类 的构造器org.apache.hadoop.hbase.RegionLoad
 
regionLoadPB - 类 中的变量org.apache.hadoop.hbase.RegionLoad
 
RegionLocations - org.apache.hadoop.hbase中的类
Container for holding a list of HRegionLocation's that correspond to the same range.
RegionLocations(HRegionLocation...) - 类 的构造器org.apache.hadoop.hbase.RegionLocations
Constructs the region location list.
RegionLocations(Collection<HRegionLocation>) - 类 的构造器org.apache.hadoop.hbase.RegionLocations
 
RegionLocator - org.apache.hadoop.hbase.client中的接口
Used to view region location information for a single HBase table.
RegionMovedException - org.apache.hadoop.hbase.exceptions中的异常错误
Subclass if the server knows the region is now on another server.
RegionMovedException(ServerName, long) - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.RegionMovedException
 
RegionMovedException(String) - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.RegionMovedException
For hadoop.ipc internal call.
RegionOfflineException - org.apache.hadoop.hbase.client中的异常错误
Thrown when a table can not be located
RegionOfflineException() - 异常错误 的构造器org.apache.hadoop.hbase.client.RegionOfflineException
default constructor
RegionOfflineException(String) - 异常错误 的构造器org.apache.hadoop.hbase.client.RegionOfflineException
 
RegionOpeningException - org.apache.hadoop.hbase.exceptions中的异常错误
Subclass if the server knows the region is now on another server.
RegionOpeningException(String) - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.RegionOpeningException
 
RegionOpeningState - org.apache.hadoop.hbase.regionserver中的枚举
 
RegionReplicaUtil - org.apache.hadoop.hbase.client中的类
Utility methods which contain the logic for regions and replicas.
RegionReplicaUtil() - 类 的构造器org.apache.hadoop.hbase.client.RegionReplicaUtil
 
REGIONS_SCANNED_METRIC_NAME - 类 中的静态变量org.apache.hadoop.hbase.client.metrics.ScanMetrics
 
regionSequenceIdsToByteArray(Long, Map<byte[], Long>) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
 
RegionServerAbortedException - org.apache.hadoop.hbase.regionserver中的异常错误
Thrown by the region server when it is aborting.
RegionServerAbortedException(String) - 异常错误 的构造器org.apache.hadoop.hbase.regionserver.RegionServerAbortedException
 
RegionServerCallable<T> - org.apache.hadoop.hbase.client中的类
Implementations call a RegionServer and implement RetryingCallable.call(int).
RegionServerCallable(Connection, TableName, byte[]) - 类 的构造器org.apache.hadoop.hbase.client.RegionServerCallable
 
RegionServerCallable(Connection, TableName, byte[], int) - 类 的构造器org.apache.hadoop.hbase.client.RegionServerCallable
 
RegionServerCoprocessorRpcChannel - org.apache.hadoop.hbase.ipc中的类
Provides clients with an RPC connection to call coprocessor endpoint Services against a given region server.
RegionServerCoprocessorRpcChannel(ClusterConnection, ServerName) - 类 的构造器org.apache.hadoop.hbase.ipc.RegionServerCoprocessorRpcChannel
 
regionServerRemoved(String) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationListener
A region server has been removed from the local cluster
RegionServerRunningException - org.apache.hadoop.hbase.regionserver中的异常错误
Thrown if the region server log directory exists (which indicates another region server is running at the same address)
RegionServerRunningException() - 异常错误 的构造器org.apache.hadoop.hbase.regionserver.RegionServerRunningException
Default Constructor
RegionServerRunningException(String) - 异常错误 的构造器org.apache.hadoop.hbase.regionserver.RegionServerRunningException
Constructs the exception and supplies a string as the message
RegionServerStoppedException - org.apache.hadoop.hbase.regionserver中的异常错误
Thrown by the region server when it is in shutting down state.
RegionServerStoppedException(String) - 异常错误 的构造器org.apache.hadoop.hbase.regionserver.RegionServerStoppedException
 
RegionState - org.apache.hadoop.hbase.master中的类
State of a Region while undergoing transitions.
RegionState() - 类 的构造器org.apache.hadoop.hbase.master.RegionState
 
RegionState(HRegionInfo, RegionState.State) - 类 的构造器org.apache.hadoop.hbase.master.RegionState
 
RegionState(HRegionInfo, RegionState.State, ServerName) - 类 的构造器org.apache.hadoop.hbase.master.RegionState
 
RegionState(HRegionInfo, RegionState.State, long, ServerName) - 类 的构造器org.apache.hadoop.hbase.master.RegionState
 
RegionState(HRegionInfo, RegionState.State, long, ServerName, long) - 类 的构造器org.apache.hadoop.hbase.master.RegionState
 
RegionState.State - org.apache.hadoop.hbase.master中的枚举
 
RegionTooBusyException - org.apache.hadoop.hbase中的异常错误
Thrown by a region server if it will block and wait to serve a request.
RegionTooBusyException() - 异常错误 的构造器org.apache.hadoop.hbase.RegionTooBusyException
default constructor
RegionTooBusyException(String) - 异常错误 的构造器org.apache.hadoop.hbase.RegionTooBusyException
Constructor
RegionTransition - org.apache.hadoop.hbase中的类
Current state of a region in transition.
registerFilter(String, String) - 类 中的静态方法org.apache.hadoop.hbase.filter.ParseFilter
Register a new filter with the parser.
registerListener(ReplicationListener) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationTracker
Register a replication listener to receive replication events.
registerListener(ReplicationListener) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl
 
registerListener(ZooKeeperListener) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Register the specified listener to receive ZooKeeper events.
registerListenerFirst(ZooKeeperListener) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Register the specified listener to receive ZooKeeper events and add it as the first in the list of current listeners.
releaseHTableInterface(HTableInterface) - 类 中的方法org.apache.hadoop.hbase.client.HTableFactory
已过时。
 
releaseHTableInterface(HTableInterface) - 接口 中的方法org.apache.hadoop.hbase.client.HTableInterfaceFactory
已过时。
Release the HTable resource represented by the table.
relocateRegion(TableName, byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
Find the location of the region of tableName that row lives in, ignoring any value that might be in the cache.
relocateRegion(TableName, byte[], int) - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
Find the location of the region of tableName that row lives in, ignoring any value that might be in the cache.
relocateRegion(TableName, byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
internal method, do not use thru HConnection
relocateRegion(byte[], byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
REMOTE_RPC_CALLS_METRIC_NAME - 类 中的静态变量org.apache.hadoop.hbase.client.metrics.ScanMetrics
 
REMOTE_RPC_RETRIES_METRIC_NAME - 类 中的静态变量org.apache.hadoop.hbase.client.metrics.ScanMetrics
 
RemoteExceptionHandler - org.apache.hadoop.hbase中的类
An immutable class which contains a static method for handling org.apache.hadoop.ipc.RemoteException exceptions.
RemoteWithExtrasException - org.apache.hadoop.hbase.ipc中的异常错误
A RemoteException with some extra information.
RemoteWithExtrasException(String, String, boolean) - 异常错误 的构造器org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
 
RemoteWithExtrasException(String, String, String, int, boolean) - 异常错误 的构造器org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
 
remove(byte[]) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
remove(String) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Remove metadata represented by the key from the HTableDescriptor.values map
remove(ImmutableBytesWritable) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Remove metadata represented by the key from the HTableDescriptor.values map
remove(byte[]) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Remove metadata represented by the key from the HTableDescriptor.values map
remove(HRegionLocation) - 类 中的方法org.apache.hadoop.hbase.RegionLocations
Removes the given location from the list
remove(int) - 类 中的方法org.apache.hadoop.hbase.RegionLocations
Removes location of the given replicaId from the list
remove(R) - 接口 中的方法org.apache.hadoop.hbase.util.PoolMap.Pool
 
remove(Object) - 类 中的方法org.apache.hadoop.hbase.util.PoolMap
 
removeAllQueues() - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationQueues
Remove all replication queues for this region server.
removeAllQueues() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
removeByServer(ServerName) - 类 中的方法org.apache.hadoop.hbase.RegionLocations
Returns a new RegionLocations with the locations removed (set to null) which have the destination server as given.
removeConfiguration(String) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
Remove a configuration setting represented by the key from the HColumnDescriptor.configuration map.
removeConfiguration(String) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Remove a config setting represented by the key from the HTableDescriptor.configuration map
removeCoprocessor(String) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Remove a coprocessor from those set on the table
removeFamily(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
 
removeFamily(byte[]) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Removes the HColumnDescriptor with name specified by the parameter column from the table descriptor
removeHFileRefs(String, List<String>) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationQueues
Remove hfile references from the queue.
removeHFileRefs(String, List<String>) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
removeListener(ReplicationPeerConfigListener) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl.PeerConfigTracker
 
removeListener(ReplicationListener) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationTracker
 
removeListener(ReplicationListener) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl
 
removeListenerOfPeerConfig(ReplicationPeerConfigListener) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeer
Remove a listener when it is closed or terminated
removeListenerOfPeerConfig(ReplicationPeerConfigListener) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
 
removeLog(String, String) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationQueues
Remove an WAL file from the given queue.
removeLog(String, String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
removeMetaData(byte[]) - 类 中的方法org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
removeNonDefaultRegions(Collection<HRegionInfo>) - 类 中的静态方法org.apache.hadoop.hbase.client.RegionReplicaUtil
Removes the non-default replicas from the passed regions collection
removePeer(String) - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Removes a peer cluster and stops the replication to it.
removePeer(String) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeers
Removes a remote slave cluster and stops the replication to it.
removePeer(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
removePeerFromHFileRefs(String) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationQueues
Remove a peer from hfile reference queue.
removePeerFromHFileRefs(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
removePeerTableCFs(String, String) - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Remove some table-cfs from table-cfs config of the specified peer
removePeerTableCFs(String, Map<TableName, ? extends Collection<String>>) - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Remove some table-cfs from config of the specified peer
removeQueue(String) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationQueues
Remove a replication queue.
removeQueue(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
removeQuotesFromByteArray(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.ParseFilter
Takes a quoted byte array and converts it into an unquoted byte array For example: given a byte array representing 'abc', it returns a byte array representing abc
removeRegionReplicasFromMeta(Set<byte[]>, int, int, Connection) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Deletes some replica columns corresponding to replicas for the passed rows
removeReplicatorIfQueueIsEmpty(String) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationQueues
Remove the znode of region server if the queue is empty.
removeReplicatorIfQueueIsEmpty(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
removeValue(K, V) - 类 中的方法org.apache.hadoop.hbase.util.PoolMap
 
renew - 类 中的变量org.apache.hadoop.hbase.client.ScannerCallable
 
renewLease() - 类 中的方法org.apache.hadoop.hbase.client.ClientScanner
 
renewLease() - 接口 中的方法org.apache.hadoop.hbase.client.ResultScanner
Allow the client to renew the scanner's lease on the server.
REPLICA_ID_DELIMITER - 类 中的静态变量org.apache.hadoop.hbase.HRegionInfo
 
REPLICA_ID_FORMAT - 类 中的静态变量org.apache.hadoop.hbase.HRegionInfo
 
replicaId - 类 中的变量org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
REPLICATION_SCOPE - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
 
REPLICATION_SCOPE_BYTES - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
 
REPLICATION_WALENTRYFILTER_CONFIG_KEY - 类 中的静态变量org.apache.hadoop.hbase.client.replication.ReplicationAdmin
 
ReplicationAdmin - org.apache.hadoop.hbase.client.replication中的类
This class provides the administrative interface to HBase cluster replication.
ReplicationAdmin(Configuration) - 类 的构造器org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Constructor that creates a connection to the local ZooKeeper ensemble.
ReplicationException - org.apache.hadoop.hbase.replication中的异常错误
An HBase Replication exception.
ReplicationException() - 异常错误 的构造器org.apache.hadoop.hbase.replication.ReplicationException
 
ReplicationException(String) - 异常错误 的构造器org.apache.hadoop.hbase.replication.ReplicationException
 
ReplicationException(String, Throwable) - 异常错误 的构造器org.apache.hadoop.hbase.replication.ReplicationException
 
ReplicationException(Throwable) - 异常错误 的构造器org.apache.hadoop.hbase.replication.ReplicationException
 
ReplicationFactory - org.apache.hadoop.hbase.replication中的类
A factory class for instantiating replication objects that deal with replication state.
ReplicationFactory() - 类 的构造器org.apache.hadoop.hbase.replication.ReplicationFactory
 
REPLICATIONGLOBAL - 类 中的静态变量org.apache.hadoop.hbase.client.replication.ReplicationAdmin
 
ReplicationListener - org.apache.hadoop.hbase.replication中的接口
The replication listener interface can be implemented if a class needs to subscribe to events generated by the ReplicationTracker.
ReplicationLoadSink - org.apache.hadoop.hbase.replication中的类
A HBase ReplicationLoad to present MetricsSink information
ReplicationLoadSink(long, long) - 类 的构造器org.apache.hadoop.hbase.replication.ReplicationLoadSink
 
ReplicationLoadSource - org.apache.hadoop.hbase.replication中的类
A HBase ReplicationLoad to present MetricsSource information
ReplicationLoadSource(String, long, int, long, long) - 类 的构造器org.apache.hadoop.hbase.replication.ReplicationLoadSource
 
ReplicationPeer - org.apache.hadoop.hbase.replication中的接口
ReplicationPeer manages enabled / disabled state for the peer.
ReplicationPeer.PeerState - org.apache.hadoop.hbase.replication中的枚举
State of the peer, whether it is enabled or not
ReplicationPeerConfig - org.apache.hadoop.hbase.replication中的类
A configuration for the replication peer cluster.
ReplicationPeerConfig() - 类 的构造器org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
ReplicationPeerConfigListener - org.apache.hadoop.hbase.replication中的接口
 
ReplicationPeers - org.apache.hadoop.hbase.replication中的接口
This provides an interface for maintaining a set of peer clusters.
ReplicationPeersZKImpl - org.apache.hadoop.hbase.replication中的类
This class provides an implementation of the ReplicationPeers interface using Zookeeper.
ReplicationPeersZKImpl(ZooKeeperWatcher, Configuration, ReplicationQueuesClient, Abortable) - 类 的构造器org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
ReplicationPeerZKImpl - org.apache.hadoop.hbase.replication中的类
 
ReplicationPeerZKImpl(ZooKeeperWatcher, Configuration, String, ReplicationPeerConfig, Abortable) - 类 的构造器org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
Constructor that takes all the objects required to communicate with the specified peer, except for the region server addresses.
ReplicationPeerZKImpl.PeerConfigTracker - org.apache.hadoop.hbase.replication中的类
Tracker for PeerConfigNode of this peer
ReplicationPeerZKImpl.PeerConfigTracker(String, ZooKeeperWatcher, Abortable) - 类 的构造器org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl.PeerConfigTracker
 
ReplicationPeerZKImpl.PeerStateTracker - org.apache.hadoop.hbase.replication中的类
Tracker for state of this peer
ReplicationPeerZKImpl.PeerStateTracker(String, ZooKeeperWatcher, Abortable) - 类 的构造器org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl.PeerStateTracker
 
ReplicationQueueInfo - org.apache.hadoop.hbase.replication中的类
This class is responsible for the parsing logic for a znode representing a queue.
ReplicationQueueInfo(String) - 类 的构造器org.apache.hadoop.hbase.replication.ReplicationQueueInfo
The passed znode will be either the id of the peer cluster or the handling story of that queue in the form of id-servername-*
ReplicationQueues - org.apache.hadoop.hbase.replication中的接口
This provides an interface for maintaining a region server's replication queues.
ReplicationQueuesClient - org.apache.hadoop.hbase.replication中的接口
This provides an interface for clients of replication to view replication queues.
ReplicationQueuesClientZKImpl - org.apache.hadoop.hbase.replication中的类
 
ReplicationQueuesClientZKImpl(ZooKeeperWatcher, Configuration, Abortable) - 类 的构造器org.apache.hadoop.hbase.replication.ReplicationQueuesClientZKImpl
 
ReplicationQueuesZKImpl - org.apache.hadoop.hbase.replication中的类
This class provides an implementation of the ReplicationQueues interface using Zookeeper.
ReplicationQueuesZKImpl(ZooKeeperWatcher, Configuration, Abortable) - 类 的构造器org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
ReplicationSerDeHelper - org.apache.hadoop.hbase.replication中的类
 
ReplicationStateZKBase - org.apache.hadoop.hbase.replication中的类
This is a base class for maintaining replication state in zookeeper.
ReplicationStateZKBase(ZooKeeperWatcher, Configuration, Abortable) - 类 的构造器org.apache.hadoop.hbase.replication.ReplicationStateZKBase
 
ReplicationTracker - org.apache.hadoop.hbase.replication中的接口
This is the interface for a Replication Tracker.
ReplicationTrackerZKImpl - org.apache.hadoop.hbase.replication中的类
This class is a Zookeeper implementation of the ReplicationTracker interface.
ReplicationTrackerZKImpl(ZooKeeperWatcher, ReplicationPeers, Configuration, Abortable, Stoppable) - 类 的构造器org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl
 
ReplicationTrackerZKImpl.OtherRegionServerWatcher - org.apache.hadoop.hbase.replication中的类
Watcher used to be notified of the other region server's death in the local cluster.
ReplicationTrackerZKImpl.OtherRegionServerWatcher(ZooKeeperWatcher) - 类 的构造器org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl.OtherRegionServerWatcher
Construct a ZooKeeper event listener.
ReplicationTrackerZKImpl.PeersWatcher - org.apache.hadoop.hbase.replication中的类
Watcher used to follow the creation and deletion of peer clusters.
ReplicationTrackerZKImpl.PeersWatcher(ZooKeeperWatcher) - 类 的构造器org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl.PeersWatcher
Construct a ZooKeeper event listener.
REPLICATIONTYPE - 类 中的静态变量org.apache.hadoop.hbase.client.replication.ReplicationAdmin
 
replicationZNode - 类 中的变量org.apache.hadoop.hbase.replication.ReplicationStateZKBase
The name of the base znode that contains all replication state.
RequestConverter - org.apache.hadoop.hbase.protobuf中的类
Helper utility to build protocol buffer requests, or build components for protocol buffer requests.
RequestTooBigException - org.apache.hadoop.hbase.exceptions中的异常错误
Thrown when the size of the rpc request received by the server is too large.
RequestTooBigException() - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.RequestTooBigException
 
RequestTooBigException(String) - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.RequestTooBigException
 
reset() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
reset() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
reset() - 类 中的方法org.apache.hadoop.hbase.filter.DependentColumnFilter
 
reset() - 类 中的方法org.apache.hadoop.hbase.filter.Filter
Reset the state of the filter between rows.
reset() - 类 中的方法org.apache.hadoop.hbase.filter.FilterBase
Filters that are purely stateless and do nothing in their reset() methods can inherit this null/empty implementation.
reset() - 类 中的方法org.apache.hadoop.hbase.filter.FilterList
 
reset() - 类 中的方法org.apache.hadoop.hbase.filter.FilterListWithAND
 
reset() - 类 中的方法org.apache.hadoop.hbase.filter.FilterListWithOR
 
reset() - 类 中的方法org.apache.hadoop.hbase.filter.FilterWrapper
 
reset() - 类 中的方法org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
reset() - 类 中的方法org.apache.hadoop.hbase.filter.PrefixFilter
 
reset() - 类 中的方法org.apache.hadoop.hbase.filter.RandomRowFilter
 
reset() - 类 中的方法org.apache.hadoop.hbase.filter.RowFilter
 
reset() - 类 中的方法org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
reset() - 类 中的方法org.apache.hadoop.hbase.filter.SkipFilter
 
reset() - 类 中的方法org.apache.hadoop.hbase.filter.WhileMatchFilter
 
reset() - 类 中的方法org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
reset() - 类 中的方法org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
reset() - 类 中的方法org.apache.hadoop.hbase.ipc.ServerRpcController
 
ResponseConverter - org.apache.hadoop.hbase.protobuf中的类
Helper utility to build protocol buffer responses, or retrieve data from protocol buffer responses.
restoreSnapshot(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Restore the specified snapshot on the original table.
restoreSnapshot(String) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Restore the specified snapshot on the original table.
restoreSnapshot(byte[], boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Restore the specified snapshot on the original table.
restoreSnapshot(String, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Restore the specified snapshot on the original table.
restoreSnapshot(String, boolean, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Restore the specified snapshot on the original table.
restoreSnapshot(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Restore the specified snapshot on the original table.
restoreSnapshot(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Restore the specified snapshot on the original table.
restoreSnapshot(byte[], boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Restore the specified snapshot on the original table.
restoreSnapshot(String, boolean, boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Restore the specified snapshot on the original table.
restoreSnapshot(String, boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
RestoreSnapshotException - org.apache.hadoop.hbase.snapshot中的异常错误
Thrown when a snapshot could not be restored due to a server-side error when restoring it.
RestoreSnapshotException(String, HBaseProtos.SnapshotDescription) - 异常错误 的构造器org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
已过时。
since 1.3.0, will be removed in 3.0.0
RestoreSnapshotException(String, Throwable, HBaseProtos.SnapshotDescription) - 异常错误 的构造器org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
已过时。
since 1.3.0, will be removed in 3.0.0
RestoreSnapshotException(String) - 异常错误 的构造器org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
 
RestoreSnapshotException(String, Exception) - 异常错误 的构造器org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
 
Result - org.apache.hadoop.hbase.client中的类
Single row result of a Get or Scan query.
Result() - 类 的构造器org.apache.hadoop.hbase.client.Result
Creates an empty Result w/ no KeyValue payload; returns null if you call Result.rawCells().
Result(KeyValue[]) - 类 的构造器org.apache.hadoop.hbase.client.Result
已过时。
Use Result.create(List) instead.
Result(List<KeyValue>) - 类 的构造器org.apache.hadoop.hbase.client.Result
已过时。
Use Result.create(List) instead.
ResultBoundedCompletionService<V> - org.apache.hadoop.hbase.client中的类
A completion service for the RpcRetryingCallerFactory.
ResultBoundedCompletionService(RpcRetryingCallerFactory, Executor, int) - 类 的构造器org.apache.hadoop.hbase.client.ResultBoundedCompletionService
 
ResultScanner - org.apache.hadoop.hbase.client中的接口
Interface for client-side scanning.
ResultStatsUtil - org.apache.hadoop.hbase.client中的类
A Result with some statistics about the server/region status
RETRIES_BY_SERVER_KEY - 类 中的静态变量org.apache.hadoop.hbase.client.HConnectionManager
已过时。
RetriesExhaustedException - org.apache.hadoop.hbase.client中的异常错误
Exception thrown by HTable methods when an attempt to do something (like commit changes) fails after a bunch of retries.
RetriesExhaustedException(String) - 异常错误 的构造器org.apache.hadoop.hbase.client.RetriesExhaustedException
 
RetriesExhaustedException(String, IOException) - 异常错误 的构造器org.apache.hadoop.hbase.client.RetriesExhaustedException
 
RetriesExhaustedException(String, int, List<Throwable>) - 异常错误 的构造器org.apache.hadoop.hbase.client.RetriesExhaustedException
Create a new RetriesExhaustedException from the list of prior failures.
RetriesExhaustedException(int, List<RetriesExhaustedException.ThrowableWithExtraContext>) - 异常错误 的构造器org.apache.hadoop.hbase.client.RetriesExhaustedException
Create a new RetriesExhaustedException from the list of prior failures.
RetriesExhaustedException.ThrowableWithExtraContext - org.apache.hadoop.hbase.client中的类
Datastructure that allows adding more info around Throwable incident.
RetriesExhaustedException.ThrowableWithExtraContext(Throwable, long, String) - 类 的构造器org.apache.hadoop.hbase.client.RetriesExhaustedException.ThrowableWithExtraContext
 
RetriesExhaustedWithDetailsException - org.apache.hadoop.hbase.client中的异常错误
This subclass of RetriesExhaustedException is thrown when we have more information about which rows were causing which exceptions on what servers.
RetriesExhaustedWithDetailsException(String) - 异常错误 的构造器org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
RetriesExhaustedWithDetailsException(String, IOException) - 异常错误 的构造器org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
RetriesExhaustedWithDetailsException(List<Throwable>, List<Row>, List<String>) - 异常错误 的构造器org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
RetryImmediatelyException - org.apache.hadoop.hbase中的异常错误
 
RetryImmediatelyException(String) - 异常错误 的构造器org.apache.hadoop.hbase.RetryImmediatelyException
 
RetryingCallable<T> - org.apache.hadoop.hbase.client中的接口
A Callable<T> that will be retried.
RETURN_RESULTS - 类 中的静态变量org.apache.hadoop.hbase.client.Mutation
已过时。
this field is private as of HBase 2.0.
reversed - 类 中的变量org.apache.hadoop.hbase.filter.Filter
 
ReversedClientScanner - org.apache.hadoop.hbase.client中的类
A reversed client scanner which support backward scanning
ReversedClientScanner(Configuration, Scan, TableName, ClusterConnection, RpcRetryingCallerFactory, RpcControllerFactory, ExecutorService, int) - 类 的构造器org.apache.hadoop.hbase.client.ReversedClientScanner
Create a new ReversibleClientScanner for the specified table Note that the passed Scan's start row maybe changed.
ReversedScannerCallable - org.apache.hadoop.hbase.client中的类
A reversed ScannerCallable which supports backward scanning.
ReversedScannerCallable(ClusterConnection, TableName, Scan, ScanMetrics, RpcControllerFactory) - 类 的构造器org.apache.hadoop.hbase.client.ReversedScannerCallable
 
ReversedScannerCallable(ClusterConnection, TableName, Scan, ScanMetrics, RpcControllerFactory, int) - 类 的构造器org.apache.hadoop.hbase.client.ReversedScannerCallable
 
revoke(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
A utility used to revoke a user's global permissions.
revoke(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, TableName, byte[], byte[], Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
A utility used to revoke a user's table permissions.
revoke(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, String, Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
A utility used to revoke a user's namespace permissions.
revoke(Connection, TableName, String, byte[], byte[], Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlClient
Revokes the permission on the table
revoke(Connection, String, String, Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlClient
Revokes the permission on the table for the specified user.
revoke(Connection, String, Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlClient
Revoke global permissions for the specified user.
revoke(Configuration, TableName, String, byte[], byte[], Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlClient
revoke(Configuration, String, String, Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlClient
revoke(Configuration, String, Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlClient
rollHLogWriter(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
rollWALWriter(ServerName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Roll the log writer.
rollWALWriter(ServerName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
row - 类 中的变量org.apache.hadoop.hbase.client.Mutation
 
row - 类 中的变量org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
row - 类 中的变量org.apache.hadoop.hbase.client.RegionServerCallable
 
Row - org.apache.hadoop.hbase.client中的接口
Has a row.
rowCount(TableName, ColumnInterpreter<R, S, P, Q, T>, Scan) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.AggregationClient
It gives the row count, by summing up the individual results obtained from regions.
rowCount(Table, ColumnInterpreter<R, S, P, Q, T>, Scan) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.AggregationClient
It gives the row count, by summing up the individual results obtained from regions.
RowFilter - org.apache.hadoop.hbase.filter中的类
This filter is used to filter based on the key.
RowFilter(CompareFilter.CompareOp, ByteArrayComparable) - 类 的构造器org.apache.hadoop.hbase.filter.RowFilter
Constructor.
RowMutations - org.apache.hadoop.hbase.client中的类
Performs multiple mutations atomically on a single row.
RowMutations() - 类 的构造器org.apache.hadoop.hbase.client.RowMutations
Constructor for Writable.
RowMutations(byte[]) - 类 的构造器org.apache.hadoop.hbase.client.RowMutations
Create an atomic mutation for the specified row.
RowTooBigException - org.apache.hadoop.hbase.client中的异常错误
Gets or Scans throw this exception if running without in-row scan flag set and row size appears to exceed max configured size (configurable via hbase.table.max.rowsize).
RowTooBigException(String) - 异常错误 的构造器org.apache.hadoop.hbase.client.RowTooBigException
 
RPAREN - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for RPAREN
RPC_CALLS_METRIC_NAME - 类 中的静态变量org.apache.hadoop.hbase.client.metrics.ScanMetrics
 
RPC_RETRIES_METRIC_NAME - 类 中的静态变量org.apache.hadoop.hbase.client.metrics.ScanMetrics
 
RpcClient - org.apache.hadoop.hbase.ipc中的接口
Interface for RpcClient implementations so ConnectionManager can handle it.
RpcClientFactory - org.apache.hadoop.hbase.ipc中的类
Factory to create a RpcClient
rpcControllerFactory - 类 中的变量org.apache.hadoop.hbase.client.ClientScanner
 
rpcControllerFactory - 类 中的变量org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
RpcControllerFactory - org.apache.hadoop.hbase.ipc中的类
Factory to create a HBaseRpcController.
RpcControllerFactory(Configuration) - 类 的构造器org.apache.hadoop.hbase.ipc.RpcControllerFactory
 
rpcHistograms - 类 中的变量org.apache.hadoop.hbase.client.MetricsConnection
 
RpcRetryingCaller<T> - org.apache.hadoop.hbase.client中的类
Runs an rpc'ing RetryingCallable.
RpcRetryingCaller(long, long, int, int) - 类 的构造器org.apache.hadoop.hbase.client.RpcRetryingCaller
 
RpcRetryingCaller(long, long, int, RetryingCallerInterceptor, int, int) - 类 的构造器org.apache.hadoop.hbase.client.RpcRetryingCaller
 
RpcRetryingCallerFactory - org.apache.hadoop.hbase.client中的类
Factory to create an RpcRetryingCaller
RpcRetryingCallerFactory(Configuration) - 类 的构造器org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
 
RpcRetryingCallerFactory(Configuration, RetryingCallerInterceptor) - 类 的构造器org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
 
RpcRetryingCallerWithReadReplicas - org.apache.hadoop.hbase.client中的类
Caller that goes to replica if the primary region does no answer within a configurable timeout.
RpcRetryingCallerWithReadReplicas(RpcControllerFactory, TableName, ClusterConnection, Get, ExecutorService, int, int, int) - 类 的构造器org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
 
rpcTimers - 类 中的变量org.apache.hadoop.hbase.client.MetricsConnection
 
RS_LOCK_ZNODE - 类 中的静态变量org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
Name of znode we use to lock during failover
rsZNode - 类 中的变量org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
run() - 类 中的方法org.apache.hadoop.hbase.client.DelayingRunner
 
run(R) - 类 中的方法org.apache.hadoop.hbase.ipc.BlockingRpcCallback
Called on completion of the RPC call with the response object, or null in the case of an error.
run(boolean) - 接口 中的方法org.apache.hadoop.hbase.ipc.HBaseRpcController.CancellationCallback
 
run(String[]) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZkAclReset
 
runCatalogScan() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Ask for a scan of the catalog table
runCatalogScan() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Ask for a scan of the catalog table
runCleanerChore() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Ask for cleaner chore to run
runCleanerChore() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
runnerStats - 类 中的变量org.apache.hadoop.hbase.client.MetricsConnection
 
running - 类 中的变量org.apache.hadoop.hbase.ipc.AbstractRpcClient
 

S

S - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'S'
SASL_DEFAULT_REALM - 类 中的静态变量org.apache.hadoop.hbase.security.SaslUtil
 
SaslChallengeDecoder - org.apache.hadoop.hbase.security中的类
Decode the sasl challenge sent by RpcServer.
SaslChallengeDecoder() - 类 的构造器org.apache.hadoop.hbase.security.SaslChallengeDecoder
 
saslClient - 类 中的变量org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
 
saslConnect(InputStream, OutputStream) - 类 中的方法org.apache.hadoop.hbase.security.HBaseSaslRpcClient
Do client side SASL authentication with server via the given InputStream and OutputStream
saslLatch - 类 中的变量org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
saslProps - 类 中的变量org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
 
SaslStatus - org.apache.hadoop.hbase.security中的枚举
 
SaslUnwrapHandler - org.apache.hadoop.hbase.security中的类
Unwrap sasl messages.
SaslUnwrapHandler(SaslClient) - 类 的构造器org.apache.hadoop.hbase.security.SaslUnwrapHandler
 
SaslUtil - org.apache.hadoop.hbase.security中的类
 
SaslUtil() - 类 的构造器org.apache.hadoop.hbase.security.SaslUtil
 
SaslUtil.QualityOfProtection - org.apache.hadoop.hbase.security中的枚举
 
SaslWrapHandler - org.apache.hadoop.hbase.security中的类
wrap sasl messages.
SaslWrapHandler(SaslClient) - 类 的构造器org.apache.hadoop.hbase.security.SaslWrapHandler
 
scan - 类 中的变量org.apache.hadoop.hbase.client.ClientScanner
 
Scan - org.apache.hadoop.hbase.client中的类
Used to perform Scan operations.
Scan() - 类 的构造器org.apache.hadoop.hbase.client.Scan
Create a Scan operation across all rows.
Scan(byte[], Filter) - 类 的构造器org.apache.hadoop.hbase.client.Scan
已过时。
use new Scan().withStartRow(startRow).setFilter(filter) instead.
Scan(byte[]) - 类 的构造器org.apache.hadoop.hbase.client.Scan
已过时。
use new Scan().withStartRow(startRow) instead.
Scan(byte[], byte[]) - 类 的构造器org.apache.hadoop.hbase.client.Scan
已过时。
use new Scan().withStartRow(startRow).withStopRow(stopRow) instead.
Scan(Scan) - 类 的构造器org.apache.hadoop.hbase.client.Scan
Creates a new instance of this class while copying all values.
Scan(Get) - 类 的构造器org.apache.hadoop.hbase.client.Scan
Builds a scan object with the same specs as get.
scan - 类 中的变量org.apache.hadoop.hbase.client.ScannerCallable
 
Scan.ReadType - org.apache.hadoop.hbase.client中的枚举
 
SCAN_ATTRIBUTES_METRICS_DATA - 类 中的静态变量org.apache.hadoop.hbase.client.Scan
已过时。
SCAN_ATTRIBUTES_METRICS_ENABLE - 类 中的静态变量org.apache.hadoop.hbase.client.Scan
已过时。
SCAN_ATTRIBUTES_TABLE_NAME - 类 中的静态变量org.apache.hadoop.hbase.client.Scan
 
scanMetrics - 类 中的变量org.apache.hadoop.hbase.client.AbstractClientScanner
 
ScanMetrics - org.apache.hadoop.hbase.client.metrics中的类
Provides metrics related to scan operations (both server side and client side metrics).
ScanMetrics() - 类 的构造器org.apache.hadoop.hbase.client.metrics.ScanMetrics
constructor
scanMetrics - 类 中的变量org.apache.hadoop.hbase.client.ScannerCallable
 
scanMetricsPublished - 类 中的变量org.apache.hadoop.hbase.client.ClientScanner
 
scannerCaching - 类 中的变量org.apache.hadoop.hbase.client.HTable
 
ScannerCallable - org.apache.hadoop.hbase.client中的类
Scanner operations such as create, next, etc.
ScannerCallable(ClusterConnection, TableName, Scan, ScanMetrics, RpcControllerFactory) - 类 的构造器org.apache.hadoop.hbase.client.ScannerCallable
 
ScannerCallable(ClusterConnection, TableName, Scan, ScanMetrics, RpcControllerFactory, int) - 类 的构造器org.apache.hadoop.hbase.client.ScannerCallable
 
scannerId - 类 中的变量org.apache.hadoop.hbase.client.ScannerCallable
 
scannerMaxResultSize - 类 中的变量org.apache.hadoop.hbase.client.HTable
 
ScannerResetException - org.apache.hadoop.hbase.exceptions中的异常错误
Thrown when the server side has received an Exception, and asks the Client to reset the scanner state by closing the current region scanner, and reopening from the start of last seen row.
ScannerResetException() - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.ScannerResetException
constructor
ScannerResetException(String) - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.ScannerResetException
Constructor
ScannerResetException(String, Exception) - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.ScannerResetException
 
scannerTimeout - 类 中的变量org.apache.hadoop.hbase.client.ClientScanner
 
ScannerTimeoutException - org.apache.hadoop.hbase.client中的异常错误
Thrown when a scanner has timed out.
ScanResultCache - org.apache.hadoop.hbase.client中的类
Used to separate the row constructing logic.
scanTracker - 类 中的变量org.apache.hadoop.hbase.client.MetricsConnection
 
SecureBulkLoadClient - org.apache.hadoop.hbase.client.coprocessor中的类
Client proxy for SecureBulkLoadProtocol used in conjunction with SecureBulkLoadEndpoint
SecureBulkLoadClient(Table) - 类 的构造器org.apache.hadoop.hbase.client.coprocessor.SecureBulkLoadClient
 
SecureBulkLoadUtil - org.apache.hadoop.hbase.security中的类
 
SecureBulkLoadUtil() - 类 的构造器org.apache.hadoop.hbase.security.SecureBulkLoadUtil
 
SecurityCapability - org.apache.hadoop.hbase.client.security中的枚举
Available security capabilities
SecurityInfo - org.apache.hadoop.hbase.security中的类
Maps RPC protocol interfaces to required configuration
SecurityInfo(String, AuthenticationProtos.TokenIdentifier.Kind) - 类 的构造器org.apache.hadoop.hbase.security.SecurityInfo
 
selectToken(Text, Collection<Token<? extends TokenIdentifier>>) - 类 中的方法org.apache.hadoop.hbase.security.token.AuthenticationTokenSelector
 
sequenceNumber - 类 中的变量org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
ServerLoad - org.apache.hadoop.hbase中的类
This class is used for exporting current state of load on a RegionServer.
ServerLoad(ClusterStatusProtos.ServerLoad) - 类 的构造器org.apache.hadoop.hbase.ServerLoad
 
serverLoad - 类 中的变量org.apache.hadoop.hbase.ServerLoad
 
ServerName - org.apache.hadoop.hbase中的类
Instance of an HBase ServerName.
SERVERNAME_PATTERN - 类 中的静态变量org.apache.hadoop.hbase.ServerName
 
SERVERNAME_SEPARATOR - 类 中的静态变量org.apache.hadoop.hbase.ServerName
This character is used as separator between server hostname, port and startcode.
ServerNotRunningYetException - org.apache.hadoop.hbase.ipc中的异常错误
 
ServerNotRunningYetException(String) - 异常错误 的构造器org.apache.hadoop.hbase.ipc.ServerNotRunningYetException
 
ServerRpcController - org.apache.hadoop.hbase.ipc中的类
Used for server-side protobuf RPC service invocations.
ServerRpcController() - 类 的构造器org.apache.hadoop.hbase.ipc.ServerRpcController
 
ServerSideScanMetrics - org.apache.hadoop.hbase.client.metrics中的类
Provides server side metrics related to scan operations.
ServerSideScanMetrics() - 类 的构造器org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
 
ServerStatistics - org.apache.hadoop.hbase.client.backoff中的类
Track the statistics for a single region
ServerStatistics() - 类 的构造器org.apache.hadoop.hbase.client.backoff.ServerStatistics
 
ServerStatistics.RegionStatistics - org.apache.hadoop.hbase.client.backoff中的类
 
ServerStatistics.RegionStatistics() - 类 的构造器org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
 
ServerStatisticTracker - org.apache.hadoop.hbase.client中的类
Tracks the statistics for multiple regions
ServerStatisticTracker() - 类 的构造器org.apache.hadoop.hbase.client.ServerStatisticTracker
 
serverStats - 类 中的变量org.apache.hadoop.hbase.client.MetricsConnection
 
ServerTooBusyException - org.apache.hadoop.hbase.ipc中的异常错误
Throw this in rpc call if there are too many pending requests for one region server
ServerTooBusyException(InetSocketAddress, long) - 异常错误 的构造器org.apache.hadoop.hbase.ipc.ServerTooBusyException
 
setACL(String, Permission) - 类 中的方法org.apache.hadoop.hbase.client.Append
 
setACL(Map<String, Permission>) - 类 中的方法org.apache.hadoop.hbase.client.Append
 
setACL(String, Permission) - 类 中的方法org.apache.hadoop.hbase.client.Delete
 
setACL(Map<String, Permission>) - 类 中的方法org.apache.hadoop.hbase.client.Delete
 
setACL(Map<String, Permission>) - 类 中的方法org.apache.hadoop.hbase.client.Get
 
setACL(String, Permission) - 类 中的方法org.apache.hadoop.hbase.client.Get
 
setACL(String, Permission) - 类 中的方法org.apache.hadoop.hbase.client.Increment
 
setACL(Map<String, Permission>) - 类 中的方法org.apache.hadoop.hbase.client.Increment
 
setACL(String, Permission) - 类 中的方法org.apache.hadoop.hbase.client.Mutation
 
setACL(Map<String, Permission>) - 类 中的方法org.apache.hadoop.hbase.client.Mutation
 
setACL(String, Permission) - 类 中的方法org.apache.hadoop.hbase.client.Put
 
setACL(Map<String, Permission>) - 类 中的方法org.apache.hadoop.hbase.client.Put
 
setACL(String, Permission) - 类 中的方法org.apache.hadoop.hbase.client.Query
 
setACL(Map<String, Permission>) - 类 中的方法org.apache.hadoop.hbase.client.Query
 
setACL(Map<String, Permission>) - 类 中的方法org.apache.hadoop.hbase.client.Scan
 
setACL(String, Permission) - 类 中的方法org.apache.hadoop.hbase.client.Scan
 
setAcl(String, List<ACL>, int) - 类 中的方法org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
setAcl is an idempotent operation.
setActions(Permission.Action[]) - 类 中的方法org.apache.hadoop.hbase.security.access.Permission
 
setAllowPartialResults(boolean) - 类 中的方法org.apache.hadoop.hbase.client.Scan
Setting whether the caller wants to see the partial results when server returns less-than-expected cells.
setAttribute(String, byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Append
 
setAttribute(String, byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Attributes
Sets an attribute.
setAttribute(String, byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Delete
 
setAttribute(String, byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Get
 
setAttribute(String, byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Increment
 
setAttribute(String, byte[]) - 类 中的方法org.apache.hadoop.hbase.client.OperationWithAttributes
 
setAttribute(String, byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Put
 
setAttribute(String, byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Scan
 
setAuthorizations(Authorizations) - 类 中的方法org.apache.hadoop.hbase.client.Get
 
setAuthorizations(Authorizations) - 类 中的方法org.apache.hadoop.hbase.client.Query
Sets the authorizations to be used by this Query
setAuthorizations(Authorizations) - 类 中的方法org.apache.hadoop.hbase.client.Scan
 
setAuths(Configuration, String[], String) - 类 中的静态方法org.apache.hadoop.hbase.security.visibility.VisibilityClient
setAuths(Connection, String[], String) - 类 中的静态方法org.apache.hadoop.hbase.security.visibility.VisibilityClient
Sets given labels globally authorized for the user.
setAutoFlush(boolean) - 类 中的方法org.apache.hadoop.hbase.client.HTable
已过时。
setAutoFlush(boolean, boolean) - 类 中的方法org.apache.hadoop.hbase.client.HTable
Turns 'auto-flush' on or off.
setAutoFlush(boolean) - 接口 中的方法org.apache.hadoop.hbase.client.HTableInterface
已过时。
in 0.96. When called with setAutoFlush(false), this function also set clearBufferOnFail to true, which is unexpected but kept for historical reasons. Replace it with setAutoFlush(false, false) if this is exactly what you want, though this is the method you want for most cases.
setAutoFlush(boolean, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.HTableInterface
已过时。
in 0.99 since setting clearBufferOnFail is deprecated. Use HTableInterface.setAutoFlush(boolean)} instead.
setAutoFlushTo(boolean) - 类 中的方法org.apache.hadoop.hbase.client.HTable
Set the autoFlush behavior, without changing the value of clearBufferOnFail.
setAutoFlushTo(boolean) - 接口 中的方法org.apache.hadoop.hbase.client.HTableInterface
已过时。
in 0.99 since setting clearBufferOnFail is deprecated. Use HTableInterface.setAutoFlush(boolean) instead, or better still, move on to BufferedMutator
setBalancerRunning(boolean, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Turn the load balancer on or off.
setBalancerRunning(boolean, boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Turn the load balancer on or off.
setBandwidth(long) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
setBatch(int) - 类 中的方法org.apache.hadoop.hbase.client.Scan
Set the maximum number of cells to return for each call to next().
setBlockCacheEnabled(boolean) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
setBlocksize(int) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
setBloomFilterType(BloomType) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
setCacheBlocks(boolean) - 类 中的方法org.apache.hadoop.hbase.client.Get
Set whether blocks should be cached for this Get.
setCacheBlocks(boolean) - 类 中的方法org.apache.hadoop.hbase.client.Scan
Set whether blocks should be cached for this Scan.
setCacheBloomsOnWrite(boolean) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
setCacheDataInL1(boolean) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
setCacheDataOnWrite(boolean) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
setCacheIndexesOnWrite(boolean) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
setCaching(int) - 类 中的方法org.apache.hadoop.hbase.client.Scan
Set the number of rows for caching that will be passed to scanners.
setCaching(int) - 类 中的方法org.apache.hadoop.hbase.client.ScannerCallable
Set the number of rows that will be fetched on next
setCallTimeMs(long) - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
setCallTimeout(int) - 类 中的方法org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
setCallTimeout(int) - 接口 中的方法org.apache.hadoop.hbase.ipc.HBaseRpcController
 
setCallTimeout(int) - 类 中的方法org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
setCellScanner(CellScanner) - 类 中的方法org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
setCellScanner(CellScanner) - 接口 中的方法org.apache.hadoop.hbase.ipc.HBaseRpcController
Only used to send cells to rpc server, the returned cells should be set by HBaseRpcController.setDone(CellScanner).
setCellScanner(CellScanner) - 类 中的方法org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
setCellVisibility(CellVisibility) - 类 中的方法org.apache.hadoop.hbase.client.Append
 
setCellVisibility(CellVisibility) - 类 中的方法org.apache.hadoop.hbase.client.Delete
 
setCellVisibility(CellVisibility) - 类 中的方法org.apache.hadoop.hbase.client.Increment
 
setCellVisibility(CellVisibility) - 类 中的方法org.apache.hadoop.hbase.client.Mutation
Sets the visibility expression associated with cells in this Mutation.
setCellVisibility(CellVisibility) - 类 中的方法org.apache.hadoop.hbase.client.Put
 
setChance(float) - 类 中的方法org.apache.hadoop.hbase.filter.RandomRowFilter
Set the chance that a row is included.
setCharset(Charset) - 类 中的方法org.apache.hadoop.hbase.filter.RegexStringComparator
Specifies the Charset to use to convert the row key to a String.
setCheckExistenceOnly(boolean) - 类 中的方法org.apache.hadoop.hbase.client.Get
 
setCleanerChoreRunning(boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Enable/Disable the cleaner chore
setCleanerChoreRunning(boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
setClose() - 类 中的方法org.apache.hadoop.hbase.client.ScannerCallable
Call this when the next invocation of call should close the scanner
setClosestRowBefore(boolean) - 类 中的方法org.apache.hadoop.hbase.client.Get
 
setClusterId(ZooKeeperWatcher, ClusterId) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKClusterId
 
setClusterIds(List<UUID>) - 类 中的方法org.apache.hadoop.hbase.client.Append
 
setClusterIds(List<UUID>) - 类 中的方法org.apache.hadoop.hbase.client.Delete
 
setClusterIds(List<UUID>) - 类 中的方法org.apache.hadoop.hbase.client.Increment
 
setClusterIds(List<UUID>) - 类 中的方法org.apache.hadoop.hbase.client.Mutation
Marks that the clusters with the given clusterIds have consumed the mutation
setClusterIds(List<UUID>) - 类 中的方法org.apache.hadoop.hbase.client.Put
 
setClusterKey(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfig
Set the clusterKey which is the concatenation of the slave cluster's: hbase.zookeeper.quorum:hbase.zookeeper.property.clientPort:zookeeper.znode.parent
setColumnFamilyTimeRange(byte[], long, long) - 类 中的方法org.apache.hadoop.hbase.client.Get
 
setColumnFamilyTimeRange(byte[], long, long) - 类 中的方法org.apache.hadoop.hbase.client.Query
Get versions of columns only within the specified timestamp range, [minStamp, maxStamp) on a per CF bases.
setColumnFamilyTimeRange(byte[], long, long) - 类 中的方法org.apache.hadoop.hbase.client.Scan
 
setCompactionCompressionType(Compression.Algorithm) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
Compression types supported in hbase.
setCompactionEnabled(boolean) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Setting the table compaction enable flag.
setCompressionType(Compression.Algorithm) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
Compression types supported in hbase.
setCompressTags(boolean) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
Set whether the tags should be compressed along with DataBlockEncoding.
setConcurrentCallsPerServer(int) - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
setConfiguration(String, String) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
Setter for storing a configuration setting in HColumnDescriptor.configuration map.
setConfiguration(String, String) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Setter for storing a configuration setting in HTableDescriptor.configuration map.
setConsistency(Consistency) - 类 中的方法org.apache.hadoop.hbase.client.Get
 
setConsistency(Consistency) - 类 中的方法org.apache.hadoop.hbase.client.Query
Sets the consistency level for this operation
setConsistency(Consistency) - 类 中的方法org.apache.hadoop.hbase.client.Scan
 
setControllerException(RpcController, IOException) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ResponseConverter
Stores an exception encountered during RPC invocation so it can be passed back through to the client.
setCounter(String, long) - 类 中的方法org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
 
setData(String, byte[], int) - 类 中的方法org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
setData is NOT an idempotent operation.
setData(ZooKeeperWatcher, String, byte[], int) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Sets the data of the existing znode to be the specified data.
setData(ZooKeeperWatcher, String, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Sets the data of the existing znode to be the specified data.
setData(String, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
 
setDataBlockEncoding(DataBlockEncoding) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
Set data block encoding algorithm used in block cache.
setDFSReplication(short) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
Set the replication factor to hfile(s) belonging to this family
setDone(CellScanner) - 类 中的方法org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
setDone(CellScanner) - 接口 中的方法org.apache.hadoop.hbase.ipc.HBaseRpcController
IMPORTANT: always call this method if the call finished without any exception to tell the HBaseRpcController that we are done.
setDone(CellScanner) - 类 中的方法org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
setDurability(Durability) - 类 中的方法org.apache.hadoop.hbase.client.Append
 
setDurability(Durability) - 类 中的方法org.apache.hadoop.hbase.client.Delete
 
setDurability(Durability) - 类 中的方法org.apache.hadoop.hbase.client.Increment
 
setDurability(Durability) - 类 中的方法org.apache.hadoop.hbase.client.Mutation
Set the durability for this mutation
setDurability(Durability) - 类 中的方法org.apache.hadoop.hbase.client.Put
 
setDurability(Durability) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Sets the Durability setting for the table.
setEncodeOnDisk(boolean) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
已过时。
As of release 0.98 (HBASE-9870). This will be removed in HBase 2.0.0. This method does nothing now.
setEncryptionKey(byte[]) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
Set the raw crypto key attribute for the family
setEncryptionType(String) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
Set the encryption algorithm for use with this family
setEventLoopConfig(Configuration, EventLoopGroup, Class<? extends Channel>) - 类 中的静态方法org.apache.hadoop.hbase.ipc.NettyRpcClientConfigHelper
Set the EventLoopGroup and channel class for AsyncRpcClient.
setEvictBlocksOnClose(boolean) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
setExists(Boolean) - 类 中的方法org.apache.hadoop.hbase.client.Result
 
setFailed(String) - 类 中的方法org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
setFailed(IOException) - 类 中的方法org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
setFailed(IOException) - 接口 中的方法org.apache.hadoop.hbase.ipc.HBaseRpcController
Set failed with an exception to pass on.
setFailed(String) - 类 中的方法org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
setFailed(IOException) - 类 中的方法org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
setFailed(String) - 类 中的方法org.apache.hadoop.hbase.ipc.ServerRpcController
 
setFailedOn(IOException) - 类 中的方法org.apache.hadoop.hbase.ipc.ServerRpcController
Sets an exception to be communicated back to the Service client.
setFamilyCellMap(NavigableMap<byte[], List<Cell>>) - 类 中的方法org.apache.hadoop.hbase.client.Append
 
setFamilyCellMap(NavigableMap<byte[], List<Cell>>) - 类 中的方法org.apache.hadoop.hbase.client.Delete
 
setFamilyCellMap(NavigableMap<byte[], List<Cell>>) - 类 中的方法org.apache.hadoop.hbase.client.Increment
 
setFamilyCellMap(NavigableMap<byte[], List<Cell>>) - 类 中的方法org.apache.hadoop.hbase.client.Mutation
Method for setting the put's familyMap
setFamilyCellMap(NavigableMap<byte[], List<Cell>>) - 类 中的方法org.apache.hadoop.hbase.client.Put
 
setFamilyMap(NavigableMap<byte[], List<KeyValue>>) - 类 中的方法org.apache.hadoop.hbase.client.Append
已过时。
setFamilyMap(NavigableMap<byte[], List<KeyValue>>) - 类 中的方法org.apache.hadoop.hbase.client.Delete
已过时。
setFamilyMap(NavigableMap<byte[], List<KeyValue>>) - 类 中的方法org.apache.hadoop.hbase.client.Increment
已过时。
setFamilyMap(NavigableMap<byte[], List<KeyValue>>) - 类 中的方法org.apache.hadoop.hbase.client.Mutation
已过时。
setFamilyMap(NavigableMap<byte[], List<KeyValue>>) - 类 中的方法org.apache.hadoop.hbase.client.Put
已过时。
setFamilyMap(Map<byte[], NavigableSet<byte[]>>) - 类 中的方法org.apache.hadoop.hbase.client.Scan
Setting the familyMap
setFilter(Filter) - 类 中的方法org.apache.hadoop.hbase.client.Get
 
setFilter(Filter) - 类 中的方法org.apache.hadoop.hbase.client.Query
Apply the specified server-side filter when performing the Query.
setFilter(Filter) - 类 中的方法org.apache.hadoop.hbase.client.Scan
 
setFilterIfMissing(boolean) - 类 中的方法org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Set whether entire row should be filtered if column is not found.
setFlushPolicyClassName(String) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
This sets the class associated with the flush policy which determines determines the stores need to be flushed when flushing a region.
setFoundKV(boolean) - 类 中的方法org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
setId(String) - 类 中的方法org.apache.hadoop.hbase.client.Append
 
setId(String) - 类 中的方法org.apache.hadoop.hbase.client.Delete
 
setId(String) - 类 中的方法org.apache.hadoop.hbase.client.Get
 
setId(String) - 类 中的方法org.apache.hadoop.hbase.client.Increment
 
setId(String) - 类 中的方法org.apache.hadoop.hbase.client.OperationWithAttributes
This method allows you to set an identifier on an operation.
setId(String) - 类 中的方法org.apache.hadoop.hbase.client.Put
 
setId(String) - 类 中的方法org.apache.hadoop.hbase.client.Scan
 
setInMemory(boolean) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
setIsolationLevel(IsolationLevel) - 类 中的方法org.apache.hadoop.hbase.client.Get
 
setIsolationLevel(IsolationLevel) - 类 中的方法org.apache.hadoop.hbase.client.Query
Set the isolation level for this query.
setIsolationLevel(IsolationLevel) - 类 中的方法org.apache.hadoop.hbase.client.Scan
 
setKeepDeletedCells(boolean) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
已过时。
As of release 1.0.0 (HBASE-12363). This will be removed in HBase 2.0.0. Use HColumnDescriptor.setKeepDeletedCells(KeepDeletedCells).
setKeepDeletedCells(KeepDeletedCells) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
setLatestVersionOnly(boolean) - 类 中的方法org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Set whether only the latest version of the column value should be compared.
setLimit(int) - 类 中的方法org.apache.hadoop.hbase.client.Scan
Set the limit of rows for this scan.
setLoadColumnFamiliesOnDemand(boolean) - 类 中的方法org.apache.hadoop.hbase.client.Get
 
setLoadColumnFamiliesOnDemand(boolean) - 类 中的方法org.apache.hadoop.hbase.client.Query
Set the value indicating whether loading CFs on demand should be allowed (cluster default is false).
setLoadColumnFamiliesOnDemand(boolean) - 类 中的方法org.apache.hadoop.hbase.client.Scan
 
setLocation(HRegionLocation) - 类 中的方法org.apache.hadoop.hbase.client.RegionServerCallable
 
setLogPosition(String, String, long) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationQueues
Set the current position for a specific WAL in a given queue.
setLogPosition(String, String, long) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
setMasterAddress(ZooKeeperWatcher, String, ServerName, int) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
Set master address into the master znode or into the backup subdirectory of backup masters; switch off the passed in znode path.
setMaxFileSize(long) - 类 中的方法org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
 
setMaxFileSize(long) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Sets the maximum size upto which a region can grow to after which a region split is triggered.
setMaxResultSize(long) - 类 中的方法org.apache.hadoop.hbase.client.Scan
Set the maximum result size.
setMaxResultsPerColumnFamily(int) - 类 中的方法org.apache.hadoop.hbase.client.Get
Set the maximum number of values to return per row per Column Family
setMaxResultsPerColumnFamily(int) - 类 中的方法org.apache.hadoop.hbase.client.Scan
Set the maximum number of values to return per row per Column Family
setMaxVersions() - 类 中的方法org.apache.hadoop.hbase.client.Get
Get all available versions.
setMaxVersions(int) - 类 中的方法org.apache.hadoop.hbase.client.Get
Get up to the specified number of versions of each column.
setMaxVersions() - 类 中的方法org.apache.hadoop.hbase.client.Scan
Get all available versions.
setMaxVersions(int) - 类 中的方法org.apache.hadoop.hbase.client.Scan
Get up to the specified number of versions of each column.
setMaxVersions(int) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
setMemStoreFlushSize(long) - 类 中的方法org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
 
setMemStoreFlushSize(long) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Represents the maximum size of the memstore after which the contents of the memstore are flushed to the filesystem.
setMetaLocation(ZooKeeperWatcher, ServerName, RegionState.State) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Sets the location of hbase:meta in ZooKeeper to the specified server address.
setMetaLocation(ZooKeeperWatcher, ServerName, int, RegionState.State) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Sets the location of hbase:meta in ZooKeeper to the specified server address.
setMetaRegion(boolean) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Used to denote if the current table represents -ROOT- or hbase:meta region.
setMinVersions(int) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
setMvccReadPoint(Scan, long) - 类 中的静态方法org.apache.hadoop.hbase.client.PackagePrivateFieldAccessor
 
setName(byte[]) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
已过时。
setName(TableName) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
已过时。
setNamespaceFilter(String) - 类 中的方法org.apache.hadoop.hbase.quotas.QuotaFilter
Set the namespace filter regex
setNeedCursorResult(boolean) - 类 中的方法org.apache.hadoop.hbase.client.Scan
When the server is slow or we scan a table with many deleted data or we use a sparse filter, the server will response heartbeat to prevent timeout.
setNewStartKey() - 类 中的方法org.apache.hadoop.hbase.client.ClientScanner
Will be called in moveToNextRegion when currentRegion is null.
setNewStartKey() - 类 中的方法org.apache.hadoop.hbase.client.ClientSimpleScanner
 
setNewStartKey() - 类 中的方法org.apache.hadoop.hbase.client.ReversedClientScanner
 
setNonce(long) - 类 中的方法org.apache.hadoop.hbase.client.Action
 
setNonceGroup(long) - 类 中的方法org.apache.hadoop.hbase.client.MultiAction
 
setNormalizationEnabled(boolean) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Setting the table normalization enable flag.
setNormalizerRunning(boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Turn region normalizer on or off.
setNormalizerRunning(boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Turn region normalizer on or off.
setOffline(boolean) - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
The parent of a region split is offline while split daughters hold references to the parent.
setOneRowLimit() - 类 中的方法org.apache.hadoop.hbase.client.Scan
Call this when you only want to get one row.
setOperationTimeout(int) - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorImpl
 
setOperationTimeout(int) - 类 中的方法org.apache.hadoop.hbase.client.HTable
 
setOperationTimeout(int) - 接口 中的方法org.apache.hadoop.hbase.client.Table
Set timeout (millisecond) of each operation in this Table instance, will override the value of hbase.client.operation.timeout in configuration.
setOwner(User) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
已过时。
since 0.94.1
setOwnerString(String) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
已过时。
since 0.94.1
setPeerTableCFs(String, String) - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
setPeerTableCFs(String, Map<TableName, ? extends Collection<String>>) - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Set the replicable table-cf config of the specified peer
setPeerTableCFsConfig(String, Map<TableName, ? extends Collection<String>>) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeers
Set the table and column-family list of the peer to ZK.
setPeerTableCFsConfig(String, Map<TableName, ? extends Collection<String>>) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
setPrefetchBlocksOnOpen(boolean) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
setPriority(int) - 类 中的方法org.apache.hadoop.hbase.client.Append
 
setPriority(int) - 类 中的方法org.apache.hadoop.hbase.client.Delete
 
setPriority(int) - 类 中的方法org.apache.hadoop.hbase.client.Get
 
setPriority(int) - 类 中的方法org.apache.hadoop.hbase.client.Increment
 
setPriority(int) - 类 中的方法org.apache.hadoop.hbase.client.OperationWithAttributes
 
setPriority(int) - 类 中的方法org.apache.hadoop.hbase.client.Scan
 
setPriority(int) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
 
setPriority(int) - 类 中的方法org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
setPriority(TableName) - 类 中的方法org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
setPriority(int) - 接口 中的方法org.apache.hadoop.hbase.ipc.HBaseRpcController
 
setPriority(TableName) - 接口 中的方法org.apache.hadoop.hbase.ipc.HBaseRpcController
 
setPriority(int) - 类 中的方法org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
setPriority(TableName) - 类 中的方法org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
setQuota(QuotaSettings) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Apply the new quota settings.
setQuota(QuotaSettings) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Apply the new quota settings.
setRaw(boolean) - 类 中的方法org.apache.hadoop.hbase.client.Scan
Enable/disable "raw" mode for this scan.
setReadOnly(boolean) - 类 中的方法org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
 
setReadOnly(boolean) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Setting the table as read only sets all the columns in the table as read only.
setReadRpcTimeout(int) - 类 中的方法org.apache.hadoop.hbase.client.HTable
 
setReadRpcTimeout(int) - 接口 中的方法org.apache.hadoop.hbase.client.Table
Set timeout (millisecond) of each rpc read request in operations of this Table instance, will override the value of hbase.rpc.read.timeout in configuration.
setReadType(Scan.ReadType) - 类 中的方法org.apache.hadoop.hbase.client.Scan
Set the read type for this scan.
setRegionCachePrefetch(TableName, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
does nothing since since 0.99
setRegionCachePrefetch(byte[], boolean) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
does nothing since 0.99
setRegionCachePrefetch(byte[], boolean) - 类 中的静态方法org.apache.hadoop.hbase.client.HTable
已过时。
does nothing since 0.99
setRegionCachePrefetch(TableName, boolean) - 类 中的静态方法org.apache.hadoop.hbase.client.HTable
已过时。
does nothing since 0.99
setRegionCachePrefetch(Configuration, byte[], boolean) - 类 中的静态方法org.apache.hadoop.hbase.client.HTable
已过时。
does nothing since 0.99
setRegionCachePrefetch(Configuration, TableName, boolean) - 类 中的静态方法org.apache.hadoop.hbase.client.HTable
已过时。
does nothing since 0.99
setRegionMemstoreReplication(boolean) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Enable or Disable the memstore replication from the primary region to the replicas.
setRegionReplication(int) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Sets the number of replicas per region.
setRegionSplitPolicyClassName(String) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
This sets the class associated with the region split policy which determines when a region split should occur.
setRenew(boolean) - 类 中的方法org.apache.hadoop.hbase.client.ScannerCallable
Indicate whether we make a call only to renew the lease, but without affected the scanner in any other way.
setReplicaId(int) - 类 中的方法org.apache.hadoop.hbase.client.Get
 
setReplicaId(int) - 类 中的方法org.apache.hadoop.hbase.client.Query
Specify region replica id where Query will fetch data from.
setReplicaId(int) - 类 中的方法org.apache.hadoop.hbase.client.Scan
 
setReplicationEndpointImpl(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfig
Sets the ReplicationEndpoint plugin class for this peer.
setRequestSizeBytes(long) - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
setResponseSizeBytes(long) - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
setReturnResults(boolean) - 类 中的方法org.apache.hadoop.hbase.client.Append
 
setReturnResults(boolean) - 类 中的方法org.apache.hadoop.hbase.client.Increment
 
setReturnResults(boolean) - 类 中的方法org.apache.hadoop.hbase.client.Mutation
 
setReversed(boolean) - 类 中的方法org.apache.hadoop.hbase.client.Scan
Set whether this scan is a reversed one This is false by default which means forward(normal) scan.
setReversed(boolean) - 类 中的方法org.apache.hadoop.hbase.filter.Filter
alter the reversed scan flag
setReversed(boolean) - 类 中的方法org.apache.hadoop.hbase.filter.FilterList
 
setReversed(boolean) - 类 中的方法org.apache.hadoop.hbase.filter.FilterListBase
 
setRootRegion(boolean) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Used to denote if the current table represents -ROOT- region.
setRowOffsetPerColumnFamily(int) - 类 中的方法org.apache.hadoop.hbase.client.Get
Set offset for the row per Column Family.
setRowOffsetPerColumnFamily(int) - 类 中的方法org.apache.hadoop.hbase.client.Scan
Set offset for the row per Column Family.
setRowPrefixFilter(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Scan
Set a filter (using stopRow and startRow) so the result set only contains rows where the rowKey starts with the specified prefix.
setRpcTimeout(int) - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorImpl
 
setRpcTimeout(int) - 类 中的方法org.apache.hadoop.hbase.client.HTable
已过时。
setRpcTimeout(int) - 接口 中的方法org.apache.hadoop.hbase.client.Table
已过时。
Use setReadRpcTimeout or setWriteRpcTimeout instead
setRunner(Runnable) - 类 中的方法org.apache.hadoop.hbase.client.DelayingRunner
 
setScanMetricsEnabled(boolean) - 类 中的方法org.apache.hadoop.hbase.client.Scan
Enable collection of ScanMetrics.
setScannerCaching(int) - 类 中的方法org.apache.hadoop.hbase.client.HTable
已过时。
setScope(int) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
setServerSideHConnectionRetries(Configuration, String, Log) - 类 中的静态方法org.apache.hadoop.hbase.client.HConnectionManager
已过时。
Internal method, do not use.
setServerSideHConnectionRetriesConfig(Configuration, String, Log) - 类 中的静态方法org.apache.hadoop.hbase.client.ConnectionUtils
Changes the configuration to set the number of retries needed when using HConnection internally, e.g. for updating catalog tables, etc.
setSmall(boolean) - 类 中的方法org.apache.hadoop.hbase.client.Scan
Set whether this scan is a small scan Small scan should use pread and big scan can use seek + read seek + read is fast but can cause two problem (1) resource contention (2) cause too much network io [89-fb] Using pread for non-compaction read request https://issues.apache.org/jira/browse/HBASE-7266 On the other hand, if setting it true, we would do openScanner,next,closeScanner in one RPC call.
setSplit(boolean) - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
 
setSplitOrMergeEnabled(boolean, boolean, Admin.MasterSwitchType...) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Turn the Split or Merge switches on or off.
setSplitOrMergeEnabled(boolean, boolean, Admin.MasterSwitchType...) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
setStartRow(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Scan
已过时。
use Scan.withStartRow(byte[]) instead. This method may change the inclusive of the stop row to keep compatible with the old behavior.
setStartTime(long) - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
setStatistics(ClientProtos.RegionLoadStats) - 类 中的方法org.apache.hadoop.hbase.client.Result
已过时。
setStatisticTracker(ServerStatisticTracker) - 类 中的方法org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
Set the tracker that should be used for tracking statistics about the server
setStopRow(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Scan
已过时。
use Scan.withStartRow(byte[]) instead. This method may change the inclusive of the stop row to keep compatible with the old behavior.
setStub(AdminProtos.AdminService.BlockingInterface) - 类 中的方法org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
setTableCFsMap(Map<TableName, ? extends Collection<String>>) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
setTableFilter(String) - 类 中的方法org.apache.hadoop.hbase.quotas.QuotaFilter
Set the table filter regex
setTableName(TableName) - 类 中的方法org.apache.hadoop.hbase.security.access.TablePermission
 
setTimeRange(long, long) - 类 中的方法org.apache.hadoop.hbase.client.Get
Get versions of columns only within the specified timestamp range, [minStamp, maxStamp).
setTimeRange(long, long) - 类 中的方法org.apache.hadoop.hbase.client.Increment
Sets the TimeRange to be used on the Get for this increment.
setTimeRange(long, long) - 类 中的方法org.apache.hadoop.hbase.client.Scan
Get versions of columns only within the specified timestamp range, [minStamp, maxStamp).
setTimestamp(long) - 类 中的方法org.apache.hadoop.hbase.client.Delete
Set the timestamp of the delete.
setTimeStamp(long) - 类 中的方法org.apache.hadoop.hbase.client.Get
Get versions of columns with the specified timestamp.
setTimeStamp(long) - 类 中的方法org.apache.hadoop.hbase.client.Scan
Get versions of columns with the specified timestamp.
setTimestamp(long) - 类 中的方法org.apache.hadoop.hbase.master.RegionState
 
setTimeToLive(int) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
setTTL(long) - 类 中的方法org.apache.hadoop.hbase.client.Append
 
setTTL(long) - 类 中的方法org.apache.hadoop.hbase.client.Delete
 
setTTL(long) - 类 中的方法org.apache.hadoop.hbase.client.Increment
 
setTTL(long) - 类 中的方法org.apache.hadoop.hbase.client.Mutation
Set the TTL desired for the result of the mutation, in milliseconds.
setTTL(long) - 类 中的方法org.apache.hadoop.hbase.client.Put
 
setupMasterlessConnection(Configuration) - 类 中的静态方法org.apache.hadoop.hbase.client.ConnectionUtils
Setup the connection class, so that it will not depend on master being online.
setupSaslHandler(ChannelPipeline) - 类 中的方法org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClient
 
setupSetQuotaRequest(MasterProtos.SetQuotaRequest.Builder) - 类 中的方法org.apache.hadoop.hbase.quotas.QuotaSettings
已过时。
Removed in HBase 2.0+ as a part of removing protobuf from our API
setUserFilter(String) - 类 中的方法org.apache.hadoop.hbase.quotas.QuotaFilter
Set the user filter regex
setValue(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
 
setValue(String, String) - 类 中的方法org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
 
setValue(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
setValue(String, String) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
setValue(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Setter for storing metadata as a (key, value) pair in HTableDescriptor.values map
setValue(ImmutableBytesWritable, ImmutableBytesWritable) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
 
setValue(String, String) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
Setter for storing metadata as a (key, value) pair in HTableDescriptor.values map
setVersions(int, int) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
Set minimum and maximum versions to keep
setWatchIfNodeExists(ZooKeeperWatcher, String) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Watch the specified znode, but only if exists.
setWriteBufferSize(long) - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorImpl
已过时。
Going away when we drop public support for HTableInterface.
setWriteBufferSize(long) - 类 中的方法org.apache.hadoop.hbase.client.HTable
Sets the size of the buffer in bytes.
setWriteBufferSize(long) - 接口 中的方法org.apache.hadoop.hbase.client.HTableInterface
已过时。
setWriteBufferSize(long) - 接口 中的方法org.apache.hadoop.hbase.client.Table
已过时。
as of 1.0.1 (should not have been in 1.0.0). Replaced by BufferedMutator and BufferedMutatorParams.writeBufferSize(long)
setWriteRpcTimeout(int) - 类 中的方法org.apache.hadoop.hbase.client.HTable
 
setWriteRpcTimeout(int) - 接口 中的方法org.apache.hadoop.hbase.client.Table
Set timeout (millisecond) of each rpc write request in operations of this Table instance, will override the value of hbase.rpc.write.timeout in configuration.
setWriteToWAL(boolean) - 类 中的方法org.apache.hadoop.hbase.client.Append
已过时。
setWriteToWAL(boolean) - 类 中的方法org.apache.hadoop.hbase.client.Delete
已过时。
setWriteToWAL(boolean) - 类 中的方法org.apache.hadoop.hbase.client.Increment
已过时。
setWriteToWAL(boolean) - 类 中的方法org.apache.hadoop.hbase.client.Mutation
已过时。
setWriteToWAL(boolean) - 类 中的方法org.apache.hadoop.hbase.client.Put
已过时。
shouldCacheBloomsOnWrite() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
已过时。
As of release 1.0.0 (HBASE-10870). This will be removed in HBase 2.0.0. Use HColumnDescriptor.isCacheBloomsOnWrite()} instead.
shouldCacheDataInL1() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
已过时。
As of release 1.0.0 (HBASE-10870). This will be removed in HBase 2.0.0. Use HColumnDescriptor.isCacheDataInL1()} instead.
shouldCacheDataOnWrite() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
已过时。
As of release 1.0.0 (HBASE-10870). This will be removed in HBase 2.0.0. Use HColumnDescriptor.isCacheDataOnWrite()} instead.
shouldCacheIndexesOnWrite() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
已过时。
As of release 1.0.0 (HBASE-10870). This will be removed in HBase 2.0.0. Use HColumnDescriptor.isCacheIndexesOnWrite() instead.
shouldCompressTags() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
已过时。
As of release 1.0.0 (HBASE-10870). This will be removed in HBase 2.0.0. Use HColumnDescriptor.isCompressTags() instead.
shouldEvictBlocksOnClose() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
已过时。
As of release 1.0.0 (HBASE-10870). This will be removed in HBase 2.0.0. Use HColumnDescriptor.isEvictBlocksOnClose()} instead.
shouldPrefetchBlocksOnOpen() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
已过时。
As of release 1.0.0 (HBASE-10870). This will be removed in HBase 2.0.0. Use HColumnDescriptor.isPrefetchBlocksOnOpen()}} instead.
shutdown() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Shuts down the HBase cluster
shutdown() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Shuts down the HBase cluster
shutdown() - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection
 
SINGLE_QUOTE - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for a single quote
SingleColumnValueExcludeFilter - org.apache.hadoop.hbase.filter中的类
A Filter that checks a single column value, but does not emit the tested column.
SingleColumnValueExcludeFilter(byte[], byte[], CompareFilter.CompareOp, byte[]) - 类 的构造器org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
Constructor for binary compare of the value of a single column.
SingleColumnValueExcludeFilter(byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable) - 类 的构造器org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
Constructor for binary compare of the value of a single column.
SingleColumnValueExcludeFilter(byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, boolean, boolean) - 类 的构造器org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
Constructor for protobuf deserialization only.
SingleColumnValueFilter - org.apache.hadoop.hbase.filter中的类
This filter is used to filter cells based on value.
SingleColumnValueFilter(byte[], byte[], CompareFilter.CompareOp, byte[]) - 类 的构造器org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Constructor for binary compare of the value of a single column.
SingleColumnValueFilter(byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable) - 类 的构造器org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Constructor for binary compare of the value of a single column.
SingleColumnValueFilter(byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, boolean, boolean) - 类 的构造器org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Constructor for protobuf deserialization only.
size() - 类 中的方法org.apache.hadoop.hbase.client.MultiAction
Get the total number of Actions
size() - 类 中的方法org.apache.hadoop.hbase.client.MultiResponse
 
size() - 类 中的方法org.apache.hadoop.hbase.client.Mutation
Number of KeyValues carried by this Mutation.
size() - 类 中的方法org.apache.hadoop.hbase.client.Result
 
size() - 类 中的方法org.apache.hadoop.hbase.filter.FilterList
 
size() - 类 中的方法org.apache.hadoop.hbase.filter.FilterListBase
 
size() - 类 中的方法org.apache.hadoop.hbase.RegionLocations
Returns the size of the list even if some of the elements might be null.
size() - 接口 中的方法org.apache.hadoop.hbase.util.PoolMap.Pool
 
size() - 类 中的方法org.apache.hadoop.hbase.util.PoolMap
 
size(K) - 类 中的方法org.apache.hadoop.hbase.util.PoolMap
 
sizeToString(long) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaSettings
 
SKIP_ARRAY - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
SKIP Array
SKIP_BUFFER - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
 
SkipFilter - org.apache.hadoop.hbase.filter中的类
A wrapper filter that filters an entire row if any of the Cell checks do not pass.
SkipFilter(Filter) - 类 的构造器org.apache.hadoop.hbase.filter.SkipFilter
 
sleep(long, int) - 类 中的方法org.apache.hadoop.hbase.client.DelegatingRetryingCallable
 
sleep(long, int) - 类 中的方法org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
sleep(long, int) - 类 中的方法org.apache.hadoop.hbase.client.RegionServerCallable
 
sleep(long, int) - 接口 中的方法org.apache.hadoop.hbase.client.RetryingCallable
 
snapshot(String, TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Take a snapshot for the given table.
snapshot(byte[], TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
public void snapshot(final String snapshotName, Create a timestamp consistent snapshot for the given table. final byte[] tableName) throws IOException, Snapshots are considered unique based on the name of the snapshot.
snapshot(String, TableName, HBaseProtos.SnapshotDescription.Type) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
已过时。
snapshot(HBaseProtos.SnapshotDescription) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
已过时。
snapshot(String, TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Take a snapshot for the given table.
snapshot(String, String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
snapshot(byte[], byte[], HBaseProtos.SnapshotDescription.Type) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Create snapshot for the given table of given flush type.
snapshot(byte[], TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
public void snapshot(final String snapshotName, Create a timestamp consistent snapshot for the given table.
snapshot(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
snapshot(String, TableName, HBaseProtos.SnapshotDescription.Type) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Create typed snapshot of the table.
snapshot(String, String, HBaseProtos.SnapshotDescription.Type) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
snapshot(String, byte[], HBaseProtos.SnapshotDescription.Type) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
snapshot(HBaseProtos.SnapshotDescription) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Take a snapshot and wait for the server to complete that snapshot (blocking).
SnapshotCreationException - org.apache.hadoop.hbase.snapshot中的异常错误
Thrown when a snapshot could not be created due to a server-side error when taking the snapshot.
SnapshotCreationException(String) - 异常错误 的构造器org.apache.hadoop.hbase.snapshot.SnapshotCreationException
Used internally by the RPC engine to pass the exception back to the client.
SnapshotCreationException(String, HBaseProtos.SnapshotDescription) - 异常错误 的构造器org.apache.hadoop.hbase.snapshot.SnapshotCreationException
Failure to create the specified snapshot.
SnapshotCreationException(String, Throwable, HBaseProtos.SnapshotDescription) - 异常错误 的构造器org.apache.hadoop.hbase.snapshot.SnapshotCreationException
已过时。
since 1.3.0, will be removed in 3.0.0
SnapshotDoesNotExistException - org.apache.hadoop.hbase.snapshot中的异常错误
Thrown when the server is looking for a snapshot, but can't find the snapshot on the filesystem.
SnapshotDoesNotExistException(String) - 异常错误 的构造器org.apache.hadoop.hbase.snapshot.SnapshotDoesNotExistException
 
SnapshotDoesNotExistException(HBaseProtos.SnapshotDescription) - 异常错误 的构造器org.apache.hadoop.hbase.snapshot.SnapshotDoesNotExistException
已过时。
since 1.3.0, will be removed in 3.0.0
SnapshotExistsException - org.apache.hadoop.hbase.snapshot中的异常错误
Thrown when a snapshot exists, but should not.
SnapshotExistsException(String) - 异常错误 的构造器org.apache.hadoop.hbase.snapshot.SnapshotExistsException
Failure due to the snapshot already existing.
SnapshotExistsException(String, HBaseProtos.SnapshotDescription) - 异常错误 的构造器org.apache.hadoop.hbase.snapshot.SnapshotExistsException
已过时。
since 1.3.0, will be removed in 3.0.0
SOCKET_TIMEOUT_CONNECT - 接口 中的静态变量org.apache.hadoop.hbase.ipc.RpcClient
 
SOCKET_TIMEOUT_READ - 接口 中的静态变量org.apache.hadoop.hbase.ipc.RpcClient
How long we wait when we wait for an answer.
SOCKET_TIMEOUT_WRITE - 接口 中的静态变量org.apache.hadoop.hbase.ipc.RpcClient
 
socketFactory - 类 中的变量org.apache.hadoop.hbase.ipc.BlockingRpcClient
 
sortAndMerge(List<MultiRowRangeFilter.RowRange>) - 类 中的静态方法org.apache.hadoop.hbase.filter.MultiRowRangeFilter
sort the ranges and if the ranges with overlap, then merge them.
SORTED_ORDINAL_SERIALIZATION_FORMAT - 类 中的静态变量org.apache.hadoop.hbase.security.visibility.VisibilityConstants
Visibility serialization version format.
SORTED_ORDINAL_SERIALIZATION_FORMAT_TAG_VAL - 类 中的静态变量org.apache.hadoop.hbase.security.visibility.VisibilityConstants
Byte representation of the visibility_serialization_version
sortedPrefixes - 类 中的变量org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
SPECIFIC_WRITE_THREAD - 接口 中的静态变量org.apache.hadoop.hbase.ipc.RpcClient
 
split(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Split a table.
split(TableName, byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Split a table.
split(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Split a table.
split(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
split(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
split(TableName, byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Split a table.
split(String, String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
split(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
split(ServerName, HRegionInfo, byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
split(RpcController, AdminProtos.AdminService.BlockingInterface, HRegionInfo, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to split a region using admin protocol.
SPLIT_POLICY - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
 
splitKerberosName(String) - 类 中的静态方法org.apache.hadoop.hbase.security.SaslUtil
Splitting fully qualified Kerberos name into parts
splitLogZNode - 类 中的变量org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
splitRegion(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Split an individual region.
splitRegion(byte[], byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Split an individual region.
splitRegion(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Split an individual region.
splitRegion(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Split an individual region.
splitRegion(Connection, HRegionInfo, HRegionInfo, HRegionInfo, ServerName, int) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Splits the region into two in an atomic operation.
stampSet - 类 中的变量org.apache.hadoop.hbase.filter.DependentColumnFilter
 
start(CoprocessorEnvironment) - 接口 中的方法org.apache.hadoop.hbase.Coprocessor
 
start() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
已过时。
 
start() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
Starts the tracking of the node in ZooKeeper.
startCancel() - 类 中的方法org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
startCancel() - 类 中的方法org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
startCancel() - 类 中的方法org.apache.hadoop.hbase.ipc.ServerRpcController
 
startPeerConfigTracker(ZooKeeperWatcher, String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
start a table-cfs tracker to listen the (table, cf-list) map change
startStateTracker(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
start a state tracker to check whether this peer is enabled or not
state - 枚举 中的变量org.apache.hadoop.hbase.security.SaslStatus
 
StatisticTrackable - org.apache.hadoop.hbase.client中的接口
Parent interface for an object to get updates about per-region statistics.
std(TableName, ColumnInterpreter<R, S, P, Q, T>, Scan) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.AggregationClient
This is the client side interface/handle for calling the std method for a given cf-cq combination.
std(Table, ColumnInterpreter<R, S, P, Q, T>, Scan) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.AggregationClient
This is the client side interface/handle for calling the std method for a given cf-cq combination.
stepDownAsLeader() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
已过时。
Removes the leader znode, if it is currently claimed by this instance.
stop(CoprocessorEnvironment) - 接口 中的方法org.apache.hadoop.hbase.Coprocessor
 
stop() - 类 中的方法org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Stop working.
stop() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
 
stopMaster() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Shuts down the current HBase master only.
stopMaster() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Shuts down the current HBase master only.
StoppedRpcClientException - org.apache.hadoop.hbase.ipc中的异常错误
 
StoppedRpcClientException() - 异常错误 的构造器org.apache.hadoop.hbase.ipc.StoppedRpcClientException
 
StoppedRpcClientException(String) - 异常错误 的构造器org.apache.hadoop.hbase.ipc.StoppedRpcClientException
 
stopRegionServer(String) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Stop the designated regionserver
stopRegionServer(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Stop the designated regionserver
stub - 类 中的变量org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
subFiltersIncludedCell - 类 中的变量org.apache.hadoop.hbase.filter.FilterListBase
For each sub-filter in filter list, we save a boolean flag to indicate that whether the return code of filterCell(c) for sub-filter is INCLUDE* (INCLUDE, INCLUDE_AND_NEXT_COL, INCLUDE_AND_SEEK_NEXT_ROW) case. if true, we need to transform cell for the sub-filter.
submit(RetryingCallable<V>, int, int) - 类 中的方法org.apache.hadoop.hbase.client.ResultBoundedCompletionService
 
SubstringComparator - org.apache.hadoop.hbase.filter中的类
This comparator is for use with SingleColumnValueFilter, for filtering based on the value of a given column.
SubstringComparator(String) - 类 的构造器org.apache.hadoop.hbase.filter.SubstringComparator
Constructor
substringType - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
SubstringType byte array
sum(TableName, ColumnInterpreter<R, S, P, Q, T>, Scan) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.AggregationClient
It sums up the value returned from various regions.
sum(Table, ColumnInterpreter<R, S, P, Q, T>, Scan) - 类 中的方法org.apache.hadoop.hbase.client.coprocessor.AggregationClient
It sums up the value returned from various regions.
sumOfMillisSecBetweenNexts - 类 中的变量org.apache.hadoop.hbase.client.metrics.ScanMetrics
sum of milliseconds between sequential next calls
SWITCH_TO_SIMPLE_AUTH - 类 中的静态变量org.apache.hadoop.hbase.security.SaslUtil
 
sync(String, AsyncCallback.VoidCallback, Object) - 类 中的方法org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
sync(String) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Forces a synchronization of this ZooKeeper client connection.

T

TAB - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for tab
Table - org.apache.hadoop.hbase.client中的接口
Used to communicate with a single HBase table.
TABLE_MULTIPLEXER_FLUSH_PERIOD_MS - 类 中的静态变量org.apache.hadoop.hbase.client.HTableMultiplexer
 
TABLE_MULTIPLEXER_INIT_THREADS - 类 中的静态变量org.apache.hadoop.hbase.client.HTableMultiplexer
 
TABLE_MULTIPLEXER_MAX_RETRIES_IN_QUEUE - 类 中的静态变量org.apache.hadoop.hbase.client.HTableMultiplexer
 
tableCFsNodeName - 类 中的变量org.apache.hadoop.hbase.replication.ReplicationStateZKBase
The name of the znode that contains tableCFs
tableExists(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
 
tableExists(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
tableExists(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
tableExists(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
tableExists(Connection, TableName) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Checks if the specified table exists.
TableExistsException - org.apache.hadoop.hbase中的异常错误
Thrown when a table exists but should not.
TableExistsException() - 异常错误 的构造器org.apache.hadoop.hbase.TableExistsException
 
TableExistsException(String) - 异常错误 的构造器org.apache.hadoop.hbase.TableExistsException
 
TableExistsException(TableName) - 异常错误 的构造器org.apache.hadoop.hbase.TableExistsException
 
tableFieldsEqual(TablePermission) - 类 中的方法org.apache.hadoop.hbase.security.access.TablePermission
 
TableInfoMissingException - org.apache.hadoop.hbase中的异常错误
Failed to find .tableinfo file under the table directory.
TableInfoMissingException() - 异常错误 的构造器org.apache.hadoop.hbase.TableInfoMissingException
Failed to find .tableinfo file under the table directory.
TableInfoMissingException(String) - 异常错误 的构造器org.apache.hadoop.hbase.TableInfoMissingException
 
TableInfoMissingException(String, Throwable) - 异常错误 的构造器org.apache.hadoop.hbase.TableInfoMissingException
 
TableInfoMissingException(Throwable) - 异常错误 的构造器org.apache.hadoop.hbase.TableInfoMissingException
 
tableLockZNode - 类 中的变量org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
tableName - 类 中的变量org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
tableName - 类 中的变量org.apache.hadoop.hbase.client.RegionServerCallable
 
tableName - 类 中的变量org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
 
TableNotDisabledException - org.apache.hadoop.hbase中的异常错误
Thrown if a table should be offline but is not.
TableNotDisabledException() - 异常错误 的构造器org.apache.hadoop.hbase.TableNotDisabledException
 
TableNotDisabledException(String) - 异常错误 的构造器org.apache.hadoop.hbase.TableNotDisabledException
 
TableNotDisabledException(byte[]) - 异常错误 的构造器org.apache.hadoop.hbase.TableNotDisabledException
 
TableNotDisabledException(TableName) - 异常错误 的构造器org.apache.hadoop.hbase.TableNotDisabledException
 
TableNotEnabledException - org.apache.hadoop.hbase中的异常错误
Thrown if a table should be enabled but is not.
TableNotEnabledException() - 异常错误 的构造器org.apache.hadoop.hbase.TableNotEnabledException
default constructor
TableNotEnabledException(String) - 异常错误 的构造器org.apache.hadoop.hbase.TableNotEnabledException
 
TableNotEnabledException(TableName) - 异常错误 的构造器org.apache.hadoop.hbase.TableNotEnabledException
 
TableNotEnabledException(byte[]) - 异常错误 的构造器org.apache.hadoop.hbase.TableNotEnabledException
 
TableNotFoundException - org.apache.hadoop.hbase中的异常错误
Thrown when a table cannot be located.
TableNotFoundException() - 异常错误 的构造器org.apache.hadoop.hbase.TableNotFoundException
 
TableNotFoundException(String) - 异常错误 的构造器org.apache.hadoop.hbase.TableNotFoundException
 
TableNotFoundException(byte[]) - 异常错误 的构造器org.apache.hadoop.hbase.TableNotFoundException
 
TableNotFoundException(TableName) - 异常错误 的构造器org.apache.hadoop.hbase.TableNotFoundException
 
TablePartiallyOpenException - org.apache.hadoop.hbase.snapshot中的异常错误
Thrown if a table should be online/offline, but is partially open.
TablePartiallyOpenException() - 异常错误 的构造器org.apache.hadoop.hbase.snapshot.TablePartiallyOpenException
Constructs an TablePartiallyOpenException with null as its error detail message.
TablePartiallyOpenException(String) - 异常错误 的构造器org.apache.hadoop.hbase.snapshot.TablePartiallyOpenException
 
TablePartiallyOpenException(TableName) - 异常错误 的构造器org.apache.hadoop.hbase.snapshot.TablePartiallyOpenException
 
TablePartiallyOpenException(byte[]) - 异常错误 的构造器org.apache.hadoop.hbase.snapshot.TablePartiallyOpenException
 
TablePermission - org.apache.hadoop.hbase.security.access中的类
Represents an authorization for access for the given actions, optionally restricted to the given column family or column qualifier, over the given table.
TablePermission() - 类 的构造器org.apache.hadoop.hbase.security.access.TablePermission
Nullary constructor for Writable, do not use
TablePermission(TableName, byte[], Permission.Action...) - 类 的构造器org.apache.hadoop.hbase.security.access.TablePermission
Create a new permission for the given table and (optionally) column family, allowing the given actions.
TablePermission(TableName, byte[], byte[], Permission.Action...) - 类 的构造器org.apache.hadoop.hbase.security.access.TablePermission
Creates a new permission for the given table, restricted to the given column family and qualifier, allowing the assigned actions to be performed.
TablePermission(TableName, byte[], byte[], byte[]) - 类 的构造器org.apache.hadoop.hbase.security.access.TablePermission
Creates a new permission for the given table, family and column qualifier, allowing the actions matching the provided byte codes to be performed.
TablePermission(String, TableName, byte[], byte[], Permission.Action...) - 类 的构造器org.apache.hadoop.hbase.security.access.TablePermission
Creates a new permission for the given namespace or table, restricted to the given column family and qualifier, allowing the assigned actions to be performed.
TablePermission(String, TableName, byte[], byte[], byte[]) - 类 的构造器org.apache.hadoop.hbase.security.access.TablePermission
Creates a new permission for the given namespace or table, family and column qualifier, allowing the actions matching the provided byte codes to be performed.
TablePermission(String, byte[]) - 类 的构造器org.apache.hadoop.hbase.security.access.TablePermission
Creates a new permission for the given namespace, allowing the actions matching the provided byte codes to be performed.
TablePermission(String, Permission.Action...) - 类 的构造器org.apache.hadoop.hbase.security.access.TablePermission
Create a new permission for the given namespace, allowing the given actions.
tableZNode - 类 中的变量org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
take() - 类 中的方法org.apache.hadoop.hbase.client.ResultBoundedCompletionService
 
takeSnapshotAsync(HBaseProtos.SnapshotDescription) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
已过时。
takeSnapshotAsync(HBaseProtos.SnapshotDescription) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Take a snapshot without waiting for the server to complete that snapshot (asynchronous) Only a single snapshot should be taken at a time, or results may be undefined.
targetReplicaId - 类 中的变量org.apache.hadoop.hbase.client.Query
 
tcpKeepAlive - 类 中的变量org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
tcpNoDelay - 类 中的变量org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
throttleNamespace(String, ThrottleType, long, TimeUnit) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Throttle the specified namespace.
throttleTable(TableName, ThrottleType, long, TimeUnit) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Throttle the specified table.
ThrottleType - org.apache.hadoop.hbase.quotas中的枚举
Describe the Throttle Type.
throttleUser(String, ThrottleType, long, TimeUnit) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Throttle the specified user.
throttleUser(String, TableName, ThrottleType, long, TimeUnit) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Throttle the specified user on the specified table.
throttleUser(String, String, ThrottleType, long, TimeUnit) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Throttle the specified user on the specified namespace.
ThrottlingException - org.apache.hadoop.hbase.quotas中的异常错误
Describe the throttling result.
ThrottlingException(String) - 异常错误 的构造器org.apache.hadoop.hbase.quotas.ThrottlingException
 
ThrottlingException(ThrottlingException.Type, long, String) - 异常错误 的构造器org.apache.hadoop.hbase.quotas.ThrottlingException
 
ThrottlingException.Type - org.apache.hadoop.hbase.quotas中的枚举
 
throwable(Throwable, boolean) - 类 中的方法org.apache.hadoop.hbase.client.DelegatingRetryingCallable
 
throwable(Throwable, boolean) - 类 中的方法org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
throwable(Throwable, boolean) - 类 中的方法org.apache.hadoop.hbase.client.RegionServerCallable
 
throwable(Throwable, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.RetryingCallable
Called when RetryingCallable.call(int) throws an exception and we are going to retry; take action to make it so we succeed on next call (clear caches, do relookup of locations, etc.).
throwInterruptedException() - 接口 中的方法org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture.WaitForStateCallable
 
throwNumReadRequestsExceeded(long) - 异常错误 中的静态方法org.apache.hadoop.hbase.quotas.ThrottlingException
 
throwNumRequestsExceeded(long) - 异常错误 中的静态方法org.apache.hadoop.hbase.quotas.ThrottlingException
 
throwNumWriteRequestsExceeded(long) - 异常错误 中的静态方法org.apache.hadoop.hbase.quotas.ThrottlingException
 
throwReadSizeExceeded(long) - 异常错误 中的静态方法org.apache.hadoop.hbase.quotas.ThrottlingException
 
throwRequestSizeExceeded(long) - 异常错误 中的静态方法org.apache.hadoop.hbase.quotas.ThrottlingException
 
throwTimeoutException(long) - 接口 中的方法org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture.WaitForStateCallable
 
throwWriteSizeExceeded(long) - 异常错误 中的静态方法org.apache.hadoop.hbase.quotas.ThrottlingException
 
timeBeforeReplicas - 类 中的变量org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
 
TimestampsFilter - org.apache.hadoop.hbase.filter中的类
Filter that returns only cells whose timestamp (version) is in the specified list of timestamps (versions).
TimestampsFilter(List<Long>) - 类 的构造器org.apache.hadoop.hbase.filter.TimestampsFilter
Constructor for filter that retains only the specified timestamps in the list.
TimestampsFilter(List<Long>, boolean) - 类 的构造器org.apache.hadoop.hbase.filter.TimestampsFilter
Constructor for filter that retains only those cells whose timestamp (version) is in the specified list of timestamps.
timeToString(TimeUnit) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaSettings
 
TNAME - 类 中的静态变量org.apache.hadoop.hbase.client.replication.ReplicationAdmin
 
toAppend(ClientProtos.MutationProto, CellScanner) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Mutate to an Append
toAuthorizations(ClientProtos.Authorizations) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Authorizations to a client Authorizations
toAuthorizations(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Authorizations bytes to a client Authorizations
toAuthorizations(Authorizations) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Create a protocol buffer Authorizations based on a client Authorizations.
toBulkLoadDescriptor(TableName, ByteString, Map<byte[], List<Path>>, Map<String, Long>, long) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
已过时。
use toBulkLoadDescriptor(TableName tableName, ByteString encodedRegionName, Map> storeFiles, Map storeFilesSize, long bulkloadSeqId, List clusterIds) instead.
toBulkLoadDescriptor(TableName, ByteString, Map<byte[], List<Path>>, Map<String, Long>, long, List<String>) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Generates a marker for the WAL so that we propagate the notion of a bulk region load throughout the WAL, keeping track of clusters who already applied the bulk event via the passed clusterIds parameter.
toByte() - 枚举 中的方法org.apache.hadoop.hbase.client.IsolationLevel
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.ClusterId
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.BinaryComparator
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.BinaryPrefixComparator
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.BitComparator
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.ByteArrayComparable
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.DependentColumnFilter
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.FamilyFilter
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.Filter
TODO: JAVADOC Concrete implementers can signal a failure condition in their code by throwing an IOException.
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.FilterBase
Return length 0 byte array for Filters that don't require special serialization
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.FilterList
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.FilterWrapper
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.FuzzyRowFilter
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.LongComparator
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.NullComparator
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.PageFilter
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.PrefixFilter
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.QualifierFilter
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.RandomRowFilter
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.RegexStringComparator
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.RowFilter
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.SkipFilter
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.SubstringComparator
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.TimestampsFilter
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.ValueFilter
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.WhileMatchFilter
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
 
toByteArray() - 类 中的方法org.apache.hadoop.hbase.RegionTransition
 
toByteArray(ReplicationPeerConfig) - 类 中的静态方法org.apache.hadoop.hbase.replication.ReplicationSerDeHelper
 
toByteArray(ZooKeeperProtos.ReplicationState.State) - 类 中的静态方法org.apache.hadoop.hbase.replication.ReplicationStateZKBase
 
toBytes() - 枚举 中的方法org.apache.hadoop.hbase.client.IsolationLevel
 
toBytes() - 类 中的方法org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
toCell(Cell) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toCell(CellProtos.Cell) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toCellVisibility(ClientProtos.CellVisibility) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer CellVisibility to a client CellVisibility
toCellVisibility(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer CellVisibility bytes to a client CellVisibility
toCellVisibility(CellVisibility) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Create a protocol buffer CellVisibility based on a client CellVisibility.
toCompactedStoreFiles(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toCompactionDescriptor(HRegionInfo, byte[], List<Path>, List<Path>, Path) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toCompactionDescriptor(HRegionInfo, byte[], byte[], List<Path>, List<Path>, Path) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toCompactionEventTrackerBytes(Set<String>) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toComparator(ByteArrayComparable) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a ByteArrayComparable to a protocol buffer Comparator
toComparator(ComparatorProtos.Comparator) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Comparator to a ByteArrayComparable
toConsistency(ClientProtos.Consistency) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toConsistency(Consistency) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toCursor(Cursor) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toCursor(Cell) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toCursor(ClientProtos.Cursor) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toDelete(ClientProtos.MutationProto) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Mutate to a Delete
toDelete(ClientProtos.MutationProto, CellScanner) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Mutate to a Delete
toDeleteType(KeyValue.Type) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a delete KeyValue type to protocol buffer DeleteType.
toDelimitedByteArray() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
Use this instead of HRegionInfo.toByteArray() when writing to a stream and you want to use the pb mergeDelimitedFrom (w/o the delimiter, pb reads to EOF which may not be what you want).
toDelimitedByteArray(HRegionInfo...) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
Serializes given HRegionInfo's as a byte array.
toDelimitedByteArray(Message) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toDescriptiveString() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
A slower (but more easy-to-read) stringification
toDurability(ClientProtos.MutationProto.Durability) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protobuf Durability into a client Durability
toDurability(Durability) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client Durability into a protbuf Durability
toException(HBaseProtos.NameBytesPair) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a stringified protocol buffer exception Parameter to a Java Exception
toFilter(FilterProtos.Filter) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Filter to a client Filter
toFilter(Filter) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client Filter to a protocol buffer Filter
toFlushDescriptor(WALProtos.FlushDescriptor.FlushAction, HRegionInfo, long, Map<byte[], List<Path>>) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toGet(ClientProtos.Get) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Get to a client Get
toGet(ClientProtos.MutationProto, CellScanner) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Mutate to a Get.
toGet(Get) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Create a protocol buffer Get based on a client Get.
toIncrement(ClientProtos.MutationProto, CellScanner) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Mutate to an Increment
toIOException(ServiceException) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Unwraps an exception from a protobuf service into the underlying (expected) IOException.
toJSON(int) - 类 中的方法org.apache.hadoop.hbase.client.Operation
Produces a JSON object for fingerprint and details exposure in a parseable format.
toJSON() - 类 中的方法org.apache.hadoop.hbase.client.Operation
Produces a JSON object sufficient for description of a query in a debugging or logging context.
TOKEN_HANDLERS - 类 中的静态变量org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
TokenUtil - org.apache.hadoop.hbase.security.token中的类
Utility methods for obtaining authentication tokens.
TokenUtil() - 类 的构造器org.apache.hadoop.hbase.security.token.TokenUtil
 
toMap(int) - 类 中的方法org.apache.hadoop.hbase.client.Delete
 
toMap(int) - 类 中的方法org.apache.hadoop.hbase.client.Get
Compile the details beyond the scope of getFingerprint (row, columns, timestamps, etc.) into a Map along with the fingerprinted information.
toMap(int) - 类 中的方法org.apache.hadoop.hbase.client.Mutation
Compile the details beyond the scope of getFingerprint (row, columns, timestamps, etc.) into a Map along with the fingerprinted information.
toMap(int) - 类 中的方法org.apache.hadoop.hbase.client.Operation
Produces a Map containing a summary of the details of a query beyond the scope of the fingerprint (i.e. columns, rows...)
toMap() - 类 中的方法org.apache.hadoop.hbase.client.Operation
Produces a Map containing a full summary of a query.
toMap(int) - 类 中的方法org.apache.hadoop.hbase.client.Scan
Compile the details beyond the scope of getFingerprint (row, columns, timestamps, etc.) into a Map along with the fingerprinted information.
toMutation(ClientProtos.MutationProto) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a MutateRequest to Mutation
toMutation(Increment, ClientProtos.MutationProto.Builder, long) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client Increment to a protobuf Mutate.
toMutation(ClientProtos.MutationProto.MutationType, Mutation) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toMutation(ClientProtos.MutationProto.MutationType, Mutation, long) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Create a protocol buffer Mutate based on a client Mutation
toMutation(ClientProtos.MutationProto.MutationType, Mutation, ClientProtos.MutationProto.Builder) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toMutation(ClientProtos.MutationProto.MutationType, Mutation, ClientProtos.MutationProto.Builder, long) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toMutationNoData(ClientProtos.MutationProto.MutationType, Mutation, ClientProtos.MutationProto.Builder) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Create a protocol buffer MutationProto based on a client Mutation.
toMutationNoData(ClientProtos.MutationProto.MutationType, Mutation) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Create a protocol buffer MutationProto based on a client Mutation.
toMutationNoData(ClientProtos.MutationProto.MutationType, Mutation, ClientProtos.MutationProto.Builder, long) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toNamespaceDescriptor(HBaseProtos.NamespaceDescriptor) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toPermission(AccessControlProtos.Permission) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Converts a Permission proto to a client Permission object.
toPermission(Permission) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client Permission to a Permission proto
toPermissionAction(AccessControlProtos.Permission.Action) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Converts a Permission.Action proto to a client Permission.Action object.
toPermissionAction(Permission.Action) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client Permission.Action to a Permission.Action proto
toPermissionActions(List<AccessControlProtos.Permission.Action>) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Converts a list of Permission.Action proto to a list of client Permission.Action objects.
toProtoNamespaceDescriptor(NamespaceDescriptor) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toProtoQuotaScope(QuotaScope) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client QuotaScope to a protocol buffer QuotaScope
toProtoQuotaScope(QuotaType) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client QuotaType to a protocol buffer QuotaType
toProtoTableName(TableName) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toProtoThrottleType(ThrottleType) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client ThrottleType to a protocol buffer ThrottleType
toProtoTimeUnit(TimeUnit) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client TimeUnit to a protocol buffer TimeUnit
toPut(ClientProtos.MutationProto) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Mutate to a Put.
toPut(ClientProtos.MutationProto, CellScanner) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Mutate to a Put.
toQuotaScope(QuotaProtos.QuotaScope) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer QuotaScope to a client QuotaScope
toQuotaScope(QuotaProtos.QuotaType) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer QuotaType to a client QuotaType
toReadType(Scan.ReadType) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toReadType(ClientProtos.Scan.ReadType) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toRegionEventDescriptor(WALProtos.RegionEventDescriptor.EventType, HRegionInfo, long, ServerName, Map<byte[], List<Path>>) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toRegionEventDescriptor(WALProtos.RegionEventDescriptor.EventType, byte[], byte[], byte[], long, ServerName, Map<byte[], List<Path>>) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toReplicationLoadSink(ClusterStatusProtos.ReplicationLoadSink) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toReplicationLoadSource(ClusterStatusProtos.ReplicationLoadSource) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toReplicationLoadSourceList(List<ClusterStatusProtos.ReplicationLoadSource>) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toResult(Result) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client Result to a protocol buffer Result
toResult(boolean, boolean) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client Result to a protocol buffer Result
toResult(ClientProtos.Result) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Result to a client Result
toResult(ClientProtos.Result, CellScanner) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Result to a client Result
toResultNoData(Result) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client Result to a protocol buffer Result.
toScan(Scan) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client Scan to a protocol buffer Scan
toScan(ClientProtos.Scan) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Scan to a client Scan
toScanMetrics(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toScanMetrics(ScanMetrics, boolean) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toSecurityCapabilityList(List<MasterProtos.SecurityCapabilitiesResponse.Capability>) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert SecurityCapabilitiesResponse.Capability to SecurityCapability
toServerName(ServerName) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a ServerName to a protocol buffer ServerName
toServerName(HBaseProtos.ServerName) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer ServerName to a ServerName
toServerNameList(List<HBaseProtos.ServerName>) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a list of protocol buffer ServerName to a list of ServerName
toShortString() - 类 中的方法org.apache.hadoop.hbase.ServerName
 
toString() - 类 中的方法org.apache.hadoop.hbase.client.HTable
 
toString() - 类 中的方法org.apache.hadoop.hbase.client.Increment
 
toString() - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection.CallTracker
 
toString(int) - 类 中的方法org.apache.hadoop.hbase.client.Operation
Produces a string representation of this Operation.
toString() - 类 中的方法org.apache.hadoop.hbase.client.Operation
Produces a string representation of this Operation.
toString() - 类 中的方法org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
 
toString() - 类 中的方法org.apache.hadoop.hbase.client.Result
 
toString() - 类 中的方法org.apache.hadoop.hbase.client.RetriesExhaustedException.ThrowableWithExtraContext
 
toString() - 类 中的方法org.apache.hadoop.hbase.client.RpcRetryingCaller
 
toString() - 类 中的方法org.apache.hadoop.hbase.ClusterId
 
toString() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
 
toString() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
toString() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
toString() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
toString() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
toString() - 类 中的方法org.apache.hadoop.hbase.filter.CompareFilter
 
toString() - 类 中的方法org.apache.hadoop.hbase.filter.DependentColumnFilter
 
toString() - 类 中的方法org.apache.hadoop.hbase.filter.FilterBase
Return filter's info for debugging and logging purpose.
toString(int) - 类 中的方法org.apache.hadoop.hbase.filter.FilterList
已过时。 
toString() - 类 中的方法org.apache.hadoop.hbase.filter.FilterList
 
toString() - 类 中的方法org.apache.hadoop.hbase.filter.FilterListBase
 
toString() - 类 中的方法org.apache.hadoop.hbase.filter.FuzzyRowFilter
 
toString() - 类 中的方法org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
toString() - 类 中的方法org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
toString(int) - 类 中的方法org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
toString() - 类 中的方法org.apache.hadoop.hbase.filter.PageFilter
 
toString() - 类 中的方法org.apache.hadoop.hbase.filter.PrefixFilter
 
toString() - 类 中的方法org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
toString() - 类 中的方法org.apache.hadoop.hbase.filter.SkipFilter
 
toString() - 类 中的方法org.apache.hadoop.hbase.filter.TimestampsFilter
 
toString(int) - 类 中的方法org.apache.hadoop.hbase.filter.TimestampsFilter
 
toString() - 类 中的方法org.apache.hadoop.hbase.filter.WhileMatchFilter
 
toString() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
toString() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
 
toString() - 类 中的方法org.apache.hadoop.hbase.HRegionLocation
 
toString() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
 
toString() - 类 中的方法org.apache.hadoop.hbase.ipc.ConnectionId
 
toString() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
 
toString() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
 
toString() - 类 中的方法org.apache.hadoop.hbase.RegionLocations
 
toString() - 类 中的方法org.apache.hadoop.hbase.RegionTransition
 
toString() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
toString() - 类 中的方法org.apache.hadoop.hbase.security.access.Permission
 
toString() - 类 中的方法org.apache.hadoop.hbase.security.access.TablePermission
 
toString() - 类 中的方法org.apache.hadoop.hbase.security.access.UserPermission
 
toString() - 类 中的方法org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
toString() - 类 中的方法org.apache.hadoop.hbase.security.visibility.Authorizations
 
toString() - 类 中的方法org.apache.hadoop.hbase.security.visibility.CellVisibility
 
toString() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
 
toString() - 类 中的方法org.apache.hadoop.hbase.ServerName
 
toString(HBaseProtos.SnapshotDescription) - 类 中的静态方法org.apache.hadoop.hbase.snapshot.ClientSnapshotDescriptionUtils
Returns a single line (no \n) representation of snapshot metadata.
toString() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData
已过时。
 
toString() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
 
toString() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
toStringCustomizedValues() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
 
toStringCustomizedValues() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
 
toStringTableAttributes() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
 
toTableName(TableProtos.TableName) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toTablePermission(AccessControlProtos.Permission) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Converts a Permission proto to a client TablePermission object.
toThrottleType(QuotaProtos.ThrottleType) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer ThrottleType to a client ThrottleType
toTimedQuota(long, TimeUnit, QuotaScope) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Build a protocol buffer TimedQuota
toTimeUnit(HBaseProtos.TimeUnit) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer TimeUnit to a client TimeUnit
toToken(Token<AuthenticationTokenIdentifier>) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Converts a Token instance (with embedded identifier) to the protobuf representation.
toToken(AuthenticationProtos.Token) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Converts a protobuf Token message back into a Token instance.
toUserPermission(UserPermission) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client user permission to a user permission proto
toUserPermission(AccessControlProtos.UserPermission) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Converts a user permission proto to a client user permission object.
toUsersAndPermissions(String, Permission) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toUsersAndPermissions(ListMultimap<String, Permission>) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toUsersAndPermissions(AccessControlProtos.UsersAndPermissions) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toUserTablePermissions(ListMultimap<String, TablePermission>) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a ListMultimap<String, TablePermission> where key is username to a protobuf UserPermission
toUserTablePermissions(AccessControlProtos.UsersAndPermissions) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protobuf UserTablePermissions to a ListMultimap<String, TablePermission> where key is username.
trackPeerConfigChanges(ReplicationPeerConfigListener) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeer
Setup a callback for chanages to the replication peer config
trackPeerConfigChanges(ReplicationPeerConfigListener) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
 
transform(KeyValue) - 类 中的方法org.apache.hadoop.hbase.filter.Filter
已过时。
transform(KeyValue) - 类 中的方法org.apache.hadoop.hbase.filter.FilterBase
已过时。
transform(KeyValue) - 类 中的方法org.apache.hadoop.hbase.filter.FilterList
已过时。
transform(KeyValue) - 类 中的方法org.apache.hadoop.hbase.filter.FilterWrapper
已过时。
transformCell(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
transformCell(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
transformCell(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
transformCell(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
transformCell(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.CompareFilter
 
transformCell(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.Filter
Give the filter a chance to transform the passed KeyValue.
transformCell(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.FilterBase
By default no transformation takes place Give the filter a chance to transform the passed KeyValue.
transformCell(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.FilterList
 
transformCell(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.FilterListBase
For FilterList, we can consider a filter list as a node in a tree. sub-filters of the filter list are children of the relative node.
transformCell(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.FilterWrapper
 
transformCell(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
transformCell(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
transformCell(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
transformCell(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
transformCell(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.PageFilter
 
transformCell(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.PrefixFilter
 
transformCell(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.RandomRowFilter
 
transformCell(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
transformCell(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.SkipFilter
 
transformCell(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.TimestampsFilter
 
transformCell(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.WhileMatchFilter
 
transitionNode(ZooKeeperWatcher, HRegionInfo, ServerName, EventType, EventType, int) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKAssign
Method that actually performs unassigned node transitions.
transitionNode(ZooKeeperWatcher, HRegionInfo, ServerName, EventType, EventType, int, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKAssign
 
transitionNodeClosed(ZooKeeperWatcher, HRegionInfo, ServerName, int) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKAssign
Transitions an existing unassigned node for the specified region which is currently in the CLOSING state to be in the CLOSED state.
transitionNodeOpened(ZooKeeperWatcher, HRegionInfo, ServerName, int) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKAssign
Transitions an existing unassigned node for the specified region which is currently in the OPENING state to be in the OPENED state.
transitionNodeOpening(ZooKeeperWatcher, HRegionInfo, ServerName) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKAssign
Transitions an existing unassigned node for the specified region which is currently in the OFFLINE state to be in the OPENING state.
transitionNodeOpening(ZooKeeperWatcher, HRegionInfo, ServerName, EventType) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKAssign
 
translatePFFE(Throwable) - 类 中的静态方法org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
Translates exception for preemptive fast fail checks.
truncateTable(TableName, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Truncate a table.
truncateTable(TableName, boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Truncate a table.
ts - 类 中的变量org.apache.hadoop.hbase.client.Mutation
 
TTL - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
 

U

unassign(byte[], boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Unassign a region from current hosting regionserver.
unassign(byte[], boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
Unassign a region from current hosting regionserver.
UNKNOWN_SERVERNAME - 类 中的静态变量org.apache.hadoop.hbase.ServerName
What to use if server name is unknown.
UnknownProtocolException - org.apache.hadoop.hbase.exceptions中的异常错误
An error requesting an RPC protocol that the server is not serving.
UnknownProtocolException(String) - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.UnknownProtocolException
 
UnknownProtocolException(Class<?>) - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.UnknownProtocolException
 
UnknownProtocolException(Class<?>, String) - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.UnknownProtocolException
 
UnknownRegionException - org.apache.hadoop.hbase中的异常错误
Thrown when we are asked to operate on a region we know nothing about.
UnknownRegionException(String) - 异常错误 的构造器org.apache.hadoop.hbase.UnknownRegionException
 
UnknownScannerException - org.apache.hadoop.hbase中的异常错误
Thrown if a region server is passed an unknown scanner ID.
UnknownScannerException() - 异常错误 的构造器org.apache.hadoop.hbase.UnknownScannerException
 
UnknownScannerException(String) - 异常错误 的构造器org.apache.hadoop.hbase.UnknownScannerException
 
UnknownScannerException(String, Exception) - 异常错误 的构造器org.apache.hadoop.hbase.UnknownScannerException
 
UnknownSnapshotException - org.apache.hadoop.hbase.snapshot中的异常错误
Exception thrown when we get a request for a snapshot we don't recognize.
UnknownSnapshotException(String) - 异常错误 的构造器org.apache.hadoop.hbase.snapshot.UnknownSnapshotException
 
UnknownSnapshotException(String, Exception) - 异常错误 的构造器org.apache.hadoop.hbase.snapshot.UnknownSnapshotException
 
UnmodifyableHTableDescriptor - org.apache.hadoop.hbase.client中的类
Read-only table descriptor.
UnmodifyableHTableDescriptor() - 类 的构造器org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
Default constructor
unregisterAllListeners() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Clean all existing listeners
unregisterListener(ZooKeeperListener) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
UnsupportedCellCodecException - org.apache.hadoop.hbase.ipc中的异常错误
 
UnsupportedCellCodecException() - 异常错误 的构造器org.apache.hadoop.hbase.ipc.UnsupportedCellCodecException
 
UnsupportedCellCodecException(String) - 异常错误 的构造器org.apache.hadoop.hbase.ipc.UnsupportedCellCodecException
 
UnsupportedCellCodecException(String, Throwable) - 异常错误 的构造器org.apache.hadoop.hbase.ipc.UnsupportedCellCodecException
 
UnsupportedCompressionCodecException - org.apache.hadoop.hbase.ipc中的异常错误
 
UnsupportedCompressionCodecException() - 异常错误 的构造器org.apache.hadoop.hbase.ipc.UnsupportedCompressionCodecException
 
UnsupportedCompressionCodecException(String) - 异常错误 的构造器org.apache.hadoop.hbase.ipc.UnsupportedCompressionCodecException
 
UnsupportedCompressionCodecException(String, Throwable) - 异常错误 的构造器org.apache.hadoop.hbase.ipc.UnsupportedCompressionCodecException
 
unthrottleNamespace(String) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Remove the throttling for the specified namespace.
unthrottleTable(TableName) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Remove the throttling for the specified table.
unthrottleUser(String) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Remove the throttling for the specified user.
unthrottleUser(String, TableName) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Remove the throttling for the specified user on the specified table.
unthrottleUser(String, String) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Remove the throttling for the specified user on the specified namespace.
unwrapKey(Configuration, String, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.security.EncryptionUtil
Unwrap a key by decrypting it with the secret key of the given subject.
unwrapRemoteException() - 异常错误 中的方法org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
 
unwrapWALKey(Configuration, String, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.security.EncryptionUtil
Unwrap a wal key by decrypting it with the secret key of the given subject.
update(ClientProtos.RegionLoadStats) - 类 中的方法org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
 
update(byte[], ClientProtos.RegionLoadStats) - 类 中的方法org.apache.hadoop.hbase.client.backoff.ServerStatistics
Good enough attempt.
update(byte[], byte[], R) - 接口 中的方法org.apache.hadoop.hbase.client.coprocessor.Batch.Callback
 
update(ClientProtos.RegionLoadStats) - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection.RegionStats
 
updateCachedLocations(TableName, byte[], byte[], Object, ServerName) - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
Update the location cache.
updateCachedLocations(TableName, byte[], Object, HRegionLocation) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
updateCachedLocations(TableName, byte[], byte[], Object, ServerName) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
internal method, do not use thru HConnection
updateCachedLocations(byte[], byte[], Object, HRegionLocation) - 接口 中的方法org.apache.hadoop.hbase.client.HConnection
已过时。
updateConfiguration(ServerName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Update the configuration and trigger an online config change on the regionserver
updateConfiguration() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
Update the configuration and trigger an online config change on all the regionservers
updateConfiguration(ServerName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
updateConfiguration() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
 
updateDelayInterval(long) - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection.RunnerStats
 
updateDelayInterval(long) - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection
Update delay interval of delay runner.
updateExistingNodeData(ZooKeeperWatcher, String, byte[], int) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
已过时。
Unused
updateLocation(HRegionLocation, boolean, boolean) - 类 中的方法org.apache.hadoop.hbase.RegionLocations
Updates the location with new only if the new location has a higher seqNum than the old one or force is true.
updatePeerConfig(String, ReplicationPeerConfig) - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
 
updatePeerConfig(String, ReplicationPeerConfig) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeers
Updates replication peer configuration and/or peer data
updatePeerConfig(String, ReplicationPeerConfig) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
updateRegionLocation(Connection, HRegionInfo, ServerName, long, long) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
Updates the location of the specified region in hbase:meta to be the specified server hostname and startcode.
updateRegionStats(ServerName, byte[], ClientProtos.RegionLoadStats) - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection
 
updateRegionStats(ServerName, byte[], ClientProtos.RegionLoadStats) - 类 中的方法org.apache.hadoop.hbase.client.ServerStatisticTracker
 
updateRegionStats(ServerName, byte[], ClientProtos.RegionLoadStats) - 接口 中的方法org.apache.hadoop.hbase.client.StatisticTrackable
Update stats per region.
updateResultsMetrics(Result[]) - 类 中的方法org.apache.hadoop.hbase.client.ScannerCallable
 
updateRpc(MetricsConnection.CallStats) - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection.CallTracker
 
updateRpc(Descriptors.MethodDescriptor, Message, MetricsConnection.CallStats) - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection
Report RPC context to metrics system.
updateServerStats(ServerName, byte[], Object) - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection
 
updateStats(T, ServerStatisticTracker, ServerName, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.client.ResultStatsUtil
Update the stats for the specified region if the result is an instance of ResultStatsUtil
updateStats(StatisticTrackable, ServerName, byte[], ClientProtos.RegionLoadStats) - 类 中的静态方法org.apache.hadoop.hbase.client.ResultStatsUtil
 
updateStats(T, ServerStatisticTracker, HRegionLocation) - 类 中的静态方法org.apache.hadoop.hbase.client.ResultStatsUtil
 
updateTimestampToNow() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
 
username - 类 中的变量org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
UserPermission - org.apache.hadoop.hbase.security.access中的类
Represents an authorization for access over the given table, column family plus qualifier, for the given user.
UserPermission() - 类 的构造器org.apache.hadoop.hbase.security.access.UserPermission
Nullary constructor for Writable, do not use
UserPermission(byte[], Permission.Action...) - 类 的构造器org.apache.hadoop.hbase.security.access.UserPermission
Creates a new instance for the given user.
UserPermission(byte[], byte[]) - 类 的构造器org.apache.hadoop.hbase.security.access.UserPermission
Creates a new instance for the given user, matching the actions with the given codes.
UserPermission(byte[], String, Permission.Action...) - 类 的构造器org.apache.hadoop.hbase.security.access.UserPermission
Creates a new instance for the given user.
UserPermission(byte[], String, byte[]) - 类 的构造器org.apache.hadoop.hbase.security.access.UserPermission
Creates a new instance for the given user, matching the actions with the given codes.
UserPermission(byte[], TableName, byte[], Permission.Action...) - 类 的构造器org.apache.hadoop.hbase.security.access.UserPermission
Creates a new instance for the given user, table and column family.
UserPermission(byte[], TableName, byte[], byte[], Permission.Action...) - 类 的构造器org.apache.hadoop.hbase.security.access.UserPermission
Creates a new permission for the given user, table, column family and column qualifier.
UserPermission(byte[], TableName, byte[], byte[], byte[]) - 类 的构造器org.apache.hadoop.hbase.security.access.UserPermission
Creates a new instance for the given user, table, column family and qualifier, matching the actions with the given codes.
UserPermission(byte[], TablePermission) - 类 的构造器org.apache.hadoop.hbase.security.access.UserPermission
Creates a new instance for the given user, table, column family and qualifier, matching the actions with the given codes.
userProvider - 类 中的变量org.apache.hadoop.hbase.ipc.AbstractRpcClient
 

V

validatePut(Put) - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorImpl
 
validatePut(Put) - 类 中的方法org.apache.hadoop.hbase.client.HTable
 
validatePut(Put, int) - 类 中的静态方法org.apache.hadoop.hbase.client.HTable
 
value() - 类 中的方法org.apache.hadoop.hbase.client.Result
Returns the value of the first column in the Result.
ValueFilter - org.apache.hadoop.hbase.filter中的类
This filter is used to filter based on column value.
ValueFilter(CompareFilter.CompareOp, ByteArrayComparable) - 类 的构造器org.apache.hadoop.hbase.filter.ValueFilter
Constructor.
valueOf(String) - 枚举 中的静态方法org.apache.hadoop.hbase.client.Admin.MasterSwitchType
已过时。
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.hadoop.hbase.client.Consistency
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.hadoop.hbase.client.Durability
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.hadoop.hbase.client.IsolationLevel
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.hadoop.hbase.client.Scan.ReadType
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.hadoop.hbase.client.security.SecurityCapability
返回带有指定名称的该类型的枚举常量。
valueOf(int) - 枚举 中的静态方法org.apache.hadoop.hbase.client.security.SecurityCapability
 
valueOf(String) - 枚举 中的静态方法org.apache.hadoop.hbase.Coprocessor.State
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.hadoop.hbase.executor.EventType
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.hadoop.hbase.executor.ExecutorType
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.hadoop.hbase.filter.BitComparator.BitwiseOp
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.hadoop.hbase.filter.CompareFilter.CompareOp
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.hadoop.hbase.filter.Filter.ReturnCode
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.hadoop.hbase.filter.FilterList.Operator
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.hadoop.hbase.filter.FilterWrapper.FilterRowRetCode
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.hadoop.hbase.filter.RegexStringComparator.EngineType
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.hadoop.hbase.KeepDeletedCells
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.hadoop.hbase.master.RegionState.State
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.hadoop.hbase.quotas.QuotaScope
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.hadoop.hbase.quotas.QuotaType
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.hadoop.hbase.quotas.ThrottleType
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.hadoop.hbase.quotas.ThrottlingException.Type
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.hadoop.hbase.regionserver.BloomType
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.hadoop.hbase.regionserver.RegionOpeningState
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.hadoop.hbase.replication.ReplicationPeer.PeerState
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.hadoop.hbase.security.access.Permission.Action
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.hadoop.hbase.security.AuthMethod
返回带有指定名称的该类型的枚举常量。
valueOf(byte) - 枚举 中的静态方法org.apache.hadoop.hbase.security.AuthMethod
Return the object represented by the code.
valueOf(String) - 枚举 中的静态方法org.apache.hadoop.hbase.security.SaslStatus
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.hadoop.hbase.security.SaslUtil.QualityOfProtection
返回带有指定名称的该类型的枚举常量。
valueOf(String, int, long) - 类 中的静态方法org.apache.hadoop.hbase.ServerName
Retrieve an instance of ServerName.
valueOf(String) - 类 中的静态方法org.apache.hadoop.hbase.ServerName
Retrieve an instance of ServerName.
valueOf(String, long) - 类 中的静态方法org.apache.hadoop.hbase.ServerName
Retrieve an instance of ServerName.
valueOf(String) - 枚举 中的静态方法org.apache.hadoop.hbase.util.PoolMap.PoolType
返回带有指定名称的该类型的枚举常量。
valueOf(String, PoolMap.PoolType, PoolMap.PoolType...) - 枚举 中的静态方法org.apache.hadoop.hbase.util.PoolMap.PoolType
 
values() - 枚举 中的静态方法org.apache.hadoop.hbase.client.Admin.MasterSwitchType
已过时。
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.hadoop.hbase.client.Consistency
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.hadoop.hbase.client.Durability
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.hadoop.hbase.client.IsolationLevel
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.hadoop.hbase.client.Scan.ReadType
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.hadoop.hbase.client.security.SecurityCapability
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.hadoop.hbase.Coprocessor.State
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.hadoop.hbase.executor.EventType
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.hadoop.hbase.executor.ExecutorType
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.hadoop.hbase.filter.BitComparator.BitwiseOp
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.hadoop.hbase.filter.CompareFilter.CompareOp
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.hadoop.hbase.filter.Filter.ReturnCode
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.hadoop.hbase.filter.FilterList.Operator
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.hadoop.hbase.filter.FilterWrapper.FilterRowRetCode
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.hadoop.hbase.filter.RegexStringComparator.EngineType
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.hadoop.hbase.KeepDeletedCells
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.hadoop.hbase.master.RegionState.State
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.hadoop.hbase.quotas.QuotaScope
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.hadoop.hbase.quotas.QuotaType
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.hadoop.hbase.quotas.ThrottleType
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.hadoop.hbase.quotas.ThrottlingException.Type
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.hadoop.hbase.regionserver.BloomType
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.hadoop.hbase.regionserver.RegionOpeningState
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.hadoop.hbase.replication.ReplicationPeer.PeerState
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.hadoop.hbase.security.access.Permission.Action
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.hadoop.hbase.security.AuthMethod
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.hadoop.hbase.security.SaslStatus
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.hadoop.hbase.security.SaslUtil.QualityOfProtection
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 接口 中的方法org.apache.hadoop.hbase.util.PoolMap.Pool
 
values() - 枚举 中的静态方法org.apache.hadoop.hbase.util.PoolMap.PoolType
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 类 中的方法org.apache.hadoop.hbase.util.PoolMap.ReusablePool
 
values() - 类 中的方法org.apache.hadoop.hbase.util.PoolMap
 
values(K) - 类 中的方法org.apache.hadoop.hbase.util.PoolMap
 
verifyMetaRegionLocation(HConnection, ZooKeeperWatcher, long) - 类 中的方法org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Verify hbase:meta is deployed and accessible.
verifyMetaRegionLocation(HConnection, ZooKeeperWatcher, long, int) - 类 中的方法org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Verify hbase:meta is deployed and accessible.
VERSION - 接口 中的静态变量org.apache.hadoop.hbase.Coprocessor
 
VERSION - 类 中的静态变量org.apache.hadoop.hbase.HRegionInfo
已过时。
VERSION - 类 中的静态变量org.apache.hadoop.hbase.security.access.Permission
 
VISIBILITY_LABELS_ATTR_KEY - 类 中的静态变量org.apache.hadoop.hbase.security.visibility.VisibilityConstants
The string that is used as key in setting the Operation attributes for visibility labels
VisibilityClient - org.apache.hadoop.hbase.security.visibility中的类
Utility client for doing visibility labels admin operations.
VisibilityClient() - 类 的构造器org.apache.hadoop.hbase.security.visibility.VisibilityClient
 
VisibilityConstants - org.apache.hadoop.hbase.security.visibility中的类
 
VisibilityConstants() - 类 的构造器org.apache.hadoop.hbase.security.visibility.VisibilityConstants
 
VisibilityControllerNotReadyException - org.apache.hadoop.hbase.security.visibility中的异常错误
 
VisibilityControllerNotReadyException(String) - 异常错误 的构造器org.apache.hadoop.hbase.security.visibility.VisibilityControllerNotReadyException
 
VisibilityLabelsValidator - org.apache.hadoop.hbase.security.visibility中的类
A simple validator that validates the labels passed
VisibilityLabelsValidator() - 类 的构造器org.apache.hadoop.hbase.security.visibility.VisibilityLabelsValidator
 
visit(Result) - 接口 中的方法org.apache.hadoop.hbase.MetaTableAccessor.Visitor
Visit the catalog table row.
visitNamespaceQuotas(String, QuotaProtos.Quotas) - 接口 中的方法org.apache.hadoop.hbase.quotas.QuotaTableUtil.NamespaceQuotasVisitor
 
visitTableQuotas(TableName, QuotaProtos.Quotas) - 接口 中的方法org.apache.hadoop.hbase.quotas.QuotaTableUtil.TableQuotasVisitor
 
visitUserQuotas(String, QuotaProtos.Quotas) - 接口 中的方法org.apache.hadoop.hbase.quotas.QuotaTableUtil.UserQuotasVisitor
 
visitUserQuotas(String, TableName, QuotaProtos.Quotas) - 接口 中的方法org.apache.hadoop.hbase.quotas.QuotaTableUtil.UserQuotasVisitor
 
visitUserQuotas(String, String, QuotaProtos.Quotas) - 接口 中的方法org.apache.hadoop.hbase.quotas.QuotaTableUtil.UserQuotasVisitor
 

W

W - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'W'
waitForBaseZNode(Configuration) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Waits for HBase installation's base (parent) znode to become available.
waitForState(long, HBaseAdmin.ProcedureFuture.WaitForStateCallable) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
waitMetaRegionLocation(ZooKeeperWatcher, long) - 类 中的方法org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Gets the meta region location, if available, and waits for up to the specified timeout if not immediately available.
waitMetaRegionLocation(ZooKeeperWatcher, int, long) - 类 中的方法org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Gets the meta region location, if available, and waits for up to the specified timeout if not immediately available.
waitMetaRegionLocation(ZooKeeperWatcher) - 类 中的方法org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Waits indefinitely for availability of hbase:meta.
waitOperationResult(long) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
Fallback implementation in case the procedure is not supported by the server.
waitToBecomeLeader() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
已过时。
Blocks until this instance has claimed the leader ZNode in ZooKeeper
warmupRegion(RpcController, AdminProtos.AdminService.BlockingInterface, HRegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to warmup a region given a region name using admin protocol
wasOperationAttemptedByServer() - 异常错误 中的方法org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
 
watchAndCheckExists(ZooKeeperWatcher, String) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKUtil
Watch the specified znode for delete/create/change events.
watcher - 类 中的变量org.apache.hadoop.hbase.zookeeper.ZooKeeperListener
 
WHEEL_TIMER - 类 中的静态变量org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
WHILE_ARRAY - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
WHILE Array
WHILE_BUFFER - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
 
WhileMatchFilter - org.apache.hadoop.hbase.filter中的类
WhileMatchFilter(Filter) - 类 的构造器org.apache.hadoop.hbase.filter.WhileMatchFilter
 
WHITESPACE - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for whitespace
withStartRow(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Scan
Set the start row of the scan.
withStartRow(byte[], boolean) - 类 中的方法org.apache.hadoop.hbase.client.Scan
Set the start row of the scan.
withStopRow(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Scan
Set the stop row of the scan.
withStopRow(byte[], boolean) - 类 中的方法org.apache.hadoop.hbase.client.Scan
Set the stop row of the scan.
wrapKey(Configuration, byte[], String) - 类 中的静态方法org.apache.hadoop.hbase.security.EncryptionUtil
Protect a key by encrypting it with the secret key of the given subject.
wrapKey(Configuration, String, Key) - 类 中的静态方法org.apache.hadoop.hbase.security.EncryptionUtil
Protect a key by encrypting it with the secret key of the given subject.
Writables - org.apache.hadoop.hbase.util中的类
Utility class with methods for manipulating Writable objects
Writables() - 类 的构造器org.apache.hadoop.hbase.util.Writables
 
write(DataOutput) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
已过时。
Writables are going away. Use HColumnDescriptor.toByteArray() instead.
write(DataOutput) - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
已过时。
Use protobuf serialization instead. See HRegionInfo.toByteArray() and HRegionInfo.toDelimitedByteArray()
write(DataOutput) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
已过时。
Writables are going away. Use MessageLite.toByteArray() instead.
write(DataOutput) - 类 中的方法org.apache.hadoop.hbase.security.access.Permission
 
write(DataOutput) - 类 中的方法org.apache.hadoop.hbase.security.access.TablePermission
 
write(DataOutput) - 类 中的方法org.apache.hadoop.hbase.security.access.UserPermission
 
write(DataOutput) - 枚举 中的方法org.apache.hadoop.hbase.security.AuthMethod
Write to out
write(ChannelHandlerContext, Object, ChannelPromise) - 类 中的方法org.apache.hadoop.hbase.security.SaslWrapHandler
 
write(DataOutput) - 类 中的方法org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
WRITE_BUFFER_SIZE_DEFAULT - 类 中的静态变量org.apache.hadoop.hbase.client.ConnectionConfiguration
 
WRITE_BUFFER_SIZE_KEY - 类 中的静态变量org.apache.hadoop.hbase.client.ConnectionConfiguration
 
writeBufferSize(long) - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorParams
Override the write buffer size specified by the provided Connection's Configuration instance, via the configuration key hbase.client.write.buffer.
writeMapAsString(Map<String, Object>) - 类 中的静态方法org.apache.hadoop.hbase.util.JsonMapper
 
writeObjectAsString(Object) - 类 中的静态方法org.apache.hadoop.hbase.util.JsonMapper
 
writeScanMetrics() - 类 中的方法org.apache.hadoop.hbase.client.ClientScanner
Publish the scan metrics.
writeTO - 类 中的变量org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
WrongRegionException - org.apache.hadoop.hbase.regionserver中的异常错误
Thrown when a request contains a key which is not part of this region
WrongRegionException() - 异常错误 的构造器org.apache.hadoop.hbase.regionserver.WrongRegionException
constructor
WrongRegionException(String) - 异常错误 的构造器org.apache.hadoop.hbase.regionserver.WrongRegionException
Constructor
WrongRowIOException - org.apache.hadoop.hbase.client中的异常错误
 
WrongRowIOException(String) - 异常错误 的构造器org.apache.hadoop.hbase.client.WrongRowIOException
 
WrongVersionException - org.apache.hadoop.hbase.ipc中的异常错误
 
WrongVersionException() - 异常错误 的构造器org.apache.hadoop.hbase.ipc.WrongVersionException
 
WrongVersionException(String) - 异常错误 的构造器org.apache.hadoop.hbase.ipc.WrongVersionException
 
WrongVersionException(String, Throwable) - 异常错误 的构造器org.apache.hadoop.hbase.ipc.WrongVersionException
 

Y

YouAreDeadException - org.apache.hadoop.hbase中的异常错误
This exception is thrown by the master when a region server reports and is already being processed as dead.
YouAreDeadException(String) - 异常错误 的构造器org.apache.hadoop.hbase.YouAreDeadException
 

Z

ZERO - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for Zero
ZkAclReset - org.apache.hadoop.hbase.zookeeper中的类
You may add the jaas.conf option -Djava.security.auth.login.config=/PATH/jaas.conf You may also specify -D to set options "hbase.zookeeper.quorum" (it should be in hbase-site.xml) "zookeeper.znode.parent" (it should be in hbase-site.xml) Use -set-acls to set the ACLs, no option to erase ACLs
ZkAclReset() - 类 的构造器org.apache.hadoop.hbase.zookeeper.ZkAclReset
 
ZKAssign - org.apache.hadoop.hbase.zookeeper中的类
Utility class for doing region assignment in ZooKeeper.
ZKAssign() - 类 的构造器org.apache.hadoop.hbase.zookeeper.ZKAssign
 
ZKClusterId - org.apache.hadoop.hbase.zookeeper中的类
Publishes and synchronizes a unique identifier specific to a given HBase cluster.
ZKClusterId(ZooKeeperWatcher, Abortable) - 类 的构造器org.apache.hadoop.hbase.zookeeper.ZKClusterId
 
ZKLeaderManager - org.apache.hadoop.hbase.zookeeper中的类
已过时。
Not used
ZKLeaderManager(ZooKeeperWatcher, String, byte[], Stoppable) - 类 的构造器org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
已过时。
 
ZKTableStateClientSideReader - org.apache.hadoop.hbase.zookeeper中的类
Non-instantiable class that provides helper functions to learn about HBase table state for code running on client side (hence, not having access to consensus context).
ZKUtil - org.apache.hadoop.hbase.zookeeper中的类
Internal HBase utility class for ZooKeeper.
ZKUtil() - 类 的构造器org.apache.hadoop.hbase.zookeeper.ZKUtil
 
ZKUtil.NodeAndData - org.apache.hadoop.hbase.zookeeper中的类
已过时。
Unused
ZKUtil.NodeAndData(String, byte[]) - 类 的构造器org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData
已过时。
 
ZKUtil.ZKUtilOp - org.apache.hadoop.hbase.zookeeper中的类
Represents an action taken by ZKUtil, e.g. createAndFailSilent.
ZKUtil.ZKUtilOp.CreateAndFailSilent - org.apache.hadoop.hbase.zookeeper中的类
ZKUtilOp representing createAndFailSilent in ZooKeeper (attempt to create node, ignore error if already exists)
ZKUtil.ZKUtilOp.DeleteNodeFailSilent - org.apache.hadoop.hbase.zookeeper中的类
ZKUtilOp representing deleteNodeFailSilent in ZooKeeper (attempt to delete node, ignore error if node doesn't exist)
ZKUtil.ZKUtilOp.SetData - org.apache.hadoop.hbase.zookeeper中的类
ZKUtilOp representing setData in ZooKeeper
ZNODE_PATH_SEPARATOR - 类 中的静态变量org.apache.hadoop.hbase.zookeeper.ZKUtil
 
zookeeper - 类 中的变量org.apache.hadoop.hbase.replication.ReplicationStateZKBase
 
ZOOKEEPER_ZNODE_REPLICATION_HFILE_REFS_DEFAULT - 类 中的静态变量org.apache.hadoop.hbase.replication.ReplicationStateZKBase
 
ZOOKEEPER_ZNODE_REPLICATION_HFILE_REFS_KEY - 类 中的静态变量org.apache.hadoop.hbase.replication.ReplicationStateZKBase
 
ZooKeeperConnectionException - org.apache.hadoop.hbase中的异常错误
Thrown if the client can't connect to ZooKeeper.
ZooKeeperConnectionException() - 异常错误 的构造器org.apache.hadoop.hbase.ZooKeeperConnectionException
 
ZooKeeperConnectionException(String) - 异常错误 的构造器org.apache.hadoop.hbase.ZooKeeperConnectionException
 
ZooKeeperConnectionException(String, Exception) - 异常错误 的构造器org.apache.hadoop.hbase.ZooKeeperConnectionException
Constructor taking another exception.
ZooKeeperListener - org.apache.hadoop.hbase.zookeeper中的类
Base class for internal listeners of ZooKeeper events.
ZooKeeperListener(ZooKeeperWatcher) - 类 的构造器org.apache.hadoop.hbase.zookeeper.ZooKeeperListener
Construct a ZooKeeper event listener.
ZooKeeperNodeTracker - org.apache.hadoop.hbase.zookeeper中的类
Tracks the availability and value of a single ZooKeeper node.
ZooKeeperNodeTracker(ZooKeeperWatcher, String, Abortable) - 类 的构造器org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
Constructs a new ZK node tracker.
ZooKeeperWatcher - org.apache.hadoop.hbase.zookeeper中的类
Acts as the single ZooKeeper Watcher.
ZooKeeperWatcher(Configuration, String, Abortable) - 类 的构造器org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Instantiate a ZooKeeper connection and watcher.
ZooKeeperWatcher(Configuration, String, Abortable, boolean) - 类 的构造器org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Instantiate a ZooKeeper connection and watcher.
A B C D E F G H I J K L M N O P Q R S T U V W Y Z 

Copyright © 2007–2021 The Apache Software Foundation. All rights reserved.