|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
Put
operation to the list of mutations
Delete
operation to the list of mutations
HTableInterface.batch(List, Object[])
, but returns an array of
results instead of using a results parameter reference.
Batch.Call.call(Object)
result.HTableInterface.batch(List, Object[])
, but with a callback.
HTableInterface.batch(List)
, but with a callback.
Bytes.compareTo(byte[], byte[])
.RpcCallback
implementation providing a
Future
-like BlockingRpcCallback.get()
method, which
will block util the instance's BlockingRpcCallback.run(Object)
method has been called..META.
.sn
.
tableName
Scan
's start row maybe changed changed.
Scan
's start
row maybe changed changed.
HTablePool.closeTablePool(String)
.
ZKConfig
.
DeserializationException
to a more palatable KeeperException
.
Service
sRpcChannel
instance
connected to the active master.
RpcChannel
instance connected to the
table region containing the specified row.
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.
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.
RpcChannel
instance connected to the
table region containing the specified row.
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.
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.
UserGroupInformation
instance.
conf
instance.
conf
instance.
User
instance specifically for use in test code.
RpcRetryingCaller
RemoteException.unwrapRemoteException()
instead.
In fact we should look into deprecating this whole class - St.Ack 2010929
HTableDescriptor.DURABILITY
instead.
.META.
in ZooKeeper.
CompareFilter
Mutation
s
Note that the items must be sorted in order of increasing durabilityDurability
setting for the table.
HConnectable.connect(org.apache.hadoop.hbase.client.HConnection)
implementation using a HConnection
instance that lasts just for the
duration of the invocation.
Filter
that represents an ordered List of Filters
which will be evaluated with a specified boolean operator FilterList.Operator.MUST_PASS_ALL
(AND
) or FilterList.Operator.MUST_PASS_ONE
(OR
).Filter
s.
Filter
s.
Filter
s and an operator.
Filter
s and an operator.
Filter.filterKeyValue(KeyValue)
calls.
FilterBase.filterKeyValue(KeyValue)
can inherit this implementation that
never filters a row.
Put
operations.
Put
operations.
.META.
, skipping regions from any
tables in the specified set of disabled tables.
.META.
, skipping regions from any
tables in the specified set of disabled tables.
.META.
.
.META.
.
.META.
table.
BlockingRpcCallback.run(Object)
or null
if a null value was
passed.
HColumnDescriptor
of the column families
of the table.
Configuration
object used by this instance.
Configuration
object used by this instance.
HColumnDescriptor.configuration
map.
HTableDescriptor.configuration
map.
User
instance within current execution context.
null
if no exception
was thrown.
HColumnDescriptor
of all the column families of the table.
HConstants.CATALOG_FAMILY
and
qualifier
of the catalog table result.
Result
.
ServerName
.
MasterAdminKeepAliveConnection
to the active master
MasterMonitorKeepAliveConnection
to the active master
.META.
or null if location is
not currently available.
PoolMap.PoolType.RoundRobin
.
PoolMap.PoolType.RoundRobin
or PoolMap.PoolType.ThreadLocal
,
otherwise default to the former.
.META.
for passed table.
RpcClient.setRpcTimeout(int)
and the given
default timeout.
Scan
object.
Scan
object.
Scan.setCaching(int)
and Scan.getCaching()
ClusterStatus.getServers()
ServerName
from catalog table Result
.
table descriptor
for this table.
table descriptor
for this table.
ByteBuffer
.
ByteBuffer
.
HTableDescriptor.values
map.
Writable.readFields(java.io.DataInput)
.
Writable.readFields(java.io.DataInput)
.
HColumnDescriptor.HColumnDescriptor(String)
and setters
HColumnDescriptor.HColumnDescriptor(String)
and setters
HColumnDescriptor.HColumnDescriptor(String)
and setters
HConnection
instance based on the given Configuration
.HConnection
s. -ROOT-
or
.META.- HTableDescriptor(TableName, HColumnDescriptor[]) -
Constructor for class org.apache.hadoop.hbase.HTableDescriptor
- INTERNAL Private constructor used internally creating table descriptors for
catalog tables,
.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,
.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
- Factory for creating HTable instances.
- HTableFactory() -
Constructor for class org.apache.hadoop.hbase.client.HTableFactory
-
- 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
-
- HTablePool - Class in org.apache.hadoop.hbase.client
- Deprecated. Use
HConnection.getTable(String)
instead. - 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
-
HTableInterface.incrementColumnValue(byte[], byte[], byte[], long, Durability)
HTableInterface.incrementColumnValue(byte[], byte[], byte[], long, Durability)
.META.
- 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.HConnectionWrapper
-
- isAborted() -
Method in class org.apache.hadoop.hbase.replication.ReplicationPeer
-
- isAborted() -
Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- isAlive() -
Method in class org.apache.hadoop.hbase.util.HasThread
-
- 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?)
- isClosed() -
Method in interface org.apache.hadoop.hbase.client.HConnection
-
- isClosed() -
Method in class org.apache.hadoop.hbase.client.HConnectionWrapper
-
- 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
- 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.HConnectionWrapper
-
- isDeferredLogFlush() -
Method in class org.apache.hadoop.hbase.HTableDescriptor
- Deprecated. use
HTableDescriptor.getDurability()
- 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 KeyValue [] 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
.
- 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.
- isHBaseSecurityEnabled(Configuration) -
Static method in class org.apache.hadoop.hbase.security.User
- Returns whether or not secure authentication is enabled for HBase.
- isInMemory() -
Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- isInterrupted() -
Method in class org.apache.hadoop.hbase.util.HasThread
-
- 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.HConnectionWrapper
-
- 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
-
- 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
.META.
- isMetaTable() -
Method in class org.apache.hadoop.hbase.HRegionInfo
-
- isMetaTable() -
Method in class org.apache.hadoop.hbase.HTableDescriptor
- Checks if the table is a
.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
-
- isOpenOrMergingOnServer(ServerName) -
Method in class org.apache.hadoop.hbase.master.RegionState
-
- isPBMagicPrefix(byte[]) -
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
-
- isPendingCloseOrClosingOnServer(ServerName) -
Method in class org.apache.hadoop.hbase.master.RegionState
-
- isPendingOpen() -
Method in class org.apache.hadoop.hbase.master.RegionState
-
- isPendingOpenOrOpeningOnServer(ServerName) -
Method in class org.apache.hadoop.hbase.master.RegionState
-
- 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.
- isReturnResults() -
Method in class org.apache.hadoop.hbase.client.Append
-
- 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
.
- isSecurityEnabled() -
Static method in class org.apache.hadoop.hbase.security.User
- Returns whether or not Kerberos authentication is configured for Hadoop.
- 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
-
- isStateEnabled(byte[]) -
Static method in class org.apache.hadoop.hbase.replication.ReplicationPeer
- Parse the raw data from ZK to get a peer's state
- isStopped() -
Method in interface org.apache.hadoop.hbase.Stoppable
-
- issueDate -
Variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- isSystemTable(TableName) -
Static method in class org.apache.hadoop.hbase.HTableDescriptor
- Checks of the tableName being passed is a system table
- 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.HConnectionWrapper
-
- isTableAvailable(byte[]) -
Method in class org.apache.hadoop.hbase.client.HConnectionWrapper
-
- isTableAvailable(TableName, byte[][]) -
Method in class org.apache.hadoop.hbase.client.HConnectionWrapper
-
- isTableAvailable(byte[], byte[][]) -
Method in class org.apache.hadoop.hbase.client.HConnectionWrapper
-
- 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.HConnectionWrapper
-
- isTableDisabled(byte[]) -
Method in class org.apache.hadoop.hbase.client.HConnectionWrapper
-
- 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.HConnectionWrapper
-
- isTableEnabled(byte[]) -
Method in class org.apache.hadoop.hbase.client.HConnectionWrapper
-
- isTableEnabled(String) -
Static method in class org.apache.hadoop.hbase.client.HTable
- Deprecated. use
HBaseAdmin.isTableEnabled(byte[])
- isTableEnabled(byte[]) -
Static method in class org.apache.hadoop.hbase.client.HTable
- Deprecated. use
HBaseAdmin.isTableEnabled(byte[])
- isTableEnabled(TableName) -
Static method in class org.apache.hadoop.hbase.client.HTable
- Deprecated. use
HBaseAdmin.isTableEnabled(byte[])
- isTableEnabled(Configuration, String) -
Static method in class org.apache.hadoop.hbase.client.HTable
- Deprecated. use
HBaseAdmin.isTableEnabled(byte[])
- isTableEnabled(Configuration, byte[]) -
Static method in class org.apache.hadoop.hbase.client.HTable
- Deprecated. use
HBaseAdmin.isTableEnabled(byte[])
- isTableEnabled(Configuration, TableName) -
Static method in class org.apache.hadoop.hbase.client.HTable
- Deprecated. use
HBaseAdmin.isTableEnabled(org.apache.hadoop.hbase.TableName tableName)
- isTablePresent(TableName) -
Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
- check if table is present .
- iterator() -
Method in class org.apache.hadoop.hbase.client.AbstractClientScanner
-
ByteBuffer
.
ByteBuffer
.
zookeeper
reference.
Service
s
against the active master.true
if this permission matches the given column
family at least.
.META.
catalog table
.META.
..META.
table scanning logic.r
to dest
.
Bytes.compareTo(byte[], byte[])
.ResultScanner.next()
.src/main/protobuf
definition files.ParseFilter
IOException
.
ServerName
from bytes
gotten from a call to ServerName.getVersionedBytes()
.
PoolMap
maps a key to a collection of values, the elements
of which are managed by a pool.ReusablePool
represents a PoolMap.Pool
that builds
on the LinkedList
class.str
Callable.call()
invocation.
ProtobufUtil.PB_MAGIC
, to flag what
follows as a protobuf in hbase.
HTableInterface.batch(java.util.List extends org.apache.hadoop.hbase.client.Row>, java.lang.Object[])
instead
Row
implementations.
HTableInterface.batchCallback(java.util.List extends org.apache.hadoop.hbase.client.Row>, java.lang.Object[], org.apache.hadoop.hbase.client.coprocessor.Batch.Callback)
instead
off
Send a ping if timeout on read.
HColumnDescriptor.parseFrom(byte[])
instead.
HTableDescriptor.parseFrom(byte[])
instead.
CompareFilter
implementations, such
as RowFilter
, QualifierFilter
, and ValueFilter
, for
filtering based on the value of a given column.Service
s
against a given table region.Callable.call()
.RemoteException
with some extra information.HTableDescriptor.values
map
HTableDescriptor.values
map
HColumnDescriptor.configuration
map.
HTableDescriptor.configuration
map
Get
or Scan
query.Result.raw()
.
RetriesExhaustedException
is thrown when we have more information about which rows were causing which
exceptions on what servers.clusterId
with the default SocketFactory
clusterId
with the default SocketFactory
RetryingCallable
.RpcRetryingCaller
null
in the case of
an error.
HTable.setAutoFlush(boolean, boolean)
HTableInterface.setAutoFlush(boolean, boolean)
Charset
to use to convert the row key to a String.
HColumnDescriptor.configuration
map.
HTableDescriptor.configuration
map.
HTableDescriptor.setDurability(Durability)
Durability
setting for the table.
Service
client.
master
znode or into the backup
subdirectory of backup masters; switch off the passed in znode
path.
.META.
in ZooKeeper to the
specified server address.
-ROOT-
or .META.
- 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.
- setName(String) -
Method in class org.apache.hadoop.hbase.util.HasThread
-
- 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.
- setPingInterval(Configuration, int) -
Static method in class org.apache.hadoop.hbase.ipc.RpcClient
- set the ping interval value in configuration
- setPriority(int) -
Method in class org.apache.hadoop.hbase.util.HasThread
-
- 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.HConnectionWrapper
-
- setRegionCachePrefetch(byte[], boolean) -
Method in class org.apache.hadoop.hbase.client.HConnectionWrapper
-
- 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
-
- setRegionServers(List<ServerName>) -
Method in class org.apache.hadoop.hbase.replication.ReplicationPeer
- Set the list of region servers for that 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
-
- 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
-
- setScannerCaching(int) -
Method in class org.apache.hadoop.hbase.client.HTable
- Deprecated. Use
Scan.setCaching(int)
- 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
.
- 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.
- 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
-
- setUncaughtExceptionHandler(Thread.UncaughtExceptionHandler) -
Method in class org.apache.hadoop.hbase.util.HasThread
-
- 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
- Setter for storing metadata as a (key, value) pair in
HTableDescriptor.values
map
- setValue(ImmutableBytesWritable, ImmutableBytesWritable) -
Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- setValue(String, String) -
Method in class org.apache.hadoop.hbase.HTableDescriptor
- Setter for storing metadata as a (key, value) pair in
HTableDescriptor.values
map
- 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
- Deprecated.
- 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
-
- shouldEvictBlocksOnClose() -
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 KeyValue checks do
not pass.
- SkipFilter(Filter) -
Constructor for class org.apache.hadoop.hbase.filter.SkipFilter
-
- skipSleepCycle() -
Method in class org.apache.hadoop.hbase.util.Sleeper
- If currently asleep, stops sleeping; if not asleep, will skip the next
sleep cycle.
- sleep() -
Method in class org.apache.hadoop.hbase.Chore
- Sleep for period.
- 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
-
- sleep() -
Method in class org.apache.hadoop.hbase.util.Sleeper
- Sleep for period.
- sleep(long) -
Method in class org.apache.hadoop.hbase.util.Sleeper
- Sleep for period adjusted by passed
startTime
- Sleeper - Class in org.apache.hadoop.hbase.util
- Sleeper for current thread.
- Sleeper(int, Stoppable) -
Constructor for class org.apache.hadoop.hbase.util.Sleeper
-
- 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[], 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
-
- socketFactory -
Variable in class org.apache.hadoop.hbase.ipc.RpcClient
-
- 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.util.HasThread
-
- 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.ReplicationPeer
- start a state tracker to check whether this peer is enabled or not
- state -
Variable in enum org.apache.hadoop.hbase.security.SaslStatus
-
- 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(String) -
Method in interface org.apache.hadoop.hbase.Stoppable
- Stop this service.
- 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.
- Stoppable - Interface in org.apache.hadoop.hbase
- Implementers are Stoppable.
- 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
-
- stopper -
Variable in class org.apache.hadoop.hbase.Chore
-
- 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
- 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.
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.).
IOException
.
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).
.META.
is deployed and accessible.
.META.
if available and waits
for up to the specified timeout if not immediately available.
.META.
.
WhileMatchFilter.filterAllRemaining()
as soon
as the wrapped filters Filter.filterRowKey(byte[], int, int)
,
Filter.filterKeyValue(org.apache.hadoop.hbase.KeyValue)
,
Filter.filterRow()
or
Filter.filterAllRemaining()
methods
returns true.HColumnDescriptor.toByteArray()
instead.
HRegionInfo.toByteArray()
and
HRegionInfo.toDelimitedByteArray()
MessageLite.toByteArray()
instead.
|
||||||||||
PREV NEXT | FRAMES NO FRAMES |