- 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.client.Admin
-
- abortProcedure(long, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- abortProcedure(long, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
- abortProcedureAsync(long, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- abortTask(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.CellSerialization
-
- accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization
-
Deprecated.
- accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.MutationSerialization
-
- accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.ResultSerialization
-
- 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
-
- add(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Append
-
- add(Cell) - Method in class org.apache.hadoop.hbase.client.Append
-
Add column and value to this Append operation.
- add(Cell) - Method in class org.apache.hadoop.hbase.client.Delete
-
Add an existing delete marker to this Delete object.
- add(Cell) - Method in class org.apache.hadoop.hbase.client.Increment
-
Add the specified KeyValue to this 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(Delete) - Method in class org.apache.hadoop.hbase.client.RowMutations
-
- add(Mutation) - Method in class org.apache.hadoop.hbase.client.RowMutations
-
Currently only supports
Put
and
Delete
mutations.
- add(List<? extends Mutation>) - Method in class org.apache.hadoop.hbase.client.RowMutations
-
Currently only supports
Put
and
Delete
mutations.
- add(String) - Method in class org.apache.hadoop.hbase.rest.client.Cluster
-
Add a node to the cluster
- add(String, int) - Method in class org.apache.hadoop.hbase.rest.client.Cluster
-
Add a node to the cluster
- add(DataType<?>) - Method in class org.apache.hadoop.hbase.types.StructBuilder
-
Append field
to the sequence of accumulated fields.
- add(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- add(byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- add(byte[][]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- add(long) - Method in class org.apache.hadoop.hbase.util.Counter
-
Deprecated.
- addAllServers(Collection<Address>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
Adds the given servers to the group.
- addAllTables(Collection<TableName>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
- addClientPort(int) - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
Add a client port to the list.
- addColumn(TableName, ColumnFamilyDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- addColumn(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Append
-
Add the specified column and value to this Append operation.
- addColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
-
Delete the latest version of the specified column.
- addColumn(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
-
Delete the specified version of the specified column.
- 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[], 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[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
-
Add the specified column and value to this Put operation.
- addColumn(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.
- addColumn(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.
- addColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
-
Get the column from the specified family with the specified qualifier.
- addColumnFamily(TableName, ColumnFamilyDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Add a column family to an existing table.
- addColumnFamily(TableName, ColumnFamilyDescriptor) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Add a column family to an existing table.
- addColumnFamily(ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- addColumnFamilyAsync(TableName, ColumnFamilyDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Add a column family to an existing table.
- addColumns(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
-
Delete all versions of the specified column.
- addColumns(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.
- addColumns(Scan, byte[][]) - Static method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Adds an array of columns specified using old format, family:qualifier.
- addConfiguration(Map<String, String>) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor.Builder
-
- addConfiguration(String, String) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor.Builder
-
- addCoprocessor(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- addCoprocessor(String, Path, int, Map<String, String>) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- addCoprocessor(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Add a table coprocessor to this table.
- addCoprocessor(String, Path, int, Map<String, String>) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Add a table coprocessor to this table.
- addCoprocessorWithSpec(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- addCoprocessorWithSpec(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Add a table coprocessor to this table.
- addDeleteMarker(Cell) - Method in class org.apache.hadoop.hbase.client.Delete
-
- addDependencyJars(JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
- addDependencyJars(Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Add the HBase dependency jars as well as jars for any of the configured
job classes to the job configuration, so that JobClient will ship them
to the cluster and add them to the DistributedCache.
- addDependencyJars(Configuration, Class<?>...) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
- addDependencyJarsForClasses(Configuration, Class<?>...) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Add the jars containing the given classes to the job's configuration
such that JobClient will ship them to the cluster and add them to
the DistributedCache.
- addExtraHeader(String, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Add extra headers.
- addFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
-
Delete all versions of all columns of the specified family.
- addFamily(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.
- 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.HTableDescriptor
-
Deprecated.
Adds a column family.
- addFamilyVersion(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.
- addFilter(List<Filter>) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- addFilter(Filter) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
Add a filter.
- addFilterAndArguments(Configuration, Class<? extends Filter>, List<String>) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
-
Add a Filter to be instantiated on import
- addHBaseDependencyJars(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Add HBase and its dependencies (only) to the job configuration.
- addHbaseResources(Configuration) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
- addImmutable(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
-
- addImmutable(byte[], byte[], long, byte[]) - Method in class org.apache.hadoop.hbase.client.Put
-
- addImmutable(byte[], ByteBuffer, long, ByteBuffer) - Method in class org.apache.hadoop.hbase.client.Put
-
- addMaster() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- addMaster(Configuration, int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- addMaster(Configuration, int, User) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- addOptions() - Method in class org.apache.hadoop.hbase.mapreduce.RowCounter
-
- addOptions() - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- addOptions() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
- addOptions() - Method in class org.apache.hadoop.hbase.util.RegionMover
-
- addPeer(String, ReplicationPeerConfig, Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- addPeer(String, ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- addRegionServer() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- addRegionServer(Configuration, int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- addRegionServer(Configuration, int, User) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- addReplicationPeer(String, ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Add a new replication peer for replicating data to slave cluster.
- addReplicationPeer(String, ReplicationPeerConfig, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Add a new replication peer for replicating data to slave cluster.
- addReplicationPeer(String, ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Add a new replication peer for replicating data to slave cluster
- addReplicationPeer(String, ReplicationPeerConfig, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Add a new replication peer for replicating data to slave cluster
- addReplicationPeerAsync(String, ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Add a new replication peer but does not block and wait for it.
- addReplicationPeerAsync(String, ReplicationPeerConfig, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Add a new replication peer but does not block and wait for it.
- Address - Class in org.apache.hadoop.hbase.net
-
An immutable type to hold a hostname and port combo, like an Endpoint
or java.net.InetSocketAddress (but without danger of our calling
resolve -- we do NOT want a resolve happening every time we want
to hold a hostname and port combo).
- addServer(Address) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
Adds the given server to the group.
- addTable(TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
- addToken(Token<? extends TokenIdentifier>) - Method in class org.apache.hadoop.hbase.security.User
-
Adds the given Token to the user's credentials.
- addTypeFilter(QuotaType) - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
Add a type to the filter list
- Admin - Interface in org.apache.hadoop.hbase.client
-
The administrative API for HBase.
- ADMIN_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- advance() - Method in interface org.apache.hadoop.hbase.CellScanner
-
Advance the scanner 1 cell.
- advance() - Method in class org.apache.hadoop.hbase.client.Result
-
- AdvancedScanResultConsumer - Interface in org.apache.hadoop.hbase.client
-
This is the low level API for asynchronous scan.
- AdvancedScanResultConsumer.ScanController - Interface in org.apache.hadoop.hbase.client
-
Used to suspend or stop a scan, or get a scan cursor if available.
- AdvancedScanResultConsumer.ScanResumer - Interface in org.apache.hadoop.hbase.client
-
Used to resume a scan.
- ALL_VERSIONS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Define for 'return-all-versions'.
- allTime() - Static method in class org.apache.hadoop.hbase.io.TimeRange
-
- 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
-
- 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(byte[], long, NavigableMap<byte[], List<Cell>>) - Constructor for class org.apache.hadoop.hbase.client.Append
-
Construct the Append with user defined data.
- append(Append) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Appends values to one or more columns within a single row.
- append(Append) - Method in interface org.apache.hadoop.hbase.client.Table
-
Appends values to one or more columns within a single row.
- appendPeerTableCFs(String, String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- appendPeerTableCFs(String, Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Deprecated.
- appendReplicationPeerTableCFs(String, Map<TableName, List<String>>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Append the replicable table column family config from the specified peer.
- appendReplicationPeerTableCFs(String, Map<TableName, List<String>>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Append the replicable table-cf config of the specified peer
- apply(byte) - Method in enum org.apache.hadoop.hbase.util.Order
-
Apply order to the byte val
.
- apply(byte[]) - Method in enum org.apache.hadoop.hbase.util.Order
-
Apply order to the byte array val
.
- apply(byte[], int, int) - Method in enum org.apache.hadoop.hbase.util.Order
-
Apply order to a range within the byte array val
.
- areAdjacent(RegionInfo, RegionInfo) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Check whether two regions are adjacent; i.e.
- areAdjacent(HRegionInfo, HRegionInfo) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- arePartsEqual(ByteBuffer, int, int, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Check whether two parts in the same buffer are equal.
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedBlob
-
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedBlobVar
-
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedFloat32
-
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedFloat64
-
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt16
-
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt32
-
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt64
-
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt8
-
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedNumeric
-
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedString
-
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.RawBytes
-
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.RawString
-
- assign(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Assign a Region.
- assign(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
- ASSIGN_RANDOM_PORTS - Static variable in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- AsyncAdmin - Interface in org.apache.hadoop.hbase.client
-
The asynchronous administrative API for HBase.
- AsyncAdminBuilder - Interface in org.apache.hadoop.hbase.client
-
- AsyncBufferedMutator - Interface in org.apache.hadoop.hbase.client
-
Used to communicate with a single HBase table in batches.
- AsyncBufferedMutatorBuilder - Interface in org.apache.hadoop.hbase.client
-
- AsyncConnection - Interface in org.apache.hadoop.hbase.client
-
The asynchronous version of Connection.
- AsyncTable<C extends ScanResultConsumerBase> - Interface in org.apache.hadoop.hbase.client
-
The interface for asynchronous version of Table.
- AsyncTable.CoprocessorCallback<R> - Interface in org.apache.hadoop.hbase.client
-
The callback when we want to execute a coprocessor call on a range of regions.
- AsyncTableBuilder<C extends ScanResultConsumerBase> - Interface in org.apache.hadoop.hbase.client
-
- AsyncTableRegionLocator - Interface in org.apache.hadoop.hbase.client
-
The asynchronous version of RegionLocator.
- at(long) - Static method in class org.apache.hadoop.hbase.io.TimeRange
-
- ATTRIBUTE_SEPERATOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- Attributes - Interface in org.apache.hadoop.hbase.client
-
- AUTHENTICATION - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
-
Denotes classes that can be used to build custom authentication solutions.
- AuthUtil - Class in org.apache.hadoop.hbase
-
- await(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.locking.EntityLock
-
- await() - Method in class org.apache.hadoop.hbase.client.locking.EntityLock
-
- CACHE_BLOOMS_ON_WRITE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- CACHE_BLOOMS_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- CACHE_DATA_IN_L1 - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- CACHE_DATA_ON_WRITE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- CACHE_DATA_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- CACHE_INDEX_ON_WRITE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- CACHE_INDEX_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- CacheEvictionStats - Class in org.apache.hadoop.hbase
-
- calculateAutoBalancedSplits(List<InputSplit>, long) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Calculates the number of MapReduce input splits for the map tasks.
- call(S, RpcController, RpcCallback<R>) - Method in interface org.apache.hadoop.hbase.client.ServiceCaller
-
Represent the actual protobuf rpc call.
- CallCancelledException - Exception in org.apache.hadoop.hbase.ipc
-
Client side call cancelled.
- CallCancelledException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.CallCancelledException
-
- CallDroppedException - Exception in org.apache.hadoop.hbase
-
Returned to the clients when their request was discarded due to server being overloaded.
- CallDroppedException() - Constructor for exception org.apache.hadoop.hbase.CallDroppedException
-
- CallDroppedException(String) - Constructor for exception org.apache.hadoop.hbase.CallDroppedException
-
- 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
-
- CallQueueTooBigException - Exception in org.apache.hadoop.hbase
-
- CallQueueTooBigException() - Constructor for exception org.apache.hadoop.hbase.CallQueueTooBigException
-
- CallQueueTooBigException(String) - Constructor for exception org.apache.hadoop.hbase.CallQueueTooBigException
-
- CallTimeoutException - Exception in org.apache.hadoop.hbase.ipc
-
Client-side call timeout
- CallTimeoutException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.CallTimeoutException
-
- CallTimeoutException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.ipc.CallTimeoutException
-
CallTimeoutException with cause
- callWithoutRetries(RetryingCallable<T>, int) - Method in interface org.apache.hadoop.hbase.client.RpcRetryingCaller
-
Call the server once only.
- callWithRetries(RetryingCallable<T>, int) - Method in interface org.apache.hadoop.hbase.client.RpcRetryingCaller
-
Retries if invocation fails.
- cancel() - Method in interface org.apache.hadoop.hbase.client.RpcRetryingCaller
-
- cancel() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
- cancel(boolean) - Method in class org.apache.hadoop.hbase.ScheduledChore
-
- cancelChore(ScheduledChore) - Method in class org.apache.hadoop.hbase.ChoreService
-
- cancelChore(ScheduledChore, boolean) - Method in class org.apache.hadoop.hbase.ChoreService
-
- canTakeRow(HRegionLocation, Row) - Method in interface org.apache.hadoop.hbase.client.RequestController.Checker
-
Checks the data whether it is valid to submit.
- CATALOG_FAMILY - Static variable in class org.apache.hadoop.hbase.HConstants
-
The catalog family
- CATALOG_FAMILY_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The catalog family as a string
- catalogJanitorSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Enable/Disable the catalog janitor/
- catalogJanitorSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Turn the catalog janitor on/off.
- Cell - Interface in org.apache.hadoop.hbase
-
The unit of storage in HBase consisting of the following fields:
- CellBuilder - Interface in org.apache.hadoop.hbase
-
- CellBuilderFactory - Class in org.apache.hadoop.hbase
-
Create a CellBuilder instance.
- CellBuilderType - Enum in org.apache.hadoop.hbase
-
- CellComparator - Interface in org.apache.hadoop.hbase
-
Comparator for comparing cells and has some specialized methods that allows comparing individual
cell components like row, family, qualifier and timestamp
- CellCounter - Class in org.apache.hadoop.hbase.mapreduce
-
A job with a a map and reduce phase to count cells in a table.
- CellCounter() - Constructor for class org.apache.hadoop.hbase.mapreduce.CellCounter
-
- CellCreator - Class in org.apache.hadoop.hbase.mapreduce
-
Facade to create Cells for HFileOutputFormat.
- CellCreator(Configuration) - Constructor for class org.apache.hadoop.hbase.mapreduce.CellCreator
-
- CellScannable - Interface in org.apache.hadoop.hbase
-
Implementer can return a CellScanner over its Cell content.
- cellScanner() - Method in interface org.apache.hadoop.hbase.CellScannable
-
- CellScanner - Interface in org.apache.hadoop.hbase
-
An interface for iterating through a sequence of cells.
- cellScanner() - Method in class org.apache.hadoop.hbase.client.Mutation
-
- cellScanner() - Method in class org.apache.hadoop.hbase.client.Result
-
- CellScannerButNoCodecException - Exception in org.apache.hadoop.hbase.ipc
-
Thrown if a cellscanner but no codec to encode it with.
- CellScannerButNoCodecException() - Constructor for exception org.apache.hadoop.hbase.ipc.CellScannerButNoCodecException
-
- CellSerialization - Class in org.apache.hadoop.hbase.mapreduce
-
Use to specify the type of serialization for the mappers and reducers
- CellSerialization() - Constructor for class org.apache.hadoop.hbase.mapreduce.CellSerialization
-
- CellSortReducer - Class in org.apache.hadoop.hbase.mapreduce
-
Emits sorted Cells.
- CellSortReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.CellSortReducer
-
- CellUtil - Class in org.apache.hadoop.hbase
-
Utility methods helpful for slinging
Cell
instances.
- cellVisibilityExpr - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
- CF_RENAME_PROP - Static variable in class org.apache.hadoop.hbase.mapreduce.Import
-
- CFNAME - Static variable in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Deprecated.
- chance - Variable in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
- checkAndDelete(byte[], byte[], byte[], byte[], Delete) - Method in interface org.apache.hadoop.hbase.client.Table
-
- checkAndDelete(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Delete) - Method in interface org.apache.hadoop.hbase.client.Table
-
- checkAndDelete(byte[], byte[], byte[], CompareOperator, byte[], Delete) - Method in interface org.apache.hadoop.hbase.client.Table
-
- checkAndMutate(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Atomically checks if a row/family/qualifier value matches the expected value.
- checkAndMutate(byte[], Filter) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Atomically checks if a row matches the specified filter.
- checkAndMutate(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Table
-
Atomically checks if a row/family/qualifier value matches the expected value.
- checkAndMutate(byte[], Filter) - Method in interface org.apache.hadoop.hbase.client.Table
-
Atomically checks if a row matches the specified filter.
- checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], RowMutations) - Method in interface org.apache.hadoop.hbase.client.Table
-
- checkAndMutate(byte[], byte[], byte[], CompareOperator, byte[], RowMutations) - Method in interface org.apache.hadoop.hbase.client.Table
-
- checkAndPut(byte[], byte[], byte[], byte[], Put) - Method in interface org.apache.hadoop.hbase.client.Table
-
- checkAndPut(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Put) - Method in interface org.apache.hadoop.hbase.client.Table
-
- checkAndPut(byte[], byte[], byte[], CompareOperator, byte[], Put) - Method in interface org.apache.hadoop.hbase.client.Table
-
- 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'
- checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat
-
- checkOutputSpecs(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
-
- checkOutputSpecs(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
Checks if the output table exists and is enabled.
- checkSizeAndGrow(int) - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
-
- CHECKSUM_TYPE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
The name of the configuration parameter that specifies
the name of an algorithm that is used to compute checksums
for newly created blocks.
- chore() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
The task to execute on each scheduled execution of the Chore
- choreForTesting() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
- ChoreService - Class in org.apache.hadoop.hbase
-
ChoreService is a service that can be used to schedule instances of
ScheduledChore
to run
periodically while sharing threads.
- ChoreService(String) - Constructor for class org.apache.hadoop.hbase.ChoreService
-
- ChoreService(String, boolean) - Constructor for class org.apache.hadoop.hbase.ChoreService
-
- ChoreService(String, int, boolean) - Constructor for class org.apache.hadoop.hbase.ChoreService
-
- Cipher - Class in org.apache.hadoop.hbase.io.crypto
-
A common interface for a cryptographic algorithm.
- Cipher(CipherProvider) - Constructor for class org.apache.hadoop.hbase.io.crypto.Cipher
-
- CIPHER_AES - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default cipher for encryption
- CipherProvider - Interface in org.apache.hadoop.hbase.io.crypto
-
An CipherProvider contributes support for various cryptographic
Ciphers.
- classifyExs(List<Throwable>) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- CLASSNAME_KEY - Static variable in interface org.apache.hadoop.hbase.client.BufferedMutator
-
Key to use setting non-default BufferedMutator implementation in Configuration.
- cleanerChoreSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Enable/Disable the cleaner chore.
- cleanerChoreSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Turn the cleaner chore on/off.
- cleanup() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
Override to run cleanup tasks when the Chore encounters an error and must stop running
- cleanupJob(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- clear() - Method in interface org.apache.hadoop.hbase.CellBuilder
-
Remove all internal elements from builder.
- clearBlockCache(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Clear all the blocks corresponding to this table from BlockCache.
- clearBlockCache(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Clear all the blocks corresponding to this table from BlockCache.
- clearCompactionQueues(ServerName, Set<String>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Clear compacting queues on a regionserver.
- clearCompactionQueues(ServerName, Set<String>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Clear compacting queues on a region server.
- clearDeadServers(List<ServerName>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Clear dead region servers from master.
- clearDeadServers(List<ServerName>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Clear dead region servers from master.
- clearRegionLocationCache() - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Clear all the entries in the region location cache, for all the tables.
- clearRegionLocationCache() - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Clear all the entries in the region location cache.
- clearRegionLocationCache() - Method in interface org.apache.hadoop.hbase.client.Connection
-
Clear all the entries in the region location cache, for all the tables.
- clearRegionLocationCache() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Clear all the entries in the region location cache.
- clearSlowLogResponses(Set<ServerName>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Clears online slow/large RPC logs from the provided list of
RegionServers
- clearSlowLogResponses(Set<ServerName>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Clears online slow RPC logs from the provided list of
RegionServers
- Client - Class in org.apache.hadoop.hbase.rest.client
-
A wrapper around HttpClient which provides some useful function and
semantics for interacting with the REST gateway.
- Client() - Constructor for class org.apache.hadoop.hbase.rest.client.Client
-
Default Constructor
- Client(Cluster) - Constructor for class org.apache.hadoop.hbase.rest.client.Client
-
Constructor
- Client(Cluster, boolean) - Constructor for class org.apache.hadoop.hbase.rest.client.Client
-
Constructor
- CLIENT_CONNECTION_REGISTRY_IMPL_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Registry implementation to be used on the client side.
- CLIENT_PORT_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The ZK client port key in the ZK properties map.
- CLIENT_ZOOKEEPER_CLIENT_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Client port of ZooKeeper for client to locate meta
- CLIENT_ZOOKEEPER_OBSERVER_MODE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Indicate whether the client ZK are observer nodes of the server ZK
- CLIENT_ZOOKEEPER_QUORUM - Static variable in class org.apache.hadoop.hbase.HConstants
-
Name of ZooKeeper quorum configuration parameter for client to locate 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.
- 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
-
- clone() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- cloneFamily(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- cloneQualifier(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- cloneRow(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
get individual arrays for tests
- cloneSnapshot(byte[], TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- cloneSnapshot(String, TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create a new table by cloning the snapshot content.
- cloneSnapshot(String, TableName, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create a new table by cloning the snapshot content.
- cloneSnapshot(String, TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Create a new table by cloning the snapshot content.
- cloneSnapshot(String, TableName, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Create a new table by cloning the snapshot content.
- cloneSnapshotAsync(String, TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create a new table by cloning the snapshot content, but does not block and wait for it to be
completely cloned.
- cloneSnapshotAsync(String, TableName, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create a new table by cloning the snapshot content.
- cloneTableSchema(TableName, TableName, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create a new table by cloning the existent table schema.
- cloneTableSchema(TableName, TableName, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Create a new table by cloning the existent table schema.
- cloneTags(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- cloneValue(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- close() - Method in interface org.apache.hadoop.hbase.client.Admin
-
- close() - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutator
-
- close() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
- close() - Method in interface org.apache.hadoop.hbase.client.Connection
-
- close() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
-
Deprecated.
- close() - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Deprecated.
- close() - Method in interface org.apache.hadoop.hbase.client.ResultScanner
-
Closes the scanner and releases any resources it has allocated
- close() - Method in interface org.apache.hadoop.hbase.client.Table
-
Releases any resources held or pending changes in internal buffers.
- close() - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
-
- close() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- close() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- close() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
Closes the split.
- close() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
Closes the split.
- close() - Method in class org.apache.hadoop.hbase.quotas.QuotaRetriever
-
- close() - Method in class org.apache.hadoop.hbase.util.RegionMover
-
- closeRegion(String, String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- closeRegion(byte[], String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- closeRegion(ServerName, HRegionInfo) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- closeRegionWithEncodedRegionName(String, String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- closeTable() - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
- closeTable() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- Cluster - Class in org.apache.hadoop.hbase.rest.client
-
A list of 'host:port' addresses of HTTP servers operating as a single
entity, for example multiple redundant web service gateways.
- Cluster() - Constructor for class org.apache.hadoop.hbase.rest.client.Cluster
-
Constructor
- Cluster(List<String>) - Constructor for class org.apache.hadoop.hbase.rest.client.Cluster
-
Constructor
- CLUSTER_DISTRIBUTED - Static variable in class org.apache.hadoop.hbase.HConstants
-
Cluster is in distributed mode or not
- CLUSTER_ID_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default value for cluster ID
- CLUSTER_ID_FILE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
name of the file for unique cluster ID
- CLUSTER_IS_DISTRIBUTED - Static variable in class org.apache.hadoop.hbase.HConstants
-
Deprecated.
- CLUSTER_IS_LOCAL - Static variable in class org.apache.hadoop.hbase.HConstants
-
Cluster is standalone or pseudo-distributed
- ClusterMetrics - Interface in org.apache.hadoop.hbase
-
Metrics information on the HBase cluster.
- ClusterStatus - Class in org.apache.hadoop.hbase
-
- ClusterStatus(String, String, Map<ServerName, ServerLoad>, Collection<ServerName>, ServerName, Collection<ServerName>, List<RegionState>, String[], Boolean, int) - Constructor for class org.apache.hadoop.hbase.ClusterStatus
-
- ClusterStatus(ClusterMetrics) - Constructor for class org.apache.hadoop.hbase.ClusterStatus
-
Deprecated.
- cmp(int) - Method in enum org.apache.hadoop.hbase.util.Order
-
Returns the adjusted trichotomous value according to the ordering imposed by this
Order
.
- colFamTimeRangeMap - Variable in class org.apache.hadoop.hbase.client.Query
-
- COLON - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for colon (:)
- COLUMN_LIST - Static variable in class org.apache.hadoop.hbase.mapred.TableInputFormat
-
space delimited list of columns
- 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
-
- ColumnFamilyDescriptor - Interface in org.apache.hadoop.hbase.client
-
An ColumnFamilyDescriptor contains information about a column family such as the
number of versions, compression settings, etc.
- ColumnFamilyDescriptorBuilder - Class in org.apache.hadoop.hbase.client
-
- 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.
- columns - Variable in class org.apache.hadoop.hbase.mapred.GroupingTableMap
-
- columns - Variable in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
The grouping columns.
- COLUMNS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- ColumnValueFilter - Class in org.apache.hadoop.hbase.filter
-
- ColumnValueFilter(byte[], byte[], CompareOperator, byte[]) - Constructor for class org.apache.hadoop.hbase.filter.ColumnValueFilter
-
- ColumnValueFilter(byte[], byte[], CompareOperator, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.ColumnValueFilter
-
- com.google.protobuf - package com.google.protobuf
-
- combineTableNameSuffix(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
- COMMA - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for a comma
- commitTask(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- compact(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Compact a table.
- compact(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Compact a column family within a table.
- compact(TableName, CompactType) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Compact a table.
- compact(TableName, byte[], CompactType) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Compact a column family within a table.
- compact(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Compact a table.
- compact(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Compact a column family within a table.
- compact(TableName, CompactType) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Compact a table.
- compact(TableName, byte[], CompactType) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Compact a column family within a table.
- COMPACTION_ENABLED - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Used by HBase Shell interface to access this metadata
attribute which denotes if the table is compaction enabled.
- COMPACTION_ENABLED - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- COMPACTION_KV_MAX - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for the maximum batch of KVs to be used in flushes and compactions
- COMPACTION_KV_MAX_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- CompactionState - Enum in org.apache.hadoop.hbase.client
-
POJO representing the compaction state
- compactionSwitch(boolean, List<String>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Turn the compaction on or off.
- compactionSwitch(boolean, List<String>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Turn the compaction on or off.
- compactRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Compact an individual region.
- compactRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Compact a column family within a region.
- compactRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Compact an individual region.
- compactRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Compact a column family within a region.
- compactRegionServer(ServerName, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- compactRegionServer(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Compact all regions on the region server.
- compactRegionServer(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Compact all regions on the region server.
- CompactType - Enum in org.apache.hadoop.hbase.client
-
Currently, there are only two compact types:
NORMAL
means do store files compaction;
MOB
means do mob files compaction.
- COMPARATOR - Static variable in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- COMPARATOR - Static variable in interface org.apache.hadoop.hbase.client.RegionInfo
-
- COMPARATOR - Static variable in interface org.apache.hadoop.hbase.client.Row
-
- COMPARATOR - Static variable in interface org.apache.hadoop.hbase.client.TableDescriptor
-
- comparator - Variable in class org.apache.hadoop.hbase.filter.CompareFilter
-
- comparator - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- Comparator() - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable.Comparator
-
constructor
- COMPARATOR_IGNORE_REPLICATION - Static variable in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- COMPARATOR_IGNORE_REPLICATION - Static variable in interface org.apache.hadoop.hbase.client.TableDescriptor
-
- compare(Cell, Cell) - Method in interface org.apache.hadoop.hbase.CellComparator
-
Lexographically compares two cells.
- compare(Cell, Cell, boolean) - Method in interface org.apache.hadoop.hbase.CellComparator
-
Compare cells.
- compare(CellComparator, Cell, byte[], int, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable.Comparator
-
- compare(long) - Method in class org.apache.hadoop.hbase.io.TimeRange
-
Compare the timestamp to timerange.
- compare(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.Bytes.ByteArrayComparator
-
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.Bytes.ByteArrayComparator
-
- compare(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.Bytes.RowEndKeyComparator
-
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.Bytes.RowEndKeyComparator
-
- compareColumns(Cell, byte[], int, int, int, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Compares the cell's column (family and qualifier) with the given byte[]
- compareFamilies(Cell, Cell) - Method in interface org.apache.hadoop.hbase.CellComparator
-
Lexographically compares the families of the two cells
- compareFamilies(Cell, byte[], int, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Compares the cell's family with the given byte[]
- compareFamily(CompareFilter.CompareOp, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- compareFamily(CompareOperator, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- 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
-
- CompareFilter(CompareOperator, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.CompareFilter
-
Constructor.
- CompareFilter.CompareOp - Enum in org.apache.hadoop.hbase.filter
-
- CompareOperator - Enum in org.apache.hadoop.hbase
-
Generic set of comparison operators.
- compareQualifier(CompareFilter.CompareOp, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- compareQualifier(CompareOperator, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- compareQualifiers(Cell, Cell) - Method in interface org.apache.hadoop.hbase.CellComparator
-
Lexographically compares the qualifiers of the two cells
- compareQualifiers(Cell, byte[], int, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Compares the cell's qualifier with the given byte[]
- 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.
- compareRow(CompareFilter.CompareOp, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- compareRow(CompareOperator, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- compareRows(Cell, Cell) - Method in interface org.apache.hadoop.hbase.CellComparator
-
Lexographically compares the rows of two cells.
- compareRows(Cell, byte[], int, int) - Method in interface org.apache.hadoop.hbase.CellComparator
-
Compares the row part of the cell with a simple plain byte[] like the
stopRow in Scan.
- compareRows(ByteBuffer, Cell) - Method in interface org.apache.hadoop.hbase.CellComparator
-
- compareTimestamps(Cell, Cell) - Method in interface org.apache.hadoop.hbase.CellComparator
-
Compares cell's timestamps in DESCENDING order.
- compareTimestamps(long, long) - Method in interface org.apache.hadoop.hbase.CellComparator
-
Compares cell's timestamps in DESCENDING order.
- compareTo(Row) - Method in class org.apache.hadoop.hbase.client.Get
-
- compareTo(Row) - Method in class org.apache.hadoop.hbase.client.Mutation
-
- compareTo(RegionInfo) - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
- compareTo(Row) - Method in interface org.apache.hadoop.hbase.client.Row
-
- compareTo(Row) - Method in class org.apache.hadoop.hbase.client.RowMutations
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.BigDecimalComparator
-
- compareTo(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.filter.BigDecimalComparator
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.BinaryComparator
-
- compareTo(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.filter.BinaryComparator
-
- compareTo(byte[]) - Method in class org.apache.hadoop.hbase.filter.BinaryComponentComparator
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.BinaryComponentComparator
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.BinaryPrefixComparator
-
- compareTo(ByteBuffer, 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(ByteBuffer, 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(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
-
Special compareTo method for subclasses, to avoid copying bytes unnecessarily.
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.LongComparator
-
- compareTo(ByteBuffer, 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(ByteBuffer, 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
-
Deprecated.
- compareTo(HRegionLocation) - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- compareTo(HTableDescriptor) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Compares the descriptor with another descriptor which is passed as a parameter.
- compareTo(ImmutableBytesWritable) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Define the sort order of the BytesWritable.
- compareTo(byte[]) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Compares the bytes in this object to the specified byte array
- compareTo(TableSplit) - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
- compareTo(TableSplit) - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Compares this split against the given one.
- compareTo(Address) - Method in class org.apache.hadoop.hbase.net.Address
-
- compareTo(ServerName) - Method in class org.apache.hadoop.hbase.ServerName
-
- compareTo(Size) - Method in class org.apache.hadoop.hbase.Size
-
- compareTo(TableName) - Method in class org.apache.hadoop.hbase.TableName
-
For performance reasons, the ordering is not lexicographic.
- compareTo(ByteBuffer, int, int, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
- compareTo(byte[], int, int, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
- compareTo(ByteBuffer, int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
- compareTo(Bytes) - Method in class org.apache.hadoop.hbase.util.Bytes
-
Define the sort order of the Bytes.
- compareTo(byte[]) - Method in class org.apache.hadoop.hbase.util.Bytes
-
Compares the bytes in this object to the specified byte array
- compareTo(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- compareTo(byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Lexicographically compare two arrays.
- compareValue(CompareFilter.CompareOp, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- compareValue(CompareOperator, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- compareVersion(String, String) - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
- compareWithoutRow(Cell, Cell) - Method in interface org.apache.hadoop.hbase.CellComparator
-
Lexographically compares the two cells excluding the row part.
- COMPRESS_TAGS - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- COMPRESS_TAGS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- COMPRESSION - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- COMPRESSION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- COMPRESSION_COMPACT - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- COMPRESSION_COMPACT - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- COMPRESSION_OVERRIDE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
- computeDelta(TableDescriptor, TableDescriptor) - Static method in class org.apache.hadoop.hbase.client.TableDescriptorUtils
-
Compares two
TableDescriptor
and indicate which columns were added, deleted,
or modified from oldTD to newTD
- ConcurrentTableModificationException - Exception in org.apache.hadoop.hbase
-
Thrown when a table has been modified concurrently
- ConcurrentTableModificationException() - Constructor for exception org.apache.hadoop.hbase.ConcurrentTableModificationException
-
default constructor
- ConcurrentTableModificationException(String) - Constructor for exception org.apache.hadoop.hbase.ConcurrentTableModificationException
-
Constructor
- ConcurrentTableModificationException(byte[]) - Constructor for exception org.apache.hadoop.hbase.ConcurrentTableModificationException
-
- ConcurrentTableModificationException(TableName) - Constructor for exception org.apache.hadoop.hbase.ConcurrentTableModificationException
-
- conf - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
- CONF_DEST_PREFIX - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
Configuration prefix for overrides for the destination filesystem
- CONF_SKIP_TMP - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- CONF_SOURCE_PREFIX - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
Configuration prefix for overrides for the source filesystem
- CONFIG - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
-
Denotes class names that appear in user facing configuration files.
- CONFIGURATION - Static variable in class org.apache.hadoop.hbase.HConstants
-
- ConfigurationUtil - Class in org.apache.hadoop.hbase.util
-
Utilities for storing more complex collection types in
Configuration
instances.
- configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
-
- configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.HRegionPartitioner
-
- configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormat
-
- configureCfRenaming(Configuration, Map<String, String>) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
-
Sets a configuration property with key
Import.CF_RENAME_PROP
in conf that tells
the mapper how to rename column families.
- configureIncrementalLoad(Job, Table, RegionLocator) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
Configure a MapReduce Job to perform an incremental load into the given
table.
- configureIncrementalLoad(Job, TableDescriptor, RegionLocator) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
Configure a MapReduce Job to perform an incremental load into the given
table.
- configureIncrementalLoad(Job, List<HFileOutputFormat2.TableInfo>) - Static method in class org.apache.hadoop.hbase.mapreduce.MultiTableHFileOutputFormat
-
- configureIncrementalLoadMap(Job, TableDescriptor) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
- configureSplitTable(Job, TableName) - Static method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Sets split table in map-reduce job.
- Connection - Interface in org.apache.hadoop.hbase.client
-
A cluster connection encapsulating lower level individual connections to actual servers and
a connection to zookeeper.
- ConnectionClosedException - Exception in org.apache.hadoop.hbase.exceptions
-
Thrown when the connection is closed
- ConnectionClosedException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.ConnectionClosedException
-
- ConnectionClosedException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.ConnectionClosedException
-
ConnectionClosedException with cause
- ConnectionClosingException - Exception in org.apache.hadoop.hbase.exceptions
-
Thrown when the client believes that we are trying to communicate to has
been repeatedly unresponsive for a while.
- ConnectionClosingException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.ConnectionClosingException
-
- ConnectionClosingException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.ConnectionClosingException
-
ConnectionClosingException with cause
- ConnectionFactory - Class in org.apache.hadoop.hbase.client
-
A non-instantiable class that manages creation of
Connection
s.
- ConnectionFactory() - Constructor for class org.apache.hadoop.hbase.client.ConnectionFactory
-
No public c.tors
- Consistency - Enum in org.apache.hadoop.hbase.client
-
Consistency defines the expected consistency level for an operation.
- consistency - Variable in class org.apache.hadoop.hbase.client.Query
-
- Constants - Interface in org.apache.hadoop.hbase.rest
-
Common constants for org.apache.hadoop.hbase.rest
- contains(byte[], byte) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- contains(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- 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).
- 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 interface org.apache.hadoop.hbase.client.RegionInfo
-
- containsRange(byte[], byte[]) - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
Returns true if the given inclusive range of rows is fully contained
by this region.
- containsRow(byte[]) - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
- containsRow(byte[]) - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
- containsServer(Address) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
- containsTable(TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
- Context - Class in org.apache.hadoop.hbase.io.crypto
-
Crypto context.
- convert(HRegionInfo) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- convert(HBaseProtos.RegionInfo) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- 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
- convertScanToString(Scan) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Writes the given scan into a Base64 encoded string.
- convertStringToScan(String) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Converts the given Base64 string back into a Scan instance.
- COPROC - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
-
- CoprocessorDescriptor - Interface in org.apache.hadoop.hbase.client
-
CoprocessorDescriptor contains the details about how to build a coprocessor.
- CoprocessorDescriptorBuilder - Class in org.apache.hadoop.hbase.client
-
- 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 - Interface in org.apache.hadoop.hbase.ipc
-
Base interface which provides clients with an RPC connection to
call coprocessor endpoint Service
s.
- coprocessorService() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Creates and returns a RpcChannel
instance connected to the active
master.
- coprocessorService(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Creates and returns a RpcChannel
instance
connected to the passed region server.
- coprocessorService(Function<RpcChannel, S>, ServiceCaller<S, R>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Execute the given coprocessor call on the master.
- coprocessorService(Function<RpcChannel, S>, ServiceCaller<S, R>, ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Execute the given coprocessor call on the given region server.
- coprocessorService(Function<RpcChannel, S>, ServiceCaller<S, R>, byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Execute the given coprocessor call on the region which contains the given row
.
- coprocessorService(Function<RpcChannel, S>, ServiceCaller<S, R>, AsyncTable.CoprocessorCallback<R>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Execute a coprocessor call on the regions which are covered by a range.
- coprocessorService(byte[]) - Method in interface org.apache.hadoop.hbase.client.Table
-
Creates and returns a RpcChannel
instance connected to the
table region containing the specified row.
- coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>) - Method in interface org.apache.hadoop.hbase.client.Table
-
Creates an instance of the given Service
subclass for each table
region spanning the range from the startKey
row to endKey
row (inclusive), and
invokes the passed Batch.Call.call(T)
method
with each Service
instance.
- coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>, Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.Table
-
Creates an instance of the given Service
subclass for each table
region spanning the range from the startKey
row to endKey
row (inclusive), and
invokes the passed Batch.Call.call(T)
method
with each Service
instance.
- copy(ColumnFamilyDescriptor) - Static method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- copy(TableDescriptor) - Static method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- copy(TableName, TableDescriptor) - Static method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- copy(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Copy the byte array given in parameter and return an instance
of a new byte array with the same length and the same content.
- copy(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Copy the byte array given in parameter and return an instance
of a new byte array with the same length and the same content.
- copyBufferToStream(OutputStream, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Copy data from a buffer to an output stream.
- copyBufferToStream(DataOutput, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Copy data from a buffer to an output stream.
- copyBytes() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Returns a copy of the bytes referred to by this writable
- copyBytes() - Method in class org.apache.hadoop.hbase.util.Bytes
-
Returns a copy of the bytes referred to by this writable
- copyFamilyTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Copies the family to the given byte[]
- copyFamilyTo(Cell, ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Copies the family to the given bytebuffer
- copyFrom(Result) - Method in class org.apache.hadoop.hbase.client.Result
-
Copy another Result into this one.
- copyFromArrayToBuffer(ByteBuffer, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Copies the bytes from given array's offset to length part into the given buffer.
- copyFromArrayToBuffer(ByteBuffer, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Copies bytes from given array's offset to length part into the given buffer.
- copyFromBufferToArray(byte[], ByteBuffer, int, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Copies specified number of bytes from given offset of 'in' ByteBuffer to
the array.
- copyFromBufferToBuffer(ByteBuffer, ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Copy one buffer's whole data to another.
- copyFromBufferToBuffer(ByteBuffer, ByteBuffer, int, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Copy from one buffer to another from given offset.
- copyFromBufferToBuffer(ByteBuffer, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Copy from one buffer to another from given offset.
- copyFromStreamToBuffer(ByteBuffer, DataInputStream, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Copy the given number of bytes from the given stream and put it at the
current position of the given buffer, updating the position in the buffer.
- copyOfRange(ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
- copyQualifierTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Copies the qualifier to the given byte[]
- copyQualifierTo(Cell, ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Copies the qualifier to the given bytebuffer
- copyRow(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Copies the row to a new byte[]
- copyRowTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Copies the row to the given byte[]
- copyRowTo(Cell, ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Copies the row to the given bytebuffer
- CopyTable - Class in org.apache.hadoop.hbase.mapreduce
-
Tool used to copy a table to another one which can be on a different setup.
- CopyTable() - Constructor for class org.apache.hadoop.hbase.mapreduce.CopyTable
-
- copyTagTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- copyTagTo(Cell, ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- copyToNewArrays(Collection<ByteRange>) - Static method in class org.apache.hadoop.hbase.util.ByteRangeUtils
-
- copyValueTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Copies the value to the given byte[]
- copyValueTo(Cell, ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Copies the value to the given bytebuffer
- CORRUPT_DIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
- 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
-
Snapshot was corrupt for some reason.
- CorruptedSnapshotException(String, 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
-
Snapshot was corrupt for some reason.
- Counter - Class in org.apache.hadoop.hbase.util
-
- Counter() - Constructor for class org.apache.hadoop.hbase.util.Counter
-
Deprecated.
- Counter(long) - Constructor for class org.apache.hadoop.hbase.util.Counter
-
Deprecated.
- CP_HTD_ATTR_INCLUSION_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
- CP_HTD_ATTR_KEY_PATTERN - Static variable in class org.apache.hadoop.hbase.HConstants
-
- CP_HTD_ATTR_VALUE_PARAM_KEY_PATTERN - Static variable in class org.apache.hadoop.hbase.HConstants
-
- CP_HTD_ATTR_VALUE_PARAM_PATTERN - Static variable in class org.apache.hadoop.hbase.HConstants
-
- CP_HTD_ATTR_VALUE_PARAM_VALUE_PATTERN - Static variable in class org.apache.hadoop.hbase.HConstants
-
- CP_HTD_ATTR_VALUE_PATTERN - Static variable in class org.apache.hadoop.hbase.HConstants
-
- create(CellBuilderType) - Static method in class org.apache.hadoop.hbase.CellBuilderFactory
-
Create a CellBuilder instance.
- create(Configuration) - Static method in class org.apache.hadoop.hbase.client.RequestControllerFactory
-
- 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(List<Cell>, Boolean, boolean) - Static method in class org.apache.hadoop.hbase.client.Result
-
- create(List<Cell>, Boolean, boolean, 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(Cell[], Boolean, boolean) - Static method in class org.apache.hadoop.hbase.client.Result
-
- create(Cell[], Boolean, boolean, boolean) - Static method in class org.apache.hadoop.hbase.client.Result
-
- create() - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
Creates a Configuration with HBase resources
- create(Configuration) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
- create(byte[], int, int, byte[], int, int, byte[], int, int, long, byte[], int, int) - Method in class org.apache.hadoop.hbase.mapreduce.CellCreator
-
- create(byte[], int, int, byte[], int, int, byte[], int, int, long, byte[], int, int, String) - Method in class org.apache.hadoop.hbase.mapreduce.CellCreator
-
- create(byte[], int, int, byte[], int, int, byte[], int, int, long, byte[], int, int, List<Tag>) - Method in class org.apache.hadoop.hbase.mapreduce.CellCreator
-
- create(String) - Static method in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- create(NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- create(UserGroupInformation) - Static method in class org.apache.hadoop.hbase.security.User
-
Wraps an underlying UserGroupInformation
instance.
- CREATE_TABLE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- createAsyncConnection() - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
- createAsyncConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
- createAsyncConnection(Configuration, User) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Create a new AsyncConnection instance using the passed conf
and user
.
- createCell(byte[], byte[], byte[], long, byte, byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- createCell(byte[], int, int, byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- createCell(byte[], byte[], byte[], long, byte, byte[], long) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- createCell(byte[], byte[], byte[], long, byte, byte[], byte[], long) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- createCell(byte[], byte[], byte[], long, KeyValue.Type, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- createCell(byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- createCell(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- createCell(byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- createCell(Cell, List<Tag>) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- createCell(Cell, byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- createCell(Cell, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- createCellScanner(List<? extends CellScannable>) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- createCellScanner(Iterable<Cell>) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- createCellScanner(Iterator<Cell>) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- createCellScanner(Cell[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- createCellScanner(NavigableMap<byte[], List<Cell>>) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Flatten the map of cells out under the CellScanner
- createClusterConf(Configuration, String) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
Generates a Configuration
instance by applying the ZooKeeper cluster key
to the base Configuration.
- createClusterConf(Configuration, String, String) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
Generates a Configuration
instance by applying property overrides prefixed by
a cluster profile key to the base Configuration.
- 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
-
- createCompareOperator(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Takes a compareOperator symbol as a byte array and returns the corresponding CompareOperator
- createCompleteResult(Iterable<Result>) - Static method in class org.apache.hadoop.hbase.client.Result
-
Forms a single result from the partial results in the partialResults list.
- createCompositeKey(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.MultiTableHFileOutputFormat
-
Creates a composite key to use as a mapper output key when using
MultiTableHFileOutputFormat.configureIncrementaLoad to set up bulk ingest job
- createCompositeKey(byte[], ImmutableBytesWritable) - Static method in class org.apache.hadoop.hbase.mapreduce.MultiTableHFileOutputFormat
-
Alternate api which accepts an ImmutableBytesWritable for the suffix
- createCompositeKey(String, ImmutableBytesWritable) - Static method in class org.apache.hadoop.hbase.mapreduce.MultiTableHFileOutputFormat
-
Alternate api which accepts a String for the tableName and ImmutableBytesWritable for the
suffix
- createConnection() - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Create a new Connection instance using default HBaseConfiguration.
- createConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Create a new Connection instance using the passed conf
instance.
- createConnection(Configuration, ExecutorService) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Create a new Connection instance using the passed conf
instance.
- createConnection(Configuration, User) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Create a new Connection instance using the passed conf
instance.
- createConnection(Configuration, ExecutorService, User) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Create a new Connection instance using the passed conf
instance.
- createCursorResult(Cursor) - Static method in class org.apache.hadoop.hbase.client.Result
-
- createDecryptionStream(InputStream, Context, byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Create a decrypting input stream given a context and IV
- createDecryptionStream(InputStream, Decryptor) - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Create a decrypting output stream given an initialized decryptor
- createDecryptionStream(InputStream) - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
-
Create a stream for decryption
- createEncoder(String) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
- createEncryptionStream(OutputStream, Context, byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Create an encrypting output stream given a context and IV
- createEncryptionStream(OutputStream, Encryptor) - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Create an encrypting output stream given an initialized encryptor
- createEncryptionStream(OutputStream) - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
-
Create a stream for encryption
- createEventLoopPerClient(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.NettyRpcClientConfigHelper
-
The NettyRpcClient
will create its own NioEventLoopGroup
.
- 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.ColumnValueFilter
-
Creating this filter by reflection, it is used by
ParseFilter
,
- 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.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
-
- createGroupKey(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
-
Create a key by concatenating multiple column values.
- createGroupKey(byte[][]) - Method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
Create a key by concatenating multiple column values.
- createKey() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- createKey() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- createMaxByteArray(int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Create a max byte array with the specified max byte count
- createMobRegionInfo(TableName) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Creates a RegionInfo object for MOB data.
- createNamespace(NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create a new namespace.
- createNamespace(NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Create a new namespace.
- createNamespaceAsync(NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create a new namespace.
- createNInputSplitsUniform(InputSplit, int) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Create n splits for one InputSplit, For now only support uniform distribution
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
-
Builds a TableRecordReader.
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat
-
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.WALInputFormat
-
- createRegionName(TableName, byte[], long, boolean) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Make a region name of passed parameters.
- createRegionName(TableName, byte[], String, boolean) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Make a region name of passed parameters.
- createRegionName(TableName, byte[], long, int, boolean) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Make a region name of passed parameters.
- createRegionName(TableName, byte[], byte[], boolean) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Make a region name of passed parameters.
- createRegionName(TableName, byte[], byte[], int, boolean) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Make a region name of passed parameters.
- createRegionName(TableName, byte[], long, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- createRegionName(TableName, byte[], String, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- createRegionName(TableName, byte[], long, int, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- createRegionName(TableName, byte[], byte[], boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- createRegionName(TableName, byte[], byte[], int, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- createRegionSizeCalculator(RegionLocator, Admin) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- createScanFromConfiguration(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Sets up a
Scan
instance, applying settings from the configuration property
constants defined in
TableInputFormat
.
- createScanFromCursor(Cursor) - Static method in class org.apache.hadoop.hbase.client.Scan
-
Create a new Scan with a cursor.
- createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.mapred.RowCounter
-
- createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.CellCounter
-
Sets up the actual job.
- createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.CopyTable
-
Sets up the actual job.
- createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.Export
-
Sets up the actual job.
- createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
-
Sets up the actual job.
- createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
Sets up the actual job.
- createSubmittableJob(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.RowCounter
-
Sets up the actual job.
- createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.RowCounter
-
- createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.WALPlayer
-
Sets up the actual job.
- createTable(TableDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Creates a new table.
- createTable(TableDescriptor, byte[], byte[], int) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Creates a new table with the specified number of regions.
- createTable(TableDescriptor, byte[][]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Creates a new table with an initial set of empty regions defined by the specified split keys.
- createTable(TableDescriptor) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Creates a new table.
- createTable(TableDescriptor, byte[], byte[], int) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Creates a new table with the specified number of regions.
- createTable(TableDescriptor, byte[][]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Creates a new table with an initial set of empty regions defined by the specified split keys.
- createTableAsync(TableDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Creates a new table but does not block and wait for it to come online.
- createTableAsync(TableDescriptor, byte[][]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
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
- createUserForTesting(Configuration, String, String[]) - Static method in class org.apache.hadoop.hbase.security.User
-
Generates a new User
instance specifically for use in test code.
- createValue() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- createValue() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- createVisibilityExpTags(String) - Method in interface org.apache.hadoop.hbase.mapreduce.VisibilityExpressionResolver
-
Convert visibility expression into tags to be serialized.
- CREDENTIALS_LOCATION - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- CRLF - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- CRYPTO_ALTERNATE_KEY_ALGORITHM_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the name of the alternate cipher algorithm for the cluster, a string
- CRYPTO_CIPHERPROVIDER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the crypto algorithm provider, a class name
- CRYPTO_KEY_ALGORITHM_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the algorithm used for creating jks key, a string
- CRYPTO_KEYPROVIDER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the crypto key provider, a class name
- CRYPTO_KEYPROVIDER_PARAMETERS_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the crypto key provider parameters
- CRYPTO_MASTERKEY_ALTERNATE_NAME_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the name of the alternate master key for the cluster, a string
- CRYPTO_MASTERKEY_NAME_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the name of the master key for the cluster, a string
- CRYPTO_WAL_ALGORITHM_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the algorithm to use when encrypting the WAL, a string
- CRYPTO_WAL_KEY_NAME_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the name of the master WAL encryption key for the cluster, a string
- CryptoCipherProvider - Class in org.apache.hadoop.hbase.io.crypto
-
The default cipher provider.
- curBuf - Variable in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
-
- current() - Method in interface org.apache.hadoop.hbase.CellScanner
-
- current() - Method in class org.apache.hadoop.hbase.client.Result
-
- cursor() - Method in interface org.apache.hadoop.hbase.client.AdvancedScanResultConsumer.ScanController
-
Get the scan cursor if available.
- Cursor - Class in org.apache.hadoop.hbase.client
-
- CUSTOM_FILTERS - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- 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.client.ColumnFamilyDescriptorBuilder
-
- DATA_BLOCK_ENCODING - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- DATA_FILE_UMASK_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
File permission umask to use when creating hbase data files
- DATABLOCK_ENCODING_OVERRIDE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
- DataBlockEncoding - Enum in org.apache.hadoop.hbase.io.encoding
-
Provide access to all data block encoding algorithms.
- DataType<T> - Interface in org.apache.hadoop.hbase.types
-
DataType
is the base class for all HBase data types.
- DAY_IN_SECONDS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Seconds in a day, hour and minute
- decode(PositionedByteRange) - Method in interface org.apache.hadoop.hbase.types.DataType
-
Read an instance of T
from the buffer src
.
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedBlob
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedBlobVar
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt16
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt32
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt64
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt8
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedString
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawByte
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawBytes
-
- decode(PositionedByteRange, int) - Method in class org.apache.hadoop.hbase.types.RawBytes
-
Read a byte[]
from the buffer src
.
- decode(PositionedByteRange, int) - Method in class org.apache.hadoop.hbase.types.RawBytesFixedLength
-
Read a byte[]
from the buffer src
.
- decode(PositionedByteRange, int) - Method in class org.apache.hadoop.hbase.types.RawBytesTerminated
-
Read a byte[]
from the buffer src
.
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawDouble
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawFloat
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawInteger
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawLong
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawShort
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawString
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Struct
-
- decode(PositionedByteRange, int) - Method in class org.apache.hadoop.hbase.types.Struct
-
Read the field at index
.
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
-
- decodeA(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Union2
-
Read an instance of the first type parameter from buffer src
.
- decodeB(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Union2
-
Read an instance of the second type parameter from buffer src
.
- decodeBlobCopy(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode a Blob value, byte-for-byte copy.
- decodeBlobVar(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode a blob value that was encoded using BlobVar encoding.
- decodeByte(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt8
-
Read a byte
value from the buffer src
.
- decodeByte(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawByte
-
Read a byte
value from the buffer buff
.
- decodeC(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Union3
-
Read an instance of the third type parameter from buffer src
.
- decodeD(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Union4
-
Read an instance of the fourth type parameter from buffer src
.
- decodeDouble(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
-
Read a double
value from the buffer src
.
- decodeDouble(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
-
Read a double
value from the buffer src
.
- decodeDouble(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawDouble
-
Read a double
value from the buffer buff
.
- decodeFloat(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
-
Read a float
value from the buffer dst
.
- decodeFloat(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawFloat
-
Read a float
value from the buffer buff
.
- decodeFloat32(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode a 32-bit floating point value using the fixed-length encoding.
- decodeFloat64(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode a 64-bit floating point value using the fixed-length encoding.
- decodeInt(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt32
-
Read an int
value from the buffer src
.
- decodeInt(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawInteger
-
Read an int
value from the buffer buff
.
- decodeInt16(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode an int16
value.
- decodeInt32(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode an int32
value.
- decodeInt64(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode an int64
value.
- decodeInt8(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode an int8
value.
- decodeLong(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt64
-
Read a long
value from the buffer src
.
- decodeLong(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
-
Read a long
value from the buffer src
.
- decodeLong(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawLong
-
Read a long
value from the buffer buff
.
- decodeNumericAsBigDecimal(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode a
BigDecimal
value from the variable-length encoding.
- decodeNumericAsDouble(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode a primitive double
value from the Numeric encoding.
- decodeNumericAsLong(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode a primitive long
value from the Numeric encoding.
- decodeShort(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt16
-
Read a short
value from the buffer src
.
- decodeShort(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawShort
-
Read a short
value from the buffer buff
.
- decodeString(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode a String value.
- decommissionRegionServers(List<ServerName>, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Mark region server(s) as decommissioned to prevent additional regions from getting
assigned to them.
- decommissionRegionServers(List<ServerName>, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Mark region server(s) as decommissioned to prevent additional regions from getting
assigned to them.
- decrement() - Method in class org.apache.hadoop.hbase.util.Counter
-
Deprecated.
- decrypt(byte[], int, InputStream, int, Decryptor) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Decrypt a block of ciphertext read in from a stream with the given
cipher and context
- decrypt(byte[], int, InputStream, int, Encryption.Context, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Decrypt a block of ciphertext from a stream given a context and IV
- decrypt(OutputStream, InputStream, int, Decryptor) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Decrypt a stream of ciphertext given a decryptor
- decrypt(OutputStream, InputStream, int, Encryption.Context, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Decrypt a stream of ciphertext given a context and IV
- Decryptor - Interface in org.apache.hadoop.hbase.io.crypto
-
Decryptors apply a cipher to an InputStream to recover plaintext.
- decryptWithSubjectKey(OutputStream, InputStream, int, String, Configuration, Cipher, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Decrypts a block of ciphertext with the symmetric key resolved for the given subject
- decTaskCounters(Collection<byte[]>, ServerName) - Method in interface org.apache.hadoop.hbase.client.RequestController
-
Decrement the counter if a task is accomplished.
- deepCopy() - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Create a new ByteRange
with new backing byte[] containing a copy
of the content from this
range's window.
- deepCopy() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- deepCopy() - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- deepCopy() - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
-
- deepCopy() - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- deepCopy() - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
- deepCopySubRangeTo(int, int, byte[], int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Wrapper for System.arraycopy.
- deepCopyTo(byte[], int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Wrapper for System.arraycopy.
- deepCopyToNewArray() - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Instantiate a new byte[] with exact length, which is at least 24 bytes +
length.
- DEFAULT_BLOCKCACHE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default setting for whether to use a block cache or not.
- DEFAULT_BLOCKCACHE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- DEFAULT_BLOCKSIZE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default size of blocks in files stored to the filesytem (hfiles).
- DEFAULT_BLOCKSIZE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- DEFAULT_BLOCKSIZE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default block size for an HFile.
- DEFAULT_BLOOMFILTER - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default setting for whether or not to use bloomfilters.
- DEFAULT_BLOOMFILTER - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- DEFAULT_CACHE_BLOOMS_ON_WRITE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default setting for whether to cache bloom filter blocks on write if block
caching is enabled.
- DEFAULT_CACHE_BLOOMS_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- DEFAULT_CACHE_DATA_IN_L1 - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- DEFAULT_CACHE_DATA_ON_WRITE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default setting for whether to cache data blocks on write if block caching
is enabled.
- DEFAULT_CACHE_DATA_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- DEFAULT_CACHE_INDEX_ON_WRITE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default setting for whether to cache index blocks on write if block caching
is enabled.
- DEFAULT_CACHE_INDEX_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- DEFAULT_CLIENT_ZOOKEEPER_OBSERVER_MODE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Assuming client zk not in observer mode and master need to synchronize information
- DEFAULT_CLUSTER_DISTRIBUTED - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default value for cluster distributed mode
- DEFAULT_CLUSTER_ID - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default cluster ID, cannot be used to identify a cluster so a key with
this value means it wasn't meant for replication.
- DEFAULT_COMPACTION_ENABLED - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Constant that denotes whether the table is compaction enabled by default
- DEFAULT_COMPACTION_ENABLED - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- DEFAULT_COMPRESS_TAGS - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default compress tags along with any type of DataBlockEncoding.
- DEFAULT_COMPRESS_TAGS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- DEFAULT_COMPRESSION - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default compression type.
- DEFAULT_COMPRESSION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- DEFAULT_DATA_BLOCK_ENCODING - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default data block encoding algorithm.
- DEFAULT_DATA_BLOCK_ENCODING - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- DEFAULT_DFS_REPLICATION - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- DEFAULT_DFS_REPLICATION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- DEFAULT_ENABLE_CLIENT_BACKPRESSURE - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_ENCODE_ON_DISK - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- DEFAULT_EVICT_BLOCKS_ON_CLOSE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default setting for whether to evict cached blocks from the blockcache on
close.
- DEFAULT_EVICT_BLOCKS_ON_CLOSE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- DEFAULT_EVICT_REMAIN_RATIO - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- DEFAULT_GROUP - Static variable in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
- DEFAULT_HBASE_BALANCER_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default value for the balancer period
- DEFAULT_HBASE_CLIENT_MAX_PERREGION_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_CLIENT_MAX_PERSERVER_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_CLIENT_MAX_TOTAL_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_CLIENT_OPERATION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default HBase client operation timeout, which is tantamount to a blocking call
- DEFAULT_HBASE_CLIENT_PAUSE - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_CLIENT_PERSERVER_REQUESTS_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_CLIENT_RETRIES_NUMBER - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_CLIENT_SCANNER_ASYNC_PREFETCH - Static variable in class org.apache.hadoop.hbase.client.Scan
-
- DEFAULT_HBASE_CLIENT_SCANNER_CACHING - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_CLIENT_SCANNER_MAX_RESULT_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Maximum number of bytes returned when calling a scanner's next method.
- DEFAULT_HBASE_CLIENT_SCANNER_TIMEOUT_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_CLIENT_SERVERSIDE_RETRIES_MULTIPLIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_MASTER_BALANCER_MAX_RIT_PERCENT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default value for the max percent of regions in transition
- DEFAULT_HBASE_META_BLOCK_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_META_SCANNER_CACHING - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_META_VERSIONS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_RPC_SHORTOPERATION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_RPC_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_SERVER_PAUSE - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_SERVER_SCANNER_MAX_RESULT_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Maximum number of bytes returned when calling a scanner's next method.
- DEFAULT_HBASE_SPLIT_COORDINATED_BY_ZK - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_SPLIT_WAL_MAX_SPLITTER - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HEALTH_FAILURE_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HEALTH_SCRIPT_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HEAP_OCCUPANCY_HIGH_WATERMARK - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HEAP_OCCUPANCY_LOW_WATERMARK - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HOST - Static variable in class org.apache.hadoop.hbase.HConstants
-
default host address
- DEFAULT_HREGION_EDITS_REPLAY_SKIP_ERRORS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HREGION_MEMSTORE_BLOCK_MULTIPLIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default value for hbase.hregion.memstore.block.multiplier
- DEFAULT_HSTORE_OPEN_AND_CLOSE_THREADS_MAX - Static variable in class org.apache.hadoop.hbase.HConstants
-
The default number for the max number of threads used for opening and
closing stores or store files in parallel
- DEFAULT_IN_MEMORY - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default setting for whether to try and serve this column family from memory
or not.
- DEFAULT_IN_MEMORY - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- DEFAULT_KEEP_DELETED - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default setting for preventing deleted from being collected immediately.
- DEFAULT_KEEP_DELETED - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- DEFAULT_LISTEN_PORT - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- DEFAULT_LOSSY_COUNTING_ERROR_RATE - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_MAJOR_COMPACTION_JITTER - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_MAJOR_COMPACTION_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_MASTER_HANLDER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Deprecated.
- DEFAULT_MASTER_INFOPORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
default port for master web api
- DEFAULT_MASTER_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
default port that the master listens on
- DEFAULT_MASTER_TYPE_BACKUP - Static variable in class org.apache.hadoop.hbase.HConstants
-
by default every master is a possible primary master unless the conf explicitly overrides it
- DEFAULT_MATH_CONTEXT - Static variable in class org.apache.hadoop.hbase.util.OrderedBytes
-
- DEFAULT_MAX_AGE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- DEFAULT_MAX_BACKOFF - Static variable in class org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
-
- DEFAULT_MAX_FILE_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default maximum file size
- DEFAULT_MAX_VERSIONS - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default number of versions of a record to keep.
- DEFAULT_MEMSTORE_FLUSH_SIZE - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Constant that denotes the maximum default size of the memstore in bytes after which
the contents are flushed to the store files.
- DEFAULT_MEMSTORE_FLUSH_SIZE - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- DEFAULT_MERGE_ENABLED - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Constant that denotes whether the table is merge enabled by default
- DEFAULT_META_REPLICA_NUM - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_MIN_VERSIONS - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default is not to keep a minimum of versions.
- DEFAULT_MIN_VERSIONS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- DEFAULT_MOB_CACHE_EVICT_PERIOD - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- DEFAULT_MOB_CLEANER_PERIOD - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- DEFAULT_MOB_COMPACT_PARTITION_POLICY - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- DEFAULT_MOB_COMPACT_PARTITION_POLICY - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- DEFAULT_MOB_COMPACTION_BATCH_SIZE - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- DEFAULT_MOB_COMPACTION_CHORE_PERIOD - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- DEFAULT_MOB_COMPACTION_MERGEABLE_THRESHOLD - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- DEFAULT_MOB_COMPACTION_THREADS_MAX - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- DEFAULT_MOB_DELFILE_MAX_COUNT - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- DEFAULT_MOB_FILE_CACHE_SIZE - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- DEFAULT_MOB_THRESHOLD - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- DEFAULT_MOB_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- DEFAULT_MOVE_RETRIES_MAX - Static variable in class org.apache.hadoop.hbase.util.RegionMover
-
- DEFAULT_MOVE_WAIT_MAX - Static variable in class org.apache.hadoop.hbase.util.RegionMover
-
- DEFAULT_NAMESPACE - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- DEFAULT_NAMESPACE_NAME - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
-
Default namespace name.
- DEFAULT_NAMESPACE_NAME_STR - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- DEFAULT_NEW_VERSION_BEHAVIOR - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- DEFAULT_NEW_VERSION_BEHAVIOR - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- DEFAULT_NORMALIZATION_ENABLED - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Constant that denotes whether the table is normalized by default.
- DEFAULT_NORMALIZATION_ENABLED - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- DEFAULT_ONLINE_LOG_PROVIDER_ENABLED - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_PREFETCH_BLOCKS_ON_OPEN - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- DEFAULT_PREFETCH_BLOCKS_ON_OPEN - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- DEFAULT_READONLY - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Constant that denotes whether the table is READONLY by default and is false
- DEFAULT_READONLY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- DEFAULT_REGION_MEMSTORE_REPLICATION - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- DEFAULT_REGION_MEMSTORE_REPLICATION - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- DEFAULT_REGION_REPLICATION - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- DEFAULT_REGION_REPLICATION - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- DEFAULT_REGION_SERVER_HANDLER_ABORT_ON_ERROR_PERCENT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_REGION_SERVER_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_REGION_SERVER_HIGH_PRIORITY_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_REGION_SERVER_REPLICATION_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_REGIONS_RECOVERY_INTERVAL - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_REGIONSERVER_INFOPORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
default port for region server web api
- DEFAULT_REGIONSERVER_METRICS_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_REGIONSERVER_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default port region server listens on.
- DEFAULT_REPLICA_ID - Static variable in interface org.apache.hadoop.hbase.client.RegionInfo
-
- DEFAULT_REPLICATION_SCOPE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default scope.
- DEFAULT_REPLICATION_SCOPE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- DEFAULT_SERVERSTART_WAIT_MAX - Static variable in class org.apache.hadoop.hbase.util.RegionMover
-
- DEFAULT_SLOW_LOG_RING_BUFFER_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_SLOW_LOG_SYS_TABLE_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_SNAPSHOT_RESTORE_FAILSAFE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_SNAPSHOT_RESTORE_TAKE_FAILSAFE_SNAPSHOT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_SNAPSHOT_TTL - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_SNAPSHOT_TTL_CONFIG_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_SPLIT_ENABLED - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Constant that denotes whether the table is split enabled by default
- DEFAULT_STATUS_MULTICAST_ADDRESS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_STATUS_MULTICAST_BIND_ADDRESS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_STATUS_MULTICAST_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_STATUS_MULTICAST_PUBLISHER_BIND_ADDRESS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_STORE_FILE_REF_COUNT_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_TEMPORARY_HDFS_DIRECTORY - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_THREAD_WAKE_FREQUENCY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default value for thread wake frequency
- DEFAULT_TTL - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default time to live of cell contents.
- DEFAULT_TTL - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- DEFAULT_USE_META_REPLICAS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_VERSION_FILE_WRITE_ATTEMPTS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for how often we should try to write a version file, before failing
- DEFAULT_VERSIONS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- DEFAULT_WAL_STORAGE_POLICY - Static variable in class org.apache.hadoop.hbase.HConstants
-
By default we defer the WAL storage policy to HDFS
- DEFAULT_ZK_SESSION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default value for ZooKeeper session timeout
- DEFAULT_ZOOKEEPER_CLIENT_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default client port that the zookeeper listens on
- DEFAULT_ZOOKEEPER_MAX_CLIENT_CNXNS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default limit on concurrent client-side zookeeper connections
- DEFAULT_ZOOKEEPER_ZNODE_PARENT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_ZOOKEPER_CLIENT_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_ZOOKEPER_MAX_CLIENT_CNXNS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_ZOOKEPER_RECOVERABLE_WAITIME - Static variable in class org.apache.hadoop.hbase.HConstants
-
Deprecated.
- DefaultCipherProvider - Class in org.apache.hadoop.hbase.io.crypto
-
The default cipher provider.
- DEFER_TO_HDFS_STORAGE_POLICY - Static variable in class org.apache.hadoop.hbase.HConstants
-
"NONE" is not a valid storage policy and means we defer the policy to HDFS.
- delegatee - Variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- delegatee - Variable in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- delete(Delete) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Deletes the specified cells/row.
- delete(List<Delete>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Deletes the specified cells/rows in bulk.
- 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(byte[], long, NavigableMap<byte[], List<Cell>>) - Constructor for class org.apache.hadoop.hbase.client.Delete
-
Construct the Delete with user defined data.
- delete(Delete) - Method in interface org.apache.hadoop.hbase.client.Table
-
Deletes the specified cells/row.
- delete(List<Delete>) - Method in interface org.apache.hadoop.hbase.client.Table
-
Batch Deletes the specified cells/rows from the table.
- delete(String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a DELETE request
- delete(String, Header) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a DELETE request
- delete(Cluster, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a DELETE request
- delete(Cluster, String, Header) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a DELETE request
- deleteAll(List<Delete>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
A simple version of batch delete.
- deleteColumn(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- deleteColumnFamily(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Delete a column family from a table.
- deleteColumnFamily(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Delete a column family from a table.
- deleteColumnFamilyAsync(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Delete a column family from a table.
- deleteNamespace(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Delete an existing namespace.
- deleteNamespace(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Delete an existing namespace.
- deleteNamespaceAsync(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Delete an existing namespace.
- deleteSnapshot(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- deleteSnapshot(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Delete an existing snapshot.
- deleteSnapshot(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Delete an existing snapshot.
- deleteSnapshots(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- deleteSnapshots(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Delete existing snapshots whose names match the pattern passed.
- deleteSnapshots() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Delete all existing snapshots.
- deleteSnapshots(Pattern) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Delete existing snapshots whose names match the pattern passed.
- deleteTable(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Deletes a table.
- deleteTable(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Deletes a table.
- deleteTableAsync(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Deletes the table but does not block and wait for it to be completely removed.
- deleteTables(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- deleteTables(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- deleteTableSnapshots(String, String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- deleteTableSnapshots(Pattern, Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Delete all existing snapshots matching the given table name regular expression and snapshot
name regular expression.
- deleteTableSnapshots(Pattern) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Delete all existing snapshots matching the given table name pattern.
- deleteTableSnapshots(Pattern, Pattern) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Delete all existing snapshots matching the given table name regular expression and snapshot
name regular expression.
- DELIMITER - Static variable in class org.apache.hadoop.hbase.HConstants
-
delimiter used between portions of a region name
- 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
-
- DependentColumnFilter(byte[], byte[], boolean, CompareOperator, 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.
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedBlob
-
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedBlobVar
-
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedFloat32
-
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedFloat64
-
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt16
-
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt32
-
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt64
-
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt8
-
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedNumeric
-
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedString
-
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.RawBytes
-
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.RawString
-
- deserialize(byte[]) - Static method in exception org.apache.hadoop.hbase.errorhandling.ForeignException
-
Takes a series of bytes and tries to generate an ForeignException instance for it.
- DFS_REPLICATION - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- DFS_REPLICATION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- disablePeer(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- disableReplicationPeer(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Stop the replication stream to the specified peer.
- disableReplicationPeer(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Stop the replication stream to the specified peer
- disableReplicationPeerAsync(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Disable a replication peer but does not block and wait for it.
- disableTable(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Disable table and wait on completion.
- disableTable(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Disable a table.
- disableTableAsync(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Disable the table but does not block and wait for it to be completely disabled.
- disableTableRep(TableName) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- disableTableReplication(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Disable a table's replication switch.
- disableTableReplication(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Disable a table's replication switch.
- disableTables(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- disableTables(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- disableWriteBufferPeriodicFlush() - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
-
Disable the periodical flush, i.e, set the timeout to 0.
- disableWriteBufferPeriodicFlush() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
Disable periodic flushing of the write buffer.
- DISALLOWED_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.TableName
-
One globally disallowed name
- doLoadColumnFamiliesOnDemand() - Method in class org.apache.hadoop.hbase.client.Query
-
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
-
- 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
-
- DoNotRetryRegionException - Exception in org.apache.hadoop.hbase.client
-
Similar to RegionException, but disables retries.
- DoNotRetryRegionException() - Constructor for exception org.apache.hadoop.hbase.client.DoNotRetryRegionException
-
- DoNotRetryRegionException(String) - Constructor for exception org.apache.hadoop.hbase.client.DoNotRetryRegionException
-
- DoNotRetryRegionException(Throwable) - Constructor for exception org.apache.hadoop.hbase.client.DoNotRetryRegionException
-
- doSetup(Reducer<ImmutableBytesWritable, Text, ImmutableBytesWritable, KeyValue>.Context, Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
-
Handles common parameter initialization that a subclass might want to leverage.
- doSetup(Mapper<LongWritable, Text, ImmutableBytesWritable, Put>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
Handles common parameter initialization that a subclass might want to leverage.
- doSetup(Mapper<LongWritable, Text, ImmutableBytesWritable, Text>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
-
Handles common parameter initialization that a subclass might want to leverage.
- doWork() - Method in class org.apache.hadoop.hbase.mapreduce.RowCounter
-
- doWork() - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
Execute the export snapshot by copying the snapshot metadata, hfiles and wals.
- doWork() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
- doWork() - Method in class org.apache.hadoop.hbase.util.RegionMover
-
- drainInputStreamToBuffer(InputStream) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Copy from the InputStream to a new heap ByteBuffer until the InputStream is exhausted.
- 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() - Constructor for exception org.apache.hadoop.hbase.DroppedSnapshotException
-
- DroppedSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.DroppedSnapshotException
-
- DroppedSnapshotException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.DroppedSnapshotException
-
DroppedSnapshotException with cause
- DRY_RUN_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- 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.client.TableDescriptorBuilder
-
- DURABILITY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- E - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'E'
- EMPTY_BYTE_ARRAY - Static variable in class org.apache.hadoop.hbase.HConstants
-
An empty byte array instance.
- EMPTY_BYTE_BUFFER - Static variable in class org.apache.hadoop.hbase.HConstants
-
- EMPTY_END_ROW - Static variable in class org.apache.hadoop.hbase.HConstants
-
Last row in a table.
- EMPTY_HEADER_ARRAY - Static variable in class org.apache.hadoop.hbase.rest.client.Client
-
- EMPTY_RESULT - Static variable in class org.apache.hadoop.hbase.client.Result
-
- EMPTY_SERVER_LIST - Static variable in class org.apache.hadoop.hbase.ServerName
-
- EMPTY_SERVERLOAD - Static variable in class org.apache.hadoop.hbase.ServerLoad
-
- EMPTY_START_ROW - Static variable in class org.apache.hadoop.hbase.HConstants
-
Used by scanners, etc when they want to start at the beginning of a region
- EMPTY_STRING - Static variable in class org.apache.hadoop.hbase.HConstants
-
An empty string instance.
- EMPTY_STRING - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- EMPTY_VALUE_ON_MOBCELL_MISS - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- ENABLE_CLIENT_BACKPRESSURE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Config key for if the server should send backpressure and if the client should listen to
that backpressure from the server
- ENABLE_DATA_FILE_UMASK - Static variable in class org.apache.hadoop.hbase.HConstants
-
Enable file permission modification from standard hbase
- ENABLE_WAL_COMPRESSION - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration name of WAL Compression
- ENABLE_WAL_ENCRYPTION - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for enabling WAL encryption, a boolean
- enableCatalogJanitor(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- enablePeer(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- enableReplicationPeer(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Restart the replication stream to the specified peer.
- enableReplicationPeer(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Restart the replication stream to the specified peer
- enableReplicationPeerAsync(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Enable a replication peer but does not block and wait for it.
- enableTable(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Enable a table.
- enableTable(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Enable a table.
- enableTableAsync(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Enable the table but does not block and wait for it to be completely enabled.
- enableTableRep(TableName) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- enableTableReplication(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Enable a table's replication switch.
- enableTableReplication(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Enable a table's replication switch.
- enableTables(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- enableTables(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- ENC_SEPARATOR - Static variable in interface org.apache.hadoop.hbase.client.RegionInfo
-
Separator used to demarcate the encodedName in a region name
in the new format.
- encode(PositionedByteRange, T) - Method in interface org.apache.hadoop.hbase.types.DataType
-
Write instance val
into buffer dst
.
- encode(PositionedByteRange, T) - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
-
- encode(PositionedByteRange, byte[]) - Method in class org.apache.hadoop.hbase.types.OrderedBlob
-
- encode(PositionedByteRange, byte[], int, int) - Method in class org.apache.hadoop.hbase.types.OrderedBlob
-
Write a subset of val
to dst
.
- encode(PositionedByteRange, byte[]) - Method in class org.apache.hadoop.hbase.types.OrderedBlobVar
-
- encode(PositionedByteRange, byte[], int, int) - Method in class org.apache.hadoop.hbase.types.OrderedBlobVar
-
Write a subset of val
to buff
.
- encode(PositionedByteRange, Float) - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
-
- encode(PositionedByteRange, Double) - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
-
- encode(PositionedByteRange, Short) - Method in class org.apache.hadoop.hbase.types.OrderedInt16
-
- encode(PositionedByteRange, Integer) - Method in class org.apache.hadoop.hbase.types.OrderedInt32
-
- encode(PositionedByteRange, Long) - Method in class org.apache.hadoop.hbase.types.OrderedInt64
-
- encode(PositionedByteRange, Byte) - Method in class org.apache.hadoop.hbase.types.OrderedInt8
-
- encode(PositionedByteRange, Number) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
-
- encode(PositionedByteRange, String) - Method in class org.apache.hadoop.hbase.types.OrderedString
-
- encode(PositionedByteRange, Byte) - Method in class org.apache.hadoop.hbase.types.RawByte
-
- encode(PositionedByteRange, byte[]) - Method in class org.apache.hadoop.hbase.types.RawBytes
-
- encode(PositionedByteRange, byte[], int, int) - Method in class org.apache.hadoop.hbase.types.RawBytes
-
Write val
into dst
, respecting voff
and vlen
.
- encode(PositionedByteRange, byte[], int, int) - Method in class org.apache.hadoop.hbase.types.RawBytesFixedLength
-
Write val
into buff
, respecting offset
and
length
.
- encode(PositionedByteRange, byte[], int, int) - Method in class org.apache.hadoop.hbase.types.RawBytesTerminated
-
Write val
into dst
, respecting offset
and
length
.
- encode(PositionedByteRange, Double) - Method in class org.apache.hadoop.hbase.types.RawDouble
-
- encode(PositionedByteRange, Float) - Method in class org.apache.hadoop.hbase.types.RawFloat
-
- encode(PositionedByteRange, Integer) - Method in class org.apache.hadoop.hbase.types.RawInteger
-
- encode(PositionedByteRange, Long) - Method in class org.apache.hadoop.hbase.types.RawLong
-
- encode(PositionedByteRange, Short) - Method in class org.apache.hadoop.hbase.types.RawShort
-
- encode(PositionedByteRange, String) - Method in class org.apache.hadoop.hbase.types.RawString
-
- encode(PositionedByteRange, Object[]) - Method in class org.apache.hadoop.hbase.types.Struct
-
- encode(PositionedByteRange, T) - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
-
Write instance val
into buffer dst
.
- ENCODE_ON_DISK - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- encodeBlobCopy(PositionedByteRange, byte[], int, int, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Encode a Blob value as a byte-for-byte copy.
- encodeBlobCopy(PositionedByteRange, byte[], Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Encode a Blob value as a byte-for-byte copy.
- encodeBlobVar(PositionedByteRange, byte[], int, int, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Encode a Blob value using a modified varint encoding scheme.
- encodeBlobVar(PositionedByteRange, byte[], Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Encode a blob value using a modified varint encoding scheme.
- encodeByte(PositionedByteRange, byte) - Method in class org.apache.hadoop.hbase.types.OrderedInt8
-
Write instance val
into buffer dst
.
- encodeByte(byte[], int, byte) - Method in class org.apache.hadoop.hbase.types.RawByte
-
Write instance val
into buffer buff
.
- ENCODED_REGION_NAME_REGEX - Static variable in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
A non-capture group so that this can be embedded.
- encodedClass() - Method in interface org.apache.hadoop.hbase.types.DataType
-
Inform consumers over what type this DataType
operates.
- encodedClass() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
-
- encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedBlob
-
- encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedBlobVar
-
- encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
-
- encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
-
- encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedInt16
-
- encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedInt32
-
- encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedInt64
-
- encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedInt8
-
- encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
-
- encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedString
-
- encodedClass() - Method in class org.apache.hadoop.hbase.types.RawByte
-
- encodedClass() - Method in class org.apache.hadoop.hbase.types.RawBytes
-
- encodedClass() - Method in class org.apache.hadoop.hbase.types.RawDouble
-
- encodedClass() - Method in class org.apache.hadoop.hbase.types.RawFloat
-
- encodedClass() - Method in class org.apache.hadoop.hbase.types.RawInteger
-
- encodedClass() - Method in class org.apache.hadoop.hbase.types.RawLong
-
- encodedClass() - Method in class org.apache.hadoop.hbase.types.RawShort
-
- encodedClass() - Method in class org.apache.hadoop.hbase.types.RawString
-
- encodedClass() - Method in class org.apache.hadoop.hbase.types.Struct
-
- encodedClass() - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
-
- encodedClass() - Method in class org.apache.hadoop.hbase.types.Union2
-
- encodedLength(T) - Method in interface org.apache.hadoop.hbase.types.DataType
-
Inform consumers how long the encoded byte[]
will be.
- encodedLength(T) - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
-
- encodedLength(byte[]) - Method in class org.apache.hadoop.hbase.types.OrderedBlob
-
- encodedLength(byte[]) - Method in class org.apache.hadoop.hbase.types.OrderedBlobVar
-
- encodedLength(Float) - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
-
- encodedLength(Double) - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
-
- encodedLength(Short) - Method in class org.apache.hadoop.hbase.types.OrderedInt16
-
- encodedLength(Integer) - Method in class org.apache.hadoop.hbase.types.OrderedInt32
-
- encodedLength(Long) - Method in class org.apache.hadoop.hbase.types.OrderedInt64
-
- encodedLength(Byte) - Method in class org.apache.hadoop.hbase.types.OrderedInt8
-
- encodedLength(Number) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
-
- encodedLength(String) - Method in class org.apache.hadoop.hbase.types.OrderedString
-
- encodedLength(T) - Method in class org.apache.hadoop.hbase.types.PBType
-
Deprecated.
- encodedLength(Byte) - Method in class org.apache.hadoop.hbase.types.RawByte
-
- encodedLength(byte[]) - Method in class org.apache.hadoop.hbase.types.RawBytes
-
- encodedLength(Double) - Method in class org.apache.hadoop.hbase.types.RawDouble
-
- encodedLength(Float) - Method in class org.apache.hadoop.hbase.types.RawFloat
-
- encodedLength(Integer) - Method in class org.apache.hadoop.hbase.types.RawInteger
-
- encodedLength(Long) - Method in class org.apache.hadoop.hbase.types.RawLong
-
- encodedLength(Short) - Method in class org.apache.hadoop.hbase.types.RawShort
-
- encodedLength(String) - Method in class org.apache.hadoop.hbase.types.RawString
-
- encodedLength(Object[]) - Method in class org.apache.hadoop.hbase.types.Struct
-
- encodedLength(T) - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
-
- encodeDouble(PositionedByteRange, double) - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
-
Write instance val
into buffer dst
.
- encodeDouble(PositionedByteRange, double) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
-
Write instance val
into buffer dst
.
- encodeDouble(byte[], int, double) - Method in class org.apache.hadoop.hbase.types.RawDouble
-
Write instance val
into buffer buff
.
- encodeFloat(PositionedByteRange, float) - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
-
Write instance val
into buffer buff
.
- encodeFloat(byte[], int, float) - Method in class org.apache.hadoop.hbase.types.RawFloat
-
Write instance val
into buffer buff
.
- encodeFloat32(PositionedByteRange, float, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Encode a 32-bit floating point value using the fixed-length encoding.
- encodeFloat64(PositionedByteRange, double, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Encode a 64-bit floating point value using the fixed-length encoding.
- encodeInt(PositionedByteRange, int) - Method in class org.apache.hadoop.hbase.types.OrderedInt32
-
Write instance val
into buffer dst
.
- encodeInt(byte[], int, int) - Method in class org.apache.hadoop.hbase.types.RawInteger
-
Write instance val
into buffer buff
.
- encodeInt16(PositionedByteRange, short, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Encode an int16
value using the fixed-length encoding.
- encodeInt32(PositionedByteRange, int, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Encode an int32
value using the fixed-length encoding.
- encodeInt64(PositionedByteRange, long, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Encode an int64
value using the fixed-length encoding.
- encodeInt8(PositionedByteRange, byte, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Encode an int8
value using the fixed-length encoding.
- encodeLong(PositionedByteRange, long) - Method in class org.apache.hadoop.hbase.types.OrderedInt64
-
Write instance val
into buffer dst
.
- encodeLong(PositionedByteRange, long) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
-
Write instance val
into buffer dst
.
- encodeLong(byte[], int, long) - Method in class org.apache.hadoop.hbase.types.RawLong
-
Write instance val
into buffer buff
.
- encodeNull(PositionedByteRange, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Encode a null value.
- encodeNumeric(PositionedByteRange, long, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Encode a numerical value using the variable-length encoding.
- encodeNumeric(PositionedByteRange, double, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Encode a numerical value using the variable-length encoding.
- encodeNumeric(PositionedByteRange, BigDecimal, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Encode a numerical value using the variable-length encoding.
- encodeRegionName(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
- encodeRegionName(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- encodeShort(PositionedByteRange, short) - Method in class org.apache.hadoop.hbase.types.OrderedInt16
-
Write instance val
into buffer dst
.
- encodeShort(byte[], int, short) - Method in class org.apache.hadoop.hbase.types.RawShort
-
Write instance val
into buffer buff
.
- encodeString(PositionedByteRange, String, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Encode a String value.
- encrypt(OutputStream, byte[], int, int, Encryptor) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Encrypt a block of plaintext
- encrypt(OutputStream, byte[], int, int, Encryption.Context, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Encrypt a block of plaintext
- encrypt(OutputStream, InputStream, Encryptor) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Encrypt a stream of plaintext given an encryptor
- encrypt(OutputStream, InputStream, Encryption.Context, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Encrypt a stream of plaintext given a context and IV
- ENCRYPTION - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- ENCRYPTION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- Encryption - Class in org.apache.hadoop.hbase.io.crypto
-
A facade for encryption algorithms and related support.
- Encryption.Context - Class in org.apache.hadoop.hbase.io.crypto
-
Crypto context
- ENCRYPTION_KEY - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- ENCRYPTION_KEY - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- Encryptor - Interface in org.apache.hadoop.hbase.io.crypto
-
Encryptors apply a cipher to an OutputStream to produce ciphertext.
- encryptWithSubjectKey(OutputStream, InputStream, String, Configuration, Cipher, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Encrypts a block of plaintext with the symmetric key resolved for the given subject
- END - Static variable in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
- END_TIME_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.WALInputFormat
-
- ENSEMBLE_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
The name of the ensemble table
- EntityLock - Class in org.apache.hadoop.hbase.client.locking
-
Lock for HBase Entity either a Table, a Namespace, or Regions.
- EQUAL_TO - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for equal to (=)
- EQUAL_TO_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
EQUAL_TO Array
- EQUAL_TO_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
- equals(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
equals
- equals(Object) - Method in class org.apache.hadoop.hbase.client.Get
-
- equals(Object) - Method in class org.apache.hadoop.hbase.client.Increment
-
- equals(Object) - Method in class org.apache.hadoop.hbase.client.RowMutations
-
- equals(Object) - Method in class org.apache.hadoop.hbase.ClusterStatus
-
Deprecated.
- equals(Object) - Method in class org.apache.hadoop.hbase.filter.BigDecimalComparator
-
- equals(Object) - Method in class org.apache.hadoop.hbase.filter.BinaryComponentComparator
-
- equals(Object) - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
- equals(Object) - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- equals(Object) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
- equals(Object) - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- equals(Object) - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
-
- equals(Object) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- equals(Object) - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- equals(Object) - Method in class org.apache.hadoop.hbase.filter.FamilyFilter
-
- equals(Object) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- equals(Object) - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
-
- equals(Object) - Method in class org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
-
Deprecated.
- equals(Object) - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
- equals(Object) - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
-
- equals(Object) - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
-
- equals(Object) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- equals(Object) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
-
- equals(Object) - Method in class org.apache.hadoop.hbase.filter.NullComparator
-
- equals(Object) - Method in class org.apache.hadoop.hbase.filter.PageFilter
-
- equals(Object) - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
-
- equals(Object) - Method in class org.apache.hadoop.hbase.filter.QualifierFilter
-
- equals(Object) - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
- equals(Object) - Method in class org.apache.hadoop.hbase.filter.RowFilter
-
- equals(Object) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
- equals(Object) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- equals(Object) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
-
- equals(Object) - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
- equals(Object) - Method in class org.apache.hadoop.hbase.filter.ValueFilter
-
- equals(Object) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
-
- equals(Object) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- equals(Object) - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
- equals(Object) - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- equals(Object) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Compare the contents of the descriptor with another one passed as a parameter.
- equals(Object) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
- equals(Object) - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
- equals(Object) - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
- equals(Object) - Method in class org.apache.hadoop.hbase.net.Address
-
- equals(Object) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
- equals(Object) - Method in class org.apache.hadoop.hbase.security.User
-
- equals(Object) - Method in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
- equals(Object) - Method in class org.apache.hadoop.hbase.ServerName
-
- equals(Object) - Method in class org.apache.hadoop.hbase.Size
-
- equals(Object) - Method in class org.apache.hadoop.hbase.TableName
-
- equals(ByteBuffer, int, int, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
- equals(ByteBuffer, int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
- equals(Object) - Method in class org.apache.hadoop.hbase.util.Bytes
-
- equals(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- equals(byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- equals(byte[], ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- equals(List<byte[]>, List<byte[]>) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- equals(Object) - Method in class org.apache.hadoop.hbase.util.Pair
-
- equals(Object) - Method in class org.apache.hadoop.hbase.util.PairOfSameType
-
- equals(Object) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- equals(Object) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
-
- equalsIgnoreMvccVersion(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- ESTIMATED_HEAP_TAX - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
Estimate of size cost to pay beyond payload in jvm for instance of byte [].
- estimatedHeapSizeOf(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- estimatedSerializedSizeOf(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- estimatedSerializedSizeOfKey(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- EVENT_LOOP_CONFIG - Static variable in class org.apache.hadoop.hbase.ipc.NettyRpcClientConfigHelper
-
- EVICT_BLOCKS_ON_CLOSE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- EVICT_BLOCKS_ON_CLOSE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- exceedThrottleQuotaSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Switch the exceed throttle quota.
- exceedThrottleQuotaSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Switch the exceed throttle quota.
- execProcedure(String, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Execute a distributed procedure on a cluster.
- execProcedure(String, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Execute a distributed procedure on a cluster.
- execProcedureWithRet(String, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- execProcedureWithReturn(String, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Execute a distributed procedure on a cluster.
- execProcedureWithReturn(String, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Execute a distributed procedure on a cluster.
- execute(Cluster, HttpUriRequest, Header[], String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Execute a transaction method.
- executePathOnly(Cluster, HttpUriRequest, Header[], String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Execute a transaction method given only the path.
- executeURI(HttpUriRequest, Header[], String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Execute a transaction method given a complete URI.
- exists(Get) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Test for the existence of columns in the table, as specified by the Get.
- exists(List<Get>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Test for the existence of columns in the table, as specified by the Gets.
- exists(Get) - Method in interface org.apache.hadoop.hbase.client.Table
-
Test for the existence of columns in the table, as specified by the Get.
- exists(List<Get>) - Method in interface org.apache.hadoop.hbase.client.Table
-
Test for the existence of columns in the table, as specified by the Gets.
- existsAll(List<Get>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
A simple version for batch exists.
- existsAll(List<Get>) - Method in interface org.apache.hadoop.hbase.client.Table
-
- ExponentialClientBackoffPolicy - Class in org.apache.hadoop.hbase.client.backoff
-
Simple exponential backoff policy on for the client that uses a percent^4 times the
max backoff to generate the backoff time.
- ExponentialClientBackoffPolicy(Configuration) - Constructor for class org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
-
- Export - Class in org.apache.hadoop.hbase.mapreduce
-
Export an HBase table.
- Export() - Constructor for class org.apache.hadoop.hbase.mapreduce.Export
-
- ExportSnapshot - Class in org.apache.hadoop.hbase.snapshot
-
Export the specified snapshot to a given FileSystem.
- ExportSnapshot() - Constructor for class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- ExportSnapshotException - Exception in org.apache.hadoop.hbase.snapshot
-
Thrown when a snapshot could not be exported due to an error during the operation.
- ExportSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.ExportSnapshotException
-
- ExportSnapshotException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.snapshot.ExportSnapshotException
-
- extendLimit(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
- extractArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- extractFilterSimpleExpression(byte[], int) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Extracts a simple filter expression from the filter string given by the user
- extractKeyValues(Result) - Method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
-
Extract columns values from the current record.
- extractKeyValues(Result) - Method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
Extract columns values from the current record.
- extraHeapSize() - Method in class org.apache.hadoop.hbase.client.Append
-
- extraHeapSize() - Method in class org.apache.hadoop.hbase.client.Increment
-
- extraHeapSize() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Subclasses should override this method to add the heap size of their own fields.
- get(Get) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Extracts certain cells from a given row.
- get(List<Get>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Extracts certain cells from the given rows, in batch.
- 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(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.client.Get
-
Create a Get operation for the specified row.
- Get(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.client.Get
-
Create a Get operation for the specified row.
- get(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Returns a list of all KeyValue objects with matching column family and qualifier.
- get(Get) - Method in interface org.apache.hadoop.hbase.client.Table
-
Extracts certain cells from a given row.
- get(List<Get>) - Method in interface org.apache.hadoop.hbase.client.Table
-
Extracts specified cells from the given rows, as a batch.
- get() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Get the data from the BytesWritable.
- get(String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a GET request
- get(Cluster, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a GET request
- get(String, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a GET request
- get(Cluster, String, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a GET request
- get(String, Header[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a GET request
- get(Cluster, String, Header[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a GET request
- get() - Method in class org.apache.hadoop.hbase.Size
-
get the value
- get(Size.Unit) - Method in class org.apache.hadoop.hbase.Size
-
get the value which is converted to specified unit.
- get(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Retrieve the byte at index
.
- get(int, byte[]) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Fill dst
with bytes from the range, starting from index
.
- get(int, byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Fill dst
with bytes from the range, starting from index
.
- get() - Method in class org.apache.hadoop.hbase.util.Bytes
-
Get the data from the Bytes.
- get() - Method in class org.apache.hadoop.hbase.util.Counter
-
Deprecated.
- get() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Retrieve the next byte from this range.
- get(byte[]) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Fill dst
with bytes from the range, starting from position
.
- get(byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Fill dst
with bytes from the range, starting from the current
position
.
- get(int, byte[]) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- get(int, byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- get(int, byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- get(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- get(int, byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
- get(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
- getACL() - Method in class org.apache.hadoop.hbase.client.Mutation
-
- getACL() - Method in class org.apache.hadoop.hbase.client.Query
-
- getActiveMaster() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Gets the current active master, if available.
- getAddress() - Method in class org.apache.hadoop.hbase.ServerName
-
- getAddress() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- getAdmin() - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Retrieve an
AsyncAdmin
implementation to administer an HBase cluster.
- getAdmin(ExecutorService) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Retrieve an
AsyncAdmin
implementation to administer an HBase cluster.
- getAdmin() - Method in interface org.apache.hadoop.hbase.client.Connection
-
Retrieve an Admin implementation to administer an HBase cluster.
- getAdmin() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Allows subclasses to get the
Admin
.
- getAdminBuilder() - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
- getAdminBuilder(ExecutorService) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
- getAgeOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSink
-
- getAgeOfLastShippedOp() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- getAliasPassword(String) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
-
- getAll(List<Get>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
A simple version for batch get.
- getAllFilters() - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Returns all known filters
- getAllowPartialResults() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getAllRegionLocations() - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Retrieves all of the regions associated with this table.
- getAllRegionLocations() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Retrieves all of the regions associated with this table.
- getAlterStatus(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- getAlterStatus(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- 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
-
- getAuthChore(Configuration) - Static method in class org.apache.hadoop.hbase.AuthUtil
-
- getAuthorizations() - Method in class org.apache.hadoop.hbase.client.Query
-
- getAuthRenewalChore(UserGroupInformation) - Static method in class org.apache.hadoop.hbase.AuthUtil
-
Deprecated.
Checks if security is enabled and if so, launches chore for refreshing kerberos ticket.
- getAverageLatencyForEachRegionServer() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
Deprecated.
- getAverageLoad() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
- 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.ExponentialClientBackoffPolicy
-
- getBackupMasterNames() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
- getBackupMasterNames() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
Deprecated.
- getBackupMasters() - Method in interface org.apache.hadoop.hbase.client.Admin
-
- getBackupMasters() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
- getBackupMasters() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getBackupMastersSize() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getBackupZooKeeperServerNum() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- getBadLineCount() - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
-
- getBadLineCount() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
- getBadLineCount() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
-
- getBalancerOn() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
- getBalancerOn() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
Deprecated.
- getBandwidth() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getBatch() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getBlocksize() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- getBlocksize() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getBlockSize() - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
-
Get the cipher's internal block size
- getBlockSize() - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
-
Get the cipher's internal block size
- getBloomFilterSize() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- getBloomFilterSize() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
- getBloomFilterType() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- getBloomFilterType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getBody() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- getBufferedCounterForEachRegionServer() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
Deprecated.
- getBufferedMutator(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
- getBufferedMutator(TableName, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
- getBufferedMutator(TableName) - Method in interface org.apache.hadoop.hbase.client.Connection
-
- getBufferedMutator(BufferedMutatorParams) - Method in interface org.apache.hadoop.hbase.client.Connection
-
- getBufferedMutatorBuilder(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
- getBufferedMutatorBuilder(TableName, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
- getByteBuffer() - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
-
This flips the underlying BB so be sure to use it _last_!
- getBytes() - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
The underlying byte[].
- getBytes(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Returns a new byte array, copied from the given buf
,
from the position (inclusive) to the limit (exclusive).
- 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
-
- getCause(int) - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getCauses() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getCellKeyAsString(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- getCellKeyAsString(Cell, Function<Cell, String>) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- getCellKeySerializedAsKeyValueKey(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- getCellVisibility() - Method in class org.apache.hadoop.hbase.client.Mutation
-
- getChance() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
- getCipher(String) - Method in interface org.apache.hadoop.hbase.io.crypto.CipherProvider
-
Get an Cipher
- getCipher() - Method in class org.apache.hadoop.hbase.io.crypto.Context
-
- getCipher(String) - Method in class org.apache.hadoop.hbase.io.crypto.CryptoCipherProvider
-
- getCipher(String) - Method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
-
- getCipher(Configuration, String) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Get an cipher given a name
- getCipherProvider(Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
- getClassName() - Method in interface org.apache.hadoop.hbase.client.CoprocessorDescriptor
-
- getClientMetrics() - Method in interface org.apache.hadoop.hbase.UserMetrics
-
- getClientPort() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- getClientPortList() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
Get the list of client ports.
- getCluster() - Method in class org.apache.hadoop.hbase.rest.client.Client
-
- getClusterId() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
- getClusterId() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
Deprecated.
- getClusterIds() - Method in class org.apache.hadoop.hbase.client.Mutation
-
- getClusterKey() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getClusterMetrics() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get whole cluster metrics, containing status about:
- getClusterMetrics(EnumSet<ClusterMetrics.Option>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get cluster status with a set of ClusterMetrics.Option
to get desired status.
- getClusterMetrics() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
- getClusterMetrics(EnumSet<ClusterMetrics.Option>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
- getClusterStatus() - Method in interface org.apache.hadoop.hbase.client.Admin
-
- getCode() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- getColumnCells(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Return the Cells for the specific column.
- getColumnFamilies() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
- getColumnFamilies() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- getColumnFamily(byte[]) - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Returns the ColumnDescriptor for a specific column family with name as
specified by the parameter column.
- getColumnFamily(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- getColumnFamilyCount() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Returns the count of the column families of the table.
- getColumnFamilyCount() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Returns the count of the column families of the table.
- getColumnFamilyMap() - Method in class org.apache.hadoop.hbase.client.replication.TableCFs
-
- getColumnFamilyNames() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Returns all the column family names of the current table.
- getColumnFamilyNames() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- getColumnFamilyTimeRange() - Method in class org.apache.hadoop.hbase.client.Query
-
- 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
-
- getCompactedCellCount() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- getCompactedCellCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
- getCompactingCellCount() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- getCompactingCellCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
- getCompactionCompression() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getCompactionCompressionType() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- getCompactionCompressionType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getCompactionPressure() - Method in class org.apache.hadoop.hbase.client.RegionLoadStats
-
- getCompactionState(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the current compaction state of a table.
- getCompactionState(TableName, CompactType) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the current compaction state of a table.
- getCompactionState(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the current compaction state of a table.
- getCompactionState(TableName, CompactType) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the current compaction state of a table.
- getCompactionStateForRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the current compaction state of region.
- getCompactionStateForRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the current compaction state of region.
- getComparator(Comparator<ColumnFamilyDescriptor>) - Static method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
- getComparator() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
-
- 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
-
- getCompareOperator() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
-
- getCompareOperator() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- getCompareOperator() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- getComparisonData() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
-
- getCompletedSequenceId() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- getCompletedSequenceId() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
This does not really belong inside RegionLoad but its being done in the name of expediency.
- getCompleteSequenceId() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getCompression() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getCompressionType() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- getCompressionType() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- getCompressionType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getConf() - Method in class org.apache.hadoop.hbase.io.crypto.Context
-
- getConf() - Method in class org.apache.hadoop.hbase.io.crypto.CryptoCipherProvider
-
- getConf() - Method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
-
- getConf() - Method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
Returns the current configuration.
- getConf() - Method in class org.apache.hadoop.hbase.mapreduce.HRegionPartitioner
-
Returns the current configuration.
- getConf() - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormat
-
Returns the current configuration.
- getConf() - Method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
- getConf() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Returns the current configuration.
- getConf() - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.Admin
-
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutator
-
Returns the Configuration
object used by this instance.
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Returns the Configuration
object used by this instance.
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Returns the Configuration
object used by this instance.
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
Returns the Configuration
object used by this instance.
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.Connection
-
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.Table
-
Returns the Configuration
object used by this instance.
- getConfiguration() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getConfiguration() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Getter for fetching an unmodifiable map.
- getConfiguration() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getConfigurationValue(String) - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- getConfigurationValue(String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getConfigurationValue(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Getter for accessing the configuration value by key
- getConfigurationValue(String) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
-
Getter for accessing the configuration value by key
- getConnection() - Method in interface org.apache.hadoop.hbase.client.Admin
-
- getConsistency() - Method in class org.apache.hadoop.hbase.client.Query
-
Returns the consistency level for this operation
- getCoprocessorDescriptors() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Return the list of attached co-processor represented
- getCoprocessorDescriptors() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- getCoprocessorNames() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
- getCoprocessorNames() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Return the RegionServer-level and Region-level coprocessors
- getCoprocessors() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
- getCreationTime() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
-
- getCurrent() - Static method in class org.apache.hadoop.hbase.security.User
-
Returns the User
instance within current execution context.
- getCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getCurrentKey() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
Returns the current key.
- getCurrentKey() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
Returns the current key.
- getCurrentSpaceQuotaSnapshot(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Returns the Master's view of a quota on the given namespace
or null if the Master has
no quota information on that namespace.
- getCurrentSpaceQuotaSnapshot(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Returns the Master's view of a quota on the given tableName
or null if the Master has
no quota information on that table.
- getCurrentSpaceQuotaSnapshot(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Returns the Master's view of a quota on the given namespace
or null if the Master has
no quota information on that namespace.
- getCurrentSpaceQuotaSnapshot(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Returns the Master's view of a quota on the given tableName
or null if the Master has
no quota information on that table.
- getCurrentValue() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
Returns the current value.
- getCurrentValue() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
Returns the current value.
- getCursor() - Method in class org.apache.hadoop.hbase.client.Result
-
Return the cursor if this Result is a cursor result.
- getDataBlockEncoderById(short) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Find and create data block encoder for given id;
- getDataBlockEncoding() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getDataLocality() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- getDataLocality() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
- getDate() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
The date that hbase was compiled.
- getDeadServerNames() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
- getDeadServerNames() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
Deprecated.
- getDeadServers() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getDeadServersSize() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getDecryptor() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Return a decryptor for decrypting data.
- getDefaultValues() - Static method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- getDefaultValues() - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getDelegateeForModification() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getDelegateeForModification() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- 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
-
- getDescriptiveNameFromRegionStateForDisplay(RegionState, Configuration) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- getDescriptor(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get a table descriptor.
- getDescriptor(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Method for getting the tableDescriptor
- getDescriptor() - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
- getDescriptor() - Method in interface org.apache.hadoop.hbase.client.Table
-
- getDeserializer(Class<Cell>) - Method in class org.apache.hadoop.hbase.mapreduce.CellSerialization
-
- getDeserializer(Class<KeyValue>) - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization
-
Deprecated.
- getDeserializer(Class<Mutation>) - Method in class org.apache.hadoop.hbase.mapreduce.MutationSerialization
-
- getDeserializer(Class<Result>) - Method in class org.apache.hadoop.hbase.mapreduce.ResultSerialization
-
- getDFSReplication() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- getDFSReplication() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- 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 interface org.apache.hadoop.hbase.client.TableDescriptor
-
Returns the durability setting for the table.
- getDurability() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Returns the durability setting for the table.
- getEditsRead() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- getEncodedName() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
- getEncodedName() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
- getEncodedNameAsBytes() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
- getEncodedNameAsBytes() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
- getEncodedRegionName() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the region's encoded name.
- getEncoder() - Method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Return new data block encoder for given algorithm type.
- getEncodingById(short) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
- getEncryptionKey() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- getEncryptionKey() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getEncryptionType() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- getEncryptionType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getEncryptor() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Get an encryptor for encrypting data.
- getEnd() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
-
- getEndKey() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
- getEndKey() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
- getEndKeyForDisplay(HRegionInfo, Configuration) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- getEndKeys() - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Gets the ending row key for every region in the currently open table.
- getEndKeys() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Gets the ending row key for every region in the currently open table.
- getEndRow() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
- getEndRow() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the end row.
- getEvictedBlocks() - Method in class org.apache.hadoop.hbase.CacheEvictionStats
-
- getExceptionCount() - Method in class org.apache.hadoop.hbase.CacheEvictionStats
-
- getExceptions() - Method in class org.apache.hadoop.hbase.CacheEvictionStats
-
- getExcludeNamespaces() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getExcludeTableCFsMap() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getExhaustiveDescription() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getExists() - Method in class org.apache.hadoop.hbase.client.Result
-
- getExtraHeader(String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Get an extra header value.
- getExtraHeaders() - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Get all extra headers (read-only).
- getFailedCounterForEachRegionServer() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
Deprecated.
- getFailureCount() - Method in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
-
Deprecated.
- getFamilies() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getFamilies() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- getFamiliesKeys() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- getFamily() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
-
- 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
-
- getFamilyArray() - Method in interface org.apache.hadoop.hbase.Cell
-
Contiguous bytes composed of legal HDFS filename characters which may start at any index in the
containing array.
- getFamilyCellMap() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Method for retrieving the put's familyMap
- getFamilyLength() - Method in interface org.apache.hadoop.hbase.Cell
-
- getFamilyMap() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the get's familyMap
- 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.
- getFamilyOffset() - Method in interface org.apache.hadoop.hbase.Cell
-
- 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
- getFilteredReadRequestCount() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- getFilteredReadRequestCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
- getFilteredReadRequests() - Method in interface org.apache.hadoop.hbase.UserMetrics
-
- getFilteredReadRequestsCount() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getFilteredReadRequestsCount() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- 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.
- getFirst() - Method in class org.apache.hadoop.hbase.util.Pair
-
Return the first element stored in the pair.
- getFirst() - Method in class org.apache.hadoop.hbase.util.PairOfSameType
-
Return the first element stored in the pair.
- getFirstFailureAt() - Method in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
-
Deprecated.
- getFlushPolicyClassName() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
This gets the class associated with the flush policy which determines the
stores need to be flushed when flushing a region.
- getFlushPolicyClassName() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
This gets the class associated with the flush policy which determines the stores need to be
flushed when flushing a region.
- getGroupName(String) - Static method in class org.apache.hadoop.hbase.AuthUtil
-
Deprecated.
Returns the actual name for a group principal (stripped of the
group prefix).
- getGroupNames() - Method in class org.apache.hadoop.hbase.security.User
-
Returns the list of groups of which this user is a member.
- getHBaseVersion() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
- getHBaseVersion() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
Deprecated.
- getHbck() - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Retrieve an Hbck implementation to fix an HBase cluster.
- getHbck(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Retrieve an Hbck implementation to fix an HBase cluster.
- getHbck() - Method in interface org.apache.hadoop.hbase.client.Connection
-
Retrieve an Hbck implementation to fix an HBase cluster.
- getHbck(ServerName) - Method in interface org.apache.hadoop.hbase.client.Connection
-
Retrieve an Hbck implementation to fix an HBase cluster.
- getHeader(String) - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- getHeaders() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- getHeapOccupancy() - Method in class org.apache.hadoop.hbase.client.RegionLoadStats
-
- getHostAndPort() - Method in class org.apache.hadoop.hbase.ServerName
-
- 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.net.Address
-
- getHostname() - Method in class org.apache.hadoop.hbase.ServerName
-
- getHostnameLowerCase() - 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
-
- getHTableMultiplexerStatus() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
-
Deprecated.
- getHttpClient() - Method in class org.apache.hadoop.hbase.rest.client.Client
-
- 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 enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
- getImplementationClassName() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- getInfoServerPort() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
- getInfoServerPort() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
- getInitialDelay() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
- getInMemoryCompaction() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- getInMemoryCompaction() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getInstance() - Static method in interface org.apache.hadoop.hbase.CellComparator
-
A comparator for ordering cells in user-space tables.
- getInstance() - Static method in class org.apache.hadoop.hbase.io.crypto.CryptoCipherProvider
-
- getInstance() - Static method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
-
- getInt(Configuration, String, String, int) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
- getInt(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Retrieve the int value at index
- getInt() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Retrieve the next int value from this range.
- getIsolationLevel() - Method in class org.apache.hadoop.hbase.client.Query
-
- getIv() - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
-
Get the initialization vector
- getIvLength() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Return the expected initialization vector length, in bytes, or 0 if not applicable
- getIvLength() - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
-
Get the expected length for the initialization vector
- getIvLength() - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
-
Get the expected length for the initialization vector
- getJarPath() - Method in interface org.apache.hadoop.hbase.client.CoprocessorDescriptor
-
- getKeepDeletedCells() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- getKeepDeletedCells() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getKey() - Method in class org.apache.hadoop.hbase.io.crypto.Context
-
- getKey(String) - Method in interface org.apache.hadoop.hbase.io.crypto.KeyProvider
-
Retrieve the key for a given key aliase
- getKey(String) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
-
- getKeyBytes() - Method in class org.apache.hadoop.hbase.io.crypto.Context
-
- getKeyBytesHash() - Method in class org.apache.hadoop.hbase.io.crypto.Context
-
- getKeyFormat() - Method in class org.apache.hadoop.hbase.io.crypto.Context
-
- getKeyLength() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Return the key length required by this cipher, in bytes
- getKeyProvider(Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
- getKeys(String[]) - Method in interface org.apache.hadoop.hbase.io.crypto.KeyProvider
-
Retrieve keys for a given set of key aliases
- getKeys(String[]) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
-
- getKeyValues(Configuration, String) - Static method in class org.apache.hadoop.hbase.util.ConfigurationUtil
-
Retrieve a list of key value pairs from configuration, stored under the provided key
- getKeyValues(Configuration, String, char) - Static method in class org.apache.hadoop.hbase.util.ConfigurationUtil
-
Retrieve a list of key value pairs from configuration, stored under the provided key
- getLastAttemptAt() - Method in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
-
Deprecated.
- getLastMajorCompactionTimestamp(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the timestamp of the last major compaction for the passed table
The timestamp of the oldest HFile resulting from a major compaction of that table,
or 0 if no such HFile could be found.
- getLastMajorCompactionTimestamp(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the timestamp of the last major compaction for the passed table.
- getLastMajorCompactionTimestamp(TableName) - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
- getLastMajorCompactionTimestamp(byte[]) - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
- getLastMajorCompactionTimestamp() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- getLastMajorCompactionTimestamp() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
- getLastMajorCompactionTimestampForRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the timestamp of the last major compaction for the passed region.
- getLastMajorCompactionTimestampForRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the timestamp of the last major compaction for the passed region.
- getLastMajorCompactionTs() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getLastMajorCompactionTsForRegion(byte[]) - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getLastMajorCompactionTsForTable(TableName) - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getLastReportTimestamp() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
- getLastReportTimestamp() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
- getLatestVersionOnly() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Get whether only the latest version of the column value should be compared.
- getLength() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
- getLength() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
- getLength() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the length of the split.
- getLength() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
-
Retrieve the maximum length (in bytes) of encoded values.
- getLength() - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
The length of the range.
- getLength() - Method in class org.apache.hadoop.hbase.util.Bytes
-
- getLimit() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getLimit() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
- getLimit() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- getLimit() - Method in interface org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView
-
Returns the limit, in bytes, of the target (e.g.
- getLimit() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Return the current limit
- getListener() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- getLiveMasters() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- getLiveRegionServers() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- getLiveServerMetrics() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
- getLiveServerMetrics() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
Deprecated.
- getLoad(ServerName) - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getLoad() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getLoadColumnFamiliesOnDemandValue() - Method in class org.apache.hadoop.hbase.client.Query
-
Get the raw loadColumnFamiliesOnDemand setting; if it's not set, can be null.
- getLocation() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- getLocations() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
- getLocations() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the region's location as an array.
- getLocks() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get locks.
- getLocks() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
List locks.
- getLong(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Retrieve the long value at index
- getLong() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Retrieve the next long value from this range.
- getLongValue() - Method in class org.apache.hadoop.hbase.Size
-
get the value
- getMajorVersion(String) - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
- 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.Admin
-
- getMaster() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
- getMaster() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getMaster(int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- getMasterCoprocessorNames() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Helper that delegates to getClusterMetrics().getMasterCoprocessorNames().
- getMasterCoprocessorNames() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
- getMasterCoprocessorNames() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
- getMasterCoprocessorNames() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
Deprecated.
- getMasterCoprocessors() - Method in interface org.apache.hadoop.hbase.client.Admin
-
- getMasterCoprocessors() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getMasterInfoPort() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the info port of the current master if one is available.
- getMasterInfoPort() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the info port of the current master if one is available.
- getMasterInfoPort() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
- getMasterInfoPort() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
Deprecated.
- getMasterName() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
Returns detailed information about the current master
ServerName
.
- getMasterName() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
Deprecated.
- getMasters() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- getMax() - Method in class org.apache.hadoop.hbase.io.TimeRange
-
- getMaxAllowedOperationTime() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
-
- getMaxCacheSize() - Method in class org.apache.hadoop.hbase.CacheEvictionStats
-
- getMaxColumn() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- getMaxColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- getMaxCompactedStoreFileRefCount() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- getMaxCompactedStoreFileRefCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
- getMaxFileSize() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Returns the maximum size upto which a region can grow to after which a
region split is triggered.
- getMaxFileSize() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
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
-
- getMaxHeapSize() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
- getMaxHeapSize() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
- getMaxKeyValueSize() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- getMaxLatency() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
Deprecated.
- getMaxLatencyForEachRegionServer() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
Deprecated.
- getMaxPriority() - Method in class org.apache.hadoop.hbase.client.RowMutations
-
- 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
-
- getMaxVersions() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- 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
-
Deprecated.
- getMD5AsHex(byte[]) - Static method in class org.apache.hadoop.hbase.util.MD5Hash
-
Given a byte array, returns in MD5 hash as a hex string.
- getMD5AsHex(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.MD5Hash
-
Given a byte array, returns its MD5 hash as a hex string.
- getMemStoreFlushSize() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Returns the size of the memstore after which a flush to filesystem is
triggered.
- getMemStoreFlushSize() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Returns the size of the memstore after which a flush to filesystem is triggered.
- getMemstoreLoad() - Method in class org.apache.hadoop.hbase.client.RegionLoadStats
-
- getMemStoreLoad() - Method in class org.apache.hadoop.hbase.client.RegionLoadStats
-
- getMemStoreSize() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- getMemStoreSize() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
- getMemstoreSizeInMB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getMemStoreSizeMB() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getMemStoreSizeMB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getMessage() - Method in exception org.apache.hadoop.hbase.quotas.SpaceLimitingException
-
- getMin() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
Gets the minimum timestamp requested by filter.
- getMin() - Method in class org.apache.hadoop.hbase.io.TimeRange
-
- getMinColumn() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- getMinColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- getMinVersions() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- getMinVersions() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getMobCompactPartitionPolicy() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Get the mob compact partition policy for this family
- getMobCompactPartitionPolicy() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getMobThreshold() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Gets the mob threshold of the family.
- getMobThreshold() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getMutations() - Method in class org.apache.hadoop.hbase.client.RowMutations
-
- getName() - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutator
-
Gets the fully qualified table name instance of the table that this
AsyncBufferedMutator
writes to.
- getName() - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Gets the fully qualified table name instance of this table.
- getName() - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Gets the fully qualified table name instance of the table whose region we want to locate.
- getName() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
Gets the fully qualified table name instance of the table that this BufferedMutator writes to.
- getName() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- getName() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Gets the fully qualified table name instance of this table.
- getName() - Method in enum org.apache.hadoop.hbase.client.security.SecurityCapability
-
- getName() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
-
- getName() - Method in interface org.apache.hadoop.hbase.client.Table
-
Gets the fully qualified table name instance of this table.
- getName() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getName() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Return this Cipher's name
- getName() - Method in interface org.apache.hadoop.hbase.io.crypto.CipherProvider
-
Return the provider's name
- getName() - Method in class org.apache.hadoop.hbase.io.crypto.CryptoCipherProvider
-
- getName() - Method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
-
- getName() - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- getName() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getName() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
Get group name.
- getName() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
- getName() - Method in class org.apache.hadoop.hbase.security.User
-
Returns the full user name.
- getName() - Method in class org.apache.hadoop.hbase.TableName
-
- getNameAsString() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- getNameAsString() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- getNameAsString() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getNameAsString() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Get the name of the table as a String
- getNameAsString() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
- getNameAsString() - Method in class org.apache.hadoop.hbase.TableName
-
- getNameAsString() - Method in interface org.apache.hadoop.hbase.UserMetrics
-
- getNameFromId(short) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Find and return the name of data block encoder for the given id.
- getNameInBytes() - Method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
- getNamespace() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
-
- getNamespace() - Method in class org.apache.hadoop.hbase.TableName
-
- getNamespaceAsString() - Method in class org.apache.hadoop.hbase.TableName
-
- getNamespaceDescriptor(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get a namespace descriptor by name.
- getNamespaceDescriptor(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get a namespace descriptor by name
- getNamespaceFilter() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
- getNamespaces() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getNameWithNamespaceInclAsString() - Method in class org.apache.hadoop.hbase.TableName
-
Ideally, getNameAsString should contain namespace within it,
but if the namespace is default, it just returns the 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.FilterList
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
Pick the next cell that the scanner should seek to.
- getNormalizerTargetRegionCount() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Check if there is the target region count.
- getNormalizerTargetRegionCount() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- getNormalizerTargetRegionSize() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Check if there is the target region size.
- getNormalizerTargetRegionSize() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- getNoVersionMap() - Method in class org.apache.hadoop.hbase.client.Result
-
Map of families to their most recent qualifiers and values.
- getNumberOfRegions() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getNumberOfRequests() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getNumberOfTasksInProgress() - Method in interface org.apache.hadoop.hbase.client.RequestController
-
- getNumExceptions() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getOffset() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- getOffset() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
- getOffset() - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
The offset, the index into the underlying byte[] at which this range
begins.
- getOffset() - Method in class org.apache.hadoop.hbase.util.Bytes
-
- getOnlineRegions(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- getOperationTimeout() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Return the operation timeout for a rpc call.
- getOperationTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Get timeout of each operation in Table instance.
- getOperationTimeout() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- getOperationTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.Table
-
Get timeout of each operation in Table instance.
- getOperationTimeout() - Method in interface org.apache.hadoop.hbase.client.Table
-
- 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
-
- getOPsShipped() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- getOrder() - Method in interface org.apache.hadoop.hbase.types.DataType
-
Retrieve the sort
Order
imposed by this data type, or null when
natural ordering is not preserved.
- getOrder() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.OrderedBytesBase
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.PBType
-
Deprecated.
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawByte
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawBytes
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawDouble
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawFloat
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawInteger
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawLong
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawShort
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawString
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.Struct
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.Union2
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.Union3
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.Union4
-
- getOutputCommitter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
-
- getOutputCommitter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
Returns the output committer.
- getOverallAverageLatency() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
Deprecated.
- getOwner() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
-
- getOwnerString() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
- getOwnerString() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- getPageSize() - Method in class org.apache.hadoop.hbase.filter.PageFilter
-
- getPartition(ImmutableBytesWritable, V2, int) - Method in class org.apache.hadoop.hbase.mapred.HRegionPartitioner
-
- getPartition(ImmutableBytesWritable, VALUE, int) - Method in class org.apache.hadoop.hbase.mapreduce.HRegionPartitioner
-
Gets the partition number for a given key (hence record) given the total
number of partitions i.e.
- getPartition(ImmutableBytesWritable, VALUE, int) - Method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
- getPassword(Configuration, String, String) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
Get the password from the Configuration instance using the
getPassword method if it exists.
- getPeerConfig(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- getPeerConfig() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerDescription
-
- getPeerData() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getPeerID() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- getPeerId() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerDescription
-
- getPeersCount() - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Deprecated.
- getPeerState(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Deprecated.
- getPeerTableCFs(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- getPeriod() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
- getPeriodicalFlushTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutator
-
Returns the periodical flush interval, 0 means disabled.
- getPolicy() - Method in interface org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView.SpaceQuotaStatusView
-
Returns the violation policy, which may not be presented.
- getPool() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- 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.net.Address
-
- getPort() - Method in class org.apache.hadoop.hbase.ServerName
-
- getPos() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- getPos() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- getPosition() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
The current position
marker.
- 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.client.CoprocessorDescriptor
-
- getPriority() - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
- getPriority() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
- getPriority() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- getProcedures() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get procedures.
- getProcedures() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
List procedures
- getProgress() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- getProgress() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- getProgress() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
The current progress of the record reader through its data.
- getProgress() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
The current progress of the record reader through its data.
- getProperties() - Method in interface org.apache.hadoop.hbase.client.CoprocessorDescriptor
-
- getProtocol() - Method in exception org.apache.hadoop.hbase.exceptions.UnknownProtocolException
-
- getProvider() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Return the provider for this Cipher
- getQualifier() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
-
- 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.TableName
-
- getQualifierArray() - Method in interface org.apache.hadoop.hbase.Cell
-
Contiguous raw bytes that may start at any index in the containing array.
- getQualifierAsString() - Method in class org.apache.hadoop.hbase.TableName
-
- getQualifierBufferShallowCopy(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- getQualifierLength() - Method in interface org.apache.hadoop.hbase.Cell
-
- getQualifierOffset() - Method in interface org.apache.hadoop.hbase.Cell
-
- getQueueId() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- getQuota(QuotaFilter) - Method in interface org.apache.hadoop.hbase.client.Admin
-
List the quotas based on the filter.
- getQuota(QuotaFilter) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
List the quotas based on the filter.
- getQuotaRetriever(QuotaFilter) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- getQuotaStatus() - Method in interface org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView
-
Returns the status of the quota.
- getQuotaType() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
-
- getRandomKey() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Create a random symmetric key
- getReadRequestCount() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- getReadRequestCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
- getReadRequestCount() - Method in interface org.apache.hadoop.hbase.UserMetrics
-
- getReadRequestsCount() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getReadRequestsCount() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getReadRpcTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Get timeout of each rpc read request in this Table instance.
- getReadRpcTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.Table
-
Get timeout of each rpc read request in this Table instance.
- getReadRpcTimeout() - Method in interface org.apache.hadoop.hbase.client.Table
-
- getReadType() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hbase.mapred.MultiTableSnapshotInputFormat
-
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
Builds a TableRecordReader.
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat
-
- getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat
-
Creates a new record writer.
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
-
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
Creates a new record writer.
- getRegion() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- getRegionCount() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
- getRegionId() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
- getRegionId() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
- getRegionInfo() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- getRegionLocation(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Finds the region on which the given row is being served.
- getRegionLocation(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Finds the region on which the given row is being served.
- getRegionLocation(byte[], int) - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Finds the region with the given replicaId
on which the given row is being served.
- getRegionLocation(byte[], int, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Finds the region with the given replicaId
on which the given row is being served.
- getRegionLocation(byte[]) - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Finds the region on which the given row is being served.
- getRegionLocation(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Finds the region on which the given row is being served.
- getRegionLocation(byte[], int) - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Finds the region with the given replica id on which the given row is being served.
- getRegionLocation(byte[], int, boolean) - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Finds the region with the given replica id on which the given row is being served.
- getRegionLocation() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
- getRegionLocation() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the region location.
- getRegionLocations(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Find all the replicas for the region on which the given row is being served.
- getRegionLocations(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Find all the replicas for the region on which the given row is being served.
- getRegionLocations(byte[]) - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Find all the replicas for the region on which the given row is being served.
- getRegionLocations(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Find all the replicas for the region on which the given row is being served.
- getRegionLocator(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Retrieve a AsyncRegionLocator implementation to inspect region information on a table.
- getRegionLocator() - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
- getRegionLocator(TableName) - Method in interface org.apache.hadoop.hbase.client.Connection
-
Retrieve a RegionLocator implementation to inspect region information on a table.
- getRegionLocator() - Method in interface org.apache.hadoop.hbase.client.Table
-
- getRegionLocator() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- getRegionMetrics(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- getRegionMetrics(ServerName, TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get
RegionMetrics
of all regions hosted on a regionserver for a table.
- getRegionMetrics(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get a list of
RegionMetrics
of all regions hosted on a region seerver.
- getRegionMetrics(ServerName, TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get a list of
RegionMetrics
of all regions hosted on a region seerver for a table.
- getRegionMetrics() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
- getRegionMetrics() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
- getRegionName() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
- getRegionName() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
- getRegionName() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- getRegionName() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
- getRegionNameAsString() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
- getRegionNameAsString(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
- getRegionNameAsString(RegionInfo, byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
- getRegionNameAsString() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
- getRegionNameAsStringForDisplay(HRegionInfo, Configuration) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- getRegionNameForDisplay(HRegionInfo, Configuration) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- getRegionReplication() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
- getRegionReplication() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Returns the configured replicas per region
- getRegions(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get all the online regions on a region server.
- getRegions(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the regions of a given table.
- getRegions(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get all the online regions on a region server.
- getRegions(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the regions of a given table.
- getRegionsCount() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getRegionServer(int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- getRegionServer() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
-
- getRegionServerCoprocessors() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getRegionServerFilter() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
- getRegionServers() - Method in interface org.apache.hadoop.hbase.client.Admin
-
- getRegionServers(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Retrieve all current live region servers including decommissioned
if excludeDecommissionedRS is false, else non-decommissioned ones only
- getRegionServers() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
- getRegionServers() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- getRegionServerSpaceQuotaSnapshots(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- getRegionServerSpaceQuotaSnapshots(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
- getRegionsLoad() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getRegionSplitPolicyClassName() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
This gets the class associated with the region split policy which
determines when a region split should occur.
- getRegionSplitPolicyClassName() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
This gets the class associated with the region split policy which
determines when a region split should occur.
- getRegionStatesInTransition() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
- getRegionStatesInTransition() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
Deprecated.
- getRemaining() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
The number of bytes remaining between position and the end of the range.
- getReplicaId() - Method in class org.apache.hadoop.hbase.client.Query
-
Returns region replica id where Query will fetch data from.
- getReplicaId() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
- getReplicaId() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
Returns the region replica id
- getReplicationEndpointImpl() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getReplicationLag() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- getReplicationLoadSink() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
Call directly from client such as hbase shell
- getReplicationLoadSink() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Call directly from client such as hbase shell
- getReplicationLoadSourceList() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
Call directly from client such as hbase shell
- getReplicationLoadSourceList() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Call directly from client such as hbase shell
- getReplicationLoadSourceMap() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
Call directly from client such as hbase shell
- getReplicationLoadSourceMap() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Call directly from client such as hbase shell
- getReplicationPeerConfig(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Returns the configured ReplicationPeerConfig for the specified peer.
- getReplicationPeerConfig(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Returns the configured ReplicationPeerConfig for the specified peer
- getReportTime() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getReportTimestamp() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
- getReportTimestamp() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
- getRequestCount() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
- getRequestCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
- getRequestCount() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
- getRequestCount() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
- getRequestCount() - Method in interface org.apache.hadoop.hbase.UserMetrics
-
- getRequestCountPerSecond() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
- getRequestCountPerSecond() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
- 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
-
- getResponseBody(HttpResponse) - Static method in class org.apache.hadoop.hbase.rest.client.Client
-
Returns the response body of the HTTPResponse, if any, as an array of bytes.
- getRevision() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
Get the subversion revision number for the root directory
- 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.Cursor
-
- 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.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
-
- getRowArray() - Method in interface org.apache.hadoop.hbase.Cell
-
Contiguous raw bytes that may start at any index in the containing array.
- getRowByte(Cell, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Deprecated.
- getRowLength() - Method in interface org.apache.hadoop.hbase.Cell
-
- getRowOffset() - Method in interface org.apache.hadoop.hbase.Cell
-
- 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)
- getRowRanges() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
-
- getRpcTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Get timeout of each rpc request in this Table instance.
- getRpcTimeout() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- getRpcTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.Table
-
Get timeout of each rpc request in this Table instance.
- getRpcTimeout() - Method in interface org.apache.hadoop.hbase.client.Table
-