- A - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'A'
- abort(String, Throwable) - Method in interface org.apache.hadoop.hbase.Abortable
-
Abort the server or client.
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
-
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- Abortable - Interface in org.apache.hadoop.hbase
-
Interface to support the aborting of a given server or client.
- abortable - Variable in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
-
- abortable - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
-
Used to abort if a fatal error occurs
- abortable - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- AbstractClientScanner - Class in org.apache.hadoop.hbase.client
-
Helper class for custom client scanners.
- AbstractClientScanner() - Constructor for class org.apache.hadoop.hbase.client.AbstractClientScanner
-
- AccessControlClient - Class in org.apache.hadoop.hbase.security.access
-
Utility client for doing access control admin operations.
- AccessControlClient() - Constructor for class org.apache.hadoop.hbase.security.access.AccessControlClient
-
- AccessControlConstants - Interface in org.apache.hadoop.hbase.security.access
-
- AccessDeniedException - Exception in org.apache.hadoop.hbase.security
-
Exception thrown by access-related methods.
- AccessDeniedException() - Constructor for exception org.apache.hadoop.hbase.security.AccessDeniedException
-
- AccessDeniedException(Class<?>, String) - Constructor for exception org.apache.hadoop.hbase.security.AccessDeniedException
-
- AccessDeniedException(String) - Constructor for exception org.apache.hadoop.hbase.security.AccessDeniedException
-
- AccessDeniedException(Throwable) - Constructor for exception org.apache.hadoop.hbase.security.AccessDeniedException
-
- ACL_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
- Action<R> - Class in org.apache.hadoop.hbase.client
-
A Get, Put, Increment, Append, or Delete associated with it's region.
- Action(Row, int) - Constructor for class org.apache.hadoop.hbase.client.Action
-
- ACTION_BY_CODE - Static variable in class org.apache.hadoop.hbase.security.access.Permission
-
- actions - Variable in class org.apache.hadoop.hbase.client.MultiAction
-
- actions - Variable in class org.apache.hadoop.hbase.security.access.Permission
-
- add(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Append
-
Add the specified column and value to this Append operation.
- add(Cell) - Method in class org.apache.hadoop.hbase.client.Append
-
Add column and value to this Append operation.
- add(BigDecimal, BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- add(Double, Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- add(Long, Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- add(Map.Entry<byte[], List<Action<T>>>) - Method in class org.apache.hadoop.hbase.client.DelayingRunner
-
- add(Cell) - Method in class org.apache.hadoop.hbase.client.Increment
-
Add the specified KeyValue to this operation.
- add(byte[], Action<R>) - Method in class org.apache.hadoop.hbase.client.MultiAction
-
Add an Action to this container based on it's regionName.
- add(byte[], List<Action<R>>) - Method in class org.apache.hadoop.hbase.client.MultiAction
-
Add an list of Actions to this container based on it's regionName.
- add(byte[], Pair<Integer, Object>) - Method in class org.apache.hadoop.hbase.client.MultiResponse
-
Add the pair to the container, grouped by the regionName
- add(byte[], int, Object) - Method in class org.apache.hadoop.hbase.client.MultiResponse
-
- add(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
-
Add the specified column and value to this Put operation.
- add(byte[], byte[], long, byte[]) - Method in class org.apache.hadoop.hbase.client.Put
-
Add the specified column and value, with the specified timestamp as
its version to this Put operation.
- add(byte[], ByteBuffer, long, ByteBuffer) - Method in class org.apache.hadoop.hbase.client.Put
-
Add the specified column and value, with the specified timestamp as
its version to this Put operation.
- add(Cell) - Method in class org.apache.hadoop.hbase.client.Put
-
Add the specified KeyValue to this Put operation.
- add(Put) - Method in class org.apache.hadoop.hbase.client.RowMutations
-
Add a
Put
operation to the list of mutations
- add(Delete) - Method in class org.apache.hadoop.hbase.client.RowMutations
-
Add a
Delete
operation to the list of mutations
- add(S, S) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
- addCall(RpcClient.Call) - Method in class org.apache.hadoop.hbase.ipc.RpcClient.Connection
-
Add a call to this connection's call queue and notify
a listener; synchronized.
- addColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Get
-
Get the column from the specific family with the specified qualifier.
- addColumn(byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Add a column to an existing table.
- addColumn(String, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Add a column to an existing table.
- addColumn(TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Add a column to an existing table.
- addColumn(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Increment
-
Increment the column from the specific family with the specified qualifier
by the specified amount.
- addColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
-
Get the column from the specified family with the specified qualifier.
- addCoprocessor(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Add a table coprocessor to this table.
- addCoprocessor(String, Path, int, Map<String, String>) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Add a table coprocessor to this table.
- addDeleteMarker(Cell) - Method in class org.apache.hadoop.hbase.client.Delete
-
Advanced use only.
- addException(byte[], Throwable) - Method in class org.apache.hadoop.hbase.client.MultiResponse
-
- addFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.Get
-
Get all columns from the specified family.
- addFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
-
Get all columns from the specified family.
- addFamily(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
-
Does NOT add a column family.
- addFamily(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Adds a column family.
- addFilter(Filter) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
Add a filter.
- addImmutable(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
-
- addImmutable(byte[], byte[], byte[], Tag[]) - Method in class org.apache.hadoop.hbase.client.Put
-
This expects that the underlying arrays won't change.
- addImmutable(byte[], byte[], long, byte[]) - Method in class org.apache.hadoop.hbase.client.Put
-
- addImmutable(byte[], byte[], long, byte[], Tag[]) - Method in class org.apache.hadoop.hbase.client.Put
-
This expects that the underlying arrays won't change.
- addImmutable(byte[], ByteBuffer, long, ByteBuffer, Tag[]) - Method in class org.apache.hadoop.hbase.client.Put
-
This expects that the underlying arrays won't change.
- addImmutable(byte[], ByteBuffer, long, ByteBuffer) - Method in class org.apache.hadoop.hbase.client.Put
-
- addInfo(String, SecurityInfo) - Static method in class org.apache.hadoop.hbase.security.SecurityInfo
-
Adds a security configuration for a new service name.
- addJitter(long, float) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
Adds / subs a 10% jitter to a pause time.
- addLabel(Configuration, String) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
-
Utility method for adding label to the system.
- addLabels(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
-
Utility method for adding labels to the system.
- addLog(String, String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
-
Add a new HLog file to the given queue.
- addLog(String, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
-
- addPeer(String, String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Deprecated.
Use addPeer(String, ReplicationPeerConfig, Map) instead.
- addPeer(String, String, String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Deprecated.
- addPeer(String, ReplicationPeerConfig, Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Add a new remote slave cluster for replication.
- addPeer(String, ReplicationPeerConfig, String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
-
Add a new remote slave cluster for replication.
- addPeer(String, ReplicationPeerConfig, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
-
- addResults(ClientProtos.RegionLoadStats) - Method in class org.apache.hadoop.hbase.client.Result
-
Add load information about the region to the information about the result
- addTokenForJob(HConnection, JobConf, User) - Static method in class org.apache.hadoop.hbase.security.token.TokenUtil
-
Checks for an authentication token for the given user, obtaining a new token if necessary,
and adds it to the credentials for the given map reduce job.
- addTokenForJob(HConnection, User, Job) - Static method in class org.apache.hadoop.hbase.security.token.TokenUtil
-
Checks for an authentication token for the given user, obtaining a new token if necessary,
and adds it to the credentials for the given map reduce job.
- addTokenIfMissing(HConnection, User) - Static method in class org.apache.hadoop.hbase.security.token.TokenUtil
-
Checks if an authentication tokens exists for the connected cluster,
obtaining one if needed and adding it to the user's credentials.
- advance() - Method in class org.apache.hadoop.hbase.client.Result
-
- AggregationClient - Class in org.apache.hadoop.hbase.client.coprocessor
-
This client class is for invoking the aggregate functions deployed on the
Region Server side via the AggregateService.
- AggregationClient(Configuration) - Constructor for class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
-
Constructor with Conf object
- allActions() - Method in class org.apache.hadoop.hbase.client.MultiAction
-
- allTableRegions(Configuration, HConnection, TableName, boolean) - Static method in class org.apache.hadoop.hbase.client.MetaScanner
-
Lists all of the table regions currently in META.
- AND - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
AND Byte Array
- AND_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
AND Array
- AND_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
- AND_OPERATOR - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
-
- ap - Variable in class org.apache.hadoop.hbase.client.HTable
-
The Async process for puts with autoflush set to false or multiputs
- Append - Class in org.apache.hadoop.hbase.client
-
Performs Append operations on a single row.
- Append(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Append
-
Create a Append operation for the specified row.
- Append(Append) - Constructor for class org.apache.hadoop.hbase.client.Append
-
Copy constructor
- Append(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.client.Append
-
Create a Append operation for the specified row.
- append(Append) - Method in class org.apache.hadoop.hbase.client.HTable
-
Appends values to one or more columns within a single row.
- append(Append) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Appends values to one or more columns within a single row.
- applyClusterKeyToConf(Configuration, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Apply the settings in the given key to the given configuration, this is
used to communicate with distant clusters
- areAdjacent(HRegionInfo, HRegionInfo) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Check whether two regions are adjacent
- assertSnapshotRequestIsValid(HBaseProtos.SnapshotDescription) - Static method in class org.apache.hadoop.hbase.snapshot.ClientSnapshotDescriptionUtils
-
Check to make sure that the description of the snapshot requested is valid
- assign(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- assignmentZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- asyncCreate(ZooKeeperWatcher, String, byte[], AsyncCallback.StringCallback, Object) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Async creates the specified node with the specified data.
- asyncCreateNodeOffline(ZooKeeperWatcher, HRegionInfo, ServerName, AsyncCallback.StringCallback, Object) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Creates an unassigned node in the OFFLINE state for the specified region.
- Attributes - Interface in org.apache.hadoop.hbase.client
-
- AUTH_TOKEN_TYPE - Static variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- authenticationMethod - Variable in enum org.apache.hadoop.hbase.security.AuthMethod
-
- AuthenticationTokenIdentifier - Class in org.apache.hadoop.hbase.security.token
-
Represents the identity information stored in an HBase authentication token.
- AuthenticationTokenIdentifier() - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- AuthenticationTokenIdentifier(String) - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- AuthenticationTokenIdentifier(String, int, long, long) - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- AuthenticationTokenSelector - Class in org.apache.hadoop.hbase.security.token
-
- AuthenticationTokenSelector() - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationTokenSelector
-
- AuthMethod - Enum in org.apache.hadoop.hbase.security
-
Authentication method
- Authorizations - Class in 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...) - Constructor for class org.apache.hadoop.hbase.security.visibility.Authorizations
-
- Authorizations(List<String>) - Constructor for class org.apache.hadoop.hbase.security.visibility.Authorizations
-
- avg(TableName, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
-
This is the client side interface/handle for calling the average method for
a given cf-cq combination.
- avg(HTable, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
-
This is the client side interface/handle for calling the average method for
a given cf-cq combination.
- BACKOFF_POLICY_CLASS - Static variable in interface org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicy
-
- BACKSLASH - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for Backslash
- backupMasterAddressesZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- BadAuthException - Exception in org.apache.hadoop.hbase.ipc
-
- BadAuthException() - Constructor for exception org.apache.hadoop.hbase.ipc.BadAuthException
-
- BadAuthException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.BadAuthException
-
- BadAuthException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.ipc.BadAuthException
-
- balancer() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Invoke the balancer.
- balancerZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- baseZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- Batch - Class in org.apache.hadoop.hbase.client.coprocessor
-
A collection of interfaces and utilities used for interacting with custom RPC
interfaces exposed by Coprocessors.
- Batch() - Constructor for class org.apache.hadoop.hbase.client.coprocessor.Batch
-
- batch(List<? extends Row>, Object[]) - Method in class org.apache.hadoop.hbase.client.HTable
-
Method that does a batch call on Deletes, Gets, Puts, Increments, Appends and RowMutations.
- batch(List<? extends Row>) - Method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
If any exception is thrown by one of the actions, there is no way to
retrieve the partially executed results. Use HTable.batch(List, Object[])
instead.
- batch(List<? extends Row>, Object[]) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Method that does a batch call on Deletes, Gets, Puts, Increments, Appends and RowMutations.
- batch(List<? extends Row>) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
- Batch.Call<T,R> - Interface in org.apache.hadoop.hbase.client.coprocessor
-
Defines a unit of work to be executed.
- Batch.Callback<R> - Interface in org.apache.hadoop.hbase.client.coprocessor
-
- batchCallback(List<? extends Row>, Object[], Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTable
-
- batchCallback(List<? extends Row>, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTable
-
- batchCallback(List<? extends Row>, Object[], Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
- batchCallback(List<? extends Row>, Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
- batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R) - Method in class org.apache.hadoop.hbase.client.HTable
-
Creates an instance of the given
Service
subclass for each table
region spanning the range from the
startKey
row to
endKey
row (inclusive), all
the invocations to the same region server will be batched into one call.
- batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTable
-
Creates an instance of the given
Service
subclass for each table
region spanning the range from the
startKey
row to
endKey
row (inclusive), all
the invocations to the same region server will be batched into one call.
- batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
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>) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
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.
- BigDecimalColumnInterpreter - Class in org.apache.hadoop.hbase.client.coprocessor
-
ColumnInterpreter for doing Aggregation's with BigDecimal columns.
- BigDecimalColumnInterpreter() - Constructor for class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- BinaryComparator - Class in org.apache.hadoop.hbase.filter
-
- BinaryComparator(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.BinaryComparator
-
Constructor
- BinaryPrefixComparator - Class in 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[]) - Constructor for class org.apache.hadoop.hbase.filter.BinaryPrefixComparator
-
Constructor
- binaryPrefixType - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
BinaryPrefixType byte array
- binarySearch(Cell[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
- binarySearch(Cell[], byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
-
Searches for the latest value for the specified column.
- binaryType - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
BinaryType byte array
- BitComparator - Class in 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) - Constructor for class org.apache.hadoop.hbase.filter.BitComparator
-
Constructor
- BitComparator.BitwiseOp - Enum in org.apache.hadoop.hbase.filter
-
Bit operators.
- bitOperator - Variable in class org.apache.hadoop.hbase.filter.BitComparator
-
- BLOCKCACHE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- BlockingRpcCallback<R> - Class in org.apache.hadoop.hbase.ipc
-
- BlockingRpcCallback() - Constructor for class org.apache.hadoop.hbase.ipc.BlockingRpcCallback
-
- BLOCKSIZE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Size of storefile/hfile 'blocks'.
- blockUntilAvailable(ZooKeeperWatcher, long) - Static method in class org.apache.hadoop.hbase.zookeeper.MetaRegionTracker
-
Wait until the meta region is available.
- blockUntilAvailable(ZooKeeperWatcher, String, long) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
- blockUntilAvailable() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
-
Gets the data of the node, blocking until the node is available.
- blockUntilAvailable(long, boolean) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
-
Gets the data of the node, blocking until the node is available or the
specified timeout has elapsed.
- blockUntilNoRIT(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Blocks until there are no node in regions in transition.
- blockUntilRIT(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Blocks until there is at least one node in regions in transition.
- BLOOMFILTER - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- BloomType - Enum in org.apache.hadoop.hbase.regionserver
-
- bucketRsBatch(HTable, List<Row>) - Static method in class org.apache.hadoop.hbase.client.HTableUtil
-
Processes a List of Rows (Put, Delete) and writes them to an HTable instance in RegionServer buckets via the htable.batch method.
- bucketRsPut(HTable, List<Put>) - Static method in class org.apache.hadoop.hbase.client.HTableUtil
-
Processes a List of Puts and writes them to an HTable instance in RegionServer buckets via the htable.put method.
- buildActionResult(Throwable) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
-
Wrap a throwable to an action result.
- buildActionResult(ClientProtos.Result, ClientProtos.RegionLoadStats) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
-
Wrap a throwable to an action result.
- buildAddColumnRequest(TableName, HColumnDescriptor) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a protocol buffer AddColumnRequest
- buildAssignRegionRequest(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a protocol buffer AssignRegionRequest
- buildBalanceRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Creates a protocol buffer BalanceRequest
- buildBulkLoadHFileRequest(List<Pair<byte[], String>>, byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a protocol buffer bulk load request
- buildCatalogScanRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Creates a request for running a catalog scan
- buildCloseRegionRequest(ServerName, byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a CloseRegionRequest for a given region name
- buildCloseRegionRequest(ServerName, byte[], int, ServerName, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
- buildCloseRegionRequest(ServerName, String, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a CloseRegionRequest for a given encoded region name
- buildCompactRegionRequest(byte[], boolean, byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a CompactRegionRequest for a given region name
- buildCreateTableRequest(HTableDescriptor, byte[][]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Creates a protocol buffer CreateTableRequest
- buildDeleteColumnRequest(TableName, byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a protocol buffer DeleteColumnRequest
- buildDeleteTableRequest(TableName) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Creates a protocol buffer DeleteTableRequest
- buildDisableTableRequest(TableName) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Creates a protocol buffer DisableTableRequest
- buildDispatchMergingRegionsRequest(byte[], byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
- buildEnableCatalogJanitorRequest(boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Creates a request for enabling/disabling the catalog janitor
- buildEnableCatalogJanitorResponse(boolean) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
-
Creates a response for the catalog scan request
- buildEnableTableRequest(TableName) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Creates a protocol buffer EnableTableRequest
- buildException(Throwable) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
-
- buildFlushRegionRequest(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a protocol buffer FlushRegionRequest for a given region name
- buildGetClusterStatusRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Creates a protocol buffer GetClusterStatusRequest
- buildGetLastFlushedSequenceIdRequest(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Creates a request for querying the master the last flushed sequence Id for a region
- buildGetLastFlushedSequenceIdResponse(long) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
-
Creates a response for the last flushed sequence Id request
- buildGetOnlineRegionRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a protocol buffer GetOnlineRegionRequest
- buildGetOnlineRegionResponse(List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
-
A utility to build a GetOnlineRegionResponse.
- buildGetRegionInfoRequest(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a protocol buffer GetRegionInfoRequest for a given region name
- buildGetRegionInfoRequest(byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a protocol buffer GetRegionInfoRequest for a given region name
- buildGetRequest(byte[], Get) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a protocol buffer GetRequest for a client Get
- buildGetRowOrBeforeRequest(byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a new protocol buffer GetRequest to get a row, all columns in a family.
- buildGetSchemaAlterStatusRequest(TableName) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Creates a protocol buffer GetSchemaAlterStatusRequest
- buildGetServerInfoRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a new GetServerInfoRequest
- buildGetServerInfoResponse(ServerName, int) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
-
A utility to build a GetServerInfoResponse.
- buildGetStoreFileRequest(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a protocol buffer GetStoreFileRequest for a given region name
- buildGetTableDescriptorsRequest(List<TableName>) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Creates a protocol buffer GetTableDescriptorsRequest
- buildGetTableDescriptorsRequest(TableName) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Creates a protocol buffer GetTableDescriptorsRequest for a single table
- buildGetUserPermissionsResponse(List<UserPermission>) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
-
Converts the permissions list into a protocol buffer GetUserPermissionsResponse
- buildGrantRequest(String, AccessControlProtos.Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a request to grant user permissions.
- buildGrantRequest(String, TableName, byte[], byte[], AccessControlProtos.Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a request to grant user permissions.
- buildGrantRequest(String, String, AccessControlProtos.Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a request to grant user permissions.
- buildIncrementRequest(byte[], byte[], byte[], byte[], long, Durability, long, long) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a protocol buffer MutateRequest for a client increment
- buildIsCatalogJanitorEnabledRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Creates a request for querying the master whether the catalog janitor is enabled
- buildIsMasterRunningRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Creates a protocol buffer IsMasterRunningRequest
- buildMergeRegionsRequest(byte[], byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a MergeRegionsRequest for the given regions
- buildModifyColumnRequest(TableName, HColumnDescriptor) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a protocol buffer ModifyColumnRequest
- buildModifyTableRequest(TableName, HTableDescriptor) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Creates a protocol buffer ModifyTableRequest
- buildMoveRegionRequest(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a protocol buffer MoveRegionRequest
- buildMutateRequest(byte[], byte[], byte[], byte[], ByteArrayComparable, HBaseProtos.CompareType, Put) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a protocol buffer MutateRequest for a conditioned put
- buildMutateRequest(byte[], byte[], byte[], byte[], ByteArrayComparable, HBaseProtos.CompareType, Delete) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a protocol buffer MutateRequest for a conditioned delete
- buildMutateRequest(byte[], byte[], byte[], byte[], ByteArrayComparable, HBaseProtos.CompareType, RowMutations) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a protocol buffer MutateRequest for conditioned row mutations
- buildMutateRequest(byte[], Put) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a protocol buffer MutateRequest for a put
- buildMutateRequest(byte[], Append, long, long) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a protocol buffer MutateRequest for an append
- buildMutateRequest(byte[], Increment, long, long) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a protocol buffer MutateRequest for a client increment
- buildMutateRequest(byte[], Delete) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a protocol buffer MutateRequest for a delete
- buildNoDataRegionAction(byte[], RowMutations, List<CellScannable>, ClientProtos.RegionAction.Builder, ClientProtos.Action.Builder, ClientProtos.MutationProto.Builder) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a protocol buffer MultiRequest for row mutations that does not hold data.
- buildNoDataRegionAction(byte[], List<Action<R>>, List<CellScannable>, ClientProtos.RegionAction.Builder, ClientProtos.Action.Builder, ClientProtos.MutationProto.Builder) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a protocol buffer multirequest with NO data for a list of actions (data is carried
otherwise than via protobuf).
- buildOfflineRegionRequest(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Creates a protocol buffer OfflineRegionRequest
- buildOpenRegionRequest(ServerName, List<Triple<HRegionInfo, Integer, List<ServerName>>>, Boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a protocol buffer OpenRegionRequest to open a list of regions
- buildOpenRegionRequest(ServerName, HRegionInfo, int, List<ServerName>, Boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a protocol buffer OpenRegionRequest for a given region
- buildRegionAction(byte[], RowMutations) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a protocol buffer MultiRequest for row mutations.
- buildRegionAction(byte[], List<Action<R>>, ClientProtos.RegionAction.Builder, ClientProtos.Action.Builder, ClientProtos.MutationProto.Builder) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a protocol buffer multi request for a list of actions.
- buildRegionSpecifier(HBaseProtos.RegionSpecifier.RegionSpecifierType, byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Convert a byte array to a protocol buffer RegionSpecifier
- buildRevokeRequest(String, AccessControlProtos.Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a request to revoke user permissions.
- buildRevokeRequest(String, TableName, byte[], byte[], AccessControlProtos.Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a request to revoke user permissions.
- buildRevokeRequest(String, String, AccessControlProtos.Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a request to revoke user permissions.
- buildRollWALWriterRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a new RollWALWriterRequest
- buildRunCatalogScanResponse(int) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
-
Creates a response for the catalog scan request
- buildScanRequest(byte[], Scan, int, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a protocol buffer ScanRequest for a client Scan
- buildScanRequest(long, int, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a protocol buffer ScanRequest for a scanner id
- buildScanRequest(long, int, boolean, long) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a protocol buffer ScanRequest for a scanner id
- buildSetBalancerRunningRequest(boolean, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Creates a protocol buffer SetBalancerRunningRequest
- buildSplitRegionRequest(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a SplitRegionRequest for a given region name
- buildStopServerRequest(String) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a new StopServerRequest
- buildTruncateTableRequest(TableName, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Creates a protocol buffer TruncateTableRequest
- buildUnassignRegionRequest(byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Creates a protocol buffer UnassignRegionRequest
- buildUpdateFavoredNodesRequest(List<Pair<HRegionInfo, List<ServerName>>>) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
-
Create a protocol buffer UpdateFavoredNodesRequest to update a list of favorednode mappings
- bulkLoadHFile(ClientProtos.ClientService.BlockingInterface, List<Pair<byte[], String>>, byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A helper to bulk load a list of HFiles using client protocol.
- bulkLoadHFile(ClientProtos.ClientService.BlockingInterface, List<Pair<byte[], String>>, byte[], boolean, PayloadCarryingRpcController) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A helper to bulk load a list of HFiles using client protocol.
- bulkLoadHFiles(List<Pair<byte[], String>>, Token<?>, String, byte[]) - Method in class org.apache.hadoop.hbase.client.coprocessor.SecureBulkLoadClient
-
- ByteArrayComparable - Class in org.apache.hadoop.hbase.filter
-
Base class for byte array comparators
- ByteArrayComparable(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.ByteArrayComparable
-
Constructor.
- cache - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- CACHE_BLOOMS_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- CACHE_DATA_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- CACHE_INDEX_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- caching - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- call(T) - Method in interface org.apache.hadoop.hbase.client.coprocessor.Batch.Call
-
- call() - Method in class org.apache.hadoop.hbase.client.DelegatingRetryingCallable
-
- call() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
- callable - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- callBlockingMethod(Descriptors.MethodDescriptor, RpcController, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
-
- callBlockingMethod(Descriptors.MethodDescriptor, RpcController, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.RpcClient.BlockingRpcChannelImplementation
-
- callComplete() - Method in class org.apache.hadoop.hbase.ipc.RpcClient.Call
-
Indicate when the call is complete and the
value or error are available.
- caller - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- CallerDisconnectedException - Exception in org.apache.hadoop.hbase.ipc
-
Exception indicating that the remote host making this IPC lost its
IPC connection.
- CallerDisconnectedException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.CallerDisconnectedException
-
- callExecService(Descriptors.MethodDescriptor, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
-
- callExecService(Descriptors.MethodDescriptor, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.MasterCoprocessorRpcChannel
-
- callExecService(Descriptors.MethodDescriptor, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.RegionCoprocessorRpcChannel
-
- callExecService(Descriptors.MethodDescriptor, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.RegionServerCoprocessorRpcChannel
-
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
-
- calls - Variable in class org.apache.hadoop.hbase.ipc.RpcClient.Connection
-
- callWithoutRetries(RetryingCallable<T>, int) - Method in class org.apache.hadoop.hbase.client.RpcRetryingCaller
-
Call the server once only.
- callWithoutRetries(RetryingCallable<T>, int) - Method in class org.apache.hadoop.hbase.client.StatsTrackingRpcRetryingCaller
-
- callWithRetries(RetryingCallable<T>) - Method in class org.apache.hadoop.hbase.client.RpcRetryingCaller
-
- callWithRetries(RetryingCallable<T>, int) - Method in class org.apache.hadoop.hbase.client.RpcRetryingCaller
-
Retries if invocation fails.
- callWithRetries(RetryingCallable<T>, int) - Method in class org.apache.hadoop.hbase.client.StatsTrackingRpcRetryingCaller
-
- cancelConnections(String, int, IOException) - Method in class org.apache.hadoop.hbase.ipc.RpcClient
-
Interrupt the connections to the given ip:port server.
- castToCellType(BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- castToCellType(Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- castToCellType(Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- castToCellType(S) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
The response message comes as type S.
- castToReturnType(BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- castToReturnType(Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- castToReturnType(Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- castToReturnType(T) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
provides casting opportunity between the data types.
- CatalogTracker - Class in org.apache.hadoop.hbase.catalog
-
Tracks the availability of the catalog tables
hbase:meta
.
- CatalogTracker(Configuration) - Constructor for class org.apache.hadoop.hbase.catalog.CatalogTracker
-
Constructs a catalog tracker.
- CatalogTracker(ZooKeeperWatcher, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.catalog.CatalogTracker
-
Constructs the catalog tracker.
- CatalogTracker(ZooKeeperWatcher, Configuration, HConnection, Abortable) - Constructor for class org.apache.hadoop.hbase.catalog.CatalogTracker
-
- cellScanner() - Method in class org.apache.hadoop.hbase.client.Mutation
-
- cellScanner() - Method in class org.apache.hadoop.hbase.client.Result
-
- cellScanner() - Method in class org.apache.hadoop.hbase.ipc.DelegatingPayloadCarryingRpcController
-
- cellScanner() - Method in class org.apache.hadoop.hbase.ipc.PayloadCarryingRpcController
-
- CellVisibility - Class in org.apache.hadoop.hbase.security.visibility
-
This contains a visibility expression which can be associated with a cell.
- CellVisibility(String) - Constructor for class org.apache.hadoop.hbase.security.visibility.CellVisibility
-
- CF_ATTRIBUTE_EARLY_OUT - Static variable in interface 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 - Static variable in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- chance - Variable in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
- CHECK_AUTHS_FOR_MUTATION - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
-
- checkAndDelete(byte[], byte[], byte[], byte[], Delete) - Method in class org.apache.hadoop.hbase.client.HTable
-
Atomically checks if a row/family/qualifier value matches the expected
value.
- checkAndDelete(byte[], byte[], byte[], byte[], Delete) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Atomically checks if a row/family/qualifier value matches the expected
value.
- checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], RowMutations) - Method in class org.apache.hadoop.hbase.client.HTable
-
Atomically checks if a row/family/qualifier value matches the expected val
If it does, it performs the row mutations.
- checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], RowMutations) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Atomically checks if a row/family/qualifier value matches the expected val
If it does, it performs the row mutations.
- checkAndPut(byte[], byte[], byte[], byte[], Put) - Method in class org.apache.hadoop.hbase.client.HTable
-
Atomically checks if a row/family/qualifier value matches the expected
value.
- checkAndPut(byte[], byte[], byte[], byte[], Put) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Atomically checks if a row/family/qualifier value matches the expected
value.
- checkAndSetEnablingTable(TableName) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
Sets the specified table as ENABLING in zookeeper atomically
If the table is already in ENABLING state, no operation is performed
- checkClosingState(ZooKeeperWatcher, HRegionInfo, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
- checkDisabledAndSetEnablingTable(TableName) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
Sets the specified table as ENABLING in zookeeper atomically
If the table isn't in DISABLED state, no operation is performed
- checkEnabledAndSetDisablingTable(TableName) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
Sets the specified table as DISABLING in zookeeper atomically
If the table isn't in ENABLED state, no operation is performed
- checkExists(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Check if the specified node exists.
- checkFailed() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
-
Throws an IOException back out if one is currently stored.
- checkForAnd(byte[], int) - Static method in class 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) - Static method in class 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) - Static method in class 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) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Checks if the current index of filter string we are on is the beginning of the keyword 'WHILE'
- checkHBaseAvailable(Configuration) - Static method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Check to see if HBase is running.
- checkIfBaseNodeAvailable() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
-
Checks if the baseznode set as per the property 'zookeeper.znode.parent'
exists.
- checkIfRegionServerIsRemote() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
compare the local machine hostname with region server's hostname
to decide if hbase client connects to a remote region server
- checkIOException(IOException) - Static method in class org.apache.hadoop.hbase.RemoteExceptionHandler
-
Examine passed IOException.
- checkScanStopRow(byte[]) - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- checkScanStopRow(byte[]) - Method in class org.apache.hadoop.hbase.client.ReversedClientScanner
-
- checkThrowable(Throwable) - Static method in class org.apache.hadoop.hbase.RemoteExceptionHandler
-
Examine passed Throwable.
- checkZk() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
Try to create a Zookeeper connection.
- claimQueues(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
-
Take ownership for the set of queues belonging to a dead region server.
- claimQueues(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
-
- classifyExs(List<Throwable>) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- cleanupBulkLoad(String) - Method in class org.apache.hadoop.hbase.client.coprocessor.SecureBulkLoadClient
-
- cleanupCalls() - Method in class org.apache.hadoop.hbase.ipc.RpcClient.Connection
-
- cleanupCalls(long) - Method in class org.apache.hadoop.hbase.ipc.RpcClient.Connection
-
- clear() - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- clear() - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
-
- clearAuths(Configuration, String[], String) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
-
Removes given labels from user's globally authorized list of labels.
- clearCaches(ServerName) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Clear any caches that pertain to server name sn
.
- clearCaches(ServerName) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- clearRegionCache() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Allows flushing the region cache.
- clearRegionCache(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Allows flushing the region cache of all locations that pertain to
tableName
- clearRegionCache(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
- clearRegionCache() - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- clearRegionCache(TableName) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- clearRegionCache(byte[]) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- clearRegionCache() - Method in class org.apache.hadoop.hbase.client.HTable
-
Explicitly clears the region cache to fetch the latest value from META.
- ClientBackoffPolicy - Interface in 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 - Class in org.apache.hadoop.hbase.client.backoff
-
- ClientBackoffPolicyFactory.NoBackoffPolicy - Class in org.apache.hadoop.hbase.client.backoff
-
Default backoff policy that doesn't create any backoff for the client, regardless of load
- ClientBackoffPolicyFactory.NoBackoffPolicy(Configuration) - Constructor for class org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicyFactory.NoBackoffPolicy
-
- ClientScanner - Class in org.apache.hadoop.hbase.client
-
Implements the scanner interface for the HBase client.
- ClientScanner(Configuration, Scan, TableName) - Constructor for class org.apache.hadoop.hbase.client.ClientScanner
-
Deprecated.
- ClientScanner(Configuration, Scan, byte[]) - Constructor for class org.apache.hadoop.hbase.client.ClientScanner
-
- ClientScanner(Configuration, Scan, TableName, HConnection) - Constructor for class 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.
- ClientScanner(Configuration, Scan, byte[], HConnection) - Constructor for class org.apache.hadoop.hbase.client.ClientScanner
-
- ClientScanner(Configuration, Scan, TableName, HConnection, RpcRetryingCallerFactory) - Constructor for class org.apache.hadoop.hbase.client.ClientScanner
-
- ClientScanner(Configuration, Scan, TableName, HConnection, RpcRetryingCallerFactory, RpcControllerFactory) - Constructor for class 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.
- ClientSmallReversedScanner - Class in org.apache.hadoop.hbase.client
-
Client scanner for small reversed scan.
- ClientSmallReversedScanner(Configuration, Scan, TableName, HConnection) - Constructor for class org.apache.hadoop.hbase.client.ClientSmallReversedScanner
-
Create a new ReversibleClientScanner for the specified table Note that the
passed
Scan
's start row maybe changed.
- ClientSmallScanner - Class in org.apache.hadoop.hbase.client
-
Client scanner for small scan.
- ClientSmallScanner(Configuration, Scan, TableName) - Constructor for class org.apache.hadoop.hbase.client.ClientSmallScanner
-
Create a new ClientSmallScanner for the specified table.
- ClientSmallScanner(Configuration, Scan, TableName, HConnection) - Constructor for class org.apache.hadoop.hbase.client.ClientSmallScanner
-
Create a new ClientSmallScanner for the specified table.
- ClientSmallScanner(Configuration, Scan, TableName, HConnection, RpcRetryingCallerFactory, RpcControllerFactory) - Constructor for class org.apache.hadoop.hbase.client.ClientSmallScanner
-
Create a new ShortClientScanner for the specified table Note that the
passed
Scan
's start row maybe changed changed.
- ClientSnapshotDescriptionUtils - Class in org.apache.hadoop.hbase.snapshot
-
Class to help with dealing with a snapshot description on the client side.
- ClientSnapshotDescriptionUtils() - Constructor for class org.apache.hadoop.hbase.snapshot.ClientSnapshotDescriptionUtils
-
- ClockOutOfSyncException - Exception in org.apache.hadoop.hbase
-
This exception is thrown by the master when a region server clock skew is
too high.
- ClockOutOfSyncException(String) - Constructor for exception org.apache.hadoop.hbase.ClockOutOfSyncException
-
- cloneSnapshot(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Create a new table by cloning the snapshot content.
- cloneSnapshot(byte[], TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Create a new table by cloning the snapshot content.
- cloneSnapshot(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Create a new table by cloning the snapshot content.
- cloneSnapshot(String, TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Create a new table by cloning the snapshot content.
- close() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- close() - Method in class org.apache.hadoop.hbase.client.ClientSmallReversedScanner
-
- close() - Method in class org.apache.hadoop.hbase.client.ClientSmallScanner
-
- close() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- close() - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- close() - Method in class org.apache.hadoop.hbase.client.HTable
-
- close() - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Releases any resources held or pending changes in internal buffers.
- close() - Method in class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
Closes all the HTable instances , belonging to all tables in the table
pool.
- close() - Method in class org.apache.hadoop.hbase.client.MetaScanner.MetaScannerVisitorBase
-
- close() - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- close() - Method in interface org.apache.hadoop.hbase.client.ResultScanner
-
Closes the scanner and releases any resources it has allocated
- close() - Method in class org.apache.hadoop.hbase.ipc.RpcClient.Connection
-
Close the connection.
- close() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
-
- close() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- close() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
Close the connection to ZooKeeper.
- closeConnection() - Method in class org.apache.hadoop.hbase.ipc.RpcClient.Connection
-
- closed - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- CLOSED_PARAN - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
-
- closeException - Variable in class org.apache.hadoop.hbase.ipc.RpcClient.Connection
-
- closeRegion(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Close a region.
- closeRegion(byte[], String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Close a region.
- closeRegion(ServerName, HRegionInfo) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Close a region.
- closeRegion(AdminProtos.AdminService.BlockingInterface, ServerName, byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A helper to close a region given a region name
using admin protocol.
- closeRegion(AdminProtos.AdminService.BlockingInterface, ServerName, byte[], int, ServerName, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A helper to close a region given a region name
using admin protocol.
- closeRegionWithEncodedRegionName(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
For expert-admins.
- closeTablePool(String) - Method in class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
Closes all the HTable instances , belonging to the given table, in the
table pool.
- closeTablePool(byte[]) - Method in class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
- clusterId - Variable in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- ClusterId - Class in org.apache.hadoop.hbase
-
The identifier for this cluster.
- ClusterId() - Constructor for class org.apache.hadoop.hbase.ClusterId
-
New ClusterID.
- ClusterId(String) - Constructor for class org.apache.hadoop.hbase.ClusterId
-
- clusterId - Variable in class org.apache.hadoop.hbase.ipc.RpcClient
-
- clusterIdZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- clusterStateZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- ClusterStatus - Class in org.apache.hadoop.hbase
-
Status information on the HBase cluster.
- ClusterStatus() - Constructor for class org.apache.hadoop.hbase.ClusterStatus
-
Deprecated.
Used by Writables and Writables are going away.
- ClusterStatus(String, String, Map<ServerName, ServerLoad>, Collection<ServerName>, ServerName, Collection<ServerName>, Map<String, RegionState>, String[], Boolean) - Constructor for class org.apache.hadoop.hbase.ClusterStatus
-
- code() - Method in enum org.apache.hadoop.hbase.security.access.Permission.Action
-
- code - Variable in enum org.apache.hadoop.hbase.security.AuthMethod
-
The code for this method.
- COLON - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for colon (:)
- ColumnCountGetFilter - Class in org.apache.hadoop.hbase.filter
-
Simple filter that returns first N columns on row only.
- ColumnCountGetFilter(int) - Constructor for class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
- columnFamily - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- columnFamily - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- ColumnInterpreter<T,S,P extends Message,Q extends Message,R extends Message> - Class in 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() - Constructor for class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
- ColumnPaginationFilter - Class in org.apache.hadoop.hbase.filter
-
A filter, based on the ColumnCountGetFilter, takes two arguments: limit and offset.
- ColumnPaginationFilter(int, int) - Constructor for class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
Initializes filter with an integer offset and limit.
- ColumnPaginationFilter(int, byte[]) - Constructor for class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
Initializes filter with a string/bookmark based offset and limit.
- ColumnPrefixFilter - Class in org.apache.hadoop.hbase.filter
-
This filter is used for selecting only those keys with columns that matches
a particular prefix.
- ColumnPrefixFilter(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
- columnQualifier - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- columnQualifier - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- ColumnRangeFilter - Class in 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) - Constructor for class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
Create a filter to select those keys with columns that are between minColumn
and maxColumn.
- COMMA - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for a comma
- compact(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Compact a table or an individual region.
- compact(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Compact a table or an individual region.
- compact(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Compact a column family within a table or region.
- compact(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Compact a column family within a table or region.
- COMPACTION_ENABLED - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
INTERNAL Used by HBase Shell interface to access this metadata
attribute which denotes if the table is compaction enabled
- compactRegionServer(ServerName, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Compact all regions on the region server
- comparator - Variable in class org.apache.hadoop.hbase.filter.CompareFilter
-
- comparator - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- compare(BigDecimal, BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- compare(Double, Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- compare(Long, Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- compare(T, T) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
This takes care if either of arguments are null.
- CompareFilter - Class in org.apache.hadoop.hbase.filter
-
This is a generic filter to be used to filter by comparison.
- CompareFilter(CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.CompareFilter
-
Constructor.
- CompareFilter.CompareOp - Enum in org.apache.hadoop.hbase.filter
-
Comparison operators.
- compareOp - Variable in class org.apache.hadoop.hbase.filter.CompareFilter
-
- compareOp - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- compareResults(Result, Result) - Static method in class org.apache.hadoop.hbase.client.Result
-
Does a deep comparison of two Results, down to the byte arrays.
- compareTo(Object) - Method in class org.apache.hadoop.hbase.client.Action
-
- compareTo(Row) - Method in class org.apache.hadoop.hbase.client.Get
-
- compareTo(Row) - Method in class org.apache.hadoop.hbase.client.Increment
-
- compareTo(Row) - Method in class org.apache.hadoop.hbase.client.Mutation
-
- compareTo(Row) - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
-
- compareTo(Row) - Method in class org.apache.hadoop.hbase.client.RowMutations
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.BinaryComparator
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.BinaryPrefixComparator
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.BitComparator
-
- compareTo(byte[]) - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
-
Special compareTo method for subclasses, to avoid
copying byte[] unnecessarily.
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.LongComparator
-
- compareTo(byte[]) - Method in class org.apache.hadoop.hbase.filter.NullComparator
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.NullComparator
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.SubstringComparator
-
- compareTo(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- compareTo(HRegionInfo) - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- compareTo(HRegionLocation) - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- compareTo(HTableDescriptor) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Compares the descriptor with another descriptor which is passed as a parameter.
- compareTo(ServerName) - Method in class org.apache.hadoop.hbase.ServerName
-
- COMPRESS_TAGS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- COMPRESSION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- COMPRESSION_COMPACT - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- conf - Variable in class org.apache.hadoop.hbase.client.HConnectable
-
- conf - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
-
- conf - Variable in class org.apache.hadoop.hbase.ipc.RpcClient
-
- conf - Variable in class org.apache.hadoop.hbase.ipc.RpcControllerFactory
-
- conf - Variable in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
-
- connect(HConnection) - Method in class org.apache.hadoop.hbase.client.HConnectable
-
- connect(Configuration, Watcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Creates a new connection to ZooKeeper, pulling settings and ensemble config
from the specified configuration object using methods from
ZKConfig
.
- connect(Configuration, String, Watcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
- connect(Configuration, String, Watcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
- connection - Variable in class org.apache.hadoop.hbase.client.HTable
-
- connection - Variable in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- connections - Variable in class org.apache.hadoop.hbase.ipc.RpcClient
-
- ConnectionUtils - Class in org.apache.hadoop.hbase.client
-
Utility used by client connections.
- ConnectionUtils() - Constructor for class org.apache.hadoop.hbase.client.ConnectionUtils
-
- containsColumn(byte[], byte[]) - Method in class 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) - Method in class org.apache.hadoop.hbase.client.Result
-
Checks for existence of a value for the specified column (empty or not).
- containsEmptyColumn(byte[], byte[]) - Method in class 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) - Method in class org.apache.hadoop.hbase.client.Result
-
Checks if the specified column contains an empty value (a zero-length byte array).
- containsKey(Object) - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- containsNonEmptyColumn(byte[], byte[]) - Method in class 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) - Method in class 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[]) - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Returns true if the given inclusive range of rows is fully contained
by this region.
- containsRow(byte[]) - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Return true if the given row falls in this region.
- containsValue(Object) - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- controller - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
-
- convert() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
Convert a ClusterStatus to a protobuf ClusterStatus
- convert(ClusterStatusProtos.ClusterStatus) - Static method in class org.apache.hadoop.hbase.ClusterStatus
-
Convert a protobuf ClusterStatus to a ClusterStatus
- convert(HBaseProtos.ColumnFamilySchema) - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- convert() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- convert(HRegionInfo) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Convert a HRegionInfo to a RegionInfo
- convert(HBaseProtos.RegionInfo) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Convert a RegionInfo to a HRegionInfo
- convert() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- convert(HBaseProtos.TableSchema) - Static method in class org.apache.hadoop.hbase.HTableDescriptor
-
- convert() - Method in class org.apache.hadoop.hbase.master.RegionState
-
Convert a RegionState to an HBaseProtos.RegionState
- convert(ClusterStatusProtos.RegionState) - Static method in class org.apache.hadoop.hbase.master.RegionState
-
Convert a protobuf HBaseProtos.RegionState to a RegionState
- convert() - Method in enum org.apache.hadoop.hbase.master.RegionState.State
-
Convert to protobuf ClusterStatusProtos.RegionState.State
- convert(ClusterStatusProtos.RegionState.State) - Static method in enum org.apache.hadoop.hbase.master.RegionState.State
-
Convert a protobuf HBaseProtos.RegionState.State to a RegionState.State
- convert(DeserializationException) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
- convertByteArrayToBoolean(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Converts a boolean expressed in a byte array to an actual boolean
- convertByteArrayToInt(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Converts an int expressed in a byte array to an actual int
- convertByteArrayToLong(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Converts a long expressed in a byte array to an actual long
- Coprocessor - Interface in org.apache.hadoop.hbase
-
Coprocessor interface.
- Coprocessor.State - Enum in org.apache.hadoop.hbase
-
Lifecycle state of a given coprocessor instance.
- CoprocessorEnvironment - Interface in org.apache.hadoop.hbase
-
Coprocessor environment state.
- CoprocessorException - Exception in org.apache.hadoop.hbase.coprocessor
-
Thrown if a coprocessor encounters any exception.
- CoprocessorException() - Constructor for exception org.apache.hadoop.hbase.coprocessor.CoprocessorException
-
Default Constructor
- CoprocessorException(Class<?>, String) - Constructor for exception org.apache.hadoop.hbase.coprocessor.CoprocessorException
-
Constructor with a Class object and exception message.
- CoprocessorException(String) - Constructor for exception org.apache.hadoop.hbase.coprocessor.CoprocessorException
-
Constructs the exception and supplies a string as the message
- CoprocessorRpcChannel - Class in org.apache.hadoop.hbase.ipc
-
Base class which provides clients with an RPC connection to
call coprocessor endpoint
Service
s.
- CoprocessorRpcChannel() - Constructor for class org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
-
- coprocessorService() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Creates and returns a
RpcChannel
instance
connected to the active master.
- coprocessorService(ServerName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Creates and returns a
RpcChannel
instance
connected to the passed region server.
- coprocessorService(byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
-
Creates and returns a
RpcChannel
instance connected to the
table region containing the specified row.
- coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>) - Method in class org.apache.hadoop.hbase.client.HTable
-
Creates an instance of the given
Service
subclass for each table
region spanning the range from the
startKey
row to
endKey
row (inclusive),
and invokes the passed
Batch.Call.call(T)
method with each
Service
instance.
- coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTable
-
Creates an instance of the given
Service
subclass for each table
region spanning the range from the
startKey
row to
endKey
row (inclusive),
and invokes the passed
Batch.Call.call(T)
method with each
Service
instance.
- coprocessorService(byte[]) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Creates and returns a
RpcChannel
instance connected to the
table region containing the specified row.
- coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
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>) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Creates an instance of the given
Service
subclass for each table
region spanning the range from the
startKey
row to
endKey
row (inclusive),
and invokes the passed
Batch.Call.call(T)
method with each
Service
instance.
- copyFrom(Result) - Method in class org.apache.hadoop.hbase.client.Result
-
Copy another Result into this one.
- copyWritable(Writable, Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
-
Copy one Writable to another.
- copyWritable(byte[], Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
-
Copy one Writable to another.
- CorruptedSnapshotException - Exception in org.apache.hadoop.hbase.snapshot
-
Exception thrown when the found snapshot info from the filesystem is not valid
- CorruptedSnapshotException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.snapshot.CorruptedSnapshotException
-
- CorruptedSnapshotException(String, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.CorruptedSnapshotException
-
Snapshot was corrupt for some reason
- CorruptedSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.CorruptedSnapshotException
-
- counter - Variable in class org.apache.hadoop.hbase.ipc.RpcClient
-
- countOfBytesInRemoteResults - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
number of bytes in Result objects from remote region servers
- countOfBytesInResults - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
number of bytes in Result objects from region servers
- countOfNSRE - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
number of NotServingRegionException caught
- countOfRegions - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
number of regions
- countOfRemoteRPCcalls - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
number of remote RPC calls
- countOfRemoteRPCRetries - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
number of remote RPC retries
- countOfRPCcalls - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
number of RPC calls
- countOfRPCRetries - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
number of RPC retries
- create(Configuration) - Static method in class org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicyFactory
-
- create(List<Cell>) - Static method in class org.apache.hadoop.hbase.client.Result
-
Instantiate a Result with the specified List of KeyValues.
- create(List<Cell>, Boolean) - Static method in class org.apache.hadoop.hbase.client.Result
-
- create(Cell[]) - Static method in class org.apache.hadoop.hbase.client.Result
-
Instantiate a Result with the specified array of KeyValues.
- create(Configuration) - Static method in class org.apache.hadoop.hbase.client.ServerStatisticTracker
-
- create(String, byte[], List<ACL>, CreateMode) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
NONSEQUENTIAL create is idempotent operation.
- createAndAddPeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
-
Attempt to connect to a new remote slave cluster.
- createAndFailSilent(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Creates the specified node, iff the node does not exist.
- createAndFailSilent(ZooKeeperWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Creates the specified node containing specified data, iff the node does not exist.
- createAndFailSilent(String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
-
- createAndWatch(ZooKeeperWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Creates the specified node with the specified data and watches it.
- createAsyncProcess(TableName, ExecutorService, AsyncProcess.AsyncProcessCallback<R>, Configuration) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- createBlockingRpcChannel(ServerName, User, int) - Method in class org.apache.hadoop.hbase.ipc.RpcClient
-
Creates a "channel" that can be used by a blocking protobuf service.
- createClosestRowBefore(byte[]) - Method in class org.apache.hadoop.hbase.client.ReversedClientScanner
-
Create the closest row before the specified row
- createComparator(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Parses a comparator of the form comparatorType:comparatorValue form and returns a comparator
- createCompareOp(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Takes a compareOperator symbol as a byte array and returns the corresponding CompareOperator
- createConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
Create a new HConnection instance using the passed conf
instance.
- createConnection(Configuration, ExecutorService) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
Create a new HConnection instance using the passed conf
instance.
- createConnection(Configuration, User) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
Create a new HConnection instance using the passed conf
instance.
- createConnection(Configuration, ExecutorService, User) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
Create a new HConnection instance using the passed conf
instance.
- createConnection(RpcClient.ConnectionId, Codec, CompressionCodec) - Method in class org.apache.hadoop.hbase.ipc.RpcClient
-
Creates a connection.
- createDigestSaslClient(String[], String, CallbackHandler) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
- createEphemeralNodeAndWatch(ZooKeeperWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Set the specified znode to be an ephemeral node carrying the specified
data.
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.FamilyFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.FilterBase
-
Given the filter's arguments it constructs the filter
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.PageFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.PrefixFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.QualifierFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.RowFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ValueFilter
-
- createHTable(String) - Method in class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
- createHTableInterface(Configuration, byte[]) - Method in class org.apache.hadoop.hbase.client.HTableFactory
-
Deprecated.
- createHTableInterface(Configuration, byte[]) - Method in interface org.apache.hadoop.hbase.client.HTableInterfaceFactory
-
Creates a new HTableInterface.
- createKerberosSaslClient(String[], String, String) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
- createNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Create a new namespace
- createNodeClosing(ZooKeeperWatcher, HRegionInfo, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Creates a new unassigned node in the CLOSING state for the specified
region.
- createNodeIfNotExistsAndWatch(ZooKeeperWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Creates the specified znode to be a persistent node carrying the specified
data.
- createNodeIfNotExistsNoWatch(ZooKeeperWatcher, String, byte[], CreateMode) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Creates the specified znode with the specified data but does not watch it.
- createNodeOffline(ZooKeeperWatcher, HRegionInfo, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Creates a new unassigned node in the OFFLINE state for the specified region.
- createNodeOffline(ZooKeeperWatcher, HRegionInfo, ServerName, EventType) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
- createOrForceNodeOffline(ZooKeeperWatcher, HRegionInfo, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Creates or force updates an unassigned node to the OFFLINE state for the
specified region.
- createPool() - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- createRegionName(TableName, byte[], long, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Make a region name of passed parameters.
- createRegionName(TableName, byte[], String, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Make a region name of passed parameters.
- createRegionName(TableName, byte[], byte[], boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Make a region name of passed parameters.
- createRegionTransition(EventType, byte[], ServerName) - Static method in class org.apache.hadoop.hbase.RegionTransition
-
- createRegionTransition(EventType, byte[], ServerName, byte[]) - Static method in class org.apache.hadoop.hbase.RegionTransition
-
- createSetData(ZooKeeperWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Set data into node creating node if it doesn't yet exist.
- createTable(HTableDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Creates a new table.
- createTable(HTableDescriptor, byte[], byte[], int) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Creates a new table with the specified number of regions.
- createTable(HTableDescriptor, byte[][]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Creates a new table with an initial set of empty regions defined by the
specified split keys.
- createTableAsync(HTableDescriptor, byte[][]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Creates a new table but does not block and wait for it to come online.
- createTreeSet() - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- createUnescapdArgument(byte[], int, int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Removes the single quote escaping a single quote - thus it returns an unescaped argument
- createWithParents(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Creates the specified node and all parent nodes required for it to exist.
- createWithParents(ZooKeeperWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Creates the specified node and all parent nodes required for it to exist.
- CREATOR_ALL_AND_WORLD_READABLE - Static variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- current() - Method in class org.apache.hadoop.hbase.client.Result
-
- currentRegion - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- currentWriteBufferSize - Variable in class org.apache.hadoop.hbase.client.HTable
-
- CUSTOM_CALLER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
-
- CUSTOM_CONTROLLER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.RpcControllerFactory
-
- D - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'D'
- DATA_BLOCK_ENCODING - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- decodeRemoteException(RemoteException) - Static method in class org.apache.hadoop.hbase.RemoteExceptionHandler
-
Deprecated.
Use RemoteException.unwrapRemoteException()
instead.
In fact we should look into deprecating this whole class - St.Ack 2010929
- DEFAULT_ATTRIBUTE_EARLY_OUT - Static variable in interface org.apache.hadoop.hbase.security.access.AccessControlConstants
-
Default setting for hbase.security.access.early_out; true
- DEFAULT_BLOCKCACHE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default setting for whether to use a block cache or not.
- DEFAULT_BLOCKSIZE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default size of blocks in files stored to the filesytem (hfiles).
- DEFAULT_BLOOMFILTER - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default setting for whether or not to use bloomfilters.
- DEFAULT_CACHE_BLOOMS_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default setting for whether to cache bloom filter blocks on write if block
caching is enabled.
- DEFAULT_CACHE_DATA_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default setting for whether to cache data blocks on write if block caching
is enabled.
- DEFAULT_CACHE_INDEX_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default setting for whether to cache index blocks on write if block
caching is enabled.
- DEFAULT_COMPACTION_ENABLED - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
Constant that denotes whether the table is compaction enabled by default
- DEFAULT_COMPRESS_TAGS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default compress tags along with any type of DataBlockEncoding.
- DEFAULT_COMPRESSION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default compression type.
- DEFAULT_DATA_BLOCK_ENCODING - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default data block encoding algorithm.
- DEFAULT_ENCODE_ON_DISK - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default value of the flag that enables data block encoding on disk, as
opposed to encoding in cache only.
- DEFAULT_EVICT_BLOCKS_ON_CLOSE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default setting for whether to evict cached blocks from the blockcache on
close.
- DEFAULT_EXEC_PERMISSION_CHECKS - Static variable in interface org.apache.hadoop.hbase.security.access.AccessControlConstants
-
Default setting for hbase.security.exec.permission.checks; false
- DEFAULT_IN_MEMORY - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default setting for whether to serve from memory or not.
- DEFAULT_KEEP_DELETED - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default setting for preventing deleted from being collected immediately.
- DEFAULT_MAX_BACKOFF - Static variable in class org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
-
- DEFAULT_MEMSTORE_FLUSH_SIZE - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
Constant that denotes the maximum default size of the memstore after which
the contents are flushed to the store files
- DEFAULT_MIN_VERSIONS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default is not to keep a minimum of versions.
- DEFAULT_PREFETCH_BLOCKS_ON_OPEN - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- DEFAULT_READONLY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
Constant that denotes whether the table is READONLY by default and is false
- DEFAULT_REPLICATION_SCOPE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default scope.
- DEFAULT_TTL - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default time to live of cell contents.
- DEFAULT_VERSIONS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default number of versions of a record to keep.
- DEFERRED_LOG_FLUSH - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
- DelayingRunner<T> - Class in org.apache.hadoop.hbase.client
-
A wrapper for a runnable for a group of actions for a single regionserver.
- DelayingRunner(long, Map.Entry<byte[], List<Action<T>>>) - Constructor for class org.apache.hadoop.hbase.client.DelayingRunner
-
- delegate - Variable in class org.apache.hadoop.hbase.client.DelegatingRetryingCallable
-
- DelegatingPayloadCarryingRpcController - Class in org.apache.hadoop.hbase.ipc
-
- DelegatingPayloadCarryingRpcController(PayloadCarryingRpcController) - Constructor for class org.apache.hadoop.hbase.ipc.DelegatingPayloadCarryingRpcController
-
- DelegatingRetryingCallable<T,D extends RetryingCallable<T>> - Class in org.apache.hadoop.hbase.client
-
- DelegatingRetryingCallable(D) - Constructor for class org.apache.hadoop.hbase.client.DelegatingRetryingCallable
-
- Delete - Class in org.apache.hadoop.hbase.client
-
Used to perform Delete operations on a single row.
- Delete(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Delete
-
Create a Delete operation for the specified row.
- Delete(byte[], long) - Constructor for class org.apache.hadoop.hbase.client.Delete
-
Create a Delete operation for the specified row and timestamp.
- Delete(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.client.Delete
-
Create a Delete operation for the specified row and timestamp.
- Delete(byte[], int, int, long) - Constructor for class org.apache.hadoop.hbase.client.Delete
-
Create a Delete operation for the specified row and timestamp.
- Delete(Delete) - Constructor for class org.apache.hadoop.hbase.client.Delete
-
- delete(Delete) - Method in class org.apache.hadoop.hbase.client.HTable
-
Deletes the specified cells/row.
- delete(List<Delete>) - Method in class org.apache.hadoop.hbase.client.HTable
-
Deletes the specified cells/rows in bulk.
- delete(Delete) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Deletes the specified cells/row.
- delete(List<Delete>) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Deletes the specified cells/rows in bulk.
- delete(String, int) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
delete is an idempotent operation.
- deleteAllConnections(boolean) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
Deprecated.
- deleteAllConnections() - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
Deprecated.
kept for backward compatibility, but the behavior is broken. HBASE-8983
- deleteAllNodes(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Deletes all unassigned nodes regardless of their state.
- deleteCachedRegionLocation(HRegionLocation) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deletes cached locations for the specific region.
- deleteCachedRegionLocation(HRegionLocation) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- deleteChildrenRecursively(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Delete all the children of the specified node but not the node itself.
- deleteClosedNode(ZooKeeperWatcher, String, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Deletes an existing unassigned node that is in the CLOSED state for the
specified region.
- deleteClosingNode(ZooKeeperWatcher, HRegionInfo, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Deletes an existing unassigned node that is in the CLOSING state for the
specified region.
- deleteColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
-
Delete the latest version of the specified column.
- deleteColumn(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
-
Delete the specified version of the specified column.
- deleteColumn(byte[], String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Delete a column from a table.
- deleteColumn(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Delete a column from a table.
- deleteColumn(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Delete a column from a table.
- deleteColumns(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
-
Delete all versions of the specified column.
- deleteColumns(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
-
Delete all versions of the specified column with a timestamp less than
or equal to the specified timestamp.
- deleteConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
Deprecated.
- deleteFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
-
Delete all versions of all columns of the specified family.
- deleteFamily(byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
-
Delete all columns of the specified family with a timestamp less than
or equal to the specified timestamp.
- deleteFamilyVersion(byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
-
Delete all columns of the specified family with a timestamp equal to
the specified timestamp.
- deleteIfEquals(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
delete the master znode if its content is same as the parameter
- deleteMetaLocation(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.MetaRegionTracker
-
Deletes the location of hbase:meta
in ZooKeeper.
- deleteNamespace(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Delete an existing namespace.
- deleteNode(ZooKeeperWatcher, String, EventType, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Deletes an existing unassigned node that is in the specified state for the
specified region.
- deleteNode(ZooKeeperWatcher, String, EventType, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Deletes an existing unassigned node that is in the specified state for the
specified region.
- deleteNode(ZooKeeperWatcher, String, EventType, ServerName, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Deletes an existing unassigned node that is in the specified state for the
specified region.
- deleteNode(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Delete the specified node.
- deleteNode(ZooKeeperWatcher, String, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Delete the specified node with the specified version.
- deleteNodeFailSilent(ZooKeeperWatcher, HRegionInfo) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Delete the assignment node regardless of its current state.
- deleteNodeFailSilent(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Deletes the specified node.
- deleteNodeFailSilent(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
-
- deleteNodeRecursively(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Delete the specified node and all of it's children.
- deleteOfflineNode(ZooKeeperWatcher, String, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Deletes an existing unassigned node that is in the OFFLINE state for the
specified region.
- deleteOpenedNode(ZooKeeperWatcher, String, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Deletes an existing unassigned node that is in the OPENED state for the
specified region.
- deleteSnapshot(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Delete an existing snapshot.
- deleteSnapshot(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Delete an existing snapshot.
- deleteSnapshots(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Delete existing snapshots whose names match the pattern passed.
- deleteSnapshots(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Delete existing snapshots whose names match the pattern passed.
- deleteStaleConnection(HConnection) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
Deprecated.
- deleteTable(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- deleteTable(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- deleteTable(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Deletes a table.
- deleteTables(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Deletes tables matching the passed in pattern and wait on completion.
- deleteTables(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Delete tables matching the passed in pattern and wait on completion.
- DependentColumnFilter - Class in 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) - Constructor for class 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[]) - Constructor for class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
Constructor for DependentColumn filter.
- DependentColumnFilter(byte[], byte[], boolean) - Constructor for class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
Constructor for DependentColumn filter.
- DeserializationException - Exception in org.apache.hadoop.hbase.exceptions
-
Failed deserialization.
- DeserializationException() - Constructor for exception org.apache.hadoop.hbase.exceptions.DeserializationException
-
- DeserializationException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.DeserializationException
-
- DeserializationException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.DeserializationException
-
- DeserializationException(Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.DeserializationException
-
- DISABLED_ZNODE_BYTES - Static variable in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
-
- disablePeer(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Stop the replication stream to the specified peer.
- disablePeer(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
-
Stop the replication to the specified remote slave cluster.
- disablePeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
-
- disableTable(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Disable table and wait on completion.
- disableTable(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- disableTable(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- disableTableAsync(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Starts the disable of a table.
- disableTableAsync(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- disableTableAsync(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- disableTables(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Disable tables matching the passed in pattern and wait on completion.
- disableTables(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Disable tables matching the passed in pattern and wait on completion.
- dispose() - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
Release resources used by wrapped saslClient
- divideForAvg(BigDecimal, Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- divideForAvg(Double, Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- divideForAvg(Long, Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- divideForAvg(S, Long) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
used for computing average of data values.
- doCompare(CompareFilter.CompareOp, ByteArrayComparable, byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- doLoadColumnFamiliesOnDemand() - Method in class org.apache.hadoop.hbase.client.Scan
-
Get the logical value indicating whether on-demand CF loading should be allowed.
- DoNotRetryIOException - Exception in org.apache.hadoop.hbase
-
Subclass if exception is not meant to be retried: e.g.
- DoNotRetryIOException() - Constructor for exception org.apache.hadoop.hbase.DoNotRetryIOException
-
default constructor
- DoNotRetryIOException(String) - Constructor for exception org.apache.hadoop.hbase.DoNotRetryIOException
-
- DoNotRetryIOException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.DoNotRetryIOException
-
- DoNotRetryIOException(Throwable) - Constructor for exception org.apache.hadoop.hbase.DoNotRetryIOException
-
- DoubleColumnInterpreter - Class in org.apache.hadoop.hbase.client.coprocessor
-
a concrete column interpreter implementation.
- DoubleColumnInterpreter() - Constructor for class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- drainingZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- dropDependentColumn - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- dropDependentColumn() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- DroppedSnapshotException - Exception in org.apache.hadoop.hbase
-
Thrown during flush if the possibility snapshot content was not properly
persisted into store files.
- DroppedSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.DroppedSnapshotException
-
- DroppedSnapshotException() - Constructor for exception org.apache.hadoop.hbase.DroppedSnapshotException
-
default constructor
- dump(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
- Durability - Enum in 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 - Variable in class org.apache.hadoop.hbase.client.Mutation
-
- DURABILITY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
- Get - Class in org.apache.hadoop.hbase.client
-
Used to perform Get operations on a single row.
- Get(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Get
-
Create a Get operation for the specified row.
- Get(Get) - Constructor for class org.apache.hadoop.hbase.client.Get
-
Copy-constructor
- get(Get) - Method in class org.apache.hadoop.hbase.client.HTable
-
Extracts certain cells from a given row.
- get(List<Get>) - Method in class org.apache.hadoop.hbase.client.HTable
-
Extracts certain cells from the given rows, in batch.
- get(Get) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Extracts certain cells from a given row.
- get(List<Get>) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Extracts certain cells from the given rows, in batch.
- get(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
-
Returns a list of all KeyValue objects with matching column family and qualifier.
- get(int) - Static method in enum org.apache.hadoop.hbase.executor.EventType
-
- get() - Method in class org.apache.hadoop.hbase.ipc.BlockingRpcCallback
-
- get(ClientProtos.ClientService.BlockingInterface, byte[], Get) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A helper to invoke a Get using client protocol.
- get(ClientProtos.ClientService.BlockingInterface, byte[], Get, PayloadCarryingRpcController) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A helper to invoke a Get using client protocol.
- get(Object) - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- get() - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
-
- get() - Method in class org.apache.hadoop.hbase.util.PoolMap.ReusablePool
-
- getACL() - Method in class org.apache.hadoop.hbase.client.Mutation
-
- getACL() - Method in class org.apache.hadoop.hbase.client.Query
-
- getACLStrategy() - Method in class org.apache.hadoop.hbase.client.Mutation
-
- getACLStrategy() - Method in class org.apache.hadoop.hbase.client.Query
-
- getAction() - Method in class org.apache.hadoop.hbase.client.Action
-
- getActions() - Method in class org.apache.hadoop.hbase.client.DelayingRunner
-
- getActions() - Method in class org.apache.hadoop.hbase.security.access.Permission
-
- getAdmin(ServerName) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Establishes a connection to the region server at the specified address.
- getAdmin(ServerName, boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
You can pass master flag but nothing special is done.
- getAdmin(ServerName) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- getAdmin(ServerName, boolean) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- getAllFilters() - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Returns all known filters
- getAllPeerConfigs() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
-
List the cluster replication configs of all remote slave clusters (whether they are
enabled/disabled or connected/disconnected).
- getAllPeerConfigs() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
-
- getAllPeerIds() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
-
List the peer ids of all remote slave clusters (whether they are enabled/disabled or
connected/disconnected).
- getAllPeerIds() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
-
List all registered peer clusters and set a watch on their znodes.
- getAllQueues() - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
-
Get a list of all queues for this region server.
- getAllQueues(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueuesClient
-
Get a list of all queues for the specified region server.
- getAllQueues(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesClientZKImpl
-
- getAllQueues() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
-
- getAlterStatus(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Get the status of alter command - indicates how many regions have received
the updated schema Asynchronous operation.
- getAlterStatus(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Get the status of alter command - indicates how many regions have received
the updated schema Asynchronous operation.
- getAttribute(String) - Method in interface org.apache.hadoop.hbase.client.Attributes
-
Gets an attribute
- getAttribute(String) - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
- getAttributeSize() - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
- getAttributesMap() - Method in interface org.apache.hadoop.hbase.client.Attributes
-
Gets all attributes
- getAttributesMap() - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
- getAuthorizations() - Method in class org.apache.hadoop.hbase.client.Query
-
- getAuths(Configuration, String) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
-
- getAverageLatencyForEachRegionServer() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
- getAverageLoad() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getBackoffPolicy() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- getBackoffPolicy() - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- getBackoffPolicy() - Method in interface org.apache.hadoop.hbase.client.StatisticsHConnection
-
- getBackoffTime(ServerName, byte[], ServerStatistics) - Method in interface org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicy
-
- getBackoffTime(ServerName, byte[], ServerStatistics) - Method in class org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicyFactory.NoBackoffPolicy
-
- getBackoffTime(ServerName, byte[], ServerStatistics) - Method in class org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
-
- getBackupMasters() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getBackupMastersSize() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getBalancerOn() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getBaseStagingDir(Configuration) - Static method in class org.apache.hadoop.hbase.security.SecureBulkLoadUtil
-
- getBatch() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getBlocksize() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getBloomFilterType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getBufferedCounterForEachRegionServer() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
- getBytes(Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
-
- getBytes(Writable...) - Static method in class org.apache.hadoop.hbase.util.Writables
-
Put a bunch of Writables as bytes all into the one byte array.
- getCacheBlocks() - Method in class org.apache.hadoop.hbase.client.Get
-
Get whether blocks should be cached for this Get.
- getCacheBlocks() - Method in class org.apache.hadoop.hbase.client.Scan
-
Get whether blocks should be cached for this Scan.
- getCaching() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getCaching() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
Get the number of rows that will be fetched on next
- getCatalogTracker() - Method in interface org.apache.hadoop.hbase.Server
-
- getCause(int) - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getCauses() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getCellValueFromProto(HBaseProtos.BigDecimalMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- getCellValueFromProto(HBaseProtos.DoubleMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- getCellValueFromProto(HBaseProtos.LongMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- getCellValueFromProto(Q) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
This method gets the PB message corresponding to the cell type
- getCellVisibility() - Method in class org.apache.hadoop.hbase.client.Mutation
-
- getChance() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
- getChildDataAndWatchForNewChildren(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
- getChildren(String, Watcher) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
getChildren is an idempotent operation.
- getChildren(String, boolean) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
getChildren is an idempotent operation.
- getClassLoader() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
- getClient(ServerName) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Establishes a connection to the region server at the specified address, and returns
a region client protocol.
- getClient(ServerName) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- getClusterId() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getClusterIds() - Method in class org.apache.hadoop.hbase.client.Mutation
-
- getClusterKey() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getClusterStatus() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getCode() - Method in enum org.apache.hadoop.hbase.executor.EventType
-
- getColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
- getColumnCells(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Return the Cells for the specific column.
- getColumnFamilies() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- getColumnLatest(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
- getColumnLatest(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
-
- getColumnLatestCell(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
The Cell for the most recent timestamp for a given column.
- getColumnLatestCell(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
-
The Cell for the most recent timestamp for a given column.
- getColumnOffset() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- getCompactionCompression() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getCompactionCompressionType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getCompactionState(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Get the current compaction state of a table or region.
- getCompactionState(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Get the current compaction state of a table or region.
- getComparator() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- getComparator() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- getComparator() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- getCompleteSequenceId() - Method in class org.apache.hadoop.hbase.RegionLoad
-
This does not really belong inside RegionLoad but its being done in the name of expediency.
- getCompression() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getCompressionType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.client.HTable
-
Returns the Configuration
object used by this instance.
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Returns the Configuration
object used by this instance.
- getConfiguration() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- getConfiguration() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
-
Get the configuration object required to communicate with this peer
- getConfiguration() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
-
Get the configuration object required to communicate with this peer
- getConfiguration() - Method in interface org.apache.hadoop.hbase.Server
-
Gets the configuration object for this server.
- getConfiguration() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- getConfigurationValue(String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Getter for accessing the configuration value by key.
- getConfigurationValue(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Getter for accessing the configuration value by key
- getConnection() - Method in class org.apache.hadoop.hbase.catalog.CatalogTracker
-
- getConnection() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getConnection() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
Deprecated.
- getConnection() - Method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
This method will be changed from public to package protected.
- getConnection(User, RpcClient.Call, InetSocketAddress, int, Codec, CompressionCodec) - Method in class org.apache.hadoop.hbase.ipc.RpcClient
-
- getCoprocessors() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Return the list of attached co-processor represented by their name className
- getCreateTime() - Method in class org.apache.hadoop.hbase.RegionTransition
-
- getCurrentBatchPool() - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- getCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getCurrentNrHRS() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
This method will be changed from public to package protected.
- getCurrentNrHRS() - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- getCurrentPoolSize(String) - Method in class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
- getData(String, Watcher, Stat) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
getData is an idempotent operation.
- getData(String, boolean, Stat) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
getData is an idemnpotent operation.
- getData(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Gets the current data in the unassigned node for the specified region name
or fully-qualified path.
- getData(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get znode data.
- getData() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData
-
Deprecated.
- getData() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.CreateAndFailSilent
-
- getData() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.SetData
-
- getData(boolean) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
-
Gets the data of the node.
- getDataAndWatch(ZooKeeperWatcher, String, Stat) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Gets the current data in the unassigned node for the specified region name
or fully-qualified path.
- getDataAndWatch(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get the data at the specified znode and set a watch.
- getDataAndWatch(ZooKeeperWatcher, String, Stat) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get the data at the specified znode and set a watch.
- getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getDataBlockEncodingOnDisk() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getDataLocality() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getDataNoWatch(ZooKeeperWatcher, String, Stat) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Gets the current data in the unassigned node for the specified region name
or fully-qualified path.
- getDataNoWatch(ZooKeeperWatcher, String, Stat) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get the data at the specified znode without setting a watch.
- getDaughterRegions(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Returns the daughter regions by reading the corresponding columns of the catalog table
Result.
- getDeadRegionServers() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueueInfo
-
- getDeadServerNames() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getDeadServers() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getDefaultCodec(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.RpcClient
-
- getDefaultExecutor(Configuration) - Static method in class org.apache.hadoop.hbase.client.HTable
-
- getDefaultValues() - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getDesc(List<Throwable>, List<? extends Row>, List<String>) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getDesc(Map<String, Integer>) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getDisabledOrDisablingTables(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
Gets a list of all the tables set as disabled in zookeeper.
- getDisabledOrDisablingTables(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTableReadOnly
-
Gets a list of all the tables set as disabled in zookeeper.
- getDisabledTables() - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
Gets a list of all the tables set as disabled in zookeeper.
- getDisabledTables(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
Gets a list of all the tables set as disabled in zookeeper.
- getDisabledTables(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTableReadOnly
-
Gets a list of all the tables set as disabled in zookeeper.
- getDisablingTables(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
Gets a list of all the tables set as disabling in zookeeper.
- getDropDependentColumn() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- getDurability() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Get the current durability
- getDurability() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Returns the durability setting for the table.
- getEnablingTables(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
Gets a list of all the tables set as enabling in zookeeper.
- getEncodedName() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- getEncodedNameAsBytes() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- getEncryptionKey() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Return the raw crypto key attribute for the family, or null if not set
- getEncryptionType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Return the encryption algorithm in use by this family
- getEndKey() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- getEndKeys() - Method in class org.apache.hadoop.hbase.client.HTable
-
Gets the ending row key for every region in the currently open table.
- getEventType() - Method in class org.apache.hadoop.hbase.RegionTransition
-
- getException(byte[]) - Method in class org.apache.hadoop.hbase.client.MultiResponse
-
- getExceptionMessageAdditionalDetail() - Method in class org.apache.hadoop.hbase.client.DelegatingRetryingCallable
-
- getExceptionMessageAdditionalDetail() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- getExceptionMessageAdditionalDetail() - Method in interface org.apache.hadoop.hbase.client.RetryingCallable
-
- getExceptions() - Method in class org.apache.hadoop.hbase.client.MultiResponse
-
- getExhaustiveDescription() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getExists() - Method in class org.apache.hadoop.hbase.client.Result
-
- getExpirationDate() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- getExpression() - Method in class org.apache.hadoop.hbase.security.visibility.CellVisibility
-
- getFailedCounterForEachRegionServer() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
- getFailedOn() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
-
Returns any exception thrown during service method invocation, or null
if no exception
was thrown.
- getFamilies() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getFamilies() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Returns an unmodifiable collection of all the
HColumnDescriptor
of all the column families of the table.
- getFamiliesKeys() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Returns all the column family names of the current table.
- getFamily() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- getFamily() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- getFamily(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Returns the HColumnDescriptor for a specific column family with name as
specified by the parameter column.
- getFamily() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
- getFamilyCellMap() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Method for retrieving the put's familyMap
- getFamilyMap() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the get's familyMap
- getFamilyMap() - Method in class org.apache.hadoop.hbase.client.Mutation
-
- getFamilyMap(byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Map of qualifiers to values.
- getFamilyMap() - Method in class org.apache.hadoop.hbase.client.Scan
-
Getting the familyMap
- getFamilyMapOfLongs() - Method in class 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() - Method in class org.apache.hadoop.hbase.client.Query
-
- getFilter() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getFilter() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
-
- getFilter() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
-
- getFilterArguments(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Returns the arguments of the filter from the filter string
- getFilterIfMissing() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Get whether entire row should be filtered if column is not found.
- getFilterName(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Returns the filter name given a simple filter expression
- getFilters() - Method in class org.apache.hadoop.hbase.filter.FilterList
-
Get the filters.
- getFingerprint() - Method in class org.apache.hadoop.hbase.client.Get
-
Compile the table and column family (i.e.
- getFingerprint() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Compile the column family (i.e.
- getFingerprint() - Method in class 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.
- getFingerprint() - Method in class org.apache.hadoop.hbase.client.Scan
-
Compile the table and column family (i.e.
- getHBaseVersion() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getHBaseVersion() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
- getHeapOccupancyPercent() - Method in class org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
-
- getHostAndPort() - Method in class org.apache.hadoop.hbase.ServerName
-
- getHostname() - Method in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
-
- getHostname() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- getHostname() - Method in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
-
- getHostname() - Method in class org.apache.hadoop.hbase.ServerName
-
- getHostnamePort(int) - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getHostnamePort() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- getHRegionInfo(Result) - Static method in class org.apache.hadoop.hbase.client.MetaScanner
-
Returns HRegionInfo object from the column
HConstants.CATALOG_FAMILY:HConstants.REGIONINFO_QUALIFIER of the catalog
table Result.
- getHRegionInfo() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- getHRegionInfo() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
- getHRegionInfo(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Returns HRegionInfo object from the column
HConstants.CATALOG_FAMILY:HConstants.REGIONINFO_QUALIFIER of the catalog
table Result.
- getHRegionInfo(Result, byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- getHRegionInfoAndServerName(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Extract a HRegionInfo and ServerName from catalog table
Result
.
- getHTableDescriptor(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- getHTableDescriptor(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
- getHTableDescriptor(TableName) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
Connects to the master to get the table descriptor.
- getHTableDescriptor(byte[]) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- getHTableDescriptorArray(MasterProtos.GetTableDescriptorsResponse) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Get HTableDescriptor[] from GetTableDescriptorsResponse protobuf
- getHTableDescriptors(List<String>) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
- getHTableDescriptors(List<String>) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- getHTableDescriptorsByTableName(List<TableName>) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- getHTableDescriptorsByTableName(List<TableName>) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- getHTableMultiplexerStatus() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
-
- getId() - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
This method allows you to retrieve the identifier for the operation if one
was set.
- getId() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
-
Get the identifier of this peer
- getId() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
-
Get the identifier of this peer
- getId() - Method in class org.apache.hadoop.hbase.zookeeper.ZKClusterId
-
- getIdentifier() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- getInfo(String) - Static method in class org.apache.hadoop.hbase.security.SecurityInfo
-
Returns the security configuration associated with the given service name.
- getInfoServerPort() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getInputStream(InputStream) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
Get a SASL wrapped InputStream.
- getInstance() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
- getIsolationLevel() - Method in class org.apache.hadoop.hbase.client.Query
-
- getIssueDate() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- getKeepAliveMasterService() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- getKeepAliveMasterService() - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- getKeepDeletedCells() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getKeyId() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- getKind() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- getLabels() - Method in class org.apache.hadoop.hbase.security.visibility.Authorizations
-
- getLastRegion() - Method in class org.apache.hadoop.hbase.ipc.RegionCoprocessorRpcChannel
-
- getLatestVersionOnly() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Get whether only the latest version of the column value should be compared.
- getLimit() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
- getLimit() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- getListeners() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
Get a copy of current registered listeners
- getListOfRegionServers() - Method in interface org.apache.hadoop.hbase.replication.ReplicationTracker
-
Returns a list of other live region servers in the cluster.
- getListOfRegionServers() - Method in class org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl
-
Return a snapshot of the current region servers.
- getListOfReplicators() - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
-
Get a list of all region servers that have outstanding replication queues.
- getListOfReplicators() - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueuesClient
-
Get a list of all region servers that have outstanding replication queues.
- getListOfReplicators() - Method in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
-
- getLoad(ServerName) - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getLoad() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Originally, this method factored in the effect of requests going to the
server as well.
- getLoadColumnFamiliesOnDemandValue() - Method in class org.apache.hadoop.hbase.client.Scan
-
Get the raw loadColumnFamiliesOnDemand setting; if it's not set, can be null.
- getLoadSequence() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
- getLocation() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- getLocationSeqNum() - Method in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
-
- getLogPosition(String, String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
-
Get the current position for a specific HLog in a given queue.
- getLogPosition(String, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
-
- getLogsInQueue(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
-
Get a list of all HLogs in the given queue.
- getLogsInQueue(String, String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueuesClient
-
Get a list of all HLogs in the given queue on the given region server.
- getLogsInQueue(String, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesClientZKImpl
-
- getLogsInQueue(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
-
- getMap() - Method in class org.apache.hadoop.hbase.client.Result
-
Map of families to all versions of its qualifiers and values.
- getMaster() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- getMaster() - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- getMaster() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
Returns detailed information about the current master
ServerName
.
- getMasterAddress() - Method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
Get the address of the current master if one is available.
- getMasterAddress(boolean) - Method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
Get the address of the current master if one is available.
- getMasterAddress(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
Get master address.
- getMasterAddressZNode() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- getMasterCoprocessors() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getMasterCoprocessors() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getMaxColumn() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- getMaxColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- getMaxFileSize() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Returns the maximum size upto which a region can grow to after which a region
split is triggered.
- getMaxHeapMB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getMaxKeyValueSize(Configuration) - Static method in class org.apache.hadoop.hbase.client.HTable
-
- getMaxKeyValueSize() - Method in class org.apache.hadoop.hbase.client.TableConfiguration
-
- getMaxLatency() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
- getMaxLatencyForEachRegionServer() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
- getMaxResultSize() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getMaxResultsPerColumnFamily() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the get's maximum number of values
to return per Column Family
- getMaxResultsPerColumnFamily() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getMaxValue() - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- getMaxValue() - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- getMaxValue() - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- getMaxValue() - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
returns the maximum value for this type T
- getMaxVersions() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the get's maximum number of version
- getMaxVersions() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getMaxVersions() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getMechanismName() - Method in enum org.apache.hadoop.hbase.security.AuthMethod
-
Return the SASL mechanism name
- getMemStoreFlushSize() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Returns the size of the memstore after which a flush to filesystem is triggered.
- getMemstoreLoadPercent() - Method in class org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
-
- getMemstoreSizeInMB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getMemStoreSizeMB() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getMergeRegions(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Returns the merge regions by reading the corresponding columns of the catalog table
Result.
- getMessage() - Method in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
-
- getMetaLocation() - Method in class org.apache.hadoop.hbase.catalog.CatalogTracker
-
Gets the current location for hbase:meta
or null if location is
not currently available.
- getMetaOperationTimeout() - Method in class org.apache.hadoop.hbase.client.TableConfiguration
-
- getMetaRegionLocation() - Method in class org.apache.hadoop.hbase.zookeeper.MetaRegionTracker
-
Gets the meta region location, if available.
- getMetaRegionLocation(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.MetaRegionTracker
-
Gets the meta region location, if available.
- getMetaRegionState() - Method in class org.apache.hadoop.hbase.catalog.CatalogTracker
-
Get meta region state
- getMetaRegionState() - Method in class org.apache.hadoop.hbase.zookeeper.MetaRegionTracker
-
Get meta region state
- getMethod() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
-
- getMetricsMap() - Method in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
Get all of the values since the last time this function was called.
- getMin() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
Gets the minimum timestamp requested by filter.
- getMinColumn() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- getMinColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- getMinValue() - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- getMinValue() - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- getMinValue() - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- getMinValue() - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
- getMinVersions() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getMutations() - Method in class org.apache.hadoop.hbase.client.RowMutations
-
- getName() - Method in class org.apache.hadoop.hbase.client.HTable
-
- getName() - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Gets the fully qualified table name instance of this table.
- getName() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getName() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Get the name of the table as a byte array.
- getName() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getNameAsString() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getNameAsString() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Get the name of the table as a String
- getNameAsString() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getNamespace() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
- getNamespaceDescriptor(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Get a namespace descriptor by name
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- getNextCellHint(Cell) - Method in class 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) - Method in class 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) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
-
Old filter wrapper descendants will implement KV getNextKeyHint(KV) so we should call it.
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- getNextKeyHint(KeyValue) - Method in class org.apache.hadoop.hbase.filter.Filter
-
Deprecated.
- getNextKeyHint(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
Deprecated.
- getNextKeyHint(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
Deprecated.
- getNextKeyHint(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
-
Deprecated.
- getNode() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData
-
Deprecated.
- getNode() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
-
- getNodeName(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Gets the full path node name for the unassigned node for the specified
region.
- getNodeName(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get the name of the current node from the specified fully-qualified path.
- getNonce() - Method in class org.apache.hadoop.hbase.client.Action
-
- getNonceGenerator() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- getNonceGenerator() - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- getNonceGroup() - Method in class org.apache.hadoop.hbase.client.MultiAction
-
- getNonceGroup() - Method in interface org.apache.hadoop.hbase.client.NonceGenerator
-
- getNonceGroup() - Method in class org.apache.hadoop.hbase.client.PerClientRandomNonceGenerator
-
- getNoVersionMap() - Method in class org.apache.hadoop.hbase.client.Result
-
Map of families to their most recent qualifiers and values.
- getNumberOfChildren(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get the number of children of the specified node.
- getNumberOfListeners() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- getNumberOfRegions() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getNumberOfRequests() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getNumExceptions() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getOffset() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- getOnlineRegions(ServerName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Get all the online regions on a region server.
- getOnlineRegions(AdminProtos.AdminService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A helper to get the all the online regions on a region
server using admin protocol.
- getOperationTimeout() - Method in class org.apache.hadoop.hbase.client.HTable
-
- getOperationTimeout() - Method in class org.apache.hadoop.hbase.client.TableConfiguration
-
- getOperator() - Method in class org.apache.hadoop.hbase.filter.BitComparator
-
- getOperator() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- getOperator() - Method in class org.apache.hadoop.hbase.filter.FilterList
-
Get the operator.
- getOperator() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- getOriginalIndex() - Method in class org.apache.hadoop.hbase.client.Action
-
- getOutputStream(OutputStream) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
Get a SASL wrapped OutputStream.
- getOverallAverageLatency() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
- getOwnerString() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- getPageSize() - Method in class org.apache.hadoop.hbase.filter.PageFilter
-
- getParent(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Returns the full path of the immediate parent of the specified node.
- getParsedGenericInstance(Class<?>, int, ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Get an instance of the argument type declared in a class's signature.
- getPath(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
- getPath() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
-
- getPauseTime(long, int) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
Calculate pause time.
- getPayload() - Method in class org.apache.hadoop.hbase.RegionTransition
-
- getPeer(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
-
Returns the ReplicationPeer
- getPeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
-
- getPeerClusterZnode() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueueInfo
-
- getPeerConf(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
-
Returns the configuration needed to talk to the remote slave cluster.
- getPeerConf(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
-
- getPeerConfig(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- getPeerConfig() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
-
Get the peer config object
- getPeerConfig() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
-
Get the peer config object
- getPeerData() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getPeerId() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueueInfo
-
- getPeerIds() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
-
Returns the set of peerIds defined
- getPeerIds() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
-
- getPeersCount() - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Get the number of slave clusters the local cluster has.
- getPeerState(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Get the state of the specified peer cluster
- getPeerState() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
-
Returns the state of the peer
- getPeerState() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
-
- getPeerTableCFs(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Get the replicable table-cf config of the specified peer.
- getPeerTableCFsConfig(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
-
Get the table and column-family list string of the peer from ZK.
- getPeerTableCFsConfig(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
-
- getPoolSize(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.RpcClient
-
- getPoolType(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.RpcClient
-
- getPort() - Method in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
-
- getPort() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- getPort() - Method in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
-
- getPort() - Method in class org.apache.hadoop.hbase.ServerName
-
- getPrefix() - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
- getPrefix() - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- getPrefix() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
-
- getPriority() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
- getPriority() - Method in class org.apache.hadoop.hbase.ipc.DelegatingPayloadCarryingRpcController
-
- getPriority() - Method in class org.apache.hadoop.hbase.ipc.PayloadCarryingRpcController
-
- getPromotedValueFromProto(HBaseProtos.BigDecimalMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- getPromotedValueFromProto(HBaseProtos.DoubleMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- getPromotedValueFromProto(HBaseProtos.LongMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- getPromotedValueFromProto(R) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
This method gets the promoted type from the proto message
- getProtocol() - Method in exception org.apache.hadoop.hbase.exceptions.UnknownProtocolException
-
- getProtoForCellType(BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- getProtoForCellType(Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- getProtoForCellType(Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- getProtoForCellType(T) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
This method gets the PB message corresponding to the cell type
- getProtoForPromotedType(BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- getProtoForPromotedType(Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- getProtoForPromotedType(Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- getProtoForPromotedType(S) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
This method gets the PB message corresponding to the promoted type
- getQualifier() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- getQualifier() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- getQualifier() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
- getQuorum() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
Get the quorum address of this instance.
- getReadRequestsCount() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getReadRequestsCount() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getRecoverableZooKeeper() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
Get the connection to ZooKeeper.
- getRegion(CatalogTracker, byte[]) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
-
Gets the region info and assignment for the specified region.
- getRegion() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
-
- getRegion() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- getRegionCachePrefetch(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Check whether region cache prefetch is enabled or not.
- getRegionCachePrefetch(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- getRegionCachePrefetch(TableName) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- getRegionCachePrefetch(byte[]) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- getRegionCachePrefetch(Configuration, byte[]) - Static method in class org.apache.hadoop.hbase.client.HTable
-
Check whether region cache prefetch is enabled or not for the table.
- getRegionCachePrefetch(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.client.HTable
-
- getRegionCachePrefetch(byte[]) - Static method in class org.apache.hadoop.hbase.client.HTable
-
Check whether region cache prefetch is enabled or not for the table.
- getRegionCachePrefetch(TableName) - Static method in class org.apache.hadoop.hbase.client.HTable
-
- getRegionCount(Configuration, String) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
-
Count regions in hbase:meta
for passed table.
- getRegionEncodedName(HBaseProtos.RegionSpecifier) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Find the HRegion encoded name based on a region specifier
- getRegionId() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- getRegionInfo() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- getRegionInfo(AdminProtos.AdminService.BlockingInterface, byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A helper to retrieve region info given a region name
using admin protocol.
- getRegionInfos(AdminProtos.GetOnlineRegionResponse) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
-
Get the list of region info from a GetOnlineRegionResponse
- getRegionLocation(TableName, byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Find region location hosting passed row
- getRegionLocation(byte[], byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
- getRegionLocation(TableName, byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- getRegionLocation(byte[], byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- getRegionLocation(String) - Method in class org.apache.hadoop.hbase.client.HTable
-
Find region location hosting passed row using cached info
- getRegionLocation(byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
-
Finds the region on which the given row is being served.
- getRegionLocation(byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HTable
-
Finds the region on which the given row is being served.
- getRegionLocations() - Method in class org.apache.hadoop.hbase.client.HTable
-
Gets all the regions and their address for this table.
- getRegionName() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- getRegionName() - Method in class org.apache.hadoop.hbase.RegionTransition
-
- getRegionName(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Gets the region name from the full path node name of an unassigned node.
- getRegionNameAsString() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- getRegionOpeningState(AdminProtos.OpenRegionResponse) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
-
Get the region opening state from a OpenRegionResponse
- getRegionOpeningStateList(AdminProtos.OpenRegionResponse) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
-
Get a list of region opening state from a OpenRegionResponse
- getRegionResult(CatalogTracker, byte[]) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
-
Gets the result in hbase:meta for the specified region.
- getRegions() - Method in class org.apache.hadoop.hbase.client.MultiAction
-
- getRegions(AdminProtos.RollWALWriterResponse) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
-
Get the list of regions to flush from a RollLogWriterResponse
- getRegionsCount() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getRegionServerCoprocessors() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Return the RegionServer-level coprocessors
- getRegionsFromMergeQualifier(CatalogTracker, byte[]) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
-
Get regions from the merge qualifier of the specified merged region
- getRegionsInRange(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
-
Get the corresponding regions for an arbitrary range of keys.
- getRegionsInRange(byte[], byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HTable
-
Get the corresponding regions for an arbitrary range of keys.
- getRegionsInTransition() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getRegionsLoad() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getRegionSplitPolicyClassName() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
This gets the class associated with the region split policy which
determines when a region split should occur.
- getRemoteAddress() - Method in class org.apache.hadoop.hbase.ipc.RpcClient.Connection
-
- getRemoteException(ServiceException) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Return the IOException thrown by the remote server wrapped in
ServiceException as cause.
- getReplicationEndpointImpl() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getReplicationPeerConfig(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
-
Returns the configured ReplicationPeerConfig for this peerId
- getReplicationPeerConfig(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
-
- getReplicationPeers(ZooKeeperWatcher, Configuration, Abortable) - Static method in class org.apache.hadoop.hbase.replication.ReplicationFactory
-
- getReplicationQueues(ZooKeeperWatcher, Configuration, Abortable) - Static method in class org.apache.hadoop.hbase.replication.ReplicationFactory
-
- getReplicationQueuesClient(ZooKeeperWatcher, Configuration, Abortable) - Static method in class org.apache.hadoop.hbase.replication.ReplicationFactory
-
- getReplicationTracker(ZooKeeperWatcher, ReplicationPeers, Configuration, Abortable, Stoppable) - Static method in class org.apache.hadoop.hbase.replication.ReplicationFactory
-
- getRequest() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
-
- getRequestData() - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- getRequestData() - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- getRequestData() - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- getRequestData() - Method in class 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() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getRequestsCount() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getRequestsPerSecond() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getResults() - Method in class org.apache.hadoop.hbase.client.MultiResponse
-
- getResults(ClientProtos.MultiRequest, ClientProtos.MultiResponse, CellScanner) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
-
Get the results from a protocol buffer MultiResponse
- getResults(CellScanner, ClientProtos.ScanResponse) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
-
Create Results from the cells using the cells meta data.
- getRetriesNumber() - Method in class org.apache.hadoop.hbase.client.TableConfiguration
-
- getRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getRow() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the get's row
- getRow() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Method for retrieving the delete's row
- getRow() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
-
- getRow() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- getRow() - Method in class 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) - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getRow() - Method in interface org.apache.hadoop.hbase.client.Row
-
- getRow() - Method in class org.apache.hadoop.hbase.client.RowMutations
-
- getRowOffsetPerColumnFamily() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the get's offset per row per column
family (#kvs to be skipped)
- getRowOffsetPerColumnFamily() - Method in class org.apache.hadoop.hbase.client.Scan
-
Method for retrieving the scan's offset per row per column
family (#kvs to be skipped)
- getRowOrBefore(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
-
Return the row that matches row exactly,
or the one that immediately precedes it.
- getRowOrBefore(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Deprecated.
As of version 0.92 this method is deprecated without
replacement.
getRowOrBefore is used internally to find entries in hbase:meta and makes
various assumptions about the table (which are true for hbase:meta but not
in general) to be efficient.
- getRowOrBefore(ClientProtos.ClientService.BlockingInterface, byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A helper to get a row of the closet one before using client protocol without setting any
special (i.e.
- getRowOrBefore(ClientProtos.ClientService.BlockingInterface, byte[], byte[], byte[], PayloadCarryingRpcController) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A helper to get a row of the closet one before using client protocol.
- getRpcTimeout() - Static method in class org.apache.hadoop.hbase.ipc.RpcClient
-
- getRpcTimeout(int) - Static method in class org.apache.hadoop.hbase.ipc.RpcClient
-
- getRsCoprocessors() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Return the RegionServer-level and Region-level coprocessors
- getSaslQop() - Method in enum org.apache.hadoop.hbase.security.SaslUtil.QualityOfProtection
-
- getScan() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getScan() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
- getScanForTableName(TableName) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
-
This method creates a Scan object that will only scan catalog rows that
belong to the specified table.
- getScanMetrics() - Method in class org.apache.hadoop.hbase.client.AbstractClientScanner
-
- getScanner(Scan) - Method in class org.apache.hadoop.hbase.client.HTable
-
Returns a scanner on the current table as specified by the
Scan
object.
- getScanner(byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
-
Gets a scanner on the current table for the given family.
- getScanner(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
-
Gets a scanner on the current table for the given family and qualifier.
- getScanner(Scan) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Returns a scanner on the current table as specified by the
Scan
object.
- getScanner(byte[]) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Gets a scanner on the current table for the given family.
- getScanner(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Gets a scanner on the current table for the given family and qualifier.
- getScannerCaching() - Method in class org.apache.hadoop.hbase.client.HTable
-
- getScannerCaching() - Method in class org.apache.hadoop.hbase.client.TableConfiguration
-
- getScannerCallable(byte[], int) - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getScannerCallable(byte[], int, byte[]) - Method in class org.apache.hadoop.hbase.client.ReversedClientScanner
-
- getScope() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getSeqNum() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- getSeqNumDuringOpen(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
The latest seqnum that the server writing to meta observed when opening the region.
- getSequenceNumber() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- getServerInfo() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getServerInfo(AdminProtos.AdminService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A helper to get the info of a region server using admin protocol.
- getServerName() - Method in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
-
- getServerName(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- getServerName() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- getServerName() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- getServerName() - Method in class org.apache.hadoop.hbase.RegionTransition
-
- getServerName() - Method in interface org.apache.hadoop.hbase.Server
-
- getServerName() - Method in class org.apache.hadoop.hbase.ServerName
-
- getServerName(String, long) - Static method in class org.apache.hadoop.hbase.ServerName
-
- getServerNameLessStartCode(String) - Static method in class org.apache.hadoop.hbase.ServerName
-
Utility method to excise the start code from a server name
- getServerPrincipal() - Method in class org.apache.hadoop.hbase.security.SecurityInfo
-
- getServers() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getServersSize() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getServerStartcodeFromServerName(String) - Static method in class org.apache.hadoop.hbase.ServerName
-
- getServerStats(String, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Gets the statistics from the given server.
- getServerUserRegions(CatalogTracker, ServerName) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
-
- getSessionId() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- getSessionPasswd() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- getShortNameToLog() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- getShortTextFormat(Message) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Return short version of Message toString'd, shorter than TextFormat#shortDebugString.
- getSleepTime() - Method in class org.apache.hadoop.hbase.client.DelayingRunner
-
- getSnapshotDescription() - Method in exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
-
- getSplitKeysArray(MasterProtos.CreateTableRequest) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
get the split keys in form "byte [][]" from a CreateTableRequest proto
- getStagingPath(String, byte[]) - Method in class org.apache.hadoop.hbase.client.coprocessor.SecureBulkLoadClient
-
- getStagingPath(Configuration, String, byte[]) - Static method in class org.apache.hadoop.hbase.security.SecureBulkLoadUtil
-
This returns the staging path for a given column family.
- getStamp() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- getStartcode() - Method in class org.apache.hadoop.hbase.ServerName
-
- getStartEndKeys() - Method in class org.apache.hadoop.hbase.client.HTable
-
Gets the starting and ending row keys for every region in the currently
open table.
- getStartKey(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Gets the start key from the specified region name.
- getStartKey() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- getStartKeys() - Method in class org.apache.hadoop.hbase.client.HTable
-
Gets the starting row key for every region in the currently open table.
- getStartRow() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getStartTime() - Method in class org.apache.hadoop.hbase.ipc.RpcClient.Call
-
- getState() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- getState() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- getStatisticsTracker() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- getStatisticsTracker() - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- getStatisticsTracker() - Method in interface org.apache.hadoop.hbase.client.StatisticsHConnection
-
- getStats() - Method in class org.apache.hadoop.hbase.client.Result
-
- getStats(ServerName) - Method in class org.apache.hadoop.hbase.client.ServerStatisticTracker
-
- getStatsForRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.backoff.ServerStatistics
-
- getStatusOfPeer(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
-
Get the replication status for the specified connected remote slave cluster.
- getStatusOfPeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
-
- getStatusOfPeerFromBackingStore(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
-
Get the replication status for the specified remote slave cluster, which doesn't
have to be connected.
- getStatusOfPeerFromBackingStore(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
-
- getStopRow() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getStopRowKey() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
-
- getStorefileIndexSizeInMB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getStoreFiles(AdminProtos.AdminService.BlockingInterface, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A helper to get the list of files of a column family
on a given region using admin protocol.
- getStorefiles() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getStorefiles() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getStorefileSizeInMB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getStorefileSizeMB() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getStores() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getStores() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getStoreUncompressedSizeMB() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getStoreUncompressedSizeMB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getStub() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- getSupportedFilters() - Method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Return a Set of filters supported by the Filter Language
- getTable() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getTable(String) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Retrieve an HTableInterface implementation for access to a table.
- getTable(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Retrieve an HTableInterface implementation for access to a table.
- getTable(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Retrieve an HTableInterface implementation for access to a table.
- getTable(String, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Retrieve an HTableInterface implementation for access to a table.
- getTable(byte[], ExecutorService) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Retrieve an HTableInterface implementation for access to a table.
- getTable(TableName, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Retrieve an HTableInterface implementation for access to a table.
- getTable(String) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- getTable(byte[]) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- getTable(TableName) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- getTable(String, ExecutorService) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- getTable(byte[], ExecutorService) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- getTable(TableName, ExecutorService) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- getTable(String) - Method in class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
Get a reference to the specified table from the pool.
- getTable(byte[]) - Method in class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
Get a reference to the specified table from the pool.
- getTable(TableName) - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
- getTable(TableName, ExecutorService) - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
- getTable(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Gets the table name from the specified region name.
- getTable() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Get current table name of the region
- getTableCFs() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
-
Get replicable (table, cf-list) map of this peer
- getTableCFs(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
-
Get the table and column-family-list map of the peer.
- getTableCFs(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
-
- getTableCFs() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
-
Get replicable (table, cf-list) map of this peer
- getTableDescriptor(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Method for getting the tableDescriptor
- getTableDescriptor(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getTableDescriptor() - Method in class org.apache.hadoop.hbase.client.HTable
-
- getTableDescriptor() - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
- getTableDescriptors(List<String>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Get tableDescriptors
- getTableDescriptorsByTableName(List<TableName>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Get tableDescriptors
- getTableDir(Path, byte[]) - Static method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- getTableName() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getTableName() - Method in class org.apache.hadoop.hbase.client.HTable
-
Gets the name of this table.
- getTableName() - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Gets the name of this table.
- getTableName() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- getTableName(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
Since 0.96.0; use #getTable(byte[])
- getTableName() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
Since 0.96.0; use #getTable()
- getTableName() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Get the name of the table
- getTableName() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
- getTableNameArray(List<HBaseProtos.TableName>) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- getTableNames() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Deprecated.
- getTableNames(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Deprecated.
- getTableNames(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Deprecated.
- getTableNames() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
- getTableNames() - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- getTableRegions(CatalogTracker, TableName) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
-
Gets all of the regions of the specified table.
- getTableRegions(CatalogTracker, TableName, boolean) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
-
Gets all of the regions of the specified table.
- getTableRegions(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
get the regions of a given table.
- getTableRegions(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getTableRegionsAndLocations(CatalogTracker, TableName) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
-
- getTableRegionsAndLocations(CatalogTracker, TableName, boolean) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
-
- getTimeRange() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the get's TimeRange
- getTimeRange() - Method in class org.apache.hadoop.hbase.client.Increment
-
Gets the TimeRange used for this increment.
- getTimeRange() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getTimeStamp() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Method for retrieving the timestamp
- getTimestamps() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
- getTimeToLive() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getTokenKind() - Method in class org.apache.hadoop.hbase.security.SecurityInfo
-
- getTotalBufferedCounter() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
- getTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getTotalFailedCounter() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
- getTotalNumberOfRequests() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getTotalRequestsCount(ClusterStatusProtos.RegionLoad) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- getTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getTTL() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Return the TTL requested for the result of the mutation, in milliseconds.
- getUnit(String) - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getUsedHeapMB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getUser() - Method in class org.apache.hadoop.hbase.security.access.UserPermission
-
- getUser() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- getUsername() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- getUserPermissions(AccessControlProtos.AccessControlService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A utility used to get user's global permissions.
- getUserPermissions(AccessControlProtos.AccessControlService.BlockingInterface, TableName) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A utility used to get user table permissions.
- getUserPermissions(AccessControlProtos.AccessControlService.BlockingInterface, byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A utility used to get permissions for selected namespace.
- getUserPermissions(Configuration, String) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
List all the userPermissions matching the given pattern.
- getUUIDForCluster(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKClusterId
-
Get the UUID for the provided ZK watcher.
- getValue(byte[], byte[], Cell) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- getValue(byte[], byte[], Cell) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- getValue(byte[], byte[], Cell) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- getValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Get the latest version of the specified column.
- getValue(byte[], byte[], Cell) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
- getValue(byte[], byte[], KeyValue) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
Deprecated.
- getValue() - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
-
- getValue() - Method in class org.apache.hadoop.hbase.filter.SubstringComparator
-
- getValue(byte[]) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getValue(String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getValue(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Getter for accessing the metadata associated with the key
- getValue(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Getter for accessing the metadata associated with the key
- getValueAsByteBuffer(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Returns the value wrapped in a new ByteBuffer
.
- getValueAsByteBuffer(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
-
Returns the value wrapped in a new ByteBuffer
.
- getValues() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getValues() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- getVersion() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getVersion() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
- getVersion() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
HRI is no longer a VersionedWritable
- getVersion() - Method in class org.apache.hadoop.hbase.security.access.Permission
-
- getVersion(ZooKeeperWatcher, HRegionInfo) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Get the version of the specified znode
- getVersionedBytes() - Method in class org.apache.hadoop.hbase.ServerName
-
- getWatcher() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperListener
-
- getWritable(byte[], Writable) - Static method in class 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) - Static method in class org.apache.hadoop.hbase.util.Writables
-
Set bytes into the passed Writable by calling its
Writable.readFields(java.io.DataInput)
.
- getWriteBuffer() - Method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
since 0.96. This is an internal buffer that should not be read nor write.
- getWriteBufferSize() - Method in class org.apache.hadoop.hbase.client.HTable
-
Returns the maximum size in bytes of the write buffer for this HTable.
- getWriteBufferSize() - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Returns the maximum size in bytes of the write buffer for this HTable.
- getWriteBufferSize() - Method in class org.apache.hadoop.hbase.client.TableConfiguration
-
- getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getWriteToWAL() - Method in class org.apache.hadoop.hbase.client.Mutation
-
- getZKQuorumServersString(Properties) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
-
Return the ZK Quorum servers string given zk properties returned by
makeZKProps
- getZKQuorumServersString(Configuration) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
-
Return the ZK Quorum servers string given the specified configuration.
- getZooKeeper() - Method in interface org.apache.hadoop.hbase.Server
-
Gets the ZooKeeper instance for this server.
- getZooKeeper() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- getZooKeeperClusterKey(Configuration) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get the key to the ZK ensemble for this configuration without
adding a name at the end
- getZooKeeperClusterKey(Configuration, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get the key to the ZK ensemble for this configuration and append
a name at the end
- grant(AccessControlProtos.AccessControlService.BlockingInterface, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A utility used to grant a user global permissions.
- grant(AccessControlProtos.AccessControlService.BlockingInterface, String, TableName, byte[], byte[], Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A utility used to grant a user table permissions.
- grant(AccessControlProtos.AccessControlService.BlockingInterface, String, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A utility used to grant a user namespace permissions.
- grant(Configuration, TableName, String, byte[], byte[], Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
Grants permission on the specified table for the specified user
- grant(Configuration, String, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
Grants permission on the specified namespace for the specified user.
- grant(Configuration, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
Grant global permissions for the specified user.
- grant(Configuration, TableName, String, byte[], byte[], AccessControlProtos.Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
- GREATER_THAN_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
GREATER_THAN Array
- GREATER_THAN_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
- GREATER_THAN_OR_EQUAL_TO_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
GREATER_THAN_OR_EQUAL_TO Array
- GREATER_THAN_OR_EQUAL_TO_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
- H - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'H'
- has(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
-
A convenience method to determine if this object's familyMap contains
a value assigned to the given family & qualifier.
- has(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Put
-
A convenience method to determine if this object's familyMap contains
a value assigned to the given family, qualifier and timestamp.
- has(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
-
A convenience method to determine if this object's familyMap contains
a value assigned to the given family, qualifier and timestamp.
- has(byte[], byte[], long, byte[]) - Method in class org.apache.hadoop.hbase.client.Put
-
A convenience method to determine if this object's familyMap contains
the given value assigned to the given family, qualifier and timestamp.
- hasCoprocessor(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Check if the table has an attached co-processor represented by the name className
- hasFamilies() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for checking if any families have been inserted into this Get
- hasFamilies() - Method in class org.apache.hadoop.hbase.client.Increment
-
Method for checking if any families have been inserted into this Increment
- hasFamilies() - Method in class org.apache.hadoop.hbase.client.Scan
-
- hasFamily(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Checks to see if this table contains the given column family
- hasFamily() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
- hasFilter() - Method in class org.apache.hadoop.hbase.client.Scan
-
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.Filter
-
Primarily used to check for conflicts with scans(such as scans that do not read a full row at a
time).
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
Fitlers that never filter by modifying the returned List of Cells can
inherit this implementation that does nothing.
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
-
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.PageFilter
-
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
-
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
-
- hasFoundKV() - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
-
- hashCode() - Method in class org.apache.hadoop.hbase.client.Action
-
- hashCode() - Method in class org.apache.hadoop.hbase.client.Get
-
- hashCode() - Method in class org.apache.hadoop.hbase.client.Increment
-
- hashCode() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
-
- hashCode() - Method in class org.apache.hadoop.hbase.client.RowMutations
-
- hashCode() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- hashCode() - Method in class org.apache.hadoop.hbase.filter.NullComparator
-
- hashCode() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- hashCode() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- hashCode() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- hashCode() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- hashCode() - Method in class org.apache.hadoop.hbase.ipc.RpcClient.ConnectionId
-
- hashCode() - Method in class org.apache.hadoop.hbase.master.RegionState
-
Don't count timestamp in hash code calculation
- hashCode() - Method in class org.apache.hadoop.hbase.security.access.Permission
-
- hashCode() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
- hashCode() - Method in class org.apache.hadoop.hbase.security.access.UserPermission
-
- hashCode() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- hashCode() - Method in class org.apache.hadoop.hbase.ServerName
-
- hashCode() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.CreateAndFailSilent
-
- hashCode() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.DeleteNodeFailSilent
-
- hashCode() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.SetData
-
- hasHigherPriority(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Returns which operator has higher precedence
- hasId() - Method in class org.apache.hadoop.hbase.zookeeper.ZKClusterId
-
- hasLeader() - Method in class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
-
Deprecated.
- hasMaster() - Method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
Check if there is a master available.
- hasMaxHeapMB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- hasNamespace() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
- hasNonce() - Method in class org.apache.hadoop.hbase.client.Action
-
- hasNonceGroup() - Method in class org.apache.hadoop.hbase.client.MultiAction
-
- hasNumberOfRequests() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- hasQualifier() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
- hasTable() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
- hasTotalNumberOfRequests() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- hasUsedHeapMB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- HBASE_CLIENT_CONNECTION_IMPL - Static variable in interface org.apache.hadoop.hbase.client.HConnection
-
Key for configuration in Configuration whose value is the class we implement making a
new HConnection instance.
- HBaseAdmin - Class in org.apache.hadoop.hbase.client
-
Provides an interface to manage HBase database table metadata + general
administrative functions.
- HBaseAdmin(Configuration) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin
-
Constructor.
- HBaseAdmin(HConnection) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin
-
Constructor for externally managed HConnections.
- HBaseException - Exception in org.apache.hadoop.hbase.exceptions
-
Base checked exception in HBase.
- HBaseException() - Constructor for exception org.apache.hadoop.hbase.exceptions.HBaseException
-
- HBaseException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.HBaseException
-
- HBaseException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.HBaseException
-
- HBaseException(Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.HBaseException
-
- HBaseSaslRpcClient - Class in org.apache.hadoop.hbase.security
-
A utility class that encapsulates SASL logic for RPC client.
- HBaseSaslRpcClient(AuthMethod, Token<? extends TokenIdentifier>, String, boolean) - Constructor for class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
Create a HBaseSaslRpcClient for an authentication method
- HBaseSaslRpcClient(AuthMethod, Token<? extends TokenIdentifier>, String, boolean, String) - Constructor for class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
Create a HBaseSaslRpcClient for an authentication method
- HBaseSnapshotException - Exception in org.apache.hadoop.hbase.snapshot
-
General exception base class for when a snapshot fails
- HBaseSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
-
Some exception happened for a snapshot and don't even know the snapshot that it was about
- HBaseSnapshotException(String, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
-
Exception for the given snapshot that has no previous root cause
- HBaseSnapshotException(String, Throwable, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
-
Exception for the given snapshot due to another exception
- HBaseSnapshotException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
-
Exception when the description of the snapshot cannot be determined, due to some root other
root cause
- HColumnDescriptor - Class in org.apache.hadoop.hbase
-
An HColumnDescriptor contains information about a column family such as the
number of versions, compression settings, etc.
- HColumnDescriptor() - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
Used by Writables and Writables are going away.
- HColumnDescriptor(String) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
-
Construct a column descriptor specifying only the family name
The other attributes are defaulted.
- HColumnDescriptor(byte[]) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
-
Construct a column descriptor specifying only the family name
The other attributes are defaulted.
- HColumnDescriptor(HColumnDescriptor) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
-
Constructor.
- HColumnDescriptor(byte[], int, String, boolean, boolean, int, String) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
-
- HColumnDescriptor(byte[], int, String, boolean, boolean, int, int, String, int) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
-
- HColumnDescriptor(byte[], int, int, KeepDeletedCells, String, boolean, String, boolean, boolean, int, int, String, int) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
-
- HConnectable<T> - Class in org.apache.hadoop.hbase.client
-
This class makes it convenient for one to execute a command in the context
of a
HConnection
instance based on the given
Configuration
.
- HConnectable(Configuration) - Constructor for class org.apache.hadoop.hbase.client.HConnectable
-
- HConnection - Interface in org.apache.hadoop.hbase.client
-
A cluster connection.
- HConnectionManager - Class in org.apache.hadoop.hbase.client
-
A non-instantiable class that manages creation of
HConnection
s.
- HConnectionManager.HConnectionImplementation - Class in org.apache.hadoop.hbase.client
-
Encapsulates connection to zookeeper and regionservers.
- HConnectionManager.HConnectionImplementation(Configuration) - Constructor for class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
For tests.
- heapSize() - Method in class org.apache.hadoop.hbase.client.Mutation
-
- hint - Variable in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- HINT_LOOKAHEAD - Static variable in class org.apache.hadoop.hbase.client.Scan
-
EXPERT ONLY.
- HQuorumPeer - Class in org.apache.hadoop.hbase.zookeeper
-
HBase's version of ZooKeeper's QuorumPeer.
- HQuorumPeer() - Constructor for class org.apache.hadoop.hbase.zookeeper.HQuorumPeer
-
- HRegionInfo - Class in org.apache.hadoop.hbase
-
HRegion information.
- HRegionInfo() - Constructor for class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
Used by Writables and Writables are going away.
- HRegionInfo(TableName) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
-
- HRegionInfo(TableName, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
-
Construct HRegionInfo with explicit parameters
- HRegionInfo(TableName, byte[], byte[], boolean) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
-
Construct HRegionInfo with explicit parameters
- HRegionInfo(TableName, byte[], byte[], boolean, long) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
-
Construct HRegionInfo with explicit parameters
- HRegionInfo(HRegionInfo) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
-
Costruct a copy of another HRegionInfo
- HRegionLocation - Class in org.apache.hadoop.hbase
-
Data structure to hold HRegionInfo and the address for the hosting
HRegionServer.
- HRegionLocation(HRegionInfo, ServerName) - Constructor for class org.apache.hadoop.hbase.HRegionLocation
-
- HRegionLocation(HRegionInfo, ServerName, long) - Constructor for class org.apache.hadoop.hbase.HRegionLocation
-
- HTable - Class in org.apache.hadoop.hbase.client
-
Used to communicate with a single HBase table.
- HTable(Configuration, String) - Constructor for class org.apache.hadoop.hbase.client.HTable
-
Creates an object to access a HBase table.
- HTable(Configuration, byte[]) - Constructor for class org.apache.hadoop.hbase.client.HTable
-
Creates an object to access a HBase table.
- HTable(Configuration, TableName) - Constructor for class org.apache.hadoop.hbase.client.HTable
-
Creates an object to access a HBase table.
- HTable(TableName, HConnection) - Constructor for class org.apache.hadoop.hbase.client.HTable
-
Creates an object to access a HBase table.
- HTable(Configuration, byte[], ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.HTable
-
Creates an object to access a HBase table.
- HTable(Configuration, TableName, ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.HTable
-
Creates an object to access a HBase table.
- HTable(byte[], HConnection, ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.HTable
-
Creates an object to access a HBase table.
- HTable(TableName, HConnection, ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.HTable
-
Creates an object to access a HBase table.
- HTable(TableName, HConnection, TableConfiguration, RpcRetryingCallerFactory, RpcControllerFactory, ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.HTable
-
Creates an object to access a HBase table.
- HTable() - Constructor for class org.apache.hadoop.hbase.client.HTable
-
For internal testing.
- HTableDescriptor - Class in org.apache.hadoop.hbase
-
HTableDescriptor contains the details about an HBase table such as the descriptors of
all the column families, is the table a catalog table, -ROOT-
or
hbase:meta
, if the table is read only, the maximum size of the memstore,
when the region split should occur, coprocessors associated with it etc...
- HTableDescriptor(TableName, HColumnDescriptor[]) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
-
INTERNAL Private constructor used internally creating table descriptors for
catalog tables, hbase:meta
and -ROOT-
.
- HTableDescriptor(TableName, HColumnDescriptor[], Map<ImmutableBytesWritable, ImmutableBytesWritable>) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
-
INTERNAL Private constructor used internally creating table descriptors for
catalog tables, hbase:meta
and -ROOT-
.
- HTableDescriptor() - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Used by Writables and Writables are going away.
- HTableDescriptor(TableName) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
-
Construct a table descriptor specifying a TableName object
- HTableDescriptor(byte[]) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- HTableDescriptor(String) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- HTableDescriptor(HTableDescriptor) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
-
Construct a table descriptor by cloning the descriptor passed as a parameter.
- HTableFactory - Class in org.apache.hadoop.hbase.client
-
- HTableFactory() - Constructor for class org.apache.hadoop.hbase.client.HTableFactory
-
Deprecated.
- HTableInterface - Interface in org.apache.hadoop.hbase.client
-
Used to communicate with a single HBase table.
- HTableInterfaceFactory - Interface in org.apache.hadoop.hbase.client
-
Defines methods to create new HTableInterface.
- HTableMultiplexer - Class in org.apache.hadoop.hbase.client
-
HTableMultiplexer provides a thread-safe non blocking PUT API across all the tables.
- HTableMultiplexer(Configuration, int) - Constructor for class org.apache.hadoop.hbase.client.HTableMultiplexer
-
- HTableMultiplexer.HTableMultiplexerStatus - Class in org.apache.hadoop.hbase.client
-
HTableMultiplexerStatus keeps track of the current status of the HTableMultiplexer.
- HTableMultiplexer.HTableMultiplexerStatus(Map<HRegionLocation, HTableMultiplexer.FlushWorker>) - Constructor for class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
- HTablePool - Class in org.apache.hadoop.hbase.client
-
- HTablePool() - Constructor for class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
Default Constructor.
- HTablePool(Configuration, int) - Constructor for class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
Constructor to set maximum versions and use the specified configuration.
- HTablePool(Configuration, int, HTableInterfaceFactory) - Constructor for class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
Constructor to set maximum versions and use the specified configuration and
table factory.
- HTablePool(Configuration, int, PoolMap.PoolType) - Constructor for class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
Constructor to set maximum versions and use the specified configuration and
pool type.
- HTablePool(Configuration, int, HTableInterfaceFactory, PoolMap.PoolType) - Constructor for class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
Constructor to set maximum versions and use the specified configuration,
table factory and pool type.
- HTableUtil - Class in org.apache.hadoop.hbase.client
-
Utility class for HTable.
- HTableUtil() - Constructor for class org.apache.hadoop.hbase.client.HTableUtil
-
- I - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'I'
- ID_ATRIBUTE - Static variable in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
- implies(Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.Permission
-
- implies(String, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
Checks that a given table operation is authorized by this permission
instance.
- implies(TableName, byte[], byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
Checks that a given table operation is authorized by this permission
instance.
- implies(TableName, KeyValue, Permission.Action) - Method in class 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 - Variable in class org.apache.hadoop.hbase.ipc.RpcClient.Connection
-
- InclusiveStopFilter - Class in org.apache.hadoop.hbase.filter
-
A Filter that stops after the given row.
- InclusiveStopFilter(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.InclusiveStopFilter
-
- IncompatibleFilterException - Exception in org.apache.hadoop.hbase.filter
-
Used to indicate a filter incompatibility
- IncompatibleFilterException() - Constructor for exception org.apache.hadoop.hbase.filter.IncompatibleFilterException
-
constructor
- IncompatibleFilterException(String) - Constructor for exception org.apache.hadoop.hbase.filter.IncompatibleFilterException
-
constructor
- increment(BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- increment(Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- increment(Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- increment(Increment) - Method in class org.apache.hadoop.hbase.client.HTable
-
Increments one or more columns within a single row.
- increment(Increment) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Increments one or more columns within a single row.
- Increment - Class in org.apache.hadoop.hbase.client
-
Used to perform Increment operations on a single row.
- Increment(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Increment
-
Create a Increment operation for the specified row.
- Increment(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.client.Increment
-
Create a Increment operation for the specified row.
- Increment(Increment) - Constructor for class org.apache.hadoop.hbase.client.Increment
-
Copy constructor
- increment(S) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
- incrementColumnValue(byte[], byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.HTable
-
- incrementColumnValue(byte[], byte[], byte[], long, boolean) - Method in class org.apache.hadoop.hbase.client.HTable
-
- incrementColumnValue(byte[], byte[], byte[], long, Durability) - Method in class org.apache.hadoop.hbase.client.HTable
-
Atomically increments a column value.
- incrementColumnValue(byte[], byte[], byte[], long) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
- incrementColumnValue(byte[], byte[], byte[], long, Durability) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Atomically increments a column value.
- incrementColumnValue(byte[], byte[], byte[], long, boolean) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
- init() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
-
Initialize the ReplicationPeers interface.
- init() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
-
- init(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
-
Initialize the region server replication queue interface.
- init() - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueuesClient
-
Initialize the replication queue client interface.
- init() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesClientZKImpl
-
- init(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
-
- initialize(HBaseProtos.EmptyMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- initialize(HBaseProtos.EmptyMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- initialize(HBaseProtos.EmptyMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- initialize(P) - Method in class 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).
- initializeScannerInConstruction() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- initializeScannerInConstruction() - Method in class org.apache.hadoop.hbase.client.ClientSmallReversedScanner
-
- initializeScannerInConstruction() - Method in class org.apache.hadoop.hbase.client.ClientSmallScanner
-
- initScanMetrics(Scan) - Method in class org.apache.hadoop.hbase.client.AbstractClientScanner
-
Check and initialize if application wants to collect scan metrics
- injectNonceGeneratorForTesting(HConnection, NonceGenerator) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
- instance - Static variable in class org.apache.hadoop.hbase.zookeeper.EmptyWatcher
-
- instantiate(Configuration, ServerStatisticTracker) - Static method in class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
-
- instantiate(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.RpcControllerFactory
-
- instantiated - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
-
- interruptedException(InterruptedException) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
Handles InterruptedExceptions in client calls.
- InvalidFamilyOperationException - Exception in org.apache.hadoop.hbase
-
Thrown if a request is table schema modification is requested but
made for an invalid family name.
- InvalidFamilyOperationException() - Constructor for exception org.apache.hadoop.hbase.InvalidFamilyOperationException
-
default constructor
- InvalidFamilyOperationException(String) - Constructor for exception org.apache.hadoop.hbase.InvalidFamilyOperationException
-
Constructor
- InvalidFamilyOperationException(Exception) - Constructor for exception org.apache.hadoop.hbase.InvalidFamilyOperationException
-
Constructor taking another exception.
- InvalidLabelException - Exception in org.apache.hadoop.hbase.security.visibility
-
- InvalidLabelException(String) - Constructor for exception org.apache.hadoop.hbase.security.visibility.InvalidLabelException
-
- InvalidRowFilterException - Exception in org.apache.hadoop.hbase.filter
-
Used to indicate an invalid RowFilter.
- InvalidRowFilterException() - Constructor for exception org.apache.hadoop.hbase.filter.InvalidRowFilterException
-
constructor
- InvalidRowFilterException(String) - Constructor for exception org.apache.hadoop.hbase.filter.InvalidRowFilterException
-
constructor
- IPC_CLIENT_FALLBACK_TO_SIMPLE_AUTH_ALLOWED_DEFAULT - Static variable in class org.apache.hadoop.hbase.ipc.RpcClient
-
- IPC_CLIENT_FALLBACK_TO_SIMPLE_AUTH_ALLOWED_KEY - Static variable in class org.apache.hadoop.hbase.ipc.RpcClient
-
- IS_META - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
INTERNAL Used by rest interface to access this metadata
attribute which denotes if it is a catalog table, either
hbase:meta
or -ROOT-
- IS_ROOT - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
INTERNAL Used by rest interface to access this metadata
attribute which denotes if the table is a -ROOT- region or not
- isAborted() - Method in interface org.apache.hadoop.hbase.Abortable
-
Check if the server or client was aborted.
- isAborted() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isAborted() - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- isAborted() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
-
- isAborted() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- isAccessControllerRunning(Configuration) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
- isAutoFlush() - Method in class org.apache.hadoop.hbase.client.HTable
-
Tells whether or not 'auto-flush' is turned on.
- isAutoFlush() - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Tells whether or not 'auto-flush' is turned on.
- isBalancerOn() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- isBlockCacheEnabled() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- isCanceled() - Method in class org.apache.hadoop.hbase.ipc.PayloadCarryingRpcController
-
- isCanceled() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
-
- isCatalogJanitorEnabled() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Query on the catalog janitor state (Enabled/Disabled?)
- isCheckExistenceOnly() - Method in class org.apache.hadoop.hbase.client.Get
-
- isClosed() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- isClosed() - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- isClosed() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isClosed(AdminProtos.CloseRegionResponse) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
-
Check if the region is closed from a CloseRegionResponse
- isClosestRowBefore() - Method in class org.apache.hadoop.hbase.client.Get
-
- isClosing() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isCompactionEnabled() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Check if the compaction enable flag of the table is true.
- isDeadServer(ServerName) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- isDeadServer(ServerName) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- isDeferredLogFlush() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- isDisabledOrEnablingTable(TableName) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
- isDisabledTable(TableName) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
- isDisabledTable(ZooKeeperWatcher, TableName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTableReadOnly
-
Go to zookeeper and see if state of table is ZooKeeperProtos.Table.State#DISABLED
.
- isDisablingOrDisabledTable(TableName) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
- isDisablingOrDisabledTable(ZooKeeperWatcher, TableName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTableReadOnly
-
Go to zookeeper and see if state of table is ZooKeeperProtos.Table.State#DISABLING
of ZooKeeperProtos.Table.State#DISABLED
.
- isDisablingTable(TableName) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
- isDoNotRetry() - Method in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
-
- isEmpty() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Method to check if the familyMap is empty
- isEmpty() - Method in class org.apache.hadoop.hbase.client.Result
-
Check if the underlying Cell [] is empty or not
- isEmpty() - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- isEmpty() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData
-
Deprecated.
- isEnabledOrDisablingTable(TableName) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
- isEnabledTable(TableName) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
- isEnabledTable(ZooKeeperWatcher, TableName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTableReadOnly
-
Go to zookeeper and see if state of table is ZooKeeperProtos.Table.State#ENABLED
.
- isEnablingOrEnabledTable(TableName) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
- isEnablingTable(TableName) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
- isFailedClose() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isFailedOpen() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.Filter
-
Check that given column family is essential for filter to check row.
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
By default, we require all scan's column families to be present.
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
-
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
The only CF this filter needs is given column family.
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
-
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
-
- isFullServerName(String) - Static method in class org.apache.hadoop.hbase.ServerName
-
- isGetScan() - Method in class org.apache.hadoop.hbase.client.Scan
-
- isGlobal() - Method in class org.apache.hadoop.hbase.security.access.UserPermission
-
Returns true if this permission describes a global user permission.
- isInMemory() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- isLegalFamilyName(byte[]) - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- isLocationAvailable() - Method in class org.apache.hadoop.hbase.zookeeper.MetaRegionTracker
-
Checks if the meta region location is available.
- isMasterRunning() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isMasterRunning() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- isMasterRunning() - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- isMaxColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- isMerged() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isMerging() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isMergingNew() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isMetaLocationAvailable() - Method in class org.apache.hadoop.hbase.catalog.CatalogTracker
-
Checks whether meta regionserver znode has some non null data.
- isMetaRegion() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- isMetaRegion() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Checks if this table is hbase:meta
region.
- isMetaTable() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- isMetaTable() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Checks if the table is a hbase:meta
table
- isMinColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- isOffline() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- isOffline() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- IsolationLevel - Enum in org.apache.hadoop.hbase.client
-
Specify Isolation levels in Scan operations.
- isOnlineSchemaChangeSupported() - Method in enum org.apache.hadoop.hbase.executor.EventType
-
- isOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isOpened() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isOpening() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isOpenOrMergingNewOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isOpenOrMergingOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isOpenOrSplittingNewOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isOpenOrSplittingOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isPBMagicPrefix(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- isPBMagicPrefix(byte[], int, int) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- isPeerPath(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
-
Determine if a ZK path points to a peer node.
- isPendingClose() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isPendingCloseOrClosing() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isPendingCloseOrClosingOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isPendingOpen() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isPendingOpenOrOpening() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isPendingOpenOrOpeningOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isProcedureFinished(String, String, Map<String, String>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Check the current state of the specified procedure.
- isQueueRecovered() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueueInfo
-
- isQuoteUnescaped(byte[], int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Returns a boolean indicating whether the quote was escaped or not
- isRaw() - Method in class org.apache.hadoop.hbase.client.Scan
-
- isReadOnly() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Check if the readOnly flag of the table is set.
- isReadyToOffline() - Method in class org.apache.hadoop.hbase.master.RegionState
-
Check if a region state can transition to offline
- isReadyToOnline() - Method in class org.apache.hadoop.hbase.master.RegionState
-
Check if a region state can transition to online
- isRegionServerRemote - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
-
- isReturnResults() - Method in class org.apache.hadoop.hbase.client.Append
-
- isReversed() - Method in class org.apache.hadoop.hbase.client.Scan
-
Get whether this scan is a reversed one.
- isReversed() - Method in class org.apache.hadoop.hbase.filter.Filter
-
- isRootRegion() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Check if the descriptor represents a -ROOT-
region.
- isSameHostnameAndPort(ServerName, ServerName) - Static method in class org.apache.hadoop.hbase.ServerName
-
- isSecureZooKeeper(Configuration) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Returns whether or not secure authentication is enabled
(whether hbase.security.authentication
is set to
kerberos
.
- isSmall() - Method in class org.apache.hadoop.hbase.client.Scan
-
Get whether this scan is a small scan
- isSnapshotFinished(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Check the current state of the passed snapshot.
- isSplit() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- isSplit() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isSplitParent() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- isSplitting() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isSplittingNew() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isStateEnabled(byte[]) - Static method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
-
Parse the raw data from ZK to get a peer's state
- isStopped() - Method in class org.apache.hadoop.hbase.catalog.CatalogTracker
-
- issueDate - Variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- isTableAvailable(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableAvailable(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableAvailable(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableAvailable(TableName, byte[][]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Use this api to check if the table has been created with the specified number of
splitkeys which was used while creating the given table.
- isTableAvailable(byte[], byte[][]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableAvailable(String, byte[][]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableAvailable(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- isTableAvailable(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
- isTableAvailable(TableName, byte[][]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Use this api to check if the table has been created with the specified number of
splitkeys which was used while creating the given table.
- isTableAvailable(byte[], byte[][]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
- isTableAvailable(TableName) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- isTableAvailable(byte[]) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- isTableAvailable(TableName, byte[][]) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- isTableAvailable(byte[], byte[][]) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- isTableDisabled(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableDisabled(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableDisabled(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableDisabled(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- isTableDisabled(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
- isTableDisabled(TableName) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- isTableDisabled(byte[]) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- isTableEnabled(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableEnabled(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableEnabled(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableEnabled(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
A table that isTableEnabled == false and isTableDisabled == false
is possible.
- isTableEnabled(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
- isTableEnabled(TableName) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- isTableEnabled(byte[]) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- isTableEnabled(String) - Static method in class org.apache.hadoop.hbase.client.HTable
-
- isTableEnabled(byte[]) - Static method in class org.apache.hadoop.hbase.client.HTable
-
- isTableEnabled(TableName) - Static method in class org.apache.hadoop.hbase.client.HTable
-
- isTableEnabled(Configuration, String) - Static method in class org.apache.hadoop.hbase.client.HTable
-
- isTableEnabled(Configuration, byte[]) - Static method in class org.apache.hadoop.hbase.client.HTable
-
- isTableEnabled(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.client.HTable
-
- isTablePresent(TableName) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
check if table is present .
- isThisOurZnode(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
-
Checks if the provided znode is the same as this region server's
- isThisOurZnode(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
-
- isUnassignable() - Method in class 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) - Static method in class 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)
- isValidLabel(byte[]) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsValidator
-
- iterator() - Method in class org.apache.hadoop.hbase.client.AbstractClientScanner
-
- R - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'R'
- random - Static variable in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
- RandomRowFilter - Class in org.apache.hadoop.hbase.filter
-
A filter that includes rows based on a chance.
- RandomRowFilter(float) - Constructor for class org.apache.hadoop.hbase.filter.RandomRowFilter
-
Create a new filter with a specified chance for a row to be included.
- raw() - Method in class org.apache.hadoop.hbase.client.Result
-
- rawCells() - Method in class org.apache.hadoop.hbase.client.Result
-
Return the array of Cells backing this Result instance.
- read() - Method in class org.apache.hadoop.hbase.ipc.RpcClient.Connection.PingInputStream
-
Read a byte from the stream.
- read(byte[], int, int) - Method in class org.apache.hadoop.hbase.ipc.RpcClient.Connection.PingInputStream
-
Read bytes into a buffer starting from offset off
Send a ping if timeout on read.
- read(DataInput) - Static method in enum org.apache.hadoop.hbase.security.AuthMethod
-
Read from in
- readClusterIdZNode(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKClusterId
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
Use protobuf deserialization instead.
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.security.access.Permission
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.security.access.UserPermission
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- READONLY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
INTERNAL Used by rest interface to access this metadata
attribute which denotes if the table is Read Only
- readResponse() - Method in class org.apache.hadoop.hbase.ipc.RpcClient.Connection
-
- reconnectAfterExpiration() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- reconnectAfterExpiration() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- RecoverableZooKeeper - Class in org.apache.hadoop.hbase.zookeeper
-
A zookeeper that can handle 'recoverable' errors.
- RecoverableZooKeeper(String, int, Watcher, int, int) - Constructor for class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- RecoverableZooKeeper(String, int, Watcher, int, int, String) - Constructor for class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- recoveringRegionsZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- reduce(Stack<ByteBuffer>, Stack<Filter>, ByteBuffer) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
-
This function is called while parsing the filterString and an operator is parsed
- regex - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsValidator
-
- RegexStringComparator - Class in org.apache.hadoop.hbase.filter
-
- RegexStringComparator(String) - Constructor for class org.apache.hadoop.hbase.filter.RegexStringComparator
-
Constructor
Adds Pattern.DOTALL to the underlying Pattern
- RegexStringComparator(String, RegexStringComparator.EngineType) - Constructor for class org.apache.hadoop.hbase.filter.RegexStringComparator
-
Constructor
Adds Pattern.DOTALL to the underlying Pattern
- RegexStringComparator(String, int) - Constructor for class org.apache.hadoop.hbase.filter.RegexStringComparator
-
Constructor
- RegexStringComparator(String, int, RegexStringComparator.EngineType) - Constructor for class org.apache.hadoop.hbase.filter.RegexStringComparator
-
Constructor
- RegexStringComparator.EngineType - Enum in org.apache.hadoop.hbase.filter
-
Engine implementation type (default=JAVA)
- regexStringType - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
RegexStringType byte array
- RegionAlreadyInTransitionException - Exception in org.apache.hadoop.hbase.regionserver
-
This exception is thrown when a region server is asked to open or close
a region but it's already processing it
- RegionAlreadyInTransitionException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.RegionAlreadyInTransitionException
-
- RegionCoprocessorRpcChannel - Class in org.apache.hadoop.hbase.ipc
-
Provides clients with an RPC connection to call coprocessor endpoint
Service
s
against a given table region.
- RegionCoprocessorRpcChannel(HConnection, TableName, byte[], RpcRetryingCallerFactory, RpcControllerFactory) - Constructor for class org.apache.hadoop.hbase.ipc.RegionCoprocessorRpcChannel
-
- RegionCoprocessorServiceExec - Class in org.apache.hadoop.hbase.client
-
Represents a coprocessor service method execution against a single region.
- RegionCoprocessorServiceExec(byte[], byte[], Descriptors.MethodDescriptor, Message) - Constructor for class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
-
- RegionException - Exception in org.apache.hadoop.hbase
-
Thrown when something happens related to region handling.
- RegionException() - Constructor for exception org.apache.hadoop.hbase.RegionException
-
default constructor
- RegionException(String) - Constructor for exception org.apache.hadoop.hbase.RegionException
-
Constructor
- RegionInRecoveryException - Exception in org.apache.hadoop.hbase.exceptions
-
Thrown when a read request issued against a region which is in recovering state.
- RegionInRecoveryException() - Constructor for exception org.apache.hadoop.hbase.exceptions.RegionInRecoveryException
-
default constructor
- RegionInRecoveryException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.RegionInRecoveryException
-
Constructor
- RegionLoad - Class in org.apache.hadoop.hbase
-
Encapsulates per-region load metrics.
- RegionLoad(ClusterStatusProtos.RegionLoad) - Constructor for class org.apache.hadoop.hbase.RegionLoad
-
- regionLoadPB - Variable in class org.apache.hadoop.hbase.RegionLoad
-
- RegionMovedException - Exception in org.apache.hadoop.hbase.exceptions
-
Subclass if the server knows the region is now on another server.
- RegionMovedException(ServerName, long) - Constructor for exception org.apache.hadoop.hbase.exceptions.RegionMovedException
-
- RegionMovedException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.RegionMovedException
-
For hadoop.ipc internal call.
- RegionOfflineException - Exception in org.apache.hadoop.hbase.client
-
Thrown when a table can not be located
- RegionOfflineException() - Constructor for exception org.apache.hadoop.hbase.client.RegionOfflineException
-
default constructor
- RegionOfflineException(String) - Constructor for exception org.apache.hadoop.hbase.client.RegionOfflineException
-
- RegionOpeningException - Exception in org.apache.hadoop.hbase.exceptions
-
Subclass if the server knows the region is now on another server.
- RegionOpeningException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.RegionOpeningException
-
- RegionOpeningState - Enum in org.apache.hadoop.hbase.regionserver
-
- regionSequenceIdsToByteArray(Long, Map<byte[], Long>) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
- RegionServerCallable<T> - Class in org.apache.hadoop.hbase.client
-
- RegionServerCallable(HConnection, TableName, byte[]) - Constructor for class org.apache.hadoop.hbase.client.RegionServerCallable
-
- RegionServerCoprocessorRpcChannel - Class in org.apache.hadoop.hbase.ipc
-
Provides clients with an RPC connection to call coprocessor endpoint
Service
s against a given region server.
- RegionServerCoprocessorRpcChannel(HConnection, ServerName) - Constructor for class org.apache.hadoop.hbase.ipc.RegionServerCoprocessorRpcChannel
-
- regionServerRemoved(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationListener
-
A region server has been removed from the local cluster
- RegionServerRunningException - Exception in 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() - Constructor for exception org.apache.hadoop.hbase.regionserver.RegionServerRunningException
-
Default Constructor
- RegionServerRunningException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.RegionServerRunningException
-
Constructs the exception and supplies a string as the message
- RegionServerStoppedException - Exception in org.apache.hadoop.hbase.regionserver
-
Thrown by the region server when it is in shutting down state.
- RegionServerStoppedException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.RegionServerStoppedException
-
- RegionState - Class in org.apache.hadoop.hbase.master
-
State of a Region while undergoing transitions.
- RegionState() - Constructor for class org.apache.hadoop.hbase.master.RegionState
-
- RegionState(HRegionInfo, RegionState.State) - Constructor for class org.apache.hadoop.hbase.master.RegionState
-
- RegionState(HRegionInfo, RegionState.State, ServerName) - Constructor for class org.apache.hadoop.hbase.master.RegionState
-
- RegionState(HRegionInfo, RegionState.State, long, ServerName) - Constructor for class org.apache.hadoop.hbase.master.RegionState
-
- RegionState.State - Enum in org.apache.hadoop.hbase.master
-
- RegionTooBusyException - Exception in org.apache.hadoop.hbase
-
Thrown by a region server if it will block and wait to serve a request.
- RegionTooBusyException() - Constructor for exception org.apache.hadoop.hbase.RegionTooBusyException
-
default constructor
- RegionTooBusyException(String) - Constructor for exception org.apache.hadoop.hbase.RegionTooBusyException
-
Constructor
- RegionTransition - Class in org.apache.hadoop.hbase
-
Current state of a region in transition.
- registerFilter(String, String) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Register a new filter with the parser.
- registerListener(ReplicationListener) - Method in interface org.apache.hadoop.hbase.replication.ReplicationTracker
-
Register a replication listener to receive replication events.
- registerListener(ReplicationListener) - Method in class org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl
-
- registerListener(ZooKeeperListener) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
Register the specified listener to receive ZooKeeper events.
- registerListenerFirst(ZooKeeperListener) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
Register the specified listener to receive ZooKeeper events and add it as
the first in the list of current listeners.
- releaseHTableInterface(HTableInterface) - Method in class org.apache.hadoop.hbase.client.HTableFactory
-
Deprecated.
- releaseHTableInterface(HTableInterface) - Method in interface org.apache.hadoop.hbase.client.HTableInterfaceFactory
-
Release the HTable resource represented by the table.
- relocateRegion(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Find the location of the region of tableName that row
lives in, ignoring any value that might be in the cache.
- relocateRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
- relocateRegion(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- relocateRegion(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- RemoteExceptionHandler - Class in org.apache.hadoop.hbase
-
An immutable class which contains a static method for handling
org.apache.hadoop.ipc.RemoteException exceptions.
- remoteId - Variable in class org.apache.hadoop.hbase.ipc.RpcClient.Connection
-
- RemoteWithExtrasException - Exception in org.apache.hadoop.hbase.ipc
-
A RemoteException
with some extra information.
- RemoteWithExtrasException(String, String, boolean) - Constructor for exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
-
- RemoteWithExtrasException(String, String, String, int, boolean) - Constructor for exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
-
- remove(byte[]) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- remove(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- remove(ImmutableBytesWritable) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- remove(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- remove(R) - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
-
- remove(Object) - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- remove(K, V) - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- removeAllQueues() - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
-
Remove all replication queues for this region server.
- removeAllQueues() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
-
- removeConfiguration(String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- removeConfiguration(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- removeCoprocessor(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Remove a coprocessor from those set on the table
- removeEnablingTable(TableName, boolean) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
If the table is found in ENABLING state the inmemory state is removed.
- removeFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
-
- removeFamily(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Removes the HColumnDescriptor with name specified by the parameter column
from the table descriptor
- removeListener(ReplicationListener) - Method in interface org.apache.hadoop.hbase.replication.ReplicationTracker
-
- removeListener(ReplicationListener) - Method in class org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl
-
- removeLog(String, String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
-
Remove an HLog file from the given queue.
- removeLog(String, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
-
- removeMetaData(byte[]) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- removePeer(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Removes a peer cluster and stops the replication to it.
- removePeer(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
-
Removes a remote slave cluster and stops the replication to it.
- removePeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
-
- removeQueue(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
-
Remove a replication queue.
- removeQueue(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
-
- removeQuotesFromByteArray(byte[]) - Static method in class 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
- removeValue(K, V) - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- REPLICATION_SCOPE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- REPLICATION_SCOPE_BYTES - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- ReplicationAdmin - Class in org.apache.hadoop.hbase.client.replication
-
This class provides the administrative interface to HBase cluster
replication.
- ReplicationAdmin(Configuration) - Constructor for class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Constructor that creates a connection to the local ZooKeeper ensemble.
- ReplicationException - Exception in org.apache.hadoop.hbase.replication
-
An HBase Replication exception.
- ReplicationException() - Constructor for exception org.apache.hadoop.hbase.replication.ReplicationException
-
- ReplicationException(String) - Constructor for exception org.apache.hadoop.hbase.replication.ReplicationException
-
- ReplicationException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.replication.ReplicationException
-
- ReplicationException(Throwable) - Constructor for exception org.apache.hadoop.hbase.replication.ReplicationException
-
- ReplicationFactory - Class in org.apache.hadoop.hbase.replication
-
A factory class for instantiating replication objects that deal with replication state.
- ReplicationFactory() - Constructor for class org.apache.hadoop.hbase.replication.ReplicationFactory
-
- REPLICATIONGLOBAL - Static variable in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- ReplicationListener - Interface in org.apache.hadoop.hbase.replication
-
The replication listener interface can be implemented if a class needs to subscribe to events
generated by the ReplicationTracker.
- ReplicationPeer - Interface in org.apache.hadoop.hbase.replication
-
ReplicationPeer manages enabled / disabled state for the peer.
- ReplicationPeer.PeerState - Enum in org.apache.hadoop.hbase.replication
-
State of the peer, whether it is enabled or not
- ReplicationPeerConfig - Class in org.apache.hadoop.hbase.replication
-
A configuration for the replication peer cluster.
- ReplicationPeerConfig() - Constructor for class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- ReplicationPeers - Interface in org.apache.hadoop.hbase.replication
-
This provides an interface for maintaining a set of peer clusters.
- ReplicationPeersZKImpl - Class in org.apache.hadoop.hbase.replication
-
This class provides an implementation of the ReplicationPeers interface using Zookeeper.
- ReplicationPeersZKImpl(ZooKeeperWatcher, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
-
- ReplicationPeerZKImpl - Class in org.apache.hadoop.hbase.replication
-
- ReplicationPeerZKImpl(Configuration, String, ReplicationPeerConfig) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
-
Constructor that takes all the objects required to communicate with the
specified peer, except for the region server addresses.
- ReplicationPeerZKImpl.PeerStateTracker - Class in org.apache.hadoop.hbase.replication
-
Tracker for state of this peer
- ReplicationPeerZKImpl.PeerStateTracker(String, ZooKeeperWatcher, Abortable) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl.PeerStateTracker
-
- ReplicationPeerZKImpl.TableCFsTracker - Class in org.apache.hadoop.hbase.replication
-
Tracker for (table, cf-list) map of this peer
- ReplicationPeerZKImpl.TableCFsTracker(String, ZooKeeperWatcher, Abortable) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl.TableCFsTracker
-
- ReplicationQueueInfo - Class in org.apache.hadoop.hbase.replication
-
This class is responsible for the parsing logic for a znode representing a queue.
- ReplicationQueueInfo(String) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationQueueInfo
-
The passed znode will be either the id of the peer cluster or
the handling story of that queue in the form of id-servername-*
- ReplicationQueues - Interface in org.apache.hadoop.hbase.replication
-
This provides an interface for maintaining a region server's replication queues.
- ReplicationQueuesClient - Interface in org.apache.hadoop.hbase.replication
-
This provides an interface for clients of replication to view replication queues.
- ReplicationQueuesClientZKImpl - Class in org.apache.hadoop.hbase.replication
-
- ReplicationQueuesClientZKImpl(ZooKeeperWatcher, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationQueuesClientZKImpl
-
- ReplicationQueuesZKImpl - Class in org.apache.hadoop.hbase.replication
-
This class provides an implementation of the ReplicationQueues interface using Zookeeper.
- ReplicationQueuesZKImpl(ZooKeeperWatcher, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
-
- ReplicationStateZKBase - Class in org.apache.hadoop.hbase.replication
-
This is a base class for maintaining replication state in zookeeper.
- ReplicationStateZKBase(ZooKeeperWatcher, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
-
- ReplicationTracker - Interface in org.apache.hadoop.hbase.replication
-
This is the interface for a Replication Tracker.
- ReplicationTrackerZKImpl - Class in org.apache.hadoop.hbase.replication
-
This class is a Zookeeper implementation of the ReplicationTracker interface.
- ReplicationTrackerZKImpl(ZooKeeperWatcher, ReplicationPeers, Configuration, Abortable, Stoppable) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl
-
- ReplicationTrackerZKImpl.OtherRegionServerWatcher - Class in org.apache.hadoop.hbase.replication
-
Watcher used to be notified of the other region server's death in the local cluster.
- ReplicationTrackerZKImpl.OtherRegionServerWatcher(ZooKeeperWatcher) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl.OtherRegionServerWatcher
-
Construct a ZooKeeper event listener.
- ReplicationTrackerZKImpl.PeersWatcher - Class in org.apache.hadoop.hbase.replication
-
Watcher used to follow the creation and deletion of peer clusters.
- ReplicationTrackerZKImpl.PeersWatcher(ZooKeeperWatcher) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl.PeersWatcher
-
Construct a ZooKeeper event listener.
- REPLICATIONTYPE - Static variable in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- replicationZNode - Variable in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
-
The name of the base znode that contains all replication state.
- RequestConverter - Class in org.apache.hadoop.hbase.protobuf
-
Helper utility to build protocol buffer requests,
or build components for protocol buffer requests.
- reset() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
- reset() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- reset() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- reset() - Method in class org.apache.hadoop.hbase.filter.Filter
-
Reset the state of the filter between rows.
- reset() - Method in class 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() - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- reset() - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
-
- reset() - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
-
- reset() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
-
- reset() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
- reset() - Method in class org.apache.hadoop.hbase.filter.RowFilter
-
- reset() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- reset() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
-
- reset() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
-
- reset() - Method in class org.apache.hadoop.hbase.ipc.PayloadCarryingRpcController
-
- reset() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
-
- resetRpcTimeout() - Static method in class org.apache.hadoop.hbase.ipc.RpcClient
-
- ResponseConverter - Class in org.apache.hadoop.hbase.protobuf
-
Helper utility to build protocol buffer responses,
or retrieve data from protocol buffer responses.
- restoreSnapshot(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Restore the specified snapshot on the original table.
- restoreSnapshot(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Restore the specified snapshot on the original table.
- restoreSnapshot(byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Restore the specified snapshot on the original table.
- restoreSnapshot(String, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Restore the specified snapshot on the original table.
- RestoreSnapshotException - Exception in org.apache.hadoop.hbase.snapshot
-
Thrown when a snapshot could not be restored due to a server-side error when restoring it.
- RestoreSnapshotException(String, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
-
- RestoreSnapshotException(String, Throwable, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
-
- RestoreSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
-
- RestoreSnapshotException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
-
- Result - Class in org.apache.hadoop.hbase.client
-
Single row result of a
Get
or
Scan
query.
- Result() - Constructor for class org.apache.hadoop.hbase.client.Result
-
Creates an empty Result w/ no KeyValue payload; returns null if you call
Result.rawCells()
.
- Result(KeyValue[]) - Constructor for class org.apache.hadoop.hbase.client.Result
-
- Result(List<KeyValue>) - Constructor for class org.apache.hadoop.hbase.client.Result
-
- ResultScanner - Interface in org.apache.hadoop.hbase.client
-
Interface for client-side scanning.
- ResultStatsUtil - Class in org.apache.hadoop.hbase.client
-
A
Result
with some statistics about the server/region status
- retransitionNodeOpening(ZooKeeperWatcher, HRegionInfo, ServerName, int, boolean) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Retransitions an existing unassigned node for the specified region which is
currently in the OPENING state to be in the OPENING state.
- RETRIES_BY_SERVER_KEY - Static variable in class org.apache.hadoop.hbase.client.HConnectionManager
-
- RetriesExhaustedException - Exception in 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) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedException
-
- RetriesExhaustedException(String, IOException) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedException
-
- RetriesExhaustedException(String, int, List<Throwable>) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedException
-
Create a new RetriesExhaustedException from the list of prior failures.
- RetriesExhaustedException(int, List<RetriesExhaustedException.ThrowableWithExtraContext>) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedException
-
Create a new RetriesExhaustedException from the list of prior failures.
- RetriesExhaustedException.ThrowableWithExtraContext - Class in org.apache.hadoop.hbase.client
-
Datastructure that allows adding more info around Throwable incident.
- RetriesExhaustedException.ThrowableWithExtraContext(Throwable, long, String) - Constructor for class org.apache.hadoop.hbase.client.RetriesExhaustedException.ThrowableWithExtraContext
-
- RetriesExhaustedWithDetailsException - Exception in 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(List<Throwable>, List<? extends Row>, List<String>) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- RetryingCallable<T> - Interface in org.apache.hadoop.hbase.client
-
A Callable that will be retried.
- reversed - Variable in class org.apache.hadoop.hbase.filter.Filter
-
- ReversedClientScanner - Class in org.apache.hadoop.hbase.client
-
A reversed client scanner which support backward scanning
- ReversedClientScanner(Configuration, Scan, TableName, HConnection) - Constructor for class 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 - Class in org.apache.hadoop.hbase.client
-
A reversed ScannerCallable which supports backward scanning.
- ReversedScannerCallable(HConnection, TableName, Scan, ScanMetrics, byte[]) - Constructor for class org.apache.hadoop.hbase.client.ReversedScannerCallable
-
Deprecated.
- ReversedScannerCallable(HConnection, TableName, Scan, ScanMetrics, byte[], PayloadCarryingRpcController) - Constructor for class org.apache.hadoop.hbase.client.ReversedScannerCallable
-
- revoke(AccessControlProtos.AccessControlService.BlockingInterface, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A utility used to revoke a user's global permissions.
- revoke(AccessControlProtos.AccessControlService.BlockingInterface, String, TableName, byte[], byte[], Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A utility used to revoke a user's table permissions.
- revoke(AccessControlProtos.AccessControlService.BlockingInterface, String, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A utility used to revoke a user's namespace permissions.
- revoke(Configuration, TableName, String, byte[], byte[], Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
Revokes the permission on the table
- revoke(Configuration, String, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
Revokes the permission on the table for the specified user.
- revoke(Configuration, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
Revoke global permissions for the specified user.
- revoke(Configuration, String, TableName, byte[], byte[], AccessControlProtos.Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
- rollHLogWriter(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Roll the log writer.
- row - Variable in class org.apache.hadoop.hbase.client.Mutation
-
- row - Variable in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- Row - Interface in org.apache.hadoop.hbase.client
-
Has a row.
- rowCount(TableName, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
-
It gives the row count, by summing up the individual results obtained from
regions.
- rowCount(HTable, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
-
It gives the row count, by summing up the individual results obtained from
regions.
- RowFilter - Class in org.apache.hadoop.hbase.filter
-
This filter is used to filter based on the key.
- RowFilter(CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.RowFilter
-
Constructor.
- RowMutations - Class in org.apache.hadoop.hbase.client
-
Performs multiple mutations atomically on a single row.
- RowMutations() - Constructor for class org.apache.hadoop.hbase.client.RowMutations
-
Constructor for Writable.
- RowMutations(byte[]) - Constructor for class org.apache.hadoop.hbase.client.RowMutations
-
Create an atomic mutation for the specified row.
- RPAREN - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for RPAREN
- RpcClient - Class in org.apache.hadoop.hbase.ipc
-
Does RPC against a cluster.
- RpcClient(Configuration, String) - Constructor for class org.apache.hadoop.hbase.ipc.RpcClient
-
Construct an IPC client for the cluster clusterId
with the default SocketFactory
- RpcClient(Configuration, String, SocketAddress) - Constructor for class org.apache.hadoop.hbase.ipc.RpcClient
-
Construct an IPC client for the cluster clusterId
with the default SocketFactory
- RpcClient.BlockingRpcChannelImplementation - Class in org.apache.hadoop.hbase.ipc
-
Blocking rpc channel that goes via hbase rpc.
- RpcClient.BlockingRpcChannelImplementation(RpcClient, ServerName, User, int) - Constructor for class org.apache.hadoop.hbase.ipc.RpcClient.BlockingRpcChannelImplementation
-
- RpcClient.Call - Class in org.apache.hadoop.hbase.ipc
-
A call waiting for a value.
- RpcClient.Call(Descriptors.MethodDescriptor, Message, CellScanner, Message) - Constructor for class org.apache.hadoop.hbase.ipc.RpcClient.Call
-
- RpcClient.CallTimeoutException - Exception in org.apache.hadoop.hbase.ipc
-
Client-side call timeout
- RpcClient.CallTimeoutException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.RpcClient.CallTimeoutException
-
- RpcClient.Connection - Class in org.apache.hadoop.hbase.ipc
-
Thread that reads responses and notifies callers.
- RpcClient.Connection.PingInputStream - Class in org.apache.hadoop.hbase.ipc
-
This class sends a ping to the remote side when timeout on
reading.
- RpcClient.Connection.PingInputStream(InputStream) - Constructor for class org.apache.hadoop.hbase.ipc.RpcClient.Connection.PingInputStream
-
- RpcClient.ConnectionId - Class in org.apache.hadoop.hbase.ipc
-
This class holds the address and the user ticket, etc.
- RpcClient.FailedServerException - Exception in org.apache.hadoop.hbase.ipc
-
- RpcClient.FailedServerException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.RpcClient.FailedServerException
-
- rpcControllerFactory - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- RpcControllerFactory - Class in org.apache.hadoop.hbase.ipc
-
- RpcControllerFactory(Configuration) - Constructor for class org.apache.hadoop.hbase.ipc.RpcControllerFactory
-
- RpcRetryingCaller<T> - Class in org.apache.hadoop.hbase.client
-
Dynamic rather than static so can set the generic return type appropriately.
- RpcRetryingCaller(long, int, int) - Constructor for class org.apache.hadoop.hbase.client.RpcRetryingCaller
-
- RpcRetryingCallerFactory - Class in org.apache.hadoop.hbase.client
-
- RpcRetryingCallerFactory(Configuration) - Constructor for class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
-
- RpcRetryingCallerFactory(Configuration, ServerStatisticTracker) - Constructor for class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
-
- rsZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- run() - Method in class org.apache.hadoop.hbase.client.DelayingRunner
-
- run(R) - Method in class 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() - Method in class org.apache.hadoop.hbase.ipc.RpcClient.Connection
-
- runCatalogScan() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Ask for a scan of the catalog table
- running - Variable in class org.apache.hadoop.hbase.ipc.RpcClient
-
- S - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'S'
- SASL_DEFAULT_REALM - Static variable in class org.apache.hadoop.hbase.security.SaslUtil
-
- SASL_PROPS - Static variable in class org.apache.hadoop.hbase.security.SaslUtil
-
- saslConnect(InputStream, OutputStream) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
Do client side SASL authentication with server via the given InputStream
and OutputStream
- saslLatch - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- saslQop - Variable in enum org.apache.hadoop.hbase.security.SaslUtil.QualityOfProtection
-
- SaslStatus - Enum in org.apache.hadoop.hbase.security
-
- SaslUtil - Class in org.apache.hadoop.hbase.security
-
- SaslUtil() - Constructor for class org.apache.hadoop.hbase.security.SaslUtil
-
- SaslUtil.QualityOfProtection - Enum in org.apache.hadoop.hbase.security
-
- scan - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- Scan - Class in org.apache.hadoop.hbase.client
-
Used to perform Scan operations.
- Scan() - Constructor for class org.apache.hadoop.hbase.client.Scan
-
Create a Scan operation across all rows.
- Scan(byte[], Filter) - Constructor for class org.apache.hadoop.hbase.client.Scan
-
- Scan(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Scan
-
Create a Scan operation starting at the specified row.
- Scan(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.client.Scan
-
Create a Scan operation for the range of rows specified.
- Scan(Scan) - Constructor for class org.apache.hadoop.hbase.client.Scan
-
Creates a new instance of this class while copying all values.
- Scan(Get) - Constructor for class org.apache.hadoop.hbase.client.Scan
-
Builds a scan object with the same specs as get.
- SCAN_ATTRIBUTES_METRICS_DATA - Static variable in class org.apache.hadoop.hbase.client.Scan
-
- SCAN_ATTRIBUTES_METRICS_ENABLE - Static variable in class org.apache.hadoop.hbase.client.Scan
-
- SCAN_ATTRIBUTES_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.client.Scan
-
- scanMetrics - Variable in class org.apache.hadoop.hbase.client.AbstractClientScanner
-
- ScanMetrics - Class in org.apache.hadoop.hbase.client.metrics
-
Provides client-side metrics related to scan operations
The data can be passed to mapreduce framework or other systems.
- ScanMetrics() - Constructor for class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
constructor
- scanMetrics - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
-
- scanMetricsPublished - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- scannerCaching - Variable in class org.apache.hadoop.hbase.client.HTable
-
- ScannerCallable - Class in org.apache.hadoop.hbase.client
-
Scanner operations such as create, next, etc.
- ScannerCallable(HConnection, TableName, Scan, ScanMetrics, PayloadCarryingRpcController) - Constructor for class org.apache.hadoop.hbase.client.ScannerCallable
-
- ScannerCallable(HConnection, byte[], Scan, ScanMetrics) - Constructor for class org.apache.hadoop.hbase.client.ScannerCallable
-
- scannerTimeout - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- ScannerTimeoutException - Exception in org.apache.hadoop.hbase.client
-
Thrown when a scanner has timed out.
- SecureBulkLoadClient - Class in org.apache.hadoop.hbase.client.coprocessor
-
Client proxy for SecureBulkLoadProtocol
used in conjunction with SecureBulkLoadEndpoint
- SecureBulkLoadClient(HTable) - Constructor for class org.apache.hadoop.hbase.client.coprocessor.SecureBulkLoadClient
-
- SecureBulkLoadUtil - Class in org.apache.hadoop.hbase.security
-
- SecureBulkLoadUtil() - Constructor for class org.apache.hadoop.hbase.security.SecureBulkLoadUtil
-
- SecurityInfo - Class in org.apache.hadoop.hbase.security
-
Maps RPC protocol interfaces to required configuration
- SecurityInfo(String, AuthenticationProtos.TokenIdentifier.Kind) - Constructor for class org.apache.hadoop.hbase.security.SecurityInfo
-
- selectToken(Text, Collection<Token<? extends TokenIdentifier>>) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSelector
-
- sendPing() - Method in class org.apache.hadoop.hbase.ipc.RpcClient.Connection
-
- sequenceNumber - Variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- Server - Interface in org.apache.hadoop.hbase
-
Defines the set of shared functions implemented by HBase servers (Masters
and RegionServers).
- ServerLoad - Class in org.apache.hadoop.hbase
-
This class is used for exporting current state of load on a RegionServer.
- ServerLoad(ClusterStatusProtos.ServerLoad) - Constructor for class org.apache.hadoop.hbase.ServerLoad
-
- serverLoad - Variable in class org.apache.hadoop.hbase.ServerLoad
-
- ServerName - Class in org.apache.hadoop.hbase
-
Instance of an HBase ServerName.
- SERVERNAME_PATTERN - Static variable in class org.apache.hadoop.hbase.ServerName
-
- SERVERNAME_SEPARATOR - Static variable in class org.apache.hadoop.hbase.ServerName
-
This character is used as separator between server hostname, port and
startcode.
- ServerNotRunningYetException - Exception in org.apache.hadoop.hbase.ipc
-
- ServerNotRunningYetException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.ServerNotRunningYetException
-
- ServerRpcController - Class in org.apache.hadoop.hbase.ipc
-
Used for server-side protobuf RPC service invocations.
- ServerRpcController() - Constructor for class org.apache.hadoop.hbase.ipc.ServerRpcController
-
- ServerStatistics - Class in org.apache.hadoop.hbase.client.backoff
-
Track the statistics for a single region
- ServerStatistics() - Constructor for class org.apache.hadoop.hbase.client.backoff.ServerStatistics
-
- ServerStatistics.RegionStatistics - Class in org.apache.hadoop.hbase.client.backoff
-
- ServerStatistics.RegionStatistics() - Constructor for class org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
-
- ServerStatisticTracker - Class in org.apache.hadoop.hbase.client
-
Tracks the statistics for multiple regions
- ServerStatisticTracker() - Constructor for class org.apache.hadoop.hbase.client.ServerStatisticTracker
-
- setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Mutation
-
- setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Mutation
-
- setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Query
-
- setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Query
-
- setACLStrategy(boolean) - Method in class org.apache.hadoop.hbase.client.Mutation
-
- setACLStrategy(boolean) - Method in class org.apache.hadoop.hbase.client.Query
-
- setAttribute(String, byte[]) - Method in interface org.apache.hadoop.hbase.client.Attributes
-
Sets an attribute.
- setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
- setAuthorizations(Authorizations) - Method in class org.apache.hadoop.hbase.client.Query
-
Sets the authorizations to be used by this Query
- setAuths(Configuration, String[], String) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
-
Sets given labels globally authorized for the user.
- setAutoFlush(boolean) - Method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
- setAutoFlush(boolean, boolean) - Method in class org.apache.hadoop.hbase.client.HTable
-
Turns 'auto-flush' on or off.
- setAutoFlush(boolean) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Deprecated.
in 0.96. When called with setAutoFlush(false), this function also
set clearBufferOnFail to true, which is unexpected but kept for historical reasons.
Replace it with setAutoFlush(false, false) if this is exactly what you want, or by
HTableInterface.setAutoFlushTo(boolean)
for all other cases.
- setAutoFlush(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Turns 'auto-flush' on or off.
- setAutoFlushTo(boolean) - Method in class org.apache.hadoop.hbase.client.HTable
-
Set the autoFlush behavior, without changing the value of clearBufferOnFail
- setAutoFlushTo(boolean) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Set the autoFlush behavior, without changing the value of clearBufferOnFail
- setBalancerRunning(boolean, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Turn the load balancer on or off.
- setBatch(int) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the maximum number of values to return for each call to next()
- setBlockCacheEnabled(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setBlocksize(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setBloomFilterType(BloomType) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setCacheBlocks(boolean) - Method in class org.apache.hadoop.hbase.client.Get
-
Set whether blocks should be cached for this Get.
- setCacheBlocks(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set whether blocks should be cached for this Scan.
- setCacheBloomsOnWrite(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setCacheDataOnWrite(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setCacheIndexesOnWrite(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setCaching(int) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the number of rows for caching that will be passed to scanners.
- setCaching(int) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
Set the number of rows that will be fetched on next
- setCellScanner(CellScanner) - Method in class org.apache.hadoop.hbase.ipc.DelegatingPayloadCarryingRpcController
-
- setCellScanner(CellScanner) - Method in class org.apache.hadoop.hbase.ipc.PayloadCarryingRpcController
-
- setCellVisibility(CellVisibility) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Sets the visibility expression associated with cells in this Mutation.
- setChance(float) - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
Set the chance that a row is included.
- setCharset(Charset) - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator
-
Specifies the
Charset
to use to convert the row key to a String.
- setCheckExistenceOnly(boolean) - Method in class org.apache.hadoop.hbase.client.Get
-
- setClose() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
Call this when the next invocation of call should close the scanner
- setClosestRowBefore(boolean) - Method in class org.apache.hadoop.hbase.client.Get
-
- setClusterId(ZooKeeperWatcher, ClusterId) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKClusterId
-
- setClusterIds(List<UUID>) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Marks that the clusters with the given clusterIds have consumed the mutation
- setClusterKey(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
Set the clusterKey which is the concatenation of the slave cluster's:
hbase.zookeeper.quorum:hbase.zookeeper.property.clientPort:zookeeper.znode.parent
- setCompactionCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Compression types supported in hbase.
- setCompactionEnabled(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Setting the table compaction enable flag.
- setCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Compression types supported in hbase.
- setCompressTags(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Set whether the tags should be compressed along with DataBlockEncoding.
- setConfiguration(String, String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setConfiguration(String, String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- setControllerException(RpcController, IOException) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
-
Stores an exception encountered during RPC invocation so it can be passed back
through to the client.
- setCounter(String, long) - Method in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
- setData(String, byte[], int) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
setData is NOT an idempotent operation.
- setData(ZooKeeperWatcher, String, byte[], int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Sets the data of the existing znode to be the specified data.
- setData(ZooKeeperWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Sets the data of the existing znode to be the specified data.
- setData(String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
-
- setDataBlockEncoding(DataBlockEncoding) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Set data block encoding algorithm used in block cache.
- setDeferredLogFlush(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- setDeletedTable(TableName) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
Deletes the table in zookeeper.
- setDisabledTable(TableName) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
Sets the specified table as DISABLED in zookeeper.
- setDisablingTable(TableName) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
Sets the specified table as DISABLING in zookeeper.
- setDurability(Durability) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Set the durability for this mutation
- setDurability(Durability) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- setEnabledTable(TableName) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
Sets the ENABLED state in the cache and creates or force updates a node to
ENABLED state for the specified table
- setEnablingTable(TableName) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
Sets the specified table as ENABLING in zookeeper.
- setEncodeOnDisk(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- setEncryptionKey(byte[]) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Set the raw crypto key attribute for the family
- setEncryptionType(String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Set the encryption algorithm for use with this family
- setEvictBlocksOnClose(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setException(IOException) - Method in class org.apache.hadoop.hbase.ipc.RpcClient.Call
-
Set the exception when there is an error.
- setExists(Boolean) - Method in class org.apache.hadoop.hbase.client.Result
-
- setFailed(String) - Method in class org.apache.hadoop.hbase.ipc.PayloadCarryingRpcController
-
- setFailed(String) - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
-
- setFailedOn(IOException) - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
-
Sets an exception to be communicated back to the
Service
client.
- setFamilyCellMap(NavigableMap<byte[], List<Cell>>) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Method for setting the put's familyMap
- setFamilyMap(NavigableMap<byte[], List<KeyValue>>) - Method in class org.apache.hadoop.hbase.client.Mutation
-
- setFamilyMap(Map<byte[], NavigableSet<byte[]>>) - Method in class org.apache.hadoop.hbase.client.Scan
-
Setting the familyMap
- setFilter(Filter) - Method in class org.apache.hadoop.hbase.client.Get
-
- setFilter(Filter) - Method in class org.apache.hadoop.hbase.client.Query
-
Apply the specified server-side filter when performing the Query.
- setFilter(Filter) - Method in class org.apache.hadoop.hbase.client.Scan
-
- setFilterIfMissing(boolean) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Set whether entire row should be filtered if column is not found.
- setFoundKV(boolean) - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
-
- setId(String) - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
This method allows you to set an identifier on an operation.
- setInMemory(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setIsolationLevel(IsolationLevel) - Method in class org.apache.hadoop.hbase.client.Query
-
Set the isolation level for this query.
- setKeepDeletedCells(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setKeepDeletedCells(KeepDeletedCells) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setLatestVersionOnly(boolean) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Set whether only the latest version of the column value should be compared.
- setLoadColumnFamiliesOnDemand(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the value indicating whether loading CFs on demand should be allowed (cluster
default is false).
- setLocation(HRegionLocation) - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- setLogPosition(String, String, long) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
-
Set the current position for a specific HLog in a given queue.
- setLogPosition(String, String, long) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
-
- setMasterAddress(ZooKeeperWatcher, String, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
Set master address into the master
znode or into the backup
subdirectory of backup masters; switch off the passed in znode
path.
- setMaxFileSize(long) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
-
- setMaxFileSize(long) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Sets the maximum size upto which a region can grow to after which a region
split is triggered.
- setMaxResultSize(long) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the maximum result size.
- setMaxResultsPerColumnFamily(int) - Method in class org.apache.hadoop.hbase.client.Get
-
Set the maximum number of values to return per row per Column Family
- setMaxResultsPerColumnFamily(int) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the maximum number of values to return per row per Column Family
- setMaxVersions() - Method in class org.apache.hadoop.hbase.client.Get
-
Get all available versions.
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.client.Get
-
Get up to the specified number of versions of each column.
- setMaxVersions() - Method in class org.apache.hadoop.hbase.client.Scan
-
Get all available versions.
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.client.Scan
-
Get up to the specified number of versions of each column.
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setMemStoreFlushSize(long) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
-
- setMemStoreFlushSize(long) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Represents the maximum size of the memstore after which the contents of the
memstore are flushed to the filesystem.
- setMetaLocation(ZooKeeperWatcher, ServerName, RegionState.State) - Static method in class org.apache.hadoop.hbase.zookeeper.MetaRegionTracker
-
Sets the location of hbase:meta
in ZooKeeper to the
specified server address.
- setMetaRegion(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
INTERNAL Used to denote if the current table represents
-ROOT-
or hbase:meta
region.
- setMinVersions(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setName(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- setName(TableName) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- setNonce(long) - Method in class org.apache.hadoop.hbase.client.Action
-
- setNonceGroup(long) - Method in class org.apache.hadoop.hbase.client.MultiAction
-
- setOffline(boolean) - Method in class org.apache.hadoop.hbase.HRegionInfo
-
The parent of a region split is offline while split daughters hold
references to the parent.
- setOperationTimeout(int) - Method in class org.apache.hadoop.hbase.client.HTable
-
- setOwner(User) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- setOwnerString(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- setPeerTableCFs(String, String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- setPeerTableCFs(String, Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Set the replicable table-cf config of the specified peer
- setPeerTableCFsConfig(String, String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
-
Set the table and column-family list string of the peer to ZK.
- setPeerTableCFsConfig(String, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
-
- setPingInterval(Configuration, int) - Static method in class org.apache.hadoop.hbase.ipc.RpcClient
-
set the ping interval value in configuration
- setPrefetchBlocksOnOpen(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setPriority(int) - Method in class org.apache.hadoop.hbase.ipc.DelegatingPayloadCarryingRpcController
-
- setPriority(TableName) - Method in class org.apache.hadoop.hbase.ipc.DelegatingPayloadCarryingRpcController
-
- setPriority(int) - Method in class org.apache.hadoop.hbase.ipc.PayloadCarryingRpcController
-
- setPriority(TableName) - Method in class org.apache.hadoop.hbase.ipc.PayloadCarryingRpcController
-
- setRaw(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
Enable/disable "raw" mode for this scan.
- setReadOnly(boolean) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
-
- setReadOnly(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Setting the table as read only sets all the columns in the table as read
only.
- setRegionCachePrefetch(TableName, boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Enable or disable region cache prefetch for the table.
- setRegionCachePrefetch(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- setRegionCachePrefetch(TableName, boolean) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- setRegionCachePrefetch(byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
- setRegionCachePrefetch(byte[], boolean) - Static method in class org.apache.hadoop.hbase.client.HTable
-
Enable or disable region cache prefetch for the table.
- setRegionCachePrefetch(TableName, boolean) - Static method in class org.apache.hadoop.hbase.client.HTable
-
- setRegionCachePrefetch(Configuration, byte[], boolean) - Static method in class org.apache.hadoop.hbase.client.HTable
-
Enable or disable region cache prefetch for the table.
- setRegionCachePrefetch(Configuration, TableName, boolean) - Static method in class org.apache.hadoop.hbase.client.HTable
-
- setRegionSplitPolicyClassName(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
This sets the class associated with the region split policy which
determines when a region split should occur.
- setReplicationEndpointImpl(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
Sets the ReplicationEndpoint plugin class for this peer.
- setResponse(Message, CellScanner) - Method in class org.apache.hadoop.hbase.ipc.RpcClient.Call
-
Set the return value when there is no error.
- setReturnResults(boolean) - Method in class org.apache.hadoop.hbase.client.Append
-
- setReversed(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set whether this scan is a reversed one
- setReversed(boolean) - Method in class org.apache.hadoop.hbase.filter.Filter
-
alter the reversed scan flag
- setReversed(boolean) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- setRootRegion(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
INTERNAL Used to denote if the current table represents
-ROOT-
region.
- setRowOffsetPerColumnFamily(int) - Method in class org.apache.hadoop.hbase.client.Get
-
Set offset for the row per Column Family.
- setRowOffsetPerColumnFamily(int) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set offset for the row per Column Family.
- setRpcTimeout(int) - Static method in class org.apache.hadoop.hbase.ipc.RpcClient
-
- setRunner(Runnable) - Method in class org.apache.hadoop.hbase.client.DelayingRunner
-
- setScannerCaching(int) - Method in class org.apache.hadoop.hbase.client.HTable
-
- setScope(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setServerSideHConnectionRetries(Configuration, String, Log) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
Set the number of retries to use serverside when trying to communicate
with another server over
HConnection
.
- setSmall(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set whether this scan is a small scan
- setSocketTimeout(Configuration, int) - Static method in class org.apache.hadoop.hbase.ipc.RpcClient
-
Set the socket timeout
- setSplit(boolean) - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the start row of the scan.
- setStatisticTracker(ServerStatisticTracker) - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
-
Set the tracker that should be used for tracking statistics about the server
- setStopRow(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the stop row.
- setTimeRange(long, long) - Method in class org.apache.hadoop.hbase.client.Get
-
Get versions of columns only within the specified timestamp range,
[minStamp, maxStamp).
- setTimeRange(long, long) - Method in class org.apache.hadoop.hbase.client.Increment
-
Sets the TimeRange to be used on the Get for this increment.
- setTimeRange(long, long) - Method in class org.apache.hadoop.hbase.client.Scan
-
Get versions of columns only within the specified timestamp range,
[minStamp, maxStamp).
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.client.Delete
-
Set the timestamp of the delete.
- setTimeStamp(long) - Method in class org.apache.hadoop.hbase.client.Get
-
Get versions of columns with the specified timestamp.
- setTimeStamp(long) - Method in class org.apache.hadoop.hbase.client.Scan
-
Get versions of columns with the specified timestamp.
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.master.RegionState
-
- setTimeToLive(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setTTL(long) - Method in class org.apache.hadoop.hbase.client.Delete
-
- setTTL(long) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Set the TTL desired for the result of the mutation, in milliseconds.
- setupConnection() - Method in class org.apache.hadoop.hbase.ipc.RpcClient.Connection
-
- setupIOstreams() - Method in class org.apache.hadoop.hbase.ipc.RpcClient.Connection
-
- setValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
-
- setValue(String, String) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
-
- setValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setValue(String, String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- setValue(ImmutableBytesWritable, ImmutableBytesWritable) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- setValue(String, String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- setWatchIfNodeExists(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Watch the specified znode, but only if exists.
- setWriteBufferSize(long) - Method in class org.apache.hadoop.hbase.client.HTable
-
Sets the size of the buffer in bytes.
- setWriteBufferSize(long) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Sets the size of the buffer in bytes.
- setWriteToWAL(boolean) - Method in class org.apache.hadoop.hbase.client.Mutation
-
- shouldCacheBloomsOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- shouldCacheDataOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- shouldCacheIndexesOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- shouldCloseConnection - Variable in class org.apache.hadoop.hbase.ipc.RpcClient.Connection
-
- shouldCompressTags() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- shouldEvictBlocksOnClose() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- shouldPrefetchBlocksOnOpen() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- shutdown() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Shuts down the HBase cluster
- SINGLE_QUOTE - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for a single quote
- SingleColumnValueExcludeFilter - Class in 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[]) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
Constructor for binary compare of the value of a single column.
- SingleColumnValueExcludeFilter(byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class 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) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
Constructor for protobuf deserialization only.
- SingleColumnValueFilter - Class in org.apache.hadoop.hbase.filter
-
This filter is used to filter cells based on value.
- SingleColumnValueFilter(byte[], byte[], CompareFilter.CompareOp, byte[]) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Constructor for binary compare of the value of a single column.
- SingleColumnValueFilter(byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class 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) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Constructor for protobuf deserialization only.
- size() - Method in class org.apache.hadoop.hbase.client.MultiAction
-
Get the total number of Actions
- size() - Method in class org.apache.hadoop.hbase.client.MultiResponse
-
- size() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Number of KeyValues carried by this Mutation.
- size() - Method in class org.apache.hadoop.hbase.client.Result
-
- size() - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
-
- size() - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- size(K) - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- SKIP_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
SKIP Array
- SKIP_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
- SkipFilter - Class in org.apache.hadoop.hbase.filter
-
A wrapper filter that filters an entire row if any of the Cell checks do
not pass.
- SkipFilter(Filter) - Constructor for class org.apache.hadoop.hbase.filter.SkipFilter
-
- sleep(long, int) - Method in class org.apache.hadoop.hbase.client.DelegatingRetryingCallable
-
- sleep(long, int) - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- sleep(long, int) - Method in interface org.apache.hadoop.hbase.client.RetryingCallable
-
- snapshot(String, TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Take a snapshot for the given table.
- snapshot(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- snapshot(byte[], byte[], HBaseProtos.SnapshotDescription.Type) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Create snapshot for the given table of given flush type.
- snapshot(byte[], TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
public void snapshot(final String snapshotName,
Create a timestamp consistent snapshot for the given table.
- snapshot(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- snapshot(String, TableName, HBaseProtos.SnapshotDescription.Type) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Create typed snapshot of the table.
- snapshot(String, String, HBaseProtos.SnapshotDescription.Type) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- snapshot(String, byte[], HBaseProtos.SnapshotDescription.Type) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- snapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Take a snapshot and wait for the server to complete that snapshot (blocking).
- SnapshotCreationException - Exception in 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) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotCreationException
-
Used internally by the RPC engine to pass the exception back to the client.
- SnapshotCreationException(String, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotCreationException
-
Failure to create the specified snapshot
- SnapshotCreationException(String, Throwable, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotCreationException
-
Failure to create the specified snapshot due to an external cause
- SnapshotDoesNotExistException - Exception in 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) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotDoesNotExistException
-
- SnapshotDoesNotExistException(HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotDoesNotExistException
-
- SnapshotExistsException - Exception in org.apache.hadoop.hbase.snapshot
-
Thrown when a snapshot exists but should not
- SnapshotExistsException(String, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotExistsException
-
Failure due to the snapshot already existing
- socket - Variable in class org.apache.hadoop.hbase.ipc.RpcClient.Connection
-
- SOCKET_TIMEOUT - Static variable in class org.apache.hadoop.hbase.ipc.RpcClient
-
- socketFactory - Variable in class org.apache.hadoop.hbase.ipc.RpcClient
-
- SORTED_ORDINAL_SERIALIZATION_FORMAT - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
-
Visibility serialization version format.
- SORTED_ORDINAL_SERIALIZATION_FORMAT_TAG_VAL - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
-
Byte representation of the visibility_serialization_version
- sortedPrefixes - Variable in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- split(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Split a table or an individual region.
- split(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Split a table or an individual region.
- split(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- split(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Split a table or an individual region.
- split(AdminProtos.AdminService.BlockingInterface, HRegionInfo, byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A helper to split a region using admin protocol.
- SPLIT_POLICY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
- splitKerberosName(String) - Static method in class org.apache.hadoop.hbase.security.SaslUtil
-
Splitting fully qualified Kerberos name into parts
- splitLogZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- stampSet - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- start() - Method in class org.apache.hadoop.hbase.catalog.CatalogTracker
-
Starts the catalog tracker.
- start(CoprocessorEnvironment) - Method in interface org.apache.hadoop.hbase.Coprocessor
-
- start() - Method in class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
-
Deprecated.
- start() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
-
Starts the tracking of the node in ZooKeeper.
- startCancel() - Method in class org.apache.hadoop.hbase.ipc.PayloadCarryingRpcController
-
- startCancel() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
-
- startStateTracker(ZooKeeperWatcher, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
-
start a state tracker to check whether this peer is enabled or not
- startTableCFsTracker(ZooKeeperWatcher, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
-
start a table-cfs tracker to listen the (table, cf-list) map change
- state - Variable in enum org.apache.hadoop.hbase.security.SaslStatus
-
- StatisticsHConnection - Interface in org.apache.hadoop.hbase.client
-
A server statistics tracking aware HConnection.
- StatsTrackingRpcRetryingCaller<T> - Class in org.apache.hadoop.hbase.client
-
An
RpcRetryingCaller
that will update the per-region stats for the call on return,
if stats are available
- StatsTrackingRpcRetryingCaller(long, int, int, ServerStatisticTracker) - Constructor for class org.apache.hadoop.hbase.client.StatsTrackingRpcRetryingCaller
-
- std(TableName, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
-
This is the client side interface/handle for calling the std method for a
given cf-cq combination.
- std(HTable, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
-
This is the client side interface/handle for calling the std method for a
given cf-cq combination.
- stepDownAsLeader() - Method in class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
-
Deprecated.
Removes the leader znode, if it is currently claimed by this instance.
- stop() - Method in class org.apache.hadoop.hbase.catalog.CatalogTracker
-
Stop working.
- stop(CoprocessorEnvironment) - Method in interface org.apache.hadoop.hbase.Coprocessor
-
- stop() - Method in class org.apache.hadoop.hbase.ipc.RpcClient
-
Stop all threads related to this client.
- stop() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
-
- stopMaster() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Shuts down the current HBase master only.
- StoppedRpcClientException - Exception in org.apache.hadoop.hbase.ipc
-
- StoppedRpcClientException() - Constructor for exception org.apache.hadoop.hbase.ipc.StoppedRpcClientException
-
- StoppedRpcClientException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.StoppedRpcClientException
-
- stopRegionServer(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Stop the designated regionserver
- SubstringComparator - Class in org.apache.hadoop.hbase.filter
-
This comparator is for use with SingleColumnValueFilter, for filtering based on
the value of a given column.
- SubstringComparator(String) - Constructor for class org.apache.hadoop.hbase.filter.SubstringComparator
-
Constructor
- substringType - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
SubstringType byte array
- sum(TableName, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
-
It sums up the value returned from various regions.
- sum(HTable, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
-
It sums up the value returned from various regions.
- sumOfMillisSecBetweenNexts - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
sum of milliseconds between sequential next calls
- SWITCH_TO_SIMPLE_AUTH - Static variable in class org.apache.hadoop.hbase.security.SaslUtil
-
- sync(String, AsyncCallback.VoidCallback, Object) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- sync(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
Forces a synchronization of this ZooKeeper client connection.
- TAB - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for tab
- TABLE_MULTIPLEXER_FLUSH_PERIOD_MS - Static variable in class org.apache.hadoop.hbase.client.HTableMultiplexer
-
- TABLE_MULTIPLEXER_INIT_THREADS - Static variable in class org.apache.hadoop.hbase.client.HTableMultiplexer
-
- TABLE_MULTIPLEXER_MAX_RETRIES_IN_QUEUE - Static variable in class org.apache.hadoop.hbase.client.HTableMultiplexer
-
- TableConfiguration - Class in org.apache.hadoop.hbase.client
-
Configuration is a heavy weight registry that does a lot of string operations and regex matching.
- TableConfiguration() - Constructor for class org.apache.hadoop.hbase.client.TableConfiguration
-
Constructor
This is for internal testing purpose (using the default value).
- tableExists(CatalogTracker, TableName) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
-
Checks if the specified table exists.
- tableExists(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- tableExists(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- tableExists(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- TableExistsException - Exception in org.apache.hadoop.hbase
-
Thrown when a table exists but should not
- TableExistsException() - Constructor for exception org.apache.hadoop.hbase.TableExistsException
-
default constructor
- TableExistsException(String) - Constructor for exception org.apache.hadoop.hbase.TableExistsException
-
Constructor
- TableExistsException(TableName) - Constructor for exception org.apache.hadoop.hbase.TableExistsException
-
- TableInfoMissingException - Exception in org.apache.hadoop.hbase
-
Failed to find .tableinfo file under table dir
- TableInfoMissingException() - Constructor for exception org.apache.hadoop.hbase.TableInfoMissingException
-
- TableInfoMissingException(String) - Constructor for exception org.apache.hadoop.hbase.TableInfoMissingException
-
- TableInfoMissingException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.TableInfoMissingException
-
- TableInfoMissingException(Throwable) - Constructor for exception org.apache.hadoop.hbase.TableInfoMissingException
-
- tableLockZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- tableName - Variable in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- TableNotDisabledException - Exception in org.apache.hadoop.hbase
-
Thrown if a table should be offline but is not
- TableNotDisabledException() - Constructor for exception org.apache.hadoop.hbase.TableNotDisabledException
-
default constructor
- TableNotDisabledException(String) - Constructor for exception org.apache.hadoop.hbase.TableNotDisabledException
-
Constructor
- TableNotDisabledException(byte[]) - Constructor for exception org.apache.hadoop.hbase.TableNotDisabledException
-
- TableNotDisabledException(TableName) - Constructor for exception org.apache.hadoop.hbase.TableNotDisabledException
-
- TableNotEnabledException - Exception in org.apache.hadoop.hbase
-
Thrown if a table should be enabled but is not
- TableNotEnabledException() - Constructor for exception org.apache.hadoop.hbase.TableNotEnabledException
-
default constructor
- TableNotEnabledException(String) - Constructor for exception org.apache.hadoop.hbase.TableNotEnabledException
-
Constructor
- TableNotEnabledException(TableName) - Constructor for exception org.apache.hadoop.hbase.TableNotEnabledException
-
- TableNotEnabledException(byte[]) - Constructor for exception org.apache.hadoop.hbase.TableNotEnabledException
-
- TableNotFoundException - Exception in org.apache.hadoop.hbase
-
Thrown when a table can not be located
- TableNotFoundException() - Constructor for exception org.apache.hadoop.hbase.TableNotFoundException
-
default constructor
- TableNotFoundException(String) - Constructor for exception org.apache.hadoop.hbase.TableNotFoundException
-
- TableNotFoundException(byte[]) - Constructor for exception org.apache.hadoop.hbase.TableNotFoundException
-
- TableNotFoundException(TableName) - Constructor for exception org.apache.hadoop.hbase.TableNotFoundException
-
- TablePartiallyOpenException - Exception in org.apache.hadoop.hbase.snapshot
-
Thrown if a table should be online/offline but is partially open
- TablePartiallyOpenException() - Constructor for exception org.apache.hadoop.hbase.snapshot.TablePartiallyOpenException
-
- TablePartiallyOpenException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.TablePartiallyOpenException
-
- TablePartiallyOpenException(TableName) - Constructor for exception org.apache.hadoop.hbase.snapshot.TablePartiallyOpenException
-
- TablePartiallyOpenException(byte[]) - Constructor for exception org.apache.hadoop.hbase.snapshot.TablePartiallyOpenException
-
- TablePermission - Class in org.apache.hadoop.hbase.security.access
-
Represents an authorization for access for the given actions, optionally
restricted to the given column family or column qualifier, over the
given table.
- TablePermission() - Constructor for class org.apache.hadoop.hbase.security.access.TablePermission
-
Nullary constructor for Writable, do not use
- TablePermission(TableName, byte[], Permission.Action...) - Constructor for class org.apache.hadoop.hbase.security.access.TablePermission
-
Create a new permission for the given table and (optionally) column family,
allowing the given actions.
- TablePermission(TableName, byte[], byte[], Permission.Action...) - Constructor for class org.apache.hadoop.hbase.security.access.TablePermission
-
Creates a new permission for the given table, restricted to the given
column family and qualifer, allowing the assigned actions to be performed.
- TablePermission(TableName, byte[], byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.security.access.TablePermission
-
Creates a new permission for the given table, family and column qualifier,
allowing the actions matching the provided byte codes to be performed.
- TablePermission(String, TableName, byte[], byte[], Permission.Action...) - Constructor for class org.apache.hadoop.hbase.security.access.TablePermission
-
Creates a new permission for the given namespace or table, restricted to the given
column family and qualifer, allowing the assigned actions to be performed.
- TablePermission(String, TableName, byte[], byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.security.access.TablePermission
-
Creates a new permission for the given namespace or table, family and column qualifier,
allowing the actions matching the provided byte codes to be performed.
- TablePermission(String, byte[]) - Constructor for class org.apache.hadoop.hbase.security.access.TablePermission
-
Creates a new permission for the given namespace,
allowing the actions matching the provided byte codes to be performed.
- TablePermission(String, Permission.Action...) - Constructor for class org.apache.hadoop.hbase.security.access.TablePermission
-
Create a new permission for the given namespace,
allowing the given actions.
- tableZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- takeSnapshotAsync(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Take a snapshot without waiting for the server to complete that snapshot (asynchronous)
- tcpKeepAlive - Variable in class org.apache.hadoop.hbase.ipc.RpcClient
-
- tcpNoDelay - Variable in class org.apache.hadoop.hbase.ipc.RpcClient
-
- throwable(Throwable, boolean) - Method in class org.apache.hadoop.hbase.client.DelegatingRetryingCallable
-
- throwable(Throwable, boolean) - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- throwable(Throwable, boolean) - Method in interface org.apache.hadoop.hbase.client.RetryingCallable
-
Called when
Callable.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.).
- TimestampsFilter - Class in org.apache.hadoop.hbase.filter
-
Filter that returns only cells whose timestamp (version) is
in the specified list of timestamps (versions).
- TimestampsFilter(List<Long>) - Constructor for class org.apache.hadoop.hbase.filter.TimestampsFilter
-
Constructor for filter that retains only those
cells whose timestamp (version) is in the specified
list of timestamps.
- TNAME - Static variable in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- toAppend(ClientProtos.MutationProto, CellScanner) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a protocol buffer Mutate to an Append
- toAuthorizations(ClientProtos.Authorizations) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a protocol buffer Authorizations to a client Authorizations
- toAuthorizations(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a protocol buffer Authorizations bytes to a client Authorizations
- toAuthorizations(Authorizations) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Create a protocol buffer Authorizations based on a client Authorizations.
- toByte() - Method in enum org.apache.hadoop.hbase.client.IsolationLevel
-
- toByteArray() - Method in class org.apache.hadoop.hbase.ClusterId
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.BinaryComparator
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.BinaryPrefixComparator
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.BitComparator
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.FamilyFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.Filter
-
TODO: JAVADOC
Concrete implementers can signal a failure condition in their code by throwing an
IOException
.
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
Return length 0 byte array for Filters that don't require special serialization
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.LongComparator
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.NullComparator
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.PageFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.QualifierFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.RowFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.SubstringComparator
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.ValueFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- toByteArray() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- toByteArray() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- toByteArray() - Method in class org.apache.hadoop.hbase.RegionTransition
-
- toByteArray(ZooKeeperProtos.ReplicationState.State) - Static method in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
-
- toBytes() - Method in enum org.apache.hadoop.hbase.client.IsolationLevel
-
- toBytes() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- toCell(Cell) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- toCell(CellProtos.Cell) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- toCellVisibility(ClientProtos.CellVisibility) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a protocol buffer CellVisibility to a client CellVisibility
- toCellVisibility(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a protocol buffer CellVisibility bytes to a client CellVisibility
- toCellVisibility(CellVisibility) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Create a protocol buffer CellVisibility based on a client CellVisibility.
- toCompactionDescriptor(HRegionInfo, byte[], List<Path>, List<Path>, Path) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- toComparator(ByteArrayComparable) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a ByteArrayComparable to a protocol buffer Comparator
- toComparator(ComparatorProtos.Comparator) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a protocol buffer Comparator to a ByteArrayComparable
- toDelete(ClientProtos.MutationProto) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a protocol buffer Mutate to a Delete
- toDelete(ClientProtos.MutationProto, CellScanner) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a protocol buffer Mutate to a Delete
- toDeleteType(KeyValue.Type) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a delete KeyValue type to protocol buffer DeleteType.
- toDelimitedByteArray() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Use this instead of
HRegionInfo.toByteArray()
when writing to a stream and you want to use
the pb mergeDelimitedFrom (w/o the delimiter, pb reads to EOF which may not be what you want).
- toDelimitedByteArray(HRegionInfo...) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Serializes given HRegionInfo's as a byte array.
- toDelimitedByteArray(Message) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- toDescriptiveString() - Method in class org.apache.hadoop.hbase.master.RegionState
-
A slower (but more easy-to-read) stringification
- toDurability(ClientProtos.MutationProto.Durability) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a protobuf Durability into a client Durability
- toDurability(Durability) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a client Durability into a protbuf Durability
- toException(HBaseProtos.NameBytesPair) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a stringified protocol buffer exception Parameter to a Java Exception
- toFilter(FilterProtos.Filter) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a protocol buffer Filter to a client Filter
- toFilter(Filter) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a client Filter to a protocol buffer Filter
- toGet(ClientProtos.Get) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a protocol buffer Get to a client Get
- toGet(Get) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Create a protocol buffer Get based on a client Get.
- toIncrement(ClientProtos.MutationProto, CellScanner) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a protocol buffer Mutate to an Increment
- toIOException(ServiceException) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Unwraps an exception from a protobuf service into the underlying (expected) IOException.
- toJSON(int) - Method in class org.apache.hadoop.hbase.client.Operation
-
Produces a JSON object for fingerprint and details exposure in a
parseable format.
- toJSON() - Method in class org.apache.hadoop.hbase.client.Operation
-
Produces a JSON object sufficient for description of a query
in a debugging or logging context.
- tokenHandlers - Static variable in class org.apache.hadoop.hbase.ipc.RpcClient
-
- TokenUtil - Class in org.apache.hadoop.hbase.security.token
-
Utility methods for obtaining authentication tokens.
- TokenUtil() - Constructor for class org.apache.hadoop.hbase.security.token.TokenUtil
-
- toMap(int) - Method in class org.apache.hadoop.hbase.client.Delete
-
- toMap(int) - Method in class 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) - Method in class 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) - Method in class 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.
- toMap() - Method in class org.apache.hadoop.hbase.client.Operation
-
Produces a Map containing a full summary of a query.
- toMap(int) - Method in class 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) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a MutateRequest to Mutation
- toMutation(Increment, ClientProtos.MutationProto.Builder, long) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a client Increment to a protobuf Mutate.
- toMutation(ClientProtos.MutationProto.MutationType, Mutation) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- toMutation(ClientProtos.MutationProto.MutationType, Mutation, long) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Create a protocol buffer Mutate based on a client Mutation
- toMutation(ClientProtos.MutationProto.MutationType, Mutation, ClientProtos.MutationProto.Builder) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- toMutation(ClientProtos.MutationProto.MutationType, Mutation, ClientProtos.MutationProto.Builder, long) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- toMutationNoData(ClientProtos.MutationProto.MutationType, Mutation, ClientProtos.MutationProto.Builder) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Create a protocol buffer MutationProto based on a client Mutation.
- toMutationNoData(ClientProtos.MutationProto.MutationType, Mutation) - Static method in class 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) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- toNamespaceDescriptor(HBaseProtos.NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- toPermission(AccessControlProtos.Permission) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Converts a Permission proto to a client Permission object.
- toPermission(Permission) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a client Permission to a Permission proto
- toPermissionAction(AccessControlProtos.Permission.Action) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Converts a Permission.Action proto to a client Permission.Action object.
- toPermissionAction(Permission.Action) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a client Permission.Action to a Permission.Action proto
- toPermissionActions(List<AccessControlProtos.Permission.Action>) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Converts a list of Permission.Action proto to a list of client Permission.Action objects.
- toProtoNamespaceDescriptor(NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- toProtoTableName(TableName) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- toPut(ClientProtos.MutationProto) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a protocol buffer Mutate to a Put.
- toPut(ClientProtos.MutationProto, CellScanner) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a protocol buffer Mutate to a Put.
- toResult(Result) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a client Result to a protocol buffer Result
- toResult(boolean) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a client Result to a protocol buffer Result
- toResult(ClientProtos.Result) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a protocol buffer Result to a client Result
- toResult(ClientProtos.Result, CellScanner) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a protocol buffer Result to a client Result
- toResultNoData(Result) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a client Result to a protocol buffer Result.
- toScan(Scan) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a client Scan to a protocol buffer Scan
- toScan(ClientProtos.Scan) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a protocol buffer Scan to a client Scan
- toScanMetrics(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- toScanMetrics(ScanMetrics) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- toServerName(ServerName) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a ServerName to a protocol buffer ServerName
- toServerName(HBaseProtos.ServerName) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a protocol buffer ServerName to a ServerName
- toShortString() - Method in class org.apache.hadoop.hbase.ServerName
-
- toString() - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
-
An identifier that will remain the same for a given connection.
- toString() - Method in class org.apache.hadoop.hbase.client.HTable
-
- toString() - Method in class org.apache.hadoop.hbase.client.Increment
-
- toString(int) - Method in class org.apache.hadoop.hbase.client.Operation
-
Produces a string representation of this Operation.
- toString() - Method in class org.apache.hadoop.hbase.client.Operation
-
Produces a string representation of this Operation.
- toString() - Method in class org.apache.hadoop.hbase.client.Result
-
- toString() - Method in class org.apache.hadoop.hbase.client.RetriesExhaustedException.ThrowableWithExtraContext
-
- toString() - Method in class org.apache.hadoop.hbase.ClusterId
-
- toString() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- toString() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
Return filter's info for debugging and logging purpose.
- toString() - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- toString(int) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- toString() - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- toString(int) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.PageFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
- toString(int) - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
-
- toString() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- toString() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- toString() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- toString() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- toString() - Method in class org.apache.hadoop.hbase.ipc.RpcClient.Call
-
- toString() - Method in class org.apache.hadoop.hbase.ipc.RpcClient.ConnectionId
-
- toString() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- toString() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- toString() - Method in class org.apache.hadoop.hbase.RegionTransition
-
- toString() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- toString() - Method in class org.apache.hadoop.hbase.security.access.Permission
-
- toString() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
- toString() - Method in class org.apache.hadoop.hbase.security.access.UserPermission
-
- toString() - Method in class org.apache.hadoop.hbase.security.visibility.Authorizations
-
- toString() - Method in class org.apache.hadoop.hbase.security.visibility.CellVisibility
-
- toString() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- toString() - Method in class org.apache.hadoop.hbase.ServerName
-
- toString(HBaseProtos.SnapshotDescription) - Static method in class org.apache.hadoop.hbase.snapshot.ClientSnapshotDescriptionUtils
-
Returns a single line (no \n) representation of snapshot metadata.
- toString() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData
-
Deprecated.
- toString() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- toStringCustomizedValues() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- toStringCustomizedValues() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- toStringTableAttributes() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- toTableName(HBaseProtos.TableName) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- toTablePermission(AccessControlProtos.Permission) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Converts a Permission proto to a client TablePermission object.
- toToken(Token<AuthenticationTokenIdentifier>) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Converts a Token instance (with embedded identifier) to the protobuf representation.
- toToken(AuthenticationProtos.Token) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Converts a protobuf Token message back into a Token instance.
- touch() - Method in class org.apache.hadoop.hbase.ipc.RpcClient.Connection
-
Update lastActivity with the current time.
- toUserPermission(UserPermission) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a client user permission to a user permission proto
- toUserPermission(AccessControlProtos.UserPermission) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Converts a user permission proto to a client user permission object.
- toUsersAndPermissions(String, Permission) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- toUsersAndPermissions(ListMultimap<String, Permission>) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- toUsersAndPermissions(AccessControlProtos.UsersAndPermissions) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- toUserTablePermissions(ListMultimap<String, TablePermission>) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a ListMultimap where key is username
to a protobuf UserPermission
- toUserTablePermissions(AccessControlProtos.UsersAndPermissions) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Convert a protobuf UserTablePermissions to a
ListMultimap where key is username.
- transform(KeyValue) - Method in class org.apache.hadoop.hbase.filter.Filter
-
Deprecated.
- transform(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
Deprecated.
- transform(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
Deprecated.
- transform(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
-
Deprecated.
- transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.Filter
-
Give the filter a chance to transform the passed KeyValue.
- transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
By default no transformation takes place
- transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
-
- transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
-
- transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
-
- transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
-
- transformClusterKey(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Separate the given key into the three configurations it should contain:
hbase.zookeeper.quorum, hbase.zookeeper.client.port
and zookeeper.znode.parent
- transitionNode(ZooKeeperWatcher, HRegionInfo, ServerName, EventType, EventType, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Method that actually performs unassigned node transitions.
- transitionNode(ZooKeeperWatcher, HRegionInfo, ServerName, EventType, EventType, int, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
- transitionNodeClosed(ZooKeeperWatcher, HRegionInfo, ServerName, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Transitions an existing unassigned node for the specified region which is
currently in the CLOSING state to be in the CLOSED state.
- transitionNodeOpened(ZooKeeperWatcher, HRegionInfo, ServerName, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Transitions an existing unassigned node for the specified region which is
currently in the OPENING state to be in the OPENED state.
- transitionNodeOpening(ZooKeeperWatcher, HRegionInfo, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Transitions an existing unassigned node for the specified region which is
currently in the OFFLINE state to be in the OPENING state.
- transitionNodeOpening(ZooKeeperWatcher, HRegionInfo, ServerName, EventType) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
- truncateTable(TableName, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Truncate a table.
- ts - Variable in class org.apache.hadoop.hbase.client.Mutation
-
- TTL - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- validatePut(Put) - Method in class org.apache.hadoop.hbase.client.HTable
-
- validatePut(Put, int) - Static method in class org.apache.hadoop.hbase.client.HTable
-
- value() - Method in class org.apache.hadoop.hbase.client.Result
-
Returns the value of the first column in the Result.
- ValueFilter - Class in org.apache.hadoop.hbase.filter
-
This filter is used to filter based on column value.
- ValueFilter(CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.ValueFilter
-
Constructor.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.Durability
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.IsolationLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.Coprocessor.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.executor.EventType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.executor.ExecutorType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.filter.BitComparator.BitwiseOp
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.filter.CompareFilter.CompareOp
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.filter.Filter.ReturnCode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.filter.FilterList.Operator
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.filter.FilterWrapper.FilterRowRetCode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.filter.RegexStringComparator.EngineType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.KeepDeletedCells
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.RegionState.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.BloomType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.RegionOpeningState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.replication.ReplicationPeer.PeerState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.security.access.Permission.Action
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.security.AuthMethod
-
Returns the enum constant of this type with the specified name.
- valueOf(byte) - Static method in enum org.apache.hadoop.hbase.security.AuthMethod
-
Return the object represented by the code.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.security.SaslStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.security.SaslUtil.QualityOfProtection
-
Returns the enum constant of this type with the specified name.
- valueOf(String, int, long) - Static method in class org.apache.hadoop.hbase.ServerName
-
Retrieve an instance of ServerName.
- valueOf(String) - Static method in class org.apache.hadoop.hbase.ServerName
-
Retrieve an instance of ServerName.
- valueOf(String, long) - Static method in class org.apache.hadoop.hbase.ServerName
-
Retrieve an instance of ServerName.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.util.PoolMap.PoolType
-
Returns the enum constant of this type with the specified name.
- valueOf(String, PoolMap.PoolType, PoolMap.PoolType...) - Static method in enum org.apache.hadoop.hbase.util.PoolMap.PoolType
-
- values() - Static method in enum org.apache.hadoop.hbase.client.Durability
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.client.IsolationLevel
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.Coprocessor.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.executor.EventType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.executor.ExecutorType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.filter.BitComparator.BitwiseOp
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.filter.CompareFilter.CompareOp
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.filter.Filter.ReturnCode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.filter.FilterList.Operator
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.filter.FilterWrapper.FilterRowRetCode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.filter.RegexStringComparator.EngineType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.KeepDeletedCells
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.master.RegionState.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.BloomType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.RegionOpeningState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.replication.ReplicationPeer.PeerState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.security.access.Permission.Action
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.security.AuthMethod
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.security.SaslStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.security.SaslUtil.QualityOfProtection
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
-
- values() - Static method in enum org.apache.hadoop.hbase.util.PoolMap.PoolType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.hadoop.hbase.util.PoolMap.ReusablePool
-
- values() - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- values(K) - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- verifyMetaRegionLocation(long) - Method in class org.apache.hadoop.hbase.catalog.CatalogTracker
-
Verify hbase:meta
is deployed and accessible.
- VERSION - Static variable in interface org.apache.hadoop.hbase.Coprocessor
-
- VERSION - Static variable in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
- VERSION - Static variable in class org.apache.hadoop.hbase.security.access.Permission
-
- VISIBILITY_LABELS_ATTR_KEY - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
-
The string that is used as key in setting the Operation attributes for visibility labels
- VisibilityClient - Class in org.apache.hadoop.hbase.security.visibility
-
Utility client for doing visibility labels admin operations.
- VisibilityClient() - Constructor for class org.apache.hadoop.hbase.security.visibility.VisibilityClient
-
- VisibilityConstants - Class in org.apache.hadoop.hbase.security.visibility
-
- VisibilityConstants() - Constructor for class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
-
- VisibilityControllerNotReadyException - Exception in org.apache.hadoop.hbase.security.visibility
-
- VisibilityControllerNotReadyException(String) - Constructor for exception org.apache.hadoop.hbase.security.visibility.VisibilityControllerNotReadyException
-
- VisibilityLabelsValidator - Class in org.apache.hadoop.hbase.security.visibility
-
A simple validator that validates the labels passed
- VisibilityLabelsValidator() - Constructor for class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsValidator
-
- visit(Result) - Method in interface org.apache.hadoop.hbase.catalog.MetaReader.Visitor
-
Visit the catalog table row.