- 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.client.HBaseHbck
-
- Abortable - org.apache.hadoop.hbase中的接口
-
Interface to support the aborting of a given server or client.
- abortProcedure(long, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- abortProcedure(long, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
- abortProcedure(long, boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- abortProcedure(RpcController, MasterProtos.AbortProcedureRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- abortProcedureAsync(long, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- abortProcedureAsync(long, boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- 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.RpcChannelImplementation - org.apache.hadoop.hbase.ipc中的类
-
Async rpc channel that goes via hbase rpc.
- 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中的接口
-
- AccessControlUtil - 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 - 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, 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(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>>) - 类 中的方法org.apache.hadoop.hbase.client.DelayingRunner
-
- add(Cell) - 类 中的方法org.apache.hadoop.hbase.client.Delete
-
Add an existing delete marker to this Delete object.
- add(Cell) - 类 中的方法org.apache.hadoop.hbase.client.Increment
-
Add the specified KeyValue to this operation.
- add(byte[], Action) - 类 中的方法org.apache.hadoop.hbase.client.MultiAction
-
Add an Action to this container based on it's regionName.
- add(byte[], List<Action>) - 类 中的方法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(Cell) - 类 中的方法org.apache.hadoop.hbase.client.Put
-
Add the specified KeyValue to this Put operation.
- add(Put) - 类 中的方法org.apache.hadoop.hbase.client.RowMutations
-
- add(Delete) - 类 中的方法org.apache.hadoop.hbase.client.RowMutations
-
- add(Mutation) - 类 中的方法org.apache.hadoop.hbase.client.RowMutations
-
Currently only supports
Put
and
Delete
mutations.
- add(List<? extends Mutation>) - 类 中的方法org.apache.hadoop.hbase.client.RowMutations
-
Currently only supports
Put
and
Delete
mutations.
- add(S, S) - 类 中的方法org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
- addAndGet(Result[], boolean) - 类 中的方法org.apache.hadoop.hbase.client.BatchScanResultCache
-
- addColumn(TableName, ColumnFamilyDescriptor) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- addColumn(byte[], byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Append
-
Add the specified column and value to this Append operation.
- 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[], 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.
- addColumn(RpcController, MasterProtos.AddColumnRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- addColumnFamily(TableName, ColumnFamilyDescriptor) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Add a column family to an existing table.
- addColumnFamily(TableName, ColumnFamilyDescriptor) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Add a column family to an existing table.
- addColumnFamily(TableName, ColumnFamilyDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- addColumnFamily(ColumnFamilyDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- addColumnFamilyAsync(TableName, ColumnFamilyDescriptor) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Add a column family to an existing table.
- addColumnFamilyAsync(TableName, ColumnFamilyDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- 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.client.TableDescriptorBuilder
-
- addCoprocessor(String, Path, int, Map<String, String>) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- 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.client.TableDescriptorBuilder
-
- addCoprocessorWithSpec(String) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
Add a table coprocessor to this table.
- addDeleteMarker(Cell) - 类 中的方法org.apache.hadoop.hbase.client.Delete
-
- addEstimatedSize(long) - 类 中的方法org.apache.hadoop.hbase.client.ClientAsyncPrefetchScanner
-
- addEstimatedSize(long) - 类 中的方法org.apache.hadoop.hbase.client.ClientScanner
-
- addException(byte[], Throwable) - 类 中的方法org.apache.hadoop.hbase.CacheEvictionStatsBuilder
-
- 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.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
-
- addImmutable(byte[], byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Put
-
- addImmutable(byte[], byte[], long, byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Put
-
- 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.
- addLocation(Put, ServerName, long, int) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
- addPeer(String, ReplicationPeerConfig, Map<TableName, ? extends Collection<String>>) - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- addPeer(String, ReplicationPeerConfig) - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- addRegionInfo(Put, RegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
- addRegionsToMeta(Connection, List<RegionInfo>, int) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
Adds a hbase:meta row for each of the specified new regions.
- addRegionToMeta(Connection, RegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
Adds a (single) hbase:meta row for the specified new region and its daughters.
- addReplicas(TableDescriptor, List<RegionInfo>, int, int) - 类 中的静态方法org.apache.hadoop.hbase.client.RegionReplicaUtil
-
Create any replicas for the regions (the default replicas that was already created is passed to
the method)
- addReplicationBarrier(Put, long) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
- addReplicationPeer(String, ReplicationPeerConfig) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Add a new replication peer for replicating data to slave cluster.
- addReplicationPeer(String, ReplicationPeerConfig, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Add a new replication peer for replicating data to slave cluster.
- addReplicationPeer(String, ReplicationPeerConfig) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Add a new replication peer for replicating data to slave cluster
- addReplicationPeer(String, ReplicationPeerConfig, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Add a new replication peer for replicating data to slave cluster
- addReplicationPeer(String, ReplicationPeerConfig, boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- addReplicationPeer(RpcController, ReplicationProtos.AddReplicationPeerRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- addReplicationPeerAsync(String, ReplicationPeerConfig) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Add a new replication peer but does not block and wait for it.
- addReplicationPeerAsync(String, ReplicationPeerConfig, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Add a new replication peer but does not block and wait for it.
- addReplicationPeerAsync(String, ReplicationPeerConfig, boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- addSplitsToParent(Connection, RegionInfo, RegionInfo, RegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
Adds daughter region infos to hbase:meta row for the specified region.
- 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.
- 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.
- advance() - 类 中的方法org.apache.hadoop.hbase.client.Result
-
- AdvancedScanResultConsumer - org.apache.hadoop.hbase.client中的接口
-
This is the low level API for asynchronous scan.
- AdvancedScanResultConsumer.ScanController - org.apache.hadoop.hbase.client中的接口
-
Used to suspend or stop a scan, or get a scan cursor if available.
- AdvancedScanResultConsumer.ScanResumer - org.apache.hadoop.hbase.client中的接口
-
Used to resume a scan.
- 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
-
- append(CacheEvictionStats) - 类 中的方法org.apache.hadoop.hbase.CacheEvictionStatsAggregator
-
- append(CacheEvictionStats) - 类 中的方法org.apache.hadoop.hbase.CacheEvictionStatsBuilder
-
- 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(byte[], long, NavigableMap<byte[], List<Cell>>) - 类 的构造器org.apache.hadoop.hbase.client.Append
-
Construct the Append with user defined data.
- append(Append) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable
-
Appends values to one or more columns within a single row.
- append(Append) - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
- append(Append) - 接口 中的方法org.apache.hadoop.hbase.client.Table
-
Appends values to one or more columns within a single row.
- appendExcludeTableCFsToReplicationPeerConfig(Map<TableName, List<String>>, ReplicationPeerConfig) - 类 中的静态方法org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
- appendMetaData(byte[], byte[]) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKMetadata
-
- appendPeerTableCFs(String, String) - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- appendPeerTableCFs(String, Map<TableName, ? extends Collection<String>>) - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
已过时。
- appendReplicationPeerTableCFs(String, Map<TableName, List<String>>) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Append the replicable table column family config from the specified peer.
- appendReplicationPeerTableCFs(String, Map<TableName, List<String>>) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Append the replicable table-cf config of the specified peer
- appendReplicationPeerTableCFs(String, Map<TableName, List<String>>) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- appendTableCFsToReplicationPeerConfig(Map<TableName, List<String>>, ReplicationPeerConfig) - 类 中的静态方法org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
- appendTracker - 类 中的变量org.apache.hadoop.hbase.client.MetricsConnection
-
- areAdjacent(RegionInfo, RegionInfo) - 接口 中的静态方法org.apache.hadoop.hbase.client.RegionInfo
-
Check whether two regions are adjacent; i.e. lies just before or just
after in a table.
- areAdjacent(HRegionInfo, HRegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
-
- areScanStartRowAndStopRowEqual(byte[], byte[]) - 类 中的静态方法org.apache.hadoop.hbase.client.ClientUtil
-
- assertSnapshotRequestIsValid(SnapshotProtos.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 a Region.
- assign(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
- assign(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- assignRegion(RpcController, MasterProtos.AssignRegionRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- assigns(List<String>, boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseHbck
-
- assigns(List<String>, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Hbck
-
Like
Admin.assign(byte[])
but 'raw' in that it can do more than one Region at a time
-- good if many Regions to online -- and it will schedule the assigns even in the case where
Master is initializing (as long as the ProcedureExecutor is up).
- assigns(List<String>) - 接口 中的方法org.apache.hadoop.hbase.client.Hbck
-
- AsyncAdmin - org.apache.hadoop.hbase.client中的接口
-
The asynchronous administrative API for HBase.
- AsyncAdminBuilder - org.apache.hadoop.hbase.client中的接口
-
- AsyncAdminRequestRetryingCaller<T> - org.apache.hadoop.hbase.client中的类
-
- AsyncAdminRequestRetryingCaller(Timer, AsyncConnectionImpl, int, long, long, int, long, long, int, ServerName, AsyncAdminRequestRetryingCaller.Callable<T>) - 类 的构造器org.apache.hadoop.hbase.client.AsyncAdminRequestRetryingCaller
-
- AsyncAdminRequestRetryingCaller.Callable<T> - org.apache.hadoop.hbase.client中的接口
-
- AsyncBufferedMutator - org.apache.hadoop.hbase.client中的接口
-
Used to communicate with a single HBase table in batches.
- AsyncBufferedMutatorBuilder - org.apache.hadoop.hbase.client中的接口
-
- AsyncConnection - org.apache.hadoop.hbase.client中的接口
-
The asynchronous version of Connection.
- AsyncMasterRequestRpcRetryingCaller<T> - org.apache.hadoop.hbase.client中的类
-
Retry caller for a request call to master.
- AsyncMasterRequestRpcRetryingCaller(Timer, AsyncConnectionImpl, AsyncMasterRequestRpcRetryingCaller.Callable<T>, int, long, long, int, long, long, int) - 类 的构造器org.apache.hadoop.hbase.client.AsyncMasterRequestRpcRetryingCaller
-
- AsyncMasterRequestRpcRetryingCaller.Callable<T> - org.apache.hadoop.hbase.client中的接口
-
- AsyncMetaTableAccessor - org.apache.hadoop.hbase中的类
-
The asynchronous meta table accessor.
- AsyncMetaTableAccessor() - 类 的构造器org.apache.hadoop.hbase.AsyncMetaTableAccessor
-
- AsyncProcessTask<T> - org.apache.hadoop.hbase.client中的类
-
Contains the attributes of a task which will be executed
by
AsyncProcess
.
- AsyncProcessTask.Builder<T> - org.apache.hadoop.hbase.client中的类
-
- AsyncProcessTask.SubmittedRows - org.apache.hadoop.hbase.client中的枚举
-
The number of processed rows.
- AsyncRequestFuture - org.apache.hadoop.hbase.client中的接口
-
The context used to wait for results from one submit call.
- AsyncRpcRetryingCaller<T> - org.apache.hadoop.hbase.client中的类
-
- AsyncRpcRetryingCaller(Timer, AsyncConnectionImpl, int, long, long, int, long, long, int) - 类 的构造器org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
-
- AsyncServerRequestRpcRetryingCaller<T> - org.apache.hadoop.hbase.client中的类
-
Retry caller for a request call to region server.
- AsyncServerRequestRpcRetryingCaller(Timer, AsyncConnectionImpl, long, long, int, long, long, int, ServerName, AsyncServerRequestRpcRetryingCaller.Callable<T>) - 类 的构造器org.apache.hadoop.hbase.client.AsyncServerRequestRpcRetryingCaller
-
- AsyncServerRequestRpcRetryingCaller.Callable<T> - org.apache.hadoop.hbase.client中的接口
-
- AsyncTable<C extends ScanResultConsumerBase> - org.apache.hadoop.hbase.client中的接口
-
The interface for asynchronous version of Table.
- AsyncTable.CheckAndMutateBuilder - org.apache.hadoop.hbase.client中的接口
-
A helper class for sending checkAndMutate request.
- AsyncTable.CoprocessorCallback<R> - org.apache.hadoop.hbase.client中的接口
-
The callback when we want to execute a coprocessor call on a range of regions.
- AsyncTable.CoprocessorServiceBuilder<S,R> - org.apache.hadoop.hbase.client中的接口
-
Helper class for sending coprocessorService request that executes a coprocessor call on regions
which are covered by a range.
- AsyncTableBuilder<C extends ScanResultConsumerBase> - org.apache.hadoop.hbase.client中的接口
-
- AsyncTableRegionLocator - org.apache.hadoop.hbase.client中的接口
-
The asynchronous version of RegionLocator.
- 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
-
- available(Configuration) - 类 中的静态方法org.apache.hadoop.hbase.client.HBaseAdmin
-
Is HBase available?
- 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.ZNodePaths
-
- 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
-
- balance() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Invoke the balancer.
- balance(boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Invoke the balancer.
- balance() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Invoke the balancer.
- balance(boolean) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Invoke the balancer.
- balance() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- balance(boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- balance(RpcController, MasterProtos.BalanceRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- balancer() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- balancer(boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- balancerSwitch(boolean, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Turn the load balancer on or off.
- balancerSwitch(boolean) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Turn the load balancer on or off.
- balancerSwitch(boolean, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Turn the load balancer on or off.
- balancerSwitch(boolean, boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- balancerZNode - 类 中的变量org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
- baseZNode - 类 中的变量org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
- batch(List<? extends Row>) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable
-
Method that does a batch call on Deletes, Gets, Puts, Increments, Appends and RowMutations.
- 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[]) - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
- batch(List<? extends Row>, Object[], int) - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
- batch(List<? extends Row>, Object[]) - 接口 中的方法org.apache.hadoop.hbase.client.Table
-
Method that does a batch call on Deletes, Gets, Puts, Increments, Appends, RowMutations.
- 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中的接口
-
- batchAll(List<? extends Row>) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable
-
A simple version of batch.
- batchCallback(List<? extends Row>, Object[], Batch.Callback<R>) - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
- batchCallback(List<? extends Row>, Object[], Batch.Callback<R>) - 接口 中的方法org.apache.hadoop.hbase.client.Table
-
- batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R) - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
- batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R, Batch.Callback<R>) - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
- 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(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
-
- BigDecimalComparator - org.apache.hadoop.hbase.filter中的类
-
A BigDecimal comparator which numerical compares against the specified byte array
- BigDecimalComparator(BigDecimal) - 类 的构造器org.apache.hadoop.hbase.filter.BigDecimalComparator
-
- BinaryComparator - org.apache.hadoop.hbase.filter中的类
-
- 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.client.ColumnFamilyDescriptorBuilder
-
Key for the BLOCKCACHE attribute.
- BLOCKCACHE - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- BlockingRpcCallback<R> - org.apache.hadoop.hbase.ipc中的类
-
- BlockingRpcCallback() - 类 的构造器org.apache.hadoop.hbase.ipc.BlockingRpcCallback
-
- BlockingRpcCallback() - 类 的构造器org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils.BlockingRpcCallback
-
- BlockingRpcChannelImplementation(AbstractRpcClient<?>, InetSocketAddress, User, int) - 类 的构造器org.apache.hadoop.hbase.ipc.AbstractRpcClient.BlockingRpcChannelImplementation
-
- 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.client.ColumnFamilyDescriptorBuilder
-
Size of storefile/hfile 'blocks'.
- BLOCKSIZE - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- BLOOMFILTER - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- BLOOMFILTER - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- BloomType - org.apache.hadoop.hbase.regionserver中的枚举
-
- 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中的接口
-
- BufferedMutatorImpl - org.apache.hadoop.hbase.client中的类
-
Used to communicate with a single HBase table similar to
Table
but meant for batched, potentially asynchronous puts.
- BufferedMutatorParams - org.apache.hadoop.hbase.client中的类
-
- BufferedMutatorParams(TableName) - 类 的构造器org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- build() - 类 中的方法org.apache.hadoop.hbase.CacheEvictionStatsBuilder
-
- build() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdminBuilder
-
- build() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
-
- build() - 类 中的方法org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
-
- build() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTableBuilder
-
- build() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- build() - 类 中的方法org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder
-
- build() - 类 中的方法org.apache.hadoop.hbase.client.RegionInfoBuilder
-
- build() - 接口 中的方法org.apache.hadoop.hbase.client.TableBuilder
-
Create the
Table
instance.
- build() - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- build() - 类 中的方法org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- build() - 类 中的方法org.apache.hadoop.hbase.RegionMetricsBuilder
-
- build() - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Builds the configuration object from the current state of this
.
- build() - 类 中的方法org.apache.hadoop.hbase.security.access.GetUserPermissionsRequest.Builder
-
- build() - 类 中的方法org.apache.hadoop.hbase.security.access.Permission.Builder
-
- build() - 类 中的方法org.apache.hadoop.hbase.ServerMetricsBuilder
-
- buildActionResult(Throwable) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
-
Wrap a throwable to an action result.
- buildActionResult(ClientProtos.Result) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
-
Wrap a throwable to an action result.
- buildAddColumnRequest(TableName, ColumnFamilyDescriptor, long, long) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Create a protocol buffer AddColumnRequest
- buildAddReplicationPeerRequest(String, ReplicationPeerConfig, boolean) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
- buildAssignRegionRequest(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Create a protocol buffer AssignRegionRequest
- buildBalanceRequest(boolean) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a protocol buffer BalanceRequest
- buildBulkLoadHFileRequest(List<Pair<byte[], String>>, byte[], boolean, Token<?>, String) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Create a protocol buffer bulk load request
- buildBulkLoadHFileRequest(List<Pair<byte[], String>>, byte[], boolean, Token<?>, String, boolean) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Create a protocol buffer bulk load request
- buildCatalogScanRequest() - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a request for running a catalog scan
- buildClearCompactionQueuesRequest(Set<String>) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
- buildClearDeadServersRequest(Collection<ServerName>) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
- buildClearRegionBlockCacheRequest(List<RegionInfo>) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a protocol buffer ClearRegionBlockCacheRequest
- buildClearRegionBlockCacheResponse(HBaseProtos.CacheEvictionStats) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
-
Creates a protocol buffer ClearRegionBlockCacheResponse
- buildCloseRegionRequest(ServerName, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Create a CloseRegionRequest for a given region name
- buildCloseRegionRequest(ServerName, byte[], ServerName) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- buildCloseRegionRequest(ServerName, byte[], ServerName, long) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- buildCompactRegionRequest(byte[], boolean, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Create a CompactRegionRequest for a given region name
- buildCondition(byte[], byte[], byte[], ByteArrayComparable, HBaseProtos.CompareType, TimeRange) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Create a protocol buffer Condition
- buildCreateNamespaceRequest(NamespaceDescriptor) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a protocol buffer CreateNamespaceRequest
- buildCreateTableRequest(TableDescriptor, byte[][], long, long) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a protocol buffer CreateTableRequest
- buildDecommissionRegionServersRequest(List<ServerName>, boolean) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
- buildDeleteColumnRequest(TableName, byte[], long, long) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Create a protocol buffer DeleteColumnRequest
- buildDeleteNamespaceRequest(String) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a protocol buffer DeleteNamespaceRequest
- buildDeleteTableRequest(TableName, long, long) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a protocol buffer DeleteTableRequest
- buildDisableReplicationPeerRequest(String) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
- buildDisableTableRequest(TableName, long, long) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a protocol buffer DisableTableRequest
- buildEnableCatalogJanitorRequest(boolean) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a request for enabling/disabling the catalog janitor
- buildEnableCatalogJanitorResponse(boolean) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
-
Creates a response for the catalog scan request
- buildEnableReplicationPeerRequest(String) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
- buildEnableTableRequest(TableName, long, long) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a protocol buffer EnableTableRequest
- builder() - 类 中的静态方法org.apache.hadoop.hbase.CacheEvictionStats
-
- buildException(Throwable) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
-
- buildFlushRegionRequest(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Create a protocol buffer FlushRegionRequest for a given region name
- buildFlushRegionRequest(byte[], boolean) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Create a protocol buffer FlushRegionRequest for a given region name
- buildFromProto(MasterProtos.SetQuotaRequest) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaSettings
-
Converts the protocol buffer request into a QuotaSetting POJO.
- buildGetClusterStatusRequest(EnumSet<ClusterMetrics.Option>) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a protocol buffer GetClusterStatusRequest
- buildGetLastFlushedSequenceIdRequest(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a request for querying the master the last flushed sequence Id for a region
- buildGetLastFlushedSequenceIdResponse(ClusterStatusProtos.RegionStoreSequenceIds) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
-
Creates a response for the last flushed sequence Id request
- buildGetNamespaceDescriptorRequest(String) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a protocol buffer GetNamespaceDescriptorRequest
- buildGetOnlineRegionRequest() - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Create a protocol buffer GetOnlineRegionRequest
- buildGetOnlineRegionResponse(List<RegionInfo>) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
-
A utility to build a GetOnlineRegionResponse.
- buildGetQuotaStatesRequest() - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
- buildGetRegionInfoRequest(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Create a protocol buffer GetRegionInfoRequest for a given region name
- buildGetRegionInfoRequest(byte[], boolean) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Create a protocol buffer GetRegionInfoRequest for a given region name
- buildGetRegionInfoRequest(byte[], boolean, boolean) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
- buildGetRegionLoadRequest(TableName) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Create a protocol buffer GetRegionLoadRequest for all regions/regions of a table.
- buildGetReplicationPeerConfigRequest(String) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
- buildGetRequest(byte[], Get) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Create a protocol buffer GetRequest for a client Get
- buildGetSchemaAlterStatusRequest(TableName) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a protocol buffer GetSchemaAlterStatusRequest
- buildGetServerInfoRequest() - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Create a new GetServerInfoRequest
- buildGetServerInfoRequest() - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Create a new GetServerInfoRequest
- buildGetServerInfoResponse(ServerName, int) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
-
A utility to build a GetServerInfoResponse.
- buildGetSpaceQuotaRegionSizesRequest() - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
- buildGetSpaceQuotaSnapshotsRequest() - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
- buildGetStoreFileRequest(byte[], byte[]) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Create a protocol buffer GetStoreFileRequest for a given region name
- buildGetTableDescriptorsRequest(List<TableName>) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a protocol buffer GetTableDescriptorsRequest
- buildGetTableDescriptorsRequest(Pattern, boolean) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a protocol buffer GetTableDescriptorsRequest
- buildGetTableDescriptorsRequest(TableName) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a protocol buffer GetTableDescriptorsRequest for a single table
- buildGetTableNamesRequest(Pattern, boolean) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a protocol buffer GetTableNamesRequest
- buildGetTableStateRequest(TableName) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a protocol buffer GetTableStateRequest
- buildGetUserPermissionsRequest(GetUserPermissionsRequest) - 类 中的静态方法org.apache.hadoop.hbase.security.access.ShadedAccessControlUtil
-
- buildGetUserPermissionsResponse(List<UserPermission>) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlUtil
-
Converts the permissions list into a protocol buffer GetUserPermissionsResponse
- buildGetUserPermissionsResponse(List<UserPermission>) - 类 中的静态方法org.apache.hadoop.hbase.security.access.ShadedAccessControlUtil
-
- buildGrantRequest(String, TableName, byte[], byte[], boolean, AccessControlProtos.Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlUtil
-
Create a request to grant user table permissions.
- buildGrantRequest(String, String, boolean, AccessControlProtos.Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlUtil
-
Create a request to grant user namespace permissions.
- buildGrantRequest(String, boolean, AccessControlProtos.Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlUtil
-
Create a request to grant user global permissions.
- buildGrantRequest(UserPermission, boolean) - 类 中的静态方法org.apache.hadoop.hbase.security.access.ShadedAccessControlUtil
-
- buildHasPermissionResponse(boolean) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
-
Builds a protocol buffer HasPermissionResponse
- buildHasUserPermissionsRequest(String, List<Permission>) - 类 中的静态方法org.apache.hadoop.hbase.security.access.ShadedAccessControlUtil
-
- buildIncrementRequest(byte[], byte[], byte[], byte[], long, Durability, long, long) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Create a protocol buffer MutateRequest for a client increment
- buildIsBalancerEnabledRequest() - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a protocol buffer IsBalancerEnabledRequest
- buildIsCatalogJanitorEnabledRequest() - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a request for querying the master whether the catalog janitor is enabled
- buildIsCleanerChoreEnabledRequest() - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a request for querying the master whether the cleaner chore is enabled
- buildIsMasterRunningRequest() - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a protocol buffer IsMasterRunningRequest
- buildIsNormalizerEnabledRequest() - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a protocol buffer IsNormalizerEnabledRequest
- buildIsSplitOrMergeEnabledRequest(MasterSwitchType) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a protocol buffer IsSplitOrMergeEnabledRequest
- buildListReplicationPeersRequest(Pattern) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
- buildMergeTableRegionsRequest(byte[][], boolean, long, long) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
- buildModifyColumnRequest(TableName, ColumnFamilyDescriptor, long, long) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Create a protocol buffer ModifyColumnRequest
- buildModifyNamespaceRequest(NamespaceDescriptor) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a protocol buffer ModifyNamespaceRequest
- buildModifyTableRequest(TableName, TableDescriptor, long, long) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a protocol buffer ModifyTableRequest
- buildMoveRegionRequest(byte[], ServerName) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Create a protocol buffer MoveRegionRequest
- buildMutateRequest(byte[], byte[], byte[], byte[], ByteArrayComparable, HBaseProtos.CompareType, TimeRange, Put) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Create a protocol buffer MutateRequest for a conditioned put
- buildMutateRequest(byte[], byte[], byte[], byte[], ByteArrayComparable, HBaseProtos.CompareType, TimeRange, Delete) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Create a protocol buffer MutateRequest for a conditioned delete
- buildMutateRequest(byte[], byte[], byte[], byte[], ByteArrayComparable, HBaseProtos.CompareType, TimeRange, Mutation, ClientProtos.MutationProto.MutationType) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
- buildMutateRequest(byte[], byte[], byte[], byte[], ByteArrayComparable, HBaseProtos.CompareType, TimeRange, RowMutations) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Create a protocol buffer MutateRequest for conditioned row mutations
- buildMutateRequest(byte[], Put) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Create a protocol buffer MutateRequest for a put
- buildMutateRequest(byte[], Append, long, long) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Create a protocol buffer MutateRequest for an append
- buildMutateRequest(byte[], Increment, long, long) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Create a protocol buffer MutateRequest for a client increment
- buildMutateRequest(byte[], Delete) - 类 中的静态方法org.apache.hadoop.hbase.shaded.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.shaded.protobuf.RequestConverter
-
Create a protocol buffer MultiRequest for row mutations that does not hold data.
- buildNoDataRegionActions(byte[], Iterable<Action>, List<CellScannable>, ClientProtos.MultiRequest.Builder, ClientProtos.RegionAction.Builder, ClientProtos.Action.Builder, ClientProtos.MutationProto.Builder, long, Map<Integer, Integer>) - 类 中的静态方法org.apache.hadoop.hbase.shaded.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.shaded.protobuf.RequestConverter
-
Creates a protocol buffer NormalizeRequest
- buildOfflineRegionRequest(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a protocol buffer OfflineRegionRequest
- buildOpenRegionRequest(ServerName, RegionInfo, List<ServerName>) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Create a protocol buffer OpenRegionRequest for a given region
- buildProcedureDescription(String, String, Map<String, String>) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- buildRecommissionRegionServerRequest(ServerName, List<byte[]>) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
- buildRegionAction(byte[], RowMutations) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Create a protocol buffer MultiRequest for row mutations.
- buildRegionActions(byte[], List<Action>, ClientProtos.MultiRequest.Builder, ClientProtos.RegionAction.Builder, ClientProtos.Action.Builder, ClientProtos.MutationProto.Builder, long, Map<Integer, Integer>) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Create a protocol buffer multi request for a list of actions.
- buildRegionOpenInfo(RegionInfo, List<ServerName>, long) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Create a RegionOpenInfo based on given region info and version of offline node
- buildRegionSpecifier(HBaseProtos.RegionSpecifier.RegionSpecifierType, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a byte array to a protocol buffer RegionSpecifier
- buildRegionSpecifier(HBaseProtos.RegionSpecifier.RegionSpecifierType, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Convert a byte array to a protocol buffer RegionSpecifier
- buildRemoveReplicationPeerRequest(String) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
- buildRevokeRequest(String, AccessControlProtos.Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlUtil
-
Create a request to revoke user global permissions.
- buildRevokeRequest(String, String, AccessControlProtos.Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlUtil
-
Create a request to revoke user namespace permissions.
- buildRevokeRequest(String, TableName, byte[], byte[], AccessControlProtos.Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlUtil
-
Create a request to revoke user table permissions.
- buildRevokeRequest(UserPermission) - 类 中的静态方法org.apache.hadoop.hbase.security.access.ShadedAccessControlUtil
-
- buildRollWALWriterRequest() - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Create a new RollWALWriterRequest
- buildRunCatalogScanResponse(int) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
-
Creates a response for the catalog scan request
- buildRunCleanerChoreRequest() - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a request for running cleaner chore
- buildRunCleanerChoreResponse(boolean) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
-
Creates a response for the cleaner chore request
- buildScanRequest(byte[], Scan, int, boolean) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Create a protocol buffer ScanRequest for a client Scan
- buildScanRequest(long, int, boolean, boolean) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Create a protocol buffer ScanRequest for a scanner id
- buildScanRequest(long, int, boolean, long, boolean, boolean, int) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Create a protocol buffer ScanRequest for a scanner id
- buildSetBalancerRunningRequest(boolean, boolean) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a protocol buffer SetBalancerRunningRequest
- buildSetCleanerChoreRunningRequest(boolean) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a request for enabling/disabling the cleaner chore
- buildSetNormalizerRunningRequest(boolean) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a protocol buffer SetNormalizerRunningRequest
- buildSetQuotaRequestProto(QuotaSettings) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaSettings
-
Convert a QuotaSettings to a protocol buffer SetQuotaRequest.
- buildSetSplitOrMergeEnabledRequest(boolean, boolean, MasterSwitchType...) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a protocol buffer SetSplitOrMergeEnabledRequest
- buildSetTableStateInMetaRequest(TableState) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a protocol buffer SetTableStateInMetaRequest
- buildSplitTableRegionRequest(RegionInfo, byte[], long, long) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
- buildStopServerRequest(String) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Create a new StopServerRequest
- buildTruncateTableRequest(TableName, boolean, long, long) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a protocol buffer TruncateTableRequest
- buildUnassignRegionRequest(byte[], boolean) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Creates a protocol buffer UnassignRegionRequest
- buildUpdateFavoredNodesRequest(List<Pair<RegionInfo, List<ServerName>>>) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Create a protocol buffer UpdateFavoredNodesRequest to update a list of favorednode mappings
- buildUpdateReplicationPeerConfigRequest(String, ReplicationPeerConfig) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
- buildWarmupRegionRequest(RegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
Create a WarmupRegionRequest for a given region name
- bypassGlobals(String, boolean) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Set the "bypass global settings" for the specified user
- bypassProcedure(List<Long>, long, boolean, boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseHbck
-
- bypassProcedure(List<Long>, long, boolean, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Hbck
-
Bypass specified procedure and move it to completion.
- 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
-
- cache - 类 中的变量org.apache.hadoop.hbase.client.ClientScanner
-
- CACHE_BLOOMS_ON_WRITE - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- CACHE_BLOOMS_ON_WRITE - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- CACHE_DATA_IN_L1 - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- CACHE_DATA_ON_WRITE - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- CACHE_DATA_ON_WRITE - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- CACHE_INDEX_ON_WRITE - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- CACHE_INDEX_ON_WRITE - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- CacheEvictionStats - org.apache.hadoop.hbase中的类
-
- CacheEvictionStatsAggregator - org.apache.hadoop.hbase中的类
-
Used to merge CacheEvictionStats.
- CacheEvictionStatsAggregator() - 类 的构造器org.apache.hadoop.hbase.CacheEvictionStatsAggregator
-
- CacheEvictionStatsBuilder - org.apache.hadoop.hbase中的类
-
- 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(HBaseRpcController, AdminProtos.AdminService.Interface) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdminRequestRetryingCaller.Callable
-
- call(HBaseRpcController, MasterProtos.MasterService.Interface) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncMasterRequestRpcRetryingCaller.Callable
-
- call(HBaseRpcController, ClientProtos.ClientService.Interface) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncServerRequestRpcRetryingCaller.Callable
-
- call(T) - 接口 中的方法org.apache.hadoop.hbase.client.coprocessor.Batch.Call
-
- call(HBaseRpcController) - 类 中的方法org.apache.hadoop.hbase.client.FlushRegionCallable
-
- call(int) - 类 中的方法org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
- call(HBaseRpcController) - 类 中的方法org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
Run RPC call.
- call(int) - 类 中的方法org.apache.hadoop.hbase.client.RegionServerCallable
-
- 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(S, RpcController, RpcCallback<R>) - 接口 中的方法org.apache.hadoop.hbase.client.ServiceCaller
-
Represent the actual protobuf rpc call.
- call(Callable<T>) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Contain ServiceException inside here.
- callable - 类 中的变量org.apache.hadoop.hbase.client.ClientScanner
-
- callBlockingMethod(Descriptors.MethodDescriptor, RpcController, Message, Message) - 类 中的方法org.apache.hadoop.hbase.ipc.AbstractRpcClient.BlockingRpcChannelImplementation
-
- 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
-
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, Message, RpcCallback<Message>) - 类 中的方法org.apache.hadoop.hbase.client.RegionServerCoprocessorRpcChannelImpl
-
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, Message, RpcCallback<Message>) - 类 中的方法org.apache.hadoop.hbase.ipc.AbstractRpcClient.RpcChannelImplementation
-
- CallQueueTooBigException - org.apache.hadoop.hbase中的异常错误
-
- CallQueueTooBigException() - 异常错误 的构造器org.apache.hadoop.hbase.CallQueueTooBigException
-
- CallQueueTooBigException(String) - 异常错误 的构造器org.apache.hadoop.hbase.CallQueueTooBigException
-
- CallStats() - 类 的构造器org.apache.hadoop.hbase.client.MetricsConnection.CallStats
-
- 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.
- callWithoutRetries(RetryingCallable<T>, int) - 类 中的方法org.apache.hadoop.hbase.client.RpcRetryingCallerImpl
-
- callWithRetries(RetryingCallable<T>, int) - 接口 中的方法org.apache.hadoop.hbase.client.RpcRetryingCaller
-
Retries if invocation fails.
- callWithRetries(RetryingCallable<T>, int) - 类 中的方法org.apache.hadoop.hbase.client.RpcRetryingCallerImpl
-
- cancel(boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
-
- cancel() - 接口 中的方法org.apache.hadoop.hbase.client.RpcRetryingCaller
-
- cancel() - 类 中的方法org.apache.hadoop.hbase.client.RpcRetryingCallerImpl
-
- 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.
- canTakeRow(HRegionLocation, Row) - 接口 中的方法org.apache.hadoop.hbase.client.RequestController.Checker
-
Checks the data whether it is valid to submit.
- 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.
- catalogJanitorSwitch(boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Enable/Disable the catalog janitor/
- catalogJanitorSwitch(boolean) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Turn the catalog janitor on/off.
- catalogJanitorSwitch(boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- cConnection - 类 中的变量org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
-
- 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.CryptoAESUnwrapHandler
-
- channelRead0(ChannelHandlerContext, ByteBuf) - 类 中的方法org.apache.hadoop.hbase.security.NettyHBaseRpcConnectionHeaderHandler
-
- 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
-
已过时。
- checkAndDelete(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Delete) - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
已过时。
- checkAndDelete(byte[], byte[], byte[], CompareOperator, byte[], Delete) - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
已过时。
- checkAndDelete(byte[], byte[], byte[], byte[], Delete) - 接口 中的方法org.apache.hadoop.hbase.client.Table
-
- checkAndDelete(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Delete) - 接口 中的方法org.apache.hadoop.hbase.client.Table
-
- checkAndDelete(byte[], byte[], byte[], CompareOperator, byte[], Delete) - 接口 中的方法org.apache.hadoop.hbase.client.Table
-
- checkAndGetReversed(List<Filter>, boolean) - 类 中的静态方法org.apache.hadoop.hbase.filter.FilterListBase
-
- checkAndMutate(byte[], byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable
-
Atomically checks if a row/family/qualifier value matches the expected value.
- checkAndMutate(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
- checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], RowMutations) - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
已过时。
- checkAndMutate(byte[], byte[], byte[], CompareOperator, byte[], RowMutations) - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
已过时。
- checkAndMutate(byte[], byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Table
-
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
-
- checkAndMutate(byte[], byte[], byte[], CompareOperator, byte[], RowMutations) - 接口 中的方法org.apache.hadoop.hbase.client.Table
-
- checkAndPut(byte[], byte[], byte[], byte[], Put) - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
已过时。
- checkAndPut(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Put) - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
已过时。
- checkAndPut(byte[], byte[], byte[], CompareOperator, byte[], Put) - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
已过时。
- checkAndPut(byte[], byte[], byte[], byte[], Put) - 接口 中的方法org.apache.hadoop.hbase.client.Table
-
- checkAndPut(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Put) - 接口 中的方法org.apache.hadoop.hbase.client.Table
-
- checkAndPut(byte[], byte[], byte[], CompareOperator, byte[], Put) - 接口 中的方法org.apache.hadoop.hbase.client.Table
-
- 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'
- 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
- checkState(int) - 接口 中的方法org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture.WaitForStateCallable
-
- classifyExs(List<Throwable>) - 异常错误 中的静态方法org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- CLASSNAME_KEY - 接口 中的静态变量org.apache.hadoop.hbase.client.BufferedMutator
-
Key to use setting non-default BufferedMutator implementation in Configuration.
- cleanerChoreSwitch(boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Enable/Disable the cleaner chore.
- cleanerChoreSwitch(boolean) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Turn the cleaner chore on/off.
- cleanerChoreSwitch(boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- cleanupBulkLoad(Connection, String) - 类 中的方法org.apache.hadoop.hbase.client.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.
- clearBlockCache(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Clear all the blocks corresponding to this table from BlockCache.
- clearBlockCache(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Clear all the blocks corresponding to this table from BlockCache.
- clearBlockCache(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
Clear all the blocks corresponding to this table from BlockCache.
- 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(RegionInfo) - 类 中的方法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
.
- clearCompactionQueues(ServerName, Set<String>) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Clear compacting queues on a regionserver.
- clearCompactionQueues(ServerName, Set<String>) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Clear compacting queues on a region server.
- clearCompactionQueues(ServerName, Set<String>) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- clearDeadServers(List<ServerName>) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Clear dead region servers from master.
- clearDeadServers(List<ServerName>) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Clear dead region servers from master.
- clearDeadServers(List<ServerName>) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- clearDeadServers(RpcController, MasterProtos.ClearDeadServersRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- clearRegionCache() - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
-
- 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.HTable
-
Explicitly clears the region cache to fetch the latest value from META.
- clearRegionLocationCache() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncConnection
-
Clear all the entries in the region location cache, for all the tables.
- clearRegionLocationCache() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Clear all the entries in the region location cache.
- clearRegionLocationCache() - 接口 中的方法org.apache.hadoop.hbase.client.Connection
-
Clear all the entries in the region location cache, for all the tables.
- clearRegionLocationCache() - 类 中的方法org.apache.hadoop.hbase.client.HRegionLocator
-
- clearRegionLocationCache() - 接口 中的方法org.apache.hadoop.hbase.client.RegionLocator
-
Clear all the entries in the region location cache.
- CLIENT_NONCES_ENABLED_KEY - 接口 中的静态变量org.apache.hadoop.hbase.client.NonceGenerator
-
- CLIENT_SIDE_METRICS_ENABLED_KEY - 类 中的静态变量org.apache.hadoop.hbase.client.MetricsConnection
-
Set this key to true
to enable metrics collection of client requests.
- ClientAsyncPrefetchScanner - org.apache.hadoop.hbase.client中的类
-
ClientAsyncPrefetchScanner implements async scanner behaviour.
- ClientAsyncPrefetchScanner(Configuration, Scan, TableName, ClusterConnection, RpcRetryingCallerFactory, RpcControllerFactory, ExecutorService, int) - 类 的构造器org.apache.hadoop.hbase.client.ClientAsyncPrefetchScanner
-
- 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
- ClientCoprocessorRpcController - org.apache.hadoop.hbase.client中的类
-
Client side rpc controller for coprocessor implementation.
- ClientCoprocessorRpcController() - 类 的构造器org.apache.hadoop.hbase.client.ClientCoprocessorRpcController
-
- 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.
- ClientServiceCallable<T> - org.apache.hadoop.hbase.client中的类
-
A RegionServerCallable set to use the Client protocol.
- ClientServiceCallable(Connection, TableName, byte[], RpcController, int) - 类 的构造器org.apache.hadoop.hbase.client.ClientServiceCallable
-
- 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
-
- clone() - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- cloneSnapshot(byte[], 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(String, TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Create a new table by cloning the snapshot content.
- cloneSnapshot(String, TableName) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Create a new table by cloning the snapshot content.
- cloneSnapshot(String, TableName, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Create a new table by cloning the snapshot content.
- cloneSnapshot(byte[], TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- cloneSnapshot(String, TableName, boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- cloneSnapshot(String, TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- cloneSnapshotAsync(String, TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Create a new table by cloning the snapshot content, but does not block
and wait for it to be completely cloned.
- cloneSnapshotAsync(String, TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- cloneTableSchema(TableName, TableName, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Create a new table by cloning the existent table schema.
- cloneTableSchema(TableName, TableName, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Create a new table by cloning the existent table schema.
- cloneTableSchema(TableName, TableName, boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- close() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- close() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncBufferedMutator
-
- close() - 接口 中的方法org.apache.hadoop.hbase.client.BufferedMutator
-
- close() - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- close() - 类 中的方法org.apache.hadoop.hbase.client.ClientAsyncPrefetchScanner
-
- close() - 类 中的方法org.apache.hadoop.hbase.client.ClientScanner
-
- close() - 接口 中的方法org.apache.hadoop.hbase.client.Connection
-
- close() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- close() - 类 中的方法org.apache.hadoop.hbase.client.HBaseHbck
-
- close() - 类 中的方法org.apache.hadoop.hbase.client.HRegionLocator
- close() - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
- close() - 类 中的方法org.apache.hadoop.hbase.client.HTableMultiplexer
-
已过时。
- 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.ShortCircuitMasterConnection
-
- 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(ChannelHandlerContext, ChannelPromise) - 类 中的方法org.apache.hadoop.hbase.security.CryptoAESWrapHandler
-
- close(ChannelHandlerContext, ChannelPromise) - 类 中的方法org.apache.hadoop.hbase.security.SaslWrapHandler
-
- close() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
-
- 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
-
- closeRegion(byte[], String) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- closeRegion(ServerName, HRegionInfo) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- closeRegion(String, String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
已过时。
- closeRegion(byte[], String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
已过时。
- closeRegion(ServerName, HRegionInfo) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
已过时。
- closeRegion(RpcController, AdminProtos.AdminService.BlockingInterface, ServerName, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
A helper to close a region given a region name
using admin protocol.
- closeRegionWithEncodedRegionName(String, String) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- closeRegionWithEncodedRegionName(String, String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
已过时。
- 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.ZNodePaths
-
- ClusterMetrics - org.apache.hadoop.hbase中的接口
-
Metrics information on the HBase cluster.
- ClusterMetrics.Option - org.apache.hadoop.hbase中的枚举
-
Kinds of ClusterMetrics
- ClusterMetricsBuilder - org.apache.hadoop.hbase中的类
-
- clusterStateZNode - 类 中的变量org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
- ClusterStatus - org.apache.hadoop.hbase中的类
-
- ClusterStatus(String, String, Map<ServerName, ServerLoad>, Collection<ServerName>, ServerName, Collection<ServerName>, List<RegionState>, String[], Boolean, int) - 类 的构造器org.apache.hadoop.hbase.ClusterStatus
-
- ClusterStatus(ClusterMetrics) - 类 的构造器org.apache.hadoop.hbase.ClusterStatus
-
已过时。
- code() - 枚举 中的方法org.apache.hadoop.hbase.security.access.Permission.Action
-
- code() - 枚举 中的方法org.apache.hadoop.hbase.security.access.Permission.Scope
-
- 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
-
- ColumnFamilyDescriptor - org.apache.hadoop.hbase.client中的接口
-
An ColumnFamilyDescriptor contains information about a column family such as the
number of versions, compression settings, etc.
- ColumnFamilyDescriptorBuilder - org.apache.hadoop.hbase.client中的类
-
- ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor - org.apache.hadoop.hbase.client中的类
-
An ModifyableFamilyDescriptor contains information about a column family such as the
number of versions, compression settings, etc.
- 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.
- ColumnValueFilter - org.apache.hadoop.hbase.filter中的类
-
- ColumnValueFilter(byte[], byte[], CompareOperator, byte[]) - 类 的构造器org.apache.hadoop.hbase.filter.ColumnValueFilter
-
- ColumnValueFilter(byte[], byte[], CompareOperator, ByteArrayComparable) - 类 的构造器org.apache.hadoop.hbase.filter.ColumnValueFilter
-
- 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, CompactType) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Compact a table.
- compact(TableName, byte[], CompactType) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Compact a column family within a table.
- compact(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Compact a table.
- compact(TableName, byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Compact a column family within a table.
- compact(TableName, CompactType) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Compact a table.
- compact(TableName, byte[], CompactType) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Compact a column family within a table.
- compact(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
Compact a table.
- compact(TableName, byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
Compact a column family within a table.
- compact(TableName, byte[], CompactType) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
Compact a column family within a table.
- compact(TableName, CompactType) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
Compact a table.
- COMPACTION_ENABLED - 类 中的静态变量org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Used by HBase Shell interface to access this metadata
attribute which denotes if the table is compaction enabled.
- COMPACTION_ENABLED - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
- CompactionState - org.apache.hadoop.hbase.client中的枚举
-
POJO representing the compaction state
- compactionSwitch(boolean, List<String>) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Turn the compaction on or off.
- compactionSwitch(boolean, List<String>) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Turn the compaction on or off.
- compactionSwitch(boolean, List<String>) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- 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.AsyncAdmin
-
Compact an individual region.
- compactRegion(byte[], byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Compact a column family within a region.
- compactRegion(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- 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
-
- compactRegionServer(ServerName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Compact all regions on the region server.
- compactRegionServer(ServerName) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Compact all regions on the region server.
- compactRegionServer(ServerName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- CompactType - org.apache.hadoop.hbase.client中的枚举
-
Currently, there are only two compact types:
NORMAL
means do store files compaction;
MOB
means do mob files compaction.
- COMPARATOR - 接口 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- COMPARATOR - 接口 中的静态变量org.apache.hadoop.hbase.client.RegionInfo
-
- COMPARATOR - 接口 中的静态变量org.apache.hadoop.hbase.client.Row
-
- COMPARATOR - 接口 中的静态变量org.apache.hadoop.hbase.client.TableDescriptor
-
- comparator - 类 中的变量org.apache.hadoop.hbase.filter.CompareFilter
-
- comparator - 类 中的变量org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- COMPARATOR_IGNORE_REPLICATION - 接口 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- COMPARATOR_IGNORE_REPLICATION - 接口 中的静态变量org.apache.hadoop.hbase.client.TableDescriptor
-
- 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
-
- compareFamily(CompareFilter.CompareOp, ByteArrayComparable, Cell) - 类 中的方法org.apache.hadoop.hbase.filter.CompareFilter
-
- compareFamily(CompareOperator, ByteArrayComparable, Cell) - 类 中的方法org.apache.hadoop.hbase.filter.CompareFilter
-
- 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
-
- CompareFilter(CompareOperator, ByteArrayComparable) - 类 的构造器org.apache.hadoop.hbase.filter.CompareFilter
-
Constructor.
- CompareFilter.CompareOp - org.apache.hadoop.hbase.filter中的枚举
-
- CompareOperator - org.apache.hadoop.hbase中的枚举
-
Generic set of comparison operators.
- compareQualifier(CompareFilter.CompareOp, ByteArrayComparable, Cell) - 类 中的方法org.apache.hadoop.hbase.filter.CompareFilter
-
- compareQualifier(CompareOperator, ByteArrayComparable, Cell) - 类 中的方法org.apache.hadoop.hbase.filter.CompareFilter
-
- compareResults(Result, Result) - 类 中的静态方法org.apache.hadoop.hbase.client.Result
-
Does a deep comparison of two Results, down to the byte arrays.
- compareRow(CompareFilter.CompareOp, ByteArrayComparable, Cell) - 类 中的方法org.apache.hadoop.hbase.filter.CompareFilter
-
- compareRow(CompareOperator, ByteArrayComparable, Cell) - 类 中的方法org.apache.hadoop.hbase.filter.CompareFilter
-
- compareTo(Action) - 类 中的方法org.apache.hadoop.hbase.client.Action
-
- compareTo(ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- compareTo(Row) - 类 中的方法org.apache.hadoop.hbase.client.Get
-
- compareTo(Row) - 类 中的方法org.apache.hadoop.hbase.client.Mutation
-
- compareTo(Row) - 类 中的方法org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
-
- compareTo(Row) - 接口 中的方法org.apache.hadoop.hbase.client.Row
-
- compareTo(Row) - 类 中的方法org.apache.hadoop.hbase.client.RowMutations
-
- compareTo(TableDescriptorBuilder.ModifyableTableDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Compares the descriptor with another descriptor which is passed as a
parameter.
- compareTo(byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.filter.BigDecimalComparator
-
- compareTo(ByteBuffer, int, int) - 类 中的方法org.apache.hadoop.hbase.filter.BigDecimalComparator
-
- compareTo(byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.filter.BinaryComparator
-
- compareTo(ByteBuffer, int, int) - 类 中的方法org.apache.hadoop.hbase.filter.BinaryComparator
-
- compareTo(byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.filter.BinaryPrefixComparator
-
- compareTo(ByteBuffer, int, int) - 类 中的方法org.apache.hadoop.hbase.filter.BinaryPrefixComparator
-
- compareTo(byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.filter.BitComparator
-
- compareTo(ByteBuffer, int, int) - 类 中的方法org.apache.hadoop.hbase.filter.BitComparator
-
- compareTo(byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.filter.LongComparator
-
- compareTo(ByteBuffer, int, int) - 类 中的方法org.apache.hadoop.hbase.filter.LongComparator
-
- compareTo(byte[]) - 类 中的方法org.apache.hadoop.hbase.filter.NullComparator
-
- compareTo(byte[], int, int) - 类 中的方法org.apache.hadoop.hbase.filter.NullComparator
-
- compareTo(ByteBuffer, 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(Size) - 类 中的方法org.apache.hadoop.hbase.Size
-
- compareValue(CompareFilter.CompareOp, ByteArrayComparable, Cell) - 类 中的方法org.apache.hadoop.hbase.filter.CompareFilter
-
- compareValue(CompareOperator, ByteArrayComparable, Cell) - 类 中的方法org.apache.hadoop.hbase.filter.CompareFilter
-
- completeExceptionally() - 类 中的方法org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
-
- COMPRESS_TAGS - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- COMPRESS_TAGS - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- COMPRESSION - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- COMPRESSION - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- COMPRESSION_COMPACT - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- COMPRESSION_COMPACT - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- compressor - 类 中的变量org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- computeDelta(TableDescriptor, TableDescriptor) - 类 中的静态方法org.apache.hadoop.hbase.client.TableDescriptorUtils
-
Compares two
TableDescriptor
and indicate which columns were added, deleted,
or modified from oldTD to newTD
- concurrentCallsPerServerHist - 类 中的变量org.apache.hadoop.hbase.client.MetricsConnection
-
- ConcurrentTableModificationException - org.apache.hadoop.hbase中的异常错误
-
Thrown when a table has been modified concurrently
- ConcurrentTableModificationException() - 异常错误 的构造器org.apache.hadoop.hbase.ConcurrentTableModificationException
-
default constructor
- ConcurrentTableModificationException(String) - 异常错误 的构造器org.apache.hadoop.hbase.ConcurrentTableModificationException
-
Constructor
- ConcurrentTableModificationException(byte[]) - 异常错误 的构造器org.apache.hadoop.hbase.ConcurrentTableModificationException
-
- ConcurrentTableModificationException(TableName) - 异常错误 的构造器org.apache.hadoop.hbase.ConcurrentTableModificationException
-
- conf - 类 中的变量org.apache.hadoop.hbase.client.ClientScanner
-
- 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
-
- conn - 类 中的变量org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
-
- 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.RegionAdminServiceCallable
-
- ConnectionClosedException - org.apache.hadoop.hbase.exceptions中的异常错误
-
Thrown when the connection is closed
- ConnectionClosedException(String) - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.ConnectionClosedException
-
- 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
Connection
s.
- ConnectionFactory() - 类 的构造器org.apache.hadoop.hbase.client.ConnectionFactory
-
No public c.tors
- connections - 类 中的变量org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- ConnectionUtils - org.apache.hadoop.hbase.client中的类
-
Utility used by client connections.
- ConnectionUtils.ShortCircuitingClusterConnection - org.apache.hadoop.hbase.client中的类
-
A ClusterConnection that will short-circuit RPC making direct invocations against the localhost
if the invocation target is 'this' server; save on network and protobuf invocations.
- 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.client.RegionInfo
-
- 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.client.RegionInfo
-
- containsRow(byte[]) - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
-
已过时。
- containsValue(Object) - 类 中的方法org.apache.hadoop.hbase.util.PoolMap
-
- controller - 类 中的变量org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
-
- convert(Map<TableName, ? extends Collection<String>>) - 类 中的静态方法org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
convert map to TableCFs Object
- convert(String) - 类 中的静态方法org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
Convert string to TableCFs Object.
- convert(ReplicationProtos.TableCF[]) - 类 中的静态方法org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
Convert TableCFs Object to String.
- convert(ReplicationProtos.ReplicationPeer) - 类 中的静态方法org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
- convert(ReplicationPeerConfig) - 类 中的静态方法org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
- convert() - 类 中的方法org.apache.hadoop.hbase.client.TableState
-
Covert to PB version of TableState
- convert(TableName, HBaseProtos.TableState) - 类 中的静态方法org.apache.hadoop.hbase.client.TableState
-
Covert from PB version of TableState
- convert(HBaseProtos.TableState.State) - 枚举 中的静态方法org.apache.hadoop.hbase.client.TableState.State
-
Covert from PB version of State
- convert() - 枚举 中的方法org.apache.hadoop.hbase.client.TableState.State
-
Covert to PB version of State
- convert() - 类 中的方法org.apache.hadoop.hbase.ClusterId
-
- convert(ClusterIdProtos.ClusterId) - 类 中的静态方法org.apache.hadoop.hbase.ClusterId
-
- convert(HRegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
-
- convert(HBaseProtos.RegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
-
- 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
- convert2Map(ReplicationProtos.TableCF[]) - 类 中的静态方法org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
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(Set<String>) - 类 中的静态方法org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
- convertToString(Map<TableName, ? extends Collection<String>>) - 类 中的静态方法org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
- Coprocessor - org.apache.hadoop.hbase中的接口
-
Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor,
RegionServerCoprocessor, and WALCoprocessor.
- Coprocessor.State - org.apache.hadoop.hbase中的枚举
-
Lifecycle state of a given coprocessor instance.
- CoprocessorDescriptor - org.apache.hadoop.hbase.client中的接口
-
CoprocessorDescriptor contains the details about how to build a coprocessor.
- CoprocessorDescriptorBuilder - org.apache.hadoop.hbase.client中的类
-
- CoprocessorEnvironment<C extends Coprocessor> - 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 interface which provides clients with an RPC connection to
call coprocessor endpoint Service
s.
- CoprocessorRpcUtils - org.apache.hadoop.hbase.ipc中的类
-
Utilities for handling coprocessor rpc service calls.
- CoprocessorRpcUtils.BlockingRpcCallback<R> - org.apache.hadoop.hbase.ipc中的类
-
- 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(Function<RpcChannel, S>, ServiceCaller<S, R>) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Execute the given coprocessor call on the master.
- coprocessorService(Function<RpcChannel, S>, ServiceCaller<S, R>, ServerName) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Execute the given coprocessor call on the given region server.
- coprocessorService(Function<RpcChannel, S>, ServiceCaller<S, R>, byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable
-
Execute the given coprocessor call on the region which contains the given row
.
- coprocessorService(Function<RpcChannel, S>, ServiceCaller<S, R>, AsyncTable.CoprocessorCallback<R>) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable
-
Execute a coprocessor call on the regions which are covered by a range.
- coprocessorService() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- coprocessorService(ServerName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- coprocessorService(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
- coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>) - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
- coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>, Batch.Callback<R>) - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
- 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.
- copy(ColumnFamilyDescriptor) - 类 中的静态方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- copy(TableDescriptor) - 类 中的静态方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- copy(TableName, TableDescriptor) - 类 中的静态方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- 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, SnapshotDescription) - 异常错误 的构造器org.apache.hadoop.hbase.snapshot.CorruptedSnapshotException
-
Snapshot was corrupt for some reason.
- 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(Configuration) - 类 中的静态方法org.apache.hadoop.hbase.client.RequestControllerFactory
-
- 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
-
- createAsyncConnection() - 类 中的静态方法org.apache.hadoop.hbase.client.ConnectionFactory
-
- createAsyncConnection(Configuration) - 类 中的静态方法org.apache.hadoop.hbase.client.ConnectionFactory
-
- createAsyncConnection(Configuration, User) - 类 中的静态方法org.apache.hadoop.hbase.client.ConnectionFactory
-
Create a new AsyncConnection instance using the passed conf
and user
.
- 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
- createCompactionState(AdminProtos.GetRegionInfoResponse.CompactionState) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- createCompactionState(CompactionState) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- 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
-
- createCompareOperator(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.filter.ParseFilter
-
Takes a compareOperator symbol as a byte array and returns the corresponding CompareOperator
- 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(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
- createCryptoAES(RPCProtos.CryptoCipherMeta, Configuration) - 类 中的静态方法org.apache.hadoop.hbase.security.EncryptionUtil
-
Helper to create an instance of CryptoAES.
- 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
-
- createEncryptionContext(Configuration, ColumnFamilyDescriptor) - 类 中的静态方法org.apache.hadoop.hbase.security.EncryptionUtil
-
Helper to create an encyption context.
- 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.ColumnValueFilter
-
Creating this filter by reflection, it is used by
ParseFilter
,
- 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
-
- createForTesting(RegionInfo, RegionState.State) - 类 中的静态方法org.apache.hadoop.hbase.master.RegionState
-
- createHBaseProtosSnapshotDesc(SnapshotDescription) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- createKerberosSaslClient(String[], String, String) - 类 中的方法org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
-
- createMobRegionInfo(TableName) - 接口 中的静态方法org.apache.hadoop.hbase.client.RegionInfo
-
Creates a RegionInfo object for MOB data.
- createNamespace(NamespaceDescriptor) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Create a new namespace.
- createNamespace(NamespaceDescriptor) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Create a new namespace.
- createNamespace(NamespaceDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- createNamespace(RpcController, MasterProtos.CreateNamespaceRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- createNamespaceAsync(NamespaceDescriptor) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Create a new namespace.
- createNamespaceAsync(NamespaceDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- createPool() - 类 中的方法org.apache.hadoop.hbase.util.PoolMap
-
- createProtosSnapShotDescType(SnapshotType) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- createProtosSnapShotDescType(SnapshotType) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- createProtosSnapShotDescType(String) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- createRegionLoadStats(ClientProtos.RegionLoadStats) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- createRegionName(TableName, byte[], long, boolean) - 接口 中的静态方法org.apache.hadoop.hbase.client.RegionInfo
-
Make a region name of passed parameters.
- createRegionName(TableName, byte[], String, boolean) - 接口 中的静态方法org.apache.hadoop.hbase.client.RegionInfo
-
Make a region name of passed parameters.
- createRegionName(TableName, byte[], long, int, boolean) - 接口 中的静态方法org.apache.hadoop.hbase.client.RegionInfo
-
Make a region name of passed parameters.
- createRegionName(TableName, byte[], byte[], boolean) - 接口 中的静态方法org.apache.hadoop.hbase.client.RegionInfo
-
Make a region name of passed parameters.
- createRegionName(TableName, byte[], byte[], int, boolean) - 接口 中的静态方法org.apache.hadoop.hbase.client.RegionInfo
-
Make a region name of passed parameters.
- createRegionName(TableName, byte[], long, boolean) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
-
- createRegionName(TableName, byte[], String, boolean) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
-
- createRegionName(TableName, byte[], long, int, boolean) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
-
- createRegionName(TableName, byte[], byte[], boolean) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
-
- createRegionName(TableName, byte[], byte[], int, boolean) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
-
- 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) - 类 中的静态方法org.apache.hadoop.hbase.client.ConnectionUtils
-
- 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.
- createSnapshotDesc(SnapshotProtos.SnapshotDescription) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- createSnapshotType(SnapshotProtos.SnapshotDescription.Type) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- createTable(TableDescriptor) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Creates a new table.
- createTable(TableDescriptor, byte[], byte[], int) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Creates a new table with the specified number of regions.
- createTable(TableDescriptor, 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(TableDescriptor) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Creates a new table.
- createTable(TableDescriptor, byte[], byte[], int) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Creates a new table with the specified number of regions.
- createTable(TableDescriptor, byte[][]) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Creates a new table with an initial set of empty regions defined by the specified split keys.
- createTable(TableDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- createTable(TableDescriptor, byte[], byte[], int) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- createTable(TableDescriptor, byte[][]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- createTable(RpcController, MasterProtos.CreateTableRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- createTableAsync(TableDescriptor) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Creates a new table but does not block and wait for it to come online.
- createTableAsync(TableDescriptor, byte[][]) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Creates a new table but does not block and wait for it to come online.
- createTableAsync(TableDescriptor, byte[][]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- createTableAsync(TableDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- 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
- CryptoAESUnwrapHandler - org.apache.hadoop.hbase.security中的类
-
Unwrap messages with Crypto AES.
- CryptoAESUnwrapHandler(CryptoAES) - 类 的构造器org.apache.hadoop.hbase.security.CryptoAESUnwrapHandler
-
- CryptoAESWrapHandler - org.apache.hadoop.hbase.security中的类
-
wrap messages with Crypto AES.
- CryptoAESWrapHandler(CryptoAES) - 类 的构造器org.apache.hadoop.hbase.security.CryptoAESWrapHandler
-
- current() - 类 中的方法org.apache.hadoop.hbase.client.Result
-
- currentRegion - 类 中的变量org.apache.hadoop.hbase.client.ClientScanner
-
- cursor() - 接口 中的方法org.apache.hadoop.hbase.client.AdvancedScanResultConsumer.ScanController
-
Get the scan cursor if available.
- Cursor - org.apache.hadoop.hbase.client中的类
-
- cursor - 类 中的变量org.apache.hadoop.hbase.client.ScannerCallable
-
- CUSTOM_CALLER_CONF_KEY - 类 中的静态变量org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
-
- 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 - 类 中的静态变量org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'D'
- DATA_BLOCK_ENCODING - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- DATA_BLOCK_ENCODING - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- decode(ChannelHandlerContext, ByteBuf, List<Object>) - 类 中的方法org.apache.hadoop.hbase.security.SaslChallengeDecoder
-
- decommissionRegionServers(List<ServerName>, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Mark region server(s) as decommissioned to prevent additional regions from getting
assigned to them.
- decommissionRegionServers(List<ServerName>, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Mark region server(s) as decommissioned to prevent additional regions from getting
assigned to them.
- decommissionRegionServers(List<ServerName>, boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- decommissionRegionServers(RpcController, MasterProtos.DecommissionRegionServersRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- decTaskCounters(Collection<byte[]>, ServerName) - 接口 中的方法org.apache.hadoop.hbase.client.RequestController
-
Decrement the counter if a task is accomplished.
- 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.client.ColumnFamilyDescriptorBuilder
-
Default setting for whether to use a block cache or not.
- DEFAULT_BLOCKCACHE - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- DEFAULT_BLOCKSIZE - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default size of blocks in files stored to the filesytem (hfiles).
- DEFAULT_BLOCKSIZE - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- DEFAULT_BLOOMFILTER - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default setting for whether or not to use bloomfilters.
- DEFAULT_BLOOMFILTER - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- DEFAULT_CACHE_BLOOMS_ON_WRITE - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default setting for whether to cache bloom filter blocks on write if block
caching is enabled.
- DEFAULT_CACHE_BLOOMS_ON_WRITE - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- DEFAULT_CACHE_DATA_IN_L1 - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- DEFAULT_CACHE_DATA_ON_WRITE - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default setting for whether to cache data blocks on write if block caching
is enabled.
- DEFAULT_CACHE_DATA_ON_WRITE - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- DEFAULT_CACHE_INDEX_ON_WRITE - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default setting for whether to cache index blocks on write if block caching
is enabled.
- DEFAULT_CACHE_INDEX_ON_WRITE - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- DEFAULT_CODEC_CLASS - 接口 中的静态变量org.apache.hadoop.hbase.ipc.RpcClient
-
- DEFAULT_COMPACTION_ENABLED - 类 中的静态变量org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Constant that denotes whether the table is compaction enabled by default
- DEFAULT_COMPACTION_ENABLED - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
- DEFAULT_COMPRESS_TAGS - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default compress tags along with any type of DataBlockEncoding.
- DEFAULT_COMPRESS_TAGS - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- DEFAULT_COMPRESSION - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default compression type.
- DEFAULT_COMPRESSION - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- DEFAULT_DATA_BLOCK_ENCODING - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default data block encoding algorithm.
- DEFAULT_DATA_BLOCK_ENCODING - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- DEFAULT_DFS_REPLICATION - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- DEFAULT_DFS_REPLICATION - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- DEFAULT_ENCODE_ON_DISK - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- DEFAULT_EVICT_BLOCKS_ON_CLOSE - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default setting for whether to evict cached blocks from the blockcache on
close.
- DEFAULT_EVICT_BLOCKS_ON_CLOSE - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- DEFAULT_EXEC_PERMISSION_CHECKS - 接口 中的静态变量org.apache.hadoop.hbase.security.access.AccessControlConstants
-
Default setting for hbase.security.exec.permission.checks; false
- DEFAULT_HBASE_CLIENT_SCANNER_ASYNC_PREFETCH - 类 中的静态变量org.apache.hadoop.hbase.client.Scan
-
- DEFAULT_IN_MEMORY - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default setting for whether to try and serve this column family from memory
or not.
- DEFAULT_IN_MEMORY - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- DEFAULT_KEEP_DELETED - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default setting for preventing deleted from being collected immediately.
- DEFAULT_KEEP_DELETED - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- DEFAULT_MAX_BACKOFF - 类 中的静态变量org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
-
- DEFAULT_MAX_VERSIONS - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default number of versions of a record to keep.
- DEFAULT_MEMSTORE_FLUSH_SIZE - 类 中的静态变量org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Constant that denotes the maximum default size of the memstore in bytes after which
the contents are flushed to the store files.
- DEFAULT_MEMSTORE_FLUSH_SIZE - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
- DEFAULT_MERGE_ENABLED - 类 中的静态变量org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Constant that denotes whether the table is merge enabled by default
- DEFAULT_MIN_VERSIONS - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default is not to keep a minimum of versions.
- DEFAULT_MIN_VERSIONS - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- DEFAULT_MOB_COMPACT_PARTITION_POLICY - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- DEFAULT_MOB_COMPACT_PARTITION_POLICY - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- DEFAULT_MOB_THRESHOLD - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- DEFAULT_MOB_THRESHOLD - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- DEFAULT_NEW_VERSION_BEHAVIOR - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- DEFAULT_NEW_VERSION_BEHAVIOR - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- DEFAULT_NORMALIZATION_ENABLED - 类 中的静态变量org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Constant that denotes whether the table is normalized by default.
- DEFAULT_NORMALIZATION_ENABLED - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
- DEFAULT_PREFETCH_BLOCKS_ON_OPEN - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- DEFAULT_PREFETCH_BLOCKS_ON_OPEN - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- DEFAULT_READONLY - 类 中的静态变量org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Constant that denotes whether the table is READONLY by default and is false
- DEFAULT_READONLY - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
- DEFAULT_REGION_MEMSTORE_REPLICATION - 类 中的静态变量org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- 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.client.TableDescriptorBuilder
-
- DEFAULT_REGION_REPLICATION - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
- DEFAULT_REPLICA_ID - 接口 中的静态变量org.apache.hadoop.hbase.client.RegionInfo
-
- DEFAULT_REPLICATION_SCOPE - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default scope.
- DEFAULT_REPLICATION_SCOPE - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- 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_SPLIT_ENABLED - 类 中的静态变量org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Constant that denotes whether the table is split enabled by default
- DEFAULT_TTL - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default time to live of cell contents.
- DEFAULT_TTL - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- DEFAULT_VERSIONS - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- DelayingRunner - 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>>) - 类 的构造器org.apache.hadoop.hbase.client.DelayingRunner
-
- delegatee - 类 中的变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- delegatee - 类 中的变量org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
- DelegatingHBaseRpcController - org.apache.hadoop.hbase.ipc中的类
-
- DelegatingHBaseRpcController(HBaseRpcController) - 类 的构造器org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
-
- delete(Delete) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable
-
Deletes the specified cells/row.
- delete(List<Delete>) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable
-
Deletes the specified cells/rows in bulk.
- 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(byte[], long, NavigableMap<byte[], List<Cell>>) - 类 的构造器org.apache.hadoop.hbase.client.Delete
-
Construct the Delete with user defined data.
- delete(Delete) - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
- delete(List<Delete>) - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
- delete(Delete) - 接口 中的方法org.apache.hadoop.hbase.client.Table
-
Deletes the specified cells/row.
- delete(List<Delete>) - 接口 中的方法org.apache.hadoop.hbase.client.Table
-
Batch Deletes the specified cells/rows from the table.
- deleteAll(List<Delete>) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable
-
A simple version of batch delete.
- deleteCachedRegionLocation(HRegionLocation) - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
-
Deletes cached locations for the specific region.
- deleteColumn(TableName, byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- deleteColumn(TableName, byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- deleteColumn(RpcController, MasterProtos.DeleteColumnRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- deleteColumnFamily(TableName, byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Delete a column family from a table.
- deleteColumnFamily(TableName, byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Delete a column family from a table.
- deleteColumnFamily(TableName, byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- deleteColumnFamilyAsync(TableName, byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Delete a column family from a table.
- deleteColumnFamilyAsync(TableName, byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- deleteMergeQualifiers(Connection, RegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
Deletes merge qualifiers for the specified merge region.
- deleteNamespace(String) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Delete an existing namespace.
- deleteNamespace(String) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Delete an existing namespace.
- deleteNamespace(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- deleteNamespace(RpcController, MasterProtos.DeleteNamespaceRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- deleteNamespaceAsync(String) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Delete an existing namespace.
- deleteNamespaceAsync(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- deleteRegionInfo(Connection, RegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
Deletes the specified region from META.
- deleteRegionInfos(Connection, List<RegionInfo>) - 类 中的静态方法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(String) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Delete an existing snapshot.
- deleteSnapshot(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- deleteSnapshot(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- deleteSnapshot(RpcController, MasterProtos.DeleteSnapshotRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- deleteSnapshots(String) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- deleteSnapshots(Pattern) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Delete existing snapshots whose names match the pattern passed.
- deleteSnapshots() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Delete all existing snapshots.
- deleteSnapshots(Pattern) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Delete existing snapshots whose names match the pattern passed.
- deleteSnapshots(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- deleteSnapshots(Pattern) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- deleteTable(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Deletes a table.
- deleteTable(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Deletes a table.
- deleteTable(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- deleteTable(RpcController, MasterProtos.DeleteTableRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- deleteTableAsync(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Deletes the table but does not block and wait for it to be completely removed.
- deleteTableAsync(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- deleteTables(String) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- deleteTables(Pattern) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- deleteTables(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- 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
-
- 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(Pattern) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Delete all existing snapshots matching the given table name pattern.
- deleteTableSnapshots(Pattern, Pattern) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
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
-
- deleteTableSnapshots(Pattern, Pattern) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- deleteTableState(Connection, TableName) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
Remove state for table from meta
- 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
-
- DependentColumnFilter(byte[], byte[], boolean, CompareOperator, 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.
- DFS_REPLICATION - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- DFS_REPLICATION - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- disablePeer(String) - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- disableReplicationPeer(String) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Stop the replication stream to the specified peer.
- disableReplicationPeer(String) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Stop the replication stream to the specified peer
- disableReplicationPeer(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- disableReplicationPeer(RpcController, ReplicationProtos.DisableReplicationPeerRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- disableReplicationPeerAsync(String) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Disable a replication peer but does not block and wait for it.
- disableReplicationPeerAsync(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- disableTable(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Disable table and wait on completion.
- disableTable(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Disable a table.
- disableTable(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- disableTable(RpcController, MasterProtos.DisableTableRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- disableTableAsync(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Disable the table but does not block and wait for it to be completely disabled.
- disableTableAsync(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- disableTableRep(TableName) - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- disableTableReplication(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Disable a table's replication switch.
- disableTableReplication(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Disable a table's replication switch.
- disableTableReplication(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- disableTables(String) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- disableTables(Pattern) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- disableTables(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- disableTables(Pattern) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- disableWriteBufferPeriodicFlush() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
-
Disable the periodical flush, i.e, set the timeout to 0.
- disableWriteBufferPeriodicFlush() - 接口 中的方法org.apache.hadoop.hbase.client.BufferedMutator
-
Disable periodic flushing of the write buffer.
- DISPLAY_KEYS_KEY - 类 中的静态变量org.apache.hadoop.hbase.client.RegionInfoDisplay
-
- 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.
- doBatchWithCallback(List<? extends Row>, Object[], Batch.Callback<R>, ClusterConnection, ExecutorService, TableName) - 类 中的静态方法org.apache.hadoop.hbase.client.HTable
-
- doCall() - 类 中的方法org.apache.hadoop.hbase.client.AsyncAdminRequestRetryingCaller
-
- doCall() - 类 中的方法org.apache.hadoop.hbase.client.AsyncMasterRequestRpcRetryingCaller
-
- doCall() - 类 中的方法org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
-
- doCall() - 类 中的方法org.apache.hadoop.hbase.client.AsyncServerRequestRpcRetryingCaller
-
- doGet(ClientProtos.GetRequest) - 类 中的方法org.apache.hadoop.hbase.client.ClientServiceCallable
-
- 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.
- doMutate(ClientProtos.MutateRequest) - 类 中的方法org.apache.hadoop.hbase.client.ClientServiceCallable
-
- 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
-
- DoNotRetryRegionException(Throwable) - 异常错误 的构造器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.ZNodePaths
-
- 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
-
- Durability - org.apache.hadoop.hbase.client中的枚举
-
Enum describing the durability guarantees for tables and
Mutation
s
Note that the items must be sorted in order of increasing durability
- durability - 类 中的变量org.apache.hadoop.hbase.client.Mutation
-
- DURABILITY - 类 中的静态变量org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- DURABILITY - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
- get(Get) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable
-
Extracts certain cells from a given row.
- get(List<Get>) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable
-
Extracts certain cells from the given rows, in batch.
- 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(byte[], int, int) - 类 的构造器org.apache.hadoop.hbase.client.Get
-
Create a Get operation for the specified row.
- Get(ByteBuffer) - 类 的构造器org.apache.hadoop.hbase.client.Get
-
Create a Get operation for the specified row.
- 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
-
- get(List<Get>) - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
- get(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Mutation
-
Returns a list of all KeyValue objects with matching column family and qualifier.
- get() - 类 中的静态方法org.apache.hadoop.hbase.client.PerClientRandomNonceGenerator
-
Get the singleton nonce generator.
- 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 specified cells from the given rows, as a batch.
- get() - 类 中的方法org.apache.hadoop.hbase.ipc.BlockingRpcCallback
-
- get() - 类 中的方法org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils.BlockingRpcCallback
-
- get() - 类 中的方法org.apache.hadoop.hbase.Size
-
get the value
- get(Size.Unit) - 类 中的方法org.apache.hadoop.hbase.Size
-
get the value which is converted to specified unit.
- get(Object) - 类 中的方法org.apache.hadoop.hbase.util.PoolMap
-
- get() - 接口 中的方法org.apache.hadoop.hbase.util.PoolMap.Pool
-
- get() - 类 中的方法org.apache.hadoop.hbase.util.PoolMap.ReusablePool
-
- get(String) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
-
- getAccessScope() - 类 中的方法org.apache.hadoop.hbase.security.access.Permission
-
- getAccessScope() - 类 中的方法org.apache.hadoop.hbase.security.access.UserPermission
-
Get this permission access scope.
- getACL() - 类 中的方法org.apache.hadoop.hbase.client.Mutation
-
- getACL() - 类 中的方法org.apache.hadoop.hbase.client.Query
-
- getAction() - 类 中的方法org.apache.hadoop.hbase.client.Action
-
- getActions() - 类 中的方法org.apache.hadoop.hbase.client.DelayingRunner
-
- getActions() - 类 中的方法org.apache.hadoop.hbase.security.access.Permission
-
- getAdmin() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncConnection
-
Retrieve an
AsyncAdmin
implementation to administer an HBase cluster.
- getAdmin(ExecutorService) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncConnection
-
Retrieve an
AsyncAdmin
implementation to administer an HBase cluster.
- 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(ServerName) - 类 中的方法org.apache.hadoop.hbase.client.ConnectionUtils.ShortCircuitingClusterConnection
-
- getAdmin() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
-
- getAdminBuilder() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncConnection
-
- getAdminBuilder(ExecutorService) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncConnection
-
- getAdminForMaster() - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
-
Get the admin service for master.
- getAgeOfLastAppliedOp() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationLoadSink
-
- getAgeOfLastShippedOp() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- getAll(List<Get>) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable
-
A simple version for batch get.
- getAllFilters() - 类 中的静态方法org.apache.hadoop.hbase.filter.ParseFilter
-
Returns all known filters
- getAllowPartialResults() - 类 中的方法org.apache.hadoop.hbase.client.Scan
-
- getAllRegionLocations() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Retrieves all of the regions associated with this table.
- getAllRegionLocations() - 类 中的方法org.apache.hadoop.hbase.client.HRegionLocator
-
- getAllRegionLocations() - 接口 中的方法org.apache.hadoop.hbase.client.RegionLocator
-
Retrieves all of the regions associated with this table.
- getAllRegions(Connection, boolean) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
Lists all of the regions currently in META.
- getAllRSGroupInfo(Connection) - 类 中的静态方法org.apache.hadoop.hbase.RSGroupTableAccessor
-
- getAlterStatus(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- getAlterStatus(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- getAlterStatus(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- getAlterStatus(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- 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.ClusterMetrics
-
- 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
-
- getBackupMasterNames() - 接口 中的方法org.apache.hadoop.hbase.ClusterMetrics
-
- getBackupMasterNames() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
-
已过时。
- getBackupMasters() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- getBackupMasters() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
- getBackupMasters() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
-
- getBackupMastersSize() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
-
- getBalancerOn() - 接口 中的方法org.apache.hadoop.hbase.ClusterMetrics
-
- getBalancerOn() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
-
已过时。
- getBandwidth() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getBarriers() - 类 中的方法org.apache.hadoop.hbase.MetaTableAccessor.ReplicationBarrierResult
-
- getBatch() - 类 中的方法org.apache.hadoop.hbase.client.Scan
-
- getBlocksize() - 接口 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- getBlocksize() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getBlocksize() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- getBloomFilterSize() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
-
已过时。
- getBloomFilterSize() - 接口 中的方法org.apache.hadoop.hbase.RegionMetrics
-
- getBloomFilterType() - 接口 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- getBloomFilterType() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getBloomFilterType() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- getBufferedCounterForEachRegionServer() - 类 中的方法org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
已过时。
- getBufferedMutator(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncConnection
-
- getBufferedMutator(TableName, ExecutorService) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncConnection
-
- getBufferedMutator(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Connection
-
- getBufferedMutator(BufferedMutatorParams) - 接口 中的方法org.apache.hadoop.hbase.client.Connection
-
- getBufferedMutatorBuilder(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncConnection
-
- getBufferedMutatorBuilder(TableName, ExecutorService) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncConnection
-
- 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.
- getCacheCount() - 类 中的方法org.apache.hadoop.hbase.client.ClientScanner
-
- 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
- getCallback() - 类 中的方法org.apache.hadoop.hbase.client.AsyncProcessTask
-
- 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
-
- getCatalogFamily() - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
Returns the column family used for meta columns.
- 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
-
- getClassLoader() - 接口 中的方法org.apache.hadoop.hbase.CoprocessorEnvironment
-
- getClassName() - 接口 中的方法org.apache.hadoop.hbase.client.CoprocessorDescriptor
-
- 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.ConnectionUtils.ShortCircuitingClusterConnection
-
- getClusterId() - 接口 中的方法org.apache.hadoop.hbase.ClusterMetrics
-
- getClusterId() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
-
已过时。
- getClusterIds() - 类 中的方法org.apache.hadoop.hbase.client.Mutation
-
- getClusterKey() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getClusterMetrics() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Get whole cluster metrics, containing status about:
hbase version
cluster id
primary/backup master(s)
master's coprocessors
live/dead regionservers
balancer
regions in transition
- getClusterMetrics(EnumSet<ClusterMetrics.Option>) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- getClusterMetrics() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
- getClusterMetrics(EnumSet<ClusterMetrics.Option>) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
- getClusterMetrics(EnumSet<ClusterMetrics.Option>) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- getClusterStatus() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- getClusterStatus(RpcController, MasterProtos.GetClusterStatusRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- getColumnCells(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Result
-
Return the Cells for the specific column.
- getColumnFamilies() - 接口 中的方法org.apache.hadoop.hbase.client.TableDescriptor
-
- getColumnFamilies() - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- getColumnFamilies() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
- getColumnFamily(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.TableDescriptor
-
Returns the ColumnDescriptor for a specific column family with name as
specified by the parameter column.
- getColumnFamily(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Returns the ColumnFamilyDescriptor for a specific column family with name as
specified by the parameter column.
- getColumnFamily(byte[]) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
- getColumnFamilyCount() - 接口 中的方法org.apache.hadoop.hbase.client.TableDescriptor
-
Returns the count of the column families of the table.
- getColumnFamilyCount() - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- getColumnFamilyCount() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
Returns the count of the column families of the table.
- getColumnFamilyMap() - 类 中的方法org.apache.hadoop.hbase.client.replication.TableCFs
-
- getColumnFamilyNames() - 接口 中的方法org.apache.hadoop.hbase.client.TableDescriptor
-
Returns all the column family names of the current table.
- getColumnFamilyNames() - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Returns all the column family names of the current table.
- getColumnFamilyNames() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
- getColumnFamilyTimeRange() - 类 中的方法org.apache.hadoop.hbase.client.Query
-
- 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
-
- getColumnsAdded() - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorUtils.TableDescriptorDelta
-
- getColumnsDeleted() - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorUtils.TableDescriptorDelta
-
- getColumnsModified() - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorUtils.TableDescriptorDelta
-
- getCompactedCellCount() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
-
已过时。
- getCompactedCellCount() - 接口 中的方法org.apache.hadoop.hbase.RegionMetrics
-
- getCompactingCellCount() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
-
已过时。
- getCompactingCellCount() - 接口 中的方法org.apache.hadoop.hbase.RegionMetrics
-
- getCompactionCompression() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
- getCompactionCompressionType() - 接口 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- getCompactionCompressionType() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getCompactionCompressionType() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- getCompactionPressure() - 类 中的方法org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
-
- getCompactionPressure() - 类 中的方法org.apache.hadoop.hbase.client.RegionLoadStats
-
- getCompactionState(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Get the current compaction state of a table.
- getCompactionState(TableName, CompactType) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Get the current compaction state of a table.
- getCompactionState(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the current compaction state of a table.
- getCompactionState(TableName, CompactType) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the current compaction state of a table.
- getCompactionState(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- getCompactionState(TableName, CompactType) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
Get the current compaction state of a table.
- getCompactionStateForRegion(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Get the current compaction state of region.
- getCompactionStateForRegion(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the current compaction state of region.
- getCompactionStateForRegion(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- getComparator(Comparator<ColumnFamilyDescriptor>) - 接口 中的静态方法org.apache.hadoop.hbase.client.TableDescriptor
-
- getComparator() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnValueFilter
-
- getComparator() - 类 中的方法org.apache.hadoop.hbase.filter.CompareFilter
-
- getComparator() - 类 中的方法org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- getComparator() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
-
- getCompareOperator() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnValueFilter
-
- getCompareOperator() - 类 中的方法org.apache.hadoop.hbase.filter.CompareFilter
-
- getCompareOperator() - 类 中的方法org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- getComparisonData() - 类 中的方法org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
-
- getCompletedSequenceId() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
-
已过时。
- getCompletedSequenceId() - 接口 中的方法org.apache.hadoop.hbase.RegionMetrics
-
This does not really belong inside RegionLoad but its being done in the name of expediency.
- getCompletedSnapshots(RpcController, MasterProtos.GetCompletedSnapshotsRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- getCompleteSequenceId() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
-
- getCompression() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
- getCompressionType() - 接口 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- getCompressionType() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- getCompressionType() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- 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.AsyncBufferedMutator
-
Returns the Configuration
object used by this instance.
- getConfiguration() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncConnection
-
Returns the Configuration
object used by this instance.
- getConfiguration() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable
-
Returns the Configuration
object used by this instance.
- 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.ColumnFamilyDescriptor
-
- getConfiguration() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getConfiguration() - 接口 中的方法org.apache.hadoop.hbase.client.Connection
-
- getConfiguration() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- getConfiguration() - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
- 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
-
已过时。
- getConfiguration() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
Getter for fetching an unmodifiable map.
- getConfiguration() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getConfigurationValue(String) - 接口 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- getConfigurationValue(String) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getConfigurationValue(String) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- getConfigurationValue(String) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
Getter for accessing the configuration value by key
- getConnectedZooKeeper(String, int) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZooKeeperHelper
-
Get a ZooKeeper instance and wait until it connected before returning.
- getConnection() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- getConnection() - 类 中的方法org.apache.hadoop.hbase.client.ClientScanner
-
- getConnection() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- getConnection() - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
INTERNAL Used by unit tests and tools to do low-level
manipulations.
- getConnection() - 类 中的方法org.apache.hadoop.hbase.client.RegionServerCallable
-
- getConnectionConfiguration() - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
-
- getConnectionExceptionTypes() - 类 中的静态方法org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
-
For test only.
- getConnectionMetrics() - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
-
- getConnectString() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
-
- getConsistency() - 类 中的方法org.apache.hadoop.hbase.client.Query
-
Returns the consistency level for this operation
- getControllerException(RpcController) - 类 中的静态方法org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
-
Retreivies exception stored during RPC invocation.
- getControllerException(RpcController) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
-
Retreivies exception stored during RPC invocation.
- getCoprocessorDescriptors() - 接口 中的方法org.apache.hadoop.hbase.client.TableDescriptor
-
Return the list of attached co-processor represented
- getCoprocessorDescriptors() - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Return the list of attached co-processor represented by their name
className
- getCoprocessorDescriptors() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
- getCoprocessorNames() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
-
已过时。
- getCoprocessorNames() - 接口 中的方法org.apache.hadoop.hbase.ServerMetrics
-
Return the RegionServer-level and Region-level coprocessors
- getCoprocessors() - 接口 中的方法org.apache.hadoop.hbase.client.TableDescriptor
-
- getCoprocessorServiceRequest(Descriptors.MethodDescriptor, Message) - 类 中的静态方法org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
-
- getCoprocessorServiceRequest(Descriptors.MethodDescriptor, Message, byte[], byte[]) - 类 中的静态方法org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
-
- getCounter(String) - 类 中的方法org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
-
- getCreationTime() - 类 中的方法org.apache.hadoop.hbase.client.SnapshotDescription
-
- getCurrentCompactedKVs() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
-
- getCurrentCompactedKVs() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
-
- getCurrentNrHRS() - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
-
- getCurrentSnapshotFromQuotaTable(Connection, TableName) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getCurrentSpaceQuotaSnapshot(String) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Returns the Master's view of a quota on the given namespace
or null if the Master has
no quota information on that namespace.
- getCurrentSpaceQuotaSnapshot(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Returns the Master's view of a quota on the given tableName
or null if the Master has
no quota information on that table.
- getCurrentSpaceQuotaSnapshot(String) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Returns the Master's view of a quota on the given namespace
or null if the Master has
no quota information on that namespace.
- getCurrentSpaceQuotaSnapshot(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Returns the Master's view of a quota on the given tableName
or null if the Master has
no quota information on that table.
- getCurrentSpaceQuotaSnapshot(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- getCurrentSpaceQuotaSnapshot(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- getCursor() - 类 中的方法org.apache.hadoop.hbase.client.Result
-
Return the cursor if this Result is a cursor result.
- getCursor() - 类 中的方法org.apache.hadoop.hbase.client.ScannerCallable
-
- getDataBlockEncoding() - 接口 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- getDataBlockEncoding() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getDataBlockEncoding() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- getDataLocality() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
-
已过时。
- getDataLocality() - 接口 中的方法org.apache.hadoop.hbase.RegionMetrics
-
- getDaughterRegions(Result) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
Returns the daughter regions by reading the corresponding columns of the catalog table
Result.
- getDeadServerNames() - 接口 中的方法org.apache.hadoop.hbase.ClusterMetrics
-
- getDeadServerNames() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
-
已过时。
- getDeadServers() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
-
- getDeadServersSize() - 类 中的方法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.client.ColumnFamilyDescriptorBuilder
-
- getDefaultValues() - 类 中的静态方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- getDelegateeForModification() - 类 中的方法org.apache.hadoop.hbase.client.ImmutableHColumnDescriptor
-
已过时。
- getDelegateeForModification() - 类 中的方法org.apache.hadoop.hbase.client.ImmutableHTableDescriptor
-
已过时。
- getDelegateeForModification() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- getDelegateeForModification() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
- getDesc(List<Throwable>, List<? extends Row>, List<String>) - 异常错误 中的静态方法org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getDesc(Map<String, Integer>) - 异常错误 中的静态方法org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getDescription() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin.TableFuture
-
- getDescriptiveNameFromRegionStateForDisplay(RegionState, Configuration) - 类 中的静态方法org.apache.hadoop.hbase.client.RegionInfoDisplay
-
Get the descriptive name as
RegionState
does it but with hidden
startkey optionally
- getDescriptiveNameFromRegionStateForDisplay(RegionState, Configuration) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
-
- getDescriptor(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Get a table descriptor.
- getDescriptor(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Method for getting the tableDescriptor
- getDescriptor(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- getDescriptor() - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
- getDescriptor() - 接口 中的方法org.apache.hadoop.hbase.client.Table
-
- getDFSReplication() - 接口 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- getDFSReplication() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getDFSReplication() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- getDropDependentColumn() - 类 中的方法org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- getDurability() - 类 中的方法org.apache.hadoop.hbase.client.Mutation
-
Get the current durability
- getDurability() - 接口 中的方法org.apache.hadoop.hbase.client.TableDescriptor
-
Returns the durability setting for the table.
- getDurability() - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Returns the durability setting for the table.
- getDurability() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
Returns the durability setting for the table.
- getEncodedName() - 接口 中的方法org.apache.hadoop.hbase.client.RegionInfo
-
- getEncodedName() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
-
已过时。
- getEncodedNameAsBytes() - 接口 中的方法org.apache.hadoop.hbase.client.RegionInfo
-
- getEncodedNameAsBytes() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
-
已过时。
- getEncryptionKey() - 接口 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- getEncryptionKey() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getEncryptionKey() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- getEncryptionType() - 接口 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- getEncryptionType() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getEncryptionType() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- getEndKey() - 接口 中的方法org.apache.hadoop.hbase.client.RegionInfo
-
- getEndKey() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
-
已过时。
- getEndKeyForDisplay(RegionInfo, Configuration) - 类 中的静态方法org.apache.hadoop.hbase.client.RegionInfoDisplay
-
Get the end key for display.
- getEndKeyForDisplay(HRegionInfo, Configuration) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
-
- getEndKeys() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Gets the ending row key for every region in the currently open table.
- getEndKeys() - 接口 中的方法org.apache.hadoop.hbase.client.RegionLocator
-
Gets the ending row key for every region in the currently open table.
- getEntry() - 类 中的方法org.apache.hadoop.hbase.client.SingleResponse
-
- getErrors() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncRequestFuture
-
- getEvictedBlocks() - 类 中的方法org.apache.hadoop.hbase.CacheEvictionStats
-
- getExceedThrottleQuotaRowKey() - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getException(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.MultiResponse
-
- getExceptionCount() - 类 中的方法org.apache.hadoop.hbase.CacheEvictionStats
-
- getExceptionMessage() - 类 中的方法org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
- 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.CacheEvictionStats
-
- getExceptions() - 类 中的方法org.apache.hadoop.hbase.client.MultiResponse
-
- getExcludeNamespaces() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getExcludeTableCFsMap() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getExecutedWriteBufferPeriodicFlushes() - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- 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.client.ClientCoprocessorRpcController
-
- 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.
- getFailedOperations() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncRequestFuture
-
- getFailureCount() - 异常错误 中的方法org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
-
- getFamilies() - 类 中的方法org.apache.hadoop.hbase.client.Scan
-
- getFamilies() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
- getFamiliesKeys() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
- getFamily() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnValueFilter
-
- getFamily() - 类 中的方法org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- getFamily() - 类 中的方法org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- getFamily(byte[]) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
- getFamily() - 类 中的方法org.apache.hadoop.hbase.security.access.GetUserPermissionsRequest
-
- 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(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
- getFilteredReadRequestCount() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
-
已过时。
- getFilteredReadRequestCount() - 接口 中的方法org.apache.hadoop.hbase.RegionMetrics
-
- getFilteredReadRequestsCount() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
-
- getFilteredReadRequestsCount() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
-
- 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.client.TableDescriptor
-
This gets the class associated with the flush policy which determines the
stores need to be flushed when flushing a region.
- getFlushPolicyClassName() - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
This gets the class associated with the flush policy which determines the
stores need to be flushed when flushing a region.
- 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.ClusterMetrics
-
- getHBaseVersion() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
-
已过时。
- getHBaseVersion() - 接口 中的方法org.apache.hadoop.hbase.CoprocessorEnvironment
-
- getHbck() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncConnection
-
Retrieve an Hbck implementation to fix an HBase cluster.
- getHbck(ServerName) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncConnection
-
Retrieve an Hbck implementation to fix an HBase cluster.
- getHbck() - 接口 中的方法org.apache.hadoop.hbase.client.Connection
-
Retrieve an Hbck implementation to fix an HBase cluster.
- getHbck(ServerName) - 接口 中的方法org.apache.hadoop.hbase.client.Connection
-
Retrieve an Hbck implementation to fix an HBase cluster.
- getHeapOccupancy() - 类 中的方法org.apache.hadoop.hbase.client.RegionLoadStats
-
- getHeapOccupancyPercent() - 类 中的方法org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
-
- getHostname() - 异常错误 中的方法org.apache.hadoop.hbase.exceptions.RegionMovedException
-
- getHostname() - 类 中的方法org.apache.hadoop.hbase.HRegionLocation
-
- getHostname() - 异常错误 中的方法org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
-
- getHostnamePort(int) - 异常错误 中的方法org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getHostnamePort() - 类 中的方法org.apache.hadoop.hbase.HRegionLocation
-
- getHRegionInfo() - 类 中的方法org.apache.hadoop.hbase.client.RegionServerCallable
-
- getHRegionInfo() - 类 中的方法org.apache.hadoop.hbase.client.ScannerCallable
-
- 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.
- getImplementationClassName() - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- getInfo(String) - 类 中的静态方法org.apache.hadoop.hbase.security.SecurityInfo
-
Returns the security configuration associated with the given service name.
- getInfoServerPort() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
-
已过时。
- getInfoServerPort() - 接口 中的方法org.apache.hadoop.hbase.ServerMetrics
-
- getInitialResponse() - 类 中的方法org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
-
- getInMemoryCompaction() - 接口 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- getInMemoryCompaction() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getInMemoryCompaction() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- getInputStream() - 类 中的方法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
-
- getJarPath() - 接口 中的方法org.apache.hadoop.hbase.client.CoprocessorDescriptor
-
- getKeepDeletedCells() - 接口 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- getKeepDeletedCells() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- 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.AsyncAdmin
-
Get the timestamp of the last major compaction for the passed table.
- getLastMajorCompactionTimestamp(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- getLastMajorCompactionTimestamp(RpcController, MasterProtos.MajorCompactionTimestampRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- getLastMajorCompactionTimestamp(TableName) - 接口 中的方法org.apache.hadoop.hbase.ClusterMetrics
-
- getLastMajorCompactionTimestamp(byte[]) - 接口 中的方法org.apache.hadoop.hbase.ClusterMetrics
-
- getLastMajorCompactionTimestamp() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
-
已过时。
- getLastMajorCompactionTimestamp() - 接口 中的方法org.apache.hadoop.hbase.RegionMetrics
-
- 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.AsyncAdmin
-
Get the timestamp of the last major compaction for the passed region.
- getLastMajorCompactionTimestampForRegion(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- getLastMajorCompactionTimestampForRegion(RpcController, MasterProtos.MajorCompactionTimestampForRegionRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- getLastMajorCompactionTs() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
-
- getLastMajorCompactionTsForRegion(byte[]) - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
-
- getLastMajorCompactionTsForTable(TableName) - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
-
- getLastReportTimestamp() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
-
已过时。
- getLastReportTimestamp() - 接口 中的方法org.apache.hadoop.hbase.ServerMetrics
-
- 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
-
- getLimit() - 类 中的方法org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
-
Returns the limit, in bytes, of the target (e.g. table, namespace).
- getLimit() - 接口 中的方法org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView
-
Returns the limit, in bytes, of the target (e.g. table, namespace).
- getListener() - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- getLiveServerMetrics() - 接口 中的方法org.apache.hadoop.hbase.ClusterMetrics
-
- getLiveServerMetrics() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
-
已过时。
- getLoad(ServerName) - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
-
- getLoad() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
-
- 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
-
- getLocks() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Get locks.
- getLocks() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
List locks.
- getLocks() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- getLocks(RpcController, MasterProtos.GetLocksRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- getLongValue() - 类 中的方法org.apache.hadoop.hbase.Size
-
get the value
- getMap() - 类 中的方法org.apache.hadoop.hbase.client.Result
-
Map of families to all versions of its qualifiers and values.
- getMaster() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- getMaster() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
- getMaster() - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
-
- getMaster() - 类 中的方法org.apache.hadoop.hbase.client.ConnectionUtils.ShortCircuitingClusterConnection
-
- getMaster() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
-
- getMasterCoprocessorNames() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Helper that delegates to getClusterMetrics().getMasterCoprocessorNames().
- getMasterCoprocessorNames() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
- getMasterCoprocessorNames() - 接口 中的方法org.apache.hadoop.hbase.ClusterMetrics
-
- getMasterCoprocessorNames() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
-
已过时。
- getMasterCoprocessors() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- 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.AsyncAdmin
-
Get the info port of the current master if one is available.
- getMasterInfoPort() - 接口 中的方法org.apache.hadoop.hbase.ClusterMetrics
-
- getMasterInfoPort() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
-
已过时。
- getMasterName() - 接口 中的方法org.apache.hadoop.hbase.ClusterMetrics
-
Returns detailed information about the current master
ServerName
.
- getMasterName() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
-
已过时。
- getMaxCacheSize() - 类 中的方法org.apache.hadoop.hbase.CacheEvictionStats
-
- getMaxColumn() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- getMaxColumnInclusive() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- getMaxFileSize() - 接口 中的方法org.apache.hadoop.hbase.client.TableDescriptor
-
Returns the maximum size upto which a region can grow to after which a
region split is triggered.
- getMaxFileSize() - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Returns the maximum size upto which a region can grow to after which a
region split is triggered.
- 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
-
- getMaxHeapSize() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
-
已过时。
- getMaxHeapSize() - 接口 中的方法org.apache.hadoop.hbase.ServerMetrics
-
- 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.ColumnFamilyDescriptor
-
- getMaxVersions() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- 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.client.TableDescriptor
-
Returns the size of the memstore after which a flush to filesystem is
triggered.
- getMemStoreFlushSize() - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Returns the size of the memstore after which a flush to filesystem is
triggered.
- getMemStoreFlushSize() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
Returns the size of the memstore after which a flush to filesystem is triggered.
- getMemstoreLoad() - 类 中的方法org.apache.hadoop.hbase.client.RegionLoadStats
-
- getMemStoreLoad() - 类 中的方法org.apache.hadoop.hbase.client.RegionLoadStats
-
- getMemStoreLoadPercent() - 类 中的方法org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
-
- getMemStoreSize() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
-
已过时。
- getMemStoreSize() - 接口 中的方法org.apache.hadoop.hbase.RegionMetrics
-
- getMemstoreSizeInMB() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
-
- getMemStoreSizeMB() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
-
- getMemStoreSizeMB() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
-
- getMergeRegions(Connection, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
- getMergeRegions(Cell[]) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
- getMessage() - 异常错误 中的方法org.apache.hadoop.hbase.exceptions.RegionMovedException
-
- getMetaHTable(Connection) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
Callers should call close on the returned
Table
instance.
- getMetaKeyForRegion(RegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
Returns the row key to use for this regionInfo
- getMetaOperationTimeout() - 类 中的方法org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getMetaReplicaCallTimeoutMicroSecondScan() - 类 中的方法org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getMetaReplicaIdFromZnode(String) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
Parse the meta replicaId from the passed znode
- getMethod() - 类 中的方法org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
-
- getMethodDescriptor(String, Descriptors.ServiceDescriptor) - 类 中的静态方法org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
-
- 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.client.ColumnFamilyDescriptor
-
- getMinVersions() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getMinVersions() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- getMobCompactPartitionPolicy() - 接口 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Get the mob compact partition policy for this family
- getMobCompactPartitionPolicy() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getMobCompactPartitionPolicy() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- getMobThreshold() - 接口 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Gets the mob threshold of the family.
- getMobThreshold() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getMobThreshold() - 类 中的方法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.AsyncBufferedMutator
-
Gets the fully qualified table name instance of the table that this
AsyncBufferedMutator
writes to.
- getName() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable
-
Gets the fully qualified table name instance of this table.
- getName() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Gets the fully qualified table name instance of the table whose region we want to locate.
- 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.ColumnFamilyDescriptor
-
- getName() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- 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.SnapshotDescription
-
- 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.RegionLoad
-
- getNameAsString() - 接口 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- getNameAsString() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- getNameAsString() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- 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.RegionMetrics
-
- getNamespace() - 类 中的方法org.apache.hadoop.hbase.quotas.QuotaSettings
-
- getNamespace() - 类 中的方法org.apache.hadoop.hbase.security.access.GetUserPermissionsRequest
-
- getNamespace() - 类 中的方法org.apache.hadoop.hbase.security.access.NamespacePermission
-
- 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.AsyncAdmin
-
Get a namespace descriptor by name
- getNamespaceDescriptor(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- getNamespaceDescriptor(RpcController, MasterProtos.GetNamespaceDescriptorRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- getNamespaceFilter() - 类 中的方法org.apache.hadoop.hbase.quotas.QuotaFilter
-
- getNamespaceFromRowKey(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getNamespaceName() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin.NamespaceFuture
-
- 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
-
- getNamespaces() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getNamespaceSnapshots(Connection) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
Returns a set of the names of all namespaces containing snapshot entries.
- getNeedResults() - 类 中的方法org.apache.hadoop.hbase.client.AsyncProcessTask
-
- 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.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.
- getNonce() - 类 中的方法org.apache.hadoop.hbase.client.Action
-
- getNonceGenerator() - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
-
- getNonceGroup() - 类 中的方法org.apache.hadoop.hbase.client.MultiAction
-
- getNonceGroup() - 接口 中的方法org.apache.hadoop.hbase.client.NonceGenerator
-
- getNonceGroup() - 类 中的方法org.apache.hadoop.hbase.client.PerClientRandomNonceGenerator
-
- getNormalizerTargetRegionCount() - 接口 中的方法org.apache.hadoop.hbase.client.TableDescriptor
-
Check if there is the target region count.
- getNormalizerTargetRegionCount() - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Check if there is the target region count.
- getNormalizerTargetRegionCount() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
- getNormalizerTargetRegionSize() - 接口 中的方法org.apache.hadoop.hbase.client.TableDescriptor
-
Check if there is the target region size.
- getNormalizerTargetRegionSize() - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Check if there is the target region size.
- getNormalizerTargetRegionSize() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
- getNoSuchSnapshot() - 类 中的静态方法org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
-
Returns a singleton that corresponds to no snapshot information.
- getNoVersionMap() - 类 中的方法org.apache.hadoop.hbase.client.Result
-
Map of families to their most recent qualifiers and values.
- getNumActionsPerServer() - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection.CallStats
-
- getNumberOfCachedRegionLocations(TableName) - 类 中的方法org.apache.hadoop.hbase.client.MetaCache
-
Return the number of cached region for a table.
- getNumberOfRegions() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
-
- getNumberOfRequests() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
-
- getNumberOfTasksInProgress() - 接口 中的方法org.apache.hadoop.hbase.client.RequestController
-
- getNumExceptions() - 异常错误 中的方法org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getObservedSnapshotSizes(Connection) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
Fetches any persisted HBase snapshot sizes stored in the quota table.
- getOffset() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- getOnlineRegions(ServerName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- getOnlineRegions(ServerName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- getOnlineRegions(AdminProtos.AdminService.BlockingInterface) - 类 中的静态方法org.apache.hadoop.hbase.shaded.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.shaded.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.AsyncProcessTask
-
- getOperationTimeout(TimeUnit) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable
-
Get timeout of each operation in Table instance.
- getOperationTimeout() - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- getOperationTimeout() - 类 中的方法org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getOperationTimeout() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- getOperationTimeout(TimeUnit) - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
- getOperationTimeout() - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
已过时。
- getOperationTimeout(TimeUnit) - 接口 中的方法org.apache.hadoop.hbase.client.Table
-
Get timeout of each operation in Table instance.
- getOperationTimeout() - 接口 中的方法org.apache.hadoop.hbase.client.Table
-
- getOperationType() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin.NamespaceFuture
-
- getOperationType() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin.TableFuture
-
- 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
-
- getOrderOfSize() - 枚举 中的方法org.apache.hadoop.hbase.Size.Unit
-
- getOriginalIndex() - 类 中的方法org.apache.hadoop.hbase.client.Action
-
- getOutputStream() - 类 中的方法org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
Get a SASL wrapped OutputStream.
- getOverallAverageLatency() - 类 中的方法org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
已过时。
- getOwner() - 类 中的方法org.apache.hadoop.hbase.client.SnapshotDescription
-
- getOwnerString() - 接口 中的方法org.apache.hadoop.hbase.client.TableDescriptor
-
- getOwnerString() - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- getOwnerString() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
- getPageSize() - 类 中的方法org.apache.hadoop.hbase.filter.PageFilter
-
- getParentRegionNames() - 类 中的方法org.apache.hadoop.hbase.MetaTableAccessor.ReplicationBarrierResult
-
- getParentsBytes(List<RegionInfo>) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
- getPauseTime(long, int) - 类 中的静态方法org.apache.hadoop.hbase.client.ConnectionUtils
-
Calculate pause time.
- getPeerClusterConfiguration(Configuration, ReplicationPeerDescription) - 类 中的静态方法org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
Returns the configuration needed to talk to the remote slave cluster.
- getPeerConfig(String) - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- getPeerConfig() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerDescription
-
- getPeerData() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getPeerID() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- getPeerId() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerDescription
-
- getPeersCount() - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
已过时。
- getPeerState(String) - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
已过时。
- getPeerTableCFs(String) - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- getPeriodicalFlushTimeout(TimeUnit) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncBufferedMutator
-
Returns the periodical flush interval, 0 means disabled.
- getPermission() - 类 中的方法org.apache.hadoop.hbase.security.access.UserPermission
-
- getPolicy() - 类 中的方法org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot.SpaceQuotaStatus
-
Returns the violation policy, which may be null.
- getPolicy() - 接口 中的方法org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView.SpaceQuotaStatusView
-
Returns the violation policy, which may not be presented.
- getPool() - 类 中的方法org.apache.hadoop.hbase.client.AsyncProcessTask
-
- 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
-
- 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.CoprocessorDescriptor
-
- 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.client.TableDescriptor
-
- getPriority() - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- 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
-
- getProcedureResult(RpcController, MasterProtos.GetProcedureResultRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- getProcedures() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Get procedures.
- getProcedures() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
List procedures
- getProcedures() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- getProcedures(RpcController, MasterProtos.GetProceduresRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- 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
- getProperties() - 接口 中的方法org.apache.hadoop.hbase.client.CoprocessorDescriptor
-
- 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
- getProtoViolationPolicy(SpaceViolationPolicy) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getQop(String) - 类 中的静态方法org.apache.hadoop.hbase.security.SaslUtil
-
- getQualifier() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnValueFilter
-
- getQualifier() - 类 中的方法org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- getQualifier() - 类 中的方法org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- getQualifier() - 类 中的方法org.apache.hadoop.hbase.security.access.GetUserPermissionsRequest
-
- getQualifier() - 类 中的方法org.apache.hadoop.hbase.security.access.TablePermission
-
- getQuota(QuotaFilter) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
List the quotas based on the filter.
- getQuota(QuotaFilter) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
List the quotas based on the filter.
- getQuota(QuotaFilter) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- getQuotaRetriever(QuotaFilter) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- getQuotaRetriever(QuotaFilter) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- getQuotaScope() - 类 中的方法org.apache.hadoop.hbase.quotas.ThrottleSettings
-
- getQuotaStates(RpcController, QuotaProtos.GetQuotaStatesRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- getQuotaStatus() - 类 中的方法org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
-
Returns the status of the quota.
- getQuotaStatus() - 接口 中的方法org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView
-
Returns the status of the quota.
- getQuotaType() - 类 中的方法org.apache.hadoop.hbase.quotas.QuotaSettings
-
- getQuotaType() - 类 中的方法org.apache.hadoop.hbase.quotas.ThrottleSettings
-
- getReadRequestCount() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
-
已过时。
- getReadRequestCount() - 接口 中的方法org.apache.hadoop.hbase.RegionMetrics
-
- getReadRequestsCount() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
-
- getReadRequestsCount() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
-
- getReadRpcTimeout(TimeUnit) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable
-
Get timeout of each rpc read request in this Table instance.
- getReadRpcTimeout() - 类 中的方法org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getReadRpcTimeout(TimeUnit) - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
- getReadRpcTimeout() - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
已过时。
- getReadRpcTimeout(TimeUnit) - 接口 中的方法org.apache.hadoop.hbase.client.Table
-
Get timeout of each rpc read request in this Table instance.
- getReadRpcTimeout() - 接口 中的方法org.apache.hadoop.hbase.client.Table
-
- getReadType() - 类 中的方法org.apache.hadoop.hbase.client.Scan
-
- getRegion() - 类 中的方法org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
-
- getRegion() - 类 中的方法org.apache.hadoop.hbase.HRegionLocation
-
- getRegion() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
-
- getRegion(Connection, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
- getRegionActionBuilderWithRegion(ClientProtos.RegionAction.Builder, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
- getRegionCount() - 接口 中的方法org.apache.hadoop.hbase.ClusterMetrics
-
- 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.shaded.protobuf.ProtobufUtil
-
Find the HRegion encoded name based on a region specifier
- getRegionId() - 接口 中的方法org.apache.hadoop.hbase.client.RegionInfo
-
- getRegionId() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
-
已过时。
- getRegionInfo() - 类 中的方法org.apache.hadoop.hbase.HRegionLocation
-
- getRegionInfo(Result) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
Returns RegionInfo object from the column
HConstants.CATALOG_FAMILY:HConstants.REGIONINFO_QUALIFIER of the catalog
table Result.
- getRegionInfo(Result, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
- getRegionInfo(RpcController, AdminProtos.AdminService.BlockingInterface, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.shaded.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(RegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.client.RegionReplicaUtil
-
Returns the RegionInfo for the default replicaId (0).
- getRegionInfoForReplica(RegionInfo, int) - 类 中的静态方法org.apache.hadoop.hbase.client.RegionReplicaUtil
-
Returns the RegionInfo for the given replicaId.
- getRegionInfos(AdminProtos.GetOnlineRegionResponse) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Get the list of region info from a GetOnlineRegionResponse
- getRegionInfos(AdminProtos.GetOnlineRegionResponse) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
-
Get the list of region info from a GetOnlineRegionResponse
- getRegionLoadInfo(AdminProtos.GetRegionLoadResponse) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- getRegionLocation(AsyncTable<?>, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.AsyncMetaTableAccessor
-
Returns the HRegionLocation from meta for the given region
- getRegionLocation(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Finds the region on which the given row is being served.
- getRegionLocation(byte[], boolean) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Finds the region on which the given row is being served.
- getRegionLocation(byte[], int) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Finds the region with the given replicaId
on which the given row is being served.
- getRegionLocation(byte[], int, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Finds the region with the given replicaId
on which the given row is being served.
- getRegionLocation(TableName, byte[], boolean) - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
-
Find region location hosting passed row
- getRegionLocation(byte[], int, boolean) - 类 中的方法org.apache.hadoop.hbase.client.HRegionLocator
-
- 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(byte[], int) - 接口 中的方法org.apache.hadoop.hbase.client.RegionLocator
-
Finds the region with the given replica id on which the given row is being served.
- getRegionLocation(byte[], int, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.RegionLocator
-
Finds the region with the given replica id 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, RegionInfo) - 类 中的静态方法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(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Find all the replicas for the region on which the given row is being served.
- getRegionLocations(byte[], boolean) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Find all the replicas for the region on which the given row is being served.
- getRegionLocations(byte[], boolean) - 类 中的方法org.apache.hadoop.hbase.client.HRegionLocator
-
- getRegionLocations(ClusterConnection, TableName, byte[], boolean, int) - 类 中的静态方法org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
- getRegionLocations(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.RegionLocator
-
Find all the replicas for the region on which the given row is being served.
- getRegionLocations(byte[], boolean) - 接口 中的方法org.apache.hadoop.hbase.client.RegionLocator
-
Find all the replicas for the region on which the given row is being served.
- getRegionLocations(Result) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
Returns an HRegionLocationList extracted from the result.
- getRegionLocations() - 类 中的方法org.apache.hadoop.hbase.RegionLocations
-
- getRegionLocationWithEncodedName(AsyncTable<?>, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.AsyncMetaTableAccessor
-
Returns the HRegionLocation from meta for the given encoded region name
- getRegionLocator(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncConnection
-
Retrieve a AsyncRegionLocator implementation to inspect region information on a table.
- getRegionLocator(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Connection
-
Retrieve a RegionLocator implementation to inspect region information on a table.
- getRegionLocator() - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
- getRegionMetrics(ServerName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- getRegionMetrics(ServerName, TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Get
RegionMetrics
of all regions hosted on a regionserver for a table.
- getRegionMetrics(ServerName) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Get a list of
RegionMetrics
of all regions hosted on a region seerver.
- getRegionMetrics(ServerName, TableName) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Get a list of
RegionMetrics
of all regions hosted on a region seerver for a table.
- getRegionMetrics(ServerName, TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- getRegionMetrics() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
-
已过时。
- getRegionMetrics() - 接口 中的方法org.apache.hadoop.hbase.ServerMetrics
-
- getRegionName() - 接口 中的方法org.apache.hadoop.hbase.client.RegionInfo
-
- getRegionName() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
-
已过时。
- getRegionName() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
-
已过时。
- getRegionName() - 接口 中的方法org.apache.hadoop.hbase.RegionMetrics
-
- getRegionNameAsString() - 接口 中的方法org.apache.hadoop.hbase.client.RegionInfo
-
- getRegionNameAsString(byte[]) - 接口 中的静态方法org.apache.hadoop.hbase.client.RegionInfo
-
- getRegionNameAsString(RegionInfo, byte[]) - 接口 中的静态方法org.apache.hadoop.hbase.client.RegionInfo
-
- getRegionNameAsString() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
-
已过时。
- getRegionNameAsStringForDisplay(RegionInfo, Configuration) - 类 中的静态方法org.apache.hadoop.hbase.client.RegionInfoDisplay
-
Get the region name for display.
- getRegionNameAsStringForDisplay(HRegionInfo, Configuration) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
-
- getRegionNameForDisplay(RegionInfo, Configuration) - 类 中的静态方法org.apache.hadoop.hbase.client.RegionInfoDisplay
-
Get the region name for display.
- getRegionNameForDisplay(HRegionInfo, Configuration) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
-
- getRegionReplication() - 接口 中的方法org.apache.hadoop.hbase.client.TableDescriptor
-
- getRegionReplication() - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Returns the configured replicas per region
- 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(ServerName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Get all the online regions on a region server.
- getRegions(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Get the regions of a given table.
- getRegions(ServerName) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Get all the online regions on a region server.
- getRegions(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the regions of a given table.
- getRegions(ServerName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- getRegions(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- getRegions() - 类 中的方法org.apache.hadoop.hbase.client.MultiAction
-
- getRegionsCount() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
-
- getRegionServer() - 类 中的方法org.apache.hadoop.hbase.quotas.QuotaSettings
-
- getRegionServerCoprocessors() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
-
- getRegionServerFilter() - 类 中的方法org.apache.hadoop.hbase.quotas.QuotaFilter
-
- getRegionServerFromRowKey(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getRegionServerQuota(Connection, String) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getRegionServerRowKey(String) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getRegionServers() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- getRegionServers() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
- getRegionServerSpaceQuotaSnapshots(ServerName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- getRegionServerSpaceQuotaSnapshots(ServerName) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
- getRegionServerSpaceQuotaSnapshots(ServerName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- getRegionsLoad() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
-
- getRegionSplitPolicyClassName() - 接口 中的方法org.apache.hadoop.hbase.client.TableDescriptor
-
This gets the class associated with the region split policy which
determines when a region split should occur.
- getRegionSplitPolicyClassName() - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
This gets the class associated with the region split policy which
determines when a region split should occur.
- getRegionSplitPolicyClassName() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
This gets the class associated with the region split policy which
determines when a region split should occur.
- getRegionStatesInTransition() - 接口 中的方法org.apache.hadoop.hbase.ClusterMetrics
-
- getRegionStatesInTransition() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
-
已过时。
- getRemoteException(ServiceException) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Return the IOException thrown by the remote server wrapped in
ServiceException as cause.
- getRemoteException(ServiceException) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Return the IOException thrown by the remote server wrapped in
ServiceException as cause.
- 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.client.RegionInfo
-
- getReplicaId() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
-
已过时。
Returns the region replica id
- getReplicationBarrier(Connection, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
- getReplicationBarrierResult(Connection, TableName, byte[], byte[]) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
- getReplicationBarriers(Result) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
- 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
- getReplicationLoadSink() - 接口 中的方法org.apache.hadoop.hbase.ServerMetrics
-
Call directly from client such as hbase shell
- getReplicationLoadSourceList() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
-
已过时。
Call directly from client such as hbase shell
- getReplicationLoadSourceList() - 接口 中的方法org.apache.hadoop.hbase.ServerMetrics
-
Call directly from client such as hbase shell
- getReplicationPeerConfig(String) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Returns the configured ReplicationPeerConfig for the specified peer.
- getReplicationPeerConfig(String) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Returns the configured ReplicationPeerConfig for the specified peer
- getReplicationPeerConfig(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- getReplicationPeerConfig(RpcController, ReplicationProtos.GetReplicationPeerConfigRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- getReportTime() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
-
- getReportTimestamp() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
-
已过时。
- getReportTimestamp() - 接口 中的方法org.apache.hadoop.hbase.ServerMetrics
-
- getRequest() - 类 中的方法org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
-
- getRequest(Service, Descriptors.MethodDescriptor, ByteString) - 类 中的静态方法org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
-
- getRequestCount() - 接口 中的方法org.apache.hadoop.hbase.ClusterMetrics
-
- getRequestCount() - 接口 中的方法org.apache.hadoop.hbase.RegionMetrics
-
- getRequestCount() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
-
已过时。
- getRequestCount() - 接口 中的方法org.apache.hadoop.hbase.ServerMetrics
-
- getRequestCountPerSecond() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
-
已过时。
- getRequestCountPerSecond() - 接口 中的方法org.apache.hadoop.hbase.ServerMetrics
-
- 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
-
- getResponse(ClientProtos.CoprocessorServiceResponse, Message) - 类 中的静态方法org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
-
- getResponse(Message, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
-
- getResponseSizeBytes() - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection.CallStats
-
- getResult() - 类 中的方法org.apache.hadoop.hbase.client.SingleResponse.Entry
-
- getResult(ClientProtos.MutateRequest, ClientProtos.MutateResponse, CellScanner) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
-
- getResults() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncRequestFuture
-
- getResults() - 类 中的方法org.apache.hadoop.hbase.client.MultiResponse
-
- getResults(ClientProtos.MultiRequest, ClientProtos.MultiResponse, CellScanner) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
-
Get the results from a protocol buffer MultiResponse
- getResults(ClientProtos.MultiRequest, Map<Integer, Integer>, ClientProtos.MultiResponse, CellScanner) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
-
Get the results from a protocol buffer MultiResponse
- getResults(CellScanner, ClientProtos.ScanResponse) - 类 中的静态方法org.apache.hadoop.hbase.shaded.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
-
- getRowAccess() - 类 中的方法org.apache.hadoop.hbase.client.AsyncProcessTask
-
- 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)
- getRowRanges() - 类 中的方法org.apache.hadoop.hbase.filter.MultiRowRangeFilter
-
- getRpcController() - 类 中的方法org.apache.hadoop.hbase.client.RegionServerCallable
-
- getRpcControllerCellScanner() - 类 中的方法org.apache.hadoop.hbase.client.RegionServerCallable
-
Get the RpcController CellScanner.
- getRpcControllerFactory() - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
-
- getRpcRetryingCallerFactory() - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
-
- getRpcTimeout() - 类 中的方法org.apache.hadoop.hbase.client.AsyncProcessTask
-
- getRpcTimeout(TimeUnit) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable
-
Get timeout of each rpc request in this Table instance.
- getRpcTimeout() - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- getRpcTimeout() - 类 中的方法org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getRpcTimeout(TimeUnit) - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
- getRpcTimeout() - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
已过时。
- getRpcTimeout(TimeUnit) - 接口 中的方法org.apache.hadoop.hbase.client.Table
-
Get timeout of each rpc request in this Table instance.
- getRpcTimeout() - 接口 中的方法org.apache.hadoop.hbase.client.Table
-
- getRsCoprocessors() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
-
- getRSGroupInfo(Connection, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.RSGroupTableAccessor
-
- getSaslQOP() - 类 中的方法org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
- getSaslQOP() - 类 中的方法org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClient
-
- getSaslQop() - 枚举 中的方法org.apache.hadoop.hbase.security.SaslUtil.QualityOfProtection
-
- getScan() - 类 中的方法org.apache.hadoop.hbase.client.ClientScanner
-
- getScan() - 类 中的方法org.apache.hadoop.hbase.client.ScannerCallable
-
- getScanForTableName(Connection, TableName) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
已过时。
- 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
-
- getScanMetrics(ClientProtos.ScanResponse) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
-
- getScanner(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable
-
Gets a scanner on the current table for the given family.
- getScanner(byte[], byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable
-
Gets a scanner on the current table for the given family and qualifier.
- getScanner(Scan) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable
-
Returns a scanner on the current table as specified by the
Scan
object.
- 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
-
- 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
-
- getScanTimeout(TimeUnit) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable
-
Get the timeout of a single operation in a scan.
- getSchemaAlterStatus(RpcController, MasterProtos.GetSchemaAlterStatusRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- getScope() - 接口 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- getScope() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- 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.AsyncAdmin
-
- getSecurityCapabilities() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- getSecurityCapabilities(RpcController, MasterProtos.SecurityCapabilitiesRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- getSeqNum() - 类 中的方法org.apache.hadoop.hbase.HRegionLocation
-
- getSeqNumColumn(int) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
Returns the column qualifier for seqNum column for replicaId
- 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(RpcController, AdminProtos.AdminService.BlockingInterface) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A helper to get the info of a region server using admin protocol.
- getServerInfo(RpcController, AdminProtos.AdminService.BlockingInterface) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
A helper to get the info of a region server using admin protocol.
- getServerName() - 异常错误 中的方法org.apache.hadoop.hbase.exceptions.RegionMovedException
-
- getServerName() - 类 中的方法org.apache.hadoop.hbase.HRegionLocation
-
- getServerName() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
-
- getServerName(Result, int) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
- getServerName() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
-
已过时。
- getServerName() - 接口 中的方法org.apache.hadoop.hbase.ServerMetrics
-
- getServerPrincipal() - 类 中的方法org.apache.hadoop.hbase.security.SecurityInfo
-
- getServers() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
-
- getServersName() - 接口 中的方法org.apache.hadoop.hbase.ClusterMetrics
-
- getServersName() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
-
已过时。
- getServersSize() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
-
- 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(Descriptors.ServiceDescriptor) - 类 中的静态方法org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
-
Returns the name to use for coprocessor service calls.
- getServices() - 接口 中的方法org.apache.hadoop.hbase.Coprocessor
-
Coprocessor endpoints providing protobuf services should override this method.
- 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.client.RegionInfo
-
- getShortNameToLog(RegionInfo...) - 接口 中的静态方法org.apache.hadoop.hbase.client.RegionInfo
-
- getShortNameToLog(List<RegionInfo>) - 接口 中的静态方法org.apache.hadoop.hbase.client.RegionInfo
-
- getShortNameToLog() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
-
已过时。
- getShortNameToLog(HRegionInfo...) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
-
- getShortNameToLog(List<HRegionInfo>) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
-
- getShortTextFormat(Message) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Return short version of Message toString'd, shorter than TextFormat#shortDebugString.
- getSimpleName() - 枚举 中的方法org.apache.hadoop.hbase.Size.Unit
-
- getSizeOfLogQueue() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- getSleepTime() - 类 中的方法org.apache.hadoop.hbase.client.DelayingRunner
-
- getSnapshotDescription() - 异常错误 中的方法org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
-
- getSnapshots(Connection) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getSnapshotSizeQualifier(String) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getSoftLimit() - 类 中的方法org.apache.hadoop.hbase.quotas.ThrottleSettings
-
- getSpaceQuotaRegionSizes(RpcController, QuotaProtos.GetSpaceQuotaRegionSizesRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- getSpaceQuotaTableSizes() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Fetches the table sizes on the filesystem as tracked by the HBase Master.
- getSpaceQuotaTableSizes() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Fetches the table sizes on the filesystem as tracked by the HBase Master.
- getSpaceQuotaTableSizes() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- getSplitKeysArray(MasterProtos.CreateTableRequest) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
get the split keys in form "byte [][]" from a CreateTableRequest proto
- getStamp() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
-
- getStartCodeColumn(int) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
Returns the column qualifier for server start code column for replicaId
- getStartEndKeys() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Gets the starting and ending row keys for every region in the currently open table.
- getStartEndKeys() - 接口 中的方法org.apache.hadoop.hbase.client.RegionLocator
-
Gets the starting and ending row keys for every region in the currently open table.
- getStartKey() - 接口 中的方法org.apache.hadoop.hbase.client.RegionInfo
-
- getStartKey(byte[]) - 接口 中的静态方法org.apache.hadoop.hbase.client.RegionInfo
-
Gets the start key from the specified region name.
- getStartKey(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
-
- getStartKey() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
-
已过时。
- getStartKeyForDisplay(RegionInfo, Configuration) - 类 中的静态方法org.apache.hadoop.hbase.client.RegionInfoDisplay
-
Get the start key for display.
- getStartKeyForDisplay(HRegionInfo, Configuration) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
-
- getStartKeys() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Gets the starting row key for every region in the currently open table.
- 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.client.TableState
-
- getState() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
-
- getState() - 类 中的方法org.apache.hadoop.hbase.MetaTableAccessor.ReplicationBarrierResult
-
- 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
-
- getStopRow() - 类 中的方法org.apache.hadoop.hbase.client.Scan
-
- getStopRowKey() - 类 中的方法org.apache.hadoop.hbase.filter.InclusiveStopFilter
-
- getStoragePolicy() - 接口 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Not using enum
here because HDFS is not using enum
for storage policy, see
org.apache.hadoop.hdfs.server.blockmanagement.BlockStoragePolicySuite for more details.
- getStoragePolicy() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getStoragePolicy() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- getStoreCompleteSequenceId() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
-
- getStoreCount() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
-
已过时。
- getStoreCount() - 接口 中的方法org.apache.hadoop.hbase.RegionMetrics
-
- getStoreFileCount() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
-
已过时。
- getStoreFileCount() - 接口 中的方法org.apache.hadoop.hbase.RegionMetrics
-
- getStoreFileIndexSize() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
-
已过时。
- getStoreFileIndexSize() - 接口 中的方法org.apache.hadoop.hbase.RegionMetrics
-
TODO: why we pass the same value to different counters?
- getStorefileIndexSizeInMB() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
-
- getStorefileIndexSizeKB() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
-
- getStorefileIndexSizeKB() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
-
- getStorefileIndexSizeMB() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
-
- getStoreFileRootLevelIndexSize() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
-
已过时。
- getStoreFileRootLevelIndexSize() - 接口 中的方法org.apache.hadoop.hbase.RegionMetrics
-
- getStorefiles() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
-
- getStorefiles() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
-
- getStoreFiles(AdminProtos.AdminService.BlockingInterface, byte[], byte[]) - 类 中的静态方法org.apache.hadoop.hbase.shaded.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.shaded.protobuf.ProtobufUtil
-
A helper to get the list of files of a column family
on a given region using admin protocol.
- getStoreFileSize() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
-
已过时。
- getStoreFileSize() - 接口 中的方法org.apache.hadoop.hbase.RegionMetrics
-
- getStorefileSizeInMB() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
-
- getStorefileSizeMB() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
-
- getStorefileSizeMB() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
-
- getStoreFileUncompressedDataIndexSize() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
-
已过时。
- getStoreFileUncompressedDataIndexSize() - 接口 中的方法org.apache.hadoop.hbase.RegionMetrics
-
- getStores() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
-
- getStores() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
-
- getStoreSequenceId() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
-
已过时。
- getStoreSequenceId() - 接口 中的方法org.apache.hadoop.hbase.RegionMetrics
-
- getStoreUncompressedSizeMB() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
-
- getStoreUncompressedSizeMB() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
-
- getStub() - 类 中的方法org.apache.hadoop.hbase.client.RegionServerCallable
-
- getSubmittedRows() - 类 中的方法org.apache.hadoop.hbase.client.AsyncProcessTask
-
- getSupportedFilters() - 类 中的方法org.apache.hadoop.hbase.filter.ParseFilter
-
Return a Set of filters supported by the Filter Language
- getTable(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncConnection
-
Retrieve an
AsyncTable
implementation for accessing a table.
- getTable(TableName, ExecutorService) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncConnection
-
Retrieve an
AsyncTable
implementation for accessing a table.
- 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() - 接口 中的方法org.apache.hadoop.hbase.client.RegionInfo
-
- getTable(byte[]) - 接口 中的静态方法org.apache.hadoop.hbase.client.RegionInfo
-
Gets the table name from the specified region name.
- getTable() - 类 中的方法org.apache.hadoop.hbase.client.replication.TableCFs
-
- getTable() - 类 中的方法org.apache.hadoop.hbase.client.SnapshotDescription
-
- getTable(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
-
- getTable() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
-
已过时。
Get current table name of the region
- getTableBuilder(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncConnection
-
- getTableBuilder(TableName, ExecutorService) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncConnection
-
- getTableBuilder(TableName, ExecutorService) - 接口 中的方法org.apache.hadoop.hbase.client.Connection
-
- getTableCF(ReplicationProtos.TableCF[], String) - 类 中的静态方法org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
Get TableCF in TableCFs, if not exist, return null.
- getTableCFsMap() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getTableDescriptor(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- getTableDescriptor(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- getTableDescriptor() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin.TableFuture
-
- getTableDescriptor() - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
已过时。
- getTableDescriptor() - 接口 中的方法org.apache.hadoop.hbase.client.Table
-
- getTableDescriptors(List<String>) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- getTableDescriptors(List<String>) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- getTableDescriptors(RpcController, MasterProtos.GetTableDescriptorsRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- getTableDescriptorsByTableName(List<TableName>) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- getTableDescriptorsByTableName(List<TableName>) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- getTableEncodedRegionNameAndLastBarrier(Connection, TableName) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
- getTableEncodedRegionNamesForSerialReplication(Connection, TableName) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
- getTableFilter() - 类 中的方法org.apache.hadoop.hbase.quotas.QuotaFilter
-
- getTableFromRowKey(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getTableHRegionLocations(AsyncTable<AdvancedScanResultConsumer>, Optional<TableName>) - 类 中的静态方法org.apache.hadoop.hbase.AsyncMetaTableAccessor
-
Used to get all region locations for the specific table.
- getTableName() - 类 中的方法org.apache.hadoop.hbase.client.AsyncProcessTask
-
- getTableName() - 类 中的方法org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
-
- getTableName() - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- getTableName() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin.TableFuture
-
- getTableName() - 类 中的方法org.apache.hadoop.hbase.client.RegionServerCallable
-
- getTableName() - 类 中的方法org.apache.hadoop.hbase.client.SnapshotDescription
-
- getTableName() - 接口 中的方法org.apache.hadoop.hbase.client.TableDescriptor
-
Get the name of the table
- getTableName() - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Get the name of the table
- getTableName() - 类 中的方法org.apache.hadoop.hbase.client.TableState
-
Table name for state
- 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.GetUserPermissionsRequest
-
- getTableName() - 类 中的方法org.apache.hadoop.hbase.security.access.TablePermission
-
- getTableNameArray(List<HBaseProtos.TableName>) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- getTableNameAsString() - 类 中的方法org.apache.hadoop.hbase.client.SnapshotDescription
-
- getTableNames(RpcController, MasterProtos.GetTableNamesRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- getTableQuota(Connection, TableName) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getTableRegions(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- getTableRegions(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- getTableRegions(Connection, TableName) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
Gets all of the regions of the specified table.
- getTableRegions(Connection, TableName, boolean) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
Gets all of the regions of the specified table.
- getTableRegionsAndLocations(Connection, TableName) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
Do not use this method to get meta table regions, use methods in MetaTableLocator instead.
- getTableRegionsAndLocations(Connection, TableName, boolean) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
Do not use this method to get meta table regions, use methods in MetaTableLocator instead.
- getTableRowKey(TableName) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getTableRowKeyRegex(String) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getTableSnapshots(Connection) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
Returns a multimap for all existing table snapshot entries.
- getTableStartRowForMeta(TableName, MetaTableAccessor.QueryType) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
- getTableState(AsyncTable<?>, TableName) - 类 中的静态方法org.apache.hadoop.hbase.AsyncMetaTableAccessor
-
- getTableState(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
-
Retrieve TableState, represent current table state.
- getTableState(RpcController, MasterProtos.GetTableStateRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- getTableState(Connection, TableName) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
Fetch table state for given table from META table
- getTableState(Result) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
Decode table state from META Result.
- getTableStates(Connection) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
Fetch table states from META table
- getTableStopRowForMeta(TableName, MetaTableAccessor.QueryType) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
- getThrottleType() - 类 中的方法org.apache.hadoop.hbase.quotas.ThrottleSettings
-
- getTimeRange() - 类 中的方法org.apache.hadoop.hbase.client.Append
-
Gets the TimeRange used for this append.
- 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
-
- getTimestamp() - 类 中的方法org.apache.hadoop.hbase.client.Mutation
-
Method for retrieving the timestamp.
- getTimeStampOfLastShippedOp() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- getTimestampOfLastShippedOp() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- getTimestamps() - 类 中的方法org.apache.hadoop.hbase.filter.TimestampsFilter
-
- getTimeStampsOfLastAppliedOp() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationLoadSink
-
- getTimestampsOfLastAppliedOp() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationLoadSink
-
- getTimeToLive() - 接口 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- getTimeToLive() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getTimeToLive() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- getTimeUnit() - 类 中的方法org.apache.hadoop.hbase.quotas.ThrottleSettings
-
- 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.shaded.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.client.SnapshotDescription
-
- getType() - 异常错误 中的方法org.apache.hadoop.hbase.quotas.RpcThrottlingException
-
- getType() - 异常错误 中的方法org.apache.hadoop.hbase.quotas.ThrottlingException
-
已过时。
- getTypeFilters() - 类 中的方法org.apache.hadoop.hbase.quotas.QuotaFilter
-
- getUncompressedStoreFileSize() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
-
已过时。
- getUncompressedStoreFileSize() - 接口 中的方法org.apache.hadoop.hbase.RegionMetrics
-
- getUnit(String) - 类 中的静态方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- getUnit(String) - 类 中的静态方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- getUnit() - 类 中的方法org.apache.hadoop.hbase.Size
-
- getUsage() - 类 中的方法org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
-
Returns the current usage, in bytes, of the target (e.g. table, namespace).
- getUsage() - 接口 中的方法org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView
-
Returns the current usage, in bytes, of the target (e.g. table, namespace).
- getUsedHeapMB() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
-
- getUsedHeapSize() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
-
已过时。
- getUsedHeapSize() - 接口 中的方法org.apache.hadoop.hbase.ServerMetrics
-
- 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.access.GetUserPermissionsRequest
-
- getUsername() - 类 中的方法org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- getUserPermissions(GetUserPermissionsRequest) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Get the global/namespace/table permissions for user
- getUserPermissions(GetUserPermissionsRequest) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the global/namespace/table permissions for user
- getUserPermissions(GetUserPermissionsRequest) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- getUserPermissions(RpcController, AccessControlProtos.GetUserPermissionsRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- getUserPermissions(Connection, String) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlClient
-
List all the userPermissions matching the given pattern.
- getUserPermissions(Connection, String, String) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlClient
-
List all the userPermissions matching the given table pattern and user name.
- getUserPermissions(Connection, String, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlClient
-
List all the userPermissions matching the given table pattern and column family.
- getUserPermissions(Connection, String, byte[], String) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlClient
-
List all the userPermissions matching the given table pattern, column family and user name.
- getUserPermissions(Connection, String, byte[], byte[]) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlClient
-
List all the userPermissions matching the given table pattern, column family and column
qualifier.
- getUserPermissions(Connection, String, byte[], byte[], String) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlClient
-
List all the userPermissions matching the given table pattern, column family and column
qualifier.
- getUserPermissions(RpcController, AccessControlProtos.AccessControlService.BlockingInterface) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlUtil
-
- getUserPermissions(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlUtil
-
- getUserPermissions(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, TableName) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlUtil
-
- getUserPermissions(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, TableName, byte[], byte[], String) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlUtil
-
- getUserPermissions(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, byte[]) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlUtil
-
- getUserPermissions(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, byte[], String) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlUtil
-
- GetUserPermissionsRequest - org.apache.hadoop.hbase.security.access中的类
-
- GetUserPermissionsRequest.Builder - org.apache.hadoop.hbase.security.access中的类
-
- 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
-
- getValue(Bytes) - 接口 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- getValue(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- getValue(Bytes) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getValue(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- 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(Bytes) - 接口 中的方法org.apache.hadoop.hbase.client.TableDescriptor
-
Getter for accessing the metadata associated with the key.
- getValue(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.TableDescriptor
-
Getter for accessing the metadata associated with the key.
- getValue(String) - 接口 中的方法org.apache.hadoop.hbase.client.TableDescriptor
-
Getter for accessing the metadata associated with the key.
- getValue(Bytes) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- getValue(String) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- getValue(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- getValue(byte[], byte[], Cell) - 类 中的方法org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
- getValue() - 类 中的方法org.apache.hadoop.hbase.filter.SubstringComparator
-
- getValue(byte[]) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- getValue(String) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- getValue(Bytes) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- getValue(Bytes) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
- getValue(String) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
- getValue(byte[]) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
- getValue(String) - 枚举 中的静态方法org.apache.hadoop.hbase.KeepDeletedCells
-
- 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.client.ColumnFamilyDescriptor
-
It clone all bytes of all elements.
- getValues() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getValues() - 接口 中的方法org.apache.hadoop.hbase.client.TableDescriptor
-
- getValues() - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- getValues() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- getValues() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
- getVersion() - 类 中的方法org.apache.hadoop.hbase.client.SnapshotDescription
-
- getVersion() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
-
- getVersion() - 接口 中的方法org.apache.hadoop.hbase.CoprocessorEnvironment
-
- getVersion() - 类 中的方法org.apache.hadoop.hbase.security.access.Permission
-
- getVersion() - 接口 中的方法org.apache.hadoop.hbase.ServerMetrics
-
- getVersionInfo() - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Get a protocol buffer VersionInfo
- getVersionNumber() - 接口 中的方法org.apache.hadoop.hbase.ServerMetrics
-
- getViolationPolicy(QuotaProtos.SpaceQuota) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getWaitInterval() - 异常错误 中的方法org.apache.hadoop.hbase.quotas.RpcThrottlingException
-
- getWaitInterval() - 异常错误 中的方法org.apache.hadoop.hbase.quotas.ThrottlingException
-
已过时。
- 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)
.
- getWriteBufferPeriodicFlushTimeoutMs() - 接口 中的方法org.apache.hadoop.hbase.client.BufferedMutator
-
Returns the current periodic flush timeout value in milliseconds.
- getWriteBufferPeriodicFlushTimeoutMs() - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- getWriteBufferPeriodicFlushTimeoutMs() - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- getWriteBufferPeriodicFlushTimeoutMs() - 类 中的方法org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getWriteBufferPeriodicFlushTimerTickMs() - 接口 中的方法org.apache.hadoop.hbase.client.BufferedMutator
-
Returns the current periodic flush timertick interval in milliseconds.
- getWriteBufferPeriodicFlushTimerTickMs() - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- getWriteBufferPeriodicFlushTimerTickMs() - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- getWriteBufferPeriodicFlushTimerTickMs() - 类 中的方法org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getWriteBufferSize() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncBufferedMutator
-
Returns the maximum size in bytes of the write buffer.
- 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
-
- getWriteRequestCount() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
-
已过时。
- getWriteRequestCount() - 接口 中的方法org.apache.hadoop.hbase.RegionMetrics
-
- getWriteRequestsCount() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
-
- getWriteRequestsCount() - 类 中的方法org.apache.hadoop.hbase.ServerLoad
-
- getWriteRpcTimeout(TimeUnit) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable
-
Get timeout of each rpc write request in this Table instance.
- getWriteRpcTimeout() - 类 中的方法org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getWriteRpcTimeout(TimeUnit) - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
- getWriteRpcTimeout() - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
已过时。
- getWriteRpcTimeout(TimeUnit) - 接口 中的方法org.apache.hadoop.hbase.client.Table
-
Get timeout of each rpc write request in this Table instance.
- getWriteRpcTimeout() - 接口 中的方法org.apache.hadoop.hbase.client.Table
-
- getZNodeForReplica(int) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
Get the znode string corresponding to a replicaId
- GlobalPermission - org.apache.hadoop.hbase.security.access中的类
-
Represents an authorization for access whole cluster.
- grant(UserPermission, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Grants user specific permissions
- grant(UserPermission, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Grants user specific permissions
- grant(UserPermission, boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- grant(RpcController, AccessControlProtos.GrantRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- 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, Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlClient
-
Grants permission on the specified namespace for the specified user.
- grant(Connection, String, Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlClient
-
Grant global permissions for the specified user.
- grant(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, boolean, Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlUtil
-
- grant(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, TableName, byte[], byte[], boolean, Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlUtil
-
- grant(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, String, boolean, Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlUtil
-
- 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
-
- 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
-
- ifEquals(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateBuilder
-
Check for equality.
- ifEquals(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder
-
Check for equality.
- ifMatches(CompareOperator, byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateBuilder
-
- ifMatches(CompareOperator, byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder
-
- ifNotExists() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateBuilder
-
Check for lack of column.
- ifNotExists() - 接口 中的方法org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder
-
Check for lack of column.
- ImmutableHColumnDescriptor - org.apache.hadoop.hbase.client中的类
-
已过时。
- ImmutableHColumnDescriptor(ColumnFamilyDescriptor) - 类 的构造器org.apache.hadoop.hbase.client.ImmutableHColumnDescriptor
-
已过时。
- ImmutableHRegionInfo - org.apache.hadoop.hbase.client中的类
-
已过时。
- ImmutableHRegionInfo(RegionInfo) - 类 的构造器org.apache.hadoop.hbase.client.ImmutableHRegionInfo
-
已过时。
- ImmutableHTableDescriptor - org.apache.hadoop.hbase.client中的类
-
已过时。
- ImmutableHTableDescriptor(HTableDescriptor) - 类 的构造器org.apache.hadoop.hbase.client.ImmutableHTableDescriptor
-
已过时。
- ImmutableHTableDescriptor(TableDescriptor) - 类 的构造器org.apache.hadoop.hbase.client.ImmutableHTableDescriptor
-
已过时。
- implementationClassName(String) - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorParams
-
Specify a BufferedMutator implementation other than the default.
- implies(String, Permission.Action) - 类 中的方法org.apache.hadoop.hbase.security.access.NamespacePermission
-
check if given action is granted in given namespace.
- implies(Permission.Action) - 类 中的方法org.apache.hadoop.hbase.security.access.Permission
-
check if given action is granted
- implies(TableName, byte[], byte[], Permission.Action) - 类 中的方法org.apache.hadoop.hbase.security.access.TablePermission
-
Check if given action can performs on given table:family:qualifier.
- implies(TableName, byte[], Permission.Action) - 类 中的方法org.apache.hadoop.hbase.security.access.TablePermission
-
Check if given action can performs on given table:family.
- 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.
- IN_MEMORY - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- IN_MEMORY_COMPACTION - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- IN_MEMORY_COMPACTION - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- 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.RunnerStats
-
- incrDelayRunnersAndUpdateDelayInterval(long) - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection
-
Increment the number of delay runner counts and update delay interval of delay runner.
- increment(Increment) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable
-
Increments one or more columns within a single row.
- 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
-
- 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(byte[], long, NavigableMap<byte[], List<Cell>>) - 类 的构造器org.apache.hadoop.hbase.client.Increment
-
Construct the Increment with user defined data.
- 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.AsyncTable
-
- incrementColumnValue(byte[], byte[], byte[], long, Durability) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable
-
Atomically increments a column value.
- incrementColumnValue(byte[], byte[], byte[], long) - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
- incrementColumnValue(byte[], byte[], byte[], long, Durability) - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
- 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.
- incrMetaCacheNumClearRegion(int) - 类 中的方法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
-
- incTaskCounters(Collection<byte[]>, ServerName) - 接口 中的方法org.apache.hadoop.hbase.client.RequestController
-
Increment the counter if we build a valid task.
- initCache() - 类 中的方法org.apache.hadoop.hbase.client.ClientAsyncPrefetchScanner
-
- initCache() - 类 中的方法org.apache.hadoop.hbase.client.ClientScanner
-
- initCryptoCipher(RPCProtos.CryptoCipherMeta, Configuration) - 类 中的方法org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
- 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
- initSyncCache() - 类 中的方法org.apache.hadoop.hbase.client.ClientScanner
-
- injectNonceGeneratorForTesting(ClusterConnection, NonceGenerator) - 类 中的静态方法org.apache.hadoop.hbase.client.ConnectionUtils
-
- 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
-
- inStates(TableState.State) - 类 中的方法org.apache.hadoop.hbase.client.TableState
-
Check that table in given states
- inStates(TableState.State...) - 类 中的方法org.apache.hadoop.hbase.client.TableState
-
Check that table in given states
- INVALID_REGION_NAME_FORMAT_MESSAGE - 接口 中的静态变量org.apache.hadoop.hbase.client.RegionInfo
-
- 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
-
- 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.client.TableDescriptorBuilder
-
Used by rest interface to access this metadata attribute
which denotes if it is a catalog table, either hbase:meta
.
- IS_META - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
- IS_MOB - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- IS_MOB - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- IS_MOB_BYTES - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- IS_ROOT - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
- 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.client.HBaseHbck
-
- isAccessControllerRunning(Connection) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlClient
-
- isAdjacent(RegionInfo) - 接口 中的方法org.apache.hadoop.hbase.client.RegionInfo
-
- isAnyMetaReplicaZNode(String) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
Is the znode of any meta replica
- isAscendingOrder() - 类 中的方法org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
-
- isAsyncPrefetch() - 类 中的方法org.apache.hadoop.hbase.client.Scan
-
- isAuthorizationEnabled(Connection) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlClient
-
Return true if authorization is supported and enabled
- isBalancerEnabled() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Query the current state of the balancer.
- isBalancerEnabled() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Query the current state of the balancer.
- isBalancerEnabled() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- isBalancerEnabled(RpcController, MasterProtos.IsBalancerEnabledRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- isBalancerOn() - 类 中的方法org.apache.hadoop.hbase.ClusterStatus
-
- isBlockCacheEnabled() - 接口 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- isBlockCacheEnabled() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- isBlockCacheEnabled() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- isCacheBloomsOnWrite() - 接口 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- isCacheBloomsOnWrite() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- isCacheBloomsOnWrite() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- isCacheDataOnWrite() - 接口 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- isCacheDataOnWrite() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- isCacheDataOnWrite() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- isCacheIndexesOnWrite() - 接口 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- isCacheIndexesOnWrite() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- 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.client.ClientCoprocessorRpcController
-
- 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
-
- isCatalogJanitorEnabled() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Query on the catalog janitor state (Enabled/Disabled?).
- isCatalogJanitorEnabled() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Query on the catalog janitor state.
- isCatalogJanitorEnabled() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- isCatalogJanitorEnabled(RpcController, MasterProtos.IsCatalogJanitorEnabledRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- 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
-
- isClassLoaderLoaded() - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- isCleanerChoreEnabled() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Query on the cleaner chore state (Enabled/Disabled?).
- isCleanerChoreEnabled() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Query the current state of the cleaner chore.
- isCleanerChoreEnabled() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- isCleanerChoreEnabled(RpcController, MasterProtos.IsCleanerChoreEnabledRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- isClientReadable(String) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
Returns whether the znode is supposed to be readable by the client and DOES NOT contain
sensitive information (world readable).
- isClientScannerAsyncPrefetch() - 类 中的方法org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- isClosed() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncConnection
-
Returns whether the connection is closed or not.
- isClosed() - 接口 中的方法org.apache.hadoop.hbase.client.Connection
-
Returns whether the connection is closed or not.
- isClosed() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
-
- isClosed(AdminProtos.CloseRegionResponse) - 类 中的静态方法org.apache.hadoop.hbase.shaded.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
-
- isClosingOrClosedOnServer(ServerName) - 类 中的方法org.apache.hadoop.hbase.master.RegionState
-
- isCompactionEnabled() - 接口 中的方法org.apache.hadoop.hbase.client.TableDescriptor
-
Check if the compaction enable flag of the table is true.
- isCompactionEnabled() - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Check if the compaction enable flag of the table is true.
- 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.client.ColumnFamilyDescriptor
-
- isCompressTags() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- 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.
- isDefaultMetaReplicaZnode(String) - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
Is it the default meta replica's znode
- isDefaultReplica(int) - 类 中的静态方法org.apache.hadoop.hbase.client.RegionReplicaUtil
-
- isDefaultReplica(RegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.client.RegionReplicaUtil
-
- isDegenerate() - 接口 中的方法org.apache.hadoop.hbase.client.RegionInfo
-
- isDisabled() - 类 中的方法org.apache.hadoop.hbase.client.TableState
-
- isDisabledOrDisabling() - 类 中的方法org.apache.hadoop.hbase.client.TableState
-
- isDisabling() - 类 中的方法org.apache.hadoop.hbase.client.TableState
-
- 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.client.RowAccess
-
- 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
-
- isEmptyQuota(QuotaProtos.Quotas) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- isEnabled() - 类 中的方法org.apache.hadoop.hbase.client.TableState
-
- isEnabled() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerDescription
-
- isEnabledOrEnabling() - 类 中的方法org.apache.hadoop.hbase.client.TableState
-
- isEnabling() - 类 中的方法org.apache.hadoop.hbase.client.TableState
-
- isEncodedRegionName(byte[]) - 接口 中的静态方法org.apache.hadoop.hbase.client.RegionInfo
-
- isEncodedRegionName(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
-
- isEvictBlocksOnClose() - 接口 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- isEvictBlocksOnClose() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- 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.ColumnValueFilter
-
- 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.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
-
- isFirst() - 接口 中的方法org.apache.hadoop.hbase.client.RegionInfo
-
- isGetScan() - 类 中的方法org.apache.hadoop.hbase.client.Scan
-
- isGuaranteedClientSideOnly() - 异常错误 中的方法org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
-
- isInMemory() - 接口 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- isInMemory() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- isInMemory() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- isInReturnCodes(Filter.ReturnCode, Filter.ReturnCode...) - 类 中的静态方法org.apache.hadoop.hbase.filter.FilterListBase
-
- isInStates(TableState.State...) - 类 中的方法org.apache.hadoop.hbase.client.TableState
-
Static version of state checker
- isInViolation() - 类 中的方法org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot.SpaceQuotaStatus
-
- isInViolation() - 接口 中的方法org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView.SpaceQuotaStatusView
-
- isLast() - 接口 中的方法org.apache.hadoop.hbase.client.RegionInfo
-
- isLegalColumnFamilyName(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- isLegalFamilyName(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.HColumnDescriptor
-
- isMasterInMaintenanceMode() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Check whether Master is in maintenance mode.
- isMasterInMaintenanceMode() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Check whether master is in maintenance mode
- isMasterInMaintenanceMode() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- isMasterInMaintenanceMode(RpcController, MasterProtos.IsInMaintenanceModeRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- isMasterRunning() - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
-
- isMasterRunning(RpcController, MasterProtos.IsMasterRunningRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- isMaxColumnInclusive() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- isMerged() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
-
- isMergeEnabled() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Query the current state of the merge switch.
- isMergeEnabled() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Query the current state of the Merge switch.
- isMergeEnabled() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- isMergeEnabled() - 接口 中的方法org.apache.hadoop.hbase.client.TableDescriptor
-
Check if the merge enable flag of the table is true.
- isMergeEnabled() - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Check if the region merge enable flag of the table is true.
- isMergeEnabled() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
Check if the region merge enable flag of the table is true.
- isMerging() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
-
- isMergingNew() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
-
- isMergingNewOnServer(ServerName) - 类 中的方法org.apache.hadoop.hbase.master.RegionState
-
- isMergingNewOrOfflineOnServer(ServerName) - 类 中的方法org.apache.hadoop.hbase.master.RegionState
-
- isMergingNewOrOpenedOnServer(ServerName) - 类 中的方法org.apache.hadoop.hbase.master.RegionState
-
- isMergingOnServer(ServerName) - 类 中的方法org.apache.hadoop.hbase.master.RegionState
-
- isMetaClearingException(Throwable) - 类 中的静态方法org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
-
- isMetaRegion() - 接口 中的方法org.apache.hadoop.hbase.client.RegionInfo
-
- isMetaRegion() - 接口 中的方法org.apache.hadoop.hbase.client.TableDescriptor
-
Checks if this table is hbase:meta
region.
- isMetaRegion() - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Checks if this table is hbase:meta
region.
- 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.client.TableDescriptor
-
Checks if the table is a hbase:meta
table
- isMetaTable() - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Checks if the table is a hbase:meta
table
- 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
-
- isMobEnabled() - 接口 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Gets whether the mob is enabled for the family.
- isMobEnabled() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- isMobEnabled() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- isNamespaceRowKey(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- isNeedCursorResult() - 类 中的方法org.apache.hadoop.hbase.client.Scan
-
- isNeedProcessConnectionHeader() - 类 中的方法org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClientHandler
-
- isNewVersionBehavior() - 接口 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
By default, HBase only consider timestamp in versions.
- isNewVersionBehavior() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
By default, HBase only consider timestamp in versions.
- isNewVersionBehavior() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
By default, HBase only consider timestamp in versions.
- isNext(RegionInfo) - 接口 中的方法org.apache.hadoop.hbase.client.RegionInfo
-
- isNormalizationEnabled() - 接口 中的方法org.apache.hadoop.hbase.client.TableDescriptor
-
Check if normalization enable flag of the table is true.
- isNormalizationEnabled() - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Check if normalization enable flag of the table is true.
- 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.AsyncAdmin
-
Query the current state of the region normalizer
- isNormalizerEnabled() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- isNormalizerEnabled(RpcController, MasterProtos.IsNormalizerEnabledRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- isNull() - 类 中的方法org.apache.hadoop.hbase.quotas.QuotaFilter
-
- isOffline() - 接口 中的方法org.apache.hadoop.hbase.client.RegionInfo
-
- 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.
- isOnServer(ServerName) - 类 中的方法org.apache.hadoop.hbase.master.RegionState
-
- isOpened() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
-
- isOpenedOnServer(ServerName) - 类 中的方法org.apache.hadoop.hbase.master.RegionState
-
- isOpening() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
-
- isOpeningOrFailedOpenOnServer(ServerName) - 类 中的方法org.apache.hadoop.hbase.master.RegionState
-
- isOpeningOrOpenedOnServer(ServerName) - 类 中的方法org.apache.hadoop.hbase.master.RegionState
-
- isOverlap(RegionInfo) - 接口 中的方法org.apache.hadoop.hbase.client.RegionInfo
-
- isPartial() - 类 中的方法org.apache.hadoop.hbase.client.Result
-
- isPBMagicPrefix(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufMagic
-
- isPBMagicPrefix(byte[], int, int) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufMagic
-
- isPBMagicPrefix(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- isPBMagicPrefix(byte[], int, int) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- isPBMagicPrefix(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- isPBMagicPrefix(byte[], int, int) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- isPrefetchBlocksOnOpen() - 接口 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- isPrefetchBlocksOnOpen() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- isPrefetchBlocksOnOpen() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- isProcedureDone(RpcController, MasterProtos.IsProcedureDoneRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- 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.AsyncAdmin
-
Check the current state of the specified procedure.
- isProcedureFinished(String, String, Map<String, String>) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- isProcessed() - 类 中的方法org.apache.hadoop.hbase.client.SingleResponse.Entry
-
- 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.client.TableDescriptor
-
Check if the readOnly flag of the table is set.
- isReadOnly() - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Check if the readOnly flag of the table is set.
- 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
-
- isRegionServerRowKey(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- isReplicasForSameRegion(RegionInfo, RegionInfo) - 类 中的静态方法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
-
已过时。
This is vestigial API.
- isRpcThrottleEnabled() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Get if the rpc throttle is enabled.
- isRpcThrottleEnabled() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Get if the rpc throttle is enabled.
- isRpcThrottleEnabled() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- isRpcThrottleEnabled(RpcController, MasterProtos.IsRpcThrottleEnabledRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- isRSGroupsEnabled(Connection) - 类 中的静态方法org.apache.hadoop.hbase.RSGroupTableAccessor
-
- isScanMetricsEnabled() - 类 中的方法org.apache.hadoop.hbase.client.Scan
-
- isSearchRowInclusive() - 类 中的方法org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
-
- isSerial() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- isSmall() - 类 中的方法org.apache.hadoop.hbase.client.Scan
-
- isSnapshotDone(RpcController, MasterProtos.IsSnapshotDoneRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- isSnapshotFinished(SnapshotDescription) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Check the current state of the passed snapshot.
- isSnapshotFinished(SnapshotDescription) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Check the current state of the passed snapshot.
- isSnapshotFinished(SnapshotDescription) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- isSpecialException(Throwable) - 类 中的静态方法org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
-
- isSplit() - 接口 中的方法org.apache.hadoop.hbase.client.RegionInfo
-
- isSplit() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
-
已过时。
- isSplit() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
-
- isSplitEnabled() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Query the current state of the split switch.
- isSplitEnabled() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Query the current state of the Split switch.
- isSplitEnabled() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- isSplitEnabled() - 接口 中的方法org.apache.hadoop.hbase.client.TableDescriptor
-
Check if the split enable flag of the table is true.
- isSplitEnabled() - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Check if the split enable flag of the table is true.
- isSplitEnabled() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
Check if the region split enable flag of the table is true.
- isSplitOrMergeEnabled(MasterSwitchType) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- isSplitOrMergeEnabled(RpcController, MasterProtos.IsSplitOrMergeEnabledRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- isSplitParent() - 接口 中的方法org.apache.hadoop.hbase.client.RegionInfo
-
- isSplitParent() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
-
已过时。
- isSplitting() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
-
- isSplittingNew() - 类 中的方法org.apache.hadoop.hbase.master.RegionState
-
- isSplittingNewOnServer(ServerName) - 类 中的方法org.apache.hadoop.hbase.master.RegionState
-
- isSplittingOnServer(ServerName) - 类 中的方法org.apache.hadoop.hbase.master.RegionState
-
- isSplittingOrOpenedOnServer(ServerName) - 类 中的方法org.apache.hadoop.hbase.master.RegionState
-
- isSplittingOrSplitOnServer(ServerName) - 类 中的方法org.apache.hadoop.hbase.master.RegionState
-
- isStale() - 类 中的方法org.apache.hadoop.hbase.client.Result
-
Whether or not the results are coming from possibly stale data.
- issueDate - 类 中的变量org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- isSystemTable() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
-
已过时。
- isTableAvailable(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- isTableAvailable(TableName, byte[][]) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- isTableAvailable(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
- isTableAvailable(TableName, byte[][]) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
- 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(TableName, byte[][]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableDisabled(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- isTableDisabled(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
- isTableDisabled(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
-
- isTableDisabled(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableEnabled(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- isTableEnabled(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
- isTableEnabled(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.ClusterConnection
-
A table that isTableEnabled == false and isTableDisabled == false
is possible.
- isTableEnabled(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableRowKey(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- 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.ResultScanner
-
- iterator() - 类 中的方法org.apache.hadoop.hbase.quotas.QuotaRetriever
-
- 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, CompactType) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Major compact a table.
- majorCompact(TableName, byte[], CompactType) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Major compact a column family within a table.
- majorCompact(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Major compact a table.
- majorCompact(TableName, byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Major compact a column family within a table.
- majorCompact(TableName, CompactType) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Major compact a table.
- majorCompact(TableName, byte[], CompactType) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Major compact a column family within a table.
- majorCompact(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- majorCompact(TableName, byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
Major compact a column family within a table.
- majorCompact(TableName, byte[], CompactType) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
Major compact a column family within a table.
- majorCompact(TableName, CompactType) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
Major compact a table.
- 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.AsyncAdmin
-
Major compact a region.
- majorCompactRegion(byte[], byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Major compact a column family within region.
- majorCompactRegion(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- majorCompactRegion(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- majorCompactRegionServer(ServerName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Major compact all regions on the region server.
- majorCompactRegionServer(ServerName) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Compact all regions on the region server.
- majorCompactRegionServer(ServerName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- makeFilter(QuotaFilter) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
converts quotafilter to serializeable filterlists.
- makeGetForNamespaceQuotas(String) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- makeGetForRegionServerQuotas(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
-
- makePutForReplicationBarrier(RegionInfo, long, long) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
- makePutFromRegionInfo(RegionInfo, long) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
Generates and returns a Put containing the region into for the catalog table
- makePutFromTableState(TableState, long) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
Construct PUT for given state
- makeQuotaSnapshotGetForTable(TableName) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- makeQuotaSnapshotScan() - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
Creates a
Scan
which returns only quota snapshots from the quota table.
- makeQuotaSnapshotScanForTable(TableName) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- makeScan(QuotaFilter) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- masterAddressZNode - 类 中的变量org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
- masterMaintZNode - 类 中的变量org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
- 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
-
- MasterSwitchType - org.apache.hadoop.hbase.client中的枚举
-
Represents the master switch type
- matchedColumn - 类 中的变量org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- matches(RegionState.State...) - 枚举 中的方法org.apache.hadoop.hbase.master.RegionState.State
-
- matches(String) - 枚举 中的方法org.apache.hadoop.hbase.security.SaslUtil.QualityOfProtection
-
- matchReplicationScope(boolean) - 接口 中的方法org.apache.hadoop.hbase.client.TableDescriptor
-
Check if the table's cfs' replication scope matched with the replication state
- MAX_BACKOFF_KEY - 类 中的静态变量org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
-
- MAX_FILESIZE - 类 中的静态变量org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
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_FILESIZE - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
- MAX_KEYVALUE_SIZE_DEFAULT - 类 中的静态变量org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- MAX_KEYVALUE_SIZE_KEY - 类 中的静态变量org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- MAX_VERSIONS - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- 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.client.RegionInfo
-
- mechanismName - 枚举 中的变量org.apache.hadoop.hbase.security.AuthMethod
-
- MemoryCompactionPolicy - org.apache.hadoop.hbase中的枚举
-
Enum describing all possible memory compaction policies
- MEMSTORE_FLUSHSIZE - 类 中的静态变量org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
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.
- MEMSTORE_FLUSHSIZE - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
- merge(QuotaSettings) - 类 中的方法org.apache.hadoop.hbase.quotas.ThrottleSettings
-
- MERGE_ENABLED - 类 中的静态变量org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Used by HBase Shell interface to access this metadata
attribute which denotes if the table is merge enabled.
- MERGE_ENABLED - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
- mergeDelimitedFrom(Message.Builder, InputStream) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
This version of protobuf's mergeDelimitedFrom avoid the hard-coded 64MB limit for decoding
buffers
- 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, InputStream, int) - 类 中的静态方法org.apache.hadoop.hbase.shaded.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.shaded.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.shaded.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.shaded.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.shaded.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.shaded.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
- MergeRegionException(Throwable) - 异常错误 的构造器org.apache.hadoop.hbase.exceptions.MergeRegionException
-
- mergeRegions(byte[], byte[], boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- mergeRegions(byte[], byte[], boolean) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Merge two regions.
- mergeRegions(List<byte[]>, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Merge regions.
- mergeRegions(byte[], byte[], boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- mergeRegions(Connection, RegionInfo, Map<RegionInfo, Long>, ServerName, int) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
Merge regions into one in an atomic operation.
- mergeRegionsAsync(byte[], byte[], boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Merge two regions.
- mergeRegionsAsync(byte[][], boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Merge regions.
- mergeRegionsAsync(byte[][], boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
Merge two regions.
- mergeRegionsSync(byte[], byte[], boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
Merge two regions.
- mergeSwitch(boolean, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Turn the merge switch on or off.
- mergeSwitch(boolean) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Turn the Merge switch on or off.
- mergeSwitch(boolean, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Turn the Merge switch on or off.
- mergeSwitch(boolean, boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- mergeTableRegions(RpcController, MasterProtos.MergeTableRegionsRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- META_ZNODE_PREFIX - 类 中的静态变量org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
- 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
-
- metaReplicaZNodes - 类 中的变量org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
- MetaTableAccessor - org.apache.hadoop.hbase中的类
-
Read/write operations on hbase:meta
region as well as assignment information stored
to hbase:meta
.
- MetaTableAccessor() - 类 的构造器org.apache.hadoop.hbase.MetaTableAccessor
-
- MetaTableAccessor.CloseableVisitor - org.apache.hadoop.hbase中的接口
-
Implementations 'visit' a catalog table row but with close() at the end.
- MetaTableAccessor.DefaultVisitorBase - org.apache.hadoop.hbase中的类
-
A Visitor that skips offline regions and split parents
- MetaTableAccessor.QueryType - org.apache.hadoop.hbase中的枚举
-
- MetaTableAccessor.ReplicationBarrierResult - org.apache.hadoop.hbase中的类
-
- MetaTableAccessor.TableVisitorBase - org.apache.hadoop.hbase中的类
-
A Visitor for a table.
- MetaTableAccessor.Visitor - org.apache.hadoop.hbase中的接口
-
Implementations 'visit' a catalog table row.
- metaZNodePrefix - 类 中的变量org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
- 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.CallStats - org.apache.hadoop.hbase.client中的类
-
A container class for collecting details about the RPC call as it percolates.
- MetricsConnection.CallTracker - org.apache.hadoop.hbase.client中的类
-
- MetricsConnection.RegionStats - org.apache.hadoop.hbase.client中的类
-
- MetricsConnection.RunnerStats - org.apache.hadoop.hbase.client中的类
-
- MILLIS_BETWEEN_NEXTS_METRIC_NAME - 类 中的静态变量org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
- MIN_VERSIONS - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- MIN_VERSIONS - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- MIN_WRITE_BUFFER_PERIODIC_FLUSH_TIMERTICK_MS - 接口 中的静态变量org.apache.hadoop.hbase.client.BufferedMutator
-
Having the timer tick run more often that once every 100ms is needless and will
probably cause too many timer events firing having a negative impact on performance.
- 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
- MOB_COMPACT_PARTITION_POLICY - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- MOB_COMPACT_PARTITION_POLICY - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- MOB_COMPACT_PARTITION_POLICY_BYTES - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- MOB_THRESHOLD - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- MOB_THRESHOLD - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- MOB_THRESHOLD_BYTES - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- MobCompactPartitionPolicy - org.apache.hadoop.hbase.client中的枚举
-
Enum describing the mob compact partition policy types.
- ModifyableColumnFamilyDescriptor(byte[]) - 类 的构造器org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Construct a column descriptor specifying only the family name The other
attributes are defaulted.
- ModifyableColumnFamilyDescriptor(ColumnFamilyDescriptor) - 类 的构造器org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Constructor.
- ModifyableTableDescriptor(TableName) - 类 的构造器org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Construct a table descriptor specifying a TableName object
- ModifyableTableDescriptor(TableName, TableDescriptor) - 类 的构造器org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
已过时。
- modifyColumn(TableName, ColumnFamilyDescriptor) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- modifyColumn(RpcController, MasterProtos.ModifyColumnRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- modifyColumnFamily(TableName, ColumnFamilyDescriptor) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Modify an existing column family on a table.
- modifyColumnFamily(TableName, ColumnFamilyDescriptor) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Modify an existing column family on a table.
- modifyColumnFamily(TableName, ColumnFamilyDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- modifyColumnFamily(ColumnFamilyDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Modifies the existing column family.
- modifyColumnFamily(ColumnFamilyDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- modifyColumnFamilyAsync(TableName, ColumnFamilyDescriptor) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Modify an existing column family on a table.
- modifyColumnFamilyAsync(TableName, ColumnFamilyDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- 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.AsyncAdmin
-
Modify an existing namespace.
- modifyNamespace(NamespaceDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- modifyNamespace(RpcController, MasterProtos.ModifyNamespaceRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- modifyNamespaceAsync(NamespaceDescriptor) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Modify an existing namespace.
- modifyNamespaceAsync(NamespaceDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- modifyTable(TableName, TableDescriptor) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- modifyTable(TableDescriptor) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Modify an existing table, more IRB friendly version.
- modifyTable(TableDescriptor) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Modify an existing table, more IRB friendly version.
- modifyTable(TableDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- modifyTable(TableName, TableDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- modifyTable(RpcController, MasterProtos.ModifyTableRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- modifyTableAsync(TableName, TableDescriptor) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- modifyTableAsync(TableDescriptor) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Modify an existing table, more IRB (ruby) friendly version.
- modifyTableAsync(TableDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- modifyTableAsync(TableName, TableDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- move(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Move the region encodedRegionName
to a random server.
- move(byte[], byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- move(byte[], ServerName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Move the region rencodedRegionName
to destServerName
.
- move(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Move the region r
to a random server.
- move(byte[], ServerName) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Move the region r
to dest
.
- move(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- move(byte[], ServerName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- moveRegion(RpcController, MasterProtos.MoveRegionRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- moveToNextRegion() - 类 中的方法org.apache.hadoop.hbase.client.ClientScanner
-
Close the previous scanner and create a new ScannerCallable for the next scanner.
- MultiAction - 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
-
- 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中的类
-
- multiTracker - 类 中的变量org.apache.hadoop.hbase.client.MetricsConnection
-
- mutate(Mutation) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncBufferedMutator
-
- mutate(List<? extends Mutation>) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncBufferedMutator
-
- mutate(Mutation) - 接口 中的方法org.apache.hadoop.hbase.client.BufferedMutator
-
- mutate(List<? extends Mutation>) - 接口 中的方法org.apache.hadoop.hbase.client.BufferedMutator
-
- mutate(Mutation) - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- mutate(List<? extends Mutation>) - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- mutateRow(RowMutations) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable
-
Performs multiple mutations atomically on a single row.
- mutateRow(RowMutations) - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
- 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
-
empty construction.
- Mutation(Mutation) - 类 的构造器org.apache.hadoop.hbase.client.Mutation
-
- Mutation(byte[], long, NavigableMap<byte[], List<Cell>>) - 类 的构造器org.apache.hadoop.hbase.client.Mutation
-
Construct the mutation with user defined data.
- MUTATION_OVERHEAD - 类 中的静态变量org.apache.hadoop.hbase.client.Mutation
-
- 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.
- rawCells() - 类 中的方法org.apache.hadoop.hbase.client.Result
-
Return the array of Cells backing this Result instance.
- rawExpression() - 类 中的方法org.apache.hadoop.hbase.security.access.NamespacePermission
-
- rawExpression() - 类 中的方法org.apache.hadoop.hbase.security.access.Permission
-
- rawExpression() - 类 中的方法org.apache.hadoop.hbase.security.access.TablePermission
-
- read(DataInput) - 枚举 中的静态方法org.apache.hadoop.hbase.security.AuthMethod
-
Read from in
- readAllVersions() - 类 中的方法org.apache.hadoop.hbase.client.Get
-
Get all available versions.
- readAllVersions() - 类 中的方法org.apache.hadoop.hbase.client.Scan
-
Get all available versions.
- readFields(DataInput) - 类 中的方法org.apache.hadoop.hbase.security.access.NamespacePermission
-
- 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.token.AuthenticationTokenIdentifier
-
- READONLY - 类 中的静态变量org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Used by rest interface to access this metadata attribute
which denotes if the table is Read Only.
- READONLY - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
- ReadOnlyZKClient - org.apache.hadoop.hbase.zookeeper中的类
-
A very simple read only zookeeper implementation without watcher support.
- ReadOnlyZKClient(Configuration) - 类 的构造器org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
-
- readTO - 类 中的变量org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- readVersions(int) - 类 中的方法org.apache.hadoop.hbase.client.Get
-
Get up to the specified number of versions of each column.
- readVersions(int) - 类 中的方法org.apache.hadoop.hbase.client.Scan
-
Get up to the specified number of versions of each column.
- recommissionRegionServer(ServerName, List<byte[]>) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Remove decommission marker from a region server to allow regions assignments.
- recommissionRegionServer(ServerName, List<byte[]>) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Remove decommission marker from a region server to allow regions assignments.
- recommissionRegionServer(ServerName, List<byte[]>) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- recommissionRegionServer(RpcController, MasterProtos.RecommissionRegionServerRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- RECOVERY_RETRY - 类 中的静态变量org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
-
- RECOVERY_RETRY_INTERVAL_MILLIS - 类 中的静态变量org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
-
- 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中的类
-
- 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.client.TableDescriptorBuilder
-
The flag to indicate whether or not the memstore should be
replicated for read-replicas (CONSISTENCY => TIMELINE).
- REGION_MEMSTORE_REPLICATION - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
- 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.client.TableDescriptorBuilder
-
The number of region replicas for the table.
- REGION_REPLICATION - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
- 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
-
- 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
- RegionInfo - org.apache.hadoop.hbase.client中的接口
-
Information about a region.
- RegionInfoBuilder - org.apache.hadoop.hbase.client中的类
-
- RegionInfoDisplay - org.apache.hadoop.hbase.client中的类
-
Utility used composing RegionInfo for 'display'; e.g. on the web UI
- RegionInfoDisplay() - 类 的构造器org.apache.hadoop.hbase.client.RegionInfoDisplay
-
- RegionLoad - org.apache.hadoop.hbase中的类
-
- RegionLoad(ClusterStatusProtos.RegionLoad) - 类 的构造器org.apache.hadoop.hbase.RegionLoad
-
已过时。
- regionLoadPB - 类 中的变量org.apache.hadoop.hbase.RegionLoad
-
已过时。
- RegionLoadStats - org.apache.hadoop.hbase.client中的类
-
POJO representing region server load
- RegionLoadStats(int, int, int) - 类 的构造器org.apache.hadoop.hbase.client.RegionLoadStats
-
- 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.
- RegionMetrics - org.apache.hadoop.hbase中的接口
-
Encapsulates per-region load metrics.
- RegionMetricsBuilder - org.apache.hadoop.hbase中的类
-
- 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.
- regionNormalizerZNode - 类 中的变量org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
- 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
-
- 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
-
- 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,S> - org.apache.hadoop.hbase.client中的类
-
Implementations make a RPC call against a RegionService via a protobuf Service.
- RegionServerCallable(Connection, TableName, byte[], RpcController) - 类 的构造器org.apache.hadoop.hbase.client.RegionServerCallable
-
- RegionServerCallable(Connection, TableName, byte[], RpcController, int) - 类 的构造器org.apache.hadoop.hbase.client.RegionServerCallable
-
- RegionServerCoprocessorRpcChannelImpl - org.apache.hadoop.hbase.client中的类
-
The implementation of a region server based coprocessor rpc channel.
- 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(RegionInfo, RegionState.State, ServerName) - 类 的构造器org.apache.hadoop.hbase.master.RegionState
-
- RegionState(RegionInfo, RegionState.State, long, ServerName) - 类 的构造器org.apache.hadoop.hbase.master.RegionState
-
- RegionState(RegionInfo, RegionState.State, long, ServerName, long) - 类 的构造器org.apache.hadoop.hbase.master.RegionState
-
- RegionState.State - org.apache.hadoop.hbase.master中的枚举
-
- RegionStatistics() - 类 的构造器org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
-
- RegionStats(MetricRegistry, String) - 类 的构造器org.apache.hadoop.hbase.client.MetricsConnection.RegionStats
-
- RegionTooBusyException - org.apache.hadoop.hbase中的异常错误
-
Thrown by a region server if it will block and wait to serve a request.
- RegionTooBusyException(String) - 异常错误 的构造器org.apache.hadoop.hbase.RegionTooBusyException
-
- registerFilter(String, String) - 类 中的静态方法org.apache.hadoop.hbase.filter.ParseFilter
-
Register a new filter with the parser.
- 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.
- remainingTimeNs() - 类 中的方法org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
-
- REMOTE_RPC_CALLS_METRIC_NAME - 类 中的静态变量org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
- REMOTE_RPC_RETRIES_METRIC_NAME - 类 中的静态变量org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
- 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 map
- remove(Bytes) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
Remove metadata represented by the key from the map
- remove(byte[]) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
Remove metadata represented by the key from the 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
-
- 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.
- removeColumnFamily(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Removes the ColumnFamilyDescriptor with name specified by the parameter column
from the table descriptor
- removeColumnFamily(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- removeConfiguration(String) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- removeConfiguration(String) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- removeConfiguration(String) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
Remove a configuration setting represented by the key.
- removeConfiguration(String) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
Remove a config setting represented by the key from the map
- removeCoprocessor(String) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Remove a coprocessor from those set on the table
- removeCoprocessor(String) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- removeCoprocessor(String) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
Remove a coprocessor from those set on the table
- removeElementsWithNullLocation() - 类 中的方法org.apache.hadoop.hbase.RegionLocations
-
Set the element to null if its getServerName method returns null.
- removeExcludeTableCFsFromReplicationPeerConfig(Map<TableName, List<String>>, ReplicationPeerConfig, String) - 类 中的静态方法org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
- removeFamily(byte[]) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
Removes the HColumnDescriptor with name specified by the parameter column
from the table descriptor
- removeMetaData(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.zookeeper.ZKMetadata
-
- removeNamespaceSpaceLimit(String) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Creates a
QuotaSettings
object to remove the FileSystem space quota for the given
namespace.
- removeNonDefaultRegions(Collection<RegionInfo>) - 类 中的静态方法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
-
- removePeerTableCFs(String, String) - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- removePeerTableCFs(String, Map<TableName, ? extends Collection<String>>) - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
已过时。
- 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
- removeReplicationPeer(String) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Remove a peer and stop the replication.
- removeReplicationPeer(String) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Remove a peer and stop the replication
- removeReplicationPeer(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- removeReplicationPeer(RpcController, ReplicationProtos.RemoveReplicationPeerRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- removeReplicationPeerAsync(String) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Remove a replication peer but does not block and wait for it.
- removeReplicationPeerAsync(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- removeReplicationPeerTableCFs(String, Map<TableName, List<String>>) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Remove some table-cfs from config of the specified peer.
- removeReplicationPeerTableCFs(String, Map<TableName, List<String>>) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Remove some table-cfs from config of the specified peer
- removeReplicationPeerTableCFs(String, Map<TableName, List<String>>) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- removeTableCFsFromReplicationPeerConfig(Map<TableName, List<String>>, ReplicationPeerConfig, String) - 类 中的静态方法org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
- removeTableSpaceLimit(TableName) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Creates a
QuotaSettings
object to remove the FileSystem space quota for the given
table.
- removeValue(Bytes) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- removeValue(Bytes) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- removeValue(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- removeValue(Bytes) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- removeValue(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- 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.client.RegionInfo
-
- REPLICA_ID_FORMAT - 接口 中的静态变量org.apache.hadoop.hbase.client.RegionInfo
-
to keep appended int's sorted in string format.
- replicaId - 类 中的变量org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
- replicateAllUserTables() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- REPLICATION_PARENT_QUALIFIER - 类 中的静态变量org.apache.hadoop.hbase.MetaTableAccessor
-
- REPLICATION_SCOPE - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- REPLICATION_SCOPE - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- REPLICATION_SCOPE_BYTES - 接口 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- REPLICATION_SCOPE_BYTES - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- ReplicationAdmin - org.apache.hadoop.hbase.client.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
-
- REPLICATIONGLOBAL - 类 中的静态变量org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
已过时。
- 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
-
- ReplicationPeerConfig - org.apache.hadoop.hbase.replication中的类
-
A configuration for the replication peer cluster.
- ReplicationPeerConfig() - 类 的构造器org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- ReplicationPeerConfigBuilder - org.apache.hadoop.hbase.replication中的接口
-
- ReplicationPeerConfigUtil - org.apache.hadoop.hbase.client.replication中的类
-
Helper for TableCFs Operations.
- ReplicationPeerDescription - org.apache.hadoop.hbase.replication中的类
-
The POJO equivalent of ReplicationProtos.ReplicationPeerDescription
- ReplicationPeerDescription(String, boolean, ReplicationPeerConfig) - 类 的构造器org.apache.hadoop.hbase.replication.ReplicationPeerDescription
-
- ReplicationPeerNotFoundException - org.apache.hadoop.hbase中的异常错误
-
Thrown when a replication peer can not be found
- ReplicationPeerNotFoundException(String) - 异常错误 的构造器org.apache.hadoop.hbase.ReplicationPeerNotFoundException
-
- REPLICATIONTYPE - 类 中的静态变量org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
已过时。
- replicationZNode - 类 中的变量org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
- REQUEST_CONTROLLER_IMPL_CONF_KEY - 类 中的静态变量org.apache.hadoop.hbase.client.RequestControllerFactory
-
- RequestController - org.apache.hadoop.hbase.client中的接口
-
An interface for client request scheduling algorithm.
- RequestController.Checker - org.apache.hadoop.hbase.client中的接口
-
Picks up the valid data.
- RequestController.ReturnCode - org.apache.hadoop.hbase.client中的枚举
-
- RequestControllerFactory - org.apache.hadoop.hbase.client中的类
-
- RequestControllerFactory() - 类 的构造器org.apache.hadoop.hbase.client.RequestControllerFactory
-
- RequestConverter - org.apache.hadoop.hbase.shaded.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.client.ClientCoprocessorRpcController
-
- reset() - 接口 中的方法org.apache.hadoop.hbase.client.RequestController.Checker
-
Reset the state of the scheduler when completing the iteration of rows.
- reset() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
- reset() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- reset() - 类 中的方法org.apache.hadoop.hbase.filter.ColumnValueFilter
-
- 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.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
-
- resetCallTimeout() - 类 中的方法org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
-
- ResponseConverter - org.apache.hadoop.hbase.shaded.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(String) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Restore the specified snapshot on the original table.
- restoreSnapshot(String, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Restore the specified snapshot on the original table.
- restoreSnapshot(String, boolean, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Restore the specified snapshot on the original table.
- restoreSnapshot(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- restoreSnapshot(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- restoreSnapshot(byte[], boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- restoreSnapshot(String, boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- restoreSnapshot(String, boolean, boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- restoreSnapshot(RpcController, MasterProtos.RestoreSnapshotRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- restoreSnapshotAsync(String) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Restore the specified snapshot on the original table.
- restoreSnapshotAsync(String) - 类 中的方法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, SnapshotDescription) - 异常错误 的构造器org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
-
- RestoreSnapshotException(String, Throwable, SnapshotDescription) - 异常错误 的构造器org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
-
- RestoreSnapshotException(String) - 异常错误 的构造器org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
-
- RestoreSnapshotException(String, Throwable) - 异常错误 的构造器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()
.
- 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中的类
-
Statistics update about a server/region
- resume() - 接口 中的方法org.apache.hadoop.hbase.client.AdvancedScanResultConsumer.ScanResumer
-
Resume the scan.
- 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.
- 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.
- ReusablePool(int) - 类 的构造器org.apache.hadoop.hbase.util.PoolMap.ReusablePool
-
- 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(UserPermission) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Revokes user specific permissions
- revoke(UserPermission) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Revokes user specific permissions
- revoke(UserPermission) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- revoke(RpcController, AccessControlProtos.RevokeRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- 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 namespace for the specified user.
- revoke(Connection, String, Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlClient
-
Revoke global permissions for the specified user.
- revoke(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlUtil
-
- revoke(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, TableName, byte[], byte[], Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlUtil
-
- revoke(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, String, Permission.Action...) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlUtil
-
- 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.AsyncAdmin
-
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中的接口
-
Has a row.
- RowAccess<T> - org.apache.hadoop.hbase.client中的接口
-
Provide a way to access the inner buffer.
- 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
-
- RowFilter(CompareOperator, ByteArrayComparable) - 类 的构造器org.apache.hadoop.hbase.filter.RowFilter
-
Constructor.
- RowMutations - org.apache.hadoop.hbase.client中的类
-
Performs multiple mutations atomically on a single row.
- RowMutations(byte[]) - 类 的构造器org.apache.hadoop.hbase.client.RowMutations
-
- RowMutations(byte[], int) - 类 的构造器org.apache.hadoop.hbase.client.RowMutations
-
Create an atomic mutation for the specified row.
- RowRange() - 类 的构造器org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
-
- 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.
- RowRange(byte[], boolean, byte[], boolean) - 类 的构造器org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
-
- 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
-
- rpcCall() - 类 中的方法org.apache.hadoop.hbase.client.RegionServerCallable
-
Run the RPC call.
- rpcCall() - 类 中的方法org.apache.hadoop.hbase.client.ScannerCallable
-
- RpcChannelImplementation(AbstractRpcClient<?>, InetSocketAddress, User, int) - 类 的构造器org.apache.hadoop.hbase.ipc.AbstractRpcClient.RpcChannelImplementation
-
- RpcClient - org.apache.hadoop.hbase.ipc中的接口
-
Interface for RpcClient implementations so ConnectionManager can handle it.
- RpcClientFactory - org.apache.hadoop.hbase.ipc中的类
-
- rpcController - 类 中的变量org.apache.hadoop.hbase.client.RegionServerCallable
-
This is 99% of the time a HBaseRpcController but also used doing Coprocessor Endpoints and in
this case, it is a ServerRpcControllable which is not a HBaseRpcController.
- rpcControllerFactory - 类 中的变量org.apache.hadoop.hbase.client.ClientScanner
-
- rpcControllerFactory - 类 中的变量org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
- rpcControllerFactory - 类 中的变量org.apache.hadoop.hbase.client.ScannerCallable
-
- RpcControllerFactory - org.apache.hadoop.hbase.ipc中的类
-
- RpcControllerFactory(Configuration) - 类 的构造器org.apache.hadoop.hbase.ipc.RpcControllerFactory
-
- rpcHistograms - 类 中的变量org.apache.hadoop.hbase.client.MetricsConnection
-
- RpcRetryingCaller<T> - org.apache.hadoop.hbase.client中的接口
-
- RpcRetryingCallerFactory - org.apache.hadoop.hbase.client中的类
-
- RpcRetryingCallerFactory(Configuration) - 类 的构造器org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
-
- RpcRetryingCallerFactory(Configuration, RetryingCallerInterceptor) - 类 的构造器org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
-
- RpcRetryingCallerImpl<T> - org.apache.hadoop.hbase.client中的类
-
- RpcRetryingCallerImpl(long, long, int, int) - 类 的构造器org.apache.hadoop.hbase.client.RpcRetryingCallerImpl
-
- RpcRetryingCallerImpl(long, long, int, RetryingCallerInterceptor, int, int) - 类 的构造器org.apache.hadoop.hbase.client.RpcRetryingCallerImpl
-
- 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, int) - 类 的构造器org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
-
- RpcThrottlingException - org.apache.hadoop.hbase.quotas中的异常错误
-
Describe the throttling result.
- RpcThrottlingException(String) - 异常错误 的构造器org.apache.hadoop.hbase.quotas.RpcThrottlingException
-
- RpcThrottlingException(RpcThrottlingException.Type, long, String) - 异常错误 的构造器org.apache.hadoop.hbase.quotas.RpcThrottlingException
-
- RpcThrottlingException.Type - org.apache.hadoop.hbase.quotas中的枚举
-
- rpcTimeout(int) - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- rpcTimers - 类 中的变量org.apache.hadoop.hbase.client.MetricsConnection
-
- RSGroupTableAccessor - org.apache.hadoop.hbase中的类
-
Read rs group information from hbase:rsgroup
.
- rsZNode - 类 中的变量org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
- 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(R) - 类 中的方法org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils.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
-
- runCatalogJanitor() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Ask for a scan of the catalog table.
- runCatalogJanitor() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Ask for a scan of the catalog table.
- runCatalogJanitor() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- runCatalogScan() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- runCatalogScan(RpcController, MasterProtos.RunCatalogScanRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- runCleanerChore() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Ask for cleaner chore to run.
- runCleanerChore() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Ask for cleaner chore to run.
- runCleanerChore() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- runCleanerChore(RpcController, MasterProtos.RunCleanerChoreRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- runHbckChore() - 类 中的方法org.apache.hadoop.hbase.client.HBaseHbck
-
- runHbckChore() - 接口 中的方法org.apache.hadoop.hbase.client.Hbck
-
Request HBCK chore to run at master side.
- runnerStats - 类 中的变量org.apache.hadoop.hbase.client.MetricsConnection
-
- RunnerStats(MetricRegistry) - 类 的构造器org.apache.hadoop.hbase.client.MetricsConnection.RunnerStats
-
- running - 类 中的变量org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- 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
- 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(Scan, C) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable
-
The scan API uses the observer pattern.
- 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
-
- Scan(byte[]) - 类 的构造器org.apache.hadoop.hbase.client.Scan
-
- Scan(byte[], byte[]) - 类 的构造器org.apache.hadoop.hbase.client.Scan
-
- 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
-
- scanAll(Scan) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable
-
Return all the results that match the given scan object.
- scanByRegionEncodedName(Connection, String) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
Scans META table for a row whose key contains the specified regionEncodedName,
returning a single related Result
instance if any row is found, null otherwise.
- scanMeta(Connection, MetaTableAccessor.Visitor, TableName, byte[], int) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
Performs a scan of META table for given table starting from given row.
- scanMetaForTableRegions(Connection, MetaTableAccessor.Visitor, TableName) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
- 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
-
- 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
-
- 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
-
- ScanResultConsumer - org.apache.hadoop.hbase.client中的接口
-
Receives
Result
for an asynchronous scan.
- ScanResultConsumerBase - org.apache.hadoop.hbase.client中的接口
-
The base interface for scan result consumer.
- scanTracker - 类 中的变量org.apache.hadoop.hbase.client.MetricsConnection
-
- scheduleServerCrashProcedure(List<HBaseProtos.ServerName>) - 接口 中的方法org.apache.hadoop.hbase.client.Hbck
-
- scheduleServerCrashProcedures(List<ServerName>) - 类 中的方法org.apache.hadoop.hbase.client.HBaseHbck
-
- scheduleServerCrashProcedures(List<ServerName>) - 接口 中的方法org.apache.hadoop.hbase.client.Hbck
-
- scope - 类 中的变量org.apache.hadoop.hbase.security.access.Permission
-
- SCOPE_BY_CODE - 类 中的静态变量org.apache.hadoop.hbase.security.access.Permission
-
- SecureBulkLoadClient - org.apache.hadoop.hbase.client中的类
-
Client proxy for SecureBulkLoadProtocol
- SecureBulkLoadClient(Configuration, Table) - 类 的构造器org.apache.hadoop.hbase.client.SecureBulkLoadClient
-
- secureBulkLoadHFiles(ClientProtos.ClientService.BlockingInterface, List<Pair<byte[], String>>, byte[], boolean, Token<?>, String) - 类 中的方法org.apache.hadoop.hbase.client.SecureBulkLoadClient
-
Securely bulk load a list of HFiles using client protocol.
- secureBulkLoadHFiles(ClientProtos.ClientService.BlockingInterface, List<Pair<byte[], String>>, byte[], boolean, Token<?>, String, boolean) - 类 中的方法org.apache.hadoop.hbase.client.SecureBulkLoadClient
-
Securely bulk load a list of HFiles using client protocol.
- 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中的类
-
- ServerLoad(ClusterStatusProtos.ServerLoad) - 类 的构造器org.apache.hadoop.hbase.ServerLoad
-
已过时。
DONT USE this construction.
- ServerLoad(ServerName, ClusterStatusProtos.ServerLoad) - 类 的构造器org.apache.hadoop.hbase.ServerLoad
-
已过时。
- ServerLoad(ServerMetrics) - 类 的构造器org.apache.hadoop.hbase.ServerLoad
-
已过时。
- serverLoad - 类 中的变量org.apache.hadoop.hbase.ServerLoad
-
已过时。
- ServerMetrics - org.apache.hadoop.hbase中的接口
-
This class is used for exporting current state of load on a RegionServer.
- ServerMetricsBuilder - org.apache.hadoop.hbase中的类
-
- 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中的类
-
- 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
-
- ServiceCaller<S,R> - org.apache.hadoop.hbase.client中的接口
-
Delegate to a protobuf rpc call.
- 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
-
- 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.
- setAsyncPrefetch(boolean) - 类 中的方法org.apache.hadoop.hbase.client.Scan
-
- 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.
- setBackerMasterNames(List<ServerName>) - 类 中的方法org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- setBalancerOn(Boolean) - 类 中的方法org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- setBalancerRunning(boolean, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- setBalancerRunning(RpcController, MasterProtos.SetBalancerRunningRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- setBandwidth(long) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- setBandwidth(long) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Sets the speed, in bytes per second, for any one RegionServer to replicate data to the peer.
- 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.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- setBlockCacheEnabled(boolean) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setBlockCacheEnabled(boolean) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- setBlocksize(int) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- setBlocksize(int) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setBlocksize(int) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- setBloomFilterSize(Size) - 类 中的方法org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setBloomFilterType(BloomType) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- setBloomFilterType(BloomType) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- 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.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- setCacheBloomsOnWrite(boolean) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setCacheBloomsOnWrite(boolean) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- setCacheDataInL1(boolean) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
- setCacheDataOnWrite(boolean) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- setCacheDataOnWrite(boolean) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setCacheDataOnWrite(boolean) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- setCacheIndexesOnWrite(boolean) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- setCacheIndexesOnWrite(boolean) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- 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
-
- 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
-
- setCleanerChoreRunning(RpcController, MasterProtos.SetCleanerChoreRunningRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- 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(String) - 类 中的方法org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- 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
-
- setClusterKey(String) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Set the clusterKey which is the concatenation of the slave cluster's:
hbase.zookeeper.quorum:hbase.zookeeper.property.clientPort:zookeeper.znode.parent
- setColumnFamilies(Collection<ColumnFamilyDescriptor>) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setColumnFamily(ColumnFamilyDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Adds a column family.
- setColumnFamily(ColumnFamilyDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- 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
-
- setCompactedCellCount(long) - 类 中的方法org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setCompactingCellCount(long) - 类 中的方法org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setCompactionCompressionType(Compression.Algorithm) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Compression types supported in hbase.
- setCompactionCompressionType(Compression.Algorithm) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setCompactionCompressionType(Compression.Algorithm) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
Compression types supported in hbase.
- setCompactionEnabled(boolean) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Setting the table compaction enable flag.
- setCompactionEnabled(boolean) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setCompactionEnabled(boolean) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
Setting the table compaction enable flag.
- setCompletedSequenceId(long) - 类 中的方法org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setCompressionType(Compression.Algorithm) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Compression types supported in hbase.
- setCompressionType(Compression.Algorithm) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setCompressionType(Compression.Algorithm) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
Compression types supported in hbase.
- setCompressTags(boolean) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Set whether the tags should be compressed along with DataBlockEncoding.
- setCompressTags(boolean) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- 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.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- setConfiguration(String, String) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setConfiguration(String, String) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
Setter for storing a configuration setting.
- setConfiguration(String, String) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
Setter for storing a configuration setting in 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.ipc.CoprocessorRpcUtils
-
Stores an exception encountered during RPC invocation so it can be passed back
through to the client.
- setControllerException(RpcController, IOException) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
-
Stores an exception encountered during RPC invocation so it can be passed back
through to the client.
- setCoprocessor(String) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Add a table coprocessor to this table.
- setCoprocessor(CoprocessorDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Add a table coprocessor to this table.
- setCoprocessor(String) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setCoprocessor(CoprocessorDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setCoprocessorNames(List<String>) - 类 中的方法org.apache.hadoop.hbase.ServerMetricsBuilder
-
- setCoprocessors(Collection<CoprocessorDescriptor>) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setCoprocessorWithSpec(String) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- setCounter(String, long) - 类 中的方法org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
-
- setDataBlockEncoding(DataBlockEncoding) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Set data block encoding algorithm used in block cache.
- setDataBlockEncoding(DataBlockEncoding) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setDataBlockEncoding(DataBlockEncoding) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
Set data block encoding algorithm used in block cache.
- setDataLocality(float) - 类 中的方法org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setDeadServerNames(List<ServerName>) - 类 中的方法org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- setDFSReplication(short) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Set the replication factor to hfile(s) belonging to this family
- setDFSReplication(short) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- 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.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- setDurability(Durability) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setDurability(Durability) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
- setEncryptionKey(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Set the raw crypto key attribute for the family
- setEncryptionKey(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setEncryptionKey(byte[]) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
Set the raw crypto key attribute for the family
- setEncryptionType(String) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Set the encryption algorithm for use with this family
- setEncryptionType(String) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setEncryptionType(String) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
Set the encryption algorithm for use with this family
- setEndKey(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.RegionInfoBuilder
-
- setEntry(SingleResponse.Entry) - 类 中的方法org.apache.hadoop.hbase.client.SingleResponse
-
- 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.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- setEvictBlocksOnClose(boolean) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setEvictBlocksOnClose(boolean) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- setExcludeNamespaces(Set<String>) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- setExcludeNamespaces(Set<String>) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Sets the collection of namespaces which should not be replicated when all user tables are
configured to be replicated.
- setExcludeTableCFsMap(Map<TableName, ? extends Collection<String>>) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- setExcludeTableCFsMap(Map<TableName, List<String>>) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Sets the mapping of table name to column families which should not be replicated.
- setExists(Boolean) - 类 中的方法org.apache.hadoop.hbase.client.Result
-
- setFailed(String) - 类 中的方法org.apache.hadoop.hbase.client.ClientCoprocessorRpcController
-
- setFailed(Throwable) - 类 中的方法org.apache.hadoop.hbase.client.ClientCoprocessorRpcController
-
- 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
-
- setFamilyCellMap(NavigableMap<byte[], List<Cell>>) - 类 中的方法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
-
- setFilteredReadRequestCount(long) - 类 中的方法org.apache.hadoop.hbase.RegionMetricsBuilder
-
- 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.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
This sets the class associated with the flush policy which determines
determines the stores need to be flushed when flushing a region.
- setFlushPolicyClassName(String) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- 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
-
- setHBaseVersion(String) - 类 中的方法org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- 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
-
- setInfoServerPort(int) - 类 中的方法org.apache.hadoop.hbase.ServerMetricsBuilder
-
- setInMemory(boolean) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- setInMemory(boolean) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setInMemory(boolean) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- setInMemoryCompaction(MemoryCompactionPolicy) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- setInMemoryCompaction(MemoryCompactionPolicy) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setInMemoryCompaction(MemoryCompactionPolicy) - 类 中的方法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
-
- setJarPath(String) - 类 中的方法org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder
-
- setKeepDeletedCells(KeepDeletedCells) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- setKeepDeletedCells(KeepDeletedCells) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setKeepDeletedCells(KeepDeletedCells) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- setLastMajorCompactionTimestamp(long) - 类 中的方法org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setLastReportTimestamp(long) - 类 中的方法org.apache.hadoop.hbase.ServerMetricsBuilder
-
- 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.
- setLiveServerMetrics(Map<ServerName, ServerMetrics>) - 类 中的方法org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- 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
-
- setMasterCoprocessorNames(List<String>) - 类 中的方法org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- setMasterInfoPort(int) - 类 中的方法org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- setMasterName(ServerName) - 类 中的方法org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- setMaxAttempts(int) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdminBuilder
-
Set the max attempt times for an admin operation.
- setMaxAttempts(int) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
-
Set the max attempt times for an operation.
- setMaxAttempts(int) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTableBuilder
-
Set the max attempt times for an operation.
- setMaxFileSize(long) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Sets the maximum size upto which a region can grow to after which a
region split is triggered.
- setMaxFileSize(long) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- 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.
- setMaxHeapSize(Size) - 类 中的方法org.apache.hadoop.hbase.ServerMetricsBuilder
-
- setMaxKeyValueSize(int) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
-
Override the maximum key-value size specified by the provided
AsyncConnection
's
Configuration
instance, via the configuration key
hbase.client.keyvalue.maxsize
.
- 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
- setMaxRetries(int) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdminBuilder
-
Set the max retry times for an admin operation.
- setMaxRetries(int) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
-
Set the max retry times for an operation.
- setMaxRetries(int) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTableBuilder
-
Set the max retry times for an operation.
- setMaxVersions(int) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- setMaxVersions(int) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setMaxVersions() - 类 中的方法org.apache.hadoop.hbase.client.Get
-
- setMaxVersions(int) - 类 中的方法org.apache.hadoop.hbase.client.Get
-
- setMaxVersions() - 类 中的方法org.apache.hadoop.hbase.client.Scan
-
- setMaxVersions(int) - 类 中的方法org.apache.hadoop.hbase.client.Scan
-
- setMaxVersions(int) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- setMemStoreFlushSize(long) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Represents the maximum size of the memstore after which the contents of
the memstore are flushed to the filesystem.
- setMemStoreFlushSize(long) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- 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.
- setMemStoreSize(Size) - 类 中的方法org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setMergeEnabled(boolean) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Setting the table region merge enable flag.
- setMergeEnabled(boolean) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setMergeEnabled(boolean) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
Setting the table region merge enable flag.
- setMinVersions(int) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- setMinVersions(int) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setMinVersions(int) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- setMobCompactPartitionPolicy(MobCompactPartitionPolicy) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Set the mob compact partition policy for the family.
- setMobCompactPartitionPolicy(MobCompactPartitionPolicy) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setMobCompactPartitionPolicy(MobCompactPartitionPolicy) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
Set the mob compact partition policy for the family.
- setMobEnabled(boolean) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Enables the mob for the family.
- setMobEnabled(boolean) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setMobEnabled(boolean) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
Enables the mob for the family.
- setMobThreshold(long) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Sets the mob threshold of the family.
- setMobThreshold(long) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setMobThreshold(long) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
Sets the mob threshold of the family.
- setMvccReadPoint(Scan, long) - 类 中的静态方法org.apache.hadoop.hbase.client.PackagePrivateFieldAccessor
-
- setNamespaceFilter(String) - 类 中的方法org.apache.hadoop.hbase.quotas.QuotaFilter
-
Set the namespace filter regex
- setNamespaces(Set<String>) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- setNamespaces(Set<String>) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Sets a unique collection of HBase namespaces that should be replicated to this peer.
- 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.
- setNeedResults(boolean) - 类 中的方法org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
-
- 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
-
- setNewVersionBehavior(boolean) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- setNewVersionBehavior(boolean) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setNewVersionBehavior(boolean) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- setNonce(long) - 类 中的方法org.apache.hadoop.hbase.client.Action
-
- setNonceGroup(long) - 类 中的方法org.apache.hadoop.hbase.client.MultiAction
-
- setNormalizationEnabled(boolean) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Setting the table normalization enable flag.
- setNormalizationEnabled(boolean) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setNormalizationEnabled(boolean) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
Setting the table normalization enable flag.
- setNormalizerRunning(boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- setNormalizerRunning(RpcController, MasterProtos.SetNormalizerRunningRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- setNormalizerTargetRegionCount(int) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Setting the target region count of table normalization .
- setNormalizerTargetRegionCount(int) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setNormalizerTargetRegionCount(int) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
- setNormalizerTargetRegionSize(long) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Setting the target region size of table normalization.
- setNormalizerTargetRegionSize(long) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setNormalizerTargetRegionSize(long) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
- setNumActionsPerServer(int) - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection.CallStats
-
- setOffline(boolean) - 类 中的方法org.apache.hadoop.hbase.client.ImmutableHRegionInfo
-
已过时。
- setOffline(boolean) - 类 中的方法org.apache.hadoop.hbase.client.RegionInfoBuilder
-
- 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(long, TimeUnit) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdminBuilder
-
Set timeout for a whole admin operation.
- setOperationTimeout(long, TimeUnit) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
-
Set timeout for the background flush operation.
- setOperationTimeout(int) - 类 中的方法org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
-
- setOperationTimeout(long, TimeUnit) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTableBuilder
-
Set timeout for a whole operation such as get, put or delete.
- setOperationTimeout(int) - 接口 中的方法org.apache.hadoop.hbase.client.BufferedMutator
-
Set operation timeout for this mutator instance
- setOperationTimeout(int) - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- setOperationTimeout(int) - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
已过时。
- setOperationTimeout(int) - 接口 中的方法org.apache.hadoop.hbase.client.Table
-
- setOperationTimeout(int) - 接口 中的方法org.apache.hadoop.hbase.client.TableBuilder
-
Set timeout for a whole operation such as get, put or delete.
- setOwner(User) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- setOwner(User) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setOwner(User) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
- setOwnerString(String) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- setOwnerString(String) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setOwnerString(String) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
- setPeerTableCFs(String, Map<TableName, ? extends Collection<String>>) - 类 中的方法org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
已过时。
- setPool(ExecutorService) - 类 中的方法org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
-
- setPrefetchBlocksOnOpen(boolean) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- setPrefetchBlocksOnOpen(boolean) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setPrefetchBlocksOnOpen(boolean) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- setPriority(int) - 类 中的方法org.apache.hadoop.hbase.client.Append
-
- setPriority(int) - 类 中的方法org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder
-
- 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.Put
-
- setPriority(int) - 类 中的方法org.apache.hadoop.hbase.client.Scan
-
- setPriority(int) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- setPriority(int) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- 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
-
- setProcessed(boolean) - 类 中的方法org.apache.hadoop.hbase.client.SingleResponse.Entry
-
- setProperties(Map<String, String>) - 类 中的方法org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder
-
- setProperty(String, String) - 类 中的方法org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder
-
- setQuota(QuotaSettings) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Apply the new quota settings.
- setQuota(QuotaSettings) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Apply the new quota settings.
- setQuota(QuotaSettings) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- setQuota(RpcController, MasterProtos.SetQuotaRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- setRaw(boolean) - 类 中的方法org.apache.hadoop.hbase.client.Scan
-
Enable/disable "raw" mode for this scan.
- setReadOnly(boolean) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Setting the table as read only sets all the columns in the table as read
only.
- setReadOnly(boolean) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setReadOnly(boolean) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
Setting the table as read only sets all the columns in the table as read
only.
- setReadRequestCount(long) - 类 中的方法org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setReadRpcTimeout(long, TimeUnit) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTableBuilder
-
Set timeout for each read(get, scan) rpc request.
- setReadRpcTimeout(int) - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
已过时。
- setReadRpcTimeout(int) - 接口 中的方法org.apache.hadoop.hbase.client.Table
-
- setReadRpcTimeout(int) - 接口 中的方法org.apache.hadoop.hbase.client.TableBuilder
-
Set timeout for each read(get, scan) rpc request.
- setReadType(Scan.ReadType) - 类 中的方法org.apache.hadoop.hbase.client.Scan
-
Set the read type for this scan.
- setRegionId(long) - 类 中的方法org.apache.hadoop.hbase.client.RegionInfoBuilder
-
- setRegionMemStoreReplication(boolean) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Enable or Disable the memstore replication from the primary region to the
replicas.
- setRegionMemStoreReplication(boolean) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setRegionMemstoreReplication(boolean) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
- setRegionMemStoreReplication(boolean) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
Enable or Disable the memstore replication from the primary region to the replicas.
- setRegionMetrics(List<RegionMetrics>) - 类 中的方法org.apache.hadoop.hbase.ServerMetricsBuilder
-
- setRegionReplication(int) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Sets the number of replicas per region.
- setRegionReplication(int) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setRegionReplication(int) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
Sets the number of replicas per region.
- setRegionServerFilter(String) - 类 中的方法org.apache.hadoop.hbase.quotas.QuotaFilter
-
Set the region server filter regex
- setRegionsInTransition(List<RegionState>) - 类 中的方法org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- setRegionSplitPolicyClassName(String) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
This sets the class associated with the region split policy which
determines when a region split should occur.
- setRegionSplitPolicyClassName(String) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- 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.RegionInfoBuilder
-
- setReplicaId(int) - 类 中的方法org.apache.hadoop.hbase.client.Scan
-
- setReplicateAllUserTables(boolean) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- setReplicateAllUserTables(boolean) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Configures HBase to replicate all user tables (not system tables) to the peer.
- setReplicationEndpointImpl(String) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- setReplicationEndpointImpl(String) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Sets the ReplicationEndpoint plugin class for this peer.
- setReplicationLoadSink(ReplicationLoadSink) - 类 中的方法org.apache.hadoop.hbase.ServerMetricsBuilder
-
- setReplicationLoadSources(List<ReplicationLoadSource>) - 类 中的方法org.apache.hadoop.hbase.ServerMetricsBuilder
-
- setReplicationScope(int) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Sets replication scope all & only the columns already in the builder.
- setReportTimestamp(long) - 类 中的方法org.apache.hadoop.hbase.ServerMetricsBuilder
-
- setRequestCount(long) - 类 中的方法org.apache.hadoop.hbase.ServerMetricsBuilder
-
- setRequestCountPerSecond(long) - 类 中的方法org.apache.hadoop.hbase.ServerMetricsBuilder
-
- setRequestSizeBytes(long) - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection.CallStats
-
- setResponseSizeBytes(long) - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection.CallStats
-
- setResult(Result) - 类 中的方法org.apache.hadoop.hbase.client.SingleResponse.Entry
-
- setRetryPause(long, TimeUnit) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdminBuilder
-
Set the base pause time for retrying.
- setRetryPause(long, TimeUnit) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
-
Set the base pause time for retrying.
- setRetryPause(long, TimeUnit) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTableBuilder
-
Set the base pause time for retrying.
- setRetryPauseForCQTBE(long, TimeUnit) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdminBuilder
-
Set the base pause time for retrying when we hit CallQueueTooBigException
.
- setRetryPauseForCQTBE(long, TimeUnit) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTableBuilder
-
Set the base pause time for retrying when we hit CallQueueTooBigException
.
- 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
-
- setRowAccess(List<? extends Row>) - 类 中的方法org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
-
- setRowAccess(RowAccess<? extends Row>) - 类 中的方法org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
-
- 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.
- setRpcControllerCellScanner(CellScanner) - 类 中的方法org.apache.hadoop.hbase.client.RegionServerCallable
-
- setRpcTimeout(long, TimeUnit) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdminBuilder
-
Set timeout for each rpc request.
- setRpcTimeout(long, TimeUnit) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
-
Set timeout for each rpc request when doing background flush.
- setRpcTimeout(int) - 类 中的方法org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
-
- setRpcTimeout(long, TimeUnit) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTableBuilder
-
Set timeout for each rpc request.
- setRpcTimeout(int) - 接口 中的方法org.apache.hadoop.hbase.client.BufferedMutator
-
Set rpc timeout for this mutator instance
- setRpcTimeout(int) - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- setRpcTimeout(int) - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
已过时。
- setRpcTimeout(int) - 接口 中的方法org.apache.hadoop.hbase.client.Table
-
- setRpcTimeout(int) - 接口 中的方法org.apache.hadoop.hbase.client.TableBuilder
-
Set timeout for each rpc request.
- setRunner(Runnable) - 类 中的方法org.apache.hadoop.hbase.client.DelayingRunner
-
- setScanMetricsEnabled(boolean) - 类 中的方法org.apache.hadoop.hbase.client.Scan
-
- setScanTimeout(long, TimeUnit) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTableBuilder
-
As now we have heartbeat support for scan, ideally a scan will never timeout unless the RS is
crash.
- setScope(int) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- setScope(int) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setScope(int) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- setSerial(boolean) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Sets whether we should preserve order when replicating, i.e, serial replication.
- setServerNames(List<ServerName>) - 类 中的方法org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- setServerSideHConnectionRetriesConfig(Configuration, String, Logger) - 类 中的静态方法org.apache.hadoop.hbase.client.ConnectionUtils
-
Changes the configuration to set the number of retries needed when using Connection internally,
e.g. for updating catalog tables, etc.
- setSmall(boolean) - 类 中的方法org.apache.hadoop.hbase.client.Scan
-
- setSplit(boolean) - 类 中的方法org.apache.hadoop.hbase.client.ImmutableHRegionInfo
-
已过时。
- setSplit(boolean) - 类 中的方法org.apache.hadoop.hbase.client.RegionInfoBuilder
-
- setSplit(boolean) - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
-
已过时。
- setSplitEnabled(boolean) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Setting the table region split enable flag.
- setSplitEnabled(boolean) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setSplitEnabled(boolean) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
Setting the table region split enable flag.
- setSplitOrMergeEnabled(boolean, boolean, MasterSwitchType...) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- setSplitOrMergeEnabled(RpcController, MasterProtos.SetSplitOrMergeEnabledRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- setStartKey(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.RegionInfoBuilder
-
- setStartLogErrorsCnt(int) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdminBuilder
-
Set the number of retries that are allowed before we start to log.
- setStartLogErrorsCnt(int) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
-
Set the number of retries that are allowed before we start to log.
- setStartLogErrorsCnt(int) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTableBuilder
-
Set the number of retries that are allowed before we start to log.
- setStartRow(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.Scan
-
- setStartTime(long) - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection.CallStats
-
- setStatistics(RegionLoadStats) - 类 中的方法org.apache.hadoop.hbase.client.Result
-
Set load information about the region to the information about the 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
-
- setStoragePolicy(String) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Set the storage policy for use with this family
- setStoragePolicy(String) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setStoragePolicy(String) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
Set the storage policy for use with this family
- setStoreCount(int) - 类 中的方法org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setStoreFileCount(int) - 类 中的方法org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setStoreFileIndexSize(Size) - 类 中的方法org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setStoreFileRootLevelIndexSize(Size) - 类 中的方法org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setStoreFileSize(Size) - 类 中的方法org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setStoreFileUncompressedDataIndexSize(Size) - 类 中的方法org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setStoreSequenceIds(Map<byte[], Long>) - 类 中的方法org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setStub(AdminProtos.AdminService.BlockingInterface) - 类 中的方法org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
- setStub(S) - 类 中的方法org.apache.hadoop.hbase.client.RegionServerCallable
-
- setStubByServiceName(ServerName) - 类 中的方法org.apache.hadoop.hbase.client.ClientServiceCallable
-
- setStubByServiceName(ServerName) - 类 中的方法org.apache.hadoop.hbase.client.RegionServerCallable
-
Set the RCP client stub
- setSubmittedRows(AsyncProcessTask.SubmittedRows) - 类 中的方法org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
-
- setTableCFsMap(Map<TableName, ? extends Collection<String>>) - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- setTableCFsMap(Map<TableName, List<String>>) - 接口 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Sets an explicit map of tables and column families in those tables that should be replicated
to the given peer.
- setTableFilter(String) - 类 中的方法org.apache.hadoop.hbase.quotas.QuotaFilter
-
Set the table filter regex
- setTableName(TableName) - 类 中的方法org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
-
- setTableStateInMeta(TableState) - 类 中的方法org.apache.hadoop.hbase.client.HBaseHbck
-
- setTableStateInMeta(TableState) - 接口 中的方法org.apache.hadoop.hbase.client.Hbck
-
Update table state in Meta only.
- setTimeRange(long, long) - 类 中的方法org.apache.hadoop.hbase.client.Append
-
Sets the TimeRange to be used on the Get for this append.
- 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.Append
-
- setTimestamp(long) - 类 中的方法org.apache.hadoop.hbase.client.Delete
-
- setTimeStamp(long) - 类 中的方法org.apache.hadoop.hbase.client.Get
-
- setTimestamp(long) - 类 中的方法org.apache.hadoop.hbase.client.Get
-
Get versions of columns with the specified timestamp.
- setTimestamp(long) - 类 中的方法org.apache.hadoop.hbase.client.Increment
-
- setTimestamp(long) - 类 中的方法org.apache.hadoop.hbase.client.Mutation
-
Set the timestamp of the delete.
- setTimestamp(long) - 类 中的方法org.apache.hadoop.hbase.client.Put
-
- setTimeStamp(long) - 类 中的方法org.apache.hadoop.hbase.client.Scan
-
- setTimestamp(long) - 类 中的方法org.apache.hadoop.hbase.client.Scan
-
Get versions of columns with the specified timestamp.
- setTimeToLive(int) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- setTimeToLive(String) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- setTimeToLive(int) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setTimeToLive(String) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setTimeToLive(int) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- setTimeToLive(String) - 类 中的方法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
-
- setUncompressedStoreFileSize(Size) - 类 中的方法org.apache.hadoop.hbase.RegionMetricsBuilder
-
- 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
-
Called by toSetQuotaRequestProto()
the subclass should implement this method to set the specific SetQuotaRequest
properties.
- setupSetQuotaRequest(MasterProtos.SetQuotaRequest.Builder) - 类 中的方法org.apache.hadoop.hbase.quotas.ThrottleSettings
-
- setUsedHeapSize(Size) - 类 中的方法org.apache.hadoop.hbase.ServerMetricsBuilder
-
- setUserFilter(String) - 类 中的方法org.apache.hadoop.hbase.quotas.QuotaFilter
-
Set the user filter regex
- setValue(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- setValue(String, String) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- setValue(Bytes, Bytes) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setValue(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setValue(String, String) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setValue(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- setValue(String, String) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- setValue(Bytes, Bytes) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- setValue(String, String) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setValue(Bytes, Bytes) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setValue(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- 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 map
- setValue(Bytes, Bytes) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
- setValue(String, String) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
Setter for storing metadata as a (key, value) pair in map
- setVersion(String) - 类 中的方法org.apache.hadoop.hbase.ServerMetricsBuilder
-
- setVersionNumber(int) - 类 中的方法org.apache.hadoop.hbase.ServerMetricsBuilder
-
- setVersions(int, int) - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Set minimum and maximum versions to keep
- setVersions(int, int) - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
Set minimum and maximum versions to keep
- setWriteBufferPeriodicFlush(long, TimeUnit) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
-
Set the periodical flush interval.
- setWriteBufferPeriodicFlush(long) - 接口 中的方法org.apache.hadoop.hbase.client.BufferedMutator
-
Sets the maximum time before the buffer is automatically flushed checking once per second.
- setWriteBufferPeriodicFlush(long, long) - 接口 中的方法org.apache.hadoop.hbase.client.BufferedMutator
-
Sets the maximum time before the buffer is automatically flushed.
- setWriteBufferPeriodicFlush(long, long) - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- setWriteBufferPeriodicFlushTimeoutMs(long) - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorParams
-
Set the max timeout before the buffer is automatically flushed.
- setWriteBufferPeriodicFlushTimerTickMs(long) - 类 中的方法org.apache.hadoop.hbase.client.BufferedMutatorParams
-
Set the TimerTick how often the buffer timeout if checked.
- setWriteBufferSize(long) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
-
Override the write buffer size specified by the provided
AsyncConnection
's
Configuration
instance, via the configuration key
hbase.client.write.buffer
.
- setWriteRequestCount(long) - 类 中的方法org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setWriteRpcTimeout(long, TimeUnit) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTableBuilder
-
Set timeout for each write(put, delete) rpc request.
- setWriteRpcTimeout(int) - 类 中的方法org.apache.hadoop.hbase.client.HTable
-
已过时。
- setWriteRpcTimeout(int) - 接口 中的方法org.apache.hadoop.hbase.client.Table
-
- setWriteRpcTimeout(int) - 接口 中的方法org.apache.hadoop.hbase.client.TableBuilder
-
Set timeout for each write(put, delete) rpc request.
- ShadedAccessControlUtil - org.apache.hadoop.hbase.security.access中的类
-
Convert protobuf objects in AccessControl.proto under hbase-protocol-shaded to user-oriented
objects and vice versa.
- ShadedAccessControlUtil() - 类 的构造器org.apache.hadoop.hbase.security.access.ShadedAccessControlUtil
-
- ShortCircuitMasterConnection - org.apache.hadoop.hbase.client中的类
-
A short-circuit connection that can bypass the RPC layer (serialization, deserialization,
networking, etc..) when talking to a local master
- ShortCircuitMasterConnection(MasterProtos.MasterService.BlockingInterface) - 类 的构造器org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- shutdown() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Shuts down the HBase cluster.
- shutdown() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Shuts down the HBase cluster.
- shutdown() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- shutdown() - 类 中的方法org.apache.hadoop.hbase.client.MetricsConnection
-
- shutdown(RpcController, MasterProtos.ShutdownRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- 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
-
已过时。
- SingleColumnValueExcludeFilter(byte[], byte[], CompareOperator, 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
-
- SingleColumnValueExcludeFilter(byte[], byte[], CompareOperator, 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
-
- SingleColumnValueExcludeFilter(byte[], byte[], CompareOperator, 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
-
- SingleColumnValueFilter(byte[], byte[], CompareOperator, 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
-
- SingleColumnValueFilter(byte[], byte[], CompareOperator, 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
-
- SingleColumnValueFilter(byte[], byte[], CompareOperator, ByteArrayComparable, boolean, boolean) - 类 的构造器org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Constructor for protobuf deserialization only.
- SingleResponse - org.apache.hadoop.hbase.client中的类
-
Class for single action response
- SingleResponse() - 类 的构造器org.apache.hadoop.hbase.client.SingleResponse
-
- SingleResponse.Entry - org.apache.hadoop.hbase.client中的类
-
- 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.client.RowAccess
-
- 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中的类
-
It is used to represent the size with different units.
- Size(double, Size.Unit) - 类 的构造器org.apache.hadoop.hbase.Size
-
- size() - 接口 中的方法org.apache.hadoop.hbase.util.PoolMap.Pool
-
- size() - 类 中的方法org.apache.hadoop.hbase.util.PoolMap
-
- size(K) - 类 中的方法org.apache.hadoop.hbase.util.PoolMap
-
- Size.Unit - org.apache.hadoop.hbase中的枚举
-
- 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.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
-
Create a timestamp consistent snapshot for the given table.
- snapshot(String, TableName, SnapshotType) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Create typed snapshot of the table.
- snapshot(SnapshotDescription) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Take a snapshot and wait for the server to complete that snapshot (blocking).
- snapshot(String, TableName) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Take a snapshot for the given table.
- snapshot(String, TableName, SnapshotType) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Create typed snapshot of the table.
- snapshot(SnapshotDescription) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Take a snapshot and wait for the server to complete that snapshot asynchronously.
- snapshot(String, TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- snapshot(byte[], TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- snapshot(String, TableName, SnapshotType) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- snapshot(SnapshotDescription) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- snapshot(RpcController, MasterProtos.SnapshotRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- snapshotAsync(SnapshotDescription) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
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.
- snapshotAsync(SnapshotDescription) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- 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, SnapshotDescription) - 异常错误 的构造器org.apache.hadoop.hbase.snapshot.SnapshotCreationException
-
Failure to create the specified snapshot.
- SnapshotCreationException(String, Throwable, SnapshotDescription) - 异常错误 的构造器org.apache.hadoop.hbase.snapshot.SnapshotCreationException
-
Failure to create the specified snapshot due to an external cause.
- SnapshotDescription - org.apache.hadoop.hbase.client中的类
-
The POJO equivalent of HBaseProtos.SnapshotDescription
- SnapshotDescription(String) - 类 的构造器org.apache.hadoop.hbase.client.SnapshotDescription
-
- SnapshotDescription(String, String) - 类 的构造器org.apache.hadoop.hbase.client.SnapshotDescription
-
- SnapshotDescription(String, TableName) - 类 的构造器org.apache.hadoop.hbase.client.SnapshotDescription
-
- SnapshotDescription(String, String, SnapshotType) - 类 的构造器org.apache.hadoop.hbase.client.SnapshotDescription
-
- SnapshotDescription(String, TableName, SnapshotType) - 类 的构造器org.apache.hadoop.hbase.client.SnapshotDescription
-
- SnapshotDescription(String, String, SnapshotType, String) - 类 的构造器org.apache.hadoop.hbase.client.SnapshotDescription
-
- SnapshotDescription(String, TableName, SnapshotType, String) - 类 的构造器org.apache.hadoop.hbase.client.SnapshotDescription
-
- SnapshotDescription(String, String, SnapshotType, String, long, int) - 类 的构造器org.apache.hadoop.hbase.client.SnapshotDescription
-
- SnapshotDescription(String, TableName, SnapshotType, String, long, int) - 类 的构造器org.apache.hadoop.hbase.client.SnapshotDescription
-
- 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(SnapshotDescription) - 异常错误 的构造器org.apache.hadoop.hbase.snapshot.SnapshotDoesNotExistException
-
- 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, SnapshotDescription) - 异常错误 的构造器org.apache.hadoop.hbase.snapshot.SnapshotExistsException
-
Failure due to the snapshot already existing.
- SnapshotType - org.apache.hadoop.hbase.client中的枚举
-
POJO representing the snapshot type
- 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
-
- SpaceQuotaSnapshot - org.apache.hadoop.hbase.quotas中的类
-
A point-in-time view of a space quota on a table.
- SpaceQuotaSnapshot(SpaceQuotaSnapshot.SpaceQuotaStatus, long, long) - 类 的构造器org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
-
- SpaceQuotaSnapshot.SpaceQuotaStatus - org.apache.hadoop.hbase.quotas中的类
-
Encapsulates the state of a quota on a table.
- SpaceQuotaSnapshotView - org.apache.hadoop.hbase.quotas中的接口
-
A point-in-time view of a space quota on a table, read only.
- SpaceQuotaSnapshotView.SpaceQuotaStatusView - org.apache.hadoop.hbase.quotas中的接口
-
Encapsulates the state of a quota on a table.
- SpaceQuotaStatus(SpaceViolationPolicy) - 类 的构造器org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot.SpaceQuotaStatus
-
Constructs a SpaceQuotaSnapshot
which is in violation of the provided policy
.
- SpaceViolationPolicy - org.apache.hadoop.hbase.quotas中的枚举
-
Enumeration that represents the action HBase will take when a space quota is violated.
- 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.AsyncAdmin
-
Split a table.
- split(TableName, byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Split a table.
- split(TableName) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- split(TableName, byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- SPLIT_ENABLED - 类 中的静态变量org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Used by HBase Shell interface to access this metadata
attribute which denotes if the table is split enabled.
- SPLIT_ENABLED - 类 中的静态变量org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
- SPLIT_POLICY - 类 中的静态变量org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- 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.ZNodePaths
-
- splitRegion(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- splitRegion(byte[], byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- splitRegion(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Split an individual region.
- splitRegion(byte[], byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Split an individual region.
- splitRegion(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- splitRegion(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- splitRegion(RpcController, MasterProtos.SplitTableRegionRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- splitRegion(Connection, RegionInfo, long, RegionInfo, RegionInfo, ServerName, int) - 类 中的静态方法org.apache.hadoop.hbase.MetaTableAccessor
-
Splits the region into two in an atomic operation.
- splitRegionAsync(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Split an individual region.
- splitRegionAsync(byte[], byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Split an individual region.
- splitRegionAsync(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- splitRegionAsync(byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- splitRegionSync(byte[], byte[]) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
Split one region.
- splitRegionSync(byte[], byte[], long, TimeUnit) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
Split one region.
- splitSwitch(boolean, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Turn the split switch on or off.
- splitSwitch(boolean) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Turn the Split switch on or off.
- splitSwitch(boolean, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Turn the Split switch on or off.
- splitSwitch(boolean, boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- stampSet - 类 中的变量org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- start(CoprocessorEnvironment) - 接口 中的方法org.apache.hadoop.hbase.Coprocessor
-
- startCancel() - 类 中的方法org.apache.hadoop.hbase.client.ClientCoprocessorRpcController
-
- startCancel() - 类 中的方法org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
-
- startCancel() - 类 中的方法org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
-
- startCancel() - 类 中的方法org.apache.hadoop.hbase.ipc.ServerRpcController
-
- 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.
- stop(CoprocessorEnvironment) - 接口 中的方法org.apache.hadoop.hbase.Coprocessor
-
- stopMaster() - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Shuts down the current HBase master only.
- stopMaster() - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Shuts down the current HBase master only.
- stopMaster() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- stopMaster(RpcController, MasterProtos.StopMasterRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- 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(ServerName) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Stop the designated regionserver.
- stopRegionServer(String) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- STORAGE_POLICY - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- STORAGE_POLICY - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- stub - 类 中的变量org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
- stub - 类 中的变量org.apache.hadoop.hbase.client.RegionServerCallable
-
- 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() - 类 中的方法org.apache.hadoop.hbase.CacheEvictionStatsAggregator
-
- sumOfMillisSecBetweenNexts - 类 中的变量org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
sum of milliseconds between sequential next calls
- suspend() - 接口 中的方法org.apache.hadoop.hbase.client.AdvancedScanResultConsumer.ScanController
-
Suspend the scan.
- SWITCH_TO_SIMPLE_AUTH - 类 中的静态变量org.apache.hadoop.hbase.security.SaslUtil
-
- switchExceedThrottleQuota(RpcController, MasterProtos.SwitchExceedThrottleQuotaRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- switchRpcThrottle(boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Switch the rpc throttle enable state.
- switchRpcThrottle(boolean) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
Switch the rpc throttle enabled state.
- switchRpcThrottle(boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- switchRpcThrottle(RpcController, MasterProtos.SwitchRpcThrottleRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- switchZNode - 类 中的变量org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
- 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.CheckAndMutateBuilder - org.apache.hadoop.hbase.client中的接口
-
A helper class for sending checkAndMutate request.
- 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
-
已过时。
- TableBuilder - org.apache.hadoop.hbase.client中的接口
-
For creating
Table
instance.
- TableCFs - org.apache.hadoop.hbase.client.replication中的类
-
- TableCFs(TableName, Map<String, Integer>) - 类 的构造器org.apache.hadoop.hbase.client.replication.TableCFs
-
- TableDescriptor - org.apache.hadoop.hbase.client中的接口
-
TableDescriptor contains the details about an HBase table such as the descriptors of
all the column families, is the table a catalog table, 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...
- TableDescriptorBuilder - org.apache.hadoop.hbase.client中的类
-
- TableDescriptorBuilder.ModifyableTableDescriptor - org.apache.hadoop.hbase.client中的类
-
TODO: make this private after removing the HTableDescriptor
- TableDescriptorUtils - org.apache.hadoop.hbase.client中的类
-
- TableDescriptorUtils.TableDescriptorDelta - org.apache.hadoop.hbase.client中的类
-
- tableExists(AsyncTable<?>, TableName) - 类 中的静态方法org.apache.hadoop.hbase.AsyncMetaTableAccessor
-
- tableExists(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- tableExists(TableName) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncAdmin
-
- tableExists(TableName) - 类 中的方法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
-
Check if fields of table in table permission equals.
- TableFuture(HBaseAdmin, TableName, Long) - 类 的构造器org.apache.hadoop.hbase.client.HBaseAdmin.TableFuture
-
- 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.ZNodePaths
-
- tableName - 类 中的变量org.apache.hadoop.hbase.client.ClientScanner
-
- tableName - 类 中的变量org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
- 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.
- TableState - org.apache.hadoop.hbase.client中的类
-
Represents table state.
- TableState(TableName, TableState.State) - 类 的构造器org.apache.hadoop.hbase.client.TableState
-
Create instance of TableState.
- TableState.State - org.apache.hadoop.hbase.client中的枚举
-
- TableVisitorBase(TableName) - 类 的构造器org.apache.hadoop.hbase.MetaTableAccessor.TableVisitorBase
-
- TableWaitForStateCallable() - 类 的构造器org.apache.hadoop.hbase.client.HBaseAdmin.TableFuture.TableWaitForStateCallable
-
- tableZNode - 类 中的变量org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
已过时。
- take() - 类 中的方法org.apache.hadoop.hbase.client.ResultBoundedCompletionService
-
- takeSnapshotAsync(SnapshotDescription) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
- targetReplicaId - 类 中的变量org.apache.hadoop.hbase.client.Query
-
- tcpKeepAlive - 类 中的变量org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- tcpNoDelay - 类 中的变量org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- terminate() - 接口 中的方法org.apache.hadoop.hbase.client.AdvancedScanResultConsumer.ScanController
-
Terminate the scan.
- thenDelete(Delete) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateBuilder
-
- thenDelete(Delete) - 接口 中的方法org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder
-
- thenMutate(RowMutations) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateBuilder
-
- thenMutate(RowMutations) - 接口 中的方法org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder
-
- thenPut(Put) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateBuilder
-
- thenPut(Put) - 接口 中的方法org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder
-
- throttleNamespace(String, ThrottleType, long, TimeUnit) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Throttle the specified namespace.
- throttleNamespace(String, ThrottleType, long, TimeUnit, QuotaScope) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Throttle the specified namespace.
- throttleRegionServer(String, ThrottleType, long, TimeUnit) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Throttle the specified region server.
- ThrottleSettings - org.apache.hadoop.hbase.quotas中的类
-
- throttleTable(TableName, ThrottleType, long, TimeUnit) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Throttle the specified table.
- throttleTable(TableName, ThrottleType, long, TimeUnit, QuotaScope) - 类 中的静态方法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, ThrottleType, long, TimeUnit, QuotaScope) - 类 中的静态方法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, TableName, ThrottleType, long, TimeUnit, QuotaScope) - 类 中的静态方法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.
- throttleUser(String, String, ThrottleType, long, TimeUnit, QuotaScope) - 类 中的静态方法org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Throttle the specified user on the specified namespace.
- ThrottlingException - org.apache.hadoop.hbase.quotas中的异常错误
-
- 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.RegionAdminServiceCallable
-
- throwable(Throwable, boolean) - 类 中的方法org.apache.hadoop.hbase.client.RegionServerCallable
-
- throwable(Throwable, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.RetryingCallable
-
Called when call 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.).
- ThrowableWithExtraContext(Throwable, long, String) - 类 的构造器org.apache.hadoop.hbase.client.RetriesExhaustedException.ThrowableWithExtraContext
-
- throwInterruptedException() - 接口 中的方法org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture.WaitForStateCallable
-
- throwInterruptedException() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin.TableFuture.TableWaitForStateCallable
-
- throwNumReadRequestsExceeded(long) - 异常错误 中的静态方法org.apache.hadoop.hbase.quotas.RpcThrottlingException
-
- throwNumReadRequestsExceeded(long) - 异常错误 中的静态方法org.apache.hadoop.hbase.quotas.ThrottlingException
-
已过时。
- throwNumRequestsExceeded(long) - 异常错误 中的静态方法org.apache.hadoop.hbase.quotas.RpcThrottlingException
-
- throwNumRequestsExceeded(long) - 异常错误 中的静态方法org.apache.hadoop.hbase.quotas.ThrottlingException
-
已过时。
- throwNumWriteRequestsExceeded(long) - 异常错误 中的静态方法org.apache.hadoop.hbase.quotas.RpcThrottlingException
-
- throwNumWriteRequestsExceeded(long) - 异常错误 中的静态方法org.apache.hadoop.hbase.quotas.ThrottlingException
-
已过时。
- throwReadCapacityUnitExceeded(long) - 异常错误 中的静态方法org.apache.hadoop.hbase.quotas.RpcThrottlingException
-
- throwReadSizeExceeded(long) - 异常错误 中的静态方法org.apache.hadoop.hbase.quotas.RpcThrottlingException
-
- throwReadSizeExceeded(long) - 异常错误 中的静态方法org.apache.hadoop.hbase.quotas.ThrottlingException
-
已过时。
- throwRequestCapacityUnitExceeded(long) - 异常错误 中的静态方法org.apache.hadoop.hbase.quotas.RpcThrottlingException
-
- throwRequestSizeExceeded(long) - 异常错误 中的静态方法org.apache.hadoop.hbase.quotas.RpcThrottlingException
-
- throwRequestSizeExceeded(long) - 异常错误 中的静态方法org.apache.hadoop.hbase.quotas.ThrottlingException
-
已过时。
- throwTimeoutException(long) - 接口 中的方法org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture.WaitForStateCallable
-
- throwTimeoutException(long) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin.TableFuture.TableWaitForStateCallable
-
- throwWriteCapacityUnitExceeded(long) - 异常错误 中的静态方法org.apache.hadoop.hbase.quotas.RpcThrottlingException
-
- throwWriteSizeExceeded(long) - 异常错误 中的静态方法org.apache.hadoop.hbase.quotas.RpcThrottlingException
-
- throwWriteSizeExceeded(long) - 异常错误 中的静态方法org.apache.hadoop.hbase.quotas.ThrottlingException
-
已过时。
- timeBeforeReplicas - 类 中的变量org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
-
- timeRange(TimeRange) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateBuilder
-
- timeRange(TimeRange) - 接口 中的方法org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder
-
- 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
- toAppend(ClientProtos.MutationProto, CellScanner) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer Mutate to an Append
- toAssignRegionsRequest(List<String>, boolean) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
- toAuthorizations(ClientProtos.Authorizations) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer Authorizations to a client Authorizations
- toAuthorizations(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer Authorizations bytes to a client Authorizations
- toAuthorizations(Authorizations) - 类 中的静态方法org.apache.hadoop.hbase.shaded.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.shaded.protobuf.ProtobufUtil
-
Generates a marker for the WAL so that we propagate the notion of a bulk region load
throughout the WAL.
- toByte() - 枚举 中的方法org.apache.hadoop.hbase.client.IsolationLevel
-
- toByteArray(ColumnFamilyDescriptor) - 类 中的静态方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- toByteArray(RegionInfo) - 接口 中的静态方法org.apache.hadoop.hbase.client.RegionInfo
-
- toByteArray(ReplicationPeerConfig) - 类 中的静态方法org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
- toByteArray(TableDescriptor) - 类 中的静态方法org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- toByteArray() - 类 中的方法org.apache.hadoop.hbase.ClusterId
-
- toByteArray() - 类 中的方法org.apache.hadoop.hbase.filter.BigDecimalComparator
-
- 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.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.ColumnValueFilter
-
- 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.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
-
已过时。
- toByteArrayComparable(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toBytes() - 枚举 中的方法org.apache.hadoop.hbase.client.IsolationLevel
-
- toBytes() - 类 中的方法org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- toBytes(ByteString) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toCacheEvictionStats(HBaseProtos.CacheEvictionStats) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toCacheEvictionStats(CacheEvictionStats) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toCell(Cell) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- toCell(ExtendedCellBuilder, CellProtos.Cell) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- toCell(Cell) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toCell(ExtendedCellBuilder, CellProtos.Cell) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toCellVisibility(ClientProtos.CellVisibility) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer CellVisibility to a client CellVisibility
- toCellVisibility(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer CellVisibility bytes to a client CellVisibility
- toCellVisibility(CellVisibility) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Create a protocol buffer CellVisibility based on a client CellVisibility.
- toClusterMetrics(ClusterStatusProtos.ClusterStatus) - 类 中的静态方法org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- toClusterStatus(ClusterMetrics) - 类 中的静态方法org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- toColumnFamilyDescriptor(HBaseProtos.ColumnFamilySchema) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Converts a ColumnFamilySchema to ColumnFamilyDescriptor
- toColumnFamilySchema(ColumnFamilyDescriptor) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Converts an ColumnFamilyDescriptor to ColumnFamilySchema
- toCompactedStoreFiles(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toCompactionDescriptor(RegionInfo, byte[], List<Path>, List<Path>, Path) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toCompactionDescriptor(RegionInfo, byte[], byte[], List<Path>, List<Path>, Path) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toCompactionEventTrackerBytes(Set<String>) - 类 中的静态方法org.apache.hadoop.hbase.shaded.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
- toComparator(ByteArrayComparable) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a ByteArrayComparable to a protocol buffer Comparator
- toComparator(ComparatorProtos.Comparator) - 类 中的静态方法org.apache.hadoop.hbase.shaded.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
-
- toConsistency(ClientProtos.Consistency) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toConsistency(Consistency) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toCoprocessor(Collection<String>) - 类 中的静态方法org.apache.hadoop.hbase.ServerMetricsBuilder
-
- toCursor(Cursor) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toCursor(Cell) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toCursor(ClientProtos.Cursor) - 类 中的静态方法org.apache.hadoop.hbase.shaded.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
- toDelete(ClientProtos.MutationProto) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer Mutate to a Delete
- toDelete(ClientProtos.MutationProto, CellScanner) - 类 中的静态方法org.apache.hadoop.hbase.shaded.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.
- toDeleteType(KeyValue.Type) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a delete KeyValue type to protocol buffer DeleteType.
- toDelimitedByteArray(RegionInfo...) - 接口 中的静态方法org.apache.hadoop.hbase.client.RegionInfo
-
Serializes given RegionInfo's as a byte array.
- toDelimitedByteArray(RegionInfo) - 接口 中的静态方法org.apache.hadoop.hbase.client.RegionInfo
-
Use this instead of
RegionInfo.toByteArray(RegionInfo)
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() - 类 中的方法org.apache.hadoop.hbase.HRegionInfo
-
- toDelimitedByteArray(HRegionInfo...) - 类 中的静态方法org.apache.hadoop.hbase.HRegionInfo
-
- toDelimitedByteArray(Message) - 类 中的静态方法org.apache.hadoop.hbase.shaded.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
- toDurability(ClientProtos.MutationProto.Durability) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protobuf Durability into a client Durability
- toDurability(Durability) - 类 中的静态方法org.apache.hadoop.hbase.shaded.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
- toException(HBaseProtos.NameBytesPair) - 类 中的静态方法org.apache.hadoop.hbase.shaded.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
- toFilter(FilterProtos.Filter) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer Filter to a client Filter
- toFilter(Filter) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a client Filter to a protocol buffer Filter
- toFlushDescriptor(WALProtos.FlushDescriptor.FlushAction, RegionInfo, long, Map<byte[], List<Path>>) - 类 中的静态方法org.apache.hadoop.hbase.shaded.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.
- toGet(ClientProtos.Get) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer Get to a client Get
- toGet(ClientProtos.MutationProto, CellScanner) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer Mutate to a Get.
- toGet(Get) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Create a protocol buffer Get based on a client Get.
- toGroupInfo(RSGroupProtos.RSGroupInfo) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- toHColumnDescriptor(ColumnFamilyDescriptor) - 类 中的方法org.apache.hadoop.hbase.client.ImmutableHTableDescriptor
-
已过时。
- toHColumnDescriptor(ColumnFamilyDescriptor) - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
Return a HColumnDescriptor for user to keep the compatibility as much as possible.
- toIncrement(ClientProtos.MutationProto, CellScanner) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a protocol buffer Mutate to an Increment
- toIncrement(ClientProtos.MutationProto, CellScanner) - 类 中的静态方法org.apache.hadoop.hbase.shaded.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.
- toIOException(ServiceException) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Unwraps an exception from a protobuf service into the underlying (expected) IOException.
- toJavaObject(MessageOrBuilder) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufMessageConverter
-
- 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.
- toJsonElement(MessageOrBuilder) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufMessageConverter
-
- toJsonElement(MessageOrBuilder, boolean) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufMessageConverter
-
- toJsonString(MessageOrBuilder) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufMessageConverter
-
- TOKEN_HANDLERS - 类 中的静态变量org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- toLockJson(List<LockServiceProtos.LockedResource>) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- 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(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
-
- toMutation(ClientProtos.MutationProto) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a MutateRequest to Mutation
- toMutation(ClientProtos.MutationProto.MutationType, Mutation) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toMutation(ClientProtos.MutationProto.MutationType, Mutation, long) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Create a protocol buffer Mutate based on a client Mutation
- toMutation(ClientProtos.MutationProto.MutationType, Mutation, ClientProtos.MutationProto.Builder) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toMutation(ClientProtos.MutationProto.MutationType, Mutation, ClientProtos.MutationProto.Builder, long) - 类 中的静态方法org.apache.hadoop.hbase.shaded.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
-
- toMutationNoData(ClientProtos.MutationProto.MutationType, Mutation, ClientProtos.MutationProto.Builder) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Create a protocol buffer MutationProto based on a client Mutation.
- toMutationNoData(ClientProtos.MutationProto.MutationType, Mutation) - 类 中的静态方法org.apache.hadoop.hbase.shaded.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.shaded.protobuf.ProtobufUtil
-
- toNamespaceDescriptor(HBaseProtos.NamespaceDescriptor) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toNamespaceDescriptorList(MasterProtos.ListNamespaceDescriptorsResponse) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Get a list of NamespaceDescriptor from ListNamespaceDescriptorsResponse protobuf
- toOption(ClusterStatusProtos.Option) - 类 中的静态方法org.apache.hadoop.hbase.ClusterMetricsBuilder
-
Convert ClusterStatusProtos.Option to ClusterMetrics.Option
- toOption(ClusterMetrics.Option) - 类 中的静态方法org.apache.hadoop.hbase.ClusterMetricsBuilder
-
Convert ClusterMetrics.Option to ClusterStatusProtos.Option
- toOptionalTimestamp(MasterProtos.MajorCompactionTimestampResponse) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toOptions(List<ClusterStatusProtos.Option>) - 类 中的静态方法org.apache.hadoop.hbase.ClusterMetricsBuilder
-
Convert a list of ClusterStatusProtos.Option to an enum set of ClusterMetrics.Option
- toOptions(EnumSet<ClusterMetrics.Option>) - 类 中的静态方法org.apache.hadoop.hbase.ClusterMetricsBuilder
-
Convert an enum set of ClusterMetrics.Option to a list of ClusterStatusProtos.Option
- toPermission(AccessControlProtos.Permission) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlUtil
-
Converts a Permission proto to a client Permission object.
- toPermission(Permission) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlUtil
-
Convert a client Permission to a Permission proto
- toPermission(AccessControlProtos.UsersAndPermissions) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlUtil
-
Convert a protobuf UserTablePermissions to a ListMultimap<Username, Permission>
- toPermission(AccessControlProtos.Permission) - 类 中的静态方法org.apache.hadoop.hbase.security.access.ShadedAccessControlUtil
-
Converts a Permission shaded proto to a client TablePermission object.
- toPermission(Permission) - 类 中的静态方法org.apache.hadoop.hbase.security.access.ShadedAccessControlUtil
-
Convert a client Permission to a Permission shaded proto
- toPermissionAction(AccessControlProtos.Permission.Action) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlUtil
-
Converts a Permission.Action proto to a client Permission.Action object.
- toPermissionAction(Permission.Action) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlUtil
-
Convert a client Permission.Action to a Permission.Action proto
- toPermissionAction(Permission.Action) - 类 中的静态方法org.apache.hadoop.hbase.security.access.ShadedAccessControlUtil
-
Convert a client user permission to a user permission shaded proto.
- toPermissionAction(AccessControlProtos.Permission.Action) - 类 中的静态方法org.apache.hadoop.hbase.security.access.ShadedAccessControlUtil
-
Convert a Permission.Action shaded proto to a client Permission.Action object.
- toPermissionActions(List<AccessControlProtos.Permission.Action>) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlUtil
-
Converts a list of Permission.Action proto to an array of client Permission.Action objects.
- toPermissionActions(List<AccessControlProtos.Permission.Action>) - 类 中的静态方法org.apache.hadoop.hbase.security.access.ShadedAccessControlUtil
-
Converts a list of Permission.Action shaded proto to an array of client Permission.Action
objects.
- toProcedureJson(List<ProcedureProtos.Procedure>) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Helper to convert the protobuf Procedure to JSON String
- toProto(SpaceQuotaSnapshot.SpaceQuotaStatus) - 类 中的静态方法org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot.SpaceQuotaStatus
-
- toProtoNamespaceDescriptor(NamespaceDescriptor) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toProtoQuotaScope(QuotaScope) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a client QuotaScope to a protocol buffer QuotaScope
- toProtoQuotaScope(QuotaType) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a client QuotaType to a protocol buffer QuotaType
- toProtoReplicationPeerDescription(ReplicationPeerDescription) - 类 中的静态方法org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
- toProtoSnapshot(SpaceQuotaSnapshot) - 类 中的静态方法org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
-
- toProtoSpaceQuota(long, SpaceViolationPolicy) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Builds a protocol buffer SpaceQuota.
- toProtoTableName(TableName) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- toProtoTableName(TableName) - 类 中的静态方法org.apache.hadoop.hbase.security.access.ShadedAccessControlUtil
-
- toProtoTableName(TableName) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toProtoThrottleType(ThrottleType) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a client ThrottleType to a protocol buffer ThrottleType
- toProtoTimeUnit(TimeUnit) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a client TimeUnit to a protocol buffer TimeUnit
- toProtoViolationPolicy(SpaceViolationPolicy) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Converts a client SpaceViolationPolicy to a protocol buffer SpaceViolationPolicy.
- 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.
- toPut(ClientProtos.MutationProto) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer Mutate to a Put.
- toPut(ClientProtos.MutationProto, CellScanner) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer Mutate to a Put.
- toQuotaScope(QuotaProtos.QuotaScope) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer QuotaScope to a client QuotaScope
- toQuotaScope(QuotaProtos.QuotaType) - 类 中的静态方法org.apache.hadoop.hbase.shaded.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
-
- toReadType(Scan.ReadType) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toReadType(ClientProtos.Scan.ReadType) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toRegionEventDescriptor(WALProtos.RegionEventDescriptor.EventType, RegionInfo, long, ServerName, Map<byte[], List<Path>>) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toRegionEventDescriptor(WALProtos.RegionEventDescriptor.EventType, byte[], byte[], byte[], long, ServerName, Map<byte[], List<Path>>) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toRegionInfo(RegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a RegionInfo to a Proto RegionInfo
- toRegionInfo(HBaseProtos.RegionInfo) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert HBaseProto.RegionInfo to a RegionInfo
- toRegionLoad(RegionMetrics) - 类 中的静态方法org.apache.hadoop.hbase.RegionMetricsBuilder
-
- toRegionLocation(HRegionLocation) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toRegionLocation(HBaseProtos.RegionLocation) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toRegionMetrics(AdminProtos.GetRegionLoadResponse) - 类 中的静态方法org.apache.hadoop.hbase.RegionMetricsBuilder
-
- toRegionMetrics(ClusterStatusProtos.RegionLoad) - 类 中的静态方法org.apache.hadoop.hbase.RegionMetricsBuilder
-
- toReplicationLoadSink(ClusterStatusProtos.ReplicationLoadSink) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toReplicationLoadSink(ReplicationLoadSink) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toReplicationLoadSource(ClusterStatusProtos.ReplicationLoadSource) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toReplicationLoadSource(ReplicationLoadSource) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toReplicationPeerDescription(ReplicationProtos.ReplicationPeerDescription) - 类 中的静态方法org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
- 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
- toResult(Result) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a client Result to a protocol buffer Result
- toResult(boolean, boolean) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a client Result to a protocol buffer Result
- toResult(ClientProtos.Result) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer Result to a client Result
- toResult(ClientProtos.Result, CellScanner) - 类 中的静态方法org.apache.hadoop.hbase.shaded.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.
- toResultNoData(Result) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a client Result to a protocol buffer Result.
- toRow(byte[]) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable.CoprocessorServiceBuilder
-
- toRow(byte[], boolean) - 接口 中的方法org.apache.hadoop.hbase.client.AsyncTable.CoprocessorServiceBuilder
-
- 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
- toScan(Scan) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a client Scan to a protocol buffer Scan
- toScan(ClientProtos.Scan) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer Scan to a client Scan
- toScanMetrics(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- toScanMetrics(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toScanMetrics(ScanMetrics, boolean) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toScheduleServerCrashProcedureRequest(List<ServerName>) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
- toSecurityCapabilityList(List<MasterProtos.SecurityCapabilitiesResponse.Capability>) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert SecurityCapabilitiesResponse.Capability to SecurityCapability
- toServerLoad(ServerMetrics) - 类 中的静态方法org.apache.hadoop.hbase.ServerMetricsBuilder
-
- toServerMetrics(ClusterStatusProtos.LiveServerInfo) - 类 中的静态方法org.apache.hadoop.hbase.ServerMetricsBuilder
-
- toServerMetrics(ServerName, ClusterStatusProtos.ServerLoad) - 类 中的静态方法org.apache.hadoop.hbase.ServerMetricsBuilder
-
- toServerMetrics(ServerName, int, String, ClusterStatusProtos.ServerLoad) - 类 中的静态方法org.apache.hadoop.hbase.ServerMetricsBuilder
-
- 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
- toServerName(byte[]) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Get a ServerName from the passed in data bytes.
- toServerName(ServerName) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a ServerName to a protocol buffer ServerName
- toServerName(HBaseProtos.ServerName) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer ServerName to a ServerName
- toServerNameList(List<HBaseProtos.ServerName>) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a list of protocol buffer ServerName to a list of ServerName
- toSnapshotDescriptionList(MasterProtos.GetCompletedSnapshotsResponse, Pattern) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toSpaceQuotaSnapshot(QuotaProtos.SpaceQuotaSnapshot) - 类 中的静态方法org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
-
- toStatus(QuotaProtos.SpaceQuotaStatus) - 类 中的静态方法org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot.SpaceQuotaStatus
-
- toString() - 类 中的方法org.apache.hadoop.hbase.CacheEvictionStats
-
- toString() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- toString() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin.NamespaceFuture
-
- toString() - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin.TableFuture
-
- 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.replication.TableCFs
-
- toString() - 类 中的方法org.apache.hadoop.hbase.client.Result
-
- toString() - 类 中的方法org.apache.hadoop.hbase.client.RetriesExhaustedException.ThrowableWithExtraContext
-
- toString() - 类 中的方法org.apache.hadoop.hbase.client.RpcRetryingCallerImpl
-
- toString() - 类 中的方法org.apache.hadoop.hbase.client.SnapshotDescription
-
- toString() - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- toString() - 类 中的方法org.apache.hadoop.hbase.client.TableState
-
- 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.ColumnValueFilter
-
- 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() - 类 中的方法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.master.RegionState
-
- toString() - 类 中的方法org.apache.hadoop.hbase.MetaTableAccessor.ReplicationBarrierResult
-
- toString() - 类 中的方法org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot.SpaceQuotaStatus
-
- toString() - 类 中的方法org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
-
- toString() - 类 中的方法org.apache.hadoop.hbase.quotas.ThrottleSettings
-
- toString() - 类 中的方法org.apache.hadoop.hbase.RegionLoad
-
已过时。
- toString() - 类 中的方法org.apache.hadoop.hbase.RegionLocations
-
- toString() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- toString() - 类 中的方法org.apache.hadoop.hbase.replication.ReplicationPeerDescription
-
- toString() - 类 中的方法org.apache.hadoop.hbase.security.access.GlobalPermission
-
- toString() - 类 中的方法org.apache.hadoop.hbase.security.access.NamespacePermission
-
- 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.Size
-
- toString(SnapshotProtos.SnapshotDescription) - 类 中的静态方法org.apache.hadoop.hbase.snapshot.ClientSnapshotDescriptionUtils
-
Returns a single line (no \n) representation of snapshot metadata.
- toString() - 类 中的方法org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
- toStringCustomizedValues() - 接口 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- toStringCustomizedValues() - 类 中的方法org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- toStringCustomizedValues() - 接口 中的方法org.apache.hadoop.hbase.client.TableDescriptor
-
- toStringCustomizedValues() - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- toStringCustomizedValues() - 类 中的方法org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- toStringCustomizedValues() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
- toStringTableAttributes() - 类 中的方法org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- toStringTableAttributes() - 类 中的方法org.apache.hadoop.hbase.HTableDescriptor
-
已过时。
- toTableDescriptor(HBaseProtos.TableSchema) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Converts a TableSchema to TableDescriptor
- toTableDescriptorList(MasterProtos.GetTableDescriptorsResponse) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Get a list of TableDescriptor from GetTableDescriptorsResponse protobuf
- toTableDescriptorList(MasterProtos.ListTableDescriptorsByNamespaceResponse) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Get a list of TableDescriptor from ListTableDescriptorsByNamespaceResponse protobuf
- toTableName(TableProtos.TableName) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- toTableName(HBaseProtos.TableName) - 类 中的静态方法org.apache.hadoop.hbase.security.access.ShadedAccessControlUtil
-
- toTableName(HBaseProtos.TableName) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toTableNameList(List<HBaseProtos.TableName>) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toTablePermission(AccessControlProtos.TablePermission) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlUtil
-
Converts a TablePermission proto to a client TablePermission object.
- toTableSchema(TableDescriptor) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Converts an TableDescriptor to TableSchema
- toText(Message) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toThrottleType(QuotaProtos.ThrottleType) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer ThrottleType to a client ThrottleType
- toTimedQuota(long, TimeUnit, QuotaScope) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Build a protocol buffer TimedQuota
- toTimeRange(TimeRange) - 类 中的静态方法org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- toTimeRange(HBaseProtos.TimeRange) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toTimeRange(TimeRange) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
- toTimeUnit(HBaseProtos.TimeUnit) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer TimeUnit to a client TimeUnit
- toUnassignRegionsRequest(List<String>, boolean) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
-
- toUserPermission(UserPermission) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlUtil
-
Convert a client user permission to a user permission proto
- toUserPermission(AccessControlProtos.UserPermission) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlUtil
-
Converts a user permission proto to a client user permission object.
- toUserPermission(AccessControlProtos.UsersAndPermissions) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlUtil
-
Convert a protobuf UserTablePermissions to a ListMultimap<Username, UserPermission>
- toUserPermission(AccessControlProtos.UserPermission) - 类 中的静态方法org.apache.hadoop.hbase.security.access.ShadedAccessControlUtil
-
Converts a user permission proto to a client user permission object.
- toUserPermission(UserPermission) - 类 中的静态方法org.apache.hadoop.hbase.security.access.ShadedAccessControlUtil
-
Convert a client user permission to a user permission proto
- toUsersAndPermissions(String, Permission) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlUtil
-
- toUsersAndPermissions(ListMultimap<String, Permission>) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlUtil
-
- toUsersAndPermissions(AccessControlProtos.UsersAndPermissions) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlUtil
-
- toUserTablePermissions(ListMultimap<String, UserPermission>) - 类 中的静态方法org.apache.hadoop.hbase.security.access.AccessControlUtil
-
Convert a ListMultimap<String, TablePermission> where key is username
to a protobuf UserPermission
- toUserTablePermissions(AccessControlProtos.UsersAndPermissions) - 类 中的静态方法org.apache.hadoop.hbase.security.access.ShadedAccessControlUtil
-
Convert a shaded protobuf UserTablePermissions to a ListMultimap<String, TablePermission>
where key is username.
- toUserTablePermissions(ListMultimap<String, UserPermission>) - 类 中的静态方法org.apache.hadoop.hbase.security.access.ShadedAccessControlUtil
-
Convert a ListMultimap<String, TablePermission> where key is username to a shaded
protobuf UserPermission
- toViolationPolicy(QuotaProtos.SpaceViolationPolicy) - 类 中的静态方法org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Converts a protocol buffer SpaceViolationPolicy to a client SpaceViolationPolicy.
- 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.KeyOnlyFilter
-
- transformCell(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.SkipFilter
-
- transformCell(Cell) - 类 中的方法org.apache.hadoop.hbase.filter.WhileMatchFilter
-
- 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.AsyncAdmin
-
Truncate a table.
- truncateTable(TableName, boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- truncateTable(RpcController, MasterProtos.TruncateTableRequest) - 类 中的方法org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- truncateTableAsync(TableName, boolean) - 接口 中的方法org.apache.hadoop.hbase.client.Admin
-
Truncate the table but does not block and wait for it to be completely enabled.
- truncateTableAsync(TableName, boolean) - 类 中的方法org.apache.hadoop.hbase.client.HBaseAdmin
-
- ts - 类 中的变量org.apache.hadoop.hbase.client.Mutation
-
- TTL - 类 中的静态变量org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- TTL - 类 中的静态变量org.apache.hadoop.hbase.HColumnDescriptor
-
已过时。
- type() - 类 中的方法org.apache.hadoop.hbase.client.MultiResponse
-
- type() - 类 中的方法org.apache.hadoop.hbase.client.SingleResponse
-